A B C D E F G H I J K L M N O P R S T U V W X Z
All Classes All Packages
All Classes All Packages
All Classes All Packages
A
- AbsentBlockException - Exception in org.apache.nemo.runtime.common.exception
-
An exception which represents the requested block is neither AVAILABLE nor IN_PROGRESS.
- AbsentBlockException(String, BlockState.State) - Constructor for exception org.apache.nemo.runtime.common.exception.AbsentBlockException
- AbstractBlockStore - Class in org.apache.nemo.runtime.executor.data.stores
-
This abstract class represents a default
BlockStore
, which contains other components used in each implementation ofBlockStore
. - AbstractDoFnTransform<InputT,InterT,OutputT> - Class in org.apache.nemo.compiler.frontend.beam.transform
-
This is a base class for Beam DoFn Transforms.
- AbstractDoFnTransform(DoFn<InterT, OutputT>, Coder<InputT>, Map<TupleTag<?>, Coder<?>>, TupleTag<OutputT>, List<TupleTag<?>>, WindowingStrategy<?, ?>, Map<Integer, PCollectionView<?>>, PipelineOptions, DisplayData, DoFnSchemaInformation, Map<String, PCollectionView<?>>) - Constructor for class org.apache.nemo.compiler.frontend.beam.transform.AbstractDoFnTransform
-
AbstractDoFnTransform constructor.
- accumulate(int, Set<StageEdge>, Object) - Method in class org.apache.nemo.compiler.backend.nemo.NemoPlanRewriter
-
Accumulate the data needed in Plan Rewrite.
- accumulate(int, Set<StageEdge>, Object) - Method in interface org.apache.nemo.runtime.common.plan.PlanRewriter
- ActiveContextHandler() - Constructor for class org.apache.nemo.driver.NemoDriver.ActiveContextHandler
- addAllEntry(Iterable<? extends ControlMessage.RunTimePassMessageEntry>) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsg.Builder
-
repeated .protobuf.RunTimePassMessageEntry entry = 2;
- addAllMetric(Iterable<? extends ControlMessage.Metric>) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.MetricMsg.Builder
-
repeated .protobuf.Metric metric = 1;
- addCondition(Predicate<IRDAG>) - Method in class org.apache.nemo.common.pass.Pass
-
Add the condition to the existing condition to run the pass.
- addDAGDirectory(String) - Method in class org.apache.nemo.common.test.ArgBuilder
- addDagIncomingEdge(IREdge) - Method in class org.apache.nemo.common.ir.vertex.LoopVertex
-
Adds the incoming edge of the contained DAG.
- addDagOutgoingEdge(IREdge) - Method in class org.apache.nemo.common.ir.vertex.LoopVertex
-
Adds and outgoing edge of the contained DAG.
- addEntry(int, ControlMessage.RunTimePassMessageEntry) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsg.Builder
-
repeated .protobuf.RunTimePassMessageEntry entry = 2;
- addEntry(int, ControlMessage.RunTimePassMessageEntry.Builder) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsg.Builder
-
repeated .protobuf.RunTimePassMessageEntry entry = 2;
- addEntry(ControlMessage.RunTimePassMessageEntry) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsg.Builder
-
repeated .protobuf.RunTimePassMessageEntry entry = 2;
- addEntry(ControlMessage.RunTimePassMessageEntry.Builder) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsg.Builder
-
repeated .protobuf.RunTimePassMessageEntry entry = 2;
- addEntryBuilder() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsg.Builder
-
repeated .protobuf.RunTimePassMessageEntry entry = 2;
- addEntryBuilder(int) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsg.Builder
-
repeated .protobuf.RunTimePassMessageEntry entry = 2;
- addEvent(PlanState.State, PlanState.State) - Method in class org.apache.nemo.runtime.common.metric.JobMetric
- addEvent(StageState.State, StageState.State) - Method in class org.apache.nemo.runtime.common.metric.StageMetric
- addEvent(TaskState.State, TaskState.State) - Method in class org.apache.nemo.runtime.common.metric.TaskMetric
- addEvent(T, T) - Method in interface org.apache.nemo.runtime.common.metric.StateMetric
-
Add a
StateTransitionEvent
to the metric. - addIgnoredPropertyKey(Class<? extends VertexExecutionProperty>) - Method in class org.apache.nemo.runtime.common.plan.StagePartitioner
-
By default, the stage partitioner merges two vertices into one stage if and only if the two vertices have same set of
VertexExecutionProperty
. - addInput(AccumT, AccumT) - Method in class org.apache.nemo.compiler.frontend.beam.transform.FinalCombineFn
- addInput(AccumT, InputT) - Method in class org.apache.nemo.compiler.frontend.beam.transform.PartialCombineFn
- addInput(List<KV<int[], float[]>>, KV<int[], float[]>) - Method in class org.apache.nemo.examples.beam.AlternatingLeastSquare.TrainingDataCombiner
- addIterativeIncomingEdge(IREdge) - Method in class org.apache.nemo.common.ir.vertex.LoopVertex
-
Adds an iterative incoming edge, from the previous iteration, but connection internally.
- AdditionalOutputTagProperty - Class in org.apache.nemo.common.ir.edge.executionproperty
-
Additional Output Tag Execution Property for edge that contains tag for additional outputs.
- addJobId(String) - Method in class org.apache.nemo.common.test.ArgBuilder
- addMaxTaskAttempt(int) - Method in class org.apache.nemo.common.test.ArgBuilder
- addMetric(int, ControlMessage.Metric) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.MetricMsg.Builder
-
repeated .protobuf.Metric metric = 1;
- addMetric(int, ControlMessage.Metric.Builder) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.MetricMsg.Builder
-
repeated .protobuf.Metric metric = 1;
- addMetric(ControlMessage.Metric) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.MetricMsg.Builder
-
repeated .protobuf.Metric metric = 1;
- addMetric(ControlMessage.Metric.Builder) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.MetricMsg.Builder
-
repeated .protobuf.Metric metric = 1;
- addMetricBuilder() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.MetricMsg.Builder
-
repeated .protobuf.Metric metric = 1;
- addMetricBuilder(int) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.MetricMsg.Builder
-
repeated .protobuf.Metric metric = 1;
- addNonIterativeIncomingEdge(IREdge) - Method in class org.apache.nemo.common.ir.vertex.LoopVertex
-
Adds a non-iterative incoming edge, from outside the previous iteration.
- addOptimizationPolicy(String) - Method in class org.apache.nemo.common.test.ArgBuilder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsg.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsg.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptor.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessage.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ContainerFailedMsg.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DataCollectMessage.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessage.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ExecutorFailedMsg.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.InMasterBroadcastVariableMessage.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.LaunchDAGMessage.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Metric.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.MetricMsg.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.NotificationMessage.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeInitMessage.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeLocationInfoMessage.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptor.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBlockLocationMsg.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBroadcastVariableMessage.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestPipeLocationMessage.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageEntry.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsg.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ScheduleTaskMsg.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.nemo.runtime.common.comm.GrpcMessageService.Void.Builder
- addResourceJson(String) - Method in class org.apache.nemo.common.test.ArgBuilder
- addScheduler(String) - Method in class org.apache.nemo.common.test.ArgBuilder
- addSession(Session) - Method in class org.apache.nemo.runtime.master.metric.MetricBroadcaster
-
Add a session to the session list.
- addSideInputElement(PCollectionView<?>, WindowedValue<SideInputElement<?>>) - Method in class org.apache.nemo.compiler.frontend.beam.InMemorySideInputReader
-
Stores the side input in memory to be used with main inputs.
- addState(Enum, String) - Method in class org.apache.nemo.common.StateMachine.Builder
-
Adds a state with name and description.
- addTransition(Enum, Enum, String) - Method in class org.apache.nemo.common.StateMachine.Builder
-
Adds a transition with description.
- addUserArgs(String...) - Method in class org.apache.nemo.common.test.ArgBuilder
- addUserMain(String) - Method in class org.apache.nemo.common.test.ArgBuilder
- addVertex(V) - Method in class org.apache.nemo.common.dag.DAGBuilder
-
Add vertex to the builder.
- addVertex(V, Stack<LoopVertex>) - Method in class org.apache.nemo.common.dag.DAGBuilder
-
Add vertex to the builder, using the LoopVertex stack.
- addVertex(V, DAG<V, E>) - Method in class org.apache.nemo.common.dag.DAGBuilder
-
Add vertex to the builder, using the information from the given DAG.
- advanceDAGSnapshot(BiFunction<IRDAG, IRDAG, Boolean>) - Method in class org.apache.nemo.common.ir.IRDAG
-
Used internally by Nemo to advance the DAG snapshot after applying each pass.
- AggressiveSpeculativeCloningPass - Class in org.apache.nemo.compiler.optimizer.pass.compiletime.annotating
-
Speculative execution.
- AggressiveSpeculativeCloningPass() - Constructor for class org.apache.nemo.compiler.optimizer.pass.compiletime.annotating.AggressiveSpeculativeCloningPass
-
Default constructor.
- all() - Static method in class org.apache.nemo.common.HashRange
- AllMetricServlet - Class in org.apache.nemo.runtime.master.servlet
-
Servlet which handles total metric request.
- AllMetricServlet() - Constructor for class org.apache.nemo.runtime.master.servlet.AllMetricServlet
- allocateChunk() - Method in class org.apache.nemo.runtime.executor.data.MemoryPoolAssigner
-
Returns a single
MemoryChunk
fromMemoryPoolAssigner.MemoryPool
. - AllocatedEvaluatorHandler() - Constructor for class org.apache.nemo.driver.NemoDriver.AllocatedEvaluatorHandler
- AlternatingLeastSquare - Class in org.apache.nemo.examples.beam
-
Sample Alternating Least Square application.
- AlternatingLeastSquare.CalculateNextMatrix - Class in org.apache.nemo.examples.beam
-
DoFn for calculating next matrix at each iteration.
- AlternatingLeastSquare.CreateInitialMatrix - Class in org.apache.nemo.examples.beam
-
A DoFn that creates an initial matrix.
- AlternatingLeastSquare.ParseLine - Class in org.apache.nemo.examples.beam
-
Method for parsing the input line.
- AlternatingLeastSquare.TrainingDataCombiner - Class in org.apache.nemo.examples.beam
-
Combiner for the training data.
- AlternatingLeastSquare.UngroupSingleVectorList - Class in org.apache.nemo.examples.beam
-
A DoFn that relays a single vector list.
- AlternatingLeastSquare.UpdateUserAndItemMatrix - Class in org.apache.nemo.examples.beam
-
Composite transform that wraps the transforms inside the loop.
- AlternatingLeastSquareInefficient - Class in org.apache.nemo.examples.beam
-
Sample Alternating Least Square application.
- AlternatingLeastSquareInefficient.UpdateUserAndItemMatrix - Class in org.apache.nemo.examples.beam
-
Composite transform that wraps the transforms inside the loop.
- Annotates - Annotation Type in org.apache.nemo.compiler.optimizer.pass.compiletime.annotating
-
Annotation used to indicate which execution properties the class annotates.
- AnnotatingPass - Class in org.apache.nemo.compiler.optimizer.pass.compiletime.annotating
-
A compile-time pass that annotates the IR DAG with execution properties.
- AnnotatingPass(Class<? extends AnnotatingPass>) - Constructor for class org.apache.nemo.compiler.optimizer.pass.compiletime.annotating.AnnotatingPass
-
Constructor.
- AntiAffinitySchedulingConstraint - Class in org.apache.nemo.runtime.master.scheduler
-
Check if one of the tasks running on the executor, and the task to schedule are both in the anti-affinity group.
- appendPlan(PhysicalPlan, PhysicalPlan) - Static method in class org.apache.nemo.runtime.master.PlanAppender
-
Append to plans regarding to caching.
- apply(Iterable<List<Double>>) - Method in class org.apache.nemo.examples.beam.MultinomialLogisticRegression.CombineFunctionForIterable
- apply(List<Double>, List<Double>) - Method in class org.apache.nemo.examples.beam.MultinomialLogisticRegression.CombineFunction
- apply(KV<String, Long>) - Method in class org.apache.nemo.examples.beam.BeamWordCount.FormatAsTextFn
- apply(IRDAG) - Method in class org.apache.nemo.compiler.optimizer.pass.compiletime.annotating.AggressiveSpeculativeCloningPass
- apply(IRDAG) - Method in class org.apache.nemo.compiler.optimizer.pass.compiletime.annotating.CompressionPass
- apply(IRDAG) - Method in class org.apache.nemo.compiler.optimizer.pass.compiletime.annotating.DefaultDataPersistencePass
- apply(IRDAG) - Method in class org.apache.nemo.compiler.optimizer.pass.compiletime.annotating.DefaultDataStorePass
- apply(IRDAG) - Method in class org.apache.nemo.compiler.optimizer.pass.compiletime.annotating.DefaultEdgeDecoderPass
- apply(IRDAG) - Method in class org.apache.nemo.compiler.optimizer.pass.compiletime.annotating.DefaultEdgeEncoderPass
- apply(IRDAG) - Method in class org.apache.nemo.compiler.optimizer.pass.compiletime.annotating.DefaultParallelismPass
- apply(IRDAG) - Method in class org.apache.nemo.compiler.optimizer.pass.compiletime.annotating.DefaultScheduleGroupPass
- apply(IRDAG) - Method in class org.apache.nemo.compiler.optimizer.pass.compiletime.annotating.DisaggregationEdgeDataStorePass
- apply(IRDAG) - Method in class org.apache.nemo.compiler.optimizer.pass.compiletime.annotating.DuplicateEdgeGroupSizePass
- apply(IRDAG) - Method in class org.apache.nemo.compiler.optimizer.pass.compiletime.annotating.LambdaPass
- apply(IRDAG) - Method in class org.apache.nemo.compiler.optimizer.pass.compiletime.annotating.LargeShuffleAnnotatingPass
- apply(IRDAG) - Method in class org.apache.nemo.compiler.optimizer.pass.compiletime.annotating.PipeTransferForAllEdgesPass
- apply(IRDAG) - Method in class org.apache.nemo.compiler.optimizer.pass.compiletime.annotating.ResourceLocalityPass
- apply(IRDAG) - Method in class org.apache.nemo.compiler.optimizer.pass.compiletime.annotating.ResourceSitePass
- apply(IRDAG) - Method in class org.apache.nemo.compiler.optimizer.pass.compiletime.annotating.ResourceSlotPass
- apply(IRDAG) - Method in class org.apache.nemo.compiler.optimizer.pass.compiletime.annotating.ShuffleEdgePushPass
- apply(IRDAG) - Method in class org.apache.nemo.compiler.optimizer.pass.compiletime.annotating.SkewAnnotatingPass
- apply(IRDAG) - Method in class org.apache.nemo.compiler.optimizer.pass.compiletime.annotating.TransientResourceDataTransferPass
- apply(IRDAG) - Method in class org.apache.nemo.compiler.optimizer.pass.compiletime.annotating.TransientResourcePriorityPass
- apply(IRDAG) - Method in class org.apache.nemo.compiler.optimizer.pass.compiletime.annotating.UpfrontCloningPass
- apply(IRDAG) - Method in class org.apache.nemo.compiler.optimizer.pass.compiletime.annotating.XGBoostPass
- apply(IRDAG) - Method in class org.apache.nemo.compiler.optimizer.pass.compiletime.composite.CompositePass
- apply(IRDAG) - Method in class org.apache.nemo.compiler.optimizer.pass.compiletime.reshaping.CommonSubexpressionEliminationPass
- apply(IRDAG) - Method in class org.apache.nemo.compiler.optimizer.pass.compiletime.reshaping.LargeShuffleReshapingPass
- apply(IRDAG) - Method in class org.apache.nemo.compiler.optimizer.pass.compiletime.reshaping.LoopExtractionPass
- apply(IRDAG) - Method in class org.apache.nemo.compiler.optimizer.pass.compiletime.reshaping.LoopOptimizations.LoopFusionPass
- apply(IRDAG) - Method in class org.apache.nemo.compiler.optimizer.pass.compiletime.reshaping.LoopOptimizations.LoopInvariantCodeMotionPass
- apply(IRDAG) - Method in class org.apache.nemo.compiler.optimizer.pass.compiletime.reshaping.LoopUnrollingPass
- apply(IRDAG) - Method in class org.apache.nemo.compiler.optimizer.pass.compiletime.reshaping.SamplingSkewReshapingPass
- apply(IRDAG) - Method in class org.apache.nemo.compiler.optimizer.pass.compiletime.reshaping.SamplingTaskSizingPass
- apply(IRDAG) - Method in class org.apache.nemo.compiler.optimizer.pass.compiletime.reshaping.SkewReshapingPass
- apply(IRDAG) - Method in class org.apache.nemo.runtime.common.plan.PhysicalPlanGenerator
-
Generates the
PhysicalPlan
to be executed. - apply(IRDAG) - Method in class org.apache.nemo.runtime.common.plan.StagePartitioner
- apply(IRDAG, Message<Map<Object, Long>>) - Method in class org.apache.nemo.compiler.optimizer.pass.runtime.SkewRunTimePass
- apply(IRDAG, Message<Map<String, Long>>) - Method in class org.apache.nemo.compiler.optimizer.pass.runtime.DynamicTaskSizingRuntimePass
- ArgBuilder - Class in org.apache.nemo.common.test
-
Argument builder.
- ArgBuilder() - Constructor for class org.apache.nemo.common.test.ArgBuilder
-
Constructor with default values.
- asFileAreas(KeyRange) - Method in class org.apache.nemo.runtime.executor.data.block.FileBlock
- asJsonNode() - Method in class org.apache.nemo.common.dag.DAG
- asJsonNode() - Method in interface org.apache.nemo.common.dag.DAGInterface
- asJsonNode() - Method in class org.apache.nemo.common.ir.executionproperty.ExecutionPropertyMap
- asJsonNode() - Method in class org.apache.nemo.common.ir.IRDAG
- AssociatedProperty - Annotation Type in org.apache.nemo.common.ir.executionproperty
-
Declares associated
ExecutionProperty
for implementations. - asyncConnect(String, String) - Method in class org.apache.nemo.runtime.common.message.grpc.GrpcMessageEnvironment
- asyncConnect(String, String) - Method in class org.apache.nemo.runtime.common.message.local.LocalMessageEnvironment
- asyncConnect(String, String) - Method in interface org.apache.nemo.runtime.common.message.MessageEnvironment
-
Asynchronously connect to the node called
receiverId
and return a future ofMessageSender
that sends messages to the listener withlistenerId
. - asyncConnect(String, String) - Method in class org.apache.nemo.runtime.common.message.ncs.NcsMessageEnvironment
- ATTEMPTIDX_FIELD_NUMBER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg
- AVAILABLE - org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateFromExecutor
-
AVAILABLE = 2;
- AVAILABLE - org.apache.nemo.runtime.common.state.BlockState.State
- AVAILABLE_VALUE - Static variable in enum org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateFromExecutor
-
AVAILABLE = 2;
- Average() - Constructor for class org.apache.nemo.examples.spark.sql.JavaUserDefinedTypedAggregation.Average
-
Default constructor.
- Average(long, long) - Constructor for class org.apache.nemo.examples.spark.sql.JavaUserDefinedTypedAggregation.Average
-
Public constructor.
B
- Backend<Plan> - Interface in org.apache.nemo.compiler.backend
-
Interface for backend components.
- BandwidthJSONContents() - Constructor for class org.apache.nemo.conf.JobConf.BandwidthJSONContents
- BandwidthJSONPath() - Constructor for class org.apache.nemo.conf.JobConf.BandwidthJSONPath
- BasicPullPolicy - Class in org.apache.nemo.compiler.optimizer.policy
-
Basic pull policy.
- BasicPullPolicy() - Constructor for class org.apache.nemo.compiler.optimizer.policy.BasicPullPolicy
-
Default constructor.
- BasicPushPolicy - Class in org.apache.nemo.compiler.optimizer.policy
-
Basic push policy.
- BasicPushPolicy() - Constructor for class org.apache.nemo.compiler.optimizer.policy.BasicPushPolicy
-
Default constructor.
- BatchScheduler - Class in org.apache.nemo.runtime.master.scheduler
-
(CONCURRENCY) Only a single dedicated thread should use the public methods of this class.
- BatchSchedulerUtils - Class in org.apache.nemo.runtime.master.scheduler
-
Utlity methods regarding schedulers.
- BeamBoundedSourceVertex<O> - Class in org.apache.nemo.compiler.frontend.beam.source
-
SourceVertex implementation for BoundedSource.
- BeamBoundedSourceVertex(BoundedSource<O>, DisplayData) - Constructor for class org.apache.nemo.compiler.frontend.beam.source.BeamBoundedSourceVertex
-
Constructor of BeamBoundedSourceVertex.
- BeamDecoderFactory<T> - Class in org.apache.nemo.compiler.frontend.beam.coder
-
DecoderFactory
fromCoder
. - BeamDecoderFactory(Coder<T>) - Constructor for class org.apache.nemo.compiler.frontend.beam.coder.BeamDecoderFactory
-
Constructor of BeamDecoderFactory.
- BeamEncoderFactory<T> - Class in org.apache.nemo.compiler.frontend.beam.coder
-
EncoderFactory
fromCoder
. - BeamEncoderFactory(Coder<T>) - Constructor for class org.apache.nemo.compiler.frontend.beam.coder.BeamEncoderFactory
-
Constructor of BeamEncoderFactory.
- BeamStateTranslator - Class in org.apache.nemo.client.beam
-
A
StateTranslator
for Beam. - BeamStateTranslator() - Constructor for class org.apache.nemo.client.beam.BeamStateTranslator
- BeamUnboundedSourceVertex<O,M extends org.apache.beam.sdk.io.UnboundedSource.CheckpointMark> - Class in org.apache.nemo.compiler.frontend.beam.source
-
SourceVertex implementation for UnboundedSource.
- BeamUnboundedSourceVertex(UnboundedSource<O, M>, DisplayData) - Constructor for class org.apache.nemo.compiler.frontend.beam.source.BeamUnboundedSourceVertex
-
The default constructor for beam unbounded source.
- BeamWordCount - Class in org.apache.nemo.examples.beam
-
An example that counts words in Shakespeare and includes Beam best practices.
- BeamWordCount.CountWords - Class in org.apache.nemo.examples.beam
-
A PTransform that converts a PCollection containing lines of text into a PCollection of formatted word counts.
- BeamWordCount.FormatAsTextFn - Class in org.apache.nemo.examples.beam
-
A SimpleFunction that converts a Word and Count into a printable string.
- BeamWordCount.WordCountOptions - Interface in org.apache.nemo.examples.beam
-
Options supported by
WordCount
. - beforeClose() - Method in class org.apache.nemo.compiler.frontend.beam.transform.DoFnTransform
- beforeClose() - Method in class org.apache.nemo.compiler.frontend.beam.transform.GBKTransform
-
This advances the input watermark and processing time to the timestamp max value in order to emit all data.
- beforeClose() - Method in class org.apache.nemo.compiler.frontend.beam.transform.PushBackDoFnTransform
- beforeRequest(long) - Method in class org.apache.nemo.runtime.common.ReplyFutureMap
-
Called by message sender, just before a new request is sent.
- bindService() - Method in class org.apache.nemo.runtime.common.comm.MessageServiceGrpc.MessageServiceImplBase
- Block<K extends java.io.Serializable> - Interface in org.apache.nemo.runtime.executor.data.block
-
This interface represents a block, which is the output of a specific task.
- BLOCK_MANAGER_MASTER_MESSAGE_LISTENER_ID - Static variable in interface org.apache.nemo.runtime.common.message.MessageEnvironment
- BlockFetchException - Exception in org.apache.nemo.common.exception
-
BlockFetchException.
- BlockFetchException(Throwable) - Constructor for exception org.apache.nemo.common.exception.BlockFetchException
-
BlockFetchException.
- BlockFetchFailureProperty - Class in org.apache.nemo.common.ir.edge.executionproperty
-
Decides how to react to a data block fetch failure.
- BlockFetchFailureProperty.Value - Enum in org.apache.nemo.common.ir.edge.executionproperty
-
Possible values of DataFlowModel ExecutionProperty.
- BLOCKID_FIELD_NUMBER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsg
- BLOCKID_FIELD_NUMBER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsg
- BLOCKID_FIELD_NUMBER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptor
- blockIdToFilePath(String, String) - Static method in class org.apache.nemo.runtime.executor.data.DataUtil
-
Converts a block id to the corresponding file path.
- blockIdToMetaFilePath(String, String) - Static method in class org.apache.nemo.runtime.executor.data.DataUtil
-
Converts a block id to the corresponding metadata file path.
- BLOCKIDWILDCARD_FIELD_NUMBER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBlockLocationMsg
- BlockInputReader - Class in org.apache.nemo.runtime.executor.datatransfer
-
Represents the input data transfer to a task.
- BlockLocationInfo - org.apache.nemo.runtime.common.comm.ControlMessage.MessageType
-
BlockLocationInfo = 5;
- BlockLocationInfo_VALUE - Static variable in enum org.apache.nemo.runtime.common.comm.ControlMessage.MessageType
-
BlockLocationInfo = 5;
- BLOCKLOCATIONINFOMSG_FIELD_NUMBER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
- BlockManagerMaster - Class in org.apache.nemo.runtime.master
-
Master-side block manager.
- BlockManagerMaster.BlockManagerMasterControlMessageReceiver - Class in org.apache.nemo.runtime.master
-
Handler for control messages received.
- BlockManagerMaster.BlockRequestHandler - Class in org.apache.nemo.runtime.master
-
The handler of block location requests.
- BlockManagerMasterControlMessageReceiver() - Constructor for class org.apache.nemo.runtime.master.BlockManagerMaster.BlockManagerMasterControlMessageReceiver
- BlockManagerWorker - Class in org.apache.nemo.runtime.executor.data
-
Executor-side block manager.
- BlockOutputWriter - Class in org.apache.nemo.runtime.executor.datatransfer
-
Represents the output data transfer from a task.
- BlockState - Class in org.apache.nemo.runtime.common.state
-
Represents the states of a whole data(a task output).
- BlockState() - Constructor for class org.apache.nemo.runtime.common.state.BlockState
- BlockState.State - Enum in org.apache.nemo.runtime.common.state
-
BlockState.
- BlockStateChanged - org.apache.nemo.runtime.common.comm.ControlMessage.MessageType
-
BlockStateChanged = 2;
- BlockStateChanged_VALUE - Static variable in enum org.apache.nemo.runtime.common.comm.ControlMessage.MessageType
-
BlockStateChanged = 2;
- BLOCKSTATECHANGEDMSG_FIELD_NUMBER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
- BlockStore - Interface in org.apache.nemo.runtime.executor.data.stores
-
Interface for
Block
placement. - BLOCKSTORE_FIELD_NUMBER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptor
- BlockTransferThrottler - Class in org.apache.nemo.runtime.executor.data
-
A class to restrict parallel connection per runtime edge.
- BlockWriteException - Exception in org.apache.nemo.common.exception
-
BlockWriteException.
- BlockWriteException(Throwable) - Constructor for exception org.apache.nemo.common.exception.BlockWriteException
-
BlockWriteException.
- BoundedIteratorReadable<O> - Class in org.apache.nemo.common.ir
-
An abstract readable class that retrieves data from iterator.
- BoundedIteratorReadable() - Constructor for class org.apache.nemo.common.ir.BoundedIteratorReadable
- broadcast(byte[]) - Method in class org.apache.nemo.runtime.master.metric.MetricBroadcaster
-
Send binary frame to each WebSocket session.
- broadcast(String) - Method in class org.apache.nemo.runtime.master.metric.MetricBroadcaster
-
Send text frame to each WebSocket session.
- Broadcast - Class in org.apache.nemo.examples.beam
-
Sample Broadcast application.
- BROADCAST - org.apache.nemo.common.ir.edge.executionproperty.CommunicationPatternProperty.Value
- BROADCASTID_FIELD_NUMBER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBroadcastVariableMessage
- BroadcastManagerMaster - Class in org.apache.nemo.runtime.master
-
Broadcast variables saved in the master.
- BroadcastManagerWorker - Class in org.apache.nemo.runtime.executor.data
-
Used by tasks to get/fetch (probably remote) broadcast variables.
- BROADCASTVARIABLEMSG_FIELD_NUMBER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
- BROADCASTVARS_FIELD_NUMBER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.LaunchDAGMessage
- bufferEncoder() - Method in class org.apache.nemo.examples.spark.sql.JavaUserDefinedTypedAggregation.MyAverage
-
Specifies the EncoderFactory for the intermediate value type.
- bufferSchema() - Method in class org.apache.nemo.examples.spark.sql.JavaUserDefinedUntypedAggregation.MyAverage
-
Data types of values in the aggregation buffer.
- build() - Method in class org.apache.nemo.common.dag.DAGBuilder
-
Build the DAG.
- build() - Method in class org.apache.nemo.common.StateMachine.Builder
-
Builds and returns the StateMachine.
- build() - Method in class org.apache.nemo.common.test.ArgBuilder
- build() - Method in class org.apache.nemo.compiler.optimizer.policy.PolicyBuilder
-
Build a policy using compileTimePasses and runTimePasses in this object.
- build() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsg.Builder
- build() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsg.Builder
- build() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptor.Builder
- build() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage.Builder
- build() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessage.Builder
- build() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ContainerFailedMsg.Builder
- build() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DataCollectMessage.Builder
- build() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessage.Builder
- build() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ExecutorFailedMsg.Builder
- build() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.InMasterBroadcastVariableMessage.Builder
- build() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.LaunchDAGMessage.Builder
- build() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
- build() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Metric.Builder
- build() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.MetricMsg.Builder
- build() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.NotificationMessage.Builder
- build() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeInitMessage.Builder
- build() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeLocationInfoMessage.Builder
- build() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptor.Builder
- build() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBlockLocationMsg.Builder
- build() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBroadcastVariableMessage.Builder
- build() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestPipeLocationMessage.Builder
- build() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageEntry.Builder
- build() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsg.Builder
- build() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ScheduleTaskMsg.Builder
- build() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg.Builder
- build() - Method in class org.apache.nemo.runtime.common.comm.GrpcMessageService.Void.Builder
- build(Channel, CallOptions) - Method in class org.apache.nemo.runtime.common.comm.MessageServiceGrpc.MessageServiceBlockingStub
- build(Channel, CallOptions) - Method in class org.apache.nemo.runtime.common.comm.MessageServiceGrpc.MessageServiceFutureStub
- build(Channel, CallOptions) - Method in class org.apache.nemo.runtime.common.comm.MessageServiceGrpc.MessageServiceStub
- buildEmptyDAG() - Static method in class org.apache.nemo.common.test.EmptyComponents
-
Builds dummy IR DAG for testing.
- buildEmptyDAGForSkew() - Static method in class org.apache.nemo.common.test.EmptyComponents
-
Builds dummy IR DAG to test skew handling.
- BUILDER - Static variable in class org.apache.nemo.compiler.optimizer.policy.BasicPullPolicy
- BUILDER - Static variable in class org.apache.nemo.compiler.optimizer.policy.BasicPushPolicy
- BUILDER - Static variable in class org.apache.nemo.compiler.optimizer.policy.ConditionalLargeShufflePolicy
- BUILDER - Static variable in class org.apache.nemo.compiler.optimizer.policy.DataSkewPolicy
- BUILDER - Static variable in class org.apache.nemo.compiler.optimizer.policy.DefaultPolicy
- BUILDER - Static variable in class org.apache.nemo.compiler.optimizer.policy.DefaultPolicyWithSeparatePass
- BUILDER - Static variable in class org.apache.nemo.compiler.optimizer.policy.DisaggregationPolicy
- BUILDER - Static variable in class org.apache.nemo.compiler.optimizer.policy.DynamicTaskSizingPolicy
- BUILDER - Static variable in class org.apache.nemo.compiler.optimizer.policy.LargeShufflePolicy
- BUILDER - Static variable in class org.apache.nemo.compiler.optimizer.policy.SamplingLargeShuffleSkewPolicy
- BUILDER - Static variable in class org.apache.nemo.compiler.optimizer.policy.TransientResourcePolicy
- BUILDER - Static variable in class org.apache.nemo.compiler.optimizer.policy.XGBoostPolicy
- buildInputStream(InputStream, List<DecodeStreamChainer>) - Static method in class org.apache.nemo.runtime.executor.data.DataUtil
-
Chain
InputStream
withDecodeStreamChainer
s. - buildOutputStream(OutputStream, List<EncodeStreamChainer>) - Static method in class org.apache.nemo.runtime.executor.data.DataUtil
-
Chain
OutputStream
withEncodeStreamChainer
s. - buildPartial() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsg.Builder
- buildPartial() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsg.Builder
- buildPartial() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptor.Builder
- buildPartial() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage.Builder
- buildPartial() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessage.Builder
- buildPartial() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ContainerFailedMsg.Builder
- buildPartial() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DataCollectMessage.Builder
- buildPartial() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessage.Builder
- buildPartial() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ExecutorFailedMsg.Builder
- buildPartial() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.InMasterBroadcastVariableMessage.Builder
- buildPartial() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.LaunchDAGMessage.Builder
- buildPartial() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
- buildPartial() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Metric.Builder
- buildPartial() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.MetricMsg.Builder
- buildPartial() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.NotificationMessage.Builder
- buildPartial() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeInitMessage.Builder
- buildPartial() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeLocationInfoMessage.Builder
- buildPartial() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptor.Builder
- buildPartial() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBlockLocationMsg.Builder
- buildPartial() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBroadcastVariableMessage.Builder
- buildPartial() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestPipeLocationMessage.Builder
- buildPartial() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageEntry.Builder
- buildPartial() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsg.Builder
- buildPartial() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ScheduleTaskMsg.Builder
- buildPartial() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg.Builder
- buildPartial() - Method in class org.apache.nemo.runtime.common.comm.GrpcMessageService.Void.Builder
- buildWithoutSourceCheck() - Method in class org.apache.nemo.common.dag.DAGBuilder
-
Build the DAG without source check.
- buildWithoutSourceSinkCheck() - Method in class org.apache.nemo.common.dag.DAGBuilder
-
Build the DAG without source and sink check.
- BYTE_ARRAY_BASE_OFFSET - Static variable in class org.apache.nemo.runtime.executor.data.MemoryChunk
- ByteBufferInputStream - Class in org.apache.nemo.common
-
This class is a customized input stream implementation which reads data from list of
ByteBuffer
. - ByteBufferInputStream(List<ByteBuffer>) - Constructor for class org.apache.nemo.common.ByteBufferInputStream
-
Default Constructor.
- ByteInputContext - Class in org.apache.nemo.runtime.executor.transfer
-
Container for multiple input streams.
- ByteOutputContext - Class in org.apache.nemo.runtime.executor.transfer
-
Container for multiple output streams.
- ByteOutputContext.ByteOutputStream - Class in org.apache.nemo.runtime.executor.transfer
-
An
OutputStream
implementation which buffers data toByteBuf
s. - ByteOutputStream() - Constructor for class org.apache.nemo.runtime.executor.transfer.ByteOutputContext.ByteOutputStream
- BytesDecoderFactory - Class in org.apache.nemo.common.coder
-
A
DecoderFactory
which is used for an array of bytes. - BytesEncoderFactory - Class in org.apache.nemo.common.coder
-
A
EncoderFactory
which is used for an array of bytes. - ByteTransfer - Class in org.apache.nemo.runtime.executor.transfer
-
Manages channels and exposes interface for
BlockManagerWorker
. - ByteTransferContext - Class in org.apache.nemo.runtime.executor.transfer
C
- CachedSourceVertex<T> - Class in org.apache.nemo.common.ir.vertex
-
Bounded source vertex for cached data.
- CachedSourceVertex(int) - Constructor for class org.apache.nemo.common.ir.vertex.CachedSourceVertex
-
Constructor.
- CacheIDProperty - Class in org.apache.nemo.common.ir.edge.executionproperty
-
Cache ID ExecutionProperty.
- calculate() - Method in class org.apache.nemo.compiler.backend.nemo.prophet.ParallelismProphet
-
Launch SimulationScheduler and find out the optimal parallelism.
- calculate() - Method in interface org.apache.nemo.compiler.backend.nemo.prophet.Prophet
-
Calculate the optimized values based on runtime messages.
- calculate() - Method in class org.apache.nemo.compiler.backend.nemo.prophet.SkewProphet
- CalculateNextMatrix(int, double, PCollectionView<Map<Integer, float[]>>) - Constructor for class org.apache.nemo.examples.beam.AlternatingLeastSquare.CalculateNextMatrix
-
Constructor for CalculateNextMatrix DoFn class.
- cancel() - Method in class org.apache.nemo.client.beam.NemoPipelineResult
- CANCEL_TASK - org.apache.nemo.common.ir.edge.executionproperty.BlockFetchFailureProperty.Value
-
(DEFAULT BEHAVIOR) The task will be cancelled and retried by the scheduler.
- chainInput(InputStream) - Method in interface org.apache.nemo.runtime.executor.data.streamchainer.DecodeStreamChainer
-
Chain
InputStream
and returns chainedInputStream
. - chainInput(InputStream) - Method in class org.apache.nemo.runtime.executor.data.streamchainer.DecompressionStreamChainer
- chainOutput(OutputStream) - Method in class org.apache.nemo.runtime.executor.data.streamchainer.CompressionStreamChainer
- chainOutput(OutputStream) - Method in interface org.apache.nemo.runtime.executor.data.streamchainer.EncodeStreamChainer
-
Chain
OutputStream
and returns chainedOutputStream
. - check(DAG<IRVertex, IREdge>) - Method in interface org.apache.nemo.common.ir.IRDAGChecker.GlobalDAGChecker
- checkEqualityOfIntPredicates(IntPredicate, IntPredicate, int) - Static method in class org.apache.nemo.common.Util
-
Check the equality of two intPredicates.
- checkIntegrity() - Method in class org.apache.nemo.common.ir.IRDAG
- checkState(Enum) - Method in class org.apache.nemo.common.StateMachine
-
Checks whether the current state is same as the
expectedCurrentState
. - ChunkSizeKb() - Constructor for class org.apache.nemo.conf.JobConf.ChunkSizeKb
- clear() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsg.Builder
- clear() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsg.Builder
- clear() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptor.Builder
- clear() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage.Builder
- clear() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessage.Builder
- clear() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ContainerFailedMsg.Builder
- clear() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DataCollectMessage.Builder
- clear() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessage.Builder
- clear() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ExecutorFailedMsg.Builder
- clear() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.InMasterBroadcastVariableMessage.Builder
- clear() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.LaunchDAGMessage.Builder
- clear() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
- clear() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Metric.Builder
- clear() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.MetricMsg.Builder
- clear() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.NotificationMessage.Builder
- clear() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeInitMessage.Builder
- clear() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeLocationInfoMessage.Builder
- clear() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptor.Builder
- clear() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBlockLocationMsg.Builder
- clear() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBroadcastVariableMessage.Builder
- clear() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestPipeLocationMessage.Builder
- clear() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageEntry.Builder
- clear() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsg.Builder
- clear() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ScheduleTaskMsg.Builder
- clear() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg.Builder
- clear() - Method in class org.apache.nemo.runtime.common.comm.GrpcMessageService.Void.Builder
- clearAttemptIdx() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg.Builder
-
required int32 attemptIdx = 6;
- clearBlockId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsg.Builder
-
required string blockId = 2;
- clearBlockId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsg.Builder
-
required string blockId = 2;
- clearBlockId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptor.Builder
-
required string blockId = 1;
- clearBlockIdWildcard() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBlockLocationMsg.Builder
-
required string blockIdWildcard = 2;
- clearBlockLocationInfoMsg() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.BlockLocationInfoMsg blockLocationInfoMsg = 9;
- clearBlockStateChangedMsg() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.BlockStateChangedMsg blockStateChangedMsg = 6;
- clearBlockStore() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptor.Builder
-
required .protobuf.BlockStore blockStore = 2;
- clearBroadcastId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBroadcastVariableMessage.Builder
-
required bytes broadcastId = 2;
- clearBroadcastVariableMsg() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.InMasterBroadcastVariableMessage broadcastVariableMsg = 15;
- clearBroadcastVars() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.LaunchDAGMessage.Builder
-
optional bytes broadcastVars = 2;
- clearContainerFailedMsg() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.ContainerFailedMsg containerFailedMsg = 11;
- clearContextDescriptor() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage.Builder
-
required bytes contextDescriptor = 4;
- clearDag() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.LaunchDAGMessage.Builder
-
required string dag = 1;
- clearData() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DataCollectMessage.Builder
-
required string data = 1;
- clearData() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.NotificationMessage.Builder
-
required string data = 2;
- clearDataCollected() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessage.Builder
-
optional .protobuf.DataCollectMessage dataCollected = 2;
- clearDataCollected() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.DataCollectMessage dataCollected = 13;
- clearDataDirection() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage.Builder
-
required .protobuf.ByteTransferDataDirection dataDirection = 3;
- clearDstTaskIndex() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptor.Builder
-
required int64 dstTaskIndex = 3;
- clearEntry() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsg.Builder
-
repeated .protobuf.RunTimePassMessageEntry entry = 2;
- clearException() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ExecutorFailedMsg.Builder
-
required bytes exception = 2;
- clearExecutorFailedMsg() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.ExecutorFailedMsg executorFailedMsg = 10;
- clearExecutorId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsg.Builder
-
required string executorId = 1;
- clearExecutorId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ContainerFailedMsg.Builder
-
required string executorId = 1;
- clearExecutorId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ExecutorFailedMsg.Builder
-
required string executorId = 1;
- clearExecutorId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeInitMessage.Builder
-
required string executorId = 3;
- clearExecutorId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeLocationInfoMessage.Builder
-
required string executorId = 2;
- clearExecutorId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBlockLocationMsg.Builder
-
required string executorId = 1;
- clearExecutorId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBroadcastVariableMessage.Builder
-
required string executorId = 1;
- clearExecutorId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestPipeLocationMessage.Builder
-
required string executorId = 1;
- clearExecutorId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg.Builder
-
required string executorId = 1;
- clearFailureCause() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg.Builder
-
optional .protobuf.RecoverableFailureCause failureCause = 5;
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsg.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsg.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptor.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessage.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ContainerFailedMsg.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DataCollectMessage.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessage.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ExecutorFailedMsg.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.InMasterBroadcastVariableMessage.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.LaunchDAGMessage.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Metric.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.MetricMsg.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.NotificationMessage.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeInitMessage.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeLocationInfoMessage.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptor.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBlockLocationMsg.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBroadcastVariableMessage.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestPipeLocationMessage.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageEntry.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsg.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ScheduleTaskMsg.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.nemo.runtime.common.comm.GrpcMessageService.Void.Builder
- clearId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
required int64 id = 2;
- clearInitiatorExecutorId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage.Builder
-
required string initiatorExecutorId = 1;
- clearInternalStates() - Method in class org.apache.nemo.common.ir.vertex.CachedSourceVertex
- clearInternalStates() - Method in class org.apache.nemo.common.ir.vertex.InMemorySourceVertex
- clearInternalStates() - Method in class org.apache.nemo.common.ir.vertex.SourceVertex
-
Clears internal states, must be called after getReadables().
- clearInternalStates() - Method in class org.apache.nemo.common.test.EmptyComponents.EmptySourceVertex
- clearInternalStates() - Method in class org.apache.nemo.compiler.frontend.beam.source.BeamBoundedSourceVertex
- clearInternalStates() - Method in class org.apache.nemo.compiler.frontend.beam.source.BeamUnboundedSourceVertex
- clearIsPipe() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage.Builder
-
required bool isPipe = 5;
- clearKey() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageEntry.Builder
-
required string key = 1;
- clearKeyRange() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptor.Builder
-
optional bytes keyRange = 4;
- clearLaunchDAG() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessage.Builder
-
optional .protobuf.LaunchDAGMessage launchDAG = 2;
- clearListenerId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
The id of the message listener (handler).
- clearLocation() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsg.Builder
-
The location of the block (e.g., executor id or remote store).
- clearMessage() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessage.Builder
-
optional .protobuf.NotificationMessage message = 3;
- clearMetric() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.MetricMsg.Builder
-
repeated .protobuf.Metric metric = 1;
- clearMetricField() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Metric.Builder
-
required string metricField = 3;
- clearMetricId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Metric.Builder
-
required string metricId = 2;
- clearMetricMsg() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.MetricMsg metricMsg = 12;
- clearMetricType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Metric.Builder
-
required string metricType = 1;
- clearMetricValue() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Metric.Builder
-
required bytes metricValue = 4;
- clearNumPipeToWait() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptor.Builder
-
required int64 numPipeToWait = 4;
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsg.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsg.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptor.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessage.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ContainerFailedMsg.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DataCollectMessage.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessage.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ExecutorFailedMsg.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.InMasterBroadcastVariableMessage.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.LaunchDAGMessage.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Metric.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.MetricMsg.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.NotificationMessage.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeInitMessage.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeLocationInfoMessage.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptor.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBlockLocationMsg.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBroadcastVariableMessage.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestPipeLocationMessage.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageEntry.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsg.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ScheduleTaskMsg.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.nemo.runtime.common.comm.GrpcMessageService.Void.Builder
- clearOptimizationType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessage.Builder
-
optional .protobuf.OptimizationType optimizationType = 3;
- clearOptimizationType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.NotificationMessage.Builder
-
required .protobuf.OptimizationType optimizationType = 1;
- clearOwnerExecutorId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsg.Builder
-
optional string ownerExecutorId = 4;
- clearPipeInitMsg() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.PipeInitMessage pipeInitMsg = 16;
- clearPipeLocInfoMsg() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.PipeLocationInfoMessage pipeLocInfoMsg = 18;
- clearRequestBlockLocationMsg() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.RequestBlockLocationMsg requestBlockLocationMsg = 8;
- clearRequestbroadcastVariableMsg() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.RequestBroadcastVariableMessage requestbroadcastVariableMsg = 14;
- clearRequestId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsg.Builder
-
To find the matching request msg
- clearRequestId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.InMasterBroadcastVariableMessage.Builder
-
To find the matching request msg
- clearRequestId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeLocationInfoMessage.Builder
-
To find the matching request msg
- clearRequestPipeLocMsg() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.RequestPipeLocationMessage requestPipeLocMsg = 17;
- clearRuntimeEdgeId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptor.Builder
-
required string runtimeEdgeId = 3;
- clearRuntimeEdgeId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeInitMessage.Builder
-
required string runtimeEdgeId = 2;
- clearRuntimeEdgeId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptor.Builder
-
required string runtimeEdgeId = 2;
- clearRuntimeEdgeId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestPipeLocationMessage.Builder
-
required string runtimeEdgeId = 3;
- clearRunTimePassMessageMsg() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.RunTimePassMessageMsg runTimePassMessageMsg = 7;
- clearScheduleTaskMsg() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.ScheduleTaskMsg scheduleTaskMsg = 5;
- clearSrcTaskIndex() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeInitMessage.Builder
-
required int64 srcTaskIndex = 1;
- clearSrcTaskIndex() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptor.Builder
-
required int64 srcTaskIndex = 1;
- clearSrcTaskIndex() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestPipeLocationMessage.Builder
-
required int64 srcTaskIndex = 2;
- clearState() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsg.Builder
-
optional .protobuf.BlockStateFromExecutor state = 3;
- clearState() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsg.Builder
-
required .protobuf.BlockStateFromExecutor state = 3;
- clearState() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg.Builder
-
required .protobuf.TaskStateFromExecutor state = 3;
- clearTask() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ScheduleTaskMsg.Builder
-
required bytes task = 1;
- clearTaskId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsg.Builder
-
required string taskId = 1;
- clearTaskId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg.Builder
-
required string taskId = 2;
- clearTaskStateChangedMsg() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.TaskStateChangedMsg taskStateChangedMsg = 4;
- clearTransferIndex() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage.Builder
-
required int32 transferIndex = 2;
- clearType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessage.Builder
-
required .protobuf.ClientToDriverMessageType type = 1;
- clearType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessage.Builder
-
required .protobuf.DriverToClientMessageType type = 1;
- clearType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
required .protobuf.MessageType type = 1;
- clearValue() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageEntry.Builder
-
required int64 value = 2;
- clearVariable() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.InMasterBroadcastVariableMessage.Builder
-
required bytes variable = 2;
- clearVertexPutOnHoldId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg.Builder
-
optional string vertexPutOnHoldId = 4;
- ClientEndpoint - Class in org.apache.nemo.client
-
A request endpoint in client side of a plan.
- ClientEndpoint(StateTranslator) - Constructor for class org.apache.nemo.client.ClientEndpoint
-
Constructor.
- ClientRPC - Class in org.apache.nemo.runtime.common.message
-
Driver-side RPC implementation for communication from/to Nemo Client.
- ClientSideRPCServerHost() - Constructor for class org.apache.nemo.conf.JobConf.ClientSideRPCServerHost
- ClientSideRPCServerPort() - Constructor for class org.apache.nemo.conf.JobConf.ClientSideRPCServerPort
- ClientUtils - Class in org.apache.nemo.client
-
Utility class for the Client.
- clone() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsg.Builder
- clone() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsg.Builder
- clone() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptor.Builder
- clone() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage.Builder
- clone() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessage.Builder
- clone() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ContainerFailedMsg.Builder
- clone() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DataCollectMessage.Builder
- clone() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessage.Builder
- clone() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ExecutorFailedMsg.Builder
- clone() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.InMasterBroadcastVariableMessage.Builder
- clone() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.LaunchDAGMessage.Builder
- clone() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
- clone() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Metric.Builder
- clone() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.MetricMsg.Builder
- clone() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.NotificationMessage.Builder
- clone() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeInitMessage.Builder
- clone() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeLocationInfoMessage.Builder
- clone() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptor.Builder
- clone() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBlockLocationMsg.Builder
- clone() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBroadcastVariableMessage.Builder
- clone() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestPipeLocationMessage.Builder
- clone() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageEntry.Builder
- clone() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsg.Builder
- clone() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ScheduleTaskMsg.Builder
- clone() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg.Builder
- clone() - Method in class org.apache.nemo.runtime.common.comm.GrpcMessageService.Void.Builder
- Cloneable<T extends Cloneable<T>> - Interface in org.apache.nemo.common
-
This interface is implemented by objects that can be cloned.
- CloneConf() - Constructor for class org.apache.nemo.common.ir.vertex.executionproperty.ClonedSchedulingProperty.CloneConf
-
Always clone, upfront.
- CloneConf(double, double) - Constructor for class org.apache.nemo.common.ir.vertex.executionproperty.ClonedSchedulingProperty.CloneConf
-
Clone stragglers judiciously.
- ClonedSchedulingProperty - Class in org.apache.nemo.common.ir.vertex.executionproperty
-
Specifies cloned execution of a vertex.
- ClonedSchedulingProperty.CloneConf - Class in org.apache.nemo.common.ir.vertex.executionproperty
-
Configurations for cloning.
- cloneEdge(CommunicationPatternProperty.Value, IREdge, IRVertex, IRVertex) - Static method in class org.apache.nemo.common.Util
-
Creates a new edge with several execution properties same as the given edge.
- cloneEdge(IREdge, IRVertex, IRVertex) - Static method in class org.apache.nemo.common.Util
- ClosableBlockingQueue<T> - Class in org.apache.nemo.runtime.executor.transfer
-
A blocking queue implementation which is capable of closing.
- ClosableBlockingQueue() - Constructor for class org.apache.nemo.runtime.executor.transfer.ClosableBlockingQueue
-
Creates a closable blocking queue.
- ClosableBlockingQueue(int) - Constructor for class org.apache.nemo.runtime.executor.transfer.ClosableBlockingQueue
-
Creates a closable blocking queue.
- close() - Method in interface org.apache.nemo.common.ir.Readable
-
Close.
- close() - Method in class org.apache.nemo.common.ir.vertex.transform.MessageAggregatorTransform
- close() - Method in class org.apache.nemo.common.ir.vertex.transform.MessageGeneratorTransform
- close() - Method in class org.apache.nemo.common.ir.vertex.transform.SignalTransform
- close() - Method in class org.apache.nemo.common.ir.vertex.transform.StreamTransform
- close() - Method in interface org.apache.nemo.common.ir.vertex.transform.Transform
-
Close the transform.
- close() - Method in class org.apache.nemo.common.test.EmptyComponents.EmptyTransform
- close() - Method in class org.apache.nemo.compiler.frontend.beam.transform.AbstractDoFnTransform
- close() - Method in class org.apache.nemo.compiler.frontend.beam.transform.CombineFnFinalTransform
- close() - Method in class org.apache.nemo.compiler.frontend.beam.transform.CombineFnPartialTransform
- close() - Method in class org.apache.nemo.compiler.frontend.beam.transform.CreateViewTransform
- close() - Method in class org.apache.nemo.compiler.frontend.beam.transform.FlattenTransform
- close() - Method in class org.apache.nemo.compiler.frontend.beam.transform.GroupByKeyTransform
- close() - Method in class org.apache.nemo.compiler.frontend.beam.transform.SideInputTransform
- close() - Method in class org.apache.nemo.compiler.frontend.beam.transform.WindowFnTransform
- close() - Method in class org.apache.nemo.driver.RemoteClientMessageLoggingHandler
- close() - Method in class org.apache.nemo.runtime.common.message.FailedMessageSender
- close() - Method in class org.apache.nemo.runtime.common.message.grpc.GrpcMessageEnvironment
- close() - Method in class org.apache.nemo.runtime.common.message.local.LocalMessageEnvironment
- close() - Method in class org.apache.nemo.runtime.common.message.local.LocalMessageSender
- close() - Method in interface org.apache.nemo.runtime.common.message.MessageEnvironment
-
Close this message environment.
- close() - Method in interface org.apache.nemo.runtime.common.message.MessageSender
-
Closes the connection.
- close() - Method in class org.apache.nemo.runtime.common.message.ncs.NcsMessageEnvironment
- close() - Method in class org.apache.nemo.runtime.executor.data.DirectByteBufferOutputStream
-
Closing this output stream has no effect.
- close() - Method in class org.apache.nemo.runtime.executor.datatransfer.BlockOutputWriter
-
Notifies that all writes for a block is end.
- close() - Method in interface org.apache.nemo.runtime.executor.datatransfer.OutputWriter
- close() - Method in class org.apache.nemo.runtime.executor.datatransfer.PipeOutputWriter
- close() - Method in class org.apache.nemo.runtime.executor.MetricManagerWorker
- close() - Method in interface org.apache.nemo.runtime.executor.MetricMessageSender
-
Flush the metric queue and close the metric dispatch.
- close() - Method in class org.apache.nemo.runtime.executor.transfer.ByteOutputContext.ByteOutputStream
- close() - Method in class org.apache.nemo.runtime.executor.transfer.ByteOutputContext
-
Closes this stream.
- close() - Method in class org.apache.nemo.runtime.executor.transfer.ClosableBlockingQueue
-
Mark the input end of this queue as closed.
- close() - Method in class org.apache.nemo.runtime.executor.transfer.LocalOutputContext
-
Closes this local output context.
- close() - Method in interface org.apache.nemo.runtime.executor.transfer.OutputContext
-
Closes this output context.
- close() - Method in interface org.apache.nemo.runtime.executor.transfer.TransferOutputStream
-
Closes this output stream.
- closeExceptionally(Throwable) - Method in class org.apache.nemo.runtime.executor.transfer.ClosableBlockingQueue
-
Mark the input end of this queue as closed.
- collectMetricStore() - Method in class org.apache.nemo.runtime.master.scheduler.SimulationScheduler
-
The endpoint of the simulator.
- CombineFnFinalTransform<K,A,O> - Class in org.apache.nemo.compiler.frontend.beam.transform
-
Accumulates all of the partially accumulated KVs(Key, Accum) into KVs(Key, Output).
- CombineFnFinalTransform(CombineFnBase.GlobalCombineFn<?, A, O>) - Constructor for class org.apache.nemo.compiler.frontend.beam.transform.CombineFnFinalTransform
-
Constructor.
- CombineFnPartialTransform<K,I,A> - Class in org.apache.nemo.compiler.frontend.beam.transform
-
Partially accumulates the given KVs(Key, Input) into KVs(Key, Accum).
- CombineFnPartialTransform(CombineFnBase.GlobalCombineFn<I, A, ?>) - Constructor for class org.apache.nemo.compiler.frontend.beam.transform.CombineFnPartialTransform
-
Constructor.
- CombineFunction() - Constructor for class org.apache.nemo.examples.beam.MultinomialLogisticRegression.CombineFunction
- CombineFunctionForIterable() - Constructor for class org.apache.nemo.examples.beam.MultinomialLogisticRegression.CombineFunctionForIterable
- commit() - Method in interface org.apache.nemo.runtime.executor.data.block.Block
-
Commits this block to prevent further write.
- commit() - Method in class org.apache.nemo.runtime.executor.data.block.FileBlock
-
Commits this block to prevent further write.
- commit() - Method in class org.apache.nemo.runtime.executor.data.block.NonSerializedMemoryBlock
-
Commits this block to prevent further write.
- commit() - Method in class org.apache.nemo.runtime.executor.data.block.SerializedMemoryBlock
-
Commits this block to prevent further write.
- commit() - Method in class org.apache.nemo.runtime.executor.data.partition.NonSerializedPartition
-
Commits a partition to prevent further data write.
- commit() - Method in interface org.apache.nemo.runtime.executor.data.partition.Partition
-
Commits a partition to prevent further data write.
- commit() - Method in class org.apache.nemo.runtime.executor.data.partition.SerializedPartition
-
Commits a partition to prevent further data write.
- commitBlock() - Method in class org.apache.nemo.runtime.executor.data.metadata.FileMetadata
-
Notifies that all writes are finished for the block corresponding to this metadata.
- commitBlock() - Method in class org.apache.nemo.runtime.executor.data.metadata.LocalFileMetadata
-
Notifies that all writes are finished for the block corresponding to this metadata.
- commitBlock() - Method in class org.apache.nemo.runtime.executor.data.metadata.RemoteFileMetadata
-
Write the collected
PartitionMetadata
s to the metadata file. - commitPartitions() - Method in interface org.apache.nemo.runtime.executor.data.block.Block
-
Commits all un-committed partitions.
- commitPartitions() - Method in class org.apache.nemo.runtime.executor.data.block.FileBlock
-
Commits all un-committed partitions.
- commitPartitions() - Method in class org.apache.nemo.runtime.executor.data.block.NonSerializedMemoryBlock
-
Commits all un-committed partitions.
- commitPartitions() - Method in class org.apache.nemo.runtime.executor.data.block.SerializedMemoryBlock
-
Commits all un-committed partitions.
- CommonEventHandler<T> - Interface in org.apache.nemo.common.eventhandler
-
Class for handling common events.
- CommonSubexpressionEliminationPass - Class in org.apache.nemo.compiler.optimizer.pass.compiletime.reshaping
-
Pass for Common Subexpression Elimination optimization.
- CommonSubexpressionEliminationPass() - Constructor for class org.apache.nemo.compiler.optimizer.pass.compiletime.reshaping.CommonSubexpressionEliminationPass
-
Default constructor.
- CommunicationPatternProperty - Class in org.apache.nemo.common.ir.edge.executionproperty
-
DataCommunicationPattern ExecutionProperty.
- CommunicationPatternProperty.Value - Enum in org.apache.nemo.common.ir.edge.executionproperty
-
Possible values of DataCommunicationPattern ExecutionProperty.
- compare(KV<K, Double>, KV<K, Double>) - Method in class org.apache.nemo.examples.beam.EDGARTop10BadRefererDocs.ValueComparator
- compare(KV<K, Long>, KV<K, Long>) - Method in class org.apache.nemo.examples.beam.EDGARTop10Documents.ValueComparator
- compareAndSetState(Enum, Enum) - Method in class org.apache.nemo.common.StateMachine
-
Atomically sets the state to the given updated state if the current state equals to the expected state.
- compareTo(Watermark) - Method in class org.apache.nemo.common.punctuation.Watermark
- compile(IRDAG) - Method in interface org.apache.nemo.compiler.backend.Backend
-
Compiles a DAG to a physical execution plan.
- compile(IRDAG) - Method in class org.apache.nemo.compiler.backend.nemo.NemoBackend
-
Compiles an IR DAG into a
PhysicalPlan
to be submitted to Runtime. - compileALSDAG() - Static method in class org.apache.nemo.compiler.CompilerTestUtil
- compileALSInefficientDAG() - Static method in class org.apache.nemo.compiler.CompilerTestUtil
- compileMLRDAG() - Static method in class org.apache.nemo.compiler.CompilerTestUtil
- CompilerEvent - Interface in org.apache.nemo.common.eventhandler
-
An empty interface to indicate events that are sent from Compiler.
- CompilerEventHandler<T extends CompilerEvent> - Interface in org.apache.nemo.common.eventhandler
-
Class for handling events sent from Compiler.
- CompilerTestUtil - Class in org.apache.nemo.compiler
-
Utility methods for tests.
- CompileTimeOptimizationException - Exception in org.apache.nemo.common.exception
-
CompileTimeOptimizationException.
- CompileTimeOptimizationException(String) - Constructor for exception org.apache.nemo.common.exception.CompileTimeOptimizationException
-
Constructor of CompileTimeOptimizationException.
- CompileTimeOptimizationException(Throwable) - Constructor for exception org.apache.nemo.common.exception.CompileTimeOptimizationException
-
Constructor of CompileTimeOptimizationException.
- CompileTimePass - Class in org.apache.nemo.compiler.optimizer.pass.compiletime
-
Abstract class for compile-time optimization passes that processes the DAG.
- CompileTimePass() - Constructor for class org.apache.nemo.compiler.optimizer.pass.compiletime.CompileTimePass
- compileWordCountDAG() - Static method in class org.apache.nemo.compiler.CompilerTestUtil
- COMPLETE - org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateFromExecutor
-
COMPLETE = 2;
- COMPLETE - org.apache.nemo.runtime.common.state.PlanState.State
- COMPLETE - org.apache.nemo.runtime.common.state.StageState.State
- COMPLETE - org.apache.nemo.runtime.common.state.TaskState.State
- COMPLETE_VALUE - Static variable in enum org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateFromExecutor
-
COMPLETE = 2;
- CompositePass - Class in org.apache.nemo.compiler.optimizer.pass.compiletime.composite
-
A compile-time pass composed of multiple compile-time passes, which each modifies an IR DAG.
- CompositePass(List<CompileTimePass>) - Constructor for class org.apache.nemo.compiler.optimizer.pass.compiletime.composite.CompositePass
-
Constructor.
- CompressionPass - Class in org.apache.nemo.compiler.optimizer.pass.compiletime.annotating
-
A pass for applying compression algorithm for data flowing between vertices.
- CompressionPass() - Constructor for class org.apache.nemo.compiler.optimizer.pass.compiletime.annotating.CompressionPass
-
Default constructor.
- CompressionPass(CompressionProperty.Value) - Constructor for class org.apache.nemo.compiler.optimizer.pass.compiletime.annotating.CompressionPass
-
Constructor.
- CompressionProperty - Class in org.apache.nemo.common.ir.edge.executionproperty
-
Compression ExecutionProperty.
- CompressionProperty.Value - Enum in org.apache.nemo.common.ir.edge.executionproperty
-
Possible values of Compression ExecutionProperty.
- CompressionStreamChainer - Class in org.apache.nemo.runtime.executor.data.streamchainer
-
EncodeStreamChainer
for applying compression. - CompressionStreamChainer(CompressionProperty.Value) - Constructor for class org.apache.nemo.runtime.executor.data.streamchainer.CompressionStreamChainer
-
Constructor.
- COMPUTE - Static variable in class org.apache.nemo.common.ir.vertex.executionproperty.ResourcePriorityProperty
- concatNonSerPartitions(Iterable<NonSerializedPartition>) - Static method in class org.apache.nemo.runtime.executor.data.DataUtil
-
Concatenates an iterable of non-serialized
Partition
s into a single iterable of elements. - ConditionalLargeShufflePolicy - Class in org.apache.nemo.compiler.optimizer.policy
-
A policy to demonstrate the large shuffle optimization, witch batches disk seek during data shuffle, conditionally.
- ConditionalLargeShufflePolicy() - Constructor for class org.apache.nemo.compiler.optimizer.policy.ConditionalLargeShufflePolicy
-
Default constructor.
- configure(WebSocketServletFactory) - Method in class org.apache.nemo.runtime.master.servlet.WebSocketMetricServlet
- connectSplitterVertexWithoutReplacing(E, E) - Method in class org.apache.nemo.common.dag.DAGBuilder
-
This method adds a information in SplitterVertex's LoopEdge - InternalEdge relationship and connects the Edge without replacing existing mapping relationships.
- connectSplitterVertexWithReplacing(E, E) - Method in class org.apache.nemo.common.dag.DAGBuilder
-
This method replaces current SplitterVertex's LoopEdge - InternalEdge relationship with the new relationship and connects the Edge.
- connectVertices(E) - Method in class org.apache.nemo.common.dag.DAGBuilder
-
Connect vertices at the edge.
- ContainerException - Exception in org.apache.nemo.common.exception
-
ContainerException.
- ContainerException(Throwable) - Constructor for exception org.apache.nemo.common.exception.ContainerException
-
ContainerException.
- CONTAINERFAILEDMSG_FIELD_NUMBER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
- ContainerManager - Class in org.apache.nemo.runtime.master.resource
-
(WARNING) This class is not thread-safe.
- ContainerTypeAwareSchedulingConstraint - Class in org.apache.nemo.runtime.master.scheduler
-
This policy find executors which has corresponding container type.
- contains(Predicate<V>) - Method in class org.apache.nemo.common.dag.DAGBuilder
-
check if the DAGBuilder contains any vertex that satisfies the predicate.
- contains(PCollectionView<T>) - Method in class org.apache.nemo.compiler.frontend.beam.InMemorySideInputReader
- contains(V) - Method in class org.apache.nemo.common.dag.DAGBuilder
-
check if the DAGBuilder contains the vertex.
- containsKey(Class<? extends T>) - Method in class org.apache.nemo.common.ir.executionproperty.ExecutionPropertyMap
- CONTEXTDESCRIPTOR_FIELD_NUMBER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage
- ContextStartHandler() - Constructor for class org.apache.nemo.driver.NemoContext.ContextStartHandler
- ContextStopHandler() - Constructor for class org.apache.nemo.driver.NemoContext.ContextStopHandler
- ControlMessage - Class in org.apache.nemo.runtime.common.comm
- ControlMessage.BlockLocationInfoMsg - Class in org.apache.nemo.runtime.common.comm
-
Protobuf type
protobuf.BlockLocationInfoMsg
- ControlMessage.BlockLocationInfoMsg.Builder - Class in org.apache.nemo.runtime.common.comm
-
Protobuf type
protobuf.BlockLocationInfoMsg
- ControlMessage.BlockLocationInfoMsgOrBuilder - Interface in org.apache.nemo.runtime.common.comm
- ControlMessage.BlockStateChangedMsg - Class in org.apache.nemo.runtime.common.comm
-
Protobuf type
protobuf.BlockStateChangedMsg
- ControlMessage.BlockStateChangedMsg.Builder - Class in org.apache.nemo.runtime.common.comm
-
Protobuf type
protobuf.BlockStateChangedMsg
- ControlMessage.BlockStateChangedMsgOrBuilder - Interface in org.apache.nemo.runtime.common.comm
- ControlMessage.BlockStateFromExecutor - Enum in org.apache.nemo.runtime.common.comm
-
Protobuf enum
protobuf.BlockStateFromExecutor
- ControlMessage.BlockStore - Enum in org.apache.nemo.runtime.common.comm
-
Protobuf enum
protobuf.BlockStore
- ControlMessage.BlockTransferContextDescriptor - Class in org.apache.nemo.runtime.common.comm
-
Protobuf type
protobuf.BlockTransferContextDescriptor
- ControlMessage.BlockTransferContextDescriptor.Builder - Class in org.apache.nemo.runtime.common.comm
-
Protobuf type
protobuf.BlockTransferContextDescriptor
- ControlMessage.BlockTransferContextDescriptorOrBuilder - Interface in org.apache.nemo.runtime.common.comm
- ControlMessage.ByteTransferContextSetupMessage - Class in org.apache.nemo.runtime.common.comm
-
Protobuf type
protobuf.ByteTransferContextSetupMessage
- ControlMessage.ByteTransferContextSetupMessage.Builder - Class in org.apache.nemo.runtime.common.comm
-
Protobuf type
protobuf.ByteTransferContextSetupMessage
- ControlMessage.ByteTransferContextSetupMessageOrBuilder - Interface in org.apache.nemo.runtime.common.comm
- ControlMessage.ByteTransferDataDirection - Enum in org.apache.nemo.runtime.common.comm
-
Messages between Executors
- ControlMessage.ClientToDriverMessage - Class in org.apache.nemo.runtime.common.comm
-
Protobuf type
protobuf.ClientToDriverMessage
- ControlMessage.ClientToDriverMessage.Builder - Class in org.apache.nemo.runtime.common.comm
-
Protobuf type
protobuf.ClientToDriverMessage
- ControlMessage.ClientToDriverMessageOrBuilder - Interface in org.apache.nemo.runtime.common.comm
- ControlMessage.ClientToDriverMessageType - Enum in org.apache.nemo.runtime.common.comm
-
Messages from client to driver
- ControlMessage.ContainerFailedMsg - Class in org.apache.nemo.runtime.common.comm
-
Protobuf type
protobuf.ContainerFailedMsg
- ControlMessage.ContainerFailedMsg.Builder - Class in org.apache.nemo.runtime.common.comm
-
Protobuf type
protobuf.ContainerFailedMsg
- ControlMessage.ContainerFailedMsgOrBuilder - Interface in org.apache.nemo.runtime.common.comm
- ControlMessage.DataCollectMessage - Class in org.apache.nemo.runtime.common.comm
-
Protobuf type
protobuf.DataCollectMessage
- ControlMessage.DataCollectMessage.Builder - Class in org.apache.nemo.runtime.common.comm
-
Protobuf type
protobuf.DataCollectMessage
- ControlMessage.DataCollectMessageOrBuilder - Interface in org.apache.nemo.runtime.common.comm
- ControlMessage.DriverToClientMessage - Class in org.apache.nemo.runtime.common.comm
-
Protobuf type
protobuf.DriverToClientMessage
- ControlMessage.DriverToClientMessage.Builder - Class in org.apache.nemo.runtime.common.comm
-
Protobuf type
protobuf.DriverToClientMessage
- ControlMessage.DriverToClientMessageOrBuilder - Interface in org.apache.nemo.runtime.common.comm
- ControlMessage.DriverToClientMessageType - Enum in org.apache.nemo.runtime.common.comm
-
Messages from driver to client
- ControlMessage.ExecutorFailedMsg - Class in org.apache.nemo.runtime.common.comm
-
Protobuf type
protobuf.ExecutorFailedMsg
- ControlMessage.ExecutorFailedMsg.Builder - Class in org.apache.nemo.runtime.common.comm
-
Protobuf type
protobuf.ExecutorFailedMsg
- ControlMessage.ExecutorFailedMsgOrBuilder - Interface in org.apache.nemo.runtime.common.comm
- ControlMessage.InMasterBroadcastVariableMessage - Class in org.apache.nemo.runtime.common.comm
-
Protobuf type
protobuf.InMasterBroadcastVariableMessage
- ControlMessage.InMasterBroadcastVariableMessage.Builder - Class in org.apache.nemo.runtime.common.comm
-
Protobuf type
protobuf.InMasterBroadcastVariableMessage
- ControlMessage.InMasterBroadcastVariableMessageOrBuilder - Interface in org.apache.nemo.runtime.common.comm
- ControlMessage.LaunchDAGMessage - Class in org.apache.nemo.runtime.common.comm
-
Protobuf type
protobuf.LaunchDAGMessage
- ControlMessage.LaunchDAGMessage.Builder - Class in org.apache.nemo.runtime.common.comm
-
Protobuf type
protobuf.LaunchDAGMessage
- ControlMessage.LaunchDAGMessageOrBuilder - Interface in org.apache.nemo.runtime.common.comm
- ControlMessage.Message - Class in org.apache.nemo.runtime.common.comm
-
Protobuf type
protobuf.Message
- ControlMessage.Message.Builder - Class in org.apache.nemo.runtime.common.comm
-
Protobuf type
protobuf.Message
- ControlMessage.MessageOrBuilder - Interface in org.apache.nemo.runtime.common.comm
- ControlMessage.MessageType - Enum in org.apache.nemo.runtime.common.comm
-
Protobuf enum
protobuf.MessageType
- ControlMessage.Metric - Class in org.apache.nemo.runtime.common.comm
-
Common messages
- ControlMessage.Metric.Builder - Class in org.apache.nemo.runtime.common.comm
-
Common messages
- ControlMessage.MetricMsg - Class in org.apache.nemo.runtime.common.comm
-
Protobuf type
protobuf.MetricMsg
- ControlMessage.MetricMsg.Builder - Class in org.apache.nemo.runtime.common.comm
-
Protobuf type
protobuf.MetricMsg
- ControlMessage.MetricMsgOrBuilder - Interface in org.apache.nemo.runtime.common.comm
- ControlMessage.MetricOrBuilder - Interface in org.apache.nemo.runtime.common.comm
- ControlMessage.NotificationMessage - Class in org.apache.nemo.runtime.common.comm
-
Protobuf type
protobuf.NotificationMessage
- ControlMessage.NotificationMessage.Builder - Class in org.apache.nemo.runtime.common.comm
-
Protobuf type
protobuf.NotificationMessage
- ControlMessage.NotificationMessageOrBuilder - Interface in org.apache.nemo.runtime.common.comm
- ControlMessage.OptimizationType - Enum in org.apache.nemo.runtime.common.comm
-
Protobuf enum
protobuf.OptimizationType
- ControlMessage.PipeInitMessage - Class in org.apache.nemo.runtime.common.comm
-
Protobuf type
protobuf.PipeInitMessage
- ControlMessage.PipeInitMessage.Builder - Class in org.apache.nemo.runtime.common.comm
-
Protobuf type
protobuf.PipeInitMessage
- ControlMessage.PipeInitMessageOrBuilder - Interface in org.apache.nemo.runtime.common.comm
- ControlMessage.PipeLocationInfoMessage - Class in org.apache.nemo.runtime.common.comm
-
Protobuf type
protobuf.PipeLocationInfoMessage
- ControlMessage.PipeLocationInfoMessage.Builder - Class in org.apache.nemo.runtime.common.comm
-
Protobuf type
protobuf.PipeLocationInfoMessage
- ControlMessage.PipeLocationInfoMessageOrBuilder - Interface in org.apache.nemo.runtime.common.comm
- ControlMessage.PipeTransferContextDescriptor - Class in org.apache.nemo.runtime.common.comm
-
Protobuf type
protobuf.PipeTransferContextDescriptor
- ControlMessage.PipeTransferContextDescriptor.Builder - Class in org.apache.nemo.runtime.common.comm
-
Protobuf type
protobuf.PipeTransferContextDescriptor
- ControlMessage.PipeTransferContextDescriptorOrBuilder - Interface in org.apache.nemo.runtime.common.comm
- ControlMessage.RecoverableFailureCause - Enum in org.apache.nemo.runtime.common.comm
-
Protobuf enum
protobuf.RecoverableFailureCause
- ControlMessage.RequestBlockLocationMsg - Class in org.apache.nemo.runtime.common.comm
-
Protobuf type
protobuf.RequestBlockLocationMsg
- ControlMessage.RequestBlockLocationMsg.Builder - Class in org.apache.nemo.runtime.common.comm
-
Protobuf type
protobuf.RequestBlockLocationMsg
- ControlMessage.RequestBlockLocationMsgOrBuilder - Interface in org.apache.nemo.runtime.common.comm
- ControlMessage.RequestBroadcastVariableMessage - Class in org.apache.nemo.runtime.common.comm
-
Protobuf type
protobuf.RequestBroadcastVariableMessage
- ControlMessage.RequestBroadcastVariableMessage.Builder - Class in org.apache.nemo.runtime.common.comm
-
Protobuf type
protobuf.RequestBroadcastVariableMessage
- ControlMessage.RequestBroadcastVariableMessageOrBuilder - Interface in org.apache.nemo.runtime.common.comm
- ControlMessage.RequestPipeLocationMessage - Class in org.apache.nemo.runtime.common.comm
-
Protobuf type
protobuf.RequestPipeLocationMessage
- ControlMessage.RequestPipeLocationMessage.Builder - Class in org.apache.nemo.runtime.common.comm
-
Protobuf type
protobuf.RequestPipeLocationMessage
- ControlMessage.RequestPipeLocationMessageOrBuilder - Interface in org.apache.nemo.runtime.common.comm
- ControlMessage.RunTimePassMessageEntry - Class in org.apache.nemo.runtime.common.comm
-
Protobuf type
protobuf.RunTimePassMessageEntry
- ControlMessage.RunTimePassMessageEntry.Builder - Class in org.apache.nemo.runtime.common.comm
-
Protobuf type
protobuf.RunTimePassMessageEntry
- ControlMessage.RunTimePassMessageEntryOrBuilder - Interface in org.apache.nemo.runtime.common.comm
- ControlMessage.RunTimePassMessageMsg - Class in org.apache.nemo.runtime.common.comm
-
Protobuf type
protobuf.RunTimePassMessageMsg
- ControlMessage.RunTimePassMessageMsg.Builder - Class in org.apache.nemo.runtime.common.comm
-
Protobuf type
protobuf.RunTimePassMessageMsg
- ControlMessage.RunTimePassMessageMsgOrBuilder - Interface in org.apache.nemo.runtime.common.comm
- ControlMessage.ScheduleTaskMsg - Class in org.apache.nemo.runtime.common.comm
-
Messages from Master to Executors
- ControlMessage.ScheduleTaskMsg.Builder - Class in org.apache.nemo.runtime.common.comm
-
Messages from Master to Executors
- ControlMessage.ScheduleTaskMsgOrBuilder - Interface in org.apache.nemo.runtime.common.comm
- ControlMessage.TaskStateChangedMsg - Class in org.apache.nemo.runtime.common.comm
-
Messages from Executors to Master
- ControlMessage.TaskStateChangedMsg.Builder - Class in org.apache.nemo.runtime.common.comm
-
Messages from Executors to Master
- ControlMessage.TaskStateChangedMsgOrBuilder - Interface in org.apache.nemo.runtime.common.comm
- ControlMessage.TaskStateFromExecutor - Enum in org.apache.nemo.runtime.common.comm
-
Protobuf enum
protobuf.TaskStateFromExecutor
- convertBlockState(ControlMessage.BlockStateFromExecutor) - Static method in class org.apache.nemo.runtime.master.BlockManagerMaster
-
Return the corresponding
BlockState.State
for the specifiedControlMessage.BlockStateFromExecutor
. - convertBlockState(BlockState.State) - Static method in class org.apache.nemo.runtime.master.BlockManagerMaster
-
Return the corresponding
ControlMessage.BlockStateFromExecutor
for the specifiedBlockState.State
. - convertFailureCause(ControlMessage.RecoverableFailureCause) - Static method in class org.apache.nemo.runtime.common.message.MessageUtils
- convertFailureCause(TaskState.RecoverableTaskFailureCause) - Static method in class org.apache.nemo.runtime.common.message.MessageUtils
- convertState(TaskState.State) - Static method in class org.apache.nemo.runtime.common.message.MessageUtils
- convertTaskState(ControlMessage.TaskStateFromExecutor) - Static method in class org.apache.nemo.runtime.common.message.MessageUtils
- convertToNonSerPartitions(Serializer, Iterable<SerializedPartition<K>>) - Static method in class org.apache.nemo.runtime.executor.data.DataUtil
-
Converts the serialized
Partition
s in an iterable to non-serialized partitions. - convertToSerPartitions(Serializer, Iterable<NonSerializedPartition<K>>, MemoryPoolAssigner) - Static method in class org.apache.nemo.runtime.executor.data.DataUtil
-
Converts the non-serialized
Partition
s in an iterable to serialized partitions. - copyExecutionPropertiesTo(IREdge) - Method in class org.apache.nemo.common.ir.edge.IREdge
-
Static function to copy executionProperties from an edge to the other.
- copyExecutionPropertiesTo(IRVertex) - Method in class org.apache.nemo.common.ir.vertex.IRVertex
-
Static function to copy executionProperties from a vertex to the other.
- CountWords() - Constructor for class org.apache.nemo.examples.beam.BeamWordCount.CountWords
- create() - Static method in class org.apache.nemo.client.beam.NemoRunner
-
Creates and returns a new NemoRunner with default options.
- create(InputStream) - Method in class org.apache.nemo.common.coder.BytesDecoderFactory
- create(InputStream) - Method in interface org.apache.nemo.common.coder.DecoderFactory
-
Get a decoder instance.
- create(InputStream) - Method in class org.apache.nemo.common.coder.DecoderFactory.DummyDecoderFactory
- create(InputStream) - Method in class org.apache.nemo.common.coder.IntDecoderFactory
- create(InputStream) - Method in class org.apache.nemo.common.coder.LongDecoderFactory
- create(InputStream) - Method in class org.apache.nemo.common.coder.PairDecoderFactory
- create(InputStream) - Method in class org.apache.nemo.compiler.frontend.beam.coder.BeamDecoderFactory
- create(InputStream) - Method in class org.apache.nemo.runtime.executor.datatransfer.NemoEventDecoderFactory
- create(OutputStream) - Method in class org.apache.nemo.common.coder.BytesEncoderFactory
- create(OutputStream) - Method in interface org.apache.nemo.common.coder.EncoderFactory
-
Get an encoder instance.
- create(OutputStream) - Method in class org.apache.nemo.common.coder.EncoderFactory.DummyEncoderFactory
- create(OutputStream) - Method in class org.apache.nemo.common.coder.IntEncoderFactory
- create(OutputStream) - Method in class org.apache.nemo.common.coder.LongEncoderFactory
- create(OutputStream) - Method in class org.apache.nemo.common.coder.PairEncoderFactory
- create(OutputStream) - Method in class org.apache.nemo.compiler.frontend.beam.coder.BeamEncoderFactory
- create(OutputStream) - Method in class org.apache.nemo.runtime.executor.datatransfer.NemoEventEncoderFactory
- create(String) - Static method in class org.apache.nemo.runtime.executor.data.metadata.RemoteFileMetadata
-
Creates a new block metadata.
- create(NemoPipelineOptions) - Static method in class org.apache.nemo.client.beam.NemoRunner
-
Creates and returns a new NemoRunner with specified options.
- createAccumulator() - Method in class org.apache.nemo.compiler.frontend.beam.transform.FinalCombineFn
- createAccumulator() - Method in class org.apache.nemo.compiler.frontend.beam.transform.PartialCombineFn
- createAccumulator() - Method in class org.apache.nemo.examples.beam.AlternatingLeastSquare.TrainingDataCombiner
- createBlock(String) - Method in interface org.apache.nemo.runtime.executor.data.stores.BlockStore
-
Creates a new block.
- createBlock(String) - Method in class org.apache.nemo.runtime.executor.data.stores.GlusterFileStore
- createBlock(String) - Method in class org.apache.nemo.runtime.executor.data.stores.LocalFileStore
- createBlock(String) - Method in class org.apache.nemo.runtime.executor.data.stores.MemoryStore
- createBlock(String) - Method in class org.apache.nemo.runtime.executor.data.stores.SerializedMemoryStore
- createBlock(String, DataStoreProperty.Value) - Method in class org.apache.nemo.runtime.executor.data.BlockManagerWorker
-
Creates a new block.
- createControlEdge(IRVertex, IRVertex) - Static method in class org.apache.nemo.common.Util
-
A control edge enforces an execution ordering between the source vertex and the destination vertex.
- createReader(String, IRVertex, RuntimeEdge) - Method in class org.apache.nemo.runtime.executor.datatransfer.IntermediateDataIOFactory
-
Creates an
InputReader
between two stages. - CreateViewTransform<I,O> - Class in org.apache.nemo.compiler.frontend.beam.transform
-
This transforms emits materialized data for each window.
- CreateViewTransform(ViewFn<Materializations.MultimapView<Void, ?>, O>) - Constructor for class org.apache.nemo.compiler.frontend.beam.transform.CreateViewTransform
-
Constructor of CreateViewTransform.
- CreateViewTransform.MultiView<T> - Class in org.apache.nemo.compiler.frontend.beam.transform
-
Represents
PrimitiveViewT
supplied to theViewFn
. - createWriter(String, RuntimeEdge<?>) - Method in class org.apache.nemo.runtime.executor.datatransfer.IntermediateDataIOFactory
-
Creates an
OutputWriter
between two stages.
D
- DAG<V extends Vertex,E extends Edge<V>> - Class in org.apache.nemo.common.dag
-
DAG implementation.
- DAG(Set<V>, Map<V, Set<E>>, Map<V, Set<E>>, Map<V, LoopVertex>, Map<V, Integer>) - Constructor for class org.apache.nemo.common.dag.DAG
-
Constructor of DAG, called by the DAGBuilder.
- DAG_FIELD_NUMBER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.LaunchDAGMessage
- DAGBuilder<V extends Vertex,E extends Edge<V>> - Class in org.apache.nemo.common.dag
-
DAG Builder.
- DAGBuilder() - Constructor for class org.apache.nemo.common.dag.DAGBuilder
-
Constructor of DAGBuilder: it initializes everything.
- DAGBuilder(DAG<V, E>) - Constructor for class org.apache.nemo.common.dag.DAGBuilder
-
Constructor of DAGBuilder with a DAG to start from.
- DAGDirectory() - Constructor for class org.apache.nemo.conf.JobConf.DAGDirectory
- DAGInterface<V extends Vertex,E extends Edge<V>> - Interface in org.apache.nemo.common.dag
-
Methods for querying a directed-acyclic graph (DAG).
- DAGInterface.TraversalOrder - Enum in org.apache.nemo.common.dag
-
Indicates the traversal order of this DAG.
- DATA_FIELD_NUMBER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.DataCollectMessage
- DATA_FIELD_NUMBER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.NotificationMessage
- DataCollected - org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessageType
-
DataCollected = 2;
- DATACOLLECTED_FIELD_NUMBER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessage
- DATACOLLECTED_FIELD_NUMBER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
- DataCollected_VALUE - Static variable in enum org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessageType
-
DataCollected = 2;
- DATADIRECTION_FIELD_NUMBER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage
- DataFetcherOutputCollector<O> - Class in org.apache.nemo.runtime.executor.datatransfer
-
This collector receives data from DataFetcher and forwards it to the next operator.
- DataFetcherOutputCollector(OperatorVertex, int, InputWatermarkManager) - Constructor for class org.apache.nemo.runtime.executor.datatransfer.DataFetcherOutputCollector
-
It forwards output to the next operator.
- DataFlowProperty - Class in org.apache.nemo.common.ir.edge.executionproperty
-
DataFlowModel ExecutionProperty.
- DataFlowProperty.Value - Enum in org.apache.nemo.common.ir.edge.executionproperty
-
Possible values of DataFlowModel ExecutionProperty.
- DataPersistenceProperty - Class in org.apache.nemo.common.ir.edge.executionproperty
-
Data persistence ExecutionProperty.
- DataPersistenceProperty.Value - Enum in org.apache.nemo.common.ir.edge.executionproperty
-
Possible options for the data persistence strategy.
- DataPlaneConf - Class in org.apache.nemo.conf
-
Data plane Configuration for Executors.
- DataSkewPolicy - Class in org.apache.nemo.compiler.optimizer.policy
-
A policy to perform data skew dynamic optimization.
- DataSkewPolicy() - Constructor for class org.apache.nemo.compiler.optimizer.policy.DataSkewPolicy
-
Default constructor.
- DataSourceException - Exception in org.apache.nemo.common.exception
-
DataSourceException Thrown when any exception occurs in data sources.
- DataSourceException(Throwable) - Constructor for exception org.apache.nemo.common.exception.DataSourceException
-
DataSourceException.
- DataStoreProperty - Class in org.apache.nemo.common.ir.edge.executionproperty
-
DataStore ExecutionProperty.
- DataStoreProperty.Value - Enum in org.apache.nemo.common.ir.edge.executionproperty
-
Possible values of DataStore ExecutionProperty.
- DataTransferEvent - Class in org.apache.nemo.runtime.common.metric
-
Event for data transfer, such as data read or write.
- DataTransferEvent(long, DataTransferEvent.TransferType) - Constructor for class org.apache.nemo.runtime.common.metric.DataTransferEvent
- DataTransferEvent.TransferType - Enum in org.apache.nemo.runtime.common.metric
-
Enum of transfer types.
- dataType() - Method in class org.apache.nemo.examples.spark.sql.JavaUserDefinedUntypedAggregation.MyAverage
-
The data type of the returned value.
- DataUtil - Class in org.apache.nemo.runtime.executor.data
-
Utility methods for data handling (e.g., (de)serialization).
- DataUtil.InputStreamIterator<T> - Class in org.apache.nemo.runtime.executor.data
-
An iterator that emits objects from
InputStream
using the correspondingDecoderFactory
. - DataUtil.IteratorWithNumBytes<T> - Interface in org.apache.nemo.runtime.executor.data
-
Iterator
with interface to access to the number of bytes. - DataUtil.IteratorWithNumBytes.NumBytesNotSupportedException - Exception in org.apache.nemo.runtime.executor.data
-
Exception indicates
DataUtil.IteratorWithNumBytes.getNumSerializedBytes()
orDataUtil.IteratorWithNumBytes.getNumEncodedBytes()
is not supported. - DBAddress() - Constructor for class org.apache.nemo.conf.JobConf.DBAddress
- DBEnabled() - Constructor for class org.apache.nemo.conf.JobConf.DBEnabled
- DBId() - Constructor for class org.apache.nemo.conf.JobConf.DBId
- DBPasswd() - Constructor for class org.apache.nemo.conf.JobConf.DBPasswd
- decode() - Method in interface org.apache.nemo.common.coder.DecoderFactory.Decoder
-
Decodes the a value from the given input stream.
- decode(InputStream) - Method in class org.apache.nemo.compiler.frontend.beam.coder.SideInputCoder
- decode(InputStream) - Method in class org.apache.nemo.examples.beam.FloatArrayCoder
- decode(InputStream) - Method in class org.apache.nemo.examples.beam.IntArrayCoder
- decode(InputStream) - Method in class org.apache.nemo.examples.beam.ObjectCoderForString
- DecoderFactory<T> - Interface in org.apache.nemo.common.coder
-
A decoder factory object which generates decoders that decode byte streams into values of type
T
. - DecoderFactory.Decoder<T> - Interface in org.apache.nemo.common.coder
-
Interface of Decoder.
- DecoderFactory.DummyDecoderFactory - Class in org.apache.nemo.common.coder
-
Dummy coder factory implementation which is not supposed to be used.
- DecoderProperty - Class in org.apache.nemo.common.ir.edge.executionproperty
-
Decoder ExecutionProperty.
- DecodeStreamChainer - Interface in org.apache.nemo.runtime.executor.data.streamchainer
-
A
DecodeStreamChainer
object indicates each stream manipulation strategy. - DecompressionProperty - Class in org.apache.nemo.common.ir.edge.executionproperty
-
Decompression ExecutionProperty.
- DecompressionStreamChainer - Class in org.apache.nemo.runtime.executor.data.streamchainer
-
DecodeStreamChainer
for applying compression. - DecompressionStreamChainer(CompressionProperty.Value) - Constructor for class org.apache.nemo.runtime.executor.data.streamchainer.DecompressionStreamChainer
-
Constructor.
- decreaseMaxNumberOfIterations() - Method in class org.apache.nemo.common.ir.vertex.LoopVertex
-
decrease the value of maximum number of iterations by 1.
- DEDICATED_KEY_PER_ELEMENT - org.apache.nemo.common.ir.edge.executionproperty.PartitionerProperty.Type
- DedicatedKeyPerElement - Annotation Type in org.apache.nemo.common.partitioner
-
Declares that all of the designated keys for each element in a
Partitioner
is dedicated for the element. - DedicatedKeyPerElementPartitioner - Class in org.apache.nemo.common.partitioner
-
An implementation of
Partitioner
which assigns a dedicated key per an output data from a task. - DedicatedKeyPerElementPartitioner() - Constructor for class org.apache.nemo.common.partitioner.DedicatedKeyPerElementPartitioner
-
Constructor.
- DefaultCompositePass - Class in org.apache.nemo.compiler.optimizer.pass.compiletime.composite
-
A series of primitive passes that is applied commonly to all policies.
- DefaultCompositePass() - Constructor for class org.apache.nemo.compiler.optimizer.pass.compiletime.composite.DefaultCompositePass
-
Default constructor.
- DefaultDataPersistencePass - Class in org.apache.nemo.compiler.optimizer.pass.compiletime.annotating
-
Pass for initiating IREdge data persistence ExecutionProperty with default values.
- DefaultDataPersistencePass() - Constructor for class org.apache.nemo.compiler.optimizer.pass.compiletime.annotating.DefaultDataPersistencePass
-
Default constructor.
- DefaultDataStorePass - Class in org.apache.nemo.compiler.optimizer.pass.compiletime.annotating
-
Edge data store pass to process inter-stage memory store edges.
- DefaultDataStorePass() - Constructor for class org.apache.nemo.compiler.optimizer.pass.compiletime.annotating.DefaultDataStorePass
-
Default constructor.
- DefaultEdgeDecoderPass - Class in org.apache.nemo.compiler.optimizer.pass.compiletime.annotating
-
Pass for initiating IREdge Decoder ExecutionProperty with default dummy coder.
- DefaultEdgeDecoderPass() - Constructor for class org.apache.nemo.compiler.optimizer.pass.compiletime.annotating.DefaultEdgeDecoderPass
-
Default constructor.
- DefaultEdgeEncoderPass - Class in org.apache.nemo.compiler.optimizer.pass.compiletime.annotating
-
Pass for initiating IREdge Encoder ExecutionProperty with default dummy coder.
- DefaultEdgeEncoderPass() - Constructor for class org.apache.nemo.compiler.optimizer.pass.compiletime.annotating.DefaultEdgeEncoderPass
-
Default constructor.
- DefaultExecutorRepresenter - Class in org.apache.nemo.runtime.master.resource
-
(WARNING) This class is not thread-safe, and thus should only be accessed through ExecutorRegistry.
- DefaultExecutorRepresenter(String, ResourceSpecification, MessageSender<ControlMessage.Message>, ActiveContext, ExecutorService, String) - Constructor for class org.apache.nemo.runtime.master.resource.DefaultExecutorRepresenter
-
Creates a reference to the specified executor.
- DefaultOutputManager<OutputT> - Class in org.apache.nemo.compiler.frontend.beam.transform
-
Default output emitter that uses outputCollector.
- DefaultParallelismPass - Class in org.apache.nemo.compiler.optimizer.pass.compiletime.annotating
-
Optimization pass for tagging parallelism execution property.
- DefaultParallelismPass() - Constructor for class org.apache.nemo.compiler.optimizer.pass.compiletime.annotating.DefaultParallelismPass
-
Default constructor with desired number of source parallelism 1, shuffle decreasing factor 2.
- DefaultParallelismPass(int, int) - Constructor for class org.apache.nemo.compiler.optimizer.pass.compiletime.annotating.DefaultParallelismPass
-
Default constructor.
- DefaultPolicy - Class in org.apache.nemo.compiler.optimizer.policy
-
A basic default policy, that performs the minimum amount of optimization to be done to a specific DAG.
- DefaultPolicy() - Constructor for class org.apache.nemo.compiler.optimizer.policy.DefaultPolicy
-
Default constructor.
- DefaultPolicyWithSeparatePass - Class in org.apache.nemo.compiler.optimizer.policy
-
A simple example policy to demonstrate a policy with a separate, refactored pass.
- DefaultPolicyWithSeparatePass() - Constructor for class org.apache.nemo.compiler.optimizer.policy.DefaultPolicyWithSeparatePass
-
Default constructor.
- DefaultPolicyWithSeparatePass.RefactoredPass - Class in org.apache.nemo.compiler.optimizer.policy
-
A simple custom pass consisted of the two passes at the end of the default pass.
- DefaultScheduleGroupPass - Class in org.apache.nemo.compiler.optimizer.pass.compiletime.annotating
-
A pass for assigning each stages in schedule groups.
- DefaultScheduleGroupPass() - Constructor for class org.apache.nemo.compiler.optimizer.pass.compiletime.annotating.DefaultScheduleGroupPass
-
Default constructor.
- DefaultScheduleGroupPass(boolean, boolean, boolean) - Constructor for class org.apache.nemo.compiler.optimizer.pass.compiletime.annotating.DefaultScheduleGroupPass
-
Constructor.
- delete(IRVertex) - Method in class org.apache.nemo.common.ir.IRDAG
-
Deletes a previously inserted utility vertex.
- deleteBlock(String) - Method in interface org.apache.nemo.runtime.executor.data.stores.BlockStore
-
Deletes a block from this store.
- deleteBlock(String) - Method in class org.apache.nemo.runtime.executor.data.stores.GlusterFileStore
-
Removes the file that the target block is stored.
- deleteBlock(String) - Method in class org.apache.nemo.runtime.executor.data.stores.LocalFileStore
-
Removes the file that the target block is stored.
- deleteBlock(String) - Method in class org.apache.nemo.runtime.executor.data.stores.MemoryStore
- deleteBlock(String) - Method in class org.apache.nemo.runtime.executor.data.stores.SerializedMemoryStore
- deleteFile() - Method in class org.apache.nemo.runtime.executor.data.block.FileBlock
-
Deletes the file that contains this block data.
- deleteMetadata() - Method in class org.apache.nemo.runtime.executor.data.metadata.FileMetadata
-
Deletes the metadata.
- deleteMetadata() - Method in class org.apache.nemo.runtime.executor.data.metadata.LocalFileMetadata
- deleteMetadata() - Method in class org.apache.nemo.runtime.executor.data.metadata.RemoteFileMetadata
- deleteOutputFile(String, String) - Static method in class org.apache.nemo.common.test.ExampleTestUtil
-
Delete output files.
- DeployMode() - Constructor for class org.apache.nemo.conf.JobConf.DeployMode
- deregister() - Method in class org.apache.nemo.runtime.executor.transfer.ByteTransferContext
-
De-registers this context from
ContextManager
. - deserializePartition(int, Serializer, K, InputStream) - Static method in class org.apache.nemo.runtime.executor.data.DataUtil
-
Reads the data of a partition from an input stream and deserializes it.
- deterministic() - Method in class org.apache.nemo.examples.spark.sql.JavaUserDefinedUntypedAggregation.MyAverage
-
Whether this function always returns the same output on the identical input.
- dfsDo(IRVertex, Consumer<IRVertex>, DAGInterface.TraversalOrder, Set<IRVertex>) - Method in class org.apache.nemo.common.ir.IRDAG
- dfsDo(V, Consumer<V>, DAGInterface.TraversalOrder, Set<V>) - Method in class org.apache.nemo.common.dag.DAG
- dfsDo(V, Consumer<V>, DAGInterface.TraversalOrder, Set<V>) - Method in interface org.apache.nemo.common.dag.DAGInterface
-
A recursive helper function for
DAGInterface.dfsTraverse(Consumer, TraversalOrder)
. - dfsTraverse(Consumer<IRVertex>, DAGInterface.TraversalOrder) - Method in class org.apache.nemo.common.ir.IRDAG
- dfsTraverse(Consumer<V>, DAGInterface.TraversalOrder) - Method in class org.apache.nemo.common.dag.DAG
- dfsTraverse(Consumer<V>, DAGInterface.TraversalOrder) - Method in interface org.apache.nemo.common.dag.DAGInterface
-
Traverses the DAG by DFS, applying the given function.
- DirectByteBufferOutputStream - Class in org.apache.nemo.runtime.executor.data
-
This class is a customized output stream implementation backed by
ByteBuffer
, which utilizes off heap memory when writing the data via MemoryPoolAssigner. - DirectByteBufferOutputStream(MemoryPoolAssigner) - Constructor for class org.apache.nemo.runtime.executor.data.DirectByteBufferOutputStream
-
Default constructor.
- DisaggregationEdgeDataStorePass - Class in org.apache.nemo.compiler.optimizer.pass.compiletime.annotating
-
A pass to support Disaggregated Resources by tagging edges.
- DisaggregationEdgeDataStorePass() - Constructor for class org.apache.nemo.compiler.optimizer.pass.compiletime.annotating.DisaggregationEdgeDataStorePass
-
Default constructor.
- DisaggregationPolicy - Class in org.apache.nemo.compiler.optimizer.policy
-
A policy to demonstrate the disaggregation optimization, that uses GlusterFS as file storage.
- DisaggregationPolicy() - Constructor for class org.apache.nemo.compiler.optimizer.policy.DisaggregationPolicy
-
Default constructor.
- DISCARD - org.apache.nemo.common.ir.edge.executionproperty.DataPersistenceProperty.Value
- doCheck(DAG<IRVertex, IREdge>) - Method in class org.apache.nemo.common.ir.IRDAGChecker
-
Applies all of the checkers on the DAG.
- DoFnTransform<InputT,OutputT> - Class in org.apache.nemo.compiler.frontend.beam.transform
-
DoFn transform implementation when there is no side input.
- DoFnTransform(DoFn<InputT, OutputT>, Coder<InputT>, Map<TupleTag<?>, Coder<?>>, TupleTag<OutputT>, List<TupleTag<?>>, WindowingStrategy<?, ?>, PipelineOptions, DisplayData, DoFnSchemaInformation, Map<String, PCollectionView<?>>) - Constructor for class org.apache.nemo.compiler.frontend.beam.transform.DoFnTransform
-
DoFnTransform Constructor.
- doGet(HttpServletRequest, HttpServletResponse) - Method in class org.apache.nemo.runtime.master.servlet.AllMetricServlet
- doGet(HttpServletRequest, HttpServletResponse) - Method in class org.apache.nemo.runtime.master.servlet.JobMetricServlet
- doGet(HttpServletRequest, HttpServletResponse) - Method in class org.apache.nemo.runtime.master.servlet.StageMetricServlet
- doGet(HttpServletRequest, HttpServletResponse) - Method in class org.apache.nemo.runtime.master.servlet.TaskMetricServlet
- DriverEndpoint - Class in org.apache.nemo.client
-
A request endpoint in driver side of a plan.
- DriverEndpoint(PlanStateManager, ClientEndpoint) - Constructor for class org.apache.nemo.client.DriverEndpoint
-
Construct an endpoint in driver side.
- DriverMemMb() - Constructor for class org.apache.nemo.conf.JobConf.DriverMemMb
- DriverReady - org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessageType
-
DriverReady = 1;
- DriverReady_VALUE - Static variable in enum org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessageType
-
DriverReady = 1;
- DriverRPCServer - Class in org.apache.nemo.client
-
Client-side RPC implementation for communication from/to Nemo Driver.
- DriverRPCServer() - Constructor for class org.apache.nemo.client.DriverRPCServer
- DriverShutdown - org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessageType
-
DriverShutdown = 1;
- DriverShutdown_VALUE - Static variable in enum org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessageType
-
DriverShutdown = 1;
- DriverStarted - org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessageType
-
DriverStarted = 0;
- DriverStarted_VALUE - Static variable in enum org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessageType
-
DriverStarted = 0;
- DriverStopHandler() - Constructor for class org.apache.nemo.driver.NemoDriver.DriverStopHandler
- DSTTASKINDEX_FIELD_NUMBER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptor
- DUMMY_DECODER_FACTORY - Static variable in interface org.apache.nemo.common.coder.DecoderFactory
-
Dummy coder factory.
- DUMMY_ENCODER_FACTORY - Static variable in interface org.apache.nemo.common.coder.EncoderFactory
-
Dummy encoder factory.
- DummyDecoderFactory() - Constructor for class org.apache.nemo.common.coder.DecoderFactory.DummyDecoderFactory
- DummyEncoderFactory() - Constructor for class org.apache.nemo.common.coder.EncoderFactory.DummyEncoderFactory
- dumpAllMetricToFile(String) - Method in class org.apache.nemo.runtime.master.metric.MetricStore
-
Same as dumpAllMetricToJson(), but this will save it to the file.
- dumpAllMetricToJson() - Method in class org.apache.nemo.runtime.master.metric.MetricStore
-
Dumps JSON-serialized string of all stored metric.
- dumpMetricToJson(Class<T>) - Method in class org.apache.nemo.runtime.master.metric.MetricStore
-
Dumps JSON-serialized string of specific metric.
- duplicate() - Method in class org.apache.nemo.runtime.executor.data.MemoryChunk
-
Makes the duplicated instance of this MemoryChunk.
- DuplicateEdgeGroupProperty - Class in org.apache.nemo.common.ir.edge.executionproperty
-
Invariant data ExecutionProperty.
- DuplicateEdgeGroupPropertyValue - Class in org.apache.nemo.common.ir.edge.executionproperty
-
Value of DuplicateEdgeGroupProperty.
- DuplicateEdgeGroupPropertyValue(String) - Constructor for class org.apache.nemo.common.ir.edge.executionproperty.DuplicateEdgeGroupPropertyValue
-
Constructor.
- DuplicateEdgeGroupSizePass - Class in org.apache.nemo.compiler.optimizer.pass.compiletime.annotating
-
A pass for annotate duplicate data for each edge.
- DuplicateEdgeGroupSizePass() - Constructor for class org.apache.nemo.compiler.optimizer.pass.compiletime.annotating.DuplicateEdgeGroupSizePass
-
Default constructor.
- DynamicOptimizationException - Exception in org.apache.nemo.common.exception
-
DynamicOptimizationException.
- DynamicOptimizationException(String) - Constructor for exception org.apache.nemo.common.exception.DynamicOptimizationException
-
Constructor of DynamicOptimizationException.
- DynamicOptimizationException(Throwable) - Constructor for exception org.apache.nemo.common.exception.DynamicOptimizationException
-
Constructor of DynamicOptimizationException.
- DynamicTaskSizingPolicy - Class in org.apache.nemo.compiler.optimizer.policy
-
A policy to dynamically resize tasks in runtime.
- DynamicTaskSizingPolicy() - Constructor for class org.apache.nemo.compiler.optimizer.policy.DynamicTaskSizingPolicy
-
Default constructor.
- DynamicTaskSizingRuntimePass - Class in org.apache.nemo.compiler.optimizer.pass.runtime
-
Runtime pass for Dynamic Task Sizing policy.
- DynamicTaskSizingRuntimePass() - Constructor for class org.apache.nemo.compiler.optimizer.pass.runtime.DynamicTaskSizingRuntimePass
-
Default Constructor.
E
- EDGARAvgDocSize - Class in org.apache.nemo.examples.beam
-
Application for EDGAR dataset.
- EDGARDocumentSuccessRate - Class in org.apache.nemo.examples.beam
-
Application for EDGAR dataset.
- EDGARRequestsByCIK - Class in org.apache.nemo.examples.beam
-
Application for EDGAR dataset.
- EDGARTop10BadRefererDocs - Class in org.apache.nemo.examples.beam
-
Application for EDGAR dataset.
- EDGARTop10BadRefererDocs.ValueComparator<K> - Class in org.apache.nemo.examples.beam
-
Value comparator comparing the double value.
- EDGARTop10Documents - Class in org.apache.nemo.examples.beam
-
Application for EDGAR dataset.
- EDGARTop10Documents.ValueComparator<K> - Class in org.apache.nemo.examples.beam
-
Value comparator comparing the long value.
- Edge<V extends Vertex> - Class in org.apache.nemo.common.dag
-
Connects two vertices of a DAG.
- Edge(String, V, V) - Constructor for class org.apache.nemo.common.dag.Edge
-
Constructor for Edge.
- EdgeExecutionProperty<T extends java.io.Serializable> - Class in org.apache.nemo.common.ir.executionproperty
-
ExecutionProperty
forIREdge
. - EdgeExecutionProperty(T) - Constructor for class org.apache.nemo.common.ir.executionproperty.EdgeExecutionProperty
-
Default constructor.
- emit(Object) - Method in class org.apache.nemo.runtime.executor.datatransfer.OperatorWatermarkCollector
- emit(String, Object) - Method in class org.apache.nemo.runtime.executor.datatransfer.OperatorWatermarkCollector
- emit(String, T) - Method in interface org.apache.nemo.common.ir.OutputCollector
-
Multi-destination emit.
- emit(String, T) - Method in class org.apache.nemo.compiler.frontend.beam.transform.GBKTransform.GBKOutputCollector
-
Emit output value to
dstVertexId
. - emit(String, T) - Method in class org.apache.nemo.runtime.executor.datatransfer.DataFetcherOutputCollector
- emit(String, T) - Method in class org.apache.nemo.runtime.executor.datatransfer.OperatorVertexOutputCollector
- emit(String, T) - Method in class org.apache.nemo.runtime.executor.datatransfer.RunTimeMessageOutputCollector
- emit(O) - Method in interface org.apache.nemo.common.ir.OutputCollector
-
Single-destination emit.
- emit(O) - Method in class org.apache.nemo.runtime.executor.datatransfer.DataFetcherOutputCollector
- emit(O) - Method in class org.apache.nemo.runtime.executor.datatransfer.OperatorVertexOutputCollector
- emit(O) - Method in class org.apache.nemo.runtime.executor.datatransfer.RunTimeMessageOutputCollector
- emit(WindowedValue<KV<K, OutputT>>) - Method in class org.apache.nemo.compiler.frontend.beam.transform.GBKTransform.GBKOutputCollector
-
Emit output.
- emitLatencymark(LatencyMark) - Method in interface org.apache.nemo.common.ir.OutputCollector
-
Emit latencymark to downstream vertices.
- emitLatencymark(LatencyMark) - Method in class org.apache.nemo.compiler.frontend.beam.transform.GBKTransform.GBKOutputCollector
-
Emit latencymark.
- emitLatencymark(LatencyMark) - Method in class org.apache.nemo.runtime.executor.datatransfer.DataFetcherOutputCollector
- emitLatencymark(LatencyMark) - Method in class org.apache.nemo.runtime.executor.datatransfer.OperatorVertexOutputCollector
- emitLatencymark(LatencyMark) - Method in class org.apache.nemo.runtime.executor.datatransfer.OperatorWatermarkCollector
- emitLatencymark(LatencyMark) - Method in class org.apache.nemo.runtime.executor.datatransfer.RunTimeMessageOutputCollector
- emitWatermark(Watermark) - Method in interface org.apache.nemo.common.ir.OutputCollector
-
Emit watermark to downstream vertices.
- emitWatermark(Watermark) - Method in class org.apache.nemo.compiler.frontend.beam.transform.GBKTransform.GBKOutputCollector
-
Emit watermark.
- emitWatermark(Watermark) - Method in class org.apache.nemo.runtime.executor.datatransfer.DataFetcherOutputCollector
- emitWatermark(Watermark) - Method in class org.apache.nemo.runtime.executor.datatransfer.OperatorVertexOutputCollector
- emitWatermark(Watermark) - Method in class org.apache.nemo.runtime.executor.datatransfer.OperatorWatermarkCollector
- emitWatermark(Watermark) - Method in class org.apache.nemo.runtime.executor.datatransfer.RunTimeMessageOutputCollector
- Employee() - Constructor for class org.apache.nemo.examples.spark.sql.JavaUserDefinedTypedAggregation.Employee
- EMPTY_DAG_DIRECTORY - Static variable in class org.apache.nemo.common.dag.DAG
- EMPTY_TRANSFORM - Static variable in class org.apache.nemo.common.test.EmptyComponents
- EmptyComponents - Class in org.apache.nemo.common.test
-
Empty components to mock transform and source, for tests and examples.
- EmptyComponents.EmptySourceVertex<T> - Class in org.apache.nemo.common.test
-
An empty Source Vertex.
- EmptyComponents.EmptyTransform<I,O> - Class in org.apache.nemo.common.test
-
An empty transform.
- EmptySourceVertex(String) - Constructor for class org.apache.nemo.common.test.EmptyComponents.EmptySourceVertex
-
Constructor.
- EmptySourceVertex(String, int) - Constructor for class org.apache.nemo.common.test.EmptyComponents.EmptySourceVertex
-
Constructor.
- EmptyTransform(String) - Constructor for class org.apache.nemo.common.test.EmptyComponents.EmptyTransform
-
Default constructor.
- EnableDynamicTaskSizingProperty - Class in org.apache.nemo.common.ir.vertex.executionproperty
-
Property to enable dynamic task sizing policy.
- EnableDynamicTaskSizingProperty(Boolean) - Constructor for class org.apache.nemo.common.ir.vertex.executionproperty.EnableDynamicTaskSizingProperty
-
Default constructor.
- encode(float[], OutputStream) - Method in class org.apache.nemo.examples.beam.FloatArrayCoder
- encode(int[], OutputStream) - Method in class org.apache.nemo.examples.beam.IntArrayCoder
- encode(Object, OutputStream) - Method in class org.apache.nemo.examples.beam.ObjectCoderForString
- encode(SideInputElement<T>, OutputStream) - Method in class org.apache.nemo.compiler.frontend.beam.coder.SideInputCoder
- encode(T) - Method in interface org.apache.nemo.common.coder.EncoderFactory.Encoder
-
Encodes the given value onto the specified output stream.
- EncoderFactory<T> - Interface in org.apache.nemo.common.coder
-
A encoder factory object which generates encoders that encode values of type
T
into byte streams. - EncoderFactory.DummyEncoderFactory - Class in org.apache.nemo.common.coder
-
Dummy encoder factory implementation which is not supposed to be used.
- EncoderFactory.Encoder<T> - Interface in org.apache.nemo.common.coder
-
Interface of Encoder.
- EncoderProperty - Class in org.apache.nemo.common.ir.edge.executionproperty
-
Encoder ExecutionProperty.
- EncodeStreamChainer - Interface in org.apache.nemo.runtime.executor.data.streamchainer
-
A
EncodeStreamChainer
object indicates each stream manipulation strategy. - ensureALSOutputValidity(String, String, String) - Static method in class org.apache.nemo.common.test.ExampleTestUtil
-
This method test the output validity of AlternatingLeastSquareITCase.
- ensureOutputValidity(String, String, String) - Static method in class org.apache.nemo.common.test.ExampleTestUtil
-
Ensures output correctness with the given test resource file.
- enterCompositeTransform(TransformHierarchy.Node) - Method in class org.apache.nemo.compiler.frontend.beam.PipelineVisitor
- ENTRY_FIELD_NUMBER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsg
- EnvironmentType() - Constructor for class org.apache.nemo.conf.JobConf.EnvironmentType
- equals(Object) - Method in class org.apache.nemo.common.HashRange
- equals(Object) - Method in class org.apache.nemo.common.ir.edge.IREdge
- equals(Object) - Method in class org.apache.nemo.common.ir.executionproperty.ExecutionProperty
- equals(Object) - Method in class org.apache.nemo.common.ir.executionproperty.ExecutionPropertyMap
- equals(Object) - Method in class org.apache.nemo.common.ir.vertex.executionproperty.ClonedSchedulingProperty.CloneConf
- equals(Object) - Method in interface org.apache.nemo.common.KeyRange
-
This method should be overridden for KeyRange comparisons.
- equals(Object) - Method in class org.apache.nemo.common.Pair
- equals(Object) - Method in class org.apache.nemo.common.PairKeyExtractor
- equals(Object) - Method in class org.apache.nemo.common.punctuation.LatencyMark
- equals(Object) - Method in class org.apache.nemo.common.punctuation.Watermark
- equals(Object) - Method in class org.apache.nemo.compiler.frontend.spark.SparkKeyExtractor
- equals(Object) - Method in class org.apache.nemo.compiler.optimizer.pass.compiletime.annotating.DefaultParallelismPass
- equals(Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsg
- equals(Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsg
- equals(Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptor
- equals(Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage
- equals(Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessage
- equals(Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ContainerFailedMsg
- equals(Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DataCollectMessage
- equals(Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessage
- equals(Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ExecutorFailedMsg
- equals(Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.InMasterBroadcastVariableMessage
- equals(Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.LaunchDAGMessage
- equals(Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
- equals(Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Metric
- equals(Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.MetricMsg
- equals(Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.NotificationMessage
- equals(Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeInitMessage
- equals(Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeLocationInfoMessage
- equals(Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptor
- equals(Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBlockLocationMsg
- equals(Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBroadcastVariableMessage
- equals(Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestPipeLocationMessage
- equals(Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageEntry
- equals(Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsg
- equals(Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ScheduleTaskMsg
- equals(Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg
- equals(Object) - Method in class org.apache.nemo.runtime.common.comm.GrpcMessageService.Void
- equals(Object) - Method in class org.apache.nemo.runtime.common.plan.StageEdge
- equals(Object) - Method in class org.apache.nemo.runtime.executor.data.FileArea
- evaluate(Row) - Method in class org.apache.nemo.examples.spark.sql.JavaUserDefinedUntypedAggregation.MyAverage
-
Calculates the final result.
- Event - Class in org.apache.nemo.runtime.common.metric
-
Class for all generic event that contains timestamp at the moment.
- Event(long) - Constructor for class org.apache.nemo.runtime.common.metric.Event
-
Constructor.
- ExampleTestArgs - Class in org.apache.nemo.common.test
-
Test Arguments for Examples.
- ExampleTestUtil - Class in org.apache.nemo.common.test
-
Test Utils for Examples.
- EXCEPTION_FIELD_NUMBER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.ExecutorFailedMsg
- execute() - Method in class org.apache.nemo.runtime.executor.task.TaskExecutor
-
Execute a task, while handling unrecoverable errors and exceptions.
- execute(PhysicalPlan, int) - Method in class org.apache.nemo.runtime.master.RuntimeMaster
-
Submits the
PhysicalPlan
to Runtime. - EXECUTING - org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateFromExecutor
-
EXECUTING = 1;
- EXECUTING - org.apache.nemo.runtime.common.state.PlanState.State
- EXECUTING - org.apache.nemo.runtime.common.state.TaskState.State
- EXECUTING_VALUE - Static variable in enum org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateFromExecutor
-
EXECUTING = 1;
- ExecutionDone - org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessageType
-
ExecutionDone = 3;
- ExecutionDone_VALUE - Static variable in enum org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessageType
-
ExecutionDone = 3;
- ExecutionProperty<T extends java.io.Serializable> - Class in org.apache.nemo.common.ir.executionproperty
-
An abstract class for each execution factors.
- ExecutionProperty(T) - Constructor for class org.apache.nemo.common.ir.executionproperty.ExecutionProperty
-
Default constructor.
- ExecutionPropertyMap<T extends ExecutionProperty> - Class in org.apache.nemo.common.ir.executionproperty
-
ExecutionPropertyMap Class, which uses HashMap for keeping track of ExecutionProperties for vertices and edges.
- ExecutionPropertyMap(String) - Constructor for class org.apache.nemo.common.ir.executionproperty.ExecutionPropertyMap
-
Constructor for ExecutionPropertyMap class.
- Executor - Class in org.apache.nemo.runtime.executor
-
Executor.
- EXECUTOR_CONF - Static variable in class org.apache.nemo.conf.JobConf
- EXECUTOR_ID - Static variable in class org.apache.nemo.conf.JobConf
- EXECUTOR_MESSAGE_LISTENER_ID - Static variable in interface org.apache.nemo.runtime.common.message.MessageEnvironment
- ExecutorDataCollected - org.apache.nemo.runtime.common.comm.ControlMessage.MessageType
-
ExecutorDataCollected = 7;
- ExecutorDataCollected_VALUE - Static variable in enum org.apache.nemo.runtime.common.comm.ControlMessage.MessageType
-
ExecutorDataCollected = 7;
- ExecutorFailed - org.apache.nemo.runtime.common.comm.ControlMessage.MessageType
-
ExecutorFailed = 6;
- ExecutorFailed_VALUE - Static variable in enum org.apache.nemo.runtime.common.comm.ControlMessage.MessageType
-
ExecutorFailed = 6;
- EXECUTORFAILEDMSG_FIELD_NUMBER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
- ExecutorId() - Constructor for class org.apache.nemo.conf.JobConf.ExecutorId
- EXECUTORID_FIELD_NUMBER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsg
- EXECUTORID_FIELD_NUMBER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.ContainerFailedMsg
- EXECUTORID_FIELD_NUMBER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.ExecutorFailedMsg
- EXECUTORID_FIELD_NUMBER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeInitMessage
- EXECUTORID_FIELD_NUMBER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeLocationInfoMessage
- EXECUTORID_FIELD_NUMBER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBlockLocationMsg
- EXECUTORID_FIELD_NUMBER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBroadcastVariableMessage
- EXECUTORID_FIELD_NUMBER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestPipeLocationMessage
- EXECUTORID_FIELD_NUMBER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg
- ExecutorJSONContents() - Constructor for class org.apache.nemo.conf.JobConf.ExecutorJSONContents
- ExecutorJSONPath() - Constructor for class org.apache.nemo.conf.JobConf.ExecutorJSONPath
- ExecutorMemoryMb() - Constructor for class org.apache.nemo.conf.JobConf.ExecutorMemoryMb
- ExecutorPoisonSec() - Constructor for class org.apache.nemo.conf.JobConf.ExecutorPoisonSec
- ExecutorRegistry - Class in org.apache.nemo.runtime.master.scheduler
-
(WARNING) This class must be thread-safe.
- ExecutorRepresenter - Interface in org.apache.nemo.runtime.master.resource
-
Contains information/state regarding an executor Such information may include a) The executor's resource type.
- ExecutorType() - Constructor for class org.apache.nemo.conf.JobConf.ExecutorType
- expand(PCollection<String>) - Method in class org.apache.nemo.examples.beam.BeamWordCount.CountWords
- expand(PCollection<String>) - Method in class org.apache.nemo.examples.beam.WriteOneFilePerWindow
- expand(PCollection<KV<Integer, float[]>>) - Method in class org.apache.nemo.examples.beam.AlternatingLeastSquare.UpdateUserAndItemMatrix
- expand(PCollection<KV<Integer, float[]>>) - Method in class org.apache.nemo.examples.beam.AlternatingLeastSquareInefficient.UpdateUserAndItemMatrix
- expand(PCollection<KV<Integer, List<Double>>>) - Method in class org.apache.nemo.examples.beam.MultinomialLogisticRegression.UpdateModel
- extractKey(Object) - Method in interface org.apache.nemo.common.KeyExtractor
-
Extracts key.
- extractKey(Object) - Method in class org.apache.nemo.common.PairKeyExtractor
- extractKey(Object) - Method in class org.apache.nemo.compiler.frontend.spark.SparkKeyExtractor
- extractOutput(AccumT) - Method in class org.apache.nemo.compiler.frontend.beam.transform.FinalCombineFn
- extractOutput(AccumT) - Method in class org.apache.nemo.compiler.frontend.beam.transform.PartialCombineFn
- extractOutput(List<KV<int[], float[]>>) - Method in class org.apache.nemo.examples.beam.AlternatingLeastSquare.TrainingDataCombiner
F
- FAILED - org.apache.nemo.runtime.common.state.PlanState.State
- FAILED - org.apache.nemo.runtime.common.state.TaskState.State
- FAILED_RECOVERABLE - org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateFromExecutor
-
FAILED_RECOVERABLE = 3;
- FAILED_RECOVERABLE_VALUE - Static variable in enum org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateFromExecutor
-
FAILED_RECOVERABLE = 3;
- FAILED_UNRECOVERABLE - org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateFromExecutor
-
FAILED_UNRECOVERABLE = 4;
- FAILED_UNRECOVERABLE_VALUE - Static variable in enum org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateFromExecutor
-
FAILED_UNRECOVERABLE = 4;
- FailedContextHandler() - Constructor for class org.apache.nemo.driver.NemoDriver.FailedContextHandler
- FailedEvaluatorHandler() - Constructor for class org.apache.nemo.driver.NemoDriver.FailedEvaluatorHandler
- FailedMessageSender - Class in org.apache.nemo.runtime.common.message
-
A message sender that failed.
- FailedMessageSender() - Constructor for class org.apache.nemo.runtime.common.message.FailedMessageSender
- FAILURECAUSE_FIELD_NUMBER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg
- fetchProjectRootPath() - Static method in class org.apache.nemo.common.Util
-
Finds the project root path.
- FileArea - Class in org.apache.nemo.runtime.executor.data
-
A file area descriptor.
- FileArea(String, long, long) - Constructor for class org.apache.nemo.runtime.executor.data.FileArea
-
Creates a file area.
- FileBlock<K extends java.io.Serializable> - Class in org.apache.nemo.runtime.executor.data.block
-
This class represents a block which is stored in (local or remote) file.
- FileBlock(String, Serializer, String, FileMetadata<K>, MemoryPoolAssigner) - Constructor for class org.apache.nemo.runtime.executor.data.block.FileBlock
-
Constructor.
- FileDirectory() - Constructor for class org.apache.nemo.conf.JobConf.FileDirectory
- FileMetadata<K extends java.io.Serializable> - Class in org.apache.nemo.runtime.executor.data.metadata
-
This class represents a metadata for a
Block
. - FileMetadata() - Constructor for class org.apache.nemo.runtime.executor.data.metadata.FileMetadata
-
Construct a new file metadata.
- FileMetadata(List<PartitionMetadata<K>>) - Constructor for class org.apache.nemo.runtime.executor.data.metadata.FileMetadata
-
Construct a file metadata with existing partition metadata.
- filterEnvironmentTypeString(String) - Static method in class org.apache.nemo.compiler.optimizer.OptimizerUtils
-
Method to infiltrate keyword-containing string into the enum of Types above.
- filterVertices(Predicate<IRVertex>) - Method in class org.apache.nemo.common.ir.IRDAG
- filterVertices(Predicate<V>) - Method in class org.apache.nemo.common.dag.DAG
- filterVertices(Predicate<V>) - Method in interface org.apache.nemo.common.dag.DAGInterface
-
Filters the vertices according to the given condition.
- FinalCombineFn<AccumT,Output> - Class in org.apache.nemo.compiler.frontend.beam.transform
-
Wrapper class for
Combine.CombineFn
. - FinalCombineFn(Combine.CombineFn<?, AccumT, Output>, Coder<AccumT>) - Constructor for class org.apache.nemo.compiler.frontend.beam.transform.FinalCombineFn
- finish(JavaUserDefinedTypedAggregation.Average) - Method in class org.apache.nemo.examples.spark.sql.JavaUserDefinedTypedAggregation.MyAverage
-
Transform the output of the reduction.
- Finishmark - Class in org.apache.nemo.common.punctuation
-
Finish mark that notifies the data fetching is finished.
- flatten(List<List>) - Static method in class org.apache.nemo.runtime.common.RuntimeTestUtil
-
Flattens a nested list of elements.
- FlattenTransform<T> - Class in org.apache.nemo.compiler.frontend.beam.transform
-
Flatten transform implementation.
- FlattenTransform() - Constructor for class org.apache.nemo.compiler.frontend.beam.transform.FlattenTransform
-
FlattenTransform Constructor.
- FloatArrayCoder - Class in org.apache.nemo.examples.beam
-
EncoderFactory for float[].
- flush() - Method in class org.apache.nemo.driver.RemoteClientMessageLoggingHandler
- flush() - Method in class org.apache.nemo.runtime.executor.MetricManagerWorker
- flush() - Method in interface org.apache.nemo.runtime.executor.MetricMessageSender
-
Flush all metric inside of the queue.
- flushMetrics() - Method in class org.apache.nemo.runtime.master.RuntimeMaster
-
Flush metrics.
- forEachProperties(Consumer<? super T>) - Method in class org.apache.nemo.common.ir.executionproperty.ExecutionPropertyMap
-
Same as forEach function in Java 8, but for execution properties.
- forkInjector(Injector) - Static method in class org.apache.nemo.runtime.common.message.local.LocalMessageDispatcher
- forkInjector(Injector, String) - Static method in class org.apache.nemo.runtime.common.message.local.LocalMessageEnvironment
- FormatAsTextFn() - Constructor for class org.apache.nemo.examples.beam.BeamWordCount.FormatAsTextFn
- forNumber(int) - Static method in enum org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateFromExecutor
- forNumber(int) - Static method in enum org.apache.nemo.runtime.common.comm.ControlMessage.BlockStore
- forNumber(int) - Static method in enum org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferDataDirection
- forNumber(int) - Static method in enum org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessageType
- forNumber(int) - Static method in enum org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessageType
- forNumber(int) - Static method in enum org.apache.nemo.runtime.common.comm.ControlMessage.MessageType
- forNumber(int) - Static method in enum org.apache.nemo.runtime.common.comm.ControlMessage.OptimizationType
- forNumber(int) - Static method in enum org.apache.nemo.runtime.common.comm.ControlMessage.RecoverableFailureCause
- forNumber(int) - Static method in enum org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateFromExecutor
- FreeSlotSchedulingConstraint - Class in org.apache.nemo.runtime.master.scheduler
-
This policy finds executor that has free slot for a Task.
- fromOptions(PipelineOptions) - Static method in class org.apache.nemo.client.beam.NemoRunner
-
Static initializer for creating PipelineRunner with the given options.
G
- GBKOutputCollector(OutputCollector) - Constructor for class org.apache.nemo.compiler.frontend.beam.transform.GBKTransform.GBKOutputCollector
- GBKTransform<K,InputT,OutputT> - Class in org.apache.nemo.compiler.frontend.beam.transform
-
This transform executes GroupByKey transformation and CombinePerKey transformation when input data is unbounded or is not in a global window.
- GBKTransform(Coder<KV<K, InputT>>, Map<TupleTag<?>, Coder<?>>, TupleTag<KV<K, OutputT>>, WindowingStrategy<?, ?>, PipelineOptions, SystemReduceFn, DoFnSchemaInformation, DisplayData, boolean) - Constructor for class org.apache.nemo.compiler.frontend.beam.transform.GBKTransform
- GBKTransform.GBKOutputCollector - Class in org.apache.nemo.compiler.frontend.beam.transform
-
Wrapper class for
OutputCollector
. - generateBlockId(String, String) - Static method in class org.apache.nemo.runtime.common.RuntimeIdManager
-
Generates the ID for a block, whose data is the output of a task attempt.
- generateBlockIdWildcard(String, int) - Static method in class org.apache.nemo.runtime.common.RuntimeIdManager
-
The block ID wildcard indicates to use 'ANY' of the available blocks produced by different task attempts.
- generateDuplicatedEdgeGroupId() - Static method in class org.apache.nemo.common.ir.IdManager
- generateExecutorId() - Static method in class org.apache.nemo.runtime.common.RuntimeIdManager
-
Generates the ID for executor.
- generateMessageId() - Static method in class org.apache.nemo.common.ir.IdManager
- generateMessageId() - Static method in class org.apache.nemo.runtime.common.RuntimeIdManager
-
Generates the ID for a control message.
- generatePhysicalPlan(TestPlanGenerator.PlanType, boolean) - Static method in class org.apache.nemo.runtime.common.plan.TestPlanGenerator
- generatePhysicalPlanId() - Static method in class org.apache.nemo.runtime.common.RuntimeIdManager
-
Generates the ID for physical plan.
- generateResourceSpecId() - Static method in class org.apache.nemo.common.ir.IdManager
-
Generates the ID for a resource specification.
- generateStageId(Integer) - Static method in class org.apache.nemo.runtime.common.RuntimeIdManager
-
Generates the ID for
Stage
. - generateTaskId(String, int, int) - Static method in class org.apache.nemo.runtime.common.RuntimeIdManager
-
Generates the ID for a task.
- get() - Static method in class org.apache.nemo.common.ir.IRDAGChecker
- get() - Method in class org.apache.nemo.compiler.frontend.beam.transform.CreateViewTransform.MultiView
- get(int) - Method in class org.apache.nemo.runtime.executor.data.MemoryChunk
-
Reads the byte at the given index.
- get(int, byte[]) - Method in class org.apache.nemo.runtime.executor.data.MemoryChunk
-
Copies the data of the MemoryChunk from the specified position to target byte array.
- get(int, byte[], int, int) - Method in class org.apache.nemo.runtime.executor.data.MemoryChunk
-
Bulk get method using nk.the specified index in the MemoryChunk.
- get(Serializable) - Method in class org.apache.nemo.runtime.executor.data.BroadcastManagerWorker
-
Get the variable with the id.
- get(Class<? extends ExecutionProperty<U>>) - Method in class org.apache.nemo.common.ir.executionproperty.ExecutionPropertyMap
-
Get the value of the given execution property type.
- get(Class<? extends VertexExecutionProperty>) - Method in class org.apache.nemo.runtime.master.scheduler.SchedulingConstraintRegistry
-
Returns
SchedulingConstraint
for the givenVertexExecutionProperty
. - get(Void) - Method in class org.apache.nemo.compiler.frontend.beam.transform.CreateViewTransform.MultiView
- get(PCollectionView<T>, BoundedWindow) - Method in class org.apache.nemo.compiler.frontend.beam.InMemorySideInputReader
- getAccumulatorCoder(CoderRegistry, Coder<AccumT>) - Method in class org.apache.nemo.compiler.frontend.beam.transform.FinalCombineFn
- getAccumulatorCoder(CoderRegistry, Coder<InputT>) - Method in class org.apache.nemo.compiler.frontend.beam.transform.PartialCombineFn
- getAge() - Method in class org.apache.nemo.examples.spark.sql.JavaSparkSQLExample.Person
-
Getter.
- getAll() - Static method in class org.apache.nemo.compiler.frontend.spark.SparkBroadcastVariables
- getAllTaskAttemptIdsToItsState() - Method in class org.apache.nemo.runtime.master.PlanStateManager
- getAllTaskAttemptsOfStage(String) - Method in class org.apache.nemo.runtime.master.PlanStateManager
- getAncestors(String) - Method in class org.apache.nemo.common.dag.DAG
- getAncestors(String) - Method in interface org.apache.nemo.common.dag.DAGInterface
-
Retrieves the ancestors of a vertex.
- getAncestors(String) - Method in class org.apache.nemo.common.ir.IRDAG
- getAssignedLoopVertexOf(IRVertex) - Method in class org.apache.nemo.common.ir.IRDAG
- getAssignedLoopVertexOf(V) - Method in class org.apache.nemo.common.dag.DAG
- getAssignedLoopVertexOf(V) - Method in interface org.apache.nemo.common.dag.DAGInterface
-
Retrieves the wrapping LoopVertex of the vertex.
- getAttemptFromTaskId(String) - Static method in class org.apache.nemo.runtime.common.RuntimeIdManager
-
Extracts the attempt from a task ID.
- getAttemptIdx() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg.Builder
-
required int32 attemptIdx = 6;
- getAttemptIdx() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg
-
required int32 attemptIdx = 6;
- getAttemptIdx() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsgOrBuilder
-
required int32 attemptIdx = 6;
- getAttemptIdx() - Method in class org.apache.nemo.runtime.common.plan.Task
- getBlockHandlers(String, BlockState.State) - Method in class org.apache.nemo.runtime.master.BlockManagerMaster
-
Get handlers of blocks that are in a particular state.
- getBlockId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsg.Builder
-
required string blockId = 2;
- getBlockId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsg
-
required string blockId = 2;
- getBlockId() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsgOrBuilder
-
required string blockId = 2;
- getBlockId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsg.Builder
-
required string blockId = 2;
- getBlockId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsg
-
required string blockId = 2;
- getBlockId() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsgOrBuilder
-
required string blockId = 2;
- getBlockId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptor.Builder
-
required string blockId = 1;
- getBlockId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptor
-
required string blockId = 1;
- getBlockId() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptorOrBuilder
-
required string blockId = 1;
- getBlockId() - Method in exception org.apache.nemo.runtime.common.exception.AbsentBlockException
- getBlockIdBytes() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsg.Builder
-
required string blockId = 2;
- getBlockIdBytes() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsg
-
required string blockId = 2;
- getBlockIdBytes() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsgOrBuilder
-
required string blockId = 2;
- getBlockIdBytes() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsg.Builder
-
required string blockId = 2;
- getBlockIdBytes() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsg
-
required string blockId = 2;
- getBlockIdBytes() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsgOrBuilder
-
required string blockId = 2;
- getBlockIdBytes() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptor.Builder
-
required string blockId = 1;
- getBlockIdBytes() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptor
-
required string blockId = 1;
- getBlockIdBytes() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptorOrBuilder
-
required string blockId = 1;
- getBlockIdWildcard() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBlockLocationMsg.Builder
-
required string blockIdWildcard = 2;
- getBlockIdWildcard() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBlockLocationMsg
-
required string blockIdWildcard = 2;
- getBlockIdWildcard() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.RequestBlockLocationMsgOrBuilder
-
required string blockIdWildcard = 2;
- getBlockIdWildcardBytes() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBlockLocationMsg.Builder
-
required string blockIdWildcard = 2;
- getBlockIdWildcardBytes() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBlockLocationMsg
-
required string blockIdWildcard = 2;
- getBlockIdWildcardBytes() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.RequestBlockLocationMsgOrBuilder
-
required string blockIdWildcard = 2;
- getBlockLocationInfoMsg() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.BlockLocationInfoMsg blockLocationInfoMsg = 9;
- getBlockLocationInfoMsg() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
-
optional .protobuf.BlockLocationInfoMsg blockLocationInfoMsg = 9;
- getBlockLocationInfoMsg() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.MessageOrBuilder
-
optional .protobuf.BlockLocationInfoMsg blockLocationInfoMsg = 9;
- getBlockLocationInfoMsgBuilder() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.BlockLocationInfoMsg blockLocationInfoMsg = 9;
- getBlockLocationInfoMsgOrBuilder() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.BlockLocationInfoMsg blockLocationInfoMsg = 9;
- getBlockLocationInfoMsgOrBuilder() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
-
optional .protobuf.BlockLocationInfoMsg blockLocationInfoMsg = 9;
- getBlockLocationInfoMsgOrBuilder() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.MessageOrBuilder
-
optional .protobuf.BlockLocationInfoMsg blockLocationInfoMsg = 9;
- getBlockMap() - Method in class org.apache.nemo.runtime.executor.data.stores.LocalBlockStore
- getBlockStateChangedMsg() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.BlockStateChangedMsg blockStateChangedMsg = 6;
- getBlockStateChangedMsg() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
-
optional .protobuf.BlockStateChangedMsg blockStateChangedMsg = 6;
- getBlockStateChangedMsg() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.MessageOrBuilder
-
optional .protobuf.BlockStateChangedMsg blockStateChangedMsg = 6;
- getBlockStateChangedMsgBuilder() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.BlockStateChangedMsg blockStateChangedMsg = 6;
- getBlockStateChangedMsgOrBuilder() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.BlockStateChangedMsg blockStateChangedMsg = 6;
- getBlockStateChangedMsgOrBuilder() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
-
optional .protobuf.BlockStateChangedMsg blockStateChangedMsg = 6;
- getBlockStateChangedMsgOrBuilder() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.MessageOrBuilder
-
optional .protobuf.BlockStateChangedMsg blockStateChangedMsg = 6;
- getBlockStore() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptor.Builder
-
required .protobuf.BlockStore blockStore = 2;
- getBlockStore() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptor
-
required .protobuf.BlockStore blockStore = 2;
- getBlockStore() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptorOrBuilder
-
required .protobuf.BlockStore blockStore = 2;
- getBoundedSourceReadTime() - Method in class org.apache.nemo.runtime.common.metric.TaskMetric
-
Method related to bounded source read time.
- getBroadcastId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBroadcastVariableMessage.Builder
-
required bytes broadcastId = 2;
- getBroadcastId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBroadcastVariableMessage
-
required bytes broadcastId = 2;
- getBroadcastId() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.RequestBroadcastVariableMessageOrBuilder
-
required bytes broadcastId = 2;
- getBroadcastVariable(Serializable) - Method in interface org.apache.nemo.common.ir.vertex.transform.Transform.Context
- getBroadcastVariable(Serializable) - Method in class org.apache.nemo.runtime.executor.TransformContextImpl
- getBroadcastVariable(Serializable) - Static method in class org.apache.nemo.runtime.master.BroadcastManagerMaster
- getBroadcastVariableMsg() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.InMasterBroadcastVariableMessage broadcastVariableMsg = 15;
- getBroadcastVariableMsg() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
-
optional .protobuf.InMasterBroadcastVariableMessage broadcastVariableMsg = 15;
- getBroadcastVariableMsg() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.MessageOrBuilder
-
optional .protobuf.InMasterBroadcastVariableMessage broadcastVariableMsg = 15;
- getBroadcastVariableMsgBuilder() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.InMasterBroadcastVariableMessage broadcastVariableMsg = 15;
- getBroadcastVariableMsgOrBuilder() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.InMasterBroadcastVariableMessage broadcastVariableMsg = 15;
- getBroadcastVariableMsgOrBuilder() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
-
optional .protobuf.InMasterBroadcastVariableMessage broadcastVariableMsg = 15;
- getBroadcastVariableMsgOrBuilder() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.MessageOrBuilder
-
optional .protobuf.InMasterBroadcastVariableMessage broadcastVariableMsg = 15;
- getBroadcastVars() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.LaunchDAGMessage.Builder
-
optional bytes broadcastVars = 2;
- getBroadcastVars() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.LaunchDAGMessage
-
optional bytes broadcastVars = 2;
- getBroadcastVars() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.LaunchDAGMessageOrBuilder
-
optional bytes broadcastVars = 2;
- getBuffer() - Method in class org.apache.nemo.common.ByteBufferInputStream
-
Return next non-empty @code{ByteBuffer}.
- getBuffer() - Method in class org.apache.nemo.runtime.executor.data.MemoryChunk
-
Gets the
ByteBuffer
from this MemoryChunk. - getBuilder() - Method in class org.apache.nemo.common.ir.vertex.LoopVertex
- getBuiltJobConf() - Static method in class org.apache.nemo.client.JobLauncher
-
Get the built job configuration.
- getCapacity() - Method in class org.apache.nemo.common.ir.executionproperty.ResourceSpecification
- getChannelClass() - Method in class org.apache.nemo.runtime.common.NativeChannelImplementationSelector
- getChannelClass() - Method in interface org.apache.nemo.runtime.common.NettyChannelImplementationSelector
- getChannelClass() - Method in class org.apache.nemo.runtime.common.NioChannelImplementationSelector
- getChar(int) - Method in class org.apache.nemo.runtime.executor.data.MemoryChunk
-
Reads a char value from the given position.
- getChildren(String) - Method in class org.apache.nemo.common.dag.DAG
- getChildren(String) - Method in interface org.apache.nemo.common.dag.DAGInterface
-
Retrieves the children vertices of the given vertex.
- getChildren(String) - Method in class org.apache.nemo.common.ir.IRDAG
- getChunkSize() - Method in class org.apache.nemo.runtime.executor.data.MemoryPoolAssigner
-
Returns the chunk size of the memory pool.
- getClone() - Method in interface org.apache.nemo.common.Cloneable
-
Creates and returns a copy of this object.
- getClone() - Method in class org.apache.nemo.common.ir.vertex.CachedSourceVertex
- getClone() - Method in class org.apache.nemo.common.ir.vertex.InMemorySourceVertex
- getClone() - Method in class org.apache.nemo.common.ir.vertex.LoopVertex
- getClone() - Method in class org.apache.nemo.common.ir.vertex.OperatorVertex
- getClone() - Method in class org.apache.nemo.common.ir.vertex.utility.SamplingVertex
- getClone() - Method in class org.apache.nemo.common.test.EmptyComponents.EmptySourceVertex
- getClone() - Method in class org.apache.nemo.compiler.frontend.beam.source.BeamBoundedSourceVertex
- getClone() - Method in class org.apache.nemo.compiler.frontend.beam.source.BeamUnboundedSourceVertex
- getCloneOfOriginalEdge(IREdge) - Method in class org.apache.nemo.common.ir.vertex.utility.SamplingVertex
-
Obtains a clone of an original edge that is attached to this sampling vertex.
- getCloneOfOriginalVertex() - Method in class org.apache.nemo.common.ir.vertex.utility.SamplingVertex
- getCoderArguments() - Method in class org.apache.nemo.compiler.frontend.beam.coder.SideInputCoder
- getCollectedData() - Static method in class org.apache.nemo.client.JobLauncher
-
Get the collected data.
- getCompileTimePasses() - Method in class org.apache.nemo.compiler.optimizer.policy.PolicyBuilder
-
Getter for compile time passes.
- getCompletedFuture() - Method in class org.apache.nemo.runtime.executor.transfer.ByteInputContext
-
Returns a future, which is completed when the corresponding transfer for this context gets done.
- getCompletedTaskTimeListMs(String) - Method in class org.apache.nemo.runtime.master.PlanStateManager
-
List of task times so far for this stage.
- getCondition() - Method in class org.apache.nemo.common.pass.Pass
-
Getter for the condition under which to apply the pass.
- getContainerFailedMsg() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.ContainerFailedMsg containerFailedMsg = 11;
- getContainerFailedMsg() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
-
optional .protobuf.ContainerFailedMsg containerFailedMsg = 11;
- getContainerFailedMsg() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.MessageOrBuilder
-
optional .protobuf.ContainerFailedMsg containerFailedMsg = 11;
- getContainerFailedMsgBuilder() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.ContainerFailedMsg containerFailedMsg = 11;
- getContainerFailedMsgOrBuilder() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.ContainerFailedMsg containerFailedMsg = 11;
- getContainerFailedMsgOrBuilder() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
-
optional .protobuf.ContainerFailedMsg containerFailedMsg = 11;
- getContainerFailedMsgOrBuilder() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.MessageOrBuilder
-
optional .protobuf.ContainerFailedMsg containerFailedMsg = 11;
- getContainerId() - Method in class org.apache.nemo.runtime.common.metric.TaskMetric
-
Method related to container Id.
- getContainerType() - Method in class org.apache.nemo.common.ir.executionproperty.ResourceSpecification
- getContainerType() - Method in class org.apache.nemo.runtime.master.resource.DefaultExecutorRepresenter
- getContainerType() - Method in interface org.apache.nemo.runtime.master.resource.ExecutorRepresenter
- getContextDescriptor() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage.Builder
-
required bytes contextDescriptor = 4;
- getContextDescriptor() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage
-
required bytes contextDescriptor = 4;
- getContextDescriptor() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessageOrBuilder
-
required bytes contextDescriptor = 4;
- getContextDescriptor() - Method in class org.apache.nemo.runtime.executor.transfer.ByteTransferContext
- getContextId() - Method in class org.apache.nemo.runtime.executor.transfer.ByteTransferContext
- getConvertedPipeline() - Method in class org.apache.nemo.compiler.frontend.beam.PipelineVisitor
- getCount() - Method in class org.apache.nemo.examples.spark.sql.JavaUserDefinedTypedAggregation.Average
-
Getter.
- getCount() - Method in class org.apache.nemo.runtime.executor.data.FileArea
- getCreatedTaskId() - Method in class org.apache.nemo.common.punctuation.LatencyMark
- getCreatedTimestamp() - Method in class org.apache.nemo.common.punctuation.LatencyMark
- getCurrentState() - Method in class org.apache.nemo.common.StateMachine
- getCurrentTaskExecutionState() - Method in class org.apache.nemo.runtime.executor.TaskStateManager
- getCurrNumEncodedBytes() - Method in class org.apache.nemo.runtime.executor.data.DataUtil.InputStreamIterator
- getCurrNumEncodedBytes() - Method in interface org.apache.nemo.runtime.executor.data.DataUtil.IteratorWithNumBytes
-
This method can be called before the every actual data completely taken from iterator, When the every actual data completely taken from iterator, its return value must be same with a return value of getNumSerializedBytes().
- getCurrNumSerializedBytes() - Method in class org.apache.nemo.runtime.executor.data.DataUtil.InputStreamIterator
- getCurrNumSerializedBytes() - Method in interface org.apache.nemo.runtime.executor.data.DataUtil.IteratorWithNumBytes
-
This method can be called before the every actual data completely taken from iterator, When the every actual data completely taken from iterator, its return value must be same with a return value of getNumSerializedBytes().
- getDag() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.LaunchDAGMessage.Builder
-
required string dag = 1;
- getDag() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.LaunchDAGMessage
-
required string dag = 1;
- getDag() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.LaunchDAGMessageOrBuilder
-
required string dag = 1;
- getDAG() - Method in class org.apache.nemo.common.ir.vertex.LoopVertex
- getDagBytes() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.LaunchDAGMessage.Builder
-
required string dag = 1;
- getDagBytes() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.LaunchDAGMessage
-
required string dag = 1;
- getDagBytes() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.LaunchDAGMessageOrBuilder
-
required string dag = 1;
- getDagIncomingEdges() - Method in class org.apache.nemo.common.ir.vertex.LoopVertex
- getDagOutgoingEdges() - Method in class org.apache.nemo.common.ir.vertex.LoopVertex
- getData() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DataCollectMessage.Builder
-
required string data = 1;
- getData() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DataCollectMessage
-
required string data = 1;
- getData() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.DataCollectMessageOrBuilder
-
required string data = 1;
- getData() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.NotificationMessage.Builder
-
required string data = 2;
- getData() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.NotificationMessage
-
required string data = 2;
- getData() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.NotificationMessageOrBuilder
-
required string data = 2;
- getData() - Method in class org.apache.nemo.runtime.executor.data.partition.NonSerializedPartition
- getData() - Method in interface org.apache.nemo.runtime.executor.data.partition.Partition
- getData() - Method in class org.apache.nemo.runtime.executor.data.partition.SerializedPartition
-
This method should only be used when this partition is residing in on-heap region.
- getDataBytes() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DataCollectMessage.Builder
-
required string data = 1;
- getDataBytes() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DataCollectMessage
-
required string data = 1;
- getDataBytes() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.DataCollectMessageOrBuilder
-
required string data = 1;
- getDataBytes() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.NotificationMessage.Builder
-
required string data = 2;
- getDataBytes() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.NotificationMessage
-
required string data = 2;
- getDataBytes() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.NotificationMessageOrBuilder
-
required string data = 2;
- getDataCollected() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessage.Builder
-
optional .protobuf.DataCollectMessage dataCollected = 2;
- getDataCollected() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessage
-
optional .protobuf.DataCollectMessage dataCollected = 2;
- getDataCollected() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessageOrBuilder
-
optional .protobuf.DataCollectMessage dataCollected = 2;
- getDataCollected() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.DataCollectMessage dataCollected = 13;
- getDataCollected() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
-
optional .protobuf.DataCollectMessage dataCollected = 13;
- getDataCollected() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.MessageOrBuilder
-
optional .protobuf.DataCollectMessage dataCollected = 13;
- getDataCollectedBuilder() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessage.Builder
-
optional .protobuf.DataCollectMessage dataCollected = 2;
- getDataCollectedBuilder() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.DataCollectMessage dataCollected = 13;
- getDataCollectedOrBuilder() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessage.Builder
-
optional .protobuf.DataCollectMessage dataCollected = 2;
- getDataCollectedOrBuilder() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessage
-
optional .protobuf.DataCollectMessage dataCollected = 2;
- getDataCollectedOrBuilder() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessageOrBuilder
-
optional .protobuf.DataCollectMessage dataCollected = 2;
- getDataCollectedOrBuilder() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.DataCollectMessage dataCollected = 13;
- getDataCollectedOrBuilder() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
-
optional .protobuf.DataCollectMessage dataCollected = 13;
- getDataCollectedOrBuilder() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.MessageOrBuilder
-
optional .protobuf.DataCollectMessage dataCollected = 13;
- getDataCommunicationPattern() - Method in class org.apache.nemo.runtime.common.plan.StageEdge
- getDataDirection() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage.Builder
-
required .protobuf.ByteTransferDataDirection dataDirection = 3;
- getDataDirection() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage
-
required .protobuf.ByteTransferDataDirection dataDirection = 3;
- getDataDirection() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessageOrBuilder
-
required .protobuf.ByteTransferDataDirection dataDirection = 3;
- getDataFlowModel() - Method in class org.apache.nemo.runtime.common.plan.StageEdge
- getDataPlaneConfiguration() - Method in class org.apache.nemo.conf.DataPlaneConf
- getDecoderFactory() - Method in class org.apache.nemo.runtime.executor.data.streamchainer.Serializer
- getDecodeStreamChainers() - Method in class org.apache.nemo.runtime.executor.data.streamchainer.Serializer
- getDefaultInstance() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsg
- getDefaultInstance() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsg
- getDefaultInstance() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptor
- getDefaultInstance() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage
- getDefaultInstance() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessage
- getDefaultInstance() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ContainerFailedMsg
- getDefaultInstance() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.DataCollectMessage
- getDefaultInstance() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessage
- getDefaultInstance() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ExecutorFailedMsg
- getDefaultInstance() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.InMasterBroadcastVariableMessage
- getDefaultInstance() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.LaunchDAGMessage
- getDefaultInstance() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
- getDefaultInstance() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.Metric
- getDefaultInstance() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.MetricMsg
- getDefaultInstance() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.NotificationMessage
- getDefaultInstance() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeInitMessage
- getDefaultInstance() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeLocationInfoMessage
- getDefaultInstance() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptor
- getDefaultInstance() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBlockLocationMsg
- getDefaultInstance() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBroadcastVariableMessage
- getDefaultInstance() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestPipeLocationMessage
- getDefaultInstance() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageEntry
- getDefaultInstance() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsg
- getDefaultInstance() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ScheduleTaskMsg
- getDefaultInstance() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg
- getDefaultInstance() - Static method in class org.apache.nemo.runtime.common.comm.GrpcMessageService.Void
- getDefaultInstanceForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsg.Builder
- getDefaultInstanceForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsg
- getDefaultInstanceForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsg.Builder
- getDefaultInstanceForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsg
- getDefaultInstanceForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptor.Builder
- getDefaultInstanceForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptor
- getDefaultInstanceForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage.Builder
- getDefaultInstanceForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage
- getDefaultInstanceForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessage.Builder
- getDefaultInstanceForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessage
- getDefaultInstanceForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ContainerFailedMsg.Builder
- getDefaultInstanceForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ContainerFailedMsg
- getDefaultInstanceForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DataCollectMessage.Builder
- getDefaultInstanceForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DataCollectMessage
- getDefaultInstanceForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessage.Builder
- getDefaultInstanceForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessage
- getDefaultInstanceForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ExecutorFailedMsg.Builder
- getDefaultInstanceForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ExecutorFailedMsg
- getDefaultInstanceForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.InMasterBroadcastVariableMessage.Builder
- getDefaultInstanceForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.InMasterBroadcastVariableMessage
- getDefaultInstanceForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.LaunchDAGMessage.Builder
- getDefaultInstanceForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.LaunchDAGMessage
- getDefaultInstanceForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
- getDefaultInstanceForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
- getDefaultInstanceForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Metric.Builder
- getDefaultInstanceForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Metric
- getDefaultInstanceForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.MetricMsg.Builder
- getDefaultInstanceForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.MetricMsg
- getDefaultInstanceForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.NotificationMessage.Builder
- getDefaultInstanceForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.NotificationMessage
- getDefaultInstanceForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeInitMessage.Builder
- getDefaultInstanceForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeInitMessage
- getDefaultInstanceForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeLocationInfoMessage.Builder
- getDefaultInstanceForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeLocationInfoMessage
- getDefaultInstanceForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptor.Builder
- getDefaultInstanceForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptor
- getDefaultInstanceForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBlockLocationMsg.Builder
- getDefaultInstanceForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBlockLocationMsg
- getDefaultInstanceForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBroadcastVariableMessage.Builder
- getDefaultInstanceForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBroadcastVariableMessage
- getDefaultInstanceForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestPipeLocationMessage.Builder
- getDefaultInstanceForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestPipeLocationMessage
- getDefaultInstanceForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageEntry.Builder
- getDefaultInstanceForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageEntry
- getDefaultInstanceForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsg.Builder
- getDefaultInstanceForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsg
- getDefaultInstanceForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ScheduleTaskMsg.Builder
- getDefaultInstanceForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ScheduleTaskMsg
- getDefaultInstanceForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg.Builder
- getDefaultInstanceForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg
- getDefaultInstanceForType() - Method in class org.apache.nemo.runtime.common.comm.GrpcMessageService.Void.Builder
- getDefaultInstanceForType() - Method in class org.apache.nemo.runtime.common.comm.GrpcMessageService.Void
- getDescendants(String) - Method in class org.apache.nemo.common.dag.DAG
- getDescendants(String) - Method in interface org.apache.nemo.common.dag.DAGInterface
-
Retrieves the descendants of a vertex.
- getDescendants(String) - Method in class org.apache.nemo.common.ir.IRDAG
- getDescriptor() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsg.Builder
- getDescriptor() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsg
- getDescriptor() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsg.Builder
- getDescriptor() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsg
- getDescriptor() - Static method in enum org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateFromExecutor
- getDescriptor() - Static method in enum org.apache.nemo.runtime.common.comm.ControlMessage.BlockStore
- getDescriptor() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptor.Builder
- getDescriptor() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptor
- getDescriptor() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage.Builder
- getDescriptor() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage
- getDescriptor() - Static method in enum org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferDataDirection
- getDescriptor() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessage.Builder
- getDescriptor() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessage
- getDescriptor() - Static method in enum org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessageType
- getDescriptor() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ContainerFailedMsg.Builder
- getDescriptor() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ContainerFailedMsg
- getDescriptor() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.DataCollectMessage.Builder
- getDescriptor() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.DataCollectMessage
- getDescriptor() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessage.Builder
- getDescriptor() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessage
- getDescriptor() - Static method in enum org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessageType
- getDescriptor() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ExecutorFailedMsg.Builder
- getDescriptor() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ExecutorFailedMsg
- getDescriptor() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage
- getDescriptor() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.InMasterBroadcastVariableMessage.Builder
- getDescriptor() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.InMasterBroadcastVariableMessage
- getDescriptor() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.LaunchDAGMessage.Builder
- getDescriptor() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.LaunchDAGMessage
- getDescriptor() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
- getDescriptor() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
- getDescriptor() - Static method in enum org.apache.nemo.runtime.common.comm.ControlMessage.MessageType
- getDescriptor() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.Metric.Builder
- getDescriptor() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.Metric
- getDescriptor() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.MetricMsg.Builder
- getDescriptor() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.MetricMsg
- getDescriptor() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.NotificationMessage.Builder
- getDescriptor() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.NotificationMessage
- getDescriptor() - Static method in enum org.apache.nemo.runtime.common.comm.ControlMessage.OptimizationType
- getDescriptor() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeInitMessage.Builder
- getDescriptor() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeInitMessage
- getDescriptor() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeLocationInfoMessage.Builder
- getDescriptor() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeLocationInfoMessage
- getDescriptor() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptor.Builder
- getDescriptor() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptor
- getDescriptor() - Static method in enum org.apache.nemo.runtime.common.comm.ControlMessage.RecoverableFailureCause
- getDescriptor() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBlockLocationMsg.Builder
- getDescriptor() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBlockLocationMsg
- getDescriptor() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBroadcastVariableMessage.Builder
- getDescriptor() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBroadcastVariableMessage
- getDescriptor() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestPipeLocationMessage.Builder
- getDescriptor() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestPipeLocationMessage
- getDescriptor() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageEntry.Builder
- getDescriptor() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageEntry
- getDescriptor() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsg.Builder
- getDescriptor() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsg
- getDescriptor() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ScheduleTaskMsg.Builder
- getDescriptor() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ScheduleTaskMsg
- getDescriptor() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg.Builder
- getDescriptor() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg
- getDescriptor() - Static method in enum org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateFromExecutor
- getDescriptor() - Static method in class org.apache.nemo.runtime.common.comm.GrpcMessageService
- getDescriptor() - Static method in class org.apache.nemo.runtime.common.comm.GrpcMessageService.Void.Builder
- getDescriptor() - Static method in class org.apache.nemo.runtime.common.comm.GrpcMessageService.Void
- getDescriptorForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsg.Builder
- getDescriptorForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsg.Builder
- getDescriptorForType() - Method in enum org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateFromExecutor
- getDescriptorForType() - Method in enum org.apache.nemo.runtime.common.comm.ControlMessage.BlockStore
- getDescriptorForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptor.Builder
- getDescriptorForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage.Builder
- getDescriptorForType() - Method in enum org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferDataDirection
- getDescriptorForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessage.Builder
- getDescriptorForType() - Method in enum org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessageType
- getDescriptorForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ContainerFailedMsg.Builder
- getDescriptorForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DataCollectMessage.Builder
- getDescriptorForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessage.Builder
- getDescriptorForType() - Method in enum org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessageType
- getDescriptorForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ExecutorFailedMsg.Builder
- getDescriptorForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.InMasterBroadcastVariableMessage.Builder
- getDescriptorForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.LaunchDAGMessage.Builder
- getDescriptorForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
- getDescriptorForType() - Method in enum org.apache.nemo.runtime.common.comm.ControlMessage.MessageType
- getDescriptorForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Metric.Builder
- getDescriptorForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.MetricMsg.Builder
- getDescriptorForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.NotificationMessage.Builder
- getDescriptorForType() - Method in enum org.apache.nemo.runtime.common.comm.ControlMessage.OptimizationType
- getDescriptorForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeInitMessage.Builder
- getDescriptorForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeLocationInfoMessage.Builder
- getDescriptorForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptor.Builder
- getDescriptorForType() - Method in enum org.apache.nemo.runtime.common.comm.ControlMessage.RecoverableFailureCause
- getDescriptorForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBlockLocationMsg.Builder
- getDescriptorForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBroadcastVariableMessage.Builder
- getDescriptorForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestPipeLocationMessage.Builder
- getDescriptorForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageEntry.Builder
- getDescriptorForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsg.Builder
- getDescriptorForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ScheduleTaskMsg.Builder
- getDescriptorForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg.Builder
- getDescriptorForType() - Method in enum org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateFromExecutor
- getDescriptorForType() - Method in class org.apache.nemo.runtime.common.comm.GrpcMessageService.Void.Builder
- getDesiredSampleRate() - Method in class org.apache.nemo.common.ir.vertex.utility.SamplingVertex
- getDirectBufferList() - Method in class org.apache.nemo.runtime.executor.data.partition.SerializedPartition
-
This method is used to emit the output as
SerializedPartition
. - getDoFn() - Method in class org.apache.nemo.compiler.frontend.beam.transform.AbstractDoFnTransform
-
Getter function for DoFn.
- getDouble(int) - Method in class org.apache.nemo.runtime.executor.data.MemoryChunk
-
Reads a double value from the given position, in the system's native byte order.
- getDst() - Method in class org.apache.nemo.common.dag.Edge
- getDstIRVertex() - Method in class org.apache.nemo.runtime.common.plan.StageEdge
- getDstTaskIndex() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptor.Builder
-
required int64 dstTaskIndex = 3;
- getDstTaskIndex() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptor
-
required int64 dstTaskIndex = 3;
- getDstTaskIndex() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptorOrBuilder
-
required int64 dstTaskIndex = 3;
- getDstTaskIndex() - Method in class org.apache.nemo.runtime.executor.transfer.LocalTransferContext
-
Accessor method for the destination task index.
- getEdgeBetween(String, String) - Method in class org.apache.nemo.common.dag.DAG
- getEdgeBetween(String, String) - Method in interface org.apache.nemo.common.dag.DAGInterface
-
Retrieves the edge between two vertices.
- getEdgeBetween(String, String) - Method in class org.apache.nemo.common.ir.IRDAG
- getEdgeById(String) - Method in class org.apache.nemo.common.dag.DAG
- getEdgeById(String) - Method in interface org.apache.nemo.common.dag.DAGInterface
-
Retrieves the edge given its ID.
- getEdgeById(String) - Method in class org.apache.nemo.common.ir.IRDAG
- getEdgeId() - Method in class org.apache.nemo.runtime.executor.transfer.LocalTransferContext
-
Accessor method for the edge id.
- getEdgeIndex() - Method in class org.apache.nemo.runtime.executor.datatransfer.NextIntraTaskOperatorInfo
- getEdgeProperties() - Method in class org.apache.nemo.runtime.common.metric.JobMetric
- getEdges() - Method in class org.apache.nemo.common.dag.DAG
- getEdges() - Method in interface org.apache.nemo.common.dag.DAGInterface
-
Retrieves the edges of this DAG.
- getEdges() - Method in class org.apache.nemo.common.ir.IRDAG
- getEdgesFromOriginalToOutside(DAG<IRVertex, IREdge>) - Method in class org.apache.nemo.common.ir.vertex.utility.TaskSizeSplitterVertex
-
Get edges which come from original vertices to outer destinations by observing the dag.
- getEdgesFromOutsideToOriginal(DAG<IRVertex, IREdge>) - Method in class org.apache.nemo.common.ir.vertex.utility.TaskSizeSplitterVertex
-
Get edges which come to original vertices from outer sources by observing the dag.
- getEdgesFromOutsideToSplitter(DAG<IRVertex, IREdge>) - Method in class org.apache.nemo.common.ir.vertex.utility.TaskSizeSplitterVertex
-
Get edges which come to splitter from outside sources.
- getEdgesFromSplitterToOutside(DAG<IRVertex, IREdge>) - Method in class org.apache.nemo.common.ir.vertex.utility.TaskSizeSplitterVertex
-
Get edges which come out from splitter to outside destinations.
- getEdgeWithInternalVertex(IREdge) - Method in class org.apache.nemo.common.ir.vertex.LoopVertex
- getEdgeWithInternalVertexToEdgeWithLoop() - Method in class org.apache.nemo.common.ir.vertex.LoopVertex
-
Getter method for edgeWithInternalVertexToEdgeWithLoop.
- getEdgeWithLoop(IREdge) - Method in class org.apache.nemo.common.ir.vertex.LoopVertex
- getEdgeWithLoopToEdgeWithInternalVertex() - Method in class org.apache.nemo.common.ir.vertex.LoopVertex
-
Getter method for edgeWithLoopToEdgeWithInternalVertex.
- getElapsedTime() - Method in class org.apache.nemo.runtime.master.scheduler.SimulatedTaskExecutor
- getEnableDynamicTaskSizing() - Method in class org.apache.nemo.runtime.common.plan.Stage
- getEncodedReadBytes() - Method in class org.apache.nemo.runtime.common.metric.TaskMetric
-
Method related to encoded read bytes.
- getEncoderFactory() - Method in class org.apache.nemo.runtime.executor.data.streamchainer.Serializer
- getEncodeStreamChainers() - Method in class org.apache.nemo.runtime.executor.data.streamchainer.Serializer
- getEndTimeStamp() - Method in class org.apache.nemo.runtime.common.metric.StreamMetric
-
Get endpoint of record period.
- getEntry(int) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsg.Builder
-
repeated .protobuf.RunTimePassMessageEntry entry = 2;
- getEntry(int) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsg
-
repeated .protobuf.RunTimePassMessageEntry entry = 2;
- getEntry(int) - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsgOrBuilder
-
repeated .protobuf.RunTimePassMessageEntry entry = 2;
- getEntryBuilder(int) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsg.Builder
-
repeated .protobuf.RunTimePassMessageEntry entry = 2;
- getEntryBuilderList() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsg.Builder
-
repeated .protobuf.RunTimePassMessageEntry entry = 2;
- getEntryCount() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsg.Builder
-
repeated .protobuf.RunTimePassMessageEntry entry = 2;
- getEntryCount() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsg
-
repeated .protobuf.RunTimePassMessageEntry entry = 2;
- getEntryCount() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsgOrBuilder
-
repeated .protobuf.RunTimePassMessageEntry entry = 2;
- getEntryList() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsg.Builder
-
repeated .protobuf.RunTimePassMessageEntry entry = 2;
- getEntryList() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsg
-
repeated .protobuf.RunTimePassMessageEntry entry = 2;
- getEntryList() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsgOrBuilder
-
repeated .protobuf.RunTimePassMessageEntry entry = 2;
- getEntryOrBuilder(int) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsg.Builder
-
repeated .protobuf.RunTimePassMessageEntry entry = 2;
- getEntryOrBuilder(int) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsg
-
repeated .protobuf.RunTimePassMessageEntry entry = 2;
- getEntryOrBuilder(int) - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsgOrBuilder
-
repeated .protobuf.RunTimePassMessageEntry entry = 2;
- getEntryOrBuilderList() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsg.Builder
-
repeated .protobuf.RunTimePassMessageEntry entry = 2;
- getEntryOrBuilderList() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsg
-
repeated .protobuf.RunTimePassMessageEntry entry = 2;
- getEntryOrBuilderList() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsgOrBuilder
-
repeated .protobuf.RunTimePassMessageEntry entry = 2;
- getEstimatedSizeBytes() - Method in class org.apache.nemo.common.ir.vertex.CachedSourceVertex
- getEstimatedSizeBytes() - Method in class org.apache.nemo.common.ir.vertex.InMemorySourceVertex
- getEstimatedSizeBytes() - Method in class org.apache.nemo.common.ir.vertex.SourceVertex
-
Gets the estimated size of bytes.
- getEstimatedSizeBytes() - Method in class org.apache.nemo.common.test.EmptyComponents.EmptySourceVertex
- getEstimatedSizeBytes() - Method in class org.apache.nemo.compiler.frontend.beam.source.BeamBoundedSourceVertex
- getEstimatedSizeBytes() - Method in class org.apache.nemo.compiler.frontend.beam.source.BeamUnboundedSourceVertex
- getEventClass() - Method in interface org.apache.nemo.common.eventhandler.CommonEventHandler
-
fetches the class of the event.
- getExaminedEdges() - Method in class org.apache.nemo.compiler.optimizer.pass.runtime.Message
- getException() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ExecutorFailedMsg.Builder
-
required bytes exception = 2;
- getException() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ExecutorFailedMsg
-
required bytes exception = 2;
- getException() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.ExecutorFailedMsgOrBuilder
-
required bytes exception = 2;
- getException() - Method in class org.apache.nemo.runtime.executor.transfer.ByteTransferContext
- getExecutingTaskToRunningTimeMs(String) - Method in class org.apache.nemo.runtime.master.PlanStateManager
- getExecutionProperties() - Method in class org.apache.nemo.common.ir.edge.IREdge
- getExecutionProperties() - Method in class org.apache.nemo.common.ir.vertex.IRVertex
- getExecutionProperties() - Method in class org.apache.nemo.runtime.common.plan.RuntimeEdge
- getExecutionProperties() - Method in class org.apache.nemo.runtime.common.plan.Stage
- getExecutionProperties() - Method in class org.apache.nemo.runtime.common.plan.Task
- getExecutionPropertiesToAnnotate() - Method in class org.apache.nemo.compiler.optimizer.pass.compiletime.annotating.AnnotatingPass
-
Getter for the execution properties to annotate through the pass.
- getExecutorCapacity() - Method in class org.apache.nemo.runtime.master.resource.DefaultExecutorRepresenter
- getExecutorCapacity() - Method in interface org.apache.nemo.runtime.master.resource.ExecutorRepresenter
- getExecutorFailedMsg() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.ExecutorFailedMsg executorFailedMsg = 10;
- getExecutorFailedMsg() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
-
optional .protobuf.ExecutorFailedMsg executorFailedMsg = 10;
- getExecutorFailedMsg() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.MessageOrBuilder
-
optional .protobuf.ExecutorFailedMsg executorFailedMsg = 10;
- getExecutorFailedMsgBuilder() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.ExecutorFailedMsg executorFailedMsg = 10;
- getExecutorFailedMsgOrBuilder() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.ExecutorFailedMsg executorFailedMsg = 10;
- getExecutorFailedMsgOrBuilder() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
-
optional .protobuf.ExecutorFailedMsg executorFailedMsg = 10;
- getExecutorFailedMsgOrBuilder() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.MessageOrBuilder
-
optional .protobuf.ExecutorFailedMsg executorFailedMsg = 10;
- getExecutorId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsg.Builder
-
required string executorId = 1;
- getExecutorId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsg
-
required string executorId = 1;
- getExecutorId() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsgOrBuilder
-
required string executorId = 1;
- getExecutorId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ContainerFailedMsg.Builder
-
required string executorId = 1;
- getExecutorId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ContainerFailedMsg
-
required string executorId = 1;
- getExecutorId() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.ContainerFailedMsgOrBuilder
-
required string executorId = 1;
- getExecutorId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ExecutorFailedMsg.Builder
-
required string executorId = 1;
- getExecutorId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ExecutorFailedMsg
-
required string executorId = 1;
- getExecutorId() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.ExecutorFailedMsgOrBuilder
-
required string executorId = 1;
- getExecutorId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeInitMessage.Builder
-
required string executorId = 3;
- getExecutorId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeInitMessage
-
required string executorId = 3;
- getExecutorId() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.PipeInitMessageOrBuilder
-
required string executorId = 3;
- getExecutorId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeLocationInfoMessage.Builder
-
required string executorId = 2;
- getExecutorId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeLocationInfoMessage
-
required string executorId = 2;
- getExecutorId() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.PipeLocationInfoMessageOrBuilder
-
required string executorId = 2;
- getExecutorId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBlockLocationMsg.Builder
-
required string executorId = 1;
- getExecutorId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBlockLocationMsg
-
required string executorId = 1;
- getExecutorId() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.RequestBlockLocationMsgOrBuilder
-
required string executorId = 1;
- getExecutorId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBroadcastVariableMessage.Builder
-
required string executorId = 1;
- getExecutorId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBroadcastVariableMessage
-
required string executorId = 1;
- getExecutorId() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.RequestBroadcastVariableMessageOrBuilder
-
required string executorId = 1;
- getExecutorId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestPipeLocationMessage.Builder
-
required string executorId = 1;
- getExecutorId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestPipeLocationMessage
-
required string executorId = 1;
- getExecutorId() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.RequestPipeLocationMessageOrBuilder
-
required string executorId = 1;
- getExecutorId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg.Builder
-
required string executorId = 1;
- getExecutorId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg
-
required string executorId = 1;
- getExecutorId() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsgOrBuilder
-
required string executorId = 1;
- getExecutorId() - Method in class org.apache.nemo.runtime.executor.Executor
- getExecutorId() - Method in class org.apache.nemo.runtime.executor.transfer.LocalTransferContext
-
Accessor method for the executor id.
- getExecutorId() - Method in class org.apache.nemo.runtime.master.resource.DefaultExecutorRepresenter
- getExecutorId() - Method in interface org.apache.nemo.runtime.master.resource.ExecutorRepresenter
- getExecutorIdBytes() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsg.Builder
-
required string executorId = 1;
- getExecutorIdBytes() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsg
-
required string executorId = 1;
- getExecutorIdBytes() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsgOrBuilder
-
required string executorId = 1;
- getExecutorIdBytes() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ContainerFailedMsg.Builder
-
required string executorId = 1;
- getExecutorIdBytes() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ContainerFailedMsg
-
required string executorId = 1;
- getExecutorIdBytes() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.ContainerFailedMsgOrBuilder
-
required string executorId = 1;
- getExecutorIdBytes() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ExecutorFailedMsg.Builder
-
required string executorId = 1;
- getExecutorIdBytes() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ExecutorFailedMsg
-
required string executorId = 1;
- getExecutorIdBytes() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.ExecutorFailedMsgOrBuilder
-
required string executorId = 1;
- getExecutorIdBytes() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeInitMessage.Builder
-
required string executorId = 3;
- getExecutorIdBytes() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeInitMessage
-
required string executorId = 3;
- getExecutorIdBytes() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.PipeInitMessageOrBuilder
-
required string executorId = 3;
- getExecutorIdBytes() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeLocationInfoMessage.Builder
-
required string executorId = 2;
- getExecutorIdBytes() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeLocationInfoMessage
-
required string executorId = 2;
- getExecutorIdBytes() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.PipeLocationInfoMessageOrBuilder
-
required string executorId = 2;
- getExecutorIdBytes() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBlockLocationMsg.Builder
-
required string executorId = 1;
- getExecutorIdBytes() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBlockLocationMsg
-
required string executorId = 1;
- getExecutorIdBytes() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.RequestBlockLocationMsgOrBuilder
-
required string executorId = 1;
- getExecutorIdBytes() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBroadcastVariableMessage.Builder
-
required string executorId = 1;
- getExecutorIdBytes() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBroadcastVariableMessage
-
required string executorId = 1;
- getExecutorIdBytes() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.RequestBroadcastVariableMessageOrBuilder
-
required string executorId = 1;
- getExecutorIdBytes() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestPipeLocationMessage.Builder
-
required string executorId = 1;
- getExecutorIdBytes() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestPipeLocationMessage
-
required string executorId = 1;
- getExecutorIdBytes() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.RequestPipeLocationMessageOrBuilder
-
required string executorId = 1;
- getExecutorIdBytes() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg.Builder
-
required string executorId = 1;
- getExecutorIdBytes() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg
-
required string executorId = 1;
- getExecutorIdBytes() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsgOrBuilder
-
required string executorId = 1;
- getExecutorInfo() - Method in class org.apache.nemo.common.ir.IRDAG
-
Getter for the executor specifications information.
- getFailReason() - Method in class org.apache.nemo.common.ir.IRDAGChecker.CheckerResult
- getFailureCause() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg.Builder
-
optional .protobuf.RecoverableFailureCause failureCause = 5;
- getFailureCause() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg
-
optional .protobuf.RecoverableFailureCause failureCause = 5;
- getFailureCause() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsgOrBuilder
-
optional .protobuf.RecoverableFailureCause failureCause = 5;
- getFileBasePath() - Static method in class org.apache.nemo.common.test.ExampleTestArgs
- getFloat(int) - Method in class org.apache.nemo.runtime.executor.data.MemoryChunk
-
Reads a float value from the given position, in the system's native byte order.
- getFractionToWaitFor() - Method in class org.apache.nemo.common.ir.vertex.executionproperty.ClonedSchedulingProperty.CloneConf
- getGroupEndingVertices() - Method in class org.apache.nemo.common.ir.vertex.utility.TaskSizeSplitterVertex
- getGroupId() - Method in class org.apache.nemo.common.ir.edge.executionproperty.DuplicateEdgeGroupPropertyValue
-
Get the data id.
- getGroupSize() - Method in class org.apache.nemo.common.ir.edge.executionproperty.DuplicateEdgeGroupPropertyValue
-
Get the group size.
- getGroupStartingVertices() - Method in class org.apache.nemo.common.ir.vertex.utility.TaskSizeSplitterVertex
- getId() - Method in class org.apache.nemo.common.dag.Edge
- getId() - Method in class org.apache.nemo.common.dag.Vertex
- getId() - Method in class org.apache.nemo.common.ir.executionproperty.ExecutionPropertyMap
-
ID of the item this ExecutionPropertyMap class is keeping track of.
- getId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
required int64 id = 2;
- getId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
-
required int64 id = 2;
- getId() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.MessageOrBuilder
-
required int64 id = 2;
- getId() - Method in class org.apache.nemo.runtime.common.message.grpc.GrpcMessageEnvironment
- getId() - Method in class org.apache.nemo.runtime.common.message.local.LocalMessageEnvironment
- getId() - Method in interface org.apache.nemo.runtime.common.message.MessageEnvironment
- getId() - Method in class org.apache.nemo.runtime.common.message.ncs.NcsMessageEnvironment
- getId() - Method in class org.apache.nemo.runtime.common.metric.JobMetric
- getId() - Method in interface org.apache.nemo.runtime.common.metric.Metric
-
Get its unique id.
- getId() - Method in class org.apache.nemo.runtime.common.metric.StageMetric
- getId() - Method in class org.apache.nemo.runtime.common.metric.TaskMetric
- getId() - Method in interface org.apache.nemo.runtime.executor.data.block.Block
- getId() - Method in class org.apache.nemo.runtime.executor.data.block.FileBlock
- getId() - Method in class org.apache.nemo.runtime.executor.data.block.NonSerializedMemoryBlock
- getId() - Method in class org.apache.nemo.runtime.executor.data.block.SerializedMemoryBlock
- getIdToIRVertex() - Method in class org.apache.nemo.runtime.common.plan.PhysicalPlan
- getIncomingEdgesOf(String) - Method in class org.apache.nemo.common.dag.DAG
- getIncomingEdgesOf(String) - Method in interface org.apache.nemo.common.dag.DAGInterface
-
Retrieves the incoming edges of the given vertex.
- getIncomingEdgesOf(String) - Method in class org.apache.nemo.common.ir.IRDAG
- getIncomingEdgesOf(IRVertex) - Method in class org.apache.nemo.common.ir.IRDAG
- getIncomingEdgesOf(V) - Method in class org.apache.nemo.common.dag.DAG
- getIncomingEdgesOf(V) - Method in interface org.apache.nemo.common.dag.DAGInterface
-
Retrieves the incoming edges of the given vertex.
- getIndex() - Method in class org.apache.nemo.runtime.executor.datatransfer.WatermarkWithIndex
- getIndexFromTaskId(String) - Static method in class org.apache.nemo.runtime.common.RuntimeIdManager
-
Extracts task index from a task ID.
- getInitiatorExecutorId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage.Builder
-
required string initiatorExecutorId = 1;
- getInitiatorExecutorId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage
-
required string initiatorExecutorId = 1;
- getInitiatorExecutorId() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessageOrBuilder
-
required string initiatorExecutorId = 1;
- getInitiatorExecutorIdBytes() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage.Builder
-
required string initiatorExecutorId = 1;
- getInitiatorExecutorIdBytes() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage
-
required string initiatorExecutorId = 1;
- getInitiatorExecutorIdBytes() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessageOrBuilder
-
required string initiatorExecutorId = 1;
- getInjector() - Static method in class org.apache.nemo.runtime.common.message.local.LocalMessageDispatcher
- getInputFile() - Method in interface org.apache.nemo.examples.beam.BeamWordCount.WordCountOptions
-
By default, this example reads from a public dataset containing the text of King Lear.
- getInputSize() - Method in class org.apache.nemo.common.ir.IRDAG
- getInputSize() - Method in class org.apache.nemo.runtime.common.metric.JobMetric
- getInputStreams() - Method in class org.apache.nemo.runtime.executor.transfer.ByteInputContext
-
Returns
Iterator
ofInputStream
s. - getInstance() - Static method in class org.apache.nemo.common.punctuation.Finishmark
- getInstance() - Static method in class org.apache.nemo.runtime.master.metric.MetricBroadcaster
-
Getter for the singleton object.
- getInt(int) - Method in class org.apache.nemo.runtime.executor.data.MemoryChunk
-
Reads an int value from the given position, in the system's native byte order.
- getIRDAG() - Method in class org.apache.nemo.runtime.common.metric.JobMetric
- getIRDAG() - Method in class org.apache.nemo.runtime.common.plan.Stage
- getIrDagSummary() - Method in class org.apache.nemo.runtime.common.metric.JobMetric
- getIrVertexIdToReadable() - Method in class org.apache.nemo.runtime.common.plan.Task
- getIRVertexPropertiesAsJsonNode() - Method in class org.apache.nemo.common.ir.vertex.IRVertex
- getIsPartialCombining() - Method in class org.apache.nemo.compiler.frontend.beam.transform.GBKTransform
-
Accessor for isPartialCombining.
- getIsPipe() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage.Builder
-
required bool isPipe = 5;
- getIsPipe() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage
-
required bool isPipe = 5;
- getIsPipe() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessageOrBuilder
-
required bool isPipe = 5;
- getIsReadNotSerializedData() - Method in class org.apache.nemo.runtime.common.metric.StreamMetric
-
Get a boolean value that indicates whether it read data from local block or not.
- getIterativeIncomingEdges() - Method in class org.apache.nemo.common.ir.vertex.LoopVertex
- getIterator() - Method in class org.apache.nemo.runtime.executor.transfer.LocalInputContext
-
Creates a new iterator which iterates the receive elements from the sender.
- getJobConf(String[]) - Static method in class org.apache.nemo.client.JobLauncher
-
Get job configuration.
- getJobDuration() - Method in class org.apache.nemo.runtime.common.metric.JobMetric
- getKey() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageEntry.Builder
-
required string key = 1;
- getKey() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageEntry
-
required string key = 1;
- getKey() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageEntryOrBuilder
-
required string key = 1;
- getKey() - Method in class org.apache.nemo.runtime.executor.data.metadata.PartitionMetadata
- getKey() - Method in class org.apache.nemo.runtime.executor.data.partition.NonSerializedPartition
- getKey() - Method in interface org.apache.nemo.runtime.executor.data.partition.Partition
- getKey() - Method in class org.apache.nemo.runtime.executor.data.partition.SerializedPartition
- getKeyBytes() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageEntry.Builder
-
required string key = 1;
- getKeyBytes() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageEntry
-
required string key = 1;
- getKeyBytes() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageEntryOrBuilder
-
required string key = 1;
- getKeyRange() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptor.Builder
-
optional bytes keyRange = 4;
- getKeyRange() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptor
-
optional bytes keyRange = 4;
- getKeyRange() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptorOrBuilder
-
optional bytes keyRange = 4;
- getKeyRanges() - Method in class org.apache.nemo.runtime.common.plan.StageEdge
-
Get keyRanges for shuffle edge.
- getLatency() - Method in class org.apache.nemo.runtime.common.metric.LatencyMetric
- getLatencymark() - Method in class org.apache.nemo.runtime.common.metric.LatencyMetric
-
Get the recorded latency mark.
- getLatencyMetric() - Method in class org.apache.nemo.runtime.common.metric.TaskMetric
- getLaunchDAG() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessage.Builder
-
optional .protobuf.LaunchDAGMessage launchDAG = 2;
- getLaunchDAG() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessage
-
optional .protobuf.LaunchDAGMessage launchDAG = 2;
- getLaunchDAG() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessageOrBuilder
-
optional .protobuf.LaunchDAGMessage launchDAG = 2;
- getLaunchDAGBuilder() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessage.Builder
-
optional .protobuf.LaunchDAGMessage launchDAG = 2;
- getLaunchDAGOrBuilder() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessage.Builder
-
optional .protobuf.LaunchDAGMessage launchDAG = 2;
- getLaunchDAGOrBuilder() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessage
-
optional .protobuf.LaunchDAGMessage launchDAG = 2;
- getLaunchDAGOrBuilder() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessageOrBuilder
-
optional .protobuf.LaunchDAGMessage launchDAG = 2;
- getLength() - Method in class org.apache.nemo.runtime.executor.data.partition.SerializedPartition
- getListenerId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
The id of the message listener (handler).
- getListenerId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
-
The id of the message listener (handler).
- getListenerId() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.MessageOrBuilder
-
The id of the message listener (handler).
- getListenerIdBytes() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
The id of the message listener (handler).
- getListenerIdBytes() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
-
The id of the message listener (handler).
- getListenerIdBytes() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.MessageOrBuilder
-
The id of the message listener (handler).
- getListeningConfiguration() - Method in class org.apache.nemo.client.DriverRPCServer
- getListeningHost() - Method in class org.apache.nemo.client.DriverRPCServer
- getListeningPort() - Method in class org.apache.nemo.client.DriverRPCServer
- getLocation() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsg.Builder
-
The location of the block (e.g., executor id or remote store).
- getLocation() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsg
-
The location of the block (e.g., executor id or remote store).
- getLocation() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsgOrBuilder
-
The location of the block (e.g., executor id or remote store).
- getLocationBytes() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsg.Builder
-
The location of the block (e.g., executor id or remote store).
- getLocationBytes() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsg
-
The location of the block (e.g., executor id or remote store).
- getLocationBytes() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsgOrBuilder
-
The location of the block (e.g., executor id or remote store).
- getLocationFuture() - Method in class org.apache.nemo.runtime.master.BlockManagerMaster.BlockRequestHandler
- getLocations() - Method in interface org.apache.nemo.common.ir.Readable
-
Returns the list of locations where this readable resides.
- getLong(int) - Method in class org.apache.nemo.runtime.executor.data.MemoryChunk
-
Reads a long value from the given position.
- getLoopFusionPass() - Static method in class org.apache.nemo.compiler.optimizer.pass.compiletime.reshaping.LoopOptimizations
- getLoopInvariantCodeMotionPass() - Static method in class org.apache.nemo.compiler.optimizer.pass.compiletime.reshaping.LoopOptimizations
- getLoopStackDepthOf(IRVertex) - Method in class org.apache.nemo.common.ir.IRDAG
- getLoopStackDepthOf(V) - Method in class org.apache.nemo.common.dag.DAG
- getLoopStackDepthOf(V) - Method in interface org.apache.nemo.common.dag.DAGInterface
-
Retrieves the stack depth of the given vertex.
- getMainOutputTag() - Static method in class org.apache.nemo.common.ir.edge.executionproperty.AdditionalOutputTagProperty
- getMaxBundleSize() - Method in interface org.apache.nemo.compiler.frontend.beam.NemoPipelineOptions
- getMaxBundleTimeMills() - Method in interface org.apache.nemo.compiler.frontend.beam.NemoPipelineOptions
- getMaxNumberOfIterations() - Method in class org.apache.nemo.common.ir.vertex.LoopVertex
- getMaxOffheapRatio() - Method in class org.apache.nemo.common.ir.executionproperty.ResourceSpecification
- getMaxScheduleAttempt() - Method in class org.apache.nemo.runtime.master.PlanStateManager
- getMedianTimeMultiplier() - Method in class org.apache.nemo.common.ir.vertex.executionproperty.ClonedSchedulingProperty.CloneConf
- getMemory() - Method in class org.apache.nemo.common.ir.executionproperty.ResourceSpecification
- getMemoryChunkList() - Method in class org.apache.nemo.runtime.executor.data.DirectByteBufferOutputStream
-
Returns the list of
MemoryChunk
s that contains the written data. - getMessage() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessage.Builder
-
optional .protobuf.NotificationMessage message = 3;
- getMessage() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessage
-
optional .protobuf.NotificationMessage message = 3;
- getMessage() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessageOrBuilder
-
optional .protobuf.NotificationMessage message = 3;
- getMessageBuilder() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessage.Builder
-
optional .protobuf.NotificationMessage message = 3;
- getMessageFunction() - Method in class org.apache.nemo.common.ir.vertex.utility.runtimepass.MessageGeneratorVertex
- getMessageId() - Method in class org.apache.nemo.compiler.optimizer.pass.runtime.Message
- getMessageOrBuilder() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessage.Builder
-
optional .protobuf.NotificationMessage message = 3;
- getMessageOrBuilder() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessage
-
optional .protobuf.NotificationMessage message = 3;
- getMessageOrBuilder() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessageOrBuilder
-
optional .protobuf.NotificationMessage message = 3;
- getMessageSender(String) - Method in class org.apache.nemo.runtime.common.message.PersistentConnectionToMasterMap
-
Get the message sender corresponding to the given listener ID.
- getMessageValue() - Method in class org.apache.nemo.compiler.optimizer.pass.runtime.Message
- getMethodFor(Class<? extends ExecutionProperty>, String, Class<?>...) - Static method in class org.apache.nemo.runtime.common.metric.MetricUtils
-
Utility method to getting an optional method called 'name' for the class.
- getMetric(int) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.MetricMsg.Builder
-
repeated .protobuf.Metric metric = 1;
- getMetric(int) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.MetricMsg
-
repeated .protobuf.Metric metric = 1;
- getMetric(int) - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.MetricMsgOrBuilder
-
repeated .protobuf.Metric metric = 1;
- getMetricBuilder(int) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.MetricMsg.Builder
-
repeated .protobuf.Metric metric = 1;
- getMetricBuilderList() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.MetricMsg.Builder
-
repeated .protobuf.Metric metric = 1;
- getMetricClassByName(String) - Method in class org.apache.nemo.runtime.master.metric.MetricStore
-
Get the metric class by its name.
- getMetricCount() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.MetricMsg.Builder
-
repeated .protobuf.Metric metric = 1;
- getMetricCount() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.MetricMsg
-
repeated .protobuf.Metric metric = 1;
- getMetricCount() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.MetricMsgOrBuilder
-
repeated .protobuf.Metric metric = 1;
- getMetricField() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Metric.Builder
-
required string metricField = 3;
- getMetricField() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Metric
-
required string metricField = 3;
- getMetricField() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.MetricOrBuilder
-
required string metricField = 3;
- getMetricFieldBytes() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Metric.Builder
-
required string metricField = 3;
- getMetricFieldBytes() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Metric
-
required string metricField = 3;
- getMetricFieldBytes() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.MetricOrBuilder
-
required string metricField = 3;
- getMetricId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Metric.Builder
-
required string metricId = 2;
- getMetricId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Metric
-
required string metricId = 2;
- getMetricId() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.MetricOrBuilder
-
required string metricId = 2;
- getMetricIdBytes() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Metric.Builder
-
required string metricId = 2;
- getMetricIdBytes() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Metric
-
required string metricId = 2;
- getMetricIdBytes() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.MetricOrBuilder
-
required string metricId = 2;
- getMetricList() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.MetricMsg.Builder
-
repeated .protobuf.Metric metric = 1;
- getMetricList() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.MetricMsg
-
repeated .protobuf.Metric metric = 1;
- getMetricList() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.MetricMsgOrBuilder
-
repeated .protobuf.Metric metric = 1;
- getMetricMap(Class<T>) - Method in class org.apache.nemo.runtime.master.metric.MetricStore
-
Fetch metric map by its metric class instance.
- getMetricMsg() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.MetricMsg metricMsg = 12;
- getMetricMsg() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
-
optional .protobuf.MetricMsg metricMsg = 12;
- getMetricMsg() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.MessageOrBuilder
-
optional .protobuf.MetricMsg metricMsg = 12;
- getMetricMsgBuilder() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.MetricMsg metricMsg = 12;
- getMetricMsgOrBuilder() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.MetricMsg metricMsg = 12;
- getMetricMsgOrBuilder() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
-
optional .protobuf.MetricMsg metricMsg = 12;
- getMetricMsgOrBuilder() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.MessageOrBuilder
-
optional .protobuf.MetricMsg metricMsg = 12;
- getMetricOrBuilder(int) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.MetricMsg.Builder
-
repeated .protobuf.Metric metric = 1;
- getMetricOrBuilder(int) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.MetricMsg
-
repeated .protobuf.Metric metric = 1;
- getMetricOrBuilder(int) - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.MetricMsgOrBuilder
-
repeated .protobuf.Metric metric = 1;
- getMetricOrBuilderList() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.MetricMsg.Builder
-
repeated .protobuf.Metric metric = 1;
- getMetricOrBuilderList() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.MetricMsg
-
repeated .protobuf.Metric metric = 1;
- getMetricOrBuilderList() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.MetricMsgOrBuilder
-
repeated .protobuf.Metric metric = 1;
- getMetricType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Metric.Builder
-
required string metricType = 1;
- getMetricType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Metric
-
required string metricType = 1;
- getMetricType() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.MetricOrBuilder
-
required string metricType = 1;
- getMetricTypeBytes() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Metric.Builder
-
required string metricType = 1;
- getMetricTypeBytes() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Metric
-
required string metricType = 1;
- getMetricTypeBytes() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.MetricOrBuilder
-
required string metricType = 1;
- getMetricValue() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Metric.Builder
-
required bytes metricValue = 4;
- getMetricValue() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Metric
-
required bytes metricValue = 4;
- getMetricValue() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.MetricOrBuilder
-
required bytes metricValue = 4;
- getMetricWithId(Class<T>, String) - Method in class org.apache.nemo.runtime.master.metric.MetricStore
-
Fetch metric by its metric class instance and its id.
- getName() - Method in class org.apache.nemo.common.ir.vertex.LoopVertex
- getName() - Method in class org.apache.nemo.examples.spark.sql.JavaSparkSQLExample.Person
-
Getter.
- getName() - Method in class org.apache.nemo.examples.spark.sql.JavaUserDefinedTypedAggregation.Employee
-
Getter.
- getNewState() - Method in class org.apache.nemo.runtime.common.metric.StateTransitionEvent
-
Get new state.
- getNextOperator() - Method in class org.apache.nemo.runtime.executor.datatransfer.NextIntraTaskOperatorInfo
- getNodeName() - Method in class org.apache.nemo.runtime.master.resource.DefaultExecutorRepresenter
- getNodeName() - Method in interface org.apache.nemo.runtime.master.resource.ExecutorRepresenter
- getNonIterativeIncomingEdges() - Method in class org.apache.nemo.common.ir.vertex.LoopVertex
- getNumber() - Method in enum org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateFromExecutor
- getNumber() - Method in enum org.apache.nemo.runtime.common.comm.ControlMessage.BlockStore
- getNumber() - Method in enum org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferDataDirection
- getNumber() - Method in enum org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessageType
- getNumber() - Method in enum org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessageType
- getNumber() - Method in enum org.apache.nemo.runtime.common.comm.ControlMessage.MessageType
- getNumber() - Method in enum org.apache.nemo.runtime.common.comm.ControlMessage.OptimizationType
- getNumber() - Method in enum org.apache.nemo.runtime.common.comm.ControlMessage.RecoverableFailureCause
- getNumber() - Method in enum org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateFromExecutor
- getNumberOfRunningExecutors() - Method in class org.apache.nemo.runtime.master.scheduler.ExecutorRegistry
- getNumEncodedBytes() - Method in class org.apache.nemo.runtime.executor.data.DataUtil.InputStreamIterator
- getNumEncodedBytes() - Method in interface org.apache.nemo.runtime.executor.data.DataUtil.IteratorWithNumBytes
-
This method should be called after the actual data is taken out of iterator, since the existence of an iterator does not guarantee that data inside it is ready.
- getNumEncodedBytes() - Method in class org.apache.nemo.runtime.executor.data.partition.NonSerializedPartition
- getNumericId() - Method in class org.apache.nemo.common.dag.Edge
- getNumericId() - Method in class org.apache.nemo.common.dag.Vertex
- getNumOfComplyingRunningTasks() - Method in class org.apache.nemo.runtime.master.resource.DefaultExecutorRepresenter
- getNumOfComplyingRunningTasks() - Method in interface org.apache.nemo.runtime.master.resource.ExecutorRepresenter
- getNumOfProcessedTuples() - Method in class org.apache.nemo.runtime.common.metric.StreamMetric
-
Get the number of processed tuple.
- getNumOfRunningTasks() - Method in class org.apache.nemo.runtime.master.resource.DefaultExecutorRepresenter
- getNumOfRunningTasks() - Method in interface org.apache.nemo.runtime.master.resource.ExecutorRepresenter
- getNumPipeToWait() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptor.Builder
-
required int64 numPipeToWait = 4;
- getNumPipeToWait() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptor
-
required int64 numPipeToWait = 4;
- getNumPipeToWait() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptorOrBuilder
-
required int64 numPipeToWait = 4;
- getNumSerializedBytes() - Method in class org.apache.nemo.runtime.executor.data.DataUtil.InputStreamIterator
- getNumSerializedBytes() - Method in interface org.apache.nemo.runtime.executor.data.DataUtil.IteratorWithNumBytes
-
This method should be called after the actual data is taken out of iterator, since the existence of an iterator does not guarantee that data inside it is ready.
- getNumSerializedBytes() - Method in class org.apache.nemo.runtime.executor.data.partition.NonSerializedPartition
- getObjectSize(Object) - Static method in class org.apache.nemo.common.Util
-
Get the object byte size.
- getOffset() - Method in class org.apache.nemo.runtime.executor.data.metadata.PartitionMetadata
- getOptimizationType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessage.Builder
-
optional .protobuf.OptimizationType optimizationType = 3;
- getOptimizationType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessage
-
optional .protobuf.OptimizationType optimizationType = 3;
- getOptimizationType() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessageOrBuilder
-
optional .protobuf.OptimizationType optimizationType = 3;
- getOptimizationType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.NotificationMessage.Builder
-
required .protobuf.OptimizationType optimizationType = 1;
- getOptimizationType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.NotificationMessage
-
required .protobuf.OptimizationType optimizationType = 1;
- getOptimizationType() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.NotificationMessageOrBuilder
-
required .protobuf.OptimizationType optimizationType = 1;
- getOrCreateMetric(Class<T>, String) - Method in class org.apache.nemo.runtime.master.metric.MetricStore
-
Same as getMetricWithId(), but if there is no such metric, it will try to create new metric object using its constructor, which takes an id as a parameter.
- getOriginalVertexId() - Method in class org.apache.nemo.common.ir.vertex.utility.SamplingVertex
- getOriginalVertices() - Method in class org.apache.nemo.common.ir.vertex.utility.TaskSizeSplitterVertex
- getOutgoingEdgesOf(String) - Method in class org.apache.nemo.common.dag.DAG
- getOutgoingEdgesOf(String) - Method in interface org.apache.nemo.common.dag.DAGInterface
-
Retrieves the outgoing edges of the given vertex.
- getOutgoingEdgesOf(String) - Method in class org.apache.nemo.common.ir.IRDAG
- getOutgoingEdgesOf(IRVertex) - Method in class org.apache.nemo.common.ir.IRDAG
- getOutgoingEdgesOf(V) - Method in class org.apache.nemo.common.dag.DAG
- getOutgoingEdgesOf(V) - Method in interface org.apache.nemo.common.dag.DAGInterface
-
Retrieves the outgoing edges of the given vertex.
- getOutput() - Method in interface org.apache.nemo.examples.beam.BeamWordCount.WordCountOptions
-
Set this required option to specify where to write the output.
- getOutputCollector() - Method in class org.apache.nemo.common.ir.vertex.transform.LatencymarkEmitTransform
-
get OutputCollector.
- getOutputCollector() - Method in class org.apache.nemo.compiler.frontend.beam.transform.AbstractDoFnTransform
-
Getter function for output collector.
- getOutputContexts(RuntimeEdge, long) - Method in class org.apache.nemo.runtime.executor.data.PipeManagerWorker
-
(SYNCHRONIZATION) Called by task threads.
- getOwnerExecutorId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsg.Builder
-
optional string ownerExecutorId = 4;
- getOwnerExecutorId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsg
-
optional string ownerExecutorId = 4;
- getOwnerExecutorId() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsgOrBuilder
-
optional string ownerExecutorId = 4;
- getOwnerExecutorIdBytes() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsg.Builder
-
optional string ownerExecutorId = 4;
- getOwnerExecutorIdBytes() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsg
-
optional string ownerExecutorId = 4;
- getOwnerExecutorIdBytes() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsgOrBuilder
-
optional string ownerExecutorId = 4;
- getParallelism() - Method in class org.apache.nemo.runtime.common.plan.Stage
- getParents(String) - Method in class org.apache.nemo.common.dag.DAG
- getParents(String) - Method in interface org.apache.nemo.common.dag.DAGInterface
-
Retrieves the parent vertices of the given vertex.
- getParents(String) - Method in class org.apache.nemo.common.ir.IRDAG
- getParserForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsg
- getParserForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsg
- getParserForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptor
- getParserForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage
- getParserForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessage
- getParserForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ContainerFailedMsg
- getParserForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DataCollectMessage
- getParserForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessage
- getParserForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ExecutorFailedMsg
- getParserForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.InMasterBroadcastVariableMessage
- getParserForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.LaunchDAGMessage
- getParserForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
- getParserForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Metric
- getParserForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.MetricMsg
- getParserForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.NotificationMessage
- getParserForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeInitMessage
- getParserForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeLocationInfoMessage
- getParserForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptor
- getParserForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBlockLocationMsg
- getParserForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBroadcastVariableMessage
- getParserForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestPipeLocationMessage
- getParserForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageEntry
- getParserForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsg
- getParserForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ScheduleTaskMsg
- getParserForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg
- getParserForType() - Method in class org.apache.nemo.runtime.common.comm.GrpcMessageService.Void
- getPartitioner(ExecutionPropertyMap<EdgeExecutionProperty>, ExecutionPropertyMap<VertexExecutionProperty>) - Static method in interface org.apache.nemo.common.partitioner.Partitioner
- getPartitionerProperty() - Method in class org.apache.nemo.runtime.common.plan.Stage
- getPartitionMetadataList() - Method in class org.apache.nemo.runtime.executor.data.metadata.FileMetadata
-
Gets a list containing the partition metadata of corresponding block.
- getPartitionSize() - Method in class org.apache.nemo.runtime.executor.data.metadata.PartitionMetadata
- getPassList() - Method in class org.apache.nemo.compiler.optimizer.pass.compiletime.composite.CompositePass
-
Getter for list of compile time passes.
- getPath() - Method in class org.apache.nemo.runtime.executor.data.FileArea
- getPeakExecutionMemory() - Method in class org.apache.nemo.runtime.common.metric.TaskMetric
-
Method related to peak execution memory.
- getPhysicalPlan() - Method in class org.apache.nemo.runtime.master.PlanStateManager
- getPipeInitMsg() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.PipeInitMessage pipeInitMsg = 16;
- getPipeInitMsg() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
-
optional .protobuf.PipeInitMessage pipeInitMsg = 16;
- getPipeInitMsg() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.MessageOrBuilder
-
optional .protobuf.PipeInitMessage pipeInitMsg = 16;
- getPipeInitMsgBuilder() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.PipeInitMessage pipeInitMsg = 16;
- getPipeInitMsgOrBuilder() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.PipeInitMessage pipeInitMsg = 16;
- getPipeInitMsgOrBuilder() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
-
optional .protobuf.PipeInitMessage pipeInitMsg = 16;
- getPipeInitMsgOrBuilder() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.MessageOrBuilder
-
optional .protobuf.PipeInitMessage pipeInitMsg = 16;
- getPipelineOptions() - Method in class org.apache.nemo.client.beam.NemoRunnerRegistrar.Options
- getPipelineRunners() - Method in class org.apache.nemo.client.beam.NemoRunnerRegistrar.Runner
- getPipeLocInfoMsg() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.PipeLocationInfoMessage pipeLocInfoMsg = 18;
- getPipeLocInfoMsg() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
-
optional .protobuf.PipeLocationInfoMessage pipeLocInfoMsg = 18;
- getPipeLocInfoMsg() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.MessageOrBuilder
-
optional .protobuf.PipeLocationInfoMessage pipeLocInfoMsg = 18;
- getPipeLocInfoMsgBuilder() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.PipeLocationInfoMessage pipeLocInfoMsg = 18;
- getPipeLocInfoMsgOrBuilder() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.PipeLocationInfoMessage pipeLocInfoMsg = 18;
- getPipeLocInfoMsgOrBuilder() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
-
optional .protobuf.PipeLocationInfoMessage pipeLocInfoMsg = 18;
- getPipeLocInfoMsgOrBuilder() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.MessageOrBuilder
-
optional .protobuf.PipeLocationInfoMessage pipeLocInfoMsg = 18;
- getPlanId() - Method in class org.apache.nemo.runtime.common.plan.PhysicalPlan
- getPlanId() - Method in class org.apache.nemo.runtime.common.plan.Task
- getPlanId() - Method in class org.apache.nemo.runtime.master.PlanStateManager
- getPlanState() - Method in class org.apache.nemo.client.ClientEndpoint
-
Get the current state of the running plan.
- getPlanState() - Method in class org.apache.nemo.runtime.master.PlanStateManager
- getPlanStateManager() - Method in class org.apache.nemo.runtime.master.scheduler.SimulationScheduler
- getPoisonSec() - Method in class org.apache.nemo.common.ir.executionproperty.ResourceSpecification
- getPosition() - Method in class org.apache.nemo.runtime.executor.data.FileArea
- getPrerequisiteExecutionProperties() - Method in class org.apache.nemo.compiler.optimizer.pass.compiletime.annotating.AnnotatingPass
- getPrerequisiteExecutionProperties() - Method in class org.apache.nemo.compiler.optimizer.pass.compiletime.CompileTimePass
-
Getter for prerequisite execution properties.
- getPrerequisiteExecutionProperties() - Method in class org.apache.nemo.compiler.optimizer.pass.compiletime.composite.CompositePass
- getPrerequisiteExecutionProperties() - Method in class org.apache.nemo.compiler.optimizer.pass.compiletime.reshaping.ReshapingPass
- getPreviousSentTimestamp() - Method in class org.apache.nemo.common.punctuation.LatencyMark
- getPreviousTaskId() - Method in class org.apache.nemo.common.punctuation.LatencyMark
- getPrevState() - Method in class org.apache.nemo.runtime.common.metric.StateTransitionEvent
-
Get previous state.
- getProducerTaskIds(String) - Method in class org.apache.nemo.runtime.master.BlockManagerMaster
-
Gets the ids of the tasks which already produced or will produce data for a specific block.
- getProperties() - Method in class org.apache.nemo.runtime.executor.datatransfer.BlockInputReader
- getProperties() - Method in interface org.apache.nemo.runtime.executor.datatransfer.InputReader
- getProperties() - Method in class org.apache.nemo.runtime.executor.datatransfer.PipeInputReader
- getPropertiesAsJsonNode() - Method in class org.apache.nemo.common.dag.Edge
- getPropertiesAsJsonNode() - Method in class org.apache.nemo.common.dag.Vertex
- getPropertiesAsJsonNode() - Method in class org.apache.nemo.common.ir.edge.IREdge
- getPropertiesAsJsonNode() - Method in class org.apache.nemo.common.ir.vertex.LoopVertex
-
Parse Properties to JsonNode.
- getPropertiesAsJsonNode() - Method in class org.apache.nemo.common.ir.vertex.OperatorVertex
- getPropertiesAsJsonNode() - Method in class org.apache.nemo.common.ir.vertex.utility.SamplingVertex
- getPropertiesAsJsonNode() - Method in class org.apache.nemo.common.test.EmptyComponents.EmptySourceVertex
- getPropertiesAsJsonNode() - Method in class org.apache.nemo.compiler.frontend.beam.source.BeamBoundedSourceVertex
- getPropertiesAsJsonNode() - Method in class org.apache.nemo.compiler.frontend.beam.source.BeamUnboundedSourceVertex
- getPropertiesAsJsonNode() - Method in class org.apache.nemo.runtime.common.plan.RuntimeEdge
- getPropertiesAsJsonNode() - Method in class org.apache.nemo.runtime.common.plan.Stage
- getPropertiesAsJsonNode() - Method in class org.apache.nemo.runtime.common.plan.StageEdge
- getPropertyValue(Class<? extends EdgeExecutionProperty<T>>) - Method in class org.apache.nemo.common.ir.edge.IREdge
-
Get the executionProperty of the IREdge.
- getPropertyValue(Class<? extends EdgeExecutionProperty<T>>) - Method in class org.apache.nemo.runtime.common.plan.RuntimeEdge
-
Get the execution property of the Runtime Edge.
- getPropertyValue(Class<? extends VertexExecutionProperty<T>>) - Method in class org.apache.nemo.common.ir.vertex.IRVertex
-
Get the executionProperty of the IRVertex.
- getPropertyValue(Class<? extends VertexExecutionProperty<T>>) - Method in class org.apache.nemo.runtime.common.plan.Stage
-
Get the executionProperty of the IREdge.
- getPropertyValue(Class<? extends VertexExecutionProperty<T>>) - Method in class org.apache.nemo.runtime.common.plan.Task
-
Get the executionProperty of this task.
- getPropertyValueOrRuntimeException(Class<? extends EdgeExecutionProperty<T>>) - Method in class org.apache.nemo.runtime.common.plan.RuntimeEdge
- getPubSubEventHandler() - Method in class org.apache.nemo.common.eventhandler.PubSubEventHandlerWrapper
- getQueue() - Method in class org.apache.nemo.runtime.executor.transfer.LocalOutputContext
-
Accessor method for the queue in this local output context.
- getRangedNumList(int, int) - Static method in class org.apache.nemo.runtime.common.RuntimeTestUtil
-
Gets a list of integer pair elements in range.
- getReadables(int) - Method in class org.apache.nemo.common.ir.vertex.CachedSourceVertex
- getReadables(int) - Method in class org.apache.nemo.common.ir.vertex.InMemorySourceVertex
- getReadables(int) - Method in class org.apache.nemo.common.ir.vertex.SourceVertex
-
Gets parallel readables.
- getReadables(int) - Method in class org.apache.nemo.common.test.EmptyComponents.EmptySourceVertex
- getReadables(int) - Method in class org.apache.nemo.compiler.frontend.beam.source.BeamBoundedSourceVertex
- getReadables(int) - Method in class org.apache.nemo.compiler.frontend.beam.source.BeamUnboundedSourceVertex
- getRemoteExecutorId() - Method in class org.apache.nemo.runtime.executor.transfer.ByteTransferContext
- getRepresentativeEdgeId() - Method in class org.apache.nemo.common.ir.edge.executionproperty.DuplicateEdgeGroupPropertyValue
-
Get the physical edge id of the representative edge.
- getRequestBlockLocationMsg() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.RequestBlockLocationMsg requestBlockLocationMsg = 8;
- getRequestBlockLocationMsg() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
-
optional .protobuf.RequestBlockLocationMsg requestBlockLocationMsg = 8;
- getRequestBlockLocationMsg() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.MessageOrBuilder
-
optional .protobuf.RequestBlockLocationMsg requestBlockLocationMsg = 8;
- getRequestBlockLocationMsgBuilder() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.RequestBlockLocationMsg requestBlockLocationMsg = 8;
- getRequestBlockLocationMsgOrBuilder() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.RequestBlockLocationMsg requestBlockLocationMsg = 8;
- getRequestBlockLocationMsgOrBuilder() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
-
optional .protobuf.RequestBlockLocationMsg requestBlockLocationMsg = 8;
- getRequestBlockLocationMsgOrBuilder() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.MessageOrBuilder
-
optional .protobuf.RequestBlockLocationMsg requestBlockLocationMsg = 8;
- getRequestbroadcastVariableMsg() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.RequestBroadcastVariableMessage requestbroadcastVariableMsg = 14;
- getRequestbroadcastVariableMsg() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
-
optional .protobuf.RequestBroadcastVariableMessage requestbroadcastVariableMsg = 14;
- getRequestbroadcastVariableMsg() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.MessageOrBuilder
-
optional .protobuf.RequestBroadcastVariableMessage requestbroadcastVariableMsg = 14;
- getRequestbroadcastVariableMsgBuilder() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.RequestBroadcastVariableMessage requestbroadcastVariableMsg = 14;
- getRequestbroadcastVariableMsgOrBuilder() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.RequestBroadcastVariableMessage requestbroadcastVariableMsg = 14;
- getRequestbroadcastVariableMsgOrBuilder() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
-
optional .protobuf.RequestBroadcastVariableMessage requestbroadcastVariableMsg = 14;
- getRequestbroadcastVariableMsgOrBuilder() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.MessageOrBuilder
-
optional .protobuf.RequestBroadcastVariableMessage requestbroadcastVariableMsg = 14;
- getRequestId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsg.Builder
-
To find the matching request msg
- getRequestId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsg
-
To find the matching request msg
- getRequestId() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsgOrBuilder
-
To find the matching request msg
- getRequestId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.InMasterBroadcastVariableMessage.Builder
-
To find the matching request msg
- getRequestId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.InMasterBroadcastVariableMessage
-
To find the matching request msg
- getRequestId() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.InMasterBroadcastVariableMessageOrBuilder
-
To find the matching request msg
- getRequestId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeLocationInfoMessage.Builder
-
To find the matching request msg
- getRequestId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeLocationInfoMessage
-
To find the matching request msg
- getRequestId() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.PipeLocationInfoMessageOrBuilder
-
To find the matching request msg
- getRequestMethod() - Static method in class org.apache.nemo.runtime.common.comm.MessageServiceGrpc
- getRequestPipeLocMsg() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.RequestPipeLocationMessage requestPipeLocMsg = 17;
- getRequestPipeLocMsg() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
-
optional .protobuf.RequestPipeLocationMessage requestPipeLocMsg = 17;
- getRequestPipeLocMsg() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.MessageOrBuilder
-
optional .protobuf.RequestPipeLocationMessage requestPipeLocMsg = 17;
- getRequestPipeLocMsgBuilder() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.RequestPipeLocationMessage requestPipeLocMsg = 17;
- getRequestPipeLocMsgOrBuilder() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.RequestPipeLocationMessage requestPipeLocMsg = 17;
- getRequestPipeLocMsgOrBuilder() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
-
optional .protobuf.RequestPipeLocationMessage requestPipeLocMsg = 17;
- getRequestPipeLocMsgOrBuilder() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.MessageOrBuilder
-
optional .protobuf.RequestPipeLocationMessage requestPipeLocMsg = 17;
- getResourceSpecId() - Method in class org.apache.nemo.common.ir.executionproperty.ResourceSpecification
- getRootVertices() - Method in class org.apache.nemo.common.dag.DAG
- getRootVertices() - Method in interface org.apache.nemo.common.dag.DAGInterface
-
Retrieves the root vertices of this DAG.
- getRootVertices() - Method in class org.apache.nemo.common.ir.IRDAG
- getRunningTasks() - Method in class org.apache.nemo.runtime.master.resource.DefaultExecutorRepresenter
- getRunningTasks() - Method in interface org.apache.nemo.runtime.master.resource.ExecutorRepresenter
- getRuntimeEdgeId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptor.Builder
-
required string runtimeEdgeId = 3;
- getRuntimeEdgeId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptor
-
required string runtimeEdgeId = 3;
- getRuntimeEdgeId() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptorOrBuilder
-
required string runtimeEdgeId = 3;
- getRuntimeEdgeId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeInitMessage.Builder
-
required string runtimeEdgeId = 2;
- getRuntimeEdgeId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeInitMessage
-
required string runtimeEdgeId = 2;
- getRuntimeEdgeId() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.PipeInitMessageOrBuilder
-
required string runtimeEdgeId = 2;
- getRuntimeEdgeId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptor.Builder
-
required string runtimeEdgeId = 2;
- getRuntimeEdgeId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptor
-
required string runtimeEdgeId = 2;
- getRuntimeEdgeId() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptorOrBuilder
-
required string runtimeEdgeId = 2;
- getRuntimeEdgeId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestPipeLocationMessage.Builder
-
required string runtimeEdgeId = 3;
- getRuntimeEdgeId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestPipeLocationMessage
-
required string runtimeEdgeId = 3;
- getRuntimeEdgeId() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.RequestPipeLocationMessageOrBuilder
-
required string runtimeEdgeId = 3;
- getRuntimeEdgeIdBytes() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptor.Builder
-
required string runtimeEdgeId = 3;
- getRuntimeEdgeIdBytes() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptor
-
required string runtimeEdgeId = 3;
- getRuntimeEdgeIdBytes() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptorOrBuilder
-
required string runtimeEdgeId = 3;
- getRuntimeEdgeIdBytes() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeInitMessage.Builder
-
required string runtimeEdgeId = 2;
- getRuntimeEdgeIdBytes() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeInitMessage
-
required string runtimeEdgeId = 2;
- getRuntimeEdgeIdBytes() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.PipeInitMessageOrBuilder
-
required string runtimeEdgeId = 2;
- getRuntimeEdgeIdBytes() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptor.Builder
-
required string runtimeEdgeId = 2;
- getRuntimeEdgeIdBytes() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptor
-
required string runtimeEdgeId = 2;
- getRuntimeEdgeIdBytes() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptorOrBuilder
-
required string runtimeEdgeId = 2;
- getRuntimeEdgeIdBytes() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestPipeLocationMessage.Builder
-
required string runtimeEdgeId = 3;
- getRuntimeEdgeIdBytes() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestPipeLocationMessage
-
required string runtimeEdgeId = 3;
- getRuntimeEdgeIdBytes() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.RequestPipeLocationMessageOrBuilder
-
required string runtimeEdgeId = 3;
- getRuntimeEdgeIdFromBlockId(String) - Static method in class org.apache.nemo.runtime.common.RuntimeIdManager
-
Extracts runtime edge ID from a block ID.
- getRunTimePasses() - Method in class org.apache.nemo.compiler.optimizer.policy.PolicyBuilder
-
Getter for run time passes.
- getRunTimePassMessageMsg() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.RunTimePassMessageMsg runTimePassMessageMsg = 7;
- getRunTimePassMessageMsg() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
-
optional .protobuf.RunTimePassMessageMsg runTimePassMessageMsg = 7;
- getRunTimePassMessageMsg() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.MessageOrBuilder
-
optional .protobuf.RunTimePassMessageMsg runTimePassMessageMsg = 7;
- getRunTimePassMessageMsgBuilder() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.RunTimePassMessageMsg runTimePassMessageMsg = 7;
- getRunTimePassMessageMsgOrBuilder() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.RunTimePassMessageMsg runTimePassMessageMsg = 7;
- getRunTimePassMessageMsgOrBuilder() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
-
optional .protobuf.RunTimePassMessageMsg runTimePassMessageMsg = 7;
- getRunTimePassMessageMsgOrBuilder() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.MessageOrBuilder
-
optional .protobuf.RunTimePassMessageMsg runTimePassMessageMsg = 7;
- getSalary() - Method in class org.apache.nemo.examples.spark.sql.JavaUserDefinedTypedAggregation.Employee
-
Getter.
- getScheduleAttempt() - Method in class org.apache.nemo.runtime.common.metric.TaskMetric
-
Method related to schedule attempt.
- getScheduleGroup() - Method in class org.apache.nemo.runtime.common.plan.Stage
- getScheduleTaskMsg() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.ScheduleTaskMsg scheduleTaskMsg = 5;
- getScheduleTaskMsg() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
-
optional .protobuf.ScheduleTaskMsg scheduleTaskMsg = 5;
- getScheduleTaskMsg() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.MessageOrBuilder
-
optional .protobuf.ScheduleTaskMsg scheduleTaskMsg = 5;
- getScheduleTaskMsgBuilder() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.ScheduleTaskMsg scheduleTaskMsg = 5;
- getScheduleTaskMsgOrBuilder() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.ScheduleTaskMsg scheduleTaskMsg = 5;
- getScheduleTaskMsgOrBuilder() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
-
optional .protobuf.ScheduleTaskMsg scheduleTaskMsg = 5;
- getScheduleTaskMsgOrBuilder() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.MessageOrBuilder
-
optional .protobuf.ScheduleTaskMsg scheduleTaskMsg = 5;
- getSchedulingOverhead() - Method in class org.apache.nemo.runtime.common.metric.TaskMetric
-
Method related to scheduling overhead.
- getSendMethod() - Static method in class org.apache.nemo.runtime.common.comm.MessageServiceGrpc
- getSerializedData() - Method in interface org.apache.nemo.common.ir.vertex.transform.Transform.Context
-
Retrieve the serialized data on the executor.
- getSerializedData() - Method in class org.apache.nemo.runtime.executor.TransformContextImpl
- getSerializedIRDag() - Method in class org.apache.nemo.runtime.common.plan.Task
- getSerializedIRDAG() - Method in class org.apache.nemo.runtime.common.plan.Stage
- getSerializedReadBytes() - Method in class org.apache.nemo.runtime.common.metric.StreamMetric
-
Get the number of read bytes.
- getSerializedReadBytes() - Method in class org.apache.nemo.runtime.common.metric.TaskMetric
-
Method related to serialized read bytes.
- getSerializedSize() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsg
- getSerializedSize() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsg
- getSerializedSize() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptor
- getSerializedSize() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage
- getSerializedSize() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessage
- getSerializedSize() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ContainerFailedMsg
- getSerializedSize() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DataCollectMessage
- getSerializedSize() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessage
- getSerializedSize() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ExecutorFailedMsg
- getSerializedSize() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.InMasterBroadcastVariableMessage
- getSerializedSize() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.LaunchDAGMessage
- getSerializedSize() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
- getSerializedSize() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Metric
- getSerializedSize() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.MetricMsg
- getSerializedSize() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.NotificationMessage
- getSerializedSize() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeInitMessage
- getSerializedSize() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeLocationInfoMessage
- getSerializedSize() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptor
- getSerializedSize() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBlockLocationMsg
- getSerializedSize() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBroadcastVariableMessage
- getSerializedSize() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestPipeLocationMessage
- getSerializedSize() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageEntry
- getSerializedSize() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsg
- getSerializedSize() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ScheduleTaskMsg
- getSerializedSize() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg
- getSerializedSize() - Method in class org.apache.nemo.runtime.common.comm.GrpcMessageService.Void
- getSerializer(String) - Method in class org.apache.nemo.runtime.executor.data.PipeManagerWorker
- getSerializer(String) - Method in class org.apache.nemo.runtime.executor.data.SerializerManager
-
Return the serializer for the specified runtime edge.
- getServerChannelClass() - Method in class org.apache.nemo.runtime.common.NativeChannelImplementationSelector
- getServerChannelClass() - Method in interface org.apache.nemo.runtime.common.NettyChannelImplementationSelector
- getServerChannelClass() - Method in class org.apache.nemo.runtime.common.NioChannelImplementationSelector
- getServiceDescriptor() - Static method in class org.apache.nemo.runtime.common.comm.MessageServiceGrpc
- getShort(int) - Method in class org.apache.nemo.runtime.executor.data.MemoryChunk
-
Reads a short integer value from the given position, composing them into a short value according to the current byte order.
- getShuffleReadBytes() - Method in class org.apache.nemo.runtime.common.metric.TaskMetric
-
Method related to shuffle.
- getShuffleReadTime() - Method in class org.apache.nemo.runtime.common.metric.TaskMetric
- getShuffleWriteBytes() - Method in class org.apache.nemo.runtime.common.metric.TaskMetric
- getShuffleWriteTime() - Method in class org.apache.nemo.runtime.common.metric.TaskMetric
- getSideInputIndex() - Method in class org.apache.nemo.compiler.frontend.beam.SideInputElement
- getSideInputValue() - Method in class org.apache.nemo.compiler.frontend.beam.SideInputElement
- getSourceParallelism(InputReader) - Static method in interface org.apache.nemo.runtime.executor.datatransfer.InputReader
- getSrc() - Method in class org.apache.nemo.common.dag.Edge
- getSrcIrVertex() - Method in class org.apache.nemo.runtime.executor.datatransfer.BlockInputReader
- getSrcIrVertex() - Method in interface org.apache.nemo.runtime.executor.datatransfer.InputReader
- getSrcIrVertex() - Method in class org.apache.nemo.runtime.executor.datatransfer.PipeInputReader
- getSrcIRVertex() - Method in class org.apache.nemo.runtime.common.plan.StageEdge
- getSrcTaskIndex() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeInitMessage.Builder
-
required int64 srcTaskIndex = 1;
- getSrcTaskIndex() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeInitMessage
-
required int64 srcTaskIndex = 1;
- getSrcTaskIndex() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.PipeInitMessageOrBuilder
-
required int64 srcTaskIndex = 1;
- getSrcTaskIndex() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptor.Builder
-
required int64 srcTaskIndex = 1;
- getSrcTaskIndex() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptor
-
required int64 srcTaskIndex = 1;
- getSrcTaskIndex() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptorOrBuilder
-
required int64 srcTaskIndex = 1;
- getSrcTaskIndex() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestPipeLocationMessage.Builder
-
required int64 srcTaskIndex = 2;
- getSrcTaskIndex() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestPipeLocationMessage
-
required int64 srcTaskIndex = 2;
- getSrcTaskIndex() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.RequestPipeLocationMessageOrBuilder
-
required int64 srcTaskIndex = 2;
- getSrcTaskIndex() - Method in class org.apache.nemo.runtime.executor.transfer.LocalTransferContext
-
Accessor method for the source task index.
- getStageDAG() - Method in class org.apache.nemo.runtime.common.metric.JobMetric
- getStageDAG() - Method in class org.apache.nemo.runtime.common.plan.PhysicalPlan
- getStageId() - Method in class org.apache.nemo.runtime.common.plan.Task
- getStageIdFromTaskId(String) - Static method in class org.apache.nemo.runtime.common.RuntimeIdManager
-
Extracts stage ID from a task ID.
- getStageProperties(IRVertex) - Method in class org.apache.nemo.runtime.common.plan.StagePartitioner
- getStageState(String) - Method in class org.apache.nemo.runtime.master.PlanStateManager
- getStartTimeStamp() - Method in class org.apache.nemo.runtime.common.metric.StreamMetric
-
Get starting point of record period.
- getState() - Method in class org.apache.nemo.client.beam.NemoPipelineResult
- getState() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsg.Builder
-
optional .protobuf.BlockStateFromExecutor state = 3;
- getState() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsg
-
optional .protobuf.BlockStateFromExecutor state = 3;
- getState() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsgOrBuilder
-
optional .protobuf.BlockStateFromExecutor state = 3;
- getState() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsg.Builder
-
required .protobuf.BlockStateFromExecutor state = 3;
- getState() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsg
-
required .protobuf.BlockStateFromExecutor state = 3;
- getState() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsgOrBuilder
-
required .protobuf.BlockStateFromExecutor state = 3;
- getState() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg.Builder
-
required .protobuf.TaskStateFromExecutor state = 3;
- getState() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg
-
required .protobuf.TaskStateFromExecutor state = 3;
- getState() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsgOrBuilder
-
required .protobuf.TaskStateFromExecutor state = 3;
- getState() - Method in exception org.apache.nemo.runtime.common.exception.AbsentBlockException
- getStateInternalMap() - Method in class org.apache.nemo.compiler.frontend.beam.transform.InMemoryStateInternalsFactory
- getStateMachine() - Method in class org.apache.nemo.runtime.common.state.BlockState
- getStateMachine() - Method in class org.apache.nemo.runtime.common.state.PlanState
- getStateMachine() - Method in class org.apache.nemo.runtime.common.state.StageState
- getStateMachine() - Method in class org.apache.nemo.runtime.common.state.TaskState
- getStateTransitionEvents() - Method in class org.apache.nemo.runtime.common.metric.JobMetric
- getStateTransitionEvents() - Method in class org.apache.nemo.runtime.common.metric.StageMetric
- getStateTransitionEvents() - Method in interface org.apache.nemo.runtime.common.metric.StateMetric
-
Get its list of
StateTransitionEvent
. - getStateTransitionEvents() - Method in class org.apache.nemo.runtime.common.metric.TaskMetric
-
Method related to state transition events.
- getStaticReference() - Static method in class org.apache.nemo.runtime.executor.data.BroadcastManagerWorker
- getStore() - Static method in class org.apache.nemo.runtime.master.metric.MetricStore
-
Getter for singleton instance.
- getStreamMetric() - Method in class org.apache.nemo.runtime.common.metric.TaskMetric
-
Method related to stream metric.
- getSum() - Method in class org.apache.nemo.examples.spark.sql.JavaUserDefinedTypedAggregation.Average
-
Getter.
- getTask() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ScheduleTaskMsg.Builder
-
required bytes task = 1;
- getTask() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ScheduleTaskMsg
-
required bytes task = 1;
- getTask() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.ScheduleTaskMsgOrBuilder
-
required bytes task = 1;
- getTaskAttemptsToSchedule(String) - Method in class org.apache.nemo.runtime.master.PlanStateManager
-
Get task attempts that are "READY".
- getTaskCPUTime() - Method in class org.apache.nemo.runtime.common.metric.TaskMetric
-
Method related to task CPU time.
- getTaskDeserializationTime() - Method in class org.apache.nemo.runtime.common.metric.TaskMetric
-
Method related to task deserialization time.
- getTaskDuration() - Method in class org.apache.nemo.runtime.common.metric.TaskMetric
-
Method related to task duration.
- getTaskId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsg.Builder
-
required string taskId = 1;
- getTaskId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsg
-
required string taskId = 1;
- getTaskId() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsgOrBuilder
-
required string taskId = 1;
- getTaskId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg.Builder
-
required string taskId = 2;
- getTaskId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg
-
required string taskId = 2;
- getTaskId() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsgOrBuilder
-
required string taskId = 2;
- getTaskId() - Method in class org.apache.nemo.runtime.common.plan.Task
- getTaskIdBytes() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsg.Builder
-
required string taskId = 1;
- getTaskIdBytes() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsg
-
required string taskId = 1;
- getTaskIdBytes() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsgOrBuilder
-
required string taskId = 1;
- getTaskIdBytes() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg.Builder
-
required string taskId = 2;
- getTaskIdBytes() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg
-
required string taskId = 2;
- getTaskIdBytes() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsgOrBuilder
-
required string taskId = 2;
- getTaskIncomingEdges() - Method in class org.apache.nemo.runtime.common.plan.Task
- getTaskIndexFromBlockId(String) - Static method in class org.apache.nemo.runtime.common.RuntimeIdManager
-
Extracts task index from a block ID.
- getTaskIndices() - Method in class org.apache.nemo.runtime.common.plan.Stage
- getTaskOutgoingEdges() - Method in class org.apache.nemo.runtime.common.plan.Task
- getTaskOutputBytes() - Method in class org.apache.nemo.runtime.common.metric.TaskMetric
-
Method related to task output bytes.
- getTaskSerializationTime() - Method in class org.apache.nemo.runtime.common.metric.TaskMetric
-
Method related to task serialization time.
- getTaskSizeRatio() - Method in class org.apache.nemo.runtime.common.metric.TaskMetric
-
Method related to task size ratio.
- getTaskState(String) - Method in class org.apache.nemo.runtime.master.PlanStateManager
- getTaskStateChangedMsg() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.TaskStateChangedMsg taskStateChangedMsg = 4;
- getTaskStateChangedMsg() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
-
optional .protobuf.TaskStateChangedMsg taskStateChangedMsg = 4;
- getTaskStateChangedMsg() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.MessageOrBuilder
-
optional .protobuf.TaskStateChangedMsg taskStateChangedMsg = 4;
- getTaskStateChangedMsgBuilder() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.TaskStateChangedMsg taskStateChangedMsg = 4;
- getTaskStateChangedMsgOrBuilder() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.TaskStateChangedMsg taskStateChangedMsg = 4;
- getTaskStateChangedMsgOrBuilder() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
-
optional .protobuf.TaskStateChangedMsg taskStateChangedMsg = 4;
- getTaskStateChangedMsgOrBuilder() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.MessageOrBuilder
-
optional .protobuf.TaskStateChangedMsg taskStateChangedMsg = 4;
- getTerminationCondition() - Method in class org.apache.nemo.common.ir.vertex.LoopVertex
- getTimerInternalsMap() - Method in class org.apache.nemo.compiler.frontend.beam.transform.InMemoryTimerInternalsFactory
-
Accessor for timerInternalsMap.
- getTimestamp() - Method in class org.apache.nemo.common.punctuation.Watermark
- getTimestamp() - Method in class org.apache.nemo.runtime.common.metric.Event
-
Get timestamp.
- getTimestamp() - Method in class org.apache.nemo.runtime.common.metric.LatencyMetric
-
Get the timestamp when the latencymark is received.
- getTopologicalSort() - Method in class org.apache.nemo.common.dag.DAG
- getTopologicalSort() - Method in interface org.apache.nemo.common.dag.DAGInterface
-
Gets the DAG's vertices in topologically sorted order.
- getTopologicalSort() - Method in class org.apache.nemo.common.ir.IRDAG
- getTransferIndex() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage.Builder
-
required int32 transferIndex = 2;
- getTransferIndex() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage
-
required int32 transferIndex = 2;
- getTransferIndex() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessageOrBuilder
-
required int32 transferIndex = 2;
- getTransferType() - Method in class org.apache.nemo.runtime.common.metric.DataTransferEvent
-
Get transfer type.
- getTransform() - Method in class org.apache.nemo.common.ir.vertex.OperatorVertex
- getType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessage.Builder
-
required .protobuf.ClientToDriverMessageType type = 1;
- getType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessage
-
required .protobuf.ClientToDriverMessageType type = 1;
- getType() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessageOrBuilder
-
required .protobuf.ClientToDriverMessageType type = 1;
- getType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessage.Builder
-
required .protobuf.DriverToClientMessageType type = 1;
- getType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessage
-
required .protobuf.DriverToClientMessageType type = 1;
- getType() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessageOrBuilder
-
required .protobuf.DriverToClientMessageType type = 1;
- getType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
required .protobuf.MessageType type = 1;
- getType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
-
required .protobuf.MessageType type = 1;
- getType() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.MessageOrBuilder
-
required .protobuf.MessageType type = 1;
- getUnknownFields() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsg
- getUnknownFields() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsg
- getUnknownFields() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptor
- getUnknownFields() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage
- getUnknownFields() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessage
- getUnknownFields() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ContainerFailedMsg
- getUnknownFields() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DataCollectMessage
- getUnknownFields() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessage
- getUnknownFields() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ExecutorFailedMsg
- getUnknownFields() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.InMasterBroadcastVariableMessage
- getUnknownFields() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.LaunchDAGMessage
- getUnknownFields() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
- getUnknownFields() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Metric
- getUnknownFields() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.MetricMsg
- getUnknownFields() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.NotificationMessage
- getUnknownFields() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeInitMessage
- getUnknownFields() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeLocationInfoMessage
- getUnknownFields() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptor
- getUnknownFields() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBlockLocationMsg
- getUnknownFields() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBroadcastVariableMessage
- getUnknownFields() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestPipeLocationMessage
- getUnknownFields() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageEntry
- getUnknownFields() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsg
- getUnknownFields() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ScheduleTaskMsg
- getUnknownFields() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg
- getUnknownFields() - Method in class org.apache.nemo.runtime.common.comm.GrpcMessageService.Void
- getValue() - Method in class org.apache.nemo.common.ir.executionproperty.ExecutionProperty
- getValue() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageEntry.Builder
-
required int64 value = 2;
- getValue() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageEntry
-
required int64 value = 2;
- getValue() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageEntryOrBuilder
-
required int64 value = 2;
- getValueDescriptor() - Method in enum org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateFromExecutor
- getValueDescriptor() - Method in enum org.apache.nemo.runtime.common.comm.ControlMessage.BlockStore
- getValueDescriptor() - Method in enum org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferDataDirection
- getValueDescriptor() - Method in enum org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessageType
- getValueDescriptor() - Method in enum org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessageType
- getValueDescriptor() - Method in enum org.apache.nemo.runtime.common.comm.ControlMessage.MessageType
- getValueDescriptor() - Method in enum org.apache.nemo.runtime.common.comm.ControlMessage.OptimizationType
- getValueDescriptor() - Method in enum org.apache.nemo.runtime.common.comm.ControlMessage.RecoverableFailureCause
- getValueDescriptor() - Method in enum org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateFromExecutor
- getVariable() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.InMasterBroadcastVariableMessage.Builder
-
required bytes variable = 2;
- getVariable() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.InMasterBroadcastVariableMessage
-
required bytes variable = 2;
- getVariable() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.InMasterBroadcastVariableMessageOrBuilder
-
required bytes variable = 2;
- getVertexById(String) - Method in class org.apache.nemo.common.dag.DAG
- getVertexById(String) - Method in interface org.apache.nemo.common.dag.DAGInterface
-
Retrieves the vertex given its ID.
- getVertexById(String) - Method in class org.apache.nemo.common.ir.IRDAG
- getVertexId(Vertex) - Static method in class org.apache.nemo.common.ir.IdManager
-
Used for cloning vertices.
- getVertexIdToReadables() - Method in class org.apache.nemo.runtime.common.plan.Stage
- getVertexProperties() - Method in class org.apache.nemo.runtime.common.metric.JobMetric
- getVertexPutOnHoldId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg.Builder
-
optional string vertexPutOnHoldId = 4;
- getVertexPutOnHoldId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg
-
optional string vertexPutOnHoldId = 4;
- getVertexPutOnHoldId() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsgOrBuilder
-
optional string vertexPutOnHoldId = 4;
- getVertexPutOnHoldIdBytes() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg.Builder
-
optional string vertexPutOnHoldId = 4;
- getVertexPutOnHoldIdBytes() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg
-
optional string vertexPutOnHoldId = 4;
- getVertexPutOnHoldIdBytes() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsgOrBuilder
-
optional string vertexPutOnHoldId = 4;
- getVertices() - Method in class org.apache.nemo.common.dag.DAG
- getVertices() - Method in interface org.apache.nemo.common.dag.DAGInterface
-
Retrieves the vertices of this DAG.
- getVertices() - Method in class org.apache.nemo.common.ir.IRDAG
- getVerticesWithGroupOutgoingEdges() - Method in class org.apache.nemo.common.ir.vertex.utility.TaskSizeSplitterVertex
- getWatermark() - Method in class org.apache.nemo.runtime.executor.datatransfer.WatermarkWithIndex
- getWatermarkManager() - Method in class org.apache.nemo.runtime.executor.datatransfer.NextIntraTaskOperatorInfo
- getWildCardFromBlockId(String) - Static method in class org.apache.nemo.runtime.common.RuntimeIdManager
-
Extracts wild card from a block ID.
- getWrittenBytes() - Method in class org.apache.nemo.runtime.executor.datatransfer.BlockOutputWriter
- getWrittenBytes() - Method in interface org.apache.nemo.runtime.executor.datatransfer.OutputWriter
- getWrittenBytes() - Method in class org.apache.nemo.runtime.executor.datatransfer.PipeOutputWriter
- GLUSTER_DISK_DIRECTORY - Static variable in class org.apache.nemo.conf.JobConf
- GLUSTER_FILE_STORE - org.apache.nemo.common.ir.edge.executionproperty.DataStoreProperty.Value
- GlusterFileStore - Class in org.apache.nemo.runtime.executor.data.stores
-
Stores blocks in a mounted GlusterFS volume.
- GlusterVolumeDirectory() - Constructor for class org.apache.nemo.conf.JobConf.GlusterVolumeDirectory
- GroupByKeyTransform<I> - Class in org.apache.nemo.compiler.frontend.beam.transform
-
Group Beam KVs.
- GroupByKeyTransform() - Constructor for class org.apache.nemo.compiler.frontend.beam.transform.GroupByKeyTransform
-
GroupByKey constructor.
- GrpcMessageEnvironment - Class in org.apache.nemo.runtime.common.message.grpc
-
This class is installed when every node, containing both driver and evaluator, has been started, and setup grpc environment to implement RPC semantics defined in
org.apache.nemo.runtime.common.message
package. - GrpcMessageService - Class in org.apache.nemo.runtime.common.comm
- GrpcMessageService.Void - Class in org.apache.nemo.runtime.common.comm
-
Protobuf type
protobuf.Void
- GrpcMessageService.Void.Builder - Class in org.apache.nemo.runtime.common.comm
-
Protobuf type
protobuf.Void
- GrpcMessageService.VoidOrBuilder - Interface in org.apache.nemo.runtime.common.comm
- GZIP - org.apache.nemo.common.ir.edge.executionproperty.CompressionProperty.Value
H
- hasAttemptIdx() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg.Builder
-
required int32 attemptIdx = 6;
- hasAttemptIdx() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg
-
required int32 attemptIdx = 6;
- hasAttemptIdx() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsgOrBuilder
-
required int32 attemptIdx = 6;
- hasBlockId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsg.Builder
-
required string blockId = 2;
- hasBlockId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsg
-
required string blockId = 2;
- hasBlockId() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsgOrBuilder
-
required string blockId = 2;
- hasBlockId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsg.Builder
-
required string blockId = 2;
- hasBlockId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsg
-
required string blockId = 2;
- hasBlockId() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsgOrBuilder
-
required string blockId = 2;
- hasBlockId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptor.Builder
-
required string blockId = 1;
- hasBlockId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptor
-
required string blockId = 1;
- hasBlockId() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptorOrBuilder
-
required string blockId = 1;
- hasBlockIdWildcard() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBlockLocationMsg.Builder
-
required string blockIdWildcard = 2;
- hasBlockIdWildcard() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBlockLocationMsg
-
required string blockIdWildcard = 2;
- hasBlockIdWildcard() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.RequestBlockLocationMsgOrBuilder
-
required string blockIdWildcard = 2;
- hasBlockLocationInfoMsg() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.BlockLocationInfoMsg blockLocationInfoMsg = 9;
- hasBlockLocationInfoMsg() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
-
optional .protobuf.BlockLocationInfoMsg blockLocationInfoMsg = 9;
- hasBlockLocationInfoMsg() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.MessageOrBuilder
-
optional .protobuf.BlockLocationInfoMsg blockLocationInfoMsg = 9;
- hasBlockStateChangedMsg() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.BlockStateChangedMsg blockStateChangedMsg = 6;
- hasBlockStateChangedMsg() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
-
optional .protobuf.BlockStateChangedMsg blockStateChangedMsg = 6;
- hasBlockStateChangedMsg() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.MessageOrBuilder
-
optional .protobuf.BlockStateChangedMsg blockStateChangedMsg = 6;
- hasBlockStore() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptor.Builder
-
required .protobuf.BlockStore blockStore = 2;
- hasBlockStore() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptor
-
required .protobuf.BlockStore blockStore = 2;
- hasBlockStore() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptorOrBuilder
-
required .protobuf.BlockStore blockStore = 2;
- hasBroadcastId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBroadcastVariableMessage.Builder
-
required bytes broadcastId = 2;
- hasBroadcastId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBroadcastVariableMessage
-
required bytes broadcastId = 2;
- hasBroadcastId() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.RequestBroadcastVariableMessageOrBuilder
-
required bytes broadcastId = 2;
- hasBroadcastVariableMsg() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.InMasterBroadcastVariableMessage broadcastVariableMsg = 15;
- hasBroadcastVariableMsg() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
-
optional .protobuf.InMasterBroadcastVariableMessage broadcastVariableMsg = 15;
- hasBroadcastVariableMsg() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.MessageOrBuilder
-
optional .protobuf.InMasterBroadcastVariableMessage broadcastVariableMsg = 15;
- hasBroadcastVars() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.LaunchDAGMessage.Builder
-
optional bytes broadcastVars = 2;
- hasBroadcastVars() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.LaunchDAGMessage
-
optional bytes broadcastVars = 2;
- hasBroadcastVars() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.LaunchDAGMessageOrBuilder
-
optional bytes broadcastVars = 2;
- hasContainerFailedMsg() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.ContainerFailedMsg containerFailedMsg = 11;
- hasContainerFailedMsg() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
-
optional .protobuf.ContainerFailedMsg containerFailedMsg = 11;
- hasContainerFailedMsg() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.MessageOrBuilder
-
optional .protobuf.ContainerFailedMsg containerFailedMsg = 11;
- hasContextDescriptor() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage.Builder
-
required bytes contextDescriptor = 4;
- hasContextDescriptor() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage
-
required bytes contextDescriptor = 4;
- hasContextDescriptor() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessageOrBuilder
-
required bytes contextDescriptor = 4;
- hasDag() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.LaunchDAGMessage.Builder
-
required string dag = 1;
- hasDag() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.LaunchDAGMessage
-
required string dag = 1;
- hasDag() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.LaunchDAGMessageOrBuilder
-
required string dag = 1;
- hasData() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DataCollectMessage.Builder
-
required string data = 1;
- hasData() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DataCollectMessage
-
required string data = 1;
- hasData() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.DataCollectMessageOrBuilder
-
required string data = 1;
- hasData() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.NotificationMessage.Builder
-
required string data = 2;
- hasData() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.NotificationMessage
-
required string data = 2;
- hasData() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.NotificationMessageOrBuilder
-
required string data = 2;
- hasDataCollected() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessage.Builder
-
optional .protobuf.DataCollectMessage dataCollected = 2;
- hasDataCollected() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessage
-
optional .protobuf.DataCollectMessage dataCollected = 2;
- hasDataCollected() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessageOrBuilder
-
optional .protobuf.DataCollectMessage dataCollected = 2;
- hasDataCollected() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.DataCollectMessage dataCollected = 13;
- hasDataCollected() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
-
optional .protobuf.DataCollectMessage dataCollected = 13;
- hasDataCollected() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.MessageOrBuilder
-
optional .protobuf.DataCollectMessage dataCollected = 13;
- hasDataDirection() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage.Builder
-
required .protobuf.ByteTransferDataDirection dataDirection = 3;
- hasDataDirection() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage
-
required .protobuf.ByteTransferDataDirection dataDirection = 3;
- hasDataDirection() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessageOrBuilder
-
required .protobuf.ByteTransferDataDirection dataDirection = 3;
- hasDstTaskIndex() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptor.Builder
-
required int64 dstTaskIndex = 3;
- hasDstTaskIndex() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptor
-
required int64 dstTaskIndex = 3;
- hasDstTaskIndex() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptorOrBuilder
-
required int64 dstTaskIndex = 3;
- hasException() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ExecutorFailedMsg.Builder
-
required bytes exception = 2;
- hasException() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ExecutorFailedMsg
-
required bytes exception = 2;
- hasException() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.ExecutorFailedMsgOrBuilder
-
required bytes exception = 2;
- hasException() - Method in class org.apache.nemo.runtime.executor.transfer.ByteTransferContext
- hasExecutorFailedMsg() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.ExecutorFailedMsg executorFailedMsg = 10;
- hasExecutorFailedMsg() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
-
optional .protobuf.ExecutorFailedMsg executorFailedMsg = 10;
- hasExecutorFailedMsg() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.MessageOrBuilder
-
optional .protobuf.ExecutorFailedMsg executorFailedMsg = 10;
- hasExecutorId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsg.Builder
-
required string executorId = 1;
- hasExecutorId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsg
-
required string executorId = 1;
- hasExecutorId() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsgOrBuilder
-
required string executorId = 1;
- hasExecutorId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ContainerFailedMsg.Builder
-
required string executorId = 1;
- hasExecutorId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ContainerFailedMsg
-
required string executorId = 1;
- hasExecutorId() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.ContainerFailedMsgOrBuilder
-
required string executorId = 1;
- hasExecutorId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ExecutorFailedMsg.Builder
-
required string executorId = 1;
- hasExecutorId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ExecutorFailedMsg
-
required string executorId = 1;
- hasExecutorId() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.ExecutorFailedMsgOrBuilder
-
required string executorId = 1;
- hasExecutorId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeInitMessage.Builder
-
required string executorId = 3;
- hasExecutorId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeInitMessage
-
required string executorId = 3;
- hasExecutorId() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.PipeInitMessageOrBuilder
-
required string executorId = 3;
- hasExecutorId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeLocationInfoMessage.Builder
-
required string executorId = 2;
- hasExecutorId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeLocationInfoMessage
-
required string executorId = 2;
- hasExecutorId() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.PipeLocationInfoMessageOrBuilder
-
required string executorId = 2;
- hasExecutorId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBlockLocationMsg.Builder
-
required string executorId = 1;
- hasExecutorId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBlockLocationMsg
-
required string executorId = 1;
- hasExecutorId() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.RequestBlockLocationMsgOrBuilder
-
required string executorId = 1;
- hasExecutorId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBroadcastVariableMessage.Builder
-
required string executorId = 1;
- hasExecutorId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBroadcastVariableMessage
-
required string executorId = 1;
- hasExecutorId() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.RequestBroadcastVariableMessageOrBuilder
-
required string executorId = 1;
- hasExecutorId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestPipeLocationMessage.Builder
-
required string executorId = 1;
- hasExecutorId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestPipeLocationMessage
-
required string executorId = 1;
- hasExecutorId() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.RequestPipeLocationMessageOrBuilder
-
required string executorId = 1;
- hasExecutorId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg.Builder
-
required string executorId = 1;
- hasExecutorId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg
-
required string executorId = 1;
- hasExecutorId() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsgOrBuilder
-
required string executorId = 1;
- hasFailureCause() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg.Builder
-
optional .protobuf.RecoverableFailureCause failureCause = 5;
- hasFailureCause() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg
-
optional .protobuf.RecoverableFailureCause failureCause = 5;
- hasFailureCause() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsgOrBuilder
-
optional .protobuf.RecoverableFailureCause failureCause = 5;
- HASH - org.apache.nemo.common.ir.edge.executionproperty.PartitionerProperty.Type
- HASH_RANGE_MULTIPLIER - Static variable in class org.apache.nemo.compiler.optimizer.pass.compiletime.annotating.SkewAnnotatingPass
-
Hash range multiplier.
- hashCode() - Method in class org.apache.nemo.common.HashRange
- hashCode() - Method in class org.apache.nemo.common.ir.edge.IREdge
- hashCode() - Method in class org.apache.nemo.common.ir.executionproperty.ExecutionProperty
- hashCode() - Method in class org.apache.nemo.common.ir.executionproperty.ExecutionPropertyMap
- hashCode() - Method in class org.apache.nemo.common.ir.vertex.executionproperty.ClonedSchedulingProperty.CloneConf
- hashCode() - Method in interface org.apache.nemo.common.KeyRange
-
This method should be overridden for KeyRange comparisons.
- hashCode() - Method in class org.apache.nemo.common.Pair
- hashCode() - Method in class org.apache.nemo.common.PairKeyExtractor
- hashCode() - Method in class org.apache.nemo.common.punctuation.LatencyMark
- hashCode() - Method in class org.apache.nemo.common.punctuation.Watermark
- hashCode() - Method in class org.apache.nemo.compiler.frontend.spark.SparkKeyExtractor
- hashCode() - Method in class org.apache.nemo.compiler.optimizer.pass.compiletime.annotating.DefaultParallelismPass
- hashCode() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsg
- hashCode() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsg
- hashCode() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptor
- hashCode() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage
- hashCode() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessage
- hashCode() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ContainerFailedMsg
- hashCode() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DataCollectMessage
- hashCode() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessage
- hashCode() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ExecutorFailedMsg
- hashCode() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.InMasterBroadcastVariableMessage
- hashCode() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.LaunchDAGMessage
- hashCode() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
- hashCode() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Metric
- hashCode() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.MetricMsg
- hashCode() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.NotificationMessage
- hashCode() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeInitMessage
- hashCode() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeLocationInfoMessage
- hashCode() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptor
- hashCode() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBlockLocationMsg
- hashCode() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBroadcastVariableMessage
- hashCode() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestPipeLocationMessage
- hashCode() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageEntry
- hashCode() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsg
- hashCode() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ScheduleTaskMsg
- hashCode() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg
- hashCode() - Method in class org.apache.nemo.runtime.common.comm.GrpcMessageService.Void
- hashCode() - Method in class org.apache.nemo.runtime.common.plan.StageEdge
- hashCode() - Method in class org.apache.nemo.runtime.executor.data.FileArea
- HashPartitioner - Class in org.apache.nemo.common.partitioner
-
An implementation of
Partitioner
which hashes output data from a source task according to the key of elements. - HashPartitioner(int, KeyExtractor) - Constructor for class org.apache.nemo.common.partitioner.HashPartitioner
-
Constructor.
- HashRange - Class in org.apache.nemo.common
-
Descriptor for hash range.
- hasId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
required int64 id = 2;
- hasId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
-
required int64 id = 2;
- hasId() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.MessageOrBuilder
-
required int64 id = 2;
- hasInitiatorExecutorId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage.Builder
-
required string initiatorExecutorId = 1;
- hasInitiatorExecutorId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage
-
required string initiatorExecutorId = 1;
- hasInitiatorExecutorId() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessageOrBuilder
-
required string initiatorExecutorId = 1;
- hasIsPipe() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage.Builder
-
required bool isPipe = 5;
- hasIsPipe() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage
-
required bool isPipe = 5;
- hasIsPipe() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessageOrBuilder
-
required bool isPipe = 5;
- hasKey() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageEntry.Builder
-
required string key = 1;
- hasKey() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageEntry
-
required string key = 1;
- hasKey() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageEntryOrBuilder
-
required string key = 1;
- hasKeyRange() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptor.Builder
-
optional bytes keyRange = 4;
- hasKeyRange() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptor
-
optional bytes keyRange = 4;
- hasKeyRange() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptorOrBuilder
-
optional bytes keyRange = 4;
- hasLaunchDAG() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessage.Builder
-
optional .protobuf.LaunchDAGMessage launchDAG = 2;
- hasLaunchDAG() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessage
-
optional .protobuf.LaunchDAGMessage launchDAG = 2;
- hasLaunchDAG() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessageOrBuilder
-
optional .protobuf.LaunchDAGMessage launchDAG = 2;
- hasListenerId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
The id of the message listener (handler).
- hasListenerId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
-
The id of the message listener (handler).
- hasListenerId() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.MessageOrBuilder
-
The id of the message listener (handler).
- hasLocation() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsg.Builder
-
The location of the block (e.g., executor id or remote store).
- hasLocation() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsg
-
The location of the block (e.g., executor id or remote store).
- hasLocation() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsgOrBuilder
-
The location of the block (e.g., executor id or remote store).
- hasMessage() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessage.Builder
-
optional .protobuf.NotificationMessage message = 3;
- hasMessage() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessage
-
optional .protobuf.NotificationMessage message = 3;
- hasMessage() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessageOrBuilder
-
optional .protobuf.NotificationMessage message = 3;
- hasMetricField() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Metric.Builder
-
required string metricField = 3;
- hasMetricField() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Metric
-
required string metricField = 3;
- hasMetricField() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.MetricOrBuilder
-
required string metricField = 3;
- hasMetricId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Metric.Builder
-
required string metricId = 2;
- hasMetricId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Metric
-
required string metricId = 2;
- hasMetricId() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.MetricOrBuilder
-
required string metricId = 2;
- hasMetricMsg() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.MetricMsg metricMsg = 12;
- hasMetricMsg() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
-
optional .protobuf.MetricMsg metricMsg = 12;
- hasMetricMsg() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.MessageOrBuilder
-
optional .protobuf.MetricMsg metricMsg = 12;
- hasMetricType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Metric.Builder
-
required string metricType = 1;
- hasMetricType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Metric
-
required string metricType = 1;
- hasMetricType() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.MetricOrBuilder
-
required string metricType = 1;
- hasMetricValue() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Metric.Builder
-
required bytes metricValue = 4;
- hasMetricValue() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Metric
-
required bytes metricValue = 4;
- hasMetricValue() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.MetricOrBuilder
-
required bytes metricValue = 4;
- hasNext() - Method in class org.apache.nemo.runtime.executor.data.DataUtil.InputStreamIterator
- hasNumPipeToWait() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptor.Builder
-
required int64 numPipeToWait = 4;
- hasNumPipeToWait() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptor
-
required int64 numPipeToWait = 4;
- hasNumPipeToWait() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptorOrBuilder
-
required int64 numPipeToWait = 4;
- hasOptimizationType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessage.Builder
-
optional .protobuf.OptimizationType optimizationType = 3;
- hasOptimizationType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessage
-
optional .protobuf.OptimizationType optimizationType = 3;
- hasOptimizationType() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessageOrBuilder
-
optional .protobuf.OptimizationType optimizationType = 3;
- hasOptimizationType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.NotificationMessage.Builder
-
required .protobuf.OptimizationType optimizationType = 1;
- hasOptimizationType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.NotificationMessage
-
required .protobuf.OptimizationType optimizationType = 1;
- hasOptimizationType() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.NotificationMessageOrBuilder
-
required .protobuf.OptimizationType optimizationType = 1;
- hasOwnerExecutorId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsg.Builder
-
optional string ownerExecutorId = 4;
- hasOwnerExecutorId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsg
-
optional string ownerExecutorId = 4;
- hasOwnerExecutorId() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsgOrBuilder
-
optional string ownerExecutorId = 4;
- hasPipeInitMsg() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.PipeInitMessage pipeInitMsg = 16;
- hasPipeInitMsg() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
-
optional .protobuf.PipeInitMessage pipeInitMsg = 16;
- hasPipeInitMsg() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.MessageOrBuilder
-
optional .protobuf.PipeInitMessage pipeInitMsg = 16;
- hasPipeLocInfoMsg() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.PipeLocationInfoMessage pipeLocInfoMsg = 18;
- hasPipeLocInfoMsg() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
-
optional .protobuf.PipeLocationInfoMessage pipeLocInfoMsg = 18;
- hasPipeLocInfoMsg() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.MessageOrBuilder
-
optional .protobuf.PipeLocationInfoMessage pipeLocInfoMsg = 18;
- hasRequestBlockLocationMsg() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.RequestBlockLocationMsg requestBlockLocationMsg = 8;
- hasRequestBlockLocationMsg() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
-
optional .protobuf.RequestBlockLocationMsg requestBlockLocationMsg = 8;
- hasRequestBlockLocationMsg() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.MessageOrBuilder
-
optional .protobuf.RequestBlockLocationMsg requestBlockLocationMsg = 8;
- hasRequestbroadcastVariableMsg() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.RequestBroadcastVariableMessage requestbroadcastVariableMsg = 14;
- hasRequestbroadcastVariableMsg() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
-
optional .protobuf.RequestBroadcastVariableMessage requestbroadcastVariableMsg = 14;
- hasRequestbroadcastVariableMsg() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.MessageOrBuilder
-
optional .protobuf.RequestBroadcastVariableMessage requestbroadcastVariableMsg = 14;
- hasRequestId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsg.Builder
-
To find the matching request msg
- hasRequestId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsg
-
To find the matching request msg
- hasRequestId() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsgOrBuilder
-
To find the matching request msg
- hasRequestId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.InMasterBroadcastVariableMessage.Builder
-
To find the matching request msg
- hasRequestId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.InMasterBroadcastVariableMessage
-
To find the matching request msg
- hasRequestId() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.InMasterBroadcastVariableMessageOrBuilder
-
To find the matching request msg
- hasRequestId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeLocationInfoMessage.Builder
-
To find the matching request msg
- hasRequestId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeLocationInfoMessage
-
To find the matching request msg
- hasRequestId() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.PipeLocationInfoMessageOrBuilder
-
To find the matching request msg
- hasRequestPipeLocMsg() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.RequestPipeLocationMessage requestPipeLocMsg = 17;
- hasRequestPipeLocMsg() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
-
optional .protobuf.RequestPipeLocationMessage requestPipeLocMsg = 17;
- hasRequestPipeLocMsg() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.MessageOrBuilder
-
optional .protobuf.RequestPipeLocationMessage requestPipeLocMsg = 17;
- hasRuntimeEdgeId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptor.Builder
-
required string runtimeEdgeId = 3;
- hasRuntimeEdgeId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptor
-
required string runtimeEdgeId = 3;
- hasRuntimeEdgeId() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptorOrBuilder
-
required string runtimeEdgeId = 3;
- hasRuntimeEdgeId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeInitMessage.Builder
-
required string runtimeEdgeId = 2;
- hasRuntimeEdgeId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeInitMessage
-
required string runtimeEdgeId = 2;
- hasRuntimeEdgeId() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.PipeInitMessageOrBuilder
-
required string runtimeEdgeId = 2;
- hasRuntimeEdgeId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptor.Builder
-
required string runtimeEdgeId = 2;
- hasRuntimeEdgeId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptor
-
required string runtimeEdgeId = 2;
- hasRuntimeEdgeId() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptorOrBuilder
-
required string runtimeEdgeId = 2;
- hasRuntimeEdgeId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestPipeLocationMessage.Builder
-
required string runtimeEdgeId = 3;
- hasRuntimeEdgeId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestPipeLocationMessage
-
required string runtimeEdgeId = 3;
- hasRuntimeEdgeId() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.RequestPipeLocationMessageOrBuilder
-
required string runtimeEdgeId = 3;
- hasRunTimePassMessageMsg() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.RunTimePassMessageMsg runTimePassMessageMsg = 7;
- hasRunTimePassMessageMsg() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
-
optional .protobuf.RunTimePassMessageMsg runTimePassMessageMsg = 7;
- hasRunTimePassMessageMsg() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.MessageOrBuilder
-
optional .protobuf.RunTimePassMessageMsg runTimePassMessageMsg = 7;
- hasSameItineraryAs(IREdge) - Method in class org.apache.nemo.common.ir.edge.IREdge
- hasSameItineraryAs(StageEdge) - Method in class org.apache.nemo.runtime.common.plan.StageEdge
- hasScheduleTaskMsg() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.ScheduleTaskMsg scheduleTaskMsg = 5;
- hasScheduleTaskMsg() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
-
optional .protobuf.ScheduleTaskMsg scheduleTaskMsg = 5;
- hasScheduleTaskMsg() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.MessageOrBuilder
-
optional .protobuf.ScheduleTaskMsg scheduleTaskMsg = 5;
- hasSrcTaskIndex() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeInitMessage.Builder
-
required int64 srcTaskIndex = 1;
- hasSrcTaskIndex() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeInitMessage
-
required int64 srcTaskIndex = 1;
- hasSrcTaskIndex() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.PipeInitMessageOrBuilder
-
required int64 srcTaskIndex = 1;
- hasSrcTaskIndex() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptor.Builder
-
required int64 srcTaskIndex = 1;
- hasSrcTaskIndex() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptor
-
required int64 srcTaskIndex = 1;
- hasSrcTaskIndex() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptorOrBuilder
-
required int64 srcTaskIndex = 1;
- hasSrcTaskIndex() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestPipeLocationMessage.Builder
-
required int64 srcTaskIndex = 2;
- hasSrcTaskIndex() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestPipeLocationMessage
-
required int64 srcTaskIndex = 2;
- hasSrcTaskIndex() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.RequestPipeLocationMessageOrBuilder
-
required int64 srcTaskIndex = 2;
- hasState() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsg.Builder
-
optional .protobuf.BlockStateFromExecutor state = 3;
- hasState() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsg
-
optional .protobuf.BlockStateFromExecutor state = 3;
- hasState() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsgOrBuilder
-
optional .protobuf.BlockStateFromExecutor state = 3;
- hasState() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsg.Builder
-
required .protobuf.BlockStateFromExecutor state = 3;
- hasState() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsg
-
required .protobuf.BlockStateFromExecutor state = 3;
- hasState() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsgOrBuilder
-
required .protobuf.BlockStateFromExecutor state = 3;
- hasState() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg.Builder
-
required .protobuf.TaskStateFromExecutor state = 3;
- hasState() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg
-
required .protobuf.TaskStateFromExecutor state = 3;
- hasState() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsgOrBuilder
-
required .protobuf.TaskStateFromExecutor state = 3;
- hasTask() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ScheduleTaskMsg.Builder
-
required bytes task = 1;
- hasTask() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ScheduleTaskMsg
-
required bytes task = 1;
- hasTask() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.ScheduleTaskMsgOrBuilder
-
required bytes task = 1;
- hasTaskId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsg.Builder
-
required string taskId = 1;
- hasTaskId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsg
-
required string taskId = 1;
- hasTaskId() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsgOrBuilder
-
required string taskId = 1;
- hasTaskId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg.Builder
-
required string taskId = 2;
- hasTaskId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg
-
required string taskId = 2;
- hasTaskId() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsgOrBuilder
-
required string taskId = 2;
- hasTaskStateChangedMsg() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.TaskStateChangedMsg taskStateChangedMsg = 4;
- hasTaskStateChangedMsg() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
-
optional .protobuf.TaskStateChangedMsg taskStateChangedMsg = 4;
- hasTaskStateChangedMsg() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.MessageOrBuilder
-
optional .protobuf.TaskStateChangedMsg taskStateChangedMsg = 4;
- hasTransferIndex() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage.Builder
-
required int32 transferIndex = 2;
- hasTransferIndex() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage
-
required int32 transferIndex = 2;
- hasTransferIndex() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessageOrBuilder
-
required int32 transferIndex = 2;
- hasType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessage.Builder
-
required .protobuf.ClientToDriverMessageType type = 1;
- hasType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessage
-
required .protobuf.ClientToDriverMessageType type = 1;
- hasType() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessageOrBuilder
-
required .protobuf.ClientToDriverMessageType type = 1;
- hasType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessage.Builder
-
required .protobuf.DriverToClientMessageType type = 1;
- hasType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessage
-
required .protobuf.DriverToClientMessageType type = 1;
- hasType() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessageOrBuilder
-
required .protobuf.DriverToClientMessageType type = 1;
- hasType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
required .protobuf.MessageType type = 1;
- hasType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
-
required .protobuf.MessageType type = 1;
- hasType() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.MessageOrBuilder
-
required .protobuf.MessageType type = 1;
- hasValue() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageEntry.Builder
-
required int64 value = 2;
- hasValue() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageEntry
-
required int64 value = 2;
- hasValue() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageEntryOrBuilder
-
required int64 value = 2;
- hasVariable() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.InMasterBroadcastVariableMessage.Builder
-
required bytes variable = 2;
- hasVariable() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.InMasterBroadcastVariableMessage
-
required bytes variable = 2;
- hasVariable() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.InMasterBroadcastVariableMessageOrBuilder
-
required bytes variable = 2;
- hasVertexPutOnHoldId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg.Builder
-
optional string vertexPutOnHoldId = 4;
- hasVertexPutOnHoldId() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg
-
optional string vertexPutOnHoldId = 4;
- hasVertexPutOnHoldId() - Method in interface org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsgOrBuilder
-
optional string vertexPutOnHoldId = 4;
I
- ID_FIELD_NUMBER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
- IdManager - Class in org.apache.nemo.common.ir
-
ID manager.
- IgnoreSchedulingTempDataReceiverProperty - Class in org.apache.nemo.common.ir.vertex.executionproperty
-
A property represents that a vertex annotated with this property doesn't process any data and should be regarded as a kind of "marker" to construct a temporary edge that contains some data that have to be written before it's usage is not determined (e.g., for caching).
- IllegalEdgeOperationException - Exception in org.apache.nemo.common.exception
-
IllegalEdgeOperationException.
- IllegalEdgeOperationException(String) - Constructor for exception org.apache.nemo.common.exception.IllegalEdgeOperationException
-
IllegalEdgeOperationException.
- IllegalEdgeOperationException(Throwable) - Constructor for exception org.apache.nemo.common.exception.IllegalEdgeOperationException
-
IllegalEdgeOperationException.
- IllegalMessageException - Exception in org.apache.nemo.common.exception
-
IllegalMessageException.
- IllegalMessageException(Throwable) - Constructor for exception org.apache.nemo.common.exception.IllegalMessageException
-
IllegalMessageException.
- IllegalStateTransitionException - Exception in org.apache.nemo.common.exception
-
IllegalStateTransitionException.
- IllegalStateTransitionException(Throwable) - Constructor for exception org.apache.nemo.common.exception.IllegalStateTransitionException
-
IllegalStateTransitionException.
- IllegalVertexOperationException - Exception in org.apache.nemo.common.exception
-
IllegalVertexOperationException.
- IllegalVertexOperationException(String) - Constructor for exception org.apache.nemo.common.exception.IllegalVertexOperationException
-
IllegalVertexOperationException.
- IN_PROGRESS - org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateFromExecutor
-
IN_PROGRESS = 1;
- IN_PROGRESS - org.apache.nemo.runtime.common.state.BlockState.State
- IN_PROGRESS_VALUE - Static variable in enum org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateFromExecutor
-
IN_PROGRESS = 1;
- includes(Integer) - Method in class org.apache.nemo.common.HashRange
- includes(K) - Method in interface org.apache.nemo.common.KeyRange
- INCOMPLETE - org.apache.nemo.runtime.common.state.StageState.State
- increaseMaxNumberOfIterations() - Method in class org.apache.nemo.common.ir.vertex.LoopVertex
-
increase the value of maximum number of iterations by 1.
- increaseTestingTrial() - Method in class org.apache.nemo.common.ir.vertex.utility.TaskSizeSplitterVertex
- initialize(MutableAggregationBuffer) - Method in class org.apache.nemo.examples.spark.sql.JavaUserDefinedUntypedAggregation.MyAverage
-
Initializes the given aggregation buffer.
- initializeIterator() - Method in class org.apache.nemo.common.ir.BoundedIteratorReadable
-
Initialize iterator.
- INITIATOR_RECEIVES_DATA - org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferDataDirection
-
INITIATOR_RECEIVES_DATA = 1;
- INITIATOR_RECEIVES_DATA_VALUE - Static variable in enum org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferDataDirection
-
INITIATOR_RECEIVES_DATA = 1;
- INITIATOR_SENDS_DATA - org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferDataDirection
-
INITIATOR_SENDS_DATA = 0;
- INITIATOR_SENDS_DATA_VALUE - Static variable in enum org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferDataDirection
-
INITIATOR_SENDS_DATA = 0;
- INITIATOREXECUTORID_FIELD_NUMBER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage
- InMasterBroadcastVariable - org.apache.nemo.runtime.common.comm.ControlMessage.MessageType
-
InMasterBroadcastVariable = 12;
- InMasterBroadcastVariable_VALUE - Static variable in enum org.apache.nemo.runtime.common.comm.ControlMessage.MessageType
-
InMasterBroadcastVariable = 12;
- InMemorySideInputReader - Class in org.apache.nemo.compiler.frontend.beam
-
Accumulates and provides side inputs in memory.
- InMemorySideInputReader(Collection<PCollectionView<?>>) - Constructor for class org.apache.nemo.compiler.frontend.beam.InMemorySideInputReader
- InMemorySourceVertex<T> - Class in org.apache.nemo.common.ir.vertex
-
Source vertex with the data in memory.
- InMemorySourceVertex(Iterable<T>) - Constructor for class org.apache.nemo.common.ir.vertex.InMemorySourceVertex
-
Constructor for InMemorySourceVertex.
- InMemoryStateInternalsFactory<K> - Class in org.apache.nemo.compiler.frontend.beam.transform
-
InMemoryStateInternalsFactory.
- InMemoryStateInternalsFactory() - Constructor for class org.apache.nemo.compiler.frontend.beam.transform.InMemoryStateInternalsFactory
- InMemoryTimerInternalsFactory<K> - Class in org.apache.nemo.compiler.frontend.beam.transform
-
InMemoryTimerInternalsFactory.
- InMemoryTimerInternalsFactory() - Constructor for class org.apache.nemo.compiler.frontend.beam.transform.InMemoryTimerInternalsFactory
- INPUT_READ_FAILURE - org.apache.nemo.runtime.common.state.TaskState.RecoverableTaskFailureCause
- INPUT_TYPE_BOUNDED - Static variable in class org.apache.nemo.examples.beam.WindowedWordCount
- INPUT_TYPE_UNBOUNDED - Static variable in class org.apache.nemo.examples.beam.WindowedWordCount
- InputReader - Interface in org.apache.nemo.runtime.executor.datatransfer
-
Represents the input data transfer to a task.
- InputReadFailure - org.apache.nemo.runtime.common.comm.ControlMessage.RecoverableFailureCause
-
InputReadFailure = 0;
- InputReadFailure_VALUE - Static variable in enum org.apache.nemo.runtime.common.comm.ControlMessage.RecoverableFailureCause
-
InputReadFailure = 0;
- inputSchema() - Method in class org.apache.nemo.examples.spark.sql.JavaUserDefinedUntypedAggregation.MyAverage
-
Data types of input arguments of this aggregate function.
- InputWatermarkManager - Interface in org.apache.nemo.runtime.executor.datatransfer
-
An interface for tracking input watermarks among multiple input streams.
- insert(Set<SamplingVertex>, Set<IRVertex>) - Method in class org.apache.nemo.common.ir.IRDAG
-
Inserts a set of samplingVertices that process sampled data.
- insert(RelayVertex, IREdge) - Method in class org.apache.nemo.common.ir.IRDAG
-
Inserts a new vertex that streams data.
- insert(MessageGeneratorVertex, MessageAggregatorVertex, EncoderProperty, DecoderProperty, Set<IREdge>, Set<IREdge>) - Method in class org.apache.nemo.common.ir.IRDAG
-
Inserts a new vertex that analyzes intermediate data, and triggers a dynamic optimization.
- insert(SignalVertex, IREdge) - Method in class org.apache.nemo.common.ir.IRDAG
-
Inserts new vertex which calls for runtime pass.
- insert(TaskSizeSplitterVertex) - Method in class org.apache.nemo.common.ir.IRDAG
-
Insert TaskSizeSplitterVertex in dag.
- INTACT - org.apache.nemo.common.ir.edge.executionproperty.PartitionerProperty.Type
- IntactPartitioner - Class in org.apache.nemo.common.partitioner
-
An implementation of
Partitioner
which makes an output data from a source task to a single partition. - IntactPartitioner() - Constructor for class org.apache.nemo.common.partitioner.IntactPartitioner
- IntArrayCoder - Class in org.apache.nemo.examples.beam
-
EncoderFactory for int[].
- IntDecoderFactory - Class in org.apache.nemo.common.coder
-
A
DecoderFactory
which is used for an integer. - IntEncoderFactory - Class in org.apache.nemo.common.coder
-
A
EncoderFactory
which is used for an integer. - IntermediateDataIOFactory - Class in org.apache.nemo.runtime.executor.datatransfer
-
A factory that produces
InputReader
andOutputWriter
. - internalGetFieldAccessorTable() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsg.Builder
- internalGetFieldAccessorTable() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsg
- internalGetFieldAccessorTable() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsg.Builder
- internalGetFieldAccessorTable() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsg
- internalGetFieldAccessorTable() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptor.Builder
- internalGetFieldAccessorTable() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptor
- internalGetFieldAccessorTable() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage.Builder
- internalGetFieldAccessorTable() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage
- internalGetFieldAccessorTable() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessage.Builder
- internalGetFieldAccessorTable() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessage
- internalGetFieldAccessorTable() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ContainerFailedMsg.Builder
- internalGetFieldAccessorTable() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ContainerFailedMsg
- internalGetFieldAccessorTable() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DataCollectMessage.Builder
- internalGetFieldAccessorTable() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DataCollectMessage
- internalGetFieldAccessorTable() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessage.Builder
- internalGetFieldAccessorTable() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessage
- internalGetFieldAccessorTable() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ExecutorFailedMsg.Builder
- internalGetFieldAccessorTable() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ExecutorFailedMsg
- internalGetFieldAccessorTable() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.InMasterBroadcastVariableMessage.Builder
- internalGetFieldAccessorTable() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.InMasterBroadcastVariableMessage
- internalGetFieldAccessorTable() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.LaunchDAGMessage.Builder
- internalGetFieldAccessorTable() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.LaunchDAGMessage
- internalGetFieldAccessorTable() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
- internalGetFieldAccessorTable() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
- internalGetFieldAccessorTable() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Metric.Builder
- internalGetFieldAccessorTable() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Metric
- internalGetFieldAccessorTable() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.MetricMsg.Builder
- internalGetFieldAccessorTable() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.MetricMsg
- internalGetFieldAccessorTable() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.NotificationMessage.Builder
- internalGetFieldAccessorTable() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.NotificationMessage
- internalGetFieldAccessorTable() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeInitMessage.Builder
- internalGetFieldAccessorTable() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeInitMessage
- internalGetFieldAccessorTable() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeLocationInfoMessage.Builder
- internalGetFieldAccessorTable() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeLocationInfoMessage
- internalGetFieldAccessorTable() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptor.Builder
- internalGetFieldAccessorTable() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptor
- internalGetFieldAccessorTable() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBlockLocationMsg.Builder
- internalGetFieldAccessorTable() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBlockLocationMsg
- internalGetFieldAccessorTable() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBroadcastVariableMessage.Builder
- internalGetFieldAccessorTable() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBroadcastVariableMessage
- internalGetFieldAccessorTable() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestPipeLocationMessage.Builder
- internalGetFieldAccessorTable() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestPipeLocationMessage
- internalGetFieldAccessorTable() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageEntry.Builder
- internalGetFieldAccessorTable() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageEntry
- internalGetFieldAccessorTable() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsg.Builder
- internalGetFieldAccessorTable() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsg
- internalGetFieldAccessorTable() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ScheduleTaskMsg.Builder
- internalGetFieldAccessorTable() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ScheduleTaskMsg
- internalGetFieldAccessorTable() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg.Builder
- internalGetFieldAccessorTable() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg
- internalGetFieldAccessorTable() - Method in class org.apache.nemo.runtime.common.comm.GrpcMessageService.Void.Builder
- internalGetFieldAccessorTable() - Method in class org.apache.nemo.runtime.common.comm.GrpcMessageService.Void
- internalGetValueMap() - Static method in enum org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateFromExecutor
- internalGetValueMap() - Static method in enum org.apache.nemo.runtime.common.comm.ControlMessage.BlockStore
- internalGetValueMap() - Static method in enum org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferDataDirection
- internalGetValueMap() - Static method in enum org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessageType
- internalGetValueMap() - Static method in enum org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessageType
- internalGetValueMap() - Static method in enum org.apache.nemo.runtime.common.comm.ControlMessage.MessageType
- internalGetValueMap() - Static method in enum org.apache.nemo.runtime.common.comm.ControlMessage.OptimizationType
- internalGetValueMap() - Static method in enum org.apache.nemo.runtime.common.comm.ControlMessage.RecoverableFailureCause
- internalGetValueMap() - Static method in enum org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateFromExecutor
- InvalidParameterException - Exception in org.apache.nemo.common.exception
-
InvalidParameterException.
- InvalidParameterException(String) - Constructor for exception org.apache.nemo.common.exception.InvalidParameterException
-
InvalidParameterException.
- InvalidUserMainException - Exception in org.apache.nemo.common.exception
-
InvalidUserMainException.
- InvalidUserMainException(String) - Constructor for exception org.apache.nemo.common.exception.InvalidUserMainException
-
InvalidUserMainException.
- InvalidUserMainException(Throwable) - Constructor for exception org.apache.nemo.common.exception.InvalidUserMainException
-
InvalidUserMainException.
- IORequestHandleThreadsTotal() - Constructor for class org.apache.nemo.conf.JobConf.IORequestHandleThreadsTotal
- IRDAG - Class in org.apache.nemo.common.ir
-
An IRDAG object captures a high-level data processing application (e.g., Spark/Beam application).
- IRDAG(DAG<IRVertex, IREdge>) - Constructor for class org.apache.nemo.common.ir.IRDAG
- IRDAGChecker - Class in org.apache.nemo.common.ir
-
Checks the integrity of an IR DAG.
- IRDAGChecker.CheckerResult - Class in org.apache.nemo.common.ir
-
Result of a checker.
- IRDAGChecker.GlobalDAGChecker - Interface in org.apache.nemo.common.ir
-
Checks the entire DAG.
- irDAGSummary() - Method in class org.apache.nemo.common.ir.IRDAG
- IREdge - Class in org.apache.nemo.common.ir.edge
-
Physical execution plan of intermediate data movement.
- IREdge(CommunicationPatternProperty.Value, IRVertex, IRVertex) - Constructor for class org.apache.nemo.common.ir.edge.IREdge
-
Constructor of IREdge.
- IRVertex - Class in org.apache.nemo.common.ir.vertex
-
The basic unit of operation in a dataflow program, as well as the most important data structure in Nemo.
- IRVertex() - Constructor for class org.apache.nemo.common.ir.vertex.IRVertex
-
Constructor of IRVertex.
- IRVertex(IRVertex) - Constructor for class org.apache.nemo.common.ir.vertex.IRVertex
-
Copy Constructor for IRVertex.
- isAll() - Method in class org.apache.nemo.common.HashRange
- isAll() - Method in interface org.apache.nemo.common.KeyRange
- isBounded() - Method in class org.apache.nemo.common.ir.vertex.CachedSourceVertex
- isBounded() - Method in class org.apache.nemo.common.ir.vertex.InMemorySourceVertex
- isBounded() - Method in class org.apache.nemo.common.ir.vertex.SourceVertex
- isBounded() - Method in class org.apache.nemo.common.test.EmptyComponents.EmptySourceVertex
- isBounded() - Method in class org.apache.nemo.compiler.frontend.beam.source.BeamBoundedSourceVertex
- isBounded() - Method in class org.apache.nemo.compiler.frontend.beam.source.BeamUnboundedSourceVertex
- isClosed() - Method in class org.apache.nemo.runtime.executor.transfer.LocalOutputContext
-
Checks whether the context has been closed.
- isCommitted() - Method in interface org.apache.nemo.runtime.executor.data.block.Block
- isCommitted() - Method in class org.apache.nemo.runtime.executor.data.block.FileBlock
- isCommitted() - Method in class org.apache.nemo.runtime.executor.data.block.NonSerializedMemoryBlock
- isCommitted() - Method in class org.apache.nemo.runtime.executor.data.block.SerializedMemoryBlock
- isCommitted() - Method in class org.apache.nemo.runtime.executor.data.metadata.FileMetadata
- isCompositeVertex(IRVertex) - Method in class org.apache.nemo.common.ir.IRDAG
- isCompositeVertex(V) - Method in class org.apache.nemo.common.dag.DAG
- isCompositeVertex(V) - Method in interface org.apache.nemo.common.dag.DAGInterface
-
Checks whether the given vertex is assigned with a wrapping LoopVertex.
- isControlEdge(IREdge) - Static method in class org.apache.nemo.common.Util
- isEmpty() - Method in class org.apache.nemo.common.dag.DAGBuilder
-
Checks whether the DAGBuilder is empty.
- isEmpty() - Method in class org.apache.nemo.compiler.frontend.beam.InMemorySideInputReader
- isEmpty(InMemoryTimerInternals) - Method in class org.apache.nemo.compiler.frontend.beam.transform.InMemoryTimerInternalsFactory
-
Helper method to check if
timerInternals
doesn't have any timers left. - isFinished() - Method in class org.apache.nemo.common.ir.BoundedIteratorReadable
- isFinished() - Method in interface org.apache.nemo.common.ir.Readable
- isInitialized() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsg.Builder
- isInitialized() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsg
- isInitialized() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsg.Builder
- isInitialized() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsg
- isInitialized() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptor.Builder
- isInitialized() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptor
- isInitialized() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage.Builder
- isInitialized() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage
- isInitialized() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessage.Builder
- isInitialized() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessage
- isInitialized() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ContainerFailedMsg.Builder
- isInitialized() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ContainerFailedMsg
- isInitialized() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DataCollectMessage.Builder
- isInitialized() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DataCollectMessage
- isInitialized() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessage.Builder
- isInitialized() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessage
- isInitialized() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ExecutorFailedMsg.Builder
- isInitialized() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ExecutorFailedMsg
- isInitialized() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.InMasterBroadcastVariableMessage.Builder
- isInitialized() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.InMasterBroadcastVariableMessage
- isInitialized() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.LaunchDAGMessage.Builder
- isInitialized() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.LaunchDAGMessage
- isInitialized() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
- isInitialized() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
- isInitialized() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Metric.Builder
- isInitialized() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Metric
- isInitialized() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.MetricMsg.Builder
- isInitialized() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.MetricMsg
- isInitialized() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.NotificationMessage.Builder
- isInitialized() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.NotificationMessage
- isInitialized() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeInitMessage.Builder
- isInitialized() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeInitMessage
- isInitialized() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeLocationInfoMessage.Builder
- isInitialized() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeLocationInfoMessage
- isInitialized() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptor.Builder
- isInitialized() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptor
- isInitialized() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBlockLocationMsg.Builder
- isInitialized() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBlockLocationMsg
- isInitialized() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBroadcastVariableMessage.Builder
- isInitialized() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBroadcastVariableMessage
- isInitialized() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestPipeLocationMessage.Builder
- isInitialized() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestPipeLocationMessage
- isInitialized() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageEntry.Builder
- isInitialized() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageEntry
- isInitialized() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsg.Builder
- isInitialized() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsg
- isInitialized() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ScheduleTaskMsg.Builder
- isInitialized() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ScheduleTaskMsg
- isInitialized() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg.Builder
- isInitialized() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg
- isInitialized() - Method in class org.apache.nemo.runtime.common.comm.GrpcMessageService.Void.Builder
- isInitialized() - Method in class org.apache.nemo.runtime.common.comm.GrpcMessageService.Void
- isInitialized() - Method in class org.apache.nemo.runtime.master.PlanStateManager
- isOffheap() - Method in class org.apache.nemo.runtime.executor.data.partition.SerializedPartition
- isOutputContextClosed() - Method in class org.apache.nemo.runtime.executor.transfer.LocalInputContext
-
Checks if the connected output context has already been closed.
- isPassed() - Method in class org.apache.nemo.common.ir.IRDAGChecker.CheckerResult
- ISPIPE_FIELD_NUMBER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage
- isPlanDone() - Method in class org.apache.nemo.runtime.master.PlanStateManager
- isReadNotSerializedData() - Method in class org.apache.nemo.runtime.executor.data.DataUtil.InputStreamIterator
- isReadNotSerializedData() - Method in interface org.apache.nemo.runtime.executor.data.DataUtil.IteratorWithNumBytes
- isReady(PCollectionView, BoundedWindow) - Method in class org.apache.nemo.compiler.frontend.beam.InMemorySideInputReader
- isRepresentativeEdgeDecided() - Method in class org.apache.nemo.common.ir.edge.executionproperty.DuplicateEdgeGroupPropertyValue
- isSerialized() - Method in class org.apache.nemo.runtime.executor.data.partition.NonSerializedPartition
- isSerialized() - Method in interface org.apache.nemo.runtime.executor.data.partition.Partition
- isSerialized() - Method in class org.apache.nemo.runtime.executor.data.partition.SerializedPartition
- isUpFrontCloning() - Method in class org.apache.nemo.common.ir.vertex.executionproperty.ClonedSchedulingProperty.CloneConf
- isUtilityVertex() - Method in class org.apache.nemo.common.ir.vertex.IRVertex
- isUtilityVertex(IRVertex) - Static method in class org.apache.nemo.common.Util
J
- JavaMapReduce - Class in org.apache.nemo.examples.spark
-
Java MapReduce example.
- JavaSparkPi - Class in org.apache.nemo.examples.spark
-
Computes an approximation to pi.
- JavaSparkSQLExample - Class in org.apache.nemo.examples.spark.sql
-
Java Spark SQL Example program.
- JavaSparkSQLExample.Person - Class in org.apache.nemo.examples.spark.sql
-
Simple person class.
- JavaUserDefinedTypedAggregation - Class in org.apache.nemo.examples.spark.sql
-
Java SparkSQL example: User-defined Typed Aggregation.
- JavaUserDefinedTypedAggregation.Average - Class in org.apache.nemo.examples.spark.sql
-
Average class.
- JavaUserDefinedTypedAggregation.Employee - Class in org.apache.nemo.examples.spark.sql
-
Employee class.
- JavaUserDefinedTypedAggregation.MyAverage - Class in org.apache.nemo.examples.spark.sql
-
MyAverage class.
- JavaUserDefinedUntypedAggregation - Class in org.apache.nemo.examples.spark.sql
-
Java SparkSQL example: User-defined Untyped Aggregation.
- JavaUserDefinedUntypedAggregation.MyAverage - Class in org.apache.nemo.examples.spark.sql
-
MyAverage class.
- JavaWordAndLineCount - Class in org.apache.nemo.examples.spark
-
Java Spark word-count and line-count examples in one.
- JavaWordCount - Class in org.apache.nemo.examples.spark
-
Java Wordcount example.
- JOB_ID - Static variable in class org.apache.nemo.conf.JobConf
- JobConf - Class in org.apache.nemo.conf
-
Job Configurations.
- JobConf() - Constructor for class org.apache.nemo.conf.JobConf
- JobConf.BandwidthJSONContents - Class in org.apache.nemo.conf
-
Contents of the JSON file that specifies bandwidth between locations.
- JobConf.BandwidthJSONPath - Class in org.apache.nemo.conf
-
Path to the JSON file that specifies bandwidth between locations.
- JobConf.ChunkSizeKb - Class in org.apache.nemo.conf
-
MemoryChunk size in the memory pool.
- JobConf.ClientSideRPCServerHost - Class in org.apache.nemo.conf
-
Host of the client-side RPC server.
- JobConf.ClientSideRPCServerPort - Class in org.apache.nemo.conf
-
Port of the client-side RPC server.
- JobConf.DAGDirectory - Class in org.apache.nemo.conf
-
Directory to store JSON representation of intermediate DAGs.
- JobConf.DBAddress - Class in org.apache.nemo.conf
-
Address pointing to the DB for saving metrics.
- JobConf.DBEnabled - Class in org.apache.nemo.conf
-
Specified whether or not to enable writing metrics to DB or not.
- JobConf.DBId - Class in org.apache.nemo.conf
-
ID for the pointed DB address for saving metrics.
- JobConf.DBPasswd - Class in org.apache.nemo.conf
-
Password for the pointed DB address for saving metrics.
- JobConf.DeployMode - Class in org.apache.nemo.conf
-
Deploy mode.
- JobConf.DriverMemMb - Class in org.apache.nemo.conf
-
Nemo driver memory.
- JobConf.EnvironmentType - Class in org.apache.nemo.conf
-
Specifies the type of the environment the workload runs on.
- JobConf.ExecutorId - Class in org.apache.nemo.conf
-
Executor id.
- JobConf.ExecutorJSONContents - Class in org.apache.nemo.conf
-
Contents of the JSON file that specifies resource layout.
- JobConf.ExecutorJSONPath - Class in org.apache.nemo.conf
-
Path to the JSON file that specifies resource layout.
- JobConf.ExecutorMemoryMb - Class in org.apache.nemo.conf
-
The size of total memory in the executor.
- JobConf.ExecutorPoisonSec - Class in org.apache.nemo.conf
-
Used for fault-injected tests.
- JobConf.ExecutorType - Class in org.apache.nemo.conf
-
Executor type: lambda: Nemo will use lambda executor.
- JobConf.FileDirectory - Class in org.apache.nemo.conf
-
Directory to store files for storing blocks.
- JobConf.GlusterVolumeDirectory - Class in org.apache.nemo.conf
-
Directory points the mounted GlusterFS volume to store files in remote fashion.
- JobConf.IORequestHandleThreadsTotal - Class in org.apache.nemo.conf
-
Number of I/O threads for block fetch requests from other executor.
- JobConf.JobId - Class in org.apache.nemo.conf
-
Job id.
- JobConf.JVMHeapSlack - Class in org.apache.nemo.conf
-
The fraction of container memory not to use fo the JVM heap.
- JobConf.LatencyMarkPeriod - Class in org.apache.nemo.conf
-
Period how often latencymarks are sent from source vertex.
- JobConf.MaxNumDownloadsForARuntimeEdge - Class in org.apache.nemo.conf
-
Maximum number of parallel downloads for a runtime edge.
- JobConf.MaxOffheapRatio - Class in org.apache.nemo.conf
-
Maximum off-heap memory ratio to the total memory in the executor.
- JobConf.MaxTaskAttempt - Class in org.apache.nemo.conf
-
Max number of attempts for task scheduling.
- JobConf.OptimizationPolicy - Class in org.apache.nemo.conf
-
The name of the optimization policy.
- JobConf.PartitionTransportClientNumThreads - Class in org.apache.nemo.conf
-
The number of threads of block transfer client.
- JobConf.PartitionTransportServerBacklog - Class in org.apache.nemo.conf
-
The maximum length which the pending connection queue of block transfer may grow to.
- JobConf.PartitionTransportServerNumListeningThreads - Class in org.apache.nemo.conf
-
The number of listening threads of block transfer server.
- JobConf.PartitionTransportServerNumWorkingThreads - Class in org.apache.nemo.conf
-
The number of block transfer server threads which work on accepted connections.
- JobConf.PartitionTransportServerPort - Class in org.apache.nemo.conf
-
The TCP port to which local block transfer binds.
- JobConf.SchedulerImplClassName - Class in org.apache.nemo.conf
-
Scheduler impl.
- JobConf.ScheduleSerThread - Class in org.apache.nemo.conf
-
The number of serialization threads for scheduling.
- JobConf.StreamMetricPeriod - Class in org.apache.nemo.conf
-
Period how often stream metrics are recorded.
- JobConf.UserMainArguments - Class in org.apache.nemo.conf
-
User Main Arguments.
- JobConf.UserMainClass - Class in org.apache.nemo.conf
-
User Main Class Name.
- JobId() - Constructor for class org.apache.nemo.conf.JobConf.JobId
- JobLauncher - Class in org.apache.nemo.client
-
Job launcher.
- JobMessageHandler() - Constructor for class org.apache.nemo.client.NemoClient.JobMessageHandler
- JobMetric - Class in org.apache.nemo.runtime.common.metric
-
Metric class for Job (or
PhysicalPlan
). - JobMetric(String) - Constructor for class org.apache.nemo.runtime.common.metric.JobMetric
-
Constructor with the designated id.
- JobMetric(PhysicalPlan) - Constructor for class org.apache.nemo.runtime.common.metric.JobMetric
-
Constructor.
- JobMetricServlet - Class in org.apache.nemo.runtime.master.servlet
-
Servlet which handles
JobMetric
metric request. - JobMetricServlet() - Constructor for class org.apache.nemo.runtime.master.servlet.JobMetricServlet
- JsonParseException - Exception in org.apache.nemo.common.exception
-
JsonParseException.
- JsonParseException(Throwable) - Constructor for exception org.apache.nemo.common.exception.JsonParseException
-
JsonParseException.
- JVMHeapSlack() - Constructor for class org.apache.nemo.conf.JobConf.JVMHeapSlack
K
- KEEP - org.apache.nemo.common.ir.edge.executionproperty.DataPersistenceProperty.Value
- KEY_FIELD_NUMBER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageEntry
- keyAndValueToEP(Integer, Double, Double) - Static method in class org.apache.nemo.runtime.common.metric.MetricUtils
-
Receives the pair of execution property and value classes, and returns the optimized value of the EP.
- KeyDecoderProperty - Class in org.apache.nemo.common.ir.edge.executionproperty
-
KeyDecoder ExecutionProperty.
- KeyEncoderProperty - Class in org.apache.nemo.common.ir.edge.executionproperty
-
KeyEncoder ExecutionProperty.
- KeyExtractor - Interface in org.apache.nemo.common
-
Extracts a key from an element.
- KeyExtractorProperty - Class in org.apache.nemo.common.ir.edge.executionproperty
-
KeyExtractor ExecutionProperty.
- KeyRange<K extends java.io.Serializable> - Interface in org.apache.nemo.common
-
Represents the key range of data partitions within a block.
- KEYRANGE_FIELD_NUMBER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptor
L
- LambdaPass - Class in org.apache.nemo.compiler.optimizer.pass.compiletime.annotating
-
Lambda Pass.
- LambdaPass() - Constructor for class org.apache.nemo.compiler.optimizer.pass.compiletime.annotating.LambdaPass
- LambdaPolicy - Class in org.apache.nemo.compiler.optimizer.policy
-
Lambda Policy Description: A part of lambda executor, to support Lambda policy.
- LambdaPolicy() - Constructor for class org.apache.nemo.compiler.optimizer.policy.LambdaPolicy
-
Default constructor.
- LargeShuffleAnnotatingPass - Class in org.apache.nemo.compiler.optimizer.pass.compiletime.annotating
-
This pass assumes that a RelayVertex was previously inserted to receive each shuffle edge.
- LargeShuffleAnnotatingPass() - Constructor for class org.apache.nemo.compiler.optimizer.pass.compiletime.annotating.LargeShuffleAnnotatingPass
-
Default constructor.
- LargeShuffleCompositePass - Class in org.apache.nemo.compiler.optimizer.pass.compiletime.composite
-
A series of passes to optimize large shuffle with disk seek batching techniques.
- LargeShuffleCompositePass() - Constructor for class org.apache.nemo.compiler.optimizer.pass.compiletime.composite.LargeShuffleCompositePass
-
Default constructor.
- LargeShufflePolicy - Class in org.apache.nemo.compiler.optimizer.policy
-
A policy to demonstrate the large shuffle optimization, witch batches disk seek during data shuffle.
- LargeShufflePolicy() - Constructor for class org.apache.nemo.compiler.optimizer.policy.LargeShufflePolicy
-
Default constructor.
- LargeShuffleReshapingPass - Class in org.apache.nemo.compiler.optimizer.pass.compiletime.reshaping
-
Inserts the RelayVertex for each shuffle edge.
- LargeShuffleReshapingPass() - Constructor for class org.apache.nemo.compiler.optimizer.pass.compiletime.reshaping.LargeShuffleReshapingPass
-
Default constructor.
- LatencyMark - Class in org.apache.nemo.common.punctuation
-
Latency mark is a watermark with the data related to stream data latencies.
- LatencyMark(String, long) - Constructor for class org.apache.nemo.common.punctuation.LatencyMark
- LATENCYMARK_PERIOD - Static variable in class org.apache.nemo.conf.JobConf
- LatencymarkEmitTransform<I,O> - Class in org.apache.nemo.common.ir.vertex.transform
-
This transform emits
LatencyMark
. - LatencymarkEmitTransform() - Constructor for class org.apache.nemo.common.ir.vertex.transform.LatencymarkEmitTransform
- LatencyMarkPeriod() - Constructor for class org.apache.nemo.conf.JobConf.LatencyMarkPeriod
- LatencyMetric - Class in org.apache.nemo.runtime.common.metric
-
Metric class for recording latencymark and the time when the latencymark is recorded.
- LatencyMetric(LatencyMark, long) - Constructor for class org.apache.nemo.runtime.common.metric.LatencyMetric
-
Constructor with the latencymark and timestamp.
- launchDAG(IRDAG) - Static method in class org.apache.nemo.client.JobLauncher
-
Launch application using the application DAG.
- launchDAG(IRDAG, String) - Static method in class org.apache.nemo.client.JobLauncher
- launchDAG(IRDAG, Map<Serializable, Object>, String) - Static method in class org.apache.nemo.client.JobLauncher
- LaunchDAG - org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessageType
-
LaunchDAG = 0;
- LAUNCHDAG_FIELD_NUMBER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessage
- LaunchDAG_VALUE - Static variable in enum org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessageType
-
LaunchDAG = 0;
- LaunchOptimization - org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessageType
-
LaunchOptimization = 4;
- LaunchOptimization_VALUE - Static variable in enum org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessageType
-
LaunchOptimization = 4;
- leaveCompositeTransform(TransformHierarchy.Node) - Method in class org.apache.nemo.compiler.frontend.beam.PipelineVisitor
- left() - Method in class org.apache.nemo.common.Pair
- LimitedInputStream - Class in org.apache.nemo.runtime.executor.data
-
This class provide functionality to limit bytes read from
InputStream
. - LimitedInputStream(InputStream, long) - Constructor for class org.apache.nemo.runtime.executor.data.LimitedInputStream
-
Constructor.
- LISTENERID_FIELD_NUMBER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
- loadMetaData() - Static method in class org.apache.nemo.runtime.common.metric.MetricUtils
-
Load the BiMaps (lightweight) Metadata from the DB.
- LOCAL_DISK_DIRECTORY - Static variable in class org.apache.nemo.conf.JobConf
- LOCAL_FILE - org.apache.nemo.runtime.common.comm.ControlMessage.BlockStore
-
LOCAL_FILE = 2;
- LOCAL_FILE_STORE - org.apache.nemo.common.ir.edge.executionproperty.DataStoreProperty.Value
- LOCAL_FILE_VALUE - Static variable in enum org.apache.nemo.runtime.common.comm.ControlMessage.BlockStore
-
LOCAL_FILE = 2;
- LOCAL_MESSAGE_ENVIRONMENT_CONFIGURATION - Static variable in class org.apache.nemo.runtime.common.message.local.LocalMessageEnvironment
- LocalBlockStore - Class in org.apache.nemo.runtime.executor.data.stores
-
This abstract class represents
BlockStore
which contains the (meta)data of theBlock
s in local. - LocalBlockStore(SerializerManager, MemoryPoolAssigner) - Constructor for class org.apache.nemo.runtime.executor.data.stores.LocalBlockStore
-
Constructor.
- LocalFileMetadata<K extends java.io.Serializable> - Class in org.apache.nemo.runtime.executor.data.metadata
-
This class represents a metadata for a local file
Block
. - LocalFileMetadata() - Constructor for class org.apache.nemo.runtime.executor.data.metadata.LocalFileMetadata
-
Constructor.
- LocalFileStore - Class in org.apache.nemo.runtime.executor.data.stores
-
Stores blocks in local files.
- LocalInputContext - Class in org.apache.nemo.runtime.executor.transfer
-
This class provides a data transfer interface to the receiver side when both the sender and the receiver are in the same executor.
- LocalInputContext(LocalOutputContext) - Constructor for class org.apache.nemo.runtime.executor.transfer.LocalInputContext
-
Creates a new local input context and connect it to
localOutputContext
. - LocalitySchedulingConstraint - Class in org.apache.nemo.runtime.master.scheduler
-
This policy tries to pick the executors where the corresponding source or intermediate data for a task reside.
- LocalMessageDispatcher - Class in org.apache.nemo.runtime.common.message.local
-
Dispatch messages on a single machine.
- LocalMessageEnvironment - Class in org.apache.nemo.runtime.common.message.local
-
A simple
MessageEnvironment
implementation that works on a single node. - LocalMessageSender<T> - Class in org.apache.nemo.runtime.common.message.local
-
A simple
MessageSender
implementation that works on a single node. - LocalMessageSender(String, String, String, LocalMessageDispatcher) - Constructor for class org.apache.nemo.runtime.common.message.local.LocalMessageSender
- LocalOutputContext - Class in org.apache.nemo.runtime.executor.transfer
-
This class provides a data transfer interface to the sender side when both the sender and the receiver are in the same executor.
- LocalOutputContext(String, String, int, int) - Constructor for class org.apache.nemo.runtime.executor.transfer.LocalOutputContext
-
Creates a new local output context.
- LocalTransferContext - Class in org.apache.nemo.runtime.executor.transfer
-
This class represents the data transfer context when both the sender and the receiver are in the same executor.
- LOCATION_FIELD_NUMBER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsg
- LongDecoderFactory - Class in org.apache.nemo.common.coder
-
A
DecoderFactory
which is used for long. - LongEncoderFactory - Class in org.apache.nemo.common.coder
-
A
EncoderFactory
which is used for long. - LoopCompositeTransform<inputT extends org.apache.beam.sdk.values.PInput,outputT extends org.apache.beam.sdk.values.POutput> - Class in org.apache.nemo.compiler.frontend.beam.transform
-
A composite transform for wrapping transforms inside a loop to create loop operators in the IR.
- LoopCompositeTransform() - Constructor for class org.apache.nemo.compiler.frontend.beam.transform.LoopCompositeTransform
- LoopExtractionPass - Class in org.apache.nemo.compiler.optimizer.pass.compiletime.reshaping
-
Pass for extracting and grouping each loops together using the LoopVertex.
- LoopExtractionPass() - Constructor for class org.apache.nemo.compiler.optimizer.pass.compiletime.reshaping.LoopExtractionPass
-
Default constructor.
- LoopFusionPass() - Constructor for class org.apache.nemo.compiler.optimizer.pass.compiletime.reshaping.LoopOptimizations.LoopFusionPass
-
Default constructor.
- LoopInvariantCodeMotionPass() - Constructor for class org.apache.nemo.compiler.optimizer.pass.compiletime.reshaping.LoopOptimizations.LoopInvariantCodeMotionPass
-
Default constructor.
- LoopOptimizationCompositePass - Class in org.apache.nemo.compiler.optimizer.pass.compiletime.composite
-
A series of passes to perform LoopOptimization.
- LoopOptimizationCompositePass() - Constructor for class org.apache.nemo.compiler.optimizer.pass.compiletime.composite.LoopOptimizationCompositePass
-
Default constructor.
- LoopOptimizations - Class in org.apache.nemo.compiler.optimizer.pass.compiletime.reshaping
-
Loop Optimization.
- LoopOptimizations.LoopFusionPass - Class in org.apache.nemo.compiler.optimizer.pass.compiletime.reshaping
-
Pass for Loop Fusion optimization.
- LoopOptimizations.LoopInvariantCodeMotionPass - Class in org.apache.nemo.compiler.optimizer.pass.compiletime.reshaping
-
Pass for Loop Invariant Code Motion optimization.
- loopTerminationConditionMet() - Method in class org.apache.nemo.common.ir.vertex.LoopVertex
- loopTerminationConditionMet(Integer) - Method in class org.apache.nemo.common.ir.vertex.LoopVertex
- LoopUnrollingPass - Class in org.apache.nemo.compiler.optimizer.pass.compiletime.reshaping
-
Pass for unrolling the loops grouped by the
LoopExtractionPass
. - LoopUnrollingPass() - Constructor for class org.apache.nemo.compiler.optimizer.pass.compiletime.reshaping.LoopUnrollingPass
-
Default constructor.
- LoopVertex - Class in org.apache.nemo.common.ir.vertex
-
IRVertex that contains a partial DAG that is iterative.
- LoopVertex(String) - Constructor for class org.apache.nemo.common.ir.vertex.LoopVertex
-
The LoopVertex constructor.
- LZ4 - org.apache.nemo.common.ir.edge.executionproperty.CompressionProperty.Value
M
- main(String[]) - Static method in class org.apache.nemo.client.JobLauncher
-
Main JobLauncher method.
- main(String[]) - Static method in class org.apache.nemo.compiler.optimizer.examples.MapReduceDisaggregationOptimization
-
Main function of the example MR program.
- main(String[]) - Static method in class org.apache.nemo.examples.beam.AlternatingLeastSquare
-
Main function for the ALS BEAM program.
- main(String[]) - Static method in class org.apache.nemo.examples.beam.AlternatingLeastSquareInefficient
-
Main function for the ALS BEAM program.
- main(String[]) - Static method in class org.apache.nemo.examples.beam.BeamWordCount
- main(String[]) - Static method in class org.apache.nemo.examples.beam.Broadcast
-
Main function for the BEAM program.
- main(String[]) - Static method in class org.apache.nemo.examples.beam.EDGARAvgDocSize
-
Main function for the BEAM program.
- main(String[]) - Static method in class org.apache.nemo.examples.beam.EDGARDocumentSuccessRate
-
Main function for the BEAM program.
- main(String[]) - Static method in class org.apache.nemo.examples.beam.EDGARRequestsByCIK
-
Main function for the BEAM program.
- main(String[]) - Static method in class org.apache.nemo.examples.beam.EDGARTop10BadRefererDocs
-
Main function for the BEAM program.
- main(String[]) - Static method in class org.apache.nemo.examples.beam.EDGARTop10Documents
-
Main function for the BEAM program.
- main(String[]) - Static method in class org.apache.nemo.examples.beam.MinimalWordCount
-
Main function for the MinimalWordCount Beam program.
- main(String[]) - Static method in class org.apache.nemo.examples.beam.MultinomialLogisticRegression
-
Main function for the MLR BEAM program.
- main(String[]) - Static method in class org.apache.nemo.examples.beam.NetworkTraceAnalysis
-
Main function for the Beam program.
- main(String[]) - Static method in class org.apache.nemo.examples.beam.PartitionWordsByLength
-
Main function for the MR BEAM program.
- main(String[]) - Static method in class org.apache.nemo.examples.beam.PerKeyMedian
-
Main function for the MR BEAM program.
- main(String[]) - Static method in class org.apache.nemo.examples.beam.PerPercentileAverage
-
Main function for the MR BEAM program.
- main(String[]) - Static method in class org.apache.nemo.examples.beam.SimpleSumSQL
- main(String[]) - Static method in class org.apache.nemo.examples.beam.WindowedBroadcast
-
Main function for the MR BEAM program.
- main(String[]) - Static method in class org.apache.nemo.examples.beam.WindowedWordCount
-
Main function for the MR BEAM program.
- main(String[]) - Static method in class org.apache.nemo.examples.beam.WordCount
-
Main function for the MR BEAM program.
- main(String[]) - Static method in class org.apache.nemo.examples.beam.WordCountTimeOut1Sec
-
Main function for the MR BEAM program.
- main(String[]) - Static method in class org.apache.nemo.examples.spark.JavaMapReduce
-
Main method.
- main(String[]) - Static method in class org.apache.nemo.examples.spark.JavaSparkPi
-
Main method.
- main(String[]) - Static method in class org.apache.nemo.examples.spark.JavaWordAndLineCount
-
Main method.
- main(String[]) - Static method in class org.apache.nemo.examples.spark.JavaWordCount
-
Main method.
- main(String[]) - Static method in class org.apache.nemo.examples.spark.sql.JavaSparkSQLExample
-
Main function.
- main(String[]) - Static method in class org.apache.nemo.examples.spark.sql.JavaUserDefinedTypedAggregation
-
Main function.
- main(String[]) - Static method in class org.apache.nemo.examples.spark.sql.JavaUserDefinedUntypedAggregation
-
Main function.
- mapEdgeWithLoop(IREdge, IREdge) - Method in class org.apache.nemo.common.ir.vertex.LoopVertex
-
Maps an edge from/to loop with the corresponding edge from/to internal vertex.
- MapReduceDisaggregationOptimization - Class in org.apache.nemo.compiler.optimizer.examples
-
A sample MapReduceDisaggregationOptimization application.
- markDuplicateEdges() - Method in class org.apache.nemo.common.ir.vertex.LoopVertex
-
Marks duplicate edges with DuplicateEdgeGroupProperty.
- MASTER_COMMUNICATION_ID - Static variable in interface org.apache.nemo.runtime.common.message.MessageEnvironment
- MasterControlMessageReceiver() - Constructor for class org.apache.nemo.runtime.master.RuntimeMaster.MasterControlMessageReceiver
- MaxNumDownloadsForARuntimeEdge() - Constructor for class org.apache.nemo.conf.JobConf.MaxNumDownloadsForARuntimeEdge
- MaxOffheapRatio() - Constructor for class org.apache.nemo.conf.JobConf.MaxOffheapRatio
- MaxTaskAttempt() - Constructor for class org.apache.nemo.conf.JobConf.MaxTaskAttempt
- MEMORY - org.apache.nemo.runtime.common.comm.ControlMessage.BlockStore
-
MEMORY = 0;
- MEMORY_STORE - org.apache.nemo.common.ir.edge.executionproperty.DataStoreProperty.Value
- MEMORY_VALUE - Static variable in enum org.apache.nemo.runtime.common.comm.ControlMessage.BlockStore
-
MEMORY = 0;
- MemoryAllocationException - Exception in org.apache.nemo.runtime.executor.data
-
An exception to be thrown when a memory allocation operation is not successful.
- MemoryAllocationException(String) - Constructor for exception org.apache.nemo.runtime.executor.data.MemoryAllocationException
- MemoryChunk - Class in org.apache.nemo.runtime.executor.data
-
This class represents chunk of memory residing in off-heap region managed by
MemoryPoolAssigner
, which is backed byByteBuffer
. - MemoryPoolAssigner - Class in org.apache.nemo.runtime.executor.data
-
The MemoryPoolAssigner assigns the memory that Nemo uses for writing data blocks from the
MemoryPoolAssigner.MemoryPool
. - MemoryPoolAssigner(int, double, int) - Constructor for class org.apache.nemo.runtime.executor.data.MemoryPoolAssigner
- MemoryStore - Class in org.apache.nemo.runtime.executor.data.stores
-
Store data in local memory.
- merge(JavaUserDefinedTypedAggregation.Average, JavaUserDefinedTypedAggregation.Average) - Method in class org.apache.nemo.examples.spark.sql.JavaUserDefinedTypedAggregation.MyAverage
-
Merge two intermediate values.
- merge(MutableAggregationBuffer, Row) - Method in class org.apache.nemo.examples.spark.sql.JavaUserDefinedUntypedAggregation.MyAverage
-
Merges two aggregation buffers and stores the updated buffer values back to `buffer1`.
- mergeAccumulators(Iterable<AccumT>) - Method in class org.apache.nemo.compiler.frontend.beam.transform.FinalCombineFn
- mergeAccumulators(Iterable<AccumT>) - Method in class org.apache.nemo.compiler.frontend.beam.transform.PartialCombineFn
- mergeAccumulators(Iterable<List<KV<int[], float[]>>>) - Method in class org.apache.nemo.examples.beam.AlternatingLeastSquare.TrainingDataCombiner
- mergeBlockLocationInfoMsg(ControlMessage.BlockLocationInfoMsg) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.BlockLocationInfoMsg blockLocationInfoMsg = 9;
- mergeBlockStateChangedMsg(ControlMessage.BlockStateChangedMsg) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.BlockStateChangedMsg blockStateChangedMsg = 6;
- mergeBroadcastVariableMsg(ControlMessage.InMasterBroadcastVariableMessage) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.InMasterBroadcastVariableMessage broadcastVariableMsg = 15;
- mergeContainerFailedMsg(ControlMessage.ContainerFailedMsg) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.ContainerFailedMsg containerFailedMsg = 11;
- mergeDataCollected(ControlMessage.DataCollectMessage) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessage.Builder
-
optional .protobuf.DataCollectMessage dataCollected = 2;
- mergeDataCollected(ControlMessage.DataCollectMessage) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.DataCollectMessage dataCollected = 13;
- mergeExecutorFailedMsg(ControlMessage.ExecutorFailedMsg) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.ExecutorFailedMsg executorFailedMsg = 10;
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsg.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsg.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptor.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessage.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ContainerFailedMsg.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DataCollectMessage.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessage.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ExecutorFailedMsg.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.InMasterBroadcastVariableMessage.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.LaunchDAGMessage.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Metric.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.MetricMsg.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.NotificationMessage.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeInitMessage.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeLocationInfoMessage.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptor.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBlockLocationMsg.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBroadcastVariableMessage.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestPipeLocationMessage.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageEntry.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsg.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ScheduleTaskMsg.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.nemo.runtime.common.comm.GrpcMessageService.Void.Builder
- mergeFrom(Message) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsg.Builder
- mergeFrom(Message) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsg.Builder
- mergeFrom(Message) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptor.Builder
- mergeFrom(Message) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage.Builder
- mergeFrom(Message) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessage.Builder
- mergeFrom(Message) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ContainerFailedMsg.Builder
- mergeFrom(Message) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DataCollectMessage.Builder
- mergeFrom(Message) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessage.Builder
- mergeFrom(Message) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ExecutorFailedMsg.Builder
- mergeFrom(Message) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.InMasterBroadcastVariableMessage.Builder
- mergeFrom(Message) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.LaunchDAGMessage.Builder
- mergeFrom(Message) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
- mergeFrom(Message) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Metric.Builder
- mergeFrom(Message) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.MetricMsg.Builder
- mergeFrom(Message) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.NotificationMessage.Builder
- mergeFrom(Message) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeInitMessage.Builder
- mergeFrom(Message) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeLocationInfoMessage.Builder
- mergeFrom(Message) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptor.Builder
- mergeFrom(Message) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBlockLocationMsg.Builder
- mergeFrom(Message) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBroadcastVariableMessage.Builder
- mergeFrom(Message) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestPipeLocationMessage.Builder
- mergeFrom(Message) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageEntry.Builder
- mergeFrom(Message) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsg.Builder
- mergeFrom(Message) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ScheduleTaskMsg.Builder
- mergeFrom(Message) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg.Builder
- mergeFrom(Message) - Method in class org.apache.nemo.runtime.common.comm.GrpcMessageService.Void.Builder
- mergeFrom(ControlMessage.BlockLocationInfoMsg) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsg.Builder
- mergeFrom(ControlMessage.BlockStateChangedMsg) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsg.Builder
- mergeFrom(ControlMessage.BlockTransferContextDescriptor) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptor.Builder
- mergeFrom(ControlMessage.ByteTransferContextSetupMessage) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage.Builder
- mergeFrom(ControlMessage.ClientToDriverMessage) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessage.Builder
- mergeFrom(ControlMessage.ContainerFailedMsg) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ContainerFailedMsg.Builder
- mergeFrom(ControlMessage.DataCollectMessage) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DataCollectMessage.Builder
- mergeFrom(ControlMessage.DriverToClientMessage) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessage.Builder
- mergeFrom(ControlMessage.ExecutorFailedMsg) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ExecutorFailedMsg.Builder
- mergeFrom(ControlMessage.InMasterBroadcastVariableMessage) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.InMasterBroadcastVariableMessage.Builder
- mergeFrom(ControlMessage.LaunchDAGMessage) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.LaunchDAGMessage.Builder
- mergeFrom(ControlMessage.Message) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
- mergeFrom(ControlMessage.Metric) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Metric.Builder
- mergeFrom(ControlMessage.MetricMsg) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.MetricMsg.Builder
- mergeFrom(ControlMessage.NotificationMessage) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.NotificationMessage.Builder
- mergeFrom(ControlMessage.PipeInitMessage) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeInitMessage.Builder
- mergeFrom(ControlMessage.PipeLocationInfoMessage) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeLocationInfoMessage.Builder
- mergeFrom(ControlMessage.PipeTransferContextDescriptor) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptor.Builder
- mergeFrom(ControlMessage.RequestBlockLocationMsg) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBlockLocationMsg.Builder
- mergeFrom(ControlMessage.RequestBroadcastVariableMessage) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBroadcastVariableMessage.Builder
- mergeFrom(ControlMessage.RequestPipeLocationMessage) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestPipeLocationMessage.Builder
- mergeFrom(ControlMessage.RunTimePassMessageEntry) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageEntry.Builder
- mergeFrom(ControlMessage.RunTimePassMessageMsg) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsg.Builder
- mergeFrom(ControlMessage.ScheduleTaskMsg) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ScheduleTaskMsg.Builder
- mergeFrom(ControlMessage.TaskStateChangedMsg) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg.Builder
- mergeFrom(GrpcMessageService.Void) - Method in class org.apache.nemo.runtime.common.comm.GrpcMessageService.Void.Builder
- mergeLaunchDAG(ControlMessage.LaunchDAGMessage) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessage.Builder
-
optional .protobuf.LaunchDAGMessage launchDAG = 2;
- mergeMessage(ControlMessage.NotificationMessage) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessage.Builder
-
optional .protobuf.NotificationMessage message = 3;
- mergeMetricMsg(ControlMessage.MetricMsg) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.MetricMsg metricMsg = 12;
- mergePipeInitMsg(ControlMessage.PipeInitMessage) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.PipeInitMessage pipeInitMsg = 16;
- mergePipeLocInfoMsg(ControlMessage.PipeLocationInfoMessage) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.PipeLocationInfoMessage pipeLocInfoMsg = 18;
- mergeRequestBlockLocationMsg(ControlMessage.RequestBlockLocationMsg) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.RequestBlockLocationMsg requestBlockLocationMsg = 8;
- mergeRequestbroadcastVariableMsg(ControlMessage.RequestBroadcastVariableMessage) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.RequestBroadcastVariableMessage requestbroadcastVariableMsg = 14;
- mergeRequestPipeLocMsg(ControlMessage.RequestPipeLocationMessage) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.RequestPipeLocationMessage requestPipeLocMsg = 17;
- mergeRunTimePassMessageMsg(ControlMessage.RunTimePassMessageMsg) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.RunTimePassMessageMsg runTimePassMessageMsg = 7;
- mergeScheduleTaskMsg(ControlMessage.ScheduleTaskMsg) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.ScheduleTaskMsg scheduleTaskMsg = 5;
- mergeTaskStateChangedMsg(ControlMessage.TaskStateChangedMsg) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.TaskStateChangedMsg taskStateChangedMsg = 4;
- mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsg.Builder
- mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsg.Builder
- mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptor.Builder
- mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage.Builder
- mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessage.Builder
- mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ContainerFailedMsg.Builder
- mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DataCollectMessage.Builder
- mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessage.Builder
- mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ExecutorFailedMsg.Builder
- mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.InMasterBroadcastVariableMessage.Builder
- mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.LaunchDAGMessage.Builder
- mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
- mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Metric.Builder
- mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.MetricMsg.Builder
- mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.NotificationMessage.Builder
- mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeInitMessage.Builder
- mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeLocationInfoMessage.Builder
- mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptor.Builder
- mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBlockLocationMsg.Builder
- mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBroadcastVariableMessage.Builder
- mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestPipeLocationMessage.Builder
- mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageEntry.Builder
- mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsg.Builder
- mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ScheduleTaskMsg.Builder
- mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg.Builder
- mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.nemo.runtime.common.comm.GrpcMessageService.Void.Builder
- Message<T> - Class in org.apache.nemo.compiler.optimizer.pass.runtime
- Message(int, Set<IREdge>, T) - Constructor for class org.apache.nemo.compiler.optimizer.pass.runtime.Message
- MESSAGE_FIELD_NUMBER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessage
- MessageAggregatorTransform<K,V,O> - Class in org.apache.nemo.common.ir.vertex.transform
-
A
Transform
that aggregates statistics generated by theMessageGeneratorTransform
. - MessageAggregatorTransform(MessageAggregatorVertex.InitialStateSupplier<O>, MessageAggregatorVertex.MessageAggregatorFunction<K, V, O>) - Constructor for class org.apache.nemo.common.ir.vertex.transform.MessageAggregatorTransform
-
Default constructor.
- MessageAggregatorVertex<K,V,O> - Class in org.apache.nemo.common.ir.vertex.utility.runtimepass
-
Aggregates upstream messages.
- MessageAggregatorVertex(MessageAggregatorVertex.InitialStateSupplier<O>, MessageAggregatorVertex.MessageAggregatorFunction<K, V, O>) - Constructor for class org.apache.nemo.common.ir.vertex.utility.runtimepass.MessageAggregatorVertex
- MessageAggregatorVertex.InitialStateSupplier<O> - Interface in org.apache.nemo.common.ir.vertex.utility.runtimepass
-
Creates the initial aggregated message.
- MessageAggregatorVertex.MessageAggregatorFunction<K,V,O> - Interface in org.apache.nemo.common.ir.vertex.utility.runtimepass
-
Aggregates incoming messages.
- MessageContext - Interface in org.apache.nemo.runtime.common.message
-
This class sends a reply message from
MessageListener
. - MessageEnvironment - Interface in org.apache.nemo.runtime.common.message
-
Set up
MessageListener
s to handle incoming messages on this node, and connect to remote nodes and returnMessageSender
s to send message to them. - MessageGeneratorTransform<I,K,V> - Class in org.apache.nemo.common.ir.vertex.transform
-
A
Transform
for the message generator vertex. - MessageGeneratorTransform(MessageGeneratorVertex.MessageGeneratorFunction<I, K, V>) - Constructor for class org.apache.nemo.common.ir.vertex.transform.MessageGeneratorTransform
-
TriggerTransform constructor.
- MessageGeneratorVertex<I,K,V> - Class in org.apache.nemo.common.ir.vertex.utility.runtimepass
-
Produces a message for run-time pass.
- MessageGeneratorVertex(MessageGeneratorVertex.MessageGeneratorFunction<I, K, V>) - Constructor for class org.apache.nemo.common.ir.vertex.utility.runtimepass.MessageGeneratorVertex
- MessageGeneratorVertex.MessageGeneratorFunction<I,K,V> - Interface in org.apache.nemo.common.ir.vertex.utility.runtimepass
-
Applied on the input data elements to produce a message.
- MessageIdEdgeProperty - Class in org.apache.nemo.common.ir.edge.executionproperty
-
Vertices and edges with the same MessageId are subject to the same run-time optimization.
- MessageIdVertexProperty - Class in org.apache.nemo.common.ir.vertex.executionproperty
-
Vertices and edges with the same MessageId belong to the same run-time optimization.
- MessageListener<T> - Interface in org.apache.nemo.runtime.common.message
-
Handles messages from
MessageSender
. - MessageParameters - Class in org.apache.nemo.runtime.common.message
-
Parameters for message components.
- MessageParameters() - Constructor for class org.apache.nemo.runtime.common.message.MessageParameters
- MessageParameters.SenderId - Class in org.apache.nemo.runtime.common.message
-
Id of the sender.
- MessageSender<T> - Interface in org.apache.nemo.runtime.common.message
-
This class sends messages to
MessageListener
with some defined semantics. - MessageServiceGrpc - Class in org.apache.nemo.runtime.common.comm
-
A grpc service for implementing org.apache.nemo.runtime.common.message components using grpc
- MessageServiceGrpc.MessageServiceBlockingStub - Class in org.apache.nemo.runtime.common.comm
-
A grpc service for implementing org.apache.nemo.runtime.common.message components using grpc
- MessageServiceGrpc.MessageServiceFutureStub - Class in org.apache.nemo.runtime.common.comm
-
A grpc service for implementing org.apache.nemo.runtime.common.message components using grpc
- MessageServiceGrpc.MessageServiceImplBase - Class in org.apache.nemo.runtime.common.comm
-
A grpc service for implementing org.apache.nemo.runtime.common.message components using grpc
- MessageServiceGrpc.MessageServiceStub - Class in org.apache.nemo.runtime.common.comm
-
A grpc service for implementing org.apache.nemo.runtime.common.message components using grpc
- MessageServiceImplBase() - Constructor for class org.apache.nemo.runtime.common.comm.MessageServiceGrpc.MessageServiceImplBase
- MessageUtils - Class in org.apache.nemo.runtime.common.message
-
Utility class for messages.
- metaDataLoaded() - Static method in class org.apache.nemo.runtime.common.metric.MetricUtils
- Metric - Interface in org.apache.nemo.runtime.common.metric
-
Interface for all metrics.
- METRIC_FIELD_NUMBER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.MetricMsg
- MetricBroadcaster - Class in org.apache.nemo.runtime.master.metric
-
MetricBroadcaster broadcast metric changes to the currently active WebSocket sessions.
- MetricException - Exception in org.apache.nemo.common.exception
-
MetricException.
- MetricException(String) - Constructor for exception org.apache.nemo.common.exception.MetricException
-
MetricException.
- MetricException(Throwable) - Constructor for exception org.apache.nemo.common.exception.MetricException
-
MetricException.
- METRICFIELD_FIELD_NUMBER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.Metric
- MetricFlushed - org.apache.nemo.runtime.common.comm.ControlMessage.MessageType
-
MetricFlushed = 10;
- MetricFlushed_VALUE - Static variable in enum org.apache.nemo.runtime.common.comm.ControlMessage.MessageType
-
MetricFlushed = 10;
- METRICID_FIELD_NUMBER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.Metric
- MetricManagerMaster - Class in org.apache.nemo.runtime.master.metric
-
A default metric message handler.
- MetricManagerWorker - Class in org.apache.nemo.runtime.executor
-
Metric sender that periodically flushes the collected metrics to Driver.
- MetricMessageHandler - Interface in org.apache.nemo.runtime.master.metric
-
Metric message handler.
- MetricMessageReceived - org.apache.nemo.runtime.common.comm.ControlMessage.MessageType
-
MetricMessageReceived = 8;
- MetricMessageReceived_VALUE - Static variable in enum org.apache.nemo.runtime.common.comm.ControlMessage.MessageType
-
MetricMessageReceived = 8;
- MetricMessageSender - Interface in org.apache.nemo.runtime.executor
-
Interface for metric sender.
- METRICMSG_FIELD_NUMBER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
- metrics() - Method in class org.apache.nemo.client.beam.NemoPipelineResult
- MetricStore - Class in org.apache.nemo.runtime.master.metric
-
MetricStore stores metric data which will be used by web visualize interface, logging, and so on.
- METRICTYPE_FIELD_NUMBER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.Metric
- MetricUtils - Class in org.apache.nemo.runtime.common.metric
-
Utility class for metrics.
- METRICVALUE_FIELD_NUMBER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.Metric
- MinimalWordCount - Class in org.apache.nemo.examples.beam
-
MinimalWordCount program from BEAM.
- MinOccupancyFirstSchedulingPolicy - Class in org.apache.nemo.runtime.master.scheduler
-
This policy chooses a set of Executors, on which have minimum running Tasks.
- MultiInputWatermarkManager - Class in org.apache.nemo.runtime.executor.datatransfer
-
This tracks the minimum input watermark among multiple input streams.
- MultiInputWatermarkManager(int, OutputCollector<?>) - Constructor for class org.apache.nemo.runtime.executor.datatransfer.MultiInputWatermarkManager
- MultinomialLogisticRegression - Class in org.apache.nemo.examples.beam
-
Sample Multinomial Logistic Regression application.
- MultinomialLogisticRegression.ApplyGradient - Class in org.apache.nemo.examples.beam
-
DoFn class that applies the gradient to the model.
- MultinomialLogisticRegression.CalculateGradient - Class in org.apache.nemo.examples.beam
-
Calculate Gradient.
- MultinomialLogisticRegression.CombineFunction - Class in org.apache.nemo.examples.beam
-
Combine Function for two Double arrays.
- MultinomialLogisticRegression.CombineFunctionForIterable - Class in org.apache.nemo.examples.beam
-
Combine Function for Iterable of gradients.
- MultinomialLogisticRegression.UpdateModel - Class in org.apache.nemo.examples.beam
-
+ Composite transform that wraps the transforms inside the loop.
- MultiView(Iterable<T>) - Constructor for class org.apache.nemo.compiler.frontend.beam.transform.CreateViewTransform.MultiView
-
Constructor.
- MyAverage() - Constructor for class org.apache.nemo.examples.spark.sql.JavaUserDefinedTypedAggregation.MyAverage
- MyAverage() - Constructor for class org.apache.nemo.examples.spark.sql.JavaUserDefinedUntypedAggregation.MyAverage
-
Public constructor.
N
- NativeChannelImplementationSelector - Class in org.apache.nemo.runtime.common
-
A
NettyChannelImplementationSelector
implementation that prefers native transport if possible. - NcsMessageEnvironment - Class in org.apache.nemo.runtime.common.message.ncs
-
Message environment for NCS.
- NemoBackend - Class in org.apache.nemo.compiler.backend.nemo
-
Backend component for Nemo Runtime.
- NemoClient - Class in org.apache.nemo.client
-
A wrapper class that contains client handlers.
- NemoClient.JobMessageHandler - Class in org.apache.nemo.client
-
Message handler.
- NemoContext - Class in org.apache.nemo.driver
-
REEF Context for the Executor.
- NemoContext.ContextStartHandler - Class in org.apache.nemo.driver
-
Called when the context starts.
- NemoContext.ContextStopHandler - Class in org.apache.nemo.driver
-
Called when the context is stopped.
- NemoDriver - Class in org.apache.nemo.driver
-
REEF Driver for Nemo.
- NemoDriver.ActiveContextHandler - Class in org.apache.nemo.driver
-
Context active.
- NemoDriver.AllocatedEvaluatorHandler - Class in org.apache.nemo.driver
-
Container allocated.
- NemoDriver.DriverStopHandler - Class in org.apache.nemo.driver
-
Driver stopped.
- NemoDriver.FailedContextHandler - Class in org.apache.nemo.driver
-
Context failed.
- NemoDriver.FailedEvaluatorHandler - Class in org.apache.nemo.driver
-
Evaluator failed.
- NemoDriver.StartHandler - Class in org.apache.nemo.driver
-
Driver started.
- NemoEventDecoderFactory - Class in org.apache.nemo.runtime.executor.datatransfer
-
A factory for NemoEventDecoder.
- NemoEventDecoderFactory(DecoderFactory) - Constructor for class org.apache.nemo.runtime.executor.datatransfer.NemoEventDecoderFactory
- NemoEventEncoderFactory - Class in org.apache.nemo.runtime.executor.datatransfer
-
A factory for NemoEventEncoder.
- NemoEventEncoderFactory(EncoderFactory) - Constructor for class org.apache.nemo.runtime.executor.datatransfer.NemoEventEncoderFactory
- NemoOptimizer - Class in org.apache.nemo.compiler.optimizer
-
An interface for optimizer, which manages the optimization over submitted IR DAGs through
Policy
s. - NemoPipelineOptions - Interface in org.apache.nemo.compiler.frontend.beam
-
NemoPipelineOptions.
- NemoPipelineResult - Class in org.apache.nemo.client.beam
-
Beam result.
- NemoPipelineResult() - Constructor for class org.apache.nemo.client.beam.NemoPipelineResult
-
Default constructor.
- NemoPlanRewriter - Class in org.apache.nemo.compiler.backend.nemo
-
Rewrites the physical plan during execution, to enforce the optimizations of Nemo RunTimePasses.
- NemoPlanRewriter(NemoOptimizer, NemoBackend, InjectionFuture<SimulationScheduler>, PhysicalPlanGenerator) - Constructor for class org.apache.nemo.compiler.backend.nemo.NemoPlanRewriter
- NemoRunner - Class in org.apache.nemo.client.beam
-
Runner class for BEAM programs.
- NemoRunnerRegistrar - Class in org.apache.nemo.client.beam
- NemoRunnerRegistrar.Options - Class in org.apache.nemo.client.beam
-
Registers the
NemoPipelineOptions
. - NemoRunnerRegistrar.Runner - Class in org.apache.nemo.client.beam
-
Registers the
NemoRunner
. - NettyChannelImplementationSelector - Interface in org.apache.nemo.runtime.common
-
Selects appropriate
Channel
implementation. - NetworkTraceAnalysis - Class in org.apache.nemo.examples.beam
-
An app that analyzes data flow from network trace.
- newBlockingStub(Channel) - Static method in class org.apache.nemo.runtime.common.comm.MessageServiceGrpc
-
Creates a new blocking-style stub that supports unary and streaming output calls on the service
- newBuilder() - Static method in class org.apache.nemo.common.StateMachine
- newBuilder() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsg
- newBuilder() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsg
- newBuilder() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptor
- newBuilder() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage
- newBuilder() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessage
- newBuilder() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ContainerFailedMsg
- newBuilder() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.DataCollectMessage
- newBuilder() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessage
- newBuilder() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ExecutorFailedMsg
- newBuilder() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.InMasterBroadcastVariableMessage
- newBuilder() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.LaunchDAGMessage
- newBuilder() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
- newBuilder() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.Metric
- newBuilder() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.MetricMsg
- newBuilder() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.NotificationMessage
- newBuilder() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeInitMessage
- newBuilder() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeLocationInfoMessage
- newBuilder() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptor
- newBuilder() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBlockLocationMsg
- newBuilder() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBroadcastVariableMessage
- newBuilder() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestPipeLocationMessage
- newBuilder() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageEntry
- newBuilder() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsg
- newBuilder() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ScheduleTaskMsg
- newBuilder() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg
- newBuilder() - Static method in class org.apache.nemo.runtime.common.comm.GrpcMessageService.Void
- newBuilder(ControlMessage.BlockLocationInfoMsg) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsg
- newBuilder(ControlMessage.BlockStateChangedMsg) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsg
- newBuilder(ControlMessage.BlockTransferContextDescriptor) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptor
- newBuilder(ControlMessage.ByteTransferContextSetupMessage) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage
- newBuilder(ControlMessage.ClientToDriverMessage) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessage
- newBuilder(ControlMessage.ContainerFailedMsg) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ContainerFailedMsg
- newBuilder(ControlMessage.DataCollectMessage) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.DataCollectMessage
- newBuilder(ControlMessage.DriverToClientMessage) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessage
- newBuilder(ControlMessage.ExecutorFailedMsg) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ExecutorFailedMsg
- newBuilder(ControlMessage.InMasterBroadcastVariableMessage) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.InMasterBroadcastVariableMessage
- newBuilder(ControlMessage.LaunchDAGMessage) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.LaunchDAGMessage
- newBuilder(ControlMessage.Message) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
- newBuilder(ControlMessage.Metric) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.Metric
- newBuilder(ControlMessage.MetricMsg) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.MetricMsg
- newBuilder(ControlMessage.NotificationMessage) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.NotificationMessage
- newBuilder(ControlMessage.PipeInitMessage) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeInitMessage
- newBuilder(ControlMessage.PipeLocationInfoMessage) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeLocationInfoMessage
- newBuilder(ControlMessage.PipeTransferContextDescriptor) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptor
- newBuilder(ControlMessage.RequestBlockLocationMsg) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBlockLocationMsg
- newBuilder(ControlMessage.RequestBroadcastVariableMessage) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBroadcastVariableMessage
- newBuilder(ControlMessage.RequestPipeLocationMessage) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestPipeLocationMessage
- newBuilder(ControlMessage.RunTimePassMessageEntry) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageEntry
- newBuilder(ControlMessage.RunTimePassMessageMsg) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsg
- newBuilder(ControlMessage.ScheduleTaskMsg) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ScheduleTaskMsg
- newBuilder(ControlMessage.TaskStateChangedMsg) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg
- newBuilder(GrpcMessageService.Void) - Static method in class org.apache.nemo.runtime.common.comm.GrpcMessageService.Void
- newBuilderForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsg
- newBuilderForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsg
- newBuilderForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptor
- newBuilderForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage
- newBuilderForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessage
- newBuilderForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ContainerFailedMsg
- newBuilderForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DataCollectMessage
- newBuilderForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessage
- newBuilderForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ExecutorFailedMsg
- newBuilderForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.InMasterBroadcastVariableMessage
- newBuilderForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.LaunchDAGMessage
- newBuilderForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
- newBuilderForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Metric
- newBuilderForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.MetricMsg
- newBuilderForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.NotificationMessage
- newBuilderForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeInitMessage
- newBuilderForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeLocationInfoMessage
- newBuilderForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptor
- newBuilderForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBlockLocationMsg
- newBuilderForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBroadcastVariableMessage
- newBuilderForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestPipeLocationMessage
- newBuilderForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageEntry
- newBuilderForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsg
- newBuilderForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ScheduleTaskMsg
- newBuilderForType() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg
- newBuilderForType() - Method in class org.apache.nemo.runtime.common.comm.GrpcMessageService.Void
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsg
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsg
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptor
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessage
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ContainerFailedMsg
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DataCollectMessage
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessage
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ExecutorFailedMsg
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.InMasterBroadcastVariableMessage
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.LaunchDAGMessage
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Metric
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.MetricMsg
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.NotificationMessage
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeInitMessage
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeLocationInfoMessage
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptor
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBlockLocationMsg
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBroadcastVariableMessage
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestPipeLocationMessage
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageEntry
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsg
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ScheduleTaskMsg
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.nemo.runtime.common.comm.GrpcMessageService.Void
- newDummyShuffleEdge(IRVertex, IRVertex) - Static method in class org.apache.nemo.common.test.EmptyComponents
- newEdgeId() - Static method in class org.apache.nemo.common.ir.IdManager
- newEventLoopGroup(int, ThreadFactory) - Method in class org.apache.nemo.runtime.common.NativeChannelImplementationSelector
- newEventLoopGroup(int, ThreadFactory) - Method in interface org.apache.nemo.runtime.common.NettyChannelImplementationSelector
-
Creates a new
EventLoopGroup
. - newEventLoopGroup(int, ThreadFactory) - Method in class org.apache.nemo.runtime.common.NioChannelImplementationSelector
- newFutureStub(Channel) - Static method in class org.apache.nemo.runtime.common.comm.MessageServiceGrpc
-
Creates a new ListenableFuture-style stub that supports unary calls on the service
- newInputContext(String, byte[], boolean) - Method in class org.apache.nemo.runtime.executor.transfer.ByteTransfer
-
Initiate a transfer context to receive data.
- newInstance() - Static method in class org.apache.nemo.runtime.master.metric.MetricStore
-
Static class for creating a new instance.
- newInstance() - Static method in class org.apache.nemo.runtime.master.scheduler.ExecutorRegistry
-
Static constructor for manual usage.
- newInstance() - Static method in class org.apache.nemo.runtime.master.scheduler.PendingTaskCollectionPointer
-
Static constructor for manual usage.
- newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsg
- newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsg
- newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptor
- newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage
- newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessage
- newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ContainerFailedMsg
- newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DataCollectMessage
- newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessage
- newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ExecutorFailedMsg
- newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.InMasterBroadcastVariableMessage
- newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.LaunchDAGMessage
- newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
- newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Metric
- newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.MetricMsg
- newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.NotificationMessage
- newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeInitMessage
- newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeLocationInfoMessage
- newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptor
- newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBlockLocationMsg
- newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBroadcastVariableMessage
- newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestPipeLocationMessage
- newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageEntry
- newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsg
- newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ScheduleTaskMsg
- newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg
- newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.nemo.runtime.common.comm.GrpcMessageService.Void
- newInstance(String) - Static method in class org.apache.nemo.runtime.master.PlanStateManager
-
Static constructor for manual usage.
- newOutputContext(String, byte[], boolean) - Method in class org.apache.nemo.runtime.executor.transfer.ByteTransfer
-
Initiate a transfer context to send data.
- newOutputStream() - Method in class org.apache.nemo.runtime.executor.transfer.ByteOutputContext
-
Closes existing sub-stream (if any) and create a new sub-stream.
- newOutputStream() - Method in class org.apache.nemo.runtime.executor.transfer.LocalOutputContext
-
Creates a new output stream to which the sender sends its data.
- newOutputStream() - Method in interface org.apache.nemo.runtime.executor.transfer.OutputContext
-
Creates a new output stream to which the sender sends its data.
- newStub(Channel) - Static method in class org.apache.nemo.runtime.common.comm.MessageServiceGrpc
-
Creates a new async stub that supports all call types for the service
- newVertexId() - Static method in class org.apache.nemo.common.ir.IdManager
- next() - Method in class org.apache.nemo.runtime.executor.data.DataUtil.InputStreamIterator
- NextIntraTaskOperatorInfo - Class in org.apache.nemo.runtime.executor.datatransfer
-
Contains information for next operator: -- edgeIndex: the index of edge to next operator.
- NextIntraTaskOperatorInfo(int, OperatorVertex, InputWatermarkManager) - Constructor for class org.apache.nemo.runtime.executor.datatransfer.NextIntraTaskOperatorInfo
- NioChannelImplementationSelector - Class in org.apache.nemo.runtime.common
-
A
NettyChannelImplementationSelector
implementation that prefers nio-based channel implementation. - NodeConnectionException - Exception in org.apache.nemo.common.exception
-
NodeConnectionException.
- NodeConnectionException(Throwable) - Constructor for exception org.apache.nemo.common.exception.NodeConnectionException
-
NodeConnectionException.
- NodeShareSchedulingConstraint - Class in org.apache.nemo.runtime.master.scheduler
-
This constraint is to follow
ResourceSiteProperty
. - NONE - org.apache.nemo.common.ir.edge.executionproperty.CompressionProperty.Value
- NONE - Static variable in class org.apache.nemo.common.ir.vertex.executionproperty.ResourcePriorityProperty
- NonSerializedMemoryBlock<K extends java.io.Serializable> - Class in org.apache.nemo.runtime.executor.data.block
-
This class represents a block which is stored in local memory and not serialized.
- NonSerializedMemoryBlock(String, Serializer, MemoryPoolAssigner) - Constructor for class org.apache.nemo.runtime.executor.data.block.NonSerializedMemoryBlock
-
Constructor.
- NonSerializedPartition<K> - Class in org.apache.nemo.runtime.executor.data.partition
-
A collection of data elements.
- NonSerializedPartition(K) - Constructor for class org.apache.nemo.runtime.executor.data.partition.NonSerializedPartition
-
Creates a non-serialized
Partition
without actual data. - NonSerializedPartition(K, List, long, long) - Constructor for class org.apache.nemo.runtime.executor.data.partition.NonSerializedPartition
-
Creates a non-serialized
Partition
with actual data. - NOT_AVAILABLE - org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateFromExecutor
-
NOT_AVAILABLE = 0;
- NOT_AVAILABLE - org.apache.nemo.runtime.common.state.BlockState.State
- NOT_AVAILABLE_VALUE - Static variable in enum org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateFromExecutor
-
NOT_AVAILABLE = 0;
- Notification - org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessageType
-
Notification = 2;
- Notification_VALUE - Static variable in enum org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessageType
-
Notification = 2;
- notifyMaster(String, long) - Method in class org.apache.nemo.runtime.executor.data.PipeManagerWorker
- NoWatermarkEmitTransform<I,O> - Class in org.apache.nemo.common.ir.vertex.transform
-
This transform does not emit watermarks.
- NoWatermarkEmitTransform() - Constructor for class org.apache.nemo.common.ir.vertex.transform.NoWatermarkEmitTransform
- NUM_EQUAL_TO_DST_PARALLELISM - Static variable in class org.apache.nemo.common.ir.edge.executionproperty.PartitionerProperty
- NumBytesNotSupportedException() - Constructor for exception org.apache.nemo.runtime.executor.data.DataUtil.IteratorWithNumBytes.NumBytesNotSupportedException
- NUMPIPETOWAIT_FIELD_NUMBER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptor
O
- ObjectCoderForString - Class in org.apache.nemo.examples.beam
-
This coder acts like an object coder to conform the type, but is actually just a
StringUtf8Coder
. - of() - Static method in class org.apache.nemo.common.coder.BytesDecoderFactory
-
Static initializer of the decoder.
- of() - Static method in class org.apache.nemo.common.coder.BytesEncoderFactory
-
Static initializer of the encoder.
- of() - Static method in class org.apache.nemo.common.coder.IntDecoderFactory
-
Static initializer of the coder.
- of() - Static method in class org.apache.nemo.common.coder.IntEncoderFactory
-
Static initializer of the coder.
- of() - Static method in class org.apache.nemo.common.coder.LongDecoderFactory
-
Static initializer of the coder.
- of() - Static method in class org.apache.nemo.common.coder.LongEncoderFactory
-
Static initializer of the coder.
- of() - Static method in class org.apache.nemo.common.ir.vertex.executionproperty.IgnoreSchedulingTempDataReceiverProperty
-
Static method exposing the constructor.
- of() - Static method in class org.apache.nemo.examples.beam.FloatArrayCoder
- of() - Static method in class org.apache.nemo.examples.beam.IntArrayCoder
- of() - Static method in class org.apache.nemo.examples.beam.ObjectCoderForString
-
Public accessor of the coder.
- of(int, int) - Static method in class org.apache.nemo.common.HashRange
- of(A, B) - Static method in class org.apache.nemo.common.Pair
-
Static initializer of the Pair class.
- of(Boolean) - Static method in class org.apache.nemo.common.ir.vertex.executionproperty.EnableDynamicTaskSizingProperty
-
Static method exposing the constructor.
- of(Boolean) - Static method in class org.apache.nemo.common.ir.vertex.executionproperty.IgnoreSchedulingTempDataReceiverProperty
-
Static method exposing the constructor.
- of(Boolean) - Static method in class org.apache.nemo.common.ir.vertex.executionproperty.ResourceLocalityProperty
-
Static method getting execution property.
- of(Boolean) - Static method in class org.apache.nemo.common.ir.vertex.executionproperty.ResourceSlotProperty
-
Static method getting execution property.
- of(Integer) - Static method in class org.apache.nemo.common.ir.vertex.executionproperty.MessageIdVertexProperty
-
Static method exposing the constructor.
- of(Integer) - Static method in class org.apache.nemo.common.ir.vertex.executionproperty.ParallelismProperty
-
Static method exposing the constructor.
- of(Integer) - Static method in class org.apache.nemo.common.ir.vertex.executionproperty.ScheduleGroupProperty
-
Static method exposing the constructor.
- of(String) - Static method in class org.apache.nemo.common.ir.edge.executionproperty.AdditionalOutputTagProperty
-
Static method exposing constructor.
- of(String) - Static method in class org.apache.nemo.common.ir.vertex.executionproperty.ResourcePriorityProperty
-
Static method exposing the constructor.
- of(ArrayList<KeyRange>) - Static method in class org.apache.nemo.common.ir.edge.executionproperty.PartitionSetProperty
-
Static method exposing the constructor.
- of(ArrayList<KeyRange>) - Static method in class org.apache.nemo.common.ir.edge.executionproperty.SubPartitionSetProperty
-
Static method exposing the constructor.
- of(HashMap<String, Integer>) - Static method in class org.apache.nemo.common.ir.vertex.executionproperty.ResourceSiteProperty
-
Static method for constructing
ResourceSiteProperty
. - of(HashSet<Integer>) - Static method in class org.apache.nemo.common.ir.edge.executionproperty.MessageIdEdgeProperty
-
Static method exposing the constructor.
- of(HashSet<Integer>) - Static method in class org.apache.nemo.common.ir.vertex.executionproperty.ResourceAntiAffinityProperty
-
Static method getting execution property.
- of(Iterator<E>) - Static method in interface org.apache.nemo.runtime.executor.data.DataUtil.IteratorWithNumBytes
-
Create an
DataUtil.IteratorWithNumBytes
, with no information about the number of bytes. - of(Iterator<E>, long, long) - Static method in interface org.apache.nemo.runtime.executor.data.DataUtil.IteratorWithNumBytes
-
Create an
DataUtil.IteratorWithNumBytes
, with the number of bytes in decoded and serialized form. - of(UUID) - Static method in class org.apache.nemo.common.ir.edge.executionproperty.CacheIDProperty
-
Static method exposing the constructor.
- of(Coder) - Static method in class org.apache.nemo.compiler.frontend.beam.coder.SideInputCoder
- of(DecoderFactory) - Static method in class org.apache.nemo.common.ir.edge.executionproperty.DecoderProperty
-
Static method exposing the constructor.
- of(DecoderFactory) - Static method in class org.apache.nemo.common.ir.edge.executionproperty.KeyDecoderProperty
-
Static method exposing the constructor.
- of(DecoderFactory<A>, DecoderFactory<B>) - Static method in class org.apache.nemo.common.coder.PairDecoderFactory
-
static initializer of the class.
- of(EncoderFactory) - Static method in class org.apache.nemo.common.ir.edge.executionproperty.EncoderProperty
-
Static method exposing the constructor.
- of(EncoderFactory) - Static method in class org.apache.nemo.common.ir.edge.executionproperty.KeyEncoderProperty
-
Static method exposing the constructor.
- of(EncoderFactory<A>, EncoderFactory<B>) - Static method in class org.apache.nemo.common.coder.PairEncoderFactory
-
static initializer of the class.
- of(BlockFetchFailureProperty.Value) - Static method in class org.apache.nemo.common.ir.edge.executionproperty.BlockFetchFailureProperty
-
Static method exposing the constructor.
- of(CommunicationPatternProperty.Value) - Static method in class org.apache.nemo.common.ir.edge.executionproperty.CommunicationPatternProperty
-
Static method exposing the constructor.
- of(CompressionProperty.Value) - Static method in class org.apache.nemo.common.ir.edge.executionproperty.CompressionProperty
-
Static method exposing the constructor.
- of(CompressionProperty.Value) - Static method in class org.apache.nemo.common.ir.edge.executionproperty.DecompressionProperty
-
Static method exposing the constructor.
- of(DataFlowProperty.Value) - Static method in class org.apache.nemo.common.ir.edge.executionproperty.DataFlowProperty
-
Static method exposing the constructor.
- of(DataPersistenceProperty.Value) - Static method in class org.apache.nemo.common.ir.edge.executionproperty.DataPersistenceProperty
-
Static method exposing the constructor.
- of(DataStoreProperty.Value) - Static method in class org.apache.nemo.common.ir.edge.executionproperty.DataStoreProperty
-
Static method exposing the constructor.
- of(DuplicateEdgeGroupPropertyValue) - Static method in class org.apache.nemo.common.ir.edge.executionproperty.DuplicateEdgeGroupProperty
-
Static method exposing the constructor.
- of(PartitionerProperty.Type) - Static method in class org.apache.nemo.common.ir.edge.executionproperty.PartitionerProperty
- of(PartitionerProperty.Type, int) - Static method in class org.apache.nemo.common.ir.edge.executionproperty.PartitionerProperty
- of(IREdge, CommunicationPatternProperty.Value) - Static method in class org.apache.nemo.common.ir.executionproperty.ExecutionPropertyMap
-
Static initializer for irEdges.
- of(ClonedSchedulingProperty.CloneConf) - Static method in class org.apache.nemo.common.ir.vertex.executionproperty.ClonedSchedulingProperty
-
Static method exposing the constructor.
- of(ResourceLambdaProperty.Value) - Static method in class org.apache.nemo.common.ir.vertex.executionproperty.ResourceLambdaProperty
-
Static method exposing the constructor.
- of(IRVertex) - Static method in class org.apache.nemo.common.ir.executionproperty.ExecutionPropertyMap
-
Static initializer for irVertex.
- of(KeyExtractor) - Static method in class org.apache.nemo.common.ir.edge.executionproperty.KeyExtractorProperty
-
Static method exposing the constructor.
- of(Pair<PartitionerProperty.Type, Integer>) - Static method in class org.apache.nemo.common.ir.edge.executionproperty.PartitionerProperty
-
Static constructor.
- OFF - org.apache.nemo.common.ir.vertex.executionproperty.ResourceLambdaProperty.Value
- ON - org.apache.nemo.common.ir.vertex.executionproperty.ResourceLambdaProperty.Value
- ON_HOLD - org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateFromExecutor
-
ON_HOLD = 5;
- ON_HOLD - org.apache.nemo.runtime.common.state.TaskState.State
- ON_HOLD_VALUE - Static variable in enum org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateFromExecutor
-
ON_HOLD = 5;
- onBlockStateChanged(String, BlockState.State, String) - Method in class org.apache.nemo.runtime.master.BlockManagerMaster
-
Deals with state change of a block.
- onChannelError(Throwable) - Method in class org.apache.nemo.runtime.executor.transfer.ByteInputContext
- onChannelError(Throwable) - Method in class org.apache.nemo.runtime.executor.transfer.ByteOutputContext
- onChannelError(Throwable) - Method in class org.apache.nemo.runtime.executor.transfer.ByteTransferContext
-
Handles exception.
- onContainerAllocated(String, AllocatedEvaluator, Configuration) - Method in class org.apache.nemo.runtime.master.resource.ContainerManager
-
Take the necessary actions in container manager once a container a is allocated.
- onContainerAllocated(String, AllocatedEvaluator, Configuration) - Method in class org.apache.nemo.runtime.master.RuntimeMaster
-
Called when a container is allocated for this runtime.
- onContainerFailed(String) - Method in class org.apache.nemo.runtime.master.resource.ContainerManager
-
Re-acquire a new container using the failed container's resource spec.
- onContainerLaunched(ActiveContext) - Method in class org.apache.nemo.runtime.master.resource.ContainerManager
-
Initializes master's connection to the container once launched.
- onData(I) - Method in class org.apache.nemo.common.ir.vertex.transform.MessageGeneratorTransform
- onData(I) - Method in interface org.apache.nemo.common.ir.vertex.transform.Transform
-
On data received.
- onData(I) - Method in class org.apache.nemo.common.test.EmptyComponents.EmptyTransform
- onData(I) - Method in class org.apache.nemo.compiler.frontend.beam.transform.GroupByKeyTransform
- onData(Void) - Method in class org.apache.nemo.common.ir.vertex.transform.SignalTransform
- onData(WindowedValue) - Method in class org.apache.nemo.compiler.frontend.beam.transform.PushBackDoFnTransform
- onData(WindowedValue<InputT>) - Method in class org.apache.nemo.compiler.frontend.beam.transform.DoFnTransform
- onData(WindowedValue<KV<?, I>>) - Method in class org.apache.nemo.compiler.frontend.beam.transform.CreateViewTransform
- onData(WindowedValue<KV<K, A>>) - Method in class org.apache.nemo.compiler.frontend.beam.transform.CombineFnFinalTransform
- onData(WindowedValue<KV<K, I>>) - Method in class org.apache.nemo.compiler.frontend.beam.transform.CombineFnPartialTransform
- onData(WindowedValue<KV<K, InputT>>) - Method in class org.apache.nemo.compiler.frontend.beam.transform.GBKTransform
-
Every time a single element arrives, this method invokes runner to process a single element.
- onData(WindowedValue<T>) - Method in class org.apache.nemo.compiler.frontend.beam.transform.SideInputTransform
- onData(WindowedValue<T>) - Method in class org.apache.nemo.compiler.frontend.beam.transform.WindowFnTransform
- onData(Pair<K, V>) - Method in class org.apache.nemo.common.ir.vertex.transform.MessageAggregatorTransform
- onData(T) - Method in class org.apache.nemo.common.ir.vertex.transform.StreamTransform
- onData(T) - Method in class org.apache.nemo.compiler.frontend.beam.transform.FlattenTransform
- ONE_TO_ONE - org.apache.nemo.common.ir.edge.executionproperty.CommunicationPatternProperty.Value
- onExecutorAdded(ExecutorRepresenter) - Method in class org.apache.nemo.runtime.master.scheduler.BatchScheduler
- onExecutorAdded(ExecutorRepresenter) - Method in interface org.apache.nemo.runtime.master.scheduler.Scheduler
-
Called when an executor is added to Runtime, so that the extra resource can be used to execute the job.
- onExecutorAdded(ExecutorRepresenter) - Method in class org.apache.nemo.runtime.master.scheduler.SimulationScheduler
- onExecutorAdded(ExecutorRepresenter) - Method in class org.apache.nemo.runtime.master.scheduler.StreamingScheduler
- onExecutorFailed() - Method in class org.apache.nemo.runtime.master.resource.DefaultExecutorRepresenter
-
Marks all Tasks which were running in this executor as failed.
- onExecutorFailed() - Method in interface org.apache.nemo.runtime.master.resource.ExecutorRepresenter
-
Marks all Tasks which were running in this executor as failed.
- onExecutorFailed(FailedEvaluator) - Method in class org.apache.nemo.runtime.master.RuntimeMaster
-
Called when an executor fails due to container failure on this runtime.
- onExecutorLaunched(ActiveContext) - Method in class org.apache.nemo.runtime.master.RuntimeMaster
-
Called when an executor is launched on a container for this runtime.
- onExecutorRemoved(String) - Method in class org.apache.nemo.runtime.master.scheduler.BatchScheduler
- onExecutorRemoved(String) - Method in interface org.apache.nemo.runtime.master.scheduler.Scheduler
-
Called when an executor is removed from Runtime, so that faults related to the removal can be handled.
- onExecutorRemoved(String) - Method in class org.apache.nemo.runtime.master.scheduler.SimulationScheduler
- onExecutorRemoved(String) - Method in class org.apache.nemo.runtime.master.scheduler.StreamingScheduler
- onFailure(long, Throwable) - Method in class org.apache.nemo.runtime.common.ReplyFutureMap
-
Called for a failure in request-reply communication.
- onInputContext(ByteInputContext) - Method in class org.apache.nemo.runtime.executor.data.BlockManagerWorker
-
Respond to a block notification by another executor.
- onInputContext(ByteInputContext) - Method in class org.apache.nemo.runtime.executor.data.PipeManagerWorker
- onLatencymark(LatencyMark) - Method in class org.apache.nemo.common.ir.vertex.transform.LatencymarkEmitTransform
- onLatencymark(LatencyMark) - Method in class org.apache.nemo.common.ir.vertex.transform.NoWatermarkEmitTransform
- onLatencymark(LatencyMark) - Method in interface org.apache.nemo.common.ir.vertex.transform.Transform
-
On latencymark received.
- onLatencymark(LatencyMark) - Method in class org.apache.nemo.compiler.frontend.beam.transform.AbstractDoFnTransform
-
On latencymark received.
- onMessage(ControlMessage.Message) - Method in class org.apache.nemo.runtime.master.BlockManagerMaster.BlockManagerMasterControlMessageReceiver
- onMessage(ControlMessage.Message) - Method in class org.apache.nemo.runtime.master.PipeManagerMaster.PipeManagerMasterControlMessageReceiver
- onMessage(ControlMessage.Message) - Method in class org.apache.nemo.runtime.master.RuntimeMaster.MasterControlMessageReceiver
- onMessage(T) - Method in interface org.apache.nemo.runtime.common.message.MessageListener
-
Called back when a message is received.
- onMessageWithContext(ControlMessage.Message, MessageContext) - Method in class org.apache.nemo.runtime.master.BlockManagerMaster.BlockManagerMasterControlMessageReceiver
- onMessageWithContext(ControlMessage.Message, MessageContext) - Method in class org.apache.nemo.runtime.master.PipeManagerMaster.PipeManagerMasterControlMessageReceiver
- onMessageWithContext(ControlMessage.Message, MessageContext) - Method in class org.apache.nemo.runtime.master.RuntimeMaster.MasterControlMessageReceiver
- onMessageWithContext(T, MessageContext) - Method in interface org.apache.nemo.runtime.common.message.MessageListener
-
Called back when a message is received, and return a response using
MessageContext
. - onMetricMessageReceived(String, String, String, byte[]) - Method in class org.apache.nemo.runtime.master.metric.MetricManagerMaster
- onMetricMessageReceived(String, String, String, byte[]) - Method in interface org.apache.nemo.runtime.master.metric.MetricMessageHandler
-
Handle the received metric message.
- onNext(JobMessage) - Method in class org.apache.nemo.client.NemoClient.JobMessageHandler
- onNext(ActiveContext) - Method in class org.apache.nemo.driver.NemoDriver.ActiveContextHandler
- onNext(FailedContext) - Method in class org.apache.nemo.driver.NemoDriver.FailedContextHandler
- onNext(AllocatedEvaluator) - Method in class org.apache.nemo.driver.NemoDriver.AllocatedEvaluatorHandler
- onNext(FailedEvaluator) - Method in class org.apache.nemo.driver.NemoDriver.FailedEvaluatorHandler
- onNext(ContextStart) - Method in class org.apache.nemo.driver.NemoContext.ContextStartHandler
- onNext(ContextStop) - Method in class org.apache.nemo.driver.NemoContext.ContextStopHandler
- onNext(StartTime) - Method in class org.apache.nemo.driver.NemoDriver.StartHandler
- onNext(StopTime) - Method in class org.apache.nemo.driver.NemoDriver.DriverStopHandler
- onOutputContext(ByteOutputContext) - Method in class org.apache.nemo.runtime.executor.data.BlockManagerWorker
-
Respond to a block request by another executor.
- onOutputContext(ByteOutputContext) - Method in class org.apache.nemo.runtime.executor.data.PipeManagerWorker
-
(SYNCHRONIZATION) Called by network threads.
- onProducerTaskFailed(String) - Method in class org.apache.nemo.runtime.master.BlockManagerMaster
-
To be called when a potential producer task fails.
- onProducerTaskScheduled(String, Set<String>) - Method in class org.apache.nemo.runtime.master.BlockManagerMaster
-
To be called when a potential producer task is scheduled.
- onRunTimePassMessage(String, Object) - Method in class org.apache.nemo.runtime.master.scheduler.BatchScheduler
-
Process the RuntimePassMessage.
- onRunTimePassMessage(String, Object) - Method in class org.apache.nemo.runtime.master.scheduler.SimulationScheduler
-
Process the RuntimePassMessage.
- onRunTimePassMessage(PlanStateManager, PlanRewriter, String, Object) - Static method in class org.apache.nemo.runtime.master.scheduler.BatchSchedulerUtils
-
Process the RuntimePassMessage.
- onSpeculativeExecutionCheck() - Method in class org.apache.nemo.runtime.master.scheduler.BatchScheduler
- onSpeculativeExecutionCheck() - Method in interface org.apache.nemo.runtime.master.scheduler.Scheduler
-
Called to check for speculative execution.
- onSpeculativeExecutionCheck() - Method in class org.apache.nemo.runtime.master.scheduler.SimulationScheduler
- onSpeculativeExecutionCheck() - Method in class org.apache.nemo.runtime.master.scheduler.StreamingScheduler
- onSuccessMessage(long, T) - Method in class org.apache.nemo.runtime.common.ReplyFutureMap
-
Called by message receiver, for a successful reply message.
- onTaskExecutionComplete(String) - Method in class org.apache.nemo.runtime.master.resource.DefaultExecutorRepresenter
-
Marks the specified Task as completed.
- onTaskExecutionComplete(String) - Method in interface org.apache.nemo.runtime.master.resource.ExecutorRepresenter
-
Marks the specified Task as completed.
- onTaskExecutionFailed(String) - Method in class org.apache.nemo.runtime.master.resource.DefaultExecutorRepresenter
-
Marks the specified Task as failed.
- onTaskExecutionFailed(String) - Method in interface org.apache.nemo.runtime.master.resource.ExecutorRepresenter
-
Marks the specified Task as failed.
- onTaskReceived(Task) - Method in class org.apache.nemo.runtime.master.scheduler.SimulatedTaskExecutor
-
Handle the task and record metrics, as a real Executor#onTaskReceived would.
- onTaskScheduled(String, long) - Method in class org.apache.nemo.runtime.master.PipeManagerMaster
- onTaskScheduled(Task) - Method in class org.apache.nemo.runtime.master.resource.DefaultExecutorRepresenter
-
Marks the Task as running, and sends scheduling message to the executor.
- onTaskScheduled(Task) - Method in interface org.apache.nemo.runtime.master.resource.ExecutorRepresenter
-
Marks the Task as running, and sends scheduling message to the executor.
- onTaskStateChanged(String, TaskState.State) - Method in class org.apache.nemo.runtime.master.PlanStateManager
-
Updates the state of a task.
- onTaskStateChanged(TaskState.State, Optional<String>, Optional<TaskState.RecoverableTaskFailureCause>) - Method in class org.apache.nemo.runtime.executor.TaskStateManager
-
Updates the state of the task.
- onTaskStateReportFromExecutor(String, String, int, TaskState.State, String, TaskState.RecoverableTaskFailureCause) - Method in class org.apache.nemo.runtime.master.scheduler.BatchScheduler
-
Handles task state transition notifications sent from executors.
- onTaskStateReportFromExecutor(String, String, int, TaskState.State, String, TaskState.RecoverableTaskFailureCause) - Method in interface org.apache.nemo.runtime.master.scheduler.Scheduler
-
Called when a Task's execution state changes.
- onTaskStateReportFromExecutor(String, String, int, TaskState.State, String, TaskState.RecoverableTaskFailureCause) - Method in class org.apache.nemo.runtime.master.scheduler.SimulationScheduler
- onTaskStateReportFromExecutor(String, String, int, TaskState.State, String, TaskState.RecoverableTaskFailureCause) - Method in class org.apache.nemo.runtime.master.scheduler.StreamingScheduler
- onTransferFinished(String) - Method in class org.apache.nemo.runtime.executor.data.BlockTransferThrottler
-
Indicates the transfer has finished.
- onWatermark(Watermark) - Method in class org.apache.nemo.common.ir.vertex.transform.NoWatermarkEmitTransform
- onWatermark(Watermark) - Method in class org.apache.nemo.common.ir.vertex.transform.StreamTransform
- onWatermark(Watermark) - Method in interface org.apache.nemo.common.ir.vertex.transform.Transform
-
On watermark received.
- onWatermark(Watermark) - Method in class org.apache.nemo.compiler.frontend.beam.transform.CreateViewTransform
- onWatermark(Watermark) - Method in class org.apache.nemo.compiler.frontend.beam.transform.DoFnTransform
- onWatermark(Watermark) - Method in class org.apache.nemo.compiler.frontend.beam.transform.FlattenTransform
- onWatermark(Watermark) - Method in class org.apache.nemo.compiler.frontend.beam.transform.GBKTransform
-
Trigger timers that need to be fired at
watermark
and emit output watermark. - onWatermark(Watermark) - Method in class org.apache.nemo.compiler.frontend.beam.transform.PushBackDoFnTransform
- onWatermark(Watermark) - Method in class org.apache.nemo.compiler.frontend.beam.transform.SideInputTransform
- onWatermark(Watermark) - Method in class org.apache.nemo.compiler.frontend.beam.transform.WindowFnTransform
- onWebSocketClose(int, String) - Method in class org.apache.nemo.runtime.master.servlet.WebSocketMetricAdapter
- onWebSocketConnect(Session) - Method in class org.apache.nemo.runtime.master.servlet.WebSocketMetricAdapter
- onWebSocketError(Throwable) - Method in class org.apache.nemo.runtime.master.servlet.WebSocketMetricAdapter
- onWebSocketText(String) - Method in class org.apache.nemo.runtime.master.servlet.WebSocketMetricAdapter
- open(String) - Static method in class org.apache.nemo.runtime.executor.data.metadata.RemoteFileMetadata
-
Opens a existing block metadata in file.
- OperatorVertex - Class in org.apache.nemo.common.ir.vertex
-
IRVertex that transforms input data.
- OperatorVertex(Transform) - Constructor for class org.apache.nemo.common.ir.vertex.OperatorVertex
-
Constructor of OperatorVertex.
- OperatorVertexOutputCollector<O> - Class in org.apache.nemo.runtime.executor.datatransfer
-
OutputCollector implementation.
- OperatorVertexOutputCollector(IRVertex, List<NextIntraTaskOperatorInfo>, Map<String, List<NextIntraTaskOperatorInfo>>, List<OutputWriter>, Map<String, List<OutputWriter>>) - Constructor for class org.apache.nemo.runtime.executor.datatransfer.OperatorVertexOutputCollector
-
Constructor of the output collector.
- OperatorWatermarkCollector - Class in org.apache.nemo.runtime.executor.datatransfer
-
This class is used for collecting watermarks for an OperatorVertex.
- OperatorWatermarkCollector(OperatorVertex) - Constructor for class org.apache.nemo.runtime.executor.datatransfer.OperatorWatermarkCollector
- OptimizationPolicy() - Constructor for class org.apache.nemo.conf.JobConf.OptimizationPolicy
- OPTIMIZATIONTYPE_FIELD_NUMBER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessage
- OPTIMIZATIONTYPE_FIELD_NUMBER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.NotificationMessage
- optimizeAtCompileTime(IRDAG) - Method in class org.apache.nemo.compiler.optimizer.NemoOptimizer
- optimizeAtCompileTime(IRDAG) - Method in interface org.apache.nemo.compiler.optimizer.Optimizer
-
Optimize the submitted DAG at compile time.
- optimizeAtRunTime(IRDAG, Message) - Method in class org.apache.nemo.compiler.optimizer.NemoOptimizer
- optimizeAtRunTime(IRDAG, Message) - Method in interface org.apache.nemo.compiler.optimizer.Optimizer
-
Optimize the submitted DAG at run time.
- Optimizer - Interface in org.apache.nemo.compiler.optimizer
-
An interface for optimizer, which manages the optimization over submitted IR DAGs through
Policy
s. - OptimizerUtils - Class in org.apache.nemo.compiler.optimizer
-
Utility class for optimizer.
- Options() - Constructor for class org.apache.nemo.client.beam.NemoRunnerRegistrar.Options
- org.apache.nemo.client - package org.apache.nemo.client
- org.apache.nemo.client.beam - package org.apache.nemo.client.beam
- org.apache.nemo.common - package org.apache.nemo.common
- org.apache.nemo.common.coder - package org.apache.nemo.common.coder
- org.apache.nemo.common.dag - package org.apache.nemo.common.dag
- org.apache.nemo.common.eventhandler - package org.apache.nemo.common.eventhandler
- org.apache.nemo.common.exception - package org.apache.nemo.common.exception
- org.apache.nemo.common.ir - package org.apache.nemo.common.ir
- org.apache.nemo.common.ir.edge - package org.apache.nemo.common.ir.edge
- org.apache.nemo.common.ir.edge.executionproperty - package org.apache.nemo.common.ir.edge.executionproperty
- org.apache.nemo.common.ir.executionproperty - package org.apache.nemo.common.ir.executionproperty
- org.apache.nemo.common.ir.vertex - package org.apache.nemo.common.ir.vertex
- org.apache.nemo.common.ir.vertex.executionproperty - package org.apache.nemo.common.ir.vertex.executionproperty
- org.apache.nemo.common.ir.vertex.transform - package org.apache.nemo.common.ir.vertex.transform
- org.apache.nemo.common.ir.vertex.utility - package org.apache.nemo.common.ir.vertex.utility
- org.apache.nemo.common.ir.vertex.utility.runtimepass - package org.apache.nemo.common.ir.vertex.utility.runtimepass
- org.apache.nemo.common.partitioner - package org.apache.nemo.common.partitioner
- org.apache.nemo.common.pass - package org.apache.nemo.common.pass
- org.apache.nemo.common.punctuation - package org.apache.nemo.common.punctuation
- org.apache.nemo.common.test - package org.apache.nemo.common.test
- org.apache.nemo.compiler - package org.apache.nemo.compiler
- org.apache.nemo.compiler.backend - package org.apache.nemo.compiler.backend
- org.apache.nemo.compiler.backend.nemo - package org.apache.nemo.compiler.backend.nemo
- org.apache.nemo.compiler.backend.nemo.prophet - package org.apache.nemo.compiler.backend.nemo.prophet
- org.apache.nemo.compiler.frontend.beam - package org.apache.nemo.compiler.frontend.beam
- org.apache.nemo.compiler.frontend.beam.coder - package org.apache.nemo.compiler.frontend.beam.coder
- org.apache.nemo.compiler.frontend.beam.source - package org.apache.nemo.compiler.frontend.beam.source
- org.apache.nemo.compiler.frontend.beam.transform - package org.apache.nemo.compiler.frontend.beam.transform
- org.apache.nemo.compiler.frontend.spark - package org.apache.nemo.compiler.frontend.spark
- org.apache.nemo.compiler.optimizer - package org.apache.nemo.compiler.optimizer
- org.apache.nemo.compiler.optimizer.examples - package org.apache.nemo.compiler.optimizer.examples
- org.apache.nemo.compiler.optimizer.pass.compiletime - package org.apache.nemo.compiler.optimizer.pass.compiletime
- org.apache.nemo.compiler.optimizer.pass.compiletime.annotating - package org.apache.nemo.compiler.optimizer.pass.compiletime.annotating
- org.apache.nemo.compiler.optimizer.pass.compiletime.composite - package org.apache.nemo.compiler.optimizer.pass.compiletime.composite
- org.apache.nemo.compiler.optimizer.pass.compiletime.reshaping - package org.apache.nemo.compiler.optimizer.pass.compiletime.reshaping
- org.apache.nemo.compiler.optimizer.pass.runtime - package org.apache.nemo.compiler.optimizer.pass.runtime
- org.apache.nemo.compiler.optimizer.policy - package org.apache.nemo.compiler.optimizer.policy
- org.apache.nemo.conf - package org.apache.nemo.conf
- org.apache.nemo.driver - package org.apache.nemo.driver
- org.apache.nemo.examples.beam - package org.apache.nemo.examples.beam
- org.apache.nemo.examples.spark - package org.apache.nemo.examples.spark
- org.apache.nemo.examples.spark.sql - package org.apache.nemo.examples.spark.sql
- org.apache.nemo.runtime.common - package org.apache.nemo.runtime.common
- org.apache.nemo.runtime.common.comm - package org.apache.nemo.runtime.common.comm
- org.apache.nemo.runtime.common.exception - package org.apache.nemo.runtime.common.exception
- org.apache.nemo.runtime.common.message - package org.apache.nemo.runtime.common.message
- org.apache.nemo.runtime.common.message.grpc - package org.apache.nemo.runtime.common.message.grpc
- org.apache.nemo.runtime.common.message.local - package org.apache.nemo.runtime.common.message.local
- org.apache.nemo.runtime.common.message.ncs - package org.apache.nemo.runtime.common.message.ncs
- org.apache.nemo.runtime.common.metric - package org.apache.nemo.runtime.common.metric
- org.apache.nemo.runtime.common.plan - package org.apache.nemo.runtime.common.plan
- org.apache.nemo.runtime.common.state - package org.apache.nemo.runtime.common.state
- org.apache.nemo.runtime.executor - package org.apache.nemo.runtime.executor
- org.apache.nemo.runtime.executor.data - package org.apache.nemo.runtime.executor.data
- org.apache.nemo.runtime.executor.data.block - package org.apache.nemo.runtime.executor.data.block
- org.apache.nemo.runtime.executor.data.metadata - package org.apache.nemo.runtime.executor.data.metadata
- org.apache.nemo.runtime.executor.data.partition - package org.apache.nemo.runtime.executor.data.partition
- org.apache.nemo.runtime.executor.data.stores - package org.apache.nemo.runtime.executor.data.stores
- org.apache.nemo.runtime.executor.data.streamchainer - package org.apache.nemo.runtime.executor.data.streamchainer
- org.apache.nemo.runtime.executor.datatransfer - package org.apache.nemo.runtime.executor.datatransfer
- org.apache.nemo.runtime.executor.task - package org.apache.nemo.runtime.executor.task
- org.apache.nemo.runtime.executor.transfer - package org.apache.nemo.runtime.executor.transfer
-
Responsible for transferring block content from one executor to another.
- org.apache.nemo.runtime.master - package org.apache.nemo.runtime.master
- org.apache.nemo.runtime.master.metric - package org.apache.nemo.runtime.master.metric
- org.apache.nemo.runtime.master.resource - package org.apache.nemo.runtime.master.resource
- org.apache.nemo.runtime.master.scheduler - package org.apache.nemo.runtime.master.scheduler
- org.apache.nemo.runtime.master.servlet - package org.apache.nemo.runtime.master.servlet
- org.apache.reef.runtime.yarn - package org.apache.reef.runtime.yarn
- output(TupleTag<T>, WindowedValue<T>) - Method in class org.apache.nemo.compiler.frontend.beam.transform.DefaultOutputManager
- OUTPUT_WRITE_FAILURE - org.apache.nemo.runtime.common.state.TaskState.RecoverableTaskFailureCause
- OutputCollector<O> - Interface in org.apache.nemo.common.ir
-
Interface through which Transform emits outputs.
- OutputContext - Interface in org.apache.nemo.runtime.executor.transfer
-
Represents the output context during the data transfer between two tasks.
- outputEncoder() - Method in class org.apache.nemo.examples.spark.sql.JavaUserDefinedTypedAggregation.MyAverage
-
Specifies the EncoderFactory for the final output value type.
- OutputMismatchException - Exception in org.apache.nemo.common.exception
-
OutputMismatchException.
- OutputMismatchException(String) - Constructor for exception org.apache.nemo.common.exception.OutputMismatchException
-
Constructor of OutputMismatchException.
- OutputMismatchException(Throwable) - Constructor for exception org.apache.nemo.common.exception.OutputMismatchException
-
Constructor of OutputMismatchException.
- OutputWriteFailure - org.apache.nemo.runtime.common.comm.ControlMessage.RecoverableFailureCause
-
There is a 3rd cause: container_failure, but this is omitted here as it is never propagated with a control msg.
- OutputWriteFailure_VALUE - Static variable in enum org.apache.nemo.runtime.common.comm.ControlMessage.RecoverableFailureCause
-
There is a 3rd cause: container_failure, but this is omitted here as it is never propagated with a control msg.
- OutputWriter - Interface in org.apache.nemo.runtime.executor.datatransfer
-
Represents the output data transfer from a task.
- OWNEREXECUTORID_FIELD_NUMBER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsg
P
- Pair<A,B> - Class in org.apache.nemo.common
-
Pair class.
- PairDecoderFactory<A extends java.io.Serializable,B extends java.io.Serializable> - Class in org.apache.nemo.common.coder
-
An DecoderFactory for
Pair
. - PairEncoderFactory<A extends java.io.Serializable,B extends java.io.Serializable> - Class in org.apache.nemo.common.coder
-
An EncoderFactory for
Pair
. - PairKeyExtractor - Class in org.apache.nemo.common
-
A KeyExtractor for Pair class.
- PairKeyExtractor() - Constructor for class org.apache.nemo.common.PairKeyExtractor
- ParallelismProperty - Class in org.apache.nemo.common.ir.vertex.executionproperty
-
This property decides the number of parallel tasks to use for executing the corresponding IRVertex.
- ParallelismProphet - Class in org.apache.nemo.compiler.backend.nemo.prophet
-
A prophet for Parallelism.
- ParallelismProphet(IRDAG, PhysicalPlan, SimulationScheduler, PhysicalPlanGenerator, Set<StageEdge>) - Constructor for class org.apache.nemo.compiler.backend.nemo.prophet.ParallelismProphet
-
Default constructor for ParallelismProphet.
- parseDelimitedFrom(InputStream) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsg
- parseDelimitedFrom(InputStream) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsg
- parseDelimitedFrom(InputStream) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptor
- parseDelimitedFrom(InputStream) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage
- parseDelimitedFrom(InputStream) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessage
- parseDelimitedFrom(InputStream) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ContainerFailedMsg
- parseDelimitedFrom(InputStream) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.DataCollectMessage
- parseDelimitedFrom(InputStream) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessage
- parseDelimitedFrom(InputStream) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ExecutorFailedMsg
- parseDelimitedFrom(InputStream) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.InMasterBroadcastVariableMessage
- parseDelimitedFrom(InputStream) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.LaunchDAGMessage
- parseDelimitedFrom(InputStream) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
- parseDelimitedFrom(InputStream) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.Metric
- parseDelimitedFrom(InputStream) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.MetricMsg
- parseDelimitedFrom(InputStream) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.NotificationMessage
- parseDelimitedFrom(InputStream) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeInitMessage
- parseDelimitedFrom(InputStream) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeLocationInfoMessage
- parseDelimitedFrom(InputStream) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptor
- parseDelimitedFrom(InputStream) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBlockLocationMsg
- parseDelimitedFrom(InputStream) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBroadcastVariableMessage
- parseDelimitedFrom(InputStream) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestPipeLocationMessage
- parseDelimitedFrom(InputStream) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageEntry
- parseDelimitedFrom(InputStream) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsg
- parseDelimitedFrom(InputStream) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ScheduleTaskMsg
- parseDelimitedFrom(InputStream) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg
- parseDelimitedFrom(InputStream) - Static method in class org.apache.nemo.runtime.common.comm.GrpcMessageService.Void
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsg
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsg
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptor
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessage
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ContainerFailedMsg
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.DataCollectMessage
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessage
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ExecutorFailedMsg
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.InMasterBroadcastVariableMessage
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.LaunchDAGMessage
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.Metric
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.MetricMsg
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.NotificationMessage
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeInitMessage
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeLocationInfoMessage
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptor
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBlockLocationMsg
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBroadcastVariableMessage
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestPipeLocationMessage
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageEntry
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsg
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ScheduleTaskMsg
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.GrpcMessageService.Void
- parseFrom(byte[]) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsg
- parseFrom(byte[]) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsg
- parseFrom(byte[]) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptor
- parseFrom(byte[]) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage
- parseFrom(byte[]) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessage
- parseFrom(byte[]) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ContainerFailedMsg
- parseFrom(byte[]) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.DataCollectMessage
- parseFrom(byte[]) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessage
- parseFrom(byte[]) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ExecutorFailedMsg
- parseFrom(byte[]) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.InMasterBroadcastVariableMessage
- parseFrom(byte[]) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.LaunchDAGMessage
- parseFrom(byte[]) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
- parseFrom(byte[]) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.Metric
- parseFrom(byte[]) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.MetricMsg
- parseFrom(byte[]) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.NotificationMessage
- parseFrom(byte[]) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeInitMessage
- parseFrom(byte[]) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeLocationInfoMessage
- parseFrom(byte[]) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptor
- parseFrom(byte[]) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBlockLocationMsg
- parseFrom(byte[]) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBroadcastVariableMessage
- parseFrom(byte[]) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestPipeLocationMessage
- parseFrom(byte[]) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageEntry
- parseFrom(byte[]) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsg
- parseFrom(byte[]) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ScheduleTaskMsg
- parseFrom(byte[]) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg
- parseFrom(byte[]) - Static method in class org.apache.nemo.runtime.common.comm.GrpcMessageService.Void
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsg
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsg
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptor
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessage
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ContainerFailedMsg
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.DataCollectMessage
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessage
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ExecutorFailedMsg
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.InMasterBroadcastVariableMessage
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.LaunchDAGMessage
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.Metric
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.MetricMsg
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.NotificationMessage
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeInitMessage
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeLocationInfoMessage
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptor
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBlockLocationMsg
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBroadcastVariableMessage
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestPipeLocationMessage
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageEntry
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsg
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ScheduleTaskMsg
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.GrpcMessageService.Void
- parseFrom(ByteString) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsg
- parseFrom(ByteString) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsg
- parseFrom(ByteString) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptor
- parseFrom(ByteString) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage
- parseFrom(ByteString) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessage
- parseFrom(ByteString) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ContainerFailedMsg
- parseFrom(ByteString) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.DataCollectMessage
- parseFrom(ByteString) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessage
- parseFrom(ByteString) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ExecutorFailedMsg
- parseFrom(ByteString) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.InMasterBroadcastVariableMessage
- parseFrom(ByteString) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.LaunchDAGMessage
- parseFrom(ByteString) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
- parseFrom(ByteString) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.Metric
- parseFrom(ByteString) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.MetricMsg
- parseFrom(ByteString) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.NotificationMessage
- parseFrom(ByteString) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeInitMessage
- parseFrom(ByteString) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeLocationInfoMessage
- parseFrom(ByteString) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptor
- parseFrom(ByteString) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBlockLocationMsg
- parseFrom(ByteString) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBroadcastVariableMessage
- parseFrom(ByteString) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestPipeLocationMessage
- parseFrom(ByteString) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageEntry
- parseFrom(ByteString) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsg
- parseFrom(ByteString) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ScheduleTaskMsg
- parseFrom(ByteString) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg
- parseFrom(ByteString) - Static method in class org.apache.nemo.runtime.common.comm.GrpcMessageService.Void
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsg
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsg
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptor
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessage
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ContainerFailedMsg
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.DataCollectMessage
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessage
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ExecutorFailedMsg
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.InMasterBroadcastVariableMessage
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.LaunchDAGMessage
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.Metric
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.MetricMsg
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.NotificationMessage
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeInitMessage
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeLocationInfoMessage
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptor
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBlockLocationMsg
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBroadcastVariableMessage
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestPipeLocationMessage
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageEntry
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsg
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ScheduleTaskMsg
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.GrpcMessageService.Void
- parseFrom(CodedInputStream) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsg
- parseFrom(CodedInputStream) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsg
- parseFrom(CodedInputStream) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptor
- parseFrom(CodedInputStream) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage
- parseFrom(CodedInputStream) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessage
- parseFrom(CodedInputStream) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ContainerFailedMsg
- parseFrom(CodedInputStream) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.DataCollectMessage
- parseFrom(CodedInputStream) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessage
- parseFrom(CodedInputStream) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ExecutorFailedMsg
- parseFrom(CodedInputStream) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.InMasterBroadcastVariableMessage
- parseFrom(CodedInputStream) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.LaunchDAGMessage
- parseFrom(CodedInputStream) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
- parseFrom(CodedInputStream) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.Metric
- parseFrom(CodedInputStream) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.MetricMsg
- parseFrom(CodedInputStream) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.NotificationMessage
- parseFrom(CodedInputStream) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeInitMessage
- parseFrom(CodedInputStream) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeLocationInfoMessage
- parseFrom(CodedInputStream) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptor
- parseFrom(CodedInputStream) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBlockLocationMsg
- parseFrom(CodedInputStream) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBroadcastVariableMessage
- parseFrom(CodedInputStream) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestPipeLocationMessage
- parseFrom(CodedInputStream) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageEntry
- parseFrom(CodedInputStream) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsg
- parseFrom(CodedInputStream) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ScheduleTaskMsg
- parseFrom(CodedInputStream) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg
- parseFrom(CodedInputStream) - Static method in class org.apache.nemo.runtime.common.comm.GrpcMessageService.Void
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsg
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsg
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptor
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessage
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ContainerFailedMsg
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.DataCollectMessage
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessage
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ExecutorFailedMsg
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.InMasterBroadcastVariableMessage
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.LaunchDAGMessage
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.Metric
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.MetricMsg
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.NotificationMessage
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeInitMessage
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeLocationInfoMessage
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptor
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBlockLocationMsg
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBroadcastVariableMessage
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestPipeLocationMessage
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageEntry
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsg
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ScheduleTaskMsg
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.GrpcMessageService.Void
- parseFrom(InputStream) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsg
- parseFrom(InputStream) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsg
- parseFrom(InputStream) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptor
- parseFrom(InputStream) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage
- parseFrom(InputStream) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessage
- parseFrom(InputStream) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ContainerFailedMsg
- parseFrom(InputStream) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.DataCollectMessage
- parseFrom(InputStream) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessage
- parseFrom(InputStream) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ExecutorFailedMsg
- parseFrom(InputStream) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.InMasterBroadcastVariableMessage
- parseFrom(InputStream) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.LaunchDAGMessage
- parseFrom(InputStream) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
- parseFrom(InputStream) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.Metric
- parseFrom(InputStream) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.MetricMsg
- parseFrom(InputStream) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.NotificationMessage
- parseFrom(InputStream) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeInitMessage
- parseFrom(InputStream) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeLocationInfoMessage
- parseFrom(InputStream) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptor
- parseFrom(InputStream) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBlockLocationMsg
- parseFrom(InputStream) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBroadcastVariableMessage
- parseFrom(InputStream) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestPipeLocationMessage
- parseFrom(InputStream) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageEntry
- parseFrom(InputStream) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsg
- parseFrom(InputStream) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ScheduleTaskMsg
- parseFrom(InputStream) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg
- parseFrom(InputStream) - Static method in class org.apache.nemo.runtime.common.comm.GrpcMessageService.Void
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsg
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsg
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptor
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessage
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ContainerFailedMsg
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.DataCollectMessage
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessage
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ExecutorFailedMsg
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.InMasterBroadcastVariableMessage
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.LaunchDAGMessage
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.Metric
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.MetricMsg
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.NotificationMessage
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeInitMessage
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeLocationInfoMessage
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptor
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBlockLocationMsg
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBroadcastVariableMessage
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestPipeLocationMessage
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageEntry
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsg
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ScheduleTaskMsg
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.GrpcMessageService.Void
- parseFrom(ByteBuffer) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsg
- parseFrom(ByteBuffer) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsg
- parseFrom(ByteBuffer) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptor
- parseFrom(ByteBuffer) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage
- parseFrom(ByteBuffer) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessage
- parseFrom(ByteBuffer) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ContainerFailedMsg
- parseFrom(ByteBuffer) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.DataCollectMessage
- parseFrom(ByteBuffer) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessage
- parseFrom(ByteBuffer) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ExecutorFailedMsg
- parseFrom(ByteBuffer) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.InMasterBroadcastVariableMessage
- parseFrom(ByteBuffer) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.LaunchDAGMessage
- parseFrom(ByteBuffer) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
- parseFrom(ByteBuffer) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.Metric
- parseFrom(ByteBuffer) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.MetricMsg
- parseFrom(ByteBuffer) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.NotificationMessage
- parseFrom(ByteBuffer) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeInitMessage
- parseFrom(ByteBuffer) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeLocationInfoMessage
- parseFrom(ByteBuffer) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptor
- parseFrom(ByteBuffer) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBlockLocationMsg
- parseFrom(ByteBuffer) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBroadcastVariableMessage
- parseFrom(ByteBuffer) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestPipeLocationMessage
- parseFrom(ByteBuffer) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageEntry
- parseFrom(ByteBuffer) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsg
- parseFrom(ByteBuffer) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ScheduleTaskMsg
- parseFrom(ByteBuffer) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg
- parseFrom(ByteBuffer) - Static method in class org.apache.nemo.runtime.common.comm.GrpcMessageService.Void
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsg
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsg
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptor
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessage
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ContainerFailedMsg
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.DataCollectMessage
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessage
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ExecutorFailedMsg
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.InMasterBroadcastVariableMessage
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.LaunchDAGMessage
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.Metric
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.MetricMsg
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.NotificationMessage
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeInitMessage
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeLocationInfoMessage
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptor
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBlockLocationMsg
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBroadcastVariableMessage
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestPipeLocationMessage
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageEntry
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsg
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ScheduleTaskMsg
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.GrpcMessageService.Void
- ParseLine(boolean) - Constructor for class org.apache.nemo.examples.beam.AlternatingLeastSquare.ParseLine
-
Constructor for Parseline DoFn class.
- parser() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsg
- parser() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsg
- parser() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptor
- parser() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage
- parser() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessage
- parser() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ContainerFailedMsg
- parser() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.DataCollectMessage
- parser() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessage
- parser() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ExecutorFailedMsg
- parser() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.InMasterBroadcastVariableMessage
- parser() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.LaunchDAGMessage
- parser() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
- parser() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.Metric
- parser() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.MetricMsg
- parser() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.NotificationMessage
- parser() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeInitMessage
- parser() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeLocationInfoMessage
- parser() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptor
- parser() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBlockLocationMsg
- parser() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBroadcastVariableMessage
- parser() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestPipeLocationMessage
- parser() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageEntry
- parser() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsg
- parser() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.ScheduleTaskMsg
- parser() - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg
- parser() - Static method in class org.apache.nemo.runtime.common.comm.GrpcMessageService.Void
- PARSER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsg
-
Deprecated.
- PARSER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsg
-
Deprecated.
- PARSER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptor
-
Deprecated.
- PARSER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage
-
Deprecated.
- PARSER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessage
-
Deprecated.
- PARSER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.ContainerFailedMsg
-
Deprecated.
- PARSER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.DataCollectMessage
-
Deprecated.
- PARSER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessage
-
Deprecated.
- PARSER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.ExecutorFailedMsg
-
Deprecated.
- PARSER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.InMasterBroadcastVariableMessage
-
Deprecated.
- PARSER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.LaunchDAGMessage
-
Deprecated.
- PARSER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
-
Deprecated.
- PARSER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.Metric
-
Deprecated.
- PARSER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.MetricMsg
-
Deprecated.
- PARSER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.NotificationMessage
-
Deprecated.
- PARSER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeInitMessage
-
Deprecated.
- PARSER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeLocationInfoMessage
-
Deprecated.
- PARSER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptor
-
Deprecated.
- PARSER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBlockLocationMsg
-
Deprecated.
- PARSER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBroadcastVariableMessage
-
Deprecated.
- PARSER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestPipeLocationMessage
-
Deprecated.
- PARSER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageEntry
-
Deprecated.
- PARSER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsg
-
Deprecated.
- PARSER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.ScheduleTaskMsg
-
Deprecated.
- PARSER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg
-
Deprecated.
- PARSER - Static variable in class org.apache.nemo.runtime.common.comm.GrpcMessageService.Void
-
Deprecated.
- parseResourceSpecificationString(String) - Static method in class org.apache.nemo.common.Util
-
Utility method for parsing the resource specification string.
- PartialCombineFn<InputT,AccumT> - Class in org.apache.nemo.compiler.frontend.beam.transform
-
Wrapper class for
Combine.CombineFn
. - PartialCombineFn(Combine.CombineFn<InputT, AccumT, ?>, Coder<AccumT>) - Constructor for class org.apache.nemo.compiler.frontend.beam.transform.PartialCombineFn
- partition(Object) - Method in class org.apache.nemo.common.partitioner.DedicatedKeyPerElementPartitioner
- partition(Object) - Method in class org.apache.nemo.common.partitioner.HashPartitioner
- partition(Object) - Method in class org.apache.nemo.common.partitioner.IntactPartitioner
- partition(Object) - Method in interface org.apache.nemo.common.partitioner.Partitioner
-
Divides the output data from a task into multiple blocks.
- Partition<T,K> - Interface in org.apache.nemo.runtime.executor.data.partition
-
A collection of data elements.
- Partitioner<K extends java.io.Serializable> - Interface in org.apache.nemo.common.partitioner
-
This interface represents the way of partitioning output data from a source task.
- PartitionerProperty - Class in org.apache.nemo.common.ir.edge.executionproperty
-
Partitioner ExecutionProperty.
- PartitionerProperty.Type - Enum in org.apache.nemo.common.ir.edge.executionproperty
-
Partitioning types.
- PartitionMetadata<K extends java.io.Serializable> - Class in org.apache.nemo.runtime.executor.data.metadata
-
This class represents a metadata for a partition.
- PartitionMetadata(K, int, long) - Constructor for class org.apache.nemo.runtime.executor.data.metadata.PartitionMetadata
-
Constructor.
- PartitionSetProperty - Class in org.apache.nemo.common.ir.edge.executionproperty
-
This property decides which partitions the tasks of the destination IRVertex should fetch.
- PartitionTransportClientNumThreads() - Constructor for class org.apache.nemo.conf.JobConf.PartitionTransportClientNumThreads
- PartitionTransportServerBacklog() - Constructor for class org.apache.nemo.conf.JobConf.PartitionTransportServerBacklog
- PartitionTransportServerNumListeningThreads() - Constructor for class org.apache.nemo.conf.JobConf.PartitionTransportServerNumListeningThreads
- PartitionTransportServerNumWorkingThreads() - Constructor for class org.apache.nemo.conf.JobConf.PartitionTransportServerNumWorkingThreads
- PartitionTransportServerPort() - Constructor for class org.apache.nemo.conf.JobConf.PartitionTransportServerPort
- PartitionWordsByLength - Class in org.apache.nemo.examples.beam
-
Partition words by length example.
- Pass - Class in org.apache.nemo.common.pass
-
Abstract class for optimization passes.
- Pass() - Constructor for class org.apache.nemo.common.pass.Pass
-
Default constructor.
- pathExistsBetween(IRVertex, IRVertex) - Method in class org.apache.nemo.common.ir.IRDAG
- pathExistsBetween(V, V) - Method in class org.apache.nemo.common.dag.DAG
- pathExistsBetween(V, V) - Method in interface org.apache.nemo.common.dag.DAGInterface
-
Function checks whether there is a path between two vertices.
- peek() - Method in class org.apache.nemo.runtime.executor.transfer.ClosableBlockingQueue
-
Retrieves, but does not removes, the head of this queue, waiting if necessary.
- PendingTaskCollectionPointer - Class in org.apache.nemo.runtime.master.scheduler
-
Points to a collection of pending tasks eligible for scheduling.
- PerKeyMedian - Class in org.apache.nemo.examples.beam
-
IP stat analysis example used in skew experiment.
- PerPercentileAverage - Class in org.apache.nemo.examples.beam
-
Per percentile statistics application.
- PersistentConnectionToMasterMap - Class in org.apache.nemo.runtime.common.message
-
Persistent connection for sending messages to master.
- Person() - Constructor for class org.apache.nemo.examples.spark.sql.JavaSparkSQLExample.Person
- PhysicalPlan - Class in org.apache.nemo.runtime.common.plan
-
A job's physical plan, to be executed by the Runtime.
- PhysicalPlan(String, DAG<Stage, StageEdge>) - Constructor for class org.apache.nemo.runtime.common.plan.PhysicalPlan
-
Constructor.
- PhysicalPlanGenerationException - Exception in org.apache.nemo.common.exception
-
PhysicalPlanGenerationException.
- PhysicalPlanGenerationException(String) - Constructor for exception org.apache.nemo.common.exception.PhysicalPlanGenerationException
-
PhysicalPlanGenerationException.
- PhysicalPlanGenerationException(Throwable) - Constructor for exception org.apache.nemo.common.exception.PhysicalPlanGenerationException
-
PhysicalPlanGenerationException.
- PhysicalPlanGenerator - Class in org.apache.nemo.runtime.common.plan
-
A function that converts an IR DAG to physical DAG.
- PIPE - org.apache.nemo.common.ir.edge.executionproperty.DataStoreProperty.Value
- PIPE_MANAGER_MASTER_MESSAGE_LISTENER_ID - Static variable in interface org.apache.nemo.runtime.common.message.MessageEnvironment
- PipeContainer - Class in org.apache.nemo.runtime.executor.data
-
Writes happen in a serialized manner with
PipeContainer.putPipeListIfAbsent(Pair, int)
. - PipeInit - org.apache.nemo.runtime.common.comm.ControlMessage.MessageType
-
PipeInit = 13;
- PipeInit_VALUE - Static variable in enum org.apache.nemo.runtime.common.comm.ControlMessage.MessageType
-
PipeInit = 13;
- PIPEINITMSG_FIELD_NUMBER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
- PipeInputReader - Class in org.apache.nemo.runtime.executor.datatransfer
-
Represents the input data transfer to a task.
- PipelineVisitor - Class in org.apache.nemo.compiler.frontend.beam
-
Uses the translator and the context to build a Nemo IR DAG.
- PipelineVisitor(Pipeline, NemoPipelineOptions) - Constructor for class org.apache.nemo.compiler.frontend.beam.PipelineVisitor
- PipeLocInfo - org.apache.nemo.runtime.common.comm.ControlMessage.MessageType
-
PipeLocInfo = 15;
- PipeLocInfo_VALUE - Static variable in enum org.apache.nemo.runtime.common.comm.ControlMessage.MessageType
-
PipeLocInfo = 15;
- PIPELOCINFOMSG_FIELD_NUMBER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
- PipeManagerMaster - Class in org.apache.nemo.runtime.master
-
Master-side pipe manager.
- PipeManagerMaster.PipeManagerMasterControlMessageReceiver - Class in org.apache.nemo.runtime.master
-
Handler for control messages received.
- PipeManagerMasterControlMessageReceiver() - Constructor for class org.apache.nemo.runtime.master.PipeManagerMaster.PipeManagerMasterControlMessageReceiver
- PipeManagerWorker - Class in org.apache.nemo.runtime.executor.data
-
Two threads use this class - Network thread: Saves pipe connections created from destination tasks.
- PipeOutputWriter - Class in org.apache.nemo.runtime.executor.datatransfer
-
Represents the output data transfer from a task.
- PipeTransferForAllEdgesPass - Class in org.apache.nemo.compiler.optimizer.pass.compiletime.annotating
-
Annotate 'Pipe' on all edges.
- PipeTransferForAllEdgesPass() - Constructor for class org.apache.nemo.compiler.optimizer.pass.compiletime.annotating.PipeTransferForAllEdgesPass
-
Default constructor.
- PlanAppender - Class in org.apache.nemo.runtime.master
-
An implementation of plan appender which append two plans regarding to caching.
- PlanAppenderException - Exception in org.apache.nemo.runtime.common.exception
-
An exception which represents exception during appending plans.
- PlanAppenderException(String) - Constructor for exception org.apache.nemo.runtime.common.exception.PlanAppenderException
-
Constructor with String.
- PlanAppenderException(Throwable) - Constructor for exception org.apache.nemo.runtime.common.exception.PlanAppenderException
-
Constructor with throwable.
- PlanRewriter - Interface in org.apache.nemo.runtime.common.plan
-
PhysicalPlan rewriter.
- PlanState - Class in org.apache.nemo.runtime.common.state
-
Represents the states and their transitions of a physical plan.
- PlanState() - Constructor for class org.apache.nemo.runtime.common.state.PlanState
- PlanState.State - Enum in org.apache.nemo.runtime.common.state
-
PlanState.
- PlanStateManager - Class in org.apache.nemo.runtime.master
-
Maintains three levels of state machines (PlanState, StageState, and TaskState) of a physical plan.
- Policy - Interface in org.apache.nemo.compiler.optimizer.policy
-
An interface for policies, each of which is composed of a list of static optimization passes.
- PolicyBuilder - Class in org.apache.nemo.compiler.optimizer.policy
-
A builder for policies.
- PolicyBuilder() - Constructor for class org.apache.nemo.compiler.optimizer.policy.PolicyBuilder
-
Default constructor.
- PolicyImpl - Class in org.apache.nemo.compiler.optimizer.policy
-
Implementation of the
Policy
interface. - PolicyImpl(List<CompileTimePass>, Set<RunTimePass<?>>) - Constructor for class org.apache.nemo.compiler.optimizer.policy.PolicyImpl
-
Constructor.
- pollTimer(InMemoryTimerInternals, TimeDomain) - Method in class org.apache.nemo.compiler.frontend.beam.transform.InMemoryTimerInternalsFactory
-
Remove the next eligible timer in
timeDomain
. - POSTGRESQL_METADATA_DB_NAME - Static variable in class org.apache.nemo.runtime.common.metric.MetricUtils
- PostOrder - org.apache.nemo.common.dag.DAGInterface.TraversalOrder
- premain(String, Instrumentation) - Static method in class org.apache.nemo.common.Util
-
Method for the instrumentation: for getting the object size.
- PreOrder - org.apache.nemo.common.dag.DAGInterface.TraversalOrder
- prepare() - Method in class org.apache.nemo.common.ir.BoundedIteratorReadable
-
Prepare reading data.
- prepare() - Method in interface org.apache.nemo.common.ir.Readable
-
Prepare reading data.
- prepare(Transform.Context, OutputCollector<Void>) - Method in class org.apache.nemo.common.ir.vertex.transform.SignalTransform
- prepare(Transform.Context, OutputCollector<O>) - Method in class org.apache.nemo.common.ir.vertex.transform.LatencymarkEmitTransform
- prepare(Transform.Context, OutputCollector<O>) - Method in class org.apache.nemo.common.ir.vertex.transform.MessageAggregatorTransform
- prepare(Transform.Context, OutputCollector<O>) - Method in interface org.apache.nemo.common.ir.vertex.transform.Transform
-
Prepare the transform.
- prepare(Transform.Context, OutputCollector<O>) - Method in class org.apache.nemo.common.test.EmptyComponents.EmptyTransform
- prepare(Transform.Context, OutputCollector<WindowedValue<KV<Object, List>>>) - Method in class org.apache.nemo.compiler.frontend.beam.transform.GroupByKeyTransform
- prepare(Transform.Context, OutputCollector<WindowedValue<KV<K, A>>>) - Method in class org.apache.nemo.compiler.frontend.beam.transform.CombineFnPartialTransform
- prepare(Transform.Context, OutputCollector<WindowedValue<KV<K, O>>>) - Method in class org.apache.nemo.compiler.frontend.beam.transform.CombineFnFinalTransform
- prepare(Transform.Context, OutputCollector<WindowedValue<OutputT>>) - Method in class org.apache.nemo.compiler.frontend.beam.transform.AbstractDoFnTransform
- prepare(Transform.Context, OutputCollector<Pair<K, V>>) - Method in class org.apache.nemo.common.ir.vertex.transform.MessageGeneratorTransform
- printLogs() - Method in class org.apache.nemo.common.ir.vertex.utility.TaskSizeSplitterVertex
- processElement(DoFn.ProcessContext) - Method in class org.apache.nemo.examples.beam.MultinomialLogisticRegression.CalculateGradient
-
ProcessElement method for BEAM.
- processElement(DoFn.ProcessContext) - Method in class org.apache.nemo.examples.beam.AlternatingLeastSquare.ParseLine
-
ProcessElement method for BEAM.
- processElement(DoFn.ProcessContext) - Method in class org.apache.nemo.examples.beam.AlternatingLeastSquare.UngroupSingleVectorList
-
ProcessElement method for BEAM.
- processElement(DoFn.ProcessContext) - Method in class org.apache.nemo.examples.beam.MultinomialLogisticRegression.ApplyGradient
-
ProcessElement method for BEAM.
- processElement(DoFn.ProcessContext) - Method in class org.apache.nemo.examples.beam.AlternatingLeastSquare.CalculateNextMatrix
-
ProcessElement method for BEAM.
- processElement(DoFn.ProcessContext) - Method in class org.apache.nemo.examples.beam.AlternatingLeastSquare.CreateInitialMatrix
-
ProcessElement method for BEAM.
- processMetricMessage(String, byte[]) - Method in class org.apache.nemo.runtime.common.metric.JobMetric
- processMetricMessage(String, byte[]) - Method in interface org.apache.nemo.runtime.common.metric.Metric
-
Process metric message from evaluators.
- processMetricMessage(String, byte[]) - Method in class org.apache.nemo.runtime.common.metric.StageMetric
- processMetricMessage(String, byte[]) - Method in class org.apache.nemo.runtime.common.metric.TaskMetric
- Prophet<K,V> - Interface in org.apache.nemo.compiler.backend.nemo.prophet
-
A prophet class for dynamic optimization.
- publish(LogRecord) - Method in class org.apache.nemo.driver.RemoteClientMessageLoggingHandler
-
TODO #XXX: buffer the log messages for performance.
- PubSubEventHandlerWrapper - Class in org.apache.nemo.common.eventhandler
-
Wrapper class with a pub/sub event handler.
- PULL - org.apache.nemo.common.ir.edge.executionproperty.DataFlowProperty.Value
- PUSH - org.apache.nemo.common.ir.edge.executionproperty.DataFlowProperty.Value
- PushBackDoFnTransform<InputT,OutputT> - Class in org.apache.nemo.compiler.frontend.beam.transform
-
DoFn transform implementation with push backs for side inputs.
- PushBackDoFnTransform(DoFn<InputT, OutputT>, Coder<InputT>, Map<TupleTag<?>, Coder<?>>, TupleTag<OutputT>, List<TupleTag<?>>, WindowingStrategy<?, ?>, Map<Integer, PCollectionView<?>>, PipelineOptions, DisplayData, DoFnSchemaInformation, Map<String, PCollectionView<?>>) - Constructor for class org.apache.nemo.compiler.frontend.beam.transform.PushBackDoFnTransform
-
PushBackDoFnTransform Constructor.
- pushMessage(String) - Static method in class org.apache.nemo.compiler.optimizer.pass.compiletime.annotating.XGBoostPass
- put(int, byte) - Method in class org.apache.nemo.runtime.executor.data.MemoryChunk
-
Writes the given byte into this buffer at the given index.
- put(int, byte[]) - Method in class org.apache.nemo.runtime.executor.data.MemoryChunk
-
Copies all the data from the source byte array into the MemoryChunk beginning at the specified position.
- put(int, byte[], int, int) - Method in class org.apache.nemo.runtime.executor.data.MemoryChunk
-
Bulk put method using the specified index in the MemoryChunk.
- put(T) - Method in class org.apache.nemo.common.ir.executionproperty.ExecutionPropertyMap
-
Put the given execution property in the ExecutionPropertyMap.
- put(T) - Method in class org.apache.nemo.runtime.executor.transfer.ClosableBlockingQueue
-
Adds an element.
- put(T, Boolean) - Method in class org.apache.nemo.common.ir.executionproperty.ExecutionPropertyMap
-
Put the given execution property in the ExecutionPropertyMap.
- putChar(int, char) - Method in class org.apache.nemo.runtime.executor.data.MemoryChunk
-
Writes a char value to the given position.
- putDouble(int, double) - Method in class org.apache.nemo.runtime.executor.data.MemoryChunk
-
Writes the given double value to the given position in the system's native byte order.
- putFloat(int, float) - Method in class org.apache.nemo.runtime.executor.data.MemoryChunk
-
Writes the given float value to the given position in the system's native byte order.
- putInt(int, int) - Method in class org.apache.nemo.runtime.executor.data.MemoryChunk
-
Writes the given int value to the given position in the system's native byte order.
- putLong(int, long) - Method in class org.apache.nemo.runtime.executor.data.MemoryChunk
-
Writes the given long value to the given position in the system's native byte order.
- putMetric(T) - Method in class org.apache.nemo.runtime.master.metric.MetricStore
-
Store a metric object.
- putShort(int, short) - Method in class org.apache.nemo.runtime.executor.data.MemoryChunk
-
Writes the given short value into this buffer at the given position, using the native byte order of the system.
R
- RAND - Static variable in class org.apache.nemo.examples.beam.WindowedWordCount
- rangeBeginInclusive() - Method in class org.apache.nemo.common.HashRange
- rangeBeginInclusive() - Method in interface org.apache.nemo.common.KeyRange
- rangeEndExclusive() - Method in class org.apache.nemo.common.HashRange
- rangeEndExclusive() - Method in interface org.apache.nemo.common.KeyRange
- read() - Method in class org.apache.nemo.common.ByteBufferInputStream
-
Reads data from the list of
ByteBuffer
s. - read() - Method in class org.apache.nemo.runtime.executor.data.LimitedInputStream
- read() - Method in class org.apache.nemo.runtime.executor.datatransfer.BlockInputReader
- read() - Method in interface org.apache.nemo.runtime.executor.datatransfer.InputReader
-
Reads input data depending on the communication pattern of the srcVertex.
- read() - Method in class org.apache.nemo.runtime.executor.datatransfer.PipeInputReader
- read(int, RuntimeEdge, int) - Method in class org.apache.nemo.runtime.executor.data.PipeManagerWorker
- READ_END - org.apache.nemo.runtime.common.metric.DataTransferEvent.TransferType
- READ_START - org.apache.nemo.runtime.common.metric.DataTransferEvent.TransferType
- Readable<O> - Interface in org.apache.nemo.common.ir
-
Interface for readable.
- readBlock(String) - Method in interface org.apache.nemo.runtime.executor.data.stores.BlockStore
-
Reads a committed block from this store.
- readBlock(String) - Method in class org.apache.nemo.runtime.executor.data.stores.GlusterFileStore
-
Reads a committed block from this store.
- readBlock(String) - Method in class org.apache.nemo.runtime.executor.data.stores.LocalBlockStore
-
Reads a committed block from this store.
- readBlock(String, String, ExecutionPropertyMap<EdgeExecutionProperty>, KeyRange) - Method in class org.apache.nemo.runtime.executor.data.BlockManagerWorker
-
Inquiries the location of the specific block and routes the request to the local block manager worker or to the lower data plane.
- readCurrent() - Method in class org.apache.nemo.common.ir.BoundedIteratorReadable
- readCurrent() - Method in interface org.apache.nemo.common.ir.Readable
-
Method to read current data from the source.
- readPartitions(KeyRange) - Method in class org.apache.nemo.runtime.executor.data.block.FileBlock
-
Retrieves the partitions of this block from the file in a specific key range and deserializes it.
- readPartitions(KeyRange) - Method in class org.apache.nemo.runtime.executor.data.block.NonSerializedMemoryBlock
-
Retrieves the
NonSerializedPartition
s in a specific hash range from this block. - readPartitions(KeyRange) - Method in class org.apache.nemo.runtime.executor.data.block.SerializedMemoryBlock
-
Retrieves the
NonSerializedPartition
s in a specific hash range from this block. - readPartitions(KeyRange<K>) - Method in interface org.apache.nemo.runtime.executor.data.block.Block
-
Retrieves the
NonSerializedPartition
s in a specific key range from this block. - readSerializedPartitions(KeyRange) - Method in class org.apache.nemo.runtime.executor.data.block.FileBlock
-
Retrieves the
SerializedPartition
s in a specific key range. - readSerializedPartitions(KeyRange) - Method in class org.apache.nemo.runtime.executor.data.block.NonSerializedMemoryBlock
-
Retrieves the
SerializedPartition
s in a specific hash range. - readSerializedPartitions(KeyRange) - Method in class org.apache.nemo.runtime.executor.data.block.SerializedMemoryBlock
-
Retrieves the
SerializedPartition
s in a specific hash range. - readSerializedPartitions(KeyRange<K>) - Method in interface org.apache.nemo.runtime.executor.data.block.Block
-
Retrieves the
SerializedPartition
s in a specific key range. - readWatermark() - Method in interface org.apache.nemo.common.ir.Readable
-
Read watermark.
- READY - org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateFromExecutor
-
READY = 0;
- READY - org.apache.nemo.runtime.common.state.PlanState.State
- READY - org.apache.nemo.runtime.common.state.TaskState.State
- READY_VALUE - Static variable in enum org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateFromExecutor
-
READY = 0;
- recordExecutorInfo(List<Pair<Integer, ResourceSpecification>>) - Method in class org.apache.nemo.common.ir.IRDAG
-
Setter for the executor specifications information.
- recordIRDAGMetrics(IRDAG, String) - Method in class org.apache.nemo.runtime.master.RuntimeMaster
-
Record IR DAG related metrics.
- reduce(JavaUserDefinedTypedAggregation.Average, JavaUserDefinedTypedAggregation.Employee) - Method in class org.apache.nemo.examples.spark.sql.JavaUserDefinedTypedAggregation.MyAverage
-
Combine two values to produce a new value.
- register(Object) - Static method in class org.apache.nemo.compiler.frontend.spark.SparkBroadcastVariables
- register(String, EncoderFactory, DecoderFactory) - Method in class org.apache.nemo.runtime.executor.data.SerializerManager
-
Register a encoderFactory for runtime edge.
- register(String, EncoderFactory, DecoderFactory, CompressionProperty.Value, CompressionProperty.Value) - Method in class org.apache.nemo.runtime.executor.data.SerializerManager
-
Register a encoderFactory for runtime edge.
- registerAllExtensions(ExtensionRegistry) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage
- registerAllExtensions(ExtensionRegistry) - Static method in class org.apache.nemo.runtime.common.comm.GrpcMessageService
- registerAllExtensions(ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.ControlMessage
- registerAllExtensions(ExtensionRegistryLite) - Static method in class org.apache.nemo.runtime.common.comm.GrpcMessageService
- registerBroadcastVariablesFromClient(Map<Serializable, Object>) - Static method in class org.apache.nemo.runtime.master.BroadcastManagerMaster
- registerCompileTimePass(CompileTimePass) - Method in class org.apache.nemo.compiler.optimizer.policy.PolicyBuilder
-
Register a compile time pass.
- registerCompileTimePass(CompileTimePass, Predicate<IRDAG>) - Method in class org.apache.nemo.compiler.optimizer.policy.PolicyBuilder
-
Register compile time pass with its condition under which to run the pass.
- registerHandler(ControlMessage.ClientToDriverMessageType, EventHandler<ControlMessage.ClientToDriverMessage>) - Method in class org.apache.nemo.runtime.common.message.ClientRPC
-
Registers handler for the given type of message.
- registerHandler(ControlMessage.DriverToClientMessageType, EventHandler<ControlMessage.DriverToClientMessage>) - Method in class org.apache.nemo.client.DriverRPCServer
-
Registers handler for the given type of message.
- registerRunTimePass(RunTimePass<?>, CompileTimePass) - Method in class org.apache.nemo.compiler.optimizer.policy.PolicyBuilder
-
Register a run time pass.
- registerRunTimePass(RunTimePass<?>, CompileTimePass, Predicate<IRDAG>) - Method in class org.apache.nemo.compiler.optimizer.policy.PolicyBuilder
-
Register a run time pass.
- registerSchedulingConstraint(SchedulingConstraint) - Method in class org.apache.nemo.runtime.master.scheduler.SchedulingConstraintRegistry
-
Registers a
SchedulingConstraint
. - RelayVertex - Class in org.apache.nemo.common.ir.vertex.utility
-
Relays input data from upstream vertex to downstream vertex promptly.
- RelayVertex() - Constructor for class org.apache.nemo.common.ir.vertex.utility.RelayVertex
-
Constructor.
- release() - Method in class org.apache.nemo.runtime.executor.data.block.SerializedMemoryBlock
-
Releases the resource (i.e., off-heap memory) that the block holds.
- release() - Method in class org.apache.nemo.runtime.executor.data.MemoryChunk
-
Frees this MemoryChunk.
- release() - Method in class org.apache.nemo.runtime.executor.data.partition.SerializedPartition
-
Releases the off-heap memory that this SerializedPartition holds.
- REMOTE_FILE - org.apache.nemo.runtime.common.comm.ControlMessage.BlockStore
-
REMOTE_FILE = 3;
- REMOTE_FILE_VALUE - Static variable in enum org.apache.nemo.runtime.common.comm.ControlMessage.BlockStore
-
REMOTE_FILE = 3;
- RemoteClientMessageLoggingHandler - Class in org.apache.nemo.driver
-
A simple logging handler that forwards messages to REEF client.
- RemoteClientMessageLoggingHandler(JobMessageObserver) - Constructor for class org.apache.nemo.driver.RemoteClientMessageLoggingHandler
- RemoteFileMetadata<K extends java.io.Serializable> - Class in org.apache.nemo.runtime.executor.data.metadata
-
This class represents a metadata for a remote file block.
- RemoteFileStore - Interface in org.apache.nemo.runtime.executor.data.stores
-
Interface for remote block stores (e.g., GlusterFS, ...).
- remove(Class<? extends T>) - Method in class org.apache.nemo.common.ir.executionproperty.ExecutionPropertyMap
-
remove the execution property.
- removeBlock(String, DataStoreProperty.Value) - Method in class org.apache.nemo.runtime.executor.data.BlockManagerWorker
-
Remove the block from store.
- removeDagIncomingEdge(IREdge) - Method in class org.apache.nemo.common.ir.vertex.LoopVertex
-
Removes the incoming edge of the contained DAG.
- removeDagOutgoingEdge(IREdge) - Method in class org.apache.nemo.common.ir.vertex.LoopVertex
-
Removes a dag outgoing edge.
- removeEntry(int) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsg.Builder
-
repeated .protobuf.RunTimePassMessageEntry entry = 2;
- removeIterativeIncomingEdge(IREdge) - Method in class org.apache.nemo.common.ir.vertex.LoopVertex
-
Remove an iterative incoming edge.
- removeListener(String) - Method in class org.apache.nemo.runtime.common.message.grpc.GrpcMessageEnvironment
- removeListener(String) - Method in class org.apache.nemo.runtime.common.message.local.LocalMessageEnvironment
- removeListener(String) - Method in interface org.apache.nemo.runtime.common.message.MessageEnvironment
-
Remove the
MessageListener
bound to a specific listener ID. - removeListener(String) - Method in class org.apache.nemo.runtime.common.message.ncs.NcsMessageEnvironment
- removeMetric(int) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.MetricMsg.Builder
-
repeated .protobuf.Metric metric = 1;
- removeNonIterativeIncomingEdge(IREdge) - Method in class org.apache.nemo.common.ir.vertex.LoopVertex
-
Removes non iterative incoming edge.
- removeSession(Session) - Method in class org.apache.nemo.runtime.master.metric.MetricBroadcaster
-
Remove a session from the session list.
- removeVertex(V) - Method in class org.apache.nemo.common.dag.DAGBuilder
-
Remove the vertex from the list.
- removeWorker(String) - Method in class org.apache.nemo.runtime.master.BlockManagerMaster
-
Manages the block information when a executor is removed.
- reply(U) - Method in interface org.apache.nemo.runtime.common.message.MessageContext
-
Send back a reply message.
- ReplyFutureMap<T> - Class in org.apache.nemo.runtime.common
-
Orchestrate message sender and receiver using
CompletableFuture
for asynchronous request-reply communication. - ReplyFutureMap() - Constructor for class org.apache.nemo.runtime.common.ReplyFutureMap
- request(ControlMessage.Message) - Method in class org.apache.nemo.runtime.common.comm.MessageServiceGrpc.MessageServiceBlockingStub
-
See org.apache.nemo.runtime.common.message.MessageSender#request for more details
- request(ControlMessage.Message) - Method in class org.apache.nemo.runtime.common.comm.MessageServiceGrpc.MessageServiceFutureStub
-
See org.apache.nemo.runtime.common.message.MessageSender#request for more details
- request(ControlMessage.Message) - Method in class org.apache.nemo.runtime.common.message.FailedMessageSender
- request(ControlMessage.Message, StreamObserver<ControlMessage.Message>) - Method in class org.apache.nemo.runtime.common.comm.MessageServiceGrpc.MessageServiceImplBase
-
See org.apache.nemo.runtime.common.message.MessageSender#request for more details
- request(ControlMessage.Message, StreamObserver<ControlMessage.Message>) - Method in class org.apache.nemo.runtime.common.comm.MessageServiceGrpc.MessageServiceStub
-
See org.apache.nemo.runtime.common.message.MessageSender#request for more details
- request(T) - Method in class org.apache.nemo.runtime.common.message.local.LocalMessageSender
- request(T) - Method in interface org.apache.nemo.runtime.common.message.MessageSender
-
Send a message to corresponding
MessageListener.onMessageWithContext(T, org.apache.nemo.runtime.common.message.MessageContext)
and return a reply message. - RequestBlockLocation - org.apache.nemo.runtime.common.comm.ControlMessage.MessageType
-
RequestBlockLocation = 4;
- RequestBlockLocation_VALUE - Static variable in enum org.apache.nemo.runtime.common.comm.ControlMessage.MessageType
-
RequestBlockLocation = 4;
- REQUESTBLOCKLOCATIONMSG_FIELD_NUMBER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
- RequestBroadcastVariable - org.apache.nemo.runtime.common.comm.ControlMessage.MessageType
-
RequestBroadcastVariable = 11;
- RequestBroadcastVariable_VALUE - Static variable in enum org.apache.nemo.runtime.common.comm.ControlMessage.MessageType
-
RequestBroadcastVariable = 11;
- REQUESTBROADCASTVARIABLEMSG_FIELD_NUMBER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
- requestContainer(int, ResourceSpecification) - Method in class org.apache.nemo.runtime.master.resource.ContainerManager
-
Requests containers/evaluators with the given specifications.
- requestContainer(String) - Method in class org.apache.nemo.runtime.master.RuntimeMaster
-
Requests a container with resource specification.
- REQUESTID_FIELD_NUMBER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsg
- REQUESTID_FIELD_NUMBER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.InMasterBroadcastVariableMessage
- REQUESTID_FIELD_NUMBER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeLocationInfoMessage
- RequestMetricFlush - org.apache.nemo.runtime.common.comm.ControlMessage.MessageType
-
RequestMetricFlush = 9;
- RequestMetricFlush_VALUE - Static variable in enum org.apache.nemo.runtime.common.comm.ControlMessage.MessageType
-
RequestMetricFlush = 9;
- RequestPipeLoc - org.apache.nemo.runtime.common.comm.ControlMessage.MessageType
-
RequestPipeLoc = 14;
- RequestPipeLoc_VALUE - Static variable in enum org.apache.nemo.runtime.common.comm.ControlMessage.MessageType
-
RequestPipeLoc = 14;
- REQUESTPIPELOCMSG_FIELD_NUMBER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
- requestTransferPermission(String) - Method in class org.apache.nemo.runtime.executor.data.BlockTransferThrottler
-
Request a permission to make a connection.
- Requires - Annotation Type in org.apache.nemo.compiler.optimizer.pass.compiletime
-
Annotation used to indicate which execution properties the class requires as prerequisites.
- RESERVED - Static variable in class org.apache.nemo.common.ir.vertex.executionproperty.ResourcePriorityProperty
- reset() - Method in class org.apache.nemo.runtime.master.scheduler.SimulationScheduler
-
Reset the instance to its initial state.
- reshapeUnsafely(Function<DAG<IRVertex, IREdge>, DAG<IRVertex, IREdge>>) - Method in class org.apache.nemo.common.ir.IRDAG
-
Reshape unsafely, without guarantees on preserving application semantics.
- ReshapingPass - Class in org.apache.nemo.compiler.optimizer.pass.compiletime.reshaping
-
A compile-time pass that reshapes the structure of the IR DAG.
- ReshapingPass(Class<? extends ReshapingPass>) - Constructor for class org.apache.nemo.compiler.optimizer.pass.compiletime.reshaping.ReshapingPass
-
Constructor.
- ResourceAntiAffinityProperty - Class in org.apache.nemo.common.ir.vertex.executionproperty
-
Indices of tasks that must not concurrently run on the same executor.
- ResourceLambdaProperty - Class in org.apache.nemo.common.ir.vertex.executionproperty
-
Resource property supporting Lambda Pass.
- ResourceLambdaProperty.Value - Enum in org.apache.nemo.common.ir.vertex.executionproperty
-
Possible values of DataStore ExecutionProperty.
- ResourceLocalityPass - Class in org.apache.nemo.compiler.optimizer.pass.compiletime.annotating
-
Sets
ResourceLocalityProperty
. - ResourceLocalityPass() - Constructor for class org.apache.nemo.compiler.optimizer.pass.compiletime.annotating.ResourceLocalityPass
-
Constructor.
- ResourceLocalityProperty - Class in org.apache.nemo.common.ir.vertex.executionproperty
-
This property decides whether or not to schedule this vertex only on executors where source (including intermediate) data reside.
- ResourcePriorityProperty - Class in org.apache.nemo.common.ir.vertex.executionproperty
-
ExecutionPlacement ExecutionProperty.
- ResourceSitePass - Class in org.apache.nemo.compiler.optimizer.pass.compiletime.annotating
-
Computes and assigns appropriate share of nodes to each irVertex to minimize shuffle time, with respect to bandwidth restrictions of nodes.
- ResourceSitePass() - Constructor for class org.apache.nemo.compiler.optimizer.pass.compiletime.annotating.ResourceSitePass
-
Default constructor.
- ResourceSiteProperty - Class in org.apache.nemo.common.ir.vertex.executionproperty
-
Map between node name and the number of parallelism which will run on the node.
- ResourceSiteProperty(HashMap<String, Integer>) - Constructor for class org.apache.nemo.common.ir.vertex.executionproperty.ResourceSiteProperty
-
Default constructor.
- ResourceSlotPass - Class in org.apache.nemo.compiler.optimizer.pass.compiletime.annotating
-
Sets
ResourceSlotProperty
. - ResourceSlotPass() - Constructor for class org.apache.nemo.compiler.optimizer.pass.compiletime.annotating.ResourceSlotPass
-
Constructor.
- ResourceSlotProperty - Class in org.apache.nemo.common.ir.vertex.executionproperty
-
This property decides whether or not to comply to slot restrictions when scheduling this vertex.
- ResourceSpecification - Class in org.apache.nemo.common.ir.executionproperty
-
Represents the specifications of a resource.
- ResourceSpecification(String, int, int) - Constructor for class org.apache.nemo.common.ir.executionproperty.ResourceSpecification
- ResourceSpecification(String, int, int, OptionalDouble, OptionalInt) - Constructor for class org.apache.nemo.common.ir.executionproperty.ResourceSpecification
- restoreEdgeId(Integer) - Static method in class org.apache.nemo.common.Util
-
Method to restore String ID from the numeric ID.
- restoreVertexId(Integer) - Static method in class org.apache.nemo.common.Util
-
Method to restore String ID from the numeric ID.
- retry(int) - Method in class org.apache.nemo.runtime.executor.datatransfer.BlockInputReader
- retry(int) - Method in interface org.apache.nemo.runtime.executor.datatransfer.InputReader
-
Retry reading input data.
- retry(int) - Method in class org.apache.nemo.runtime.executor.datatransfer.PipeInputReader
- RETRY_AFTER_TWO_SECONDS_FOREVER - org.apache.nemo.common.ir.edge.executionproperty.BlockFetchFailureProperty.Value
-
Do not cancel the running task.
- returnChunksToPool(Iterable<MemoryChunk>) - Method in class org.apache.nemo.runtime.executor.data.MemoryPoolAssigner
-
Returns all the MemoryChunks in the given List of MemoryChunks.
- rewrite(int) - Method in class org.apache.nemo.compiler.backend.nemo.NemoPlanRewriter
- rewrite(int) - Method in interface org.apache.nemo.runtime.common.plan.PlanRewriter
- right() - Method in class org.apache.nemo.common.Pair
- run() - Method in class org.apache.nemo.client.DriverRPCServer
-
Runs the RPC server.
- run(String) - Method in class org.apache.nemo.driver.UserApplicationRunner
-
Run the user program submitted by Nemo Client.
- run(Pipeline) - Method in class org.apache.nemo.client.beam.NemoRunner
-
Method to run the Pipeline.
- runCompileTimeOptimization(IRDAG, String) - Method in class org.apache.nemo.compiler.optimizer.policy.BasicPullPolicy
- runCompileTimeOptimization(IRDAG, String) - Method in class org.apache.nemo.compiler.optimizer.policy.BasicPushPolicy
- runCompileTimeOptimization(IRDAG, String) - Method in class org.apache.nemo.compiler.optimizer.policy.ConditionalLargeShufflePolicy
- runCompileTimeOptimization(IRDAG, String) - Method in class org.apache.nemo.compiler.optimizer.policy.DataSkewPolicy
- runCompileTimeOptimization(IRDAG, String) - Method in class org.apache.nemo.compiler.optimizer.policy.DefaultPolicy
- runCompileTimeOptimization(IRDAG, String) - Method in class org.apache.nemo.compiler.optimizer.policy.DefaultPolicyWithSeparatePass
- runCompileTimeOptimization(IRDAG, String) - Method in class org.apache.nemo.compiler.optimizer.policy.DisaggregationPolicy
- runCompileTimeOptimization(IRDAG, String) - Method in class org.apache.nemo.compiler.optimizer.policy.DynamicTaskSizingPolicy
- runCompileTimeOptimization(IRDAG, String) - Method in class org.apache.nemo.compiler.optimizer.policy.LambdaPolicy
- runCompileTimeOptimization(IRDAG, String) - Method in class org.apache.nemo.compiler.optimizer.policy.LargeShufflePolicy
- runCompileTimeOptimization(IRDAG, String) - Method in interface org.apache.nemo.compiler.optimizer.policy.Policy
-
Optimize the DAG with the compile-time optimizations.
- runCompileTimeOptimization(IRDAG, String) - Method in class org.apache.nemo.compiler.optimizer.policy.PolicyImpl
- runCompileTimeOptimization(IRDAG, String) - Method in class org.apache.nemo.compiler.optimizer.policy.SamplingLargeShuffleSkewPolicy
- runCompileTimeOptimization(IRDAG, String) - Method in class org.apache.nemo.compiler.optimizer.policy.StreamingPolicy
- runCompileTimeOptimization(IRDAG, String) - Method in class org.apache.nemo.compiler.optimizer.policy.TestPolicy
- runCompileTimeOptimization(IRDAG, String) - Method in class org.apache.nemo.compiler.optimizer.policy.TransientResourcePolicy
- runCompileTimeOptimization(IRDAG, String) - Method in class org.apache.nemo.compiler.optimizer.policy.XGBoostPolicy
- Runner() - Constructor for class org.apache.nemo.client.beam.NemoRunnerRegistrar.Runner
- runRunTimeOptimizations(IRDAG, Message) - Method in class org.apache.nemo.compiler.optimizer.policy.PolicyImpl
- runRunTimeOptimizations(IRDAG, Message<?>) - Method in class org.apache.nemo.compiler.optimizer.policy.BasicPullPolicy
- runRunTimeOptimizations(IRDAG, Message<?>) - Method in class org.apache.nemo.compiler.optimizer.policy.BasicPushPolicy
- runRunTimeOptimizations(IRDAG, Message<?>) - Method in class org.apache.nemo.compiler.optimizer.policy.ConditionalLargeShufflePolicy
- runRunTimeOptimizations(IRDAG, Message<?>) - Method in class org.apache.nemo.compiler.optimizer.policy.DataSkewPolicy
- runRunTimeOptimizations(IRDAG, Message<?>) - Method in class org.apache.nemo.compiler.optimizer.policy.DefaultPolicy
- runRunTimeOptimizations(IRDAG, Message<?>) - Method in class org.apache.nemo.compiler.optimizer.policy.DefaultPolicyWithSeparatePass
- runRunTimeOptimizations(IRDAG, Message<?>) - Method in class org.apache.nemo.compiler.optimizer.policy.DisaggregationPolicy
- runRunTimeOptimizations(IRDAG, Message<?>) - Method in class org.apache.nemo.compiler.optimizer.policy.DynamicTaskSizingPolicy
- runRunTimeOptimizations(IRDAG, Message<?>) - Method in class org.apache.nemo.compiler.optimizer.policy.LambdaPolicy
- runRunTimeOptimizations(IRDAG, Message<?>) - Method in class org.apache.nemo.compiler.optimizer.policy.LargeShufflePolicy
- runRunTimeOptimizations(IRDAG, Message<?>) - Method in interface org.apache.nemo.compiler.optimizer.policy.Policy
-
Optimize the DAG with the run-time optimizations.
- runRunTimeOptimizations(IRDAG, Message<?>) - Method in class org.apache.nemo.compiler.optimizer.policy.SamplingLargeShuffleSkewPolicy
- runRunTimeOptimizations(IRDAG, Message<?>) - Method in class org.apache.nemo.compiler.optimizer.policy.StreamingPolicy
- runRunTimeOptimizations(IRDAG, Message<?>) - Method in class org.apache.nemo.compiler.optimizer.policy.TestPolicy
- runRunTimeOptimizations(IRDAG, Message<?>) - Method in class org.apache.nemo.compiler.optimizer.policy.TransientResourcePolicy
- runRunTimeOptimizations(IRDAG, Message<?>) - Method in class org.apache.nemo.compiler.optimizer.policy.XGBoostPolicy
- RUNTIME_MASTER_MESSAGE_LISTENER_ID - Static variable in interface org.apache.nemo.runtime.common.message.MessageEnvironment
- RuntimeEdge<V extends Vertex> - Class in org.apache.nemo.runtime.common.plan
-
Represents the edge between vertices in a logical/physical plan in runtime.
- RuntimeEdge(String, ExecutionPropertyMap<EdgeExecutionProperty>, V, V) - Constructor for class org.apache.nemo.runtime.common.plan.RuntimeEdge
-
Constructs the edge given the below parameters.
- RUNTIMEEDGEID_FIELD_NUMBER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptor
- RUNTIMEEDGEID_FIELD_NUMBER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeInitMessage
- RUNTIMEEDGEID_FIELD_NUMBER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptor
- RUNTIMEEDGEID_FIELD_NUMBER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestPipeLocationMessage
- RuntimeEvent - Interface in org.apache.nemo.common.eventhandler
-
An empty interface to indicate events that are sent from Runtime.
- RuntimeEventHandler<T extends RuntimeEvent> - Interface in org.apache.nemo.common.eventhandler
-
Class for handling events sent from Runtime.
- RuntimeIdManager - Class in org.apache.nemo.runtime.common
-
ID Generator.
- RuntimeMaster - Class in org.apache.nemo.runtime.master
-
(WARNING) Use runtimeMasterThread for all public methods to avoid race conditions.
- RuntimeMaster.MasterControlMessageReceiver - Class in org.apache.nemo.runtime.master
-
Handler for control messages received by Master.
- RunTimeMessageOutputCollector<O> - Class in org.apache.nemo.runtime.executor.datatransfer
-
OutputCollector for dynamic optimization data.
- RunTimeMessageOutputCollector(String, IRVertex, PersistentConnectionToMasterMap, TaskExecutor, boolean) - Constructor for class org.apache.nemo.runtime.executor.datatransfer.RunTimeMessageOutputCollector
- RuntimeOptimizationException - Exception in org.apache.nemo.common.exception
-
CompileTimeOptimizationException.
- RuntimeOptimizationException(String) - Constructor for exception org.apache.nemo.common.exception.RuntimeOptimizationException
-
Constructor of CompileTimeOptimizationException.
- RuntimeOptimizationException(Throwable) - Constructor for exception org.apache.nemo.common.exception.RuntimeOptimizationException
-
Constructor of RuntimeOptimizationException.
- RunTimePass<T> - Class in org.apache.nemo.compiler.optimizer.pass.runtime
-
Abstract class for dynamic optimization passes, for dynamically optimizing the IRDAG.
- RunTimePass() - Constructor for class org.apache.nemo.compiler.optimizer.pass.runtime.RunTimePass
- RunTimePassMessage - org.apache.nemo.runtime.common.comm.ControlMessage.MessageType
-
RunTimePassMessage = 3;
- RunTimePassMessage_VALUE - Static variable in enum org.apache.nemo.runtime.common.comm.ControlMessage.MessageType
-
RunTimePassMessage = 3;
- RUNTIMEPASSMESSAGEMSG_FIELD_NUMBER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
- RuntimeTestUtil - Class in org.apache.nemo.runtime.common
-
Utility class for runtime unit tests.
S
- SamplingLargeShuffleSkewPolicy - Class in org.apache.nemo.compiler.optimizer.policy
-
A policy to demonstrate the large shuffle optimization, witch batches disk seek during data shuffle.
- SamplingLargeShuffleSkewPolicy() - Constructor for class org.apache.nemo.compiler.optimizer.policy.SamplingLargeShuffleSkewPolicy
-
Default constructor.
- SamplingSkewReshapingPass - Class in org.apache.nemo.compiler.optimizer.pass.compiletime.reshaping
-
Optimizes the PartitionSet property of shuffle edges to handle data skews using the SamplingVertex.
- SamplingSkewReshapingPass() - Constructor for class org.apache.nemo.compiler.optimizer.pass.compiletime.reshaping.SamplingSkewReshapingPass
-
Default constructor.
- SamplingTaskSizingPass - Class in org.apache.nemo.compiler.optimizer.pass.compiletime.reshaping
-
Compiler pass for dynamic task size optimization.
- SamplingTaskSizingPass() - Constructor for class org.apache.nemo.compiler.optimizer.pass.compiletime.reshaping.SamplingTaskSizingPass
-
Default constructor.
- SamplingVertex - Class in org.apache.nemo.common.ir.vertex.utility
-
Executes the original IRVertex using a subset of input data partitions.
- SamplingVertex(IRVertex, float) - Constructor for class org.apache.nemo.common.ir.vertex.utility.SamplingVertex
- saveOptimizationMetricsToDB(String, String, String, String) - Method in class org.apache.nemo.runtime.master.metric.MetricStore
-
Save the job metrics for the optimization to the DB, in the form of LibSVM, to a remote DB, if applicable.
- saveVertexId(Vertex, String) - Static method in class org.apache.nemo.common.ir.IdManager
-
Save the vertex id for the vertices that can be cloned later on.
- ScheduleGroupProperty - Class in org.apache.nemo.common.ir.vertex.executionproperty
-
ScheduleGroup ExecutionProperty.
- schedulePlan(PhysicalPlan, int) - Method in class org.apache.nemo.runtime.master.scheduler.BatchScheduler
-
Schedules a given plan.
- schedulePlan(PhysicalPlan, int) - Method in interface org.apache.nemo.runtime.master.scheduler.Scheduler
-
Schedules the given plan.
- schedulePlan(PhysicalPlan, int) - Method in class org.apache.nemo.runtime.master.scheduler.SimulationScheduler
-
The entrance point of the simulator.
- schedulePlan(PhysicalPlan, int) - Method in class org.apache.nemo.runtime.master.scheduler.StreamingScheduler
- Scheduler - Interface in org.apache.nemo.runtime.master.scheduler
-
Only two threads call scheduling code: RuntimeMaster thread (RMT), and SchedulerThread(ST).
- SchedulerImplClassName() - Constructor for class org.apache.nemo.conf.JobConf.SchedulerImplClassName
- ScheduleSerThread() - Constructor for class org.apache.nemo.conf.JobConf.ScheduleSerThread
- ScheduleTask - org.apache.nemo.runtime.common.comm.ControlMessage.MessageType
-
ScheduleTask = 1;
- ScheduleTask_VALUE - Static variable in enum org.apache.nemo.runtime.common.comm.ControlMessage.MessageType
-
ScheduleTask = 1;
- SCHEDULETASKMSG_FIELD_NUMBER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
- SchedulingConstraint - Interface in org.apache.nemo.runtime.master.scheduler
-
Functions to test schedulability with a pair of an executor and a task.
- SchedulingConstraintRegistry - Class in org.apache.nemo.runtime.master.scheduler
-
Registry for
SchedulingConstraint
. - SchedulingException - Exception in org.apache.nemo.common.exception
-
SchedulingException.
- SchedulingException(Throwable) - Constructor for exception org.apache.nemo.common.exception.SchedulingException
-
SchedulingException.
- SchedulingPolicy - Interface in org.apache.nemo.runtime.master.scheduler
-
A function to select an executor from collection of available executors.
- selectExecutor(Collection<ExecutorRepresenter>, Task) - Method in class org.apache.nemo.runtime.master.scheduler.MinOccupancyFirstSchedulingPolicy
- selectExecutor(Collection<ExecutorRepresenter>, Task) - Method in interface org.apache.nemo.runtime.master.scheduler.SchedulingPolicy
-
A function to select an executor from the specified collection of available executors.
- send(String, String, String, byte[]) - Method in class org.apache.nemo.runtime.executor.MetricManagerWorker
- send(String, String, String, byte[]) - Method in interface org.apache.nemo.runtime.executor.MetricMessageSender
-
Send metric to master.
- send(ControlMessage.ClientToDriverMessage) - Method in class org.apache.nemo.client.DriverRPCServer
-
Sends a message to driver.
- send(ControlMessage.DriverToClientMessage) - Method in class org.apache.nemo.runtime.common.message.ClientRPC
-
Write message to client.
- send(ControlMessage.Message) - Method in class org.apache.nemo.runtime.common.comm.MessageServiceGrpc.MessageServiceBlockingStub
-
See org.apache.nemo.runtime.common.message.MessageSender#send for more details
- send(ControlMessage.Message) - Method in class org.apache.nemo.runtime.common.comm.MessageServiceGrpc.MessageServiceFutureStub
-
See org.apache.nemo.runtime.common.message.MessageSender#send for more details
- send(ControlMessage.Message) - Method in class org.apache.nemo.runtime.common.message.FailedMessageSender
- send(ControlMessage.Message, StreamObserver<GrpcMessageService.Void>) - Method in class org.apache.nemo.runtime.common.comm.MessageServiceGrpc.MessageServiceImplBase
-
See org.apache.nemo.runtime.common.message.MessageSender#send for more details
- send(ControlMessage.Message, StreamObserver<GrpcMessageService.Void>) - Method in class org.apache.nemo.runtime.common.comm.MessageServiceGrpc.MessageServiceStub
-
See org.apache.nemo.runtime.common.message.MessageSender#send for more details
- send(T) - Method in class org.apache.nemo.runtime.common.message.local.LocalMessageSender
- send(T) - Method in interface org.apache.nemo.runtime.common.message.MessageSender
-
Send a message to corresponding
MessageListener.onMessage(T)
. - sendControlMessage(ControlMessage.Message) - Method in class org.apache.nemo.runtime.master.resource.DefaultExecutorRepresenter
-
Sends control message to the executor.
- sendControlMessage(ControlMessage.Message) - Method in interface org.apache.nemo.runtime.master.resource.ExecutorRepresenter
-
Sends control message to the executor.
- SenderId() - Constructor for class org.apache.nemo.runtime.common.message.MessageParameters.SenderId
- sendMetric(String, String, String, byte[]) - Method in class org.apache.nemo.runtime.master.scheduler.SimulatedTaskExecutor
-
Send the metric to the scheduler, as an executor would.
- sendMetricFlushRequest() - Method in class org.apache.nemo.runtime.master.metric.MetricManagerMaster
- sendMetrics() - Method in class org.apache.nemo.runtime.executor.task.TaskExecutor
-
Send data-processing metrics.
- sendStreamMetric() - Method in class org.apache.nemo.runtime.executor.task.TaskExecutor
-
Send stream metric to the runtime master.
- SER_MEMORY - org.apache.nemo.runtime.common.comm.ControlMessage.BlockStore
-
SER_MEMORY = 1;
- SER_MEMORY_VALUE - Static variable in enum org.apache.nemo.runtime.common.comm.ControlMessage.BlockStore
-
SER_MEMORY = 1;
- SERIALIZED_MEMORY_STORE - org.apache.nemo.common.ir.edge.executionproperty.DataStoreProperty.Value
- SerializedMemoryBlock<K extends java.io.Serializable> - Class in org.apache.nemo.runtime.executor.data.block
-
This class represents a block which is serialized and stored in local memory.
- SerializedMemoryBlock(String, Serializer, MemoryPoolAssigner) - Constructor for class org.apache.nemo.runtime.executor.data.block.SerializedMemoryBlock
-
Constructor.
- SerializedMemoryStore - Class in org.apache.nemo.runtime.executor.data.stores
-
Serialize and store data in local memory.
- SerializedPartition<K> - Class in org.apache.nemo.runtime.executor.data.partition
-
A collection of data elements.
- SerializedPartition(K, byte[], int, MemoryPoolAssigner) - Constructor for class org.apache.nemo.runtime.executor.data.partition.SerializedPartition
-
Creates a serialized
Partition
with actual data residing in on-heap region. - SerializedPartition(K, List<MemoryChunk>, int, MemoryPoolAssigner) - Constructor for class org.apache.nemo.runtime.executor.data.partition.SerializedPartition
-
Creates a serialized
Partition
with actual data residing in off-heap region. - SerializedPartition(K, Serializer, MemoryPoolAssigner) - Constructor for class org.apache.nemo.runtime.executor.data.partition.SerializedPartition
-
Creates a serialized
Partition
without actual data. - Serializer<E,D> - Class in org.apache.nemo.runtime.executor.data.streamchainer
- Serializer(EncoderFactory<E>, DecoderFactory<D>, List<EncodeStreamChainer>, List<DecodeStreamChainer>) - Constructor for class org.apache.nemo.runtime.executor.data.streamchainer.Serializer
-
Constructor.
- SerializerManager - Class in org.apache.nemo.runtime.executor.data
-
Mapping from RuntimeEdgeId to
Serializer
. - SERVICE_NAME - Static variable in class org.apache.nemo.runtime.common.comm.MessageServiceGrpc
- setAge(int) - Method in class org.apache.nemo.examples.spark.sql.JavaSparkSQLExample.Person
-
Setter.
- setAttemptIdx(int) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg.Builder
-
required int32 attemptIdx = 6;
- setBandwidthSpecificationString(String) - Static method in class org.apache.nemo.compiler.optimizer.pass.compiletime.annotating.ResourceSitePass
- setBlockId(String) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsg.Builder
-
required string blockId = 2;
- setBlockId(String) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsg.Builder
-
required string blockId = 2;
- setBlockId(String) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptor.Builder
-
required string blockId = 1;
- setBlockIdBytes(ByteString) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsg.Builder
-
required string blockId = 2;
- setBlockIdBytes(ByteString) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsg.Builder
-
required string blockId = 2;
- setBlockIdBytes(ByteString) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptor.Builder
-
required string blockId = 1;
- setBlockIdWildcard(String) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBlockLocationMsg.Builder
-
required string blockIdWildcard = 2;
- setBlockIdWildcardBytes(ByteString) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBlockLocationMsg.Builder
-
required string blockIdWildcard = 2;
- setBlockLocationInfoMsg(ControlMessage.BlockLocationInfoMsg) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.BlockLocationInfoMsg blockLocationInfoMsg = 9;
- setBlockLocationInfoMsg(ControlMessage.BlockLocationInfoMsg.Builder) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.BlockLocationInfoMsg blockLocationInfoMsg = 9;
- setBlockStateChangedMsg(ControlMessage.BlockStateChangedMsg) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.BlockStateChangedMsg blockStateChangedMsg = 6;
- setBlockStateChangedMsg(ControlMessage.BlockStateChangedMsg.Builder) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.BlockStateChangedMsg blockStateChangedMsg = 6;
- setBlockStore(ControlMessage.BlockStore) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptor.Builder
-
required .protobuf.BlockStore blockStore = 2;
- setBroadcastId(ByteString) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBroadcastVariableMessage.Builder
-
required bytes broadcastId = 2;
- setBroadcastVariableMsg(ControlMessage.InMasterBroadcastVariableMessage) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.InMasterBroadcastVariableMessage broadcastVariableMsg = 15;
- setBroadcastVariableMsg(ControlMessage.InMasterBroadcastVariableMessage.Builder) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.InMasterBroadcastVariableMessage broadcastVariableMsg = 15;
- setBroadcastVars(ByteString) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.LaunchDAGMessage.Builder
-
optional bytes broadcastVars = 2;
- setChannelError(Throwable) - Method in class org.apache.nemo.runtime.executor.transfer.ByteTransferContext
-
Sets exception.
- setCommitted(boolean) - Method in class org.apache.nemo.runtime.executor.data.metadata.FileMetadata
-
Set the commit value.
- setContainerFailedMsg(ControlMessage.ContainerFailedMsg) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.ContainerFailedMsg containerFailedMsg = 11;
- setContainerFailedMsg(ControlMessage.ContainerFailedMsg.Builder) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.ContainerFailedMsg containerFailedMsg = 11;
- setContextDescriptor(ByteString) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage.Builder
-
required bytes contextDescriptor = 4;
- setCount(long) - Method in class org.apache.nemo.examples.spark.sql.JavaUserDefinedTypedAggregation.Average
-
Setter.
- setCurrentIRDAG(IRDAG) - Method in class org.apache.nemo.compiler.backend.nemo.NemoPlanRewriter
- setCurrentPhysicalPlan(PhysicalPlan) - Method in class org.apache.nemo.compiler.backend.nemo.NemoPlanRewriter
- setCurrentWatermarkOfAllMainAndSideInputs(long) - Method in class org.apache.nemo.compiler.frontend.beam.InMemorySideInputReader
-
Say a DoFn of this reader has 3 main inputs and 4 side inputs.
- setDag(String) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.LaunchDAGMessage.Builder
-
required string dag = 1;
- setDagBytes(ByteString) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.LaunchDAGMessage.Builder
-
required string dag = 1;
- setData(String) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DataCollectMessage.Builder
-
required string data = 1;
- setData(String) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.NotificationMessage.Builder
-
required string data = 2;
- setDataBytes(ByteString) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DataCollectMessage.Builder
-
required string data = 1;
- setDataBytes(ByteString) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.NotificationMessage.Builder
-
required string data = 2;
- setDataCollected(ControlMessage.DataCollectMessage) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessage.Builder
-
optional .protobuf.DataCollectMessage dataCollected = 2;
- setDataCollected(ControlMessage.DataCollectMessage) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.DataCollectMessage dataCollected = 13;
- setDataCollected(ControlMessage.DataCollectMessage.Builder) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessage.Builder
-
optional .protobuf.DataCollectMessage dataCollected = 2;
- setDataCollected(ControlMessage.DataCollectMessage.Builder) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.DataCollectMessage dataCollected = 13;
- setDataDirection(ControlMessage.ByteTransferDataDirection) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage.Builder
-
required .protobuf.ByteTransferDataDirection dataDirection = 3;
- setDstTaskIndex(long) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptor.Builder
-
required int64 dstTaskIndex = 3;
- setEntry(int, ControlMessage.RunTimePassMessageEntry) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsg.Builder
-
repeated .protobuf.RunTimePassMessageEntry entry = 2;
- setEntry(int, ControlMessage.RunTimePassMessageEntry.Builder) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsg.Builder
-
repeated .protobuf.RunTimePassMessageEntry entry = 2;
- setException(ByteString) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ExecutorFailedMsg.Builder
-
required bytes exception = 2;
- setExecutionProperties(ExecutionPropertyMap<VertexExecutionProperty>) - Method in class org.apache.nemo.runtime.common.plan.Stage
- setExecutorFailedMsg(ControlMessage.ExecutorFailedMsg) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.ExecutorFailedMsg executorFailedMsg = 10;
- setExecutorFailedMsg(ControlMessage.ExecutorFailedMsg.Builder) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.ExecutorFailedMsg executorFailedMsg = 10;
- setExecutorId(String) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsg.Builder
-
required string executorId = 1;
- setExecutorId(String) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ContainerFailedMsg.Builder
-
required string executorId = 1;
- setExecutorId(String) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ExecutorFailedMsg.Builder
-
required string executorId = 1;
- setExecutorId(String) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeInitMessage.Builder
-
required string executorId = 3;
- setExecutorId(String) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeLocationInfoMessage.Builder
-
required string executorId = 2;
- setExecutorId(String) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBlockLocationMsg.Builder
-
required string executorId = 1;
- setExecutorId(String) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBroadcastVariableMessage.Builder
-
required string executorId = 1;
- setExecutorId(String) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestPipeLocationMessage.Builder
-
required string executorId = 1;
- setExecutorId(String) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg.Builder
-
required string executorId = 1;
- setExecutorIdBytes(ByteString) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsg.Builder
-
required string executorId = 1;
- setExecutorIdBytes(ByteString) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ContainerFailedMsg.Builder
-
required string executorId = 1;
- setExecutorIdBytes(ByteString) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ExecutorFailedMsg.Builder
-
required string executorId = 1;
- setExecutorIdBytes(ByteString) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeInitMessage.Builder
-
required string executorId = 3;
- setExecutorIdBytes(ByteString) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeLocationInfoMessage.Builder
-
required string executorId = 2;
- setExecutorIdBytes(ByteString) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBlockLocationMsg.Builder
-
required string executorId = 1;
- setExecutorIdBytes(ByteString) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBroadcastVariableMessage.Builder
-
required string executorId = 1;
- setExecutorIdBytes(ByteString) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestPipeLocationMessage.Builder
-
required string executorId = 1;
- setExecutorIdBytes(ByteString) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg.Builder
-
required string executorId = 1;
- setFailureCause(ControlMessage.RecoverableFailureCause) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg.Builder
-
optional .protobuf.RecoverableFailureCause failureCause = 5;
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsg.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsg.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptor.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessage.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ContainerFailedMsg.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DataCollectMessage.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessage.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ExecutorFailedMsg.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.InMasterBroadcastVariableMessage.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.LaunchDAGMessage.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Metric.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.MetricMsg.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.NotificationMessage.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeInitMessage.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeLocationInfoMessage.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptor.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBlockLocationMsg.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBroadcastVariableMessage.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestPipeLocationMessage.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageEntry.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsg.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ScheduleTaskMsg.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.nemo.runtime.common.comm.GrpcMessageService.Void.Builder
- setGroupSize(int) - Method in class org.apache.nemo.common.ir.edge.executionproperty.DuplicateEdgeGroupPropertyValue
-
Set the group size.
- setId(long) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
required int64 id = 2;
- setInDriver() - Static method in class org.apache.nemo.common.ir.IdManager
-
Set the realm of the loaded class as REEF driver.
- setInitialState(Enum) - Method in class org.apache.nemo.common.StateMachine.Builder
- setInitiatorExecutorId(String) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage.Builder
-
required string initiatorExecutorId = 1;
- setInitiatorExecutorIdBytes(ByteString) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage.Builder
-
required string initiatorExecutorId = 1;
- setInputFile(String) - Method in interface org.apache.nemo.examples.beam.BeamWordCount.WordCountOptions
- setIRDAG(IRDAG) - Method in class org.apache.nemo.runtime.common.metric.JobMetric
-
Setter for the IR DAG.
- setIRVertexPutOnHold(IRVertex) - Method in class org.apache.nemo.runtime.executor.task.TaskExecutor
- setIsPipe(boolean) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage.Builder
-
required bool isPipe = 5;
- setJobDone() - Method in class org.apache.nemo.client.beam.NemoPipelineResult
-
Signal that the job is finished to the NemoPipelineResult object.
- setJobDuration(Long) - Method in class org.apache.nemo.runtime.common.metric.JobMetric
- setKey(String) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageEntry.Builder
-
required string key = 1;
- setKeyBytes(ByteString) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageEntry.Builder
-
required string key = 1;
- setKeyRange(ByteString) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptor.Builder
-
optional bytes keyRange = 4;
- setLaunchDAG(ControlMessage.LaunchDAGMessage) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessage.Builder
-
optional .protobuf.LaunchDAGMessage launchDAG = 2;
- setLaunchDAG(ControlMessage.LaunchDAGMessage.Builder) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessage.Builder
-
optional .protobuf.LaunchDAGMessage launchDAG = 2;
- setListenerId(String) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
The id of the message listener (handler).
- setListenerIdBytes(ByteString) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
The id of the message listener (handler).
- setLocation(String) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsg.Builder
-
The location of the block (e.g., executor id or remote store).
- setLocationBytes(ByteString) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsg.Builder
-
The location of the block (e.g., executor id or remote store).
- setMaxBundleSize(Long) - Method in interface org.apache.nemo.compiler.frontend.beam.NemoPipelineOptions
- setMaxBundleTimeMills(Long) - Method in interface org.apache.nemo.compiler.frontend.beam.NemoPipelineOptions
- setMaxNumberOfIterations(Integer) - Method in class org.apache.nemo.common.ir.vertex.LoopVertex
-
Set the maximum number of iterations.
- setMessage(ControlMessage.NotificationMessage) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessage.Builder
-
optional .protobuf.NotificationMessage message = 3;
- setMessage(ControlMessage.NotificationMessage.Builder) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessage.Builder
-
optional .protobuf.NotificationMessage message = 3;
- setMetric(int, ControlMessage.Metric) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.MetricMsg.Builder
-
repeated .protobuf.Metric metric = 1;
- setMetric(int, ControlMessage.Metric.Builder) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.MetricMsg.Builder
-
repeated .protobuf.Metric metric = 1;
- setMetricField(String) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Metric.Builder
-
required string metricField = 3;
- setMetricFieldBytes(ByteString) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Metric.Builder
-
required string metricField = 3;
- setMetricId(String) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Metric.Builder
-
required string metricId = 2;
- setMetricIdBytes(ByteString) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Metric.Builder
-
required string metricId = 2;
- setMetricMsg(ControlMessage.MetricMsg) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.MetricMsg metricMsg = 12;
- setMetricMsg(ControlMessage.MetricMsg.Builder) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.MetricMsg metricMsg = 12;
- setMetricStore(MetricStore) - Method in class org.apache.nemo.runtime.master.PlanStateManager
- setMetricType(String) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Metric.Builder
-
required string metricType = 1;
- setMetricTypeBytes(ByteString) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Metric.Builder
-
required string metricType = 1;
- setMetricValue(ByteString) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Metric.Builder
-
required bytes metricValue = 4;
- setName(String) - Method in class org.apache.nemo.examples.spark.sql.JavaSparkSQLExample.Person
-
Setter.
- setName(String) - Method in class org.apache.nemo.examples.spark.sql.JavaUserDefinedTypedAggregation.Employee
-
Setter.
- setNumOfClones(String, int, int) - Method in class org.apache.nemo.runtime.master.PlanStateManager
- setNumPipeToWait(long) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptor.Builder
-
required int64 numPipeToWait = 4;
- setOptimizationType(ControlMessage.OptimizationType) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessage.Builder
-
optional .protobuf.OptimizationType optimizationType = 3;
- setOptimizationType(ControlMessage.OptimizationType) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.NotificationMessage.Builder
-
required .protobuf.OptimizationType optimizationType = 1;
- setOutput(String) - Method in interface org.apache.nemo.examples.beam.BeamWordCount.WordCountOptions
- setOwnerExecutorId(String) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsg.Builder
-
optional string ownerExecutorId = 4;
- setOwnerExecutorIdBytes(ByteString) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsg.Builder
-
optional string ownerExecutorId = 4;
- setPipeInitMsg(ControlMessage.PipeInitMessage) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.PipeInitMessage pipeInitMsg = 16;
- setPipeInitMsg(ControlMessage.PipeInitMessage.Builder) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.PipeInitMessage pipeInitMsg = 16;
- setPipeLocInfoMsg(ControlMessage.PipeLocationInfoMessage) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.PipeLocationInfoMessage pipeLocInfoMsg = 18;
- setPipeLocInfoMsg(ControlMessage.PipeLocationInfoMessage.Builder) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.PipeLocationInfoMessage pipeLocInfoMsg = 18;
- setPreviousSentTimestamp(long) - Method in class org.apache.nemo.common.punctuation.LatencyMark
-
Set the previousSentTimestamp.
- setPreviousTaskId(String) - Method in class org.apache.nemo.common.punctuation.LatencyMark
-
Set the previousTaskId.
- setProperty(EdgeExecutionProperty<?>) - Method in class org.apache.nemo.common.ir.edge.IREdge
-
Set an executionProperty of the IREdge.
- setProperty(VertexExecutionProperty<?>) - Method in class org.apache.nemo.common.ir.vertex.IRVertex
-
Set an executionProperty of the IRVertex.
- setPropertyPermanently(EdgeExecutionProperty<?>) - Method in class org.apache.nemo.common.ir.edge.IREdge
-
Set an executionProperty of the IREdge, permanently.
- setPropertyPermanently(VertexExecutionProperty<?>) - Method in class org.apache.nemo.common.ir.vertex.IRVertex
-
Set an executionProperty of the IRVertex, permanently.
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsg.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsg.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptor.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessage.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ContainerFailedMsg.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DataCollectMessage.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessage.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ExecutorFailedMsg.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.InMasterBroadcastVariableMessage.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.LaunchDAGMessage.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Metric.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.MetricMsg.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.NotificationMessage.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeInitMessage.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeLocationInfoMessage.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptor.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBlockLocationMsg.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBroadcastVariableMessage.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestPipeLocationMessage.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageEntry.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsg.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ScheduleTaskMsg.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.nemo.runtime.common.comm.GrpcMessageService.Void.Builder
- setRepresentativeEdgeId(String) - Method in class org.apache.nemo.common.ir.edge.executionproperty.DuplicateEdgeGroupPropertyValue
-
Set physical edge id.
- setRequestBlockLocationMsg(ControlMessage.RequestBlockLocationMsg) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.RequestBlockLocationMsg requestBlockLocationMsg = 8;
- setRequestBlockLocationMsg(ControlMessage.RequestBlockLocationMsg.Builder) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.RequestBlockLocationMsg requestBlockLocationMsg = 8;
- setRequestbroadcastVariableMsg(ControlMessage.RequestBroadcastVariableMessage) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.RequestBroadcastVariableMessage requestbroadcastVariableMsg = 14;
- setRequestbroadcastVariableMsg(ControlMessage.RequestBroadcastVariableMessage.Builder) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.RequestBroadcastVariableMessage requestbroadcastVariableMsg = 14;
- setRequestId(long) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsg.Builder
-
To find the matching request msg
- setRequestId(long) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.InMasterBroadcastVariableMessage.Builder
-
To find the matching request msg
- setRequestId(long) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeLocationInfoMessage.Builder
-
To find the matching request msg
- setRequestPipeLocMsg(ControlMessage.RequestPipeLocationMessage) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.RequestPipeLocationMessage requestPipeLocMsg = 17;
- setRequestPipeLocMsg(ControlMessage.RequestPipeLocationMessage.Builder) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.RequestPipeLocationMessage requestPipeLocMsg = 17;
- setRuntimeEdgeId(String) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptor.Builder
-
required string runtimeEdgeId = 3;
- setRuntimeEdgeId(String) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeInitMessage.Builder
-
required string runtimeEdgeId = 2;
- setRuntimeEdgeId(String) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptor.Builder
-
required string runtimeEdgeId = 2;
- setRuntimeEdgeId(String) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestPipeLocationMessage.Builder
-
required string runtimeEdgeId = 3;
- setRuntimeEdgeIdBytes(ByteString) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptor.Builder
-
required string runtimeEdgeId = 3;
- setRuntimeEdgeIdBytes(ByteString) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeInitMessage.Builder
-
required string runtimeEdgeId = 2;
- setRuntimeEdgeIdBytes(ByteString) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptor.Builder
-
required string runtimeEdgeId = 2;
- setRuntimeEdgeIdBytes(ByteString) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestPipeLocationMessage.Builder
-
required string runtimeEdgeId = 3;
- setRunTimePassMessageMsg(ControlMessage.RunTimePassMessageMsg) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.RunTimePassMessageMsg runTimePassMessageMsg = 7;
- setRunTimePassMessageMsg(ControlMessage.RunTimePassMessageMsg.Builder) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.RunTimePassMessageMsg runTimePassMessageMsg = 7;
- setSalary(long) - Method in class org.apache.nemo.examples.spark.sql.JavaUserDefinedTypedAggregation.Employee
-
Setter.
- setScheduleTaskMsg(ControlMessage.ScheduleTaskMsg) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.ScheduleTaskMsg scheduleTaskMsg = 5;
- setScheduleTaskMsg(ControlMessage.ScheduleTaskMsg.Builder) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.ScheduleTaskMsg scheduleTaskMsg = 5;
- setSerializedData(String) - Method in interface org.apache.nemo.common.ir.vertex.transform.Transform.Context
-
Put serialized data to send to the executor.
- setSerializedData(String) - Method in class org.apache.nemo.runtime.executor.TransformContextImpl
- setSrcTaskIndex(long) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeInitMessage.Builder
-
required int64 srcTaskIndex = 1;
- setSrcTaskIndex(long) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptor.Builder
-
required int64 srcTaskIndex = 1;
- setSrcTaskIndex(long) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestPipeLocationMessage.Builder
-
required int64 srcTaskIndex = 2;
- setStageDAG(DAG<Stage, StageEdge>) - Method in class org.apache.nemo.runtime.common.metric.JobMetric
-
Setter for the stage DAG.
- setState(Enum) - Method in class org.apache.nemo.common.StateMachine
-
Sets the current state as a certain state.
- setState(ControlMessage.BlockStateFromExecutor) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsg.Builder
-
optional .protobuf.BlockStateFromExecutor state = 3;
- setState(ControlMessage.BlockStateFromExecutor) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsg.Builder
-
required .protobuf.BlockStateFromExecutor state = 3;
- setState(ControlMessage.TaskStateFromExecutor) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg.Builder
-
required .protobuf.TaskStateFromExecutor state = 3;
- setSum(long) - Method in class org.apache.nemo.examples.spark.sql.JavaUserDefinedTypedAggregation.Average
-
Setter.
- setTask(ByteString) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ScheduleTaskMsg.Builder
-
required bytes task = 1;
- setTaskId(String) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsg.Builder
-
required string taskId = 1;
- setTaskId(String) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg.Builder
-
required string taskId = 2;
- setTaskIdBytes(ByteString) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsg.Builder
-
required string taskId = 1;
- setTaskIdBytes(ByteString) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg.Builder
-
required string taskId = 2;
- setTaskStateChangedMsg(ControlMessage.TaskStateChangedMsg) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.TaskStateChangedMsg taskStateChangedMsg = 4;
- setTaskStateChangedMsg(ControlMessage.TaskStateChangedMsg.Builder) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
optional .protobuf.TaskStateChangedMsg taskStateChangedMsg = 4;
- setTerminationCondition(IntPredicate) - Method in class org.apache.nemo.common.ir.vertex.LoopVertex
-
Set the intPredicate termination condition for the LoopVertex.
- setTimestamp(long) - Method in class org.apache.nemo.runtime.common.metric.Event
-
Set timestamp.
- setTransferIndex(int) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage.Builder
-
required int32 transferIndex = 2;
- setTransferType(DataTransferEvent.TransferType) - Method in class org.apache.nemo.runtime.common.metric.DataTransferEvent
-
Set transfer type.
- setType(ControlMessage.ClientToDriverMessageType) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessage.Builder
-
required .protobuf.ClientToDriverMessageType type = 1;
- setType(ControlMessage.DriverToClientMessageType) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessage.Builder
-
required .protobuf.DriverToClientMessageType type = 1;
- setType(ControlMessage.MessageType) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
-
required .protobuf.MessageType type = 1;
- setUnknownFields(UnknownFieldSet) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsg.Builder
- setUnknownFields(UnknownFieldSet) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsg.Builder
- setUnknownFields(UnknownFieldSet) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptor.Builder
- setUnknownFields(UnknownFieldSet) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage.Builder
- setUnknownFields(UnknownFieldSet) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessage.Builder
- setUnknownFields(UnknownFieldSet) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ContainerFailedMsg.Builder
- setUnknownFields(UnknownFieldSet) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DataCollectMessage.Builder
- setUnknownFields(UnknownFieldSet) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessage.Builder
- setUnknownFields(UnknownFieldSet) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ExecutorFailedMsg.Builder
- setUnknownFields(UnknownFieldSet) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.InMasterBroadcastVariableMessage.Builder
- setUnknownFields(UnknownFieldSet) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.LaunchDAGMessage.Builder
- setUnknownFields(UnknownFieldSet) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message.Builder
- setUnknownFields(UnknownFieldSet) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Metric.Builder
- setUnknownFields(UnknownFieldSet) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.MetricMsg.Builder
- setUnknownFields(UnknownFieldSet) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.NotificationMessage.Builder
- setUnknownFields(UnknownFieldSet) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeInitMessage.Builder
- setUnknownFields(UnknownFieldSet) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeLocationInfoMessage.Builder
- setUnknownFields(UnknownFieldSet) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptor.Builder
- setUnknownFields(UnknownFieldSet) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBlockLocationMsg.Builder
- setUnknownFields(UnknownFieldSet) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBroadcastVariableMessage.Builder
- setUnknownFields(UnknownFieldSet) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestPipeLocationMessage.Builder
- setUnknownFields(UnknownFieldSet) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageEntry.Builder
- setUnknownFields(UnknownFieldSet) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsg.Builder
- setUnknownFields(UnknownFieldSet) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ScheduleTaskMsg.Builder
- setUnknownFields(UnknownFieldSet) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg.Builder
- setUnknownFields(UnknownFieldSet) - Method in class org.apache.nemo.runtime.common.comm.GrpcMessageService.Void.Builder
- setup(String[]) - Static method in class org.apache.nemo.client.JobLauncher
-
Set up the driver, etc.
- setupListener(String, MessageListener<T>) - Method in class org.apache.nemo.runtime.common.message.grpc.GrpcMessageEnvironment
- setupListener(String, MessageListener<T>) - Method in class org.apache.nemo.runtime.common.message.local.LocalMessageEnvironment
- setupListener(String, MessageListener<T>) - Method in interface org.apache.nemo.runtime.common.message.MessageEnvironment
-
Set up a
MessageListener
with a listener id. - setupListener(String, MessageListener<T>) - Method in class org.apache.nemo.runtime.common.message.ncs.NcsMessageEnvironment
- setValue(long) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageEntry.Builder
-
required int64 value = 2;
- setVariable(ByteString) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.InMasterBroadcastVariableMessage.Builder
-
required bytes variable = 2;
- setVertexPutOnHoldId(String) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg.Builder
-
optional string vertexPutOnHoldId = 4;
- setVertexPutOnHoldIdBytes(ByteString) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg.Builder
-
optional string vertexPutOnHoldId = 4;
- SHOULD_RETRY - org.apache.nemo.runtime.common.state.TaskState.State
- SHUFFLE - org.apache.nemo.common.ir.edge.executionproperty.CommunicationPatternProperty.Value
- ShuffleEdgePushPass - Class in org.apache.nemo.compiler.optimizer.pass.compiletime.annotating
-
A pass for tagging shuffle edges different from the default ones.
- ShuffleEdgePushPass() - Constructor for class org.apache.nemo.compiler.optimizer.pass.compiletime.annotating.ShuffleEdgePushPass
-
Default constructor.
- shutdown() - Method in class org.apache.nemo.client.DriverRPCServer
-
Shut down the server.
- shutdown() - Static method in class org.apache.nemo.client.JobLauncher
- shutdown() - Method in class org.apache.nemo.runtime.common.message.ClientRPC
-
Shuts down the transport.
- shutDown() - Method in class org.apache.nemo.runtime.master.resource.DefaultExecutorRepresenter
-
Shuts down this executor.
- shutDown() - Method in interface org.apache.nemo.runtime.master.resource.ExecutorRepresenter
-
Shuts down this executor.
- SideInputCoder<T> - Class in org.apache.nemo.compiler.frontend.beam.coder
-
EncoderFactory for side inputs.
- SideInputElement<T> - Class in org.apache.nemo.compiler.frontend.beam
-
DoFnTransform
treats elements of this type as side inputs. - SideInputElement(int, T) - Constructor for class org.apache.nemo.compiler.frontend.beam.SideInputElement
- SideInputTransform<T> - Class in org.apache.nemo.compiler.frontend.beam.transform
-
Side input transform implementation.
- SideInputTransform(int) - Constructor for class org.apache.nemo.compiler.frontend.beam.transform.SideInputTransform
-
Constructor.
- SignalTransform - Class in org.apache.nemo.common.ir.vertex.transform
-
This class evokes run-time pass when there's no need to transfer any run-time information.
- SignalTransform() - Constructor for class org.apache.nemo.common.ir.vertex.transform.SignalTransform
- SignalVertex - Class in org.apache.nemo.common.ir.vertex.utility.runtimepass
-
Signal vertex holding signal transform.
- SignalVertex() - Constructor for class org.apache.nemo.common.ir.vertex.utility.runtimepass.SignalVertex
- SimpleSumSQL - Class in org.apache.nemo.examples.beam
-
A simple SQL application.
- SimulatedTaskExecutor - Class in org.apache.nemo.runtime.master.scheduler
-
Class for simulated task execution.
- SimulationException - Exception in org.apache.nemo.common.exception
-
SimulationException.
- SimulationException(String) - Constructor for exception org.apache.nemo.common.exception.SimulationException
-
SimulationException.
- SimulationException(Throwable) - Constructor for exception org.apache.nemo.common.exception.SimulationException
-
SimulationException.
- SimulationScheduler - Class in org.apache.nemo.runtime.master.scheduler
-
Scheduler for simulating an execution not controlled by the runtime master.
- SingleInputWatermarkManager - Class in org.apache.nemo.runtime.executor.datatransfer
-
This is a special implementation for single input data stream for optimization.
- SingleInputWatermarkManager(OutputCollector) - Constructor for class org.apache.nemo.runtime.executor.datatransfer.SingleInputWatermarkManager
- size() - Method in class org.apache.nemo.runtime.executor.data.DirectByteBufferOutputStream
-
Returns the size of the data written in this output stream.
- SkewAnnotatingPass - Class in org.apache.nemo.compiler.optimizer.pass.compiletime.annotating
-
For each shuffle edge, set the number of partitions to (dstParallelism * HASH_RANGE_MULTIPLIER).
- SkewAnnotatingPass() - Constructor for class org.apache.nemo.compiler.optimizer.pass.compiletime.annotating.SkewAnnotatingPass
-
Default constructor.
- SkewCompositePass - Class in org.apache.nemo.compiler.optimizer.pass.compiletime.composite
-
Pass to modify the DAG for a job to perform data skew.
- SkewCompositePass() - Constructor for class org.apache.nemo.compiler.optimizer.pass.compiletime.composite.SkewCompositePass
-
Default constructor.
- SkewProphet - Class in org.apache.nemo.compiler.backend.nemo.prophet
-
Prophet class for skew handling.
- SkewProphet(List<ControlMessage.RunTimePassMessageEntry>) - Constructor for class org.apache.nemo.compiler.backend.nemo.prophet.SkewProphet
- SkewReshapingPass - Class in org.apache.nemo.compiler.optimizer.pass.compiletime.reshaping
-
Pass to reshape the IR DAG for skew handling.
- SkewReshapingPass() - Constructor for class org.apache.nemo.compiler.optimizer.pass.compiletime.reshaping.SkewReshapingPass
-
Default constructor.
- SkewRunTimePass - Class in org.apache.nemo.compiler.optimizer.pass.runtime
-
Dynamic optimization pass for handling data skew.
- SkewRunTimePass() - Constructor for class org.apache.nemo.compiler.optimizer.pass.runtime.SkewRunTimePass
- SkewRunTimePass(int) - Constructor for class org.apache.nemo.compiler.optimizer.pass.runtime.SkewRunTimePass
- SourceVertex<O> - Class in org.apache.nemo.common.ir.vertex
-
IRVertex that reads data from an external source.
- SourceVertex() - Constructor for class org.apache.nemo.common.ir.vertex.SourceVertex
-
Constructor for SourceVertex.
- SourceVertex(SourceVertex) - Constructor for class org.apache.nemo.common.ir.vertex.SourceVertex
-
Copy Constructor for SourceVertex.
- SparkBroadcastVariables - Class in org.apache.nemo.compiler.frontend.spark
-
Broadcast variables of Spark.
- SparkKeyExtractor - Class in org.apache.nemo.compiler.frontend.spark
-
Extracts the key from a KV element.
- SparkKeyExtractor() - Constructor for class org.apache.nemo.compiler.frontend.spark.SparkKeyExtractor
- SQLITE_DB_NAME - Static variable in class org.apache.nemo.runtime.common.metric.MetricUtils
- SRCTASKINDEX_FIELD_NUMBER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeInitMessage
- SRCTASKINDEX_FIELD_NUMBER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptor
- SRCTASKINDEX_FIELD_NUMBER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestPipeLocationMessage
- Stage - Class in org.apache.nemo.runtime.common.plan
-
Stage.
- Stage(String, List<Integer>, DAG<IRVertex, RuntimeEdge<IRVertex>>, ExecutionPropertyMap<VertexExecutionProperty>, List<Map<String, Readable>>) - Constructor for class org.apache.nemo.runtime.common.plan.Stage
-
Constructor.
- StageEdge - Class in org.apache.nemo.runtime.common.plan
-
Edge of a stage that connects an IRVertex of the source stage to an IRVertex of the destination stage.
- StageEdge(String, ExecutionPropertyMap<EdgeExecutionProperty>, IRVertex, IRVertex, Stage, Stage) - Constructor for class org.apache.nemo.runtime.common.plan.StageEdge
-
Constructor.
- StageMetric - Class in org.apache.nemo.runtime.common.metric
-
Metric class for
Stage
. - StageMetric(String) - Constructor for class org.apache.nemo.runtime.common.metric.StageMetric
- StageMetric(Stage) - Constructor for class org.apache.nemo.runtime.common.metric.StageMetric
- StageMetricServlet - Class in org.apache.nemo.runtime.master.servlet
-
Servlet which handles
StageMetric
metric request. - StageMetricServlet() - Constructor for class org.apache.nemo.runtime.master.servlet.StageMetricServlet
- StagePartitioner - Class in org.apache.nemo.runtime.common.plan
-
A function that is responsible for stage partitioning on IR DAG.
- StagePartitioner() - Constructor for class org.apache.nemo.runtime.common.plan.StagePartitioner
- stagePartitionIrDAG(IRDAG) - Method in class org.apache.nemo.runtime.common.plan.PhysicalPlanGenerator
-
We take the stage-partitioned DAG and create actual stage and stage edge objects to create a DAG of stages.
- StageState - Class in org.apache.nemo.runtime.common.state
-
Represents the states and their transitions of a stage.
- StageState() - Constructor for class org.apache.nemo.runtime.common.state.StageState
- StageState.State - Enum in org.apache.nemo.runtime.common.state
-
StageState.
- StartHandler() - Constructor for class org.apache.nemo.driver.NemoDriver.StartHandler
- STATE_FIELD_NUMBER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsg
- STATE_FIELD_NUMBER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsg
- STATE_FIELD_NUMBER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg
- stateInternalsForKey(K) - Method in class org.apache.nemo.compiler.frontend.beam.transform.InMemoryStateInternalsFactory
- StateMachine - Class in org.apache.nemo.common
-
A finite state machine that can be created with user defined states and transitions.
- StateMachine.Builder - Class in org.apache.nemo.common
-
Builder that builds a StateMachine.
- StateMetric<T extends java.io.Serializable> - Interface in org.apache.nemo.runtime.common.metric
-
Interface for metric which contians its state.
- StateTransitionEvent<T extends java.io.Serializable> - Class in org.apache.nemo.runtime.common.metric
-
Event of state transition.
- StateTransitionEvent(long, T, T) - Constructor for class org.apache.nemo.runtime.common.metric.StateTransitionEvent
- StateTranslator - Interface in org.apache.nemo.client
-
A class provides the translation between the state of plan and corresponding
ClientEndpoint
. - storeJSON(String) - Method in class org.apache.nemo.runtime.master.PlanStateManager
-
Stores JSON representation of plan state into a file.
- storeJSON(String, String, String) - Method in class org.apache.nemo.common.dag.DAG
- storeJSON(String, String, String) - Method in interface org.apache.nemo.common.dag.DAGInterface
-
Stores JSON representation of this DAG into a file.
- storeJSON(String, String, String) - Method in class org.apache.nemo.common.ir.IRDAG
- stream() - Method in class org.apache.nemo.common.ir.executionproperty.ExecutionPropertyMap
- STREAM_METRIC_PERIOD - Static variable in class org.apache.nemo.conf.JobConf
- StreamingPolicy - Class in org.apache.nemo.compiler.optimizer.policy
-
Streaming policy.
- StreamingPolicy() - Constructor for class org.apache.nemo.compiler.optimizer.policy.StreamingPolicy
-
Default constructor.
- StreamingScheduler - Class in org.apache.nemo.runtime.master.scheduler
-
A simple scheduler for streaming workloads.
- StreamMetric - Class in org.apache.nemo.runtime.common.metric
-
Metrics associated with stream.
- StreamMetric(long, long, long, long, boolean) - Constructor for class org.apache.nemo.runtime.common.metric.StreamMetric
- StreamMetricPeriod() - Constructor for class org.apache.nemo.conf.JobConf.StreamMetricPeriod
- StreamTransform<T> - Class in org.apache.nemo.common.ir.vertex.transform
-
A
Transform
relays input data from upstream vertex to downstream vertex promptly. - StreamTransform() - Constructor for class org.apache.nemo.common.ir.vertex.transform.StreamTransform
-
Default constructor.
- stringifyIRDAGProperties(IRDAG) - Static method in class org.apache.nemo.runtime.common.metric.MetricUtils
-
Stringify execution properties of an IR DAG.
- stringifyIREdgeIds(Collection<IREdge>) - Static method in class org.apache.nemo.common.Util
- stringifyIRVertexIds(Collection<IRVertex>) - Static method in class org.apache.nemo.common.Util
- stringToIdAndEPKeyIndex(String) - Static method in class org.apache.nemo.compiler.optimizer.OptimizerUtils
-
Restore the formatted string into a pair of vertex/edge id and the execution property.
- SubPartitionSetProperty - Class in org.apache.nemo.common.ir.edge.executionproperty
-
This property decides the hash partition set of sampled and optimized tasks in Dynamic Task Sizing Policy.
- SubPartitionSetProperty(ArrayList<KeyRange>) - Constructor for class org.apache.nemo.common.ir.edge.executionproperty.SubPartitionSetProperty
-
Default constructor.
T
- take() - Method in class org.apache.nemo.runtime.executor.transfer.ClosableBlockingQueue
-
Retrieves and removes the head of this queue, waiting if necessary.
- Task - Class in org.apache.nemo.runtime.common.plan
-
A Task (attempt) is a self-contained executable that can be executed on a machine.
- Task(String, String, ExecutionPropertyMap<VertexExecutionProperty>, byte[], List<StageEdge>, List<StageEdge>, Map<String, Readable>) - Constructor for class org.apache.nemo.runtime.common.plan.Task
-
Constructor.
- TASK_FIELD_NUMBER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.ScheduleTaskMsg
- TaskExecutor - Class in org.apache.nemo.runtime.executor.task
-
Executes a task.
- TaskExecutor(Task, DAG<IRVertex, RuntimeEdge<IRVertex>>, TaskStateManager, IntermediateDataIOFactory, BroadcastManagerWorker, MetricMessageSender, PersistentConnectionToMasterMap, int) - Constructor for class org.apache.nemo.runtime.executor.task.TaskExecutor
-
Constructor.
- TASKID_FIELD_NUMBER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsg
- TASKID_FIELD_NUMBER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg
- TaskMetric - Class in org.apache.nemo.runtime.common.metric
-
Metric class for
Task
. - TaskMetric(String) - Constructor for class org.apache.nemo.runtime.common.metric.TaskMetric
- TaskMetricServlet - Class in org.apache.nemo.runtime.master.servlet
-
Servlet which handles
TaskMetric
metric request. - TaskMetricServlet() - Constructor for class org.apache.nemo.runtime.master.servlet.TaskMetricServlet
- TaskSizeSplitterVertex - Class in org.apache.nemo.common.ir.vertex.utility
-
This vertex works as a partition-based sampling vertex of dynamic task sizing pass.
- TaskSizeSplitterVertex(String, Set<IRVertex>, Set<IRVertex>, Set<IRVertex>, Set<IRVertex>, Set<IREdge>, int) - Constructor for class org.apache.nemo.common.ir.vertex.utility.TaskSizeSplitterVertex
-
Default constructor of TaskSizeSplitterVertex.
- TaskState - Class in org.apache.nemo.runtime.common.state
-
Represents the states and their transitions of a task.
- TaskState() - Constructor for class org.apache.nemo.runtime.common.state.TaskState
- TaskState.RecoverableTaskFailureCause - Enum in org.apache.nemo.runtime.common.state
-
Causes of a recoverable failure.
- TaskState.State - Enum in org.apache.nemo.runtime.common.state
-
TaskState.
- TaskStateChanged - org.apache.nemo.runtime.common.comm.ControlMessage.MessageType
-
TaskStateChanged = 0;
- TaskStateChanged_VALUE - Static variable in enum org.apache.nemo.runtime.common.comm.ControlMessage.MessageType
-
TaskStateChanged = 0;
- TASKSTATECHANGEDMSG_FIELD_NUMBER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
- TaskStateManager - Class in org.apache.nemo.runtime.executor
-
Manages the states related to a task.
- TaskStateManager(Task, String, PersistentConnectionToMasterMap, MetricMessageSender) - Constructor for class org.apache.nemo.runtime.executor.TaskStateManager
- tearDown() - Method in class org.apache.nemo.examples.beam.MultinomialLogisticRegression.CalculateGradient
-
Teardown, since this logic at the moment should be executed exactly once after consuming the final data element.
- terminate() - Method in class org.apache.nemo.runtime.executor.Executor
- terminate() - Method in class org.apache.nemo.runtime.master.metric.MetricManagerMaster
- terminate() - Method in interface org.apache.nemo.runtime.master.metric.MetricMessageHandler
-
Cleans up and terminates this handler.
- terminate() - Method in class org.apache.nemo.runtime.master.resource.ContainerManager
- terminate() - Method in class org.apache.nemo.runtime.master.RuntimeMaster
-
Terminates the RuntimeMaster.
- terminate() - Method in class org.apache.nemo.runtime.master.scheduler.BatchScheduler
- terminate() - Method in interface org.apache.nemo.runtime.master.scheduler.Scheduler
-
To be called when a job should be terminated.
- terminate() - Method in class org.apache.nemo.runtime.master.scheduler.SimulationScheduler
- terminate() - Method in class org.apache.nemo.runtime.master.scheduler.StreamingScheduler
- terminationConditionEquals(LoopVertex) - Method in class org.apache.nemo.common.ir.vertex.LoopVertex
-
Check termination condition.
- TestPlanGenerator - Class in org.apache.nemo.runtime.common.plan
-
Generates physical plans for testing purposes.
- TestPlanGenerator.PlanType - Enum in org.apache.nemo.runtime.common.plan
-
Type of the plan to generate.
- TestPolicy - Class in org.apache.nemo.compiler.optimizer.policy
-
A policy for tests.
- TestPolicy() - Constructor for class org.apache.nemo.compiler.optimizer.policy.TestPolicy
- TestPolicy(boolean) - Constructor for class org.apache.nemo.compiler.optimizer.policy.TestPolicy
- testSchedulability(ExecutorRepresenter, Task) - Method in class org.apache.nemo.runtime.master.scheduler.AntiAffinitySchedulingConstraint
- testSchedulability(ExecutorRepresenter, Task) - Method in class org.apache.nemo.runtime.master.scheduler.ContainerTypeAwareSchedulingConstraint
- testSchedulability(ExecutorRepresenter, Task) - Method in class org.apache.nemo.runtime.master.scheduler.FreeSlotSchedulingConstraint
- testSchedulability(ExecutorRepresenter, Task) - Method in class org.apache.nemo.runtime.master.scheduler.LocalitySchedulingConstraint
- testSchedulability(ExecutorRepresenter, Task) - Method in class org.apache.nemo.runtime.master.scheduler.NodeShareSchedulingConstraint
- testSchedulability(ExecutorRepresenter, Task) - Method in interface org.apache.nemo.runtime.master.scheduler.SchedulingConstraint
- ThreeSequentialVertices - org.apache.nemo.runtime.common.plan.TestPlanGenerator.PlanType
- ThreeSequentialVerticesWithDifferentContainerTypes - org.apache.nemo.runtime.common.plan.TestPlanGenerator.PlanType
- TIMEOUT - Static variable in class org.apache.nemo.common.test.ExampleTestArgs
- timerInternalsForKey(K) - Method in class org.apache.nemo.compiler.frontend.beam.transform.InMemoryTimerInternalsFactory
- toBuilder() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsg
- toBuilder() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsg
- toBuilder() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptor
- toBuilder() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage
- toBuilder() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessage
- toBuilder() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ContainerFailedMsg
- toBuilder() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DataCollectMessage
- toBuilder() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessage
- toBuilder() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ExecutorFailedMsg
- toBuilder() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.InMasterBroadcastVariableMessage
- toBuilder() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.LaunchDAGMessage
- toBuilder() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
- toBuilder() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Metric
- toBuilder() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.MetricMsg
- toBuilder() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.NotificationMessage
- toBuilder() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeInitMessage
- toBuilder() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeLocationInfoMessage
- toBuilder() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptor
- toBuilder() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBlockLocationMsg
- toBuilder() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBroadcastVariableMessage
- toBuilder() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestPipeLocationMessage
- toBuilder() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageEntry
- toBuilder() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsg
- toBuilder() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ScheduleTaskMsg
- toBuilder() - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg
- toBuilder() - Method in class org.apache.nemo.runtime.common.comm.GrpcMessageService.Void
- TOKENIZER_PATTERN - Static variable in class org.apache.nemo.examples.beam.BeamWordCount
- topologicalDo(Consumer<IRVertex>) - Method in class org.apache.nemo.common.ir.IRDAG
- topologicalDo(Consumer<V>) - Method in class org.apache.nemo.common.dag.DAG
- topologicalDo(Consumer<V>) - Method in interface org.apache.nemo.common.dag.DAGInterface
-
Applies the function to each node in the DAG in a topological order.
- toString() - Method in class org.apache.nemo.common.coder.BytesDecoderFactory
- toString() - Method in class org.apache.nemo.common.coder.BytesEncoderFactory
- toString() - Method in class org.apache.nemo.common.coder.DecoderFactory.DummyDecoderFactory
- toString() - Method in class org.apache.nemo.common.coder.EncoderFactory.DummyEncoderFactory
- toString() - Method in class org.apache.nemo.common.coder.IntDecoderFactory
- toString() - Method in class org.apache.nemo.common.coder.IntEncoderFactory
- toString() - Method in class org.apache.nemo.common.coder.LongDecoderFactory
- toString() - Method in class org.apache.nemo.common.coder.LongEncoderFactory
- toString() - Method in class org.apache.nemo.common.coder.PairDecoderFactory
- toString() - Method in class org.apache.nemo.common.coder.PairEncoderFactory
- toString() - Method in class org.apache.nemo.common.dag.DAG
- toString() - Method in class org.apache.nemo.common.HashRange
-
This method should be overridden for a readable representation of KeyRange.
- toString() - Method in class org.apache.nemo.common.ir.edge.executionproperty.DuplicateEdgeGroupPropertyValue
- toString() - Method in class org.apache.nemo.common.ir.executionproperty.ExecutionProperty
- toString() - Method in class org.apache.nemo.common.ir.executionproperty.ExecutionPropertyMap
- toString() - Method in class org.apache.nemo.common.ir.IRDAG
- toString() - Method in class org.apache.nemo.common.ir.vertex.executionproperty.ClonedSchedulingProperty.CloneConf
- toString() - Method in class org.apache.nemo.common.ir.vertex.transform.MessageAggregatorTransform
- toString() - Method in class org.apache.nemo.common.ir.vertex.transform.MessageGeneratorTransform
- toString() - Method in class org.apache.nemo.common.ir.vertex.transform.SignalTransform
- toString() - Method in class org.apache.nemo.common.ir.vertex.transform.StreamTransform
- toString() - Method in class org.apache.nemo.common.ir.vertex.utility.SamplingVertex
- toString() - Method in interface org.apache.nemo.common.KeyRange
-
This method should be overridden for a readable representation of KeyRange.
- toString() - Method in class org.apache.nemo.common.Pair
- toString() - Method in class org.apache.nemo.common.punctuation.LatencyMark
- toString() - Method in class org.apache.nemo.common.punctuation.Watermark
- toString() - Method in class org.apache.nemo.common.StateMachine
- toString() - Method in class org.apache.nemo.common.test.EmptyComponents.EmptySourceVertex
- toString() - Method in class org.apache.nemo.common.test.EmptyComponents.EmptyTransform
- toString() - Method in class org.apache.nemo.compiler.frontend.beam.coder.BeamDecoderFactory
- toString() - Method in class org.apache.nemo.compiler.frontend.beam.coder.BeamEncoderFactory
- toString() - Method in class org.apache.nemo.compiler.frontend.beam.transform.AbstractDoFnTransform
- toString() - Method in class org.apache.nemo.compiler.frontend.beam.transform.CombineFnFinalTransform
- toString() - Method in class org.apache.nemo.compiler.frontend.beam.transform.CombineFnPartialTransform
- toString() - Method in class org.apache.nemo.compiler.frontend.beam.transform.CreateViewTransform
- toString() - Method in class org.apache.nemo.compiler.frontend.beam.transform.FlattenTransform
- toString() - Method in class org.apache.nemo.compiler.frontend.beam.transform.InMemoryStateInternalsFactory
- toString() - Method in class org.apache.nemo.compiler.frontend.beam.transform.InMemoryTimerInternalsFactory
- toString() - Method in class org.apache.nemo.compiler.frontend.beam.transform.SideInputTransform
- toString() - Method in class org.apache.nemo.compiler.frontend.beam.transform.WindowFnTransform
- toString() - Method in class org.apache.nemo.runtime.common.plan.PhysicalPlan
- toString() - Method in class org.apache.nemo.runtime.common.plan.StageEdge
- toString() - Method in class org.apache.nemo.runtime.common.plan.Task
- toString() - Method in class org.apache.nemo.runtime.common.state.BlockState
- toString() - Method in class org.apache.nemo.runtime.common.state.PlanState
- toString() - Method in class org.apache.nemo.runtime.common.state.StageState
- toString() - Method in class org.apache.nemo.runtime.common.state.TaskState
- toString() - Method in class org.apache.nemo.runtime.executor.data.metadata.PartitionMetadata
- toString() - Method in class org.apache.nemo.runtime.executor.datatransfer.NemoEventDecoderFactory
- toString() - Method in class org.apache.nemo.runtime.executor.datatransfer.NemoEventEncoderFactory
- toString() - Method in class org.apache.nemo.runtime.executor.datatransfer.WatermarkWithIndex
- toString() - Method in class org.apache.nemo.runtime.executor.transfer.ByteTransferContext
- toString() - Method in class org.apache.nemo.runtime.master.PlanStateManager
- toString() - Method in class org.apache.nemo.runtime.master.resource.DefaultExecutorRepresenter
- toString() - Method in class org.apache.nemo.runtime.master.scheduler.ExecutorRegistry
- trackAndEmitWatermarks(int, Watermark) - Method in interface org.apache.nemo.runtime.executor.datatransfer.InputWatermarkManager
-
This tracks the minimum input watermark among multiple input streams.
- trackAndEmitWatermarks(int, Watermark) - Method in class org.apache.nemo.runtime.executor.datatransfer.MultiInputWatermarkManager
- trackAndEmitWatermarks(int, Watermark) - Method in class org.apache.nemo.runtime.executor.datatransfer.SingleInputWatermarkManager
-
This just forwards watermarks to the next operator because it has one data stream.
- TrainingDataCombiner() - Constructor for class org.apache.nemo.examples.beam.AlternatingLeastSquare.TrainingDataCombiner
- TRANSFERINDEX_FIELD_NUMBER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage
- TransferOutputStream - Interface in org.apache.nemo.runtime.executor.transfer
-
Represents the output stream to which the sender sends its data during the data transfer.
- Transform<I,O> - Interface in org.apache.nemo.common.ir.vertex.transform
-
Interface for specifying 'What' to do with data.
- Transform.Context - Interface in org.apache.nemo.common.ir.vertex.transform
-
Context of the transform.
- TransformContextImpl - Class in org.apache.nemo.runtime.executor
-
Transform Context Implementation.
- TransformContextImpl(BroadcastManagerWorker) - Constructor for class org.apache.nemo.runtime.executor.TransformContextImpl
-
Constructor of Context Implementation.
- TRANSIENT - Static variable in class org.apache.nemo.common.ir.vertex.executionproperty.ResourcePriorityProperty
- TransientResourceCompositePass - Class in org.apache.nemo.compiler.optimizer.pass.compiletime.composite
-
A series of passes to harness transient resources.
- TransientResourceCompositePass() - Constructor for class org.apache.nemo.compiler.optimizer.pass.compiletime.composite.TransientResourceCompositePass
-
Default constructor.
- TransientResourceDataTransferPass - Class in org.apache.nemo.compiler.optimizer.pass.compiletime.annotating
-
Optimizes IREdges between transient resources and reserved resources.
- TransientResourceDataTransferPass() - Constructor for class org.apache.nemo.compiler.optimizer.pass.compiletime.annotating.TransientResourceDataTransferPass
-
Default constructor.
- TransientResourcePolicy - Class in org.apache.nemo.compiler.optimizer.policy
-
A policy to perform optimization that uses transient resources in data centers.
- TransientResourcePolicy() - Constructor for class org.apache.nemo.compiler.optimizer.policy.TransientResourcePolicy
-
Default constructor.
- TransientResourcePriorityPass - Class in org.apache.nemo.compiler.optimizer.pass.compiletime.annotating
-
Place valuable computations on reserved resources, and the rest on transient resources.
- TransientResourcePriorityPass() - Constructor for class org.apache.nemo.compiler.optimizer.pass.compiletime.annotating.TransientResourcePriorityPass
-
Default constructor.
- translateState(PlanState.State) - Method in class org.apache.nemo.client.beam.BeamStateTranslator
-
Translate a job state of nemo to a corresponding Beam state.
- translateState(PlanState.State) - Method in interface org.apache.nemo.client.StateTranslator
-
Translate a plan state of nemo to a corresponding client endpoint state.
- triggerBroadcast(Class<T>, String) - Method in class org.apache.nemo.runtime.master.metric.MetricStore
-
Send changed metric data to
MetricBroadcaster
, which will broadcast it to all active WebSocket sessions. - TwoVerticesJoined - org.apache.nemo.runtime.common.plan.TestPlanGenerator.PlanType
- TYPE_FIELD_NUMBER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessage
- TYPE_FIELD_NUMBER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessage
- TYPE_FIELD_NUMBER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
U
- UngroupSingleVectorList() - Constructor for class org.apache.nemo.examples.beam.AlternatingLeastSquare.UngroupSingleVectorList
- UnknownExecutionStateException - Exception in org.apache.nemo.common.exception
-
UnknownExecutionStateException.
- UnknownExecutionStateException(Throwable) - Constructor for exception org.apache.nemo.common.exception.UnknownExecutionStateException
-
UnknownExecutionStateException.
- UnknownFailureCauseException - Exception in org.apache.nemo.common.exception
-
UnknownFailureCauseException.
- UnknownFailureCauseException(Throwable) - Constructor for exception org.apache.nemo.common.exception.UnknownFailureCauseException
-
UnknownFailureCauseException.
- UnrecoverableFailureException - Exception in org.apache.nemo.common.exception
-
UnrecoverableFailureException.
- UnrecoverableFailureException(Throwable) - Constructor for exception org.apache.nemo.common.exception.UnrecoverableFailureException
-
UnrecoverableFailureException.
- unRollIteration(DAGBuilder<IRVertex, IREdge>) - Method in class org.apache.nemo.common.ir.vertex.LoopVertex
-
Method for unrolling an iteration of the LoopVertex.
- unRollIteration(DAGBuilder<IRVertex, IREdge>) - Method in class org.apache.nemo.common.ir.vertex.utility.TaskSizeSplitterVertex
-
Need to be careful about Signal Vertex, because they do not appear in the last iteration.
- UNSAFE - Static variable in class org.apache.nemo.runtime.executor.data.MemoryChunk
- UnsupportedBlockStoreException - Exception in org.apache.nemo.common.exception
-
UnsupportedBlockStoreException.
- UnsupportedBlockStoreException(Throwable) - Constructor for exception org.apache.nemo.common.exception.UnsupportedBlockStoreException
-
UnsupportedBlockStoreException.
- UnsupportedCommPatternException - Exception in org.apache.nemo.common.exception
-
UnsupportedCommPatternException.
- UnsupportedCommPatternException(Throwable) - Constructor for exception org.apache.nemo.common.exception.UnsupportedCommPatternException
-
UnsupportedCommPatternException.
- UnsupportedCompressionException - Exception in org.apache.nemo.common.exception
-
UnsupportedCompressionException Thrown when the compression method is not supported.
- UnsupportedCompressionException(String) - Constructor for exception org.apache.nemo.common.exception.UnsupportedCompressionException
-
Constructor.
- UnsupportedExecutionPropertyException - Exception in org.apache.nemo.common.exception
-
UnsupportedExecutionPropertyException.
- UnsupportedExecutionPropertyException(String) - Constructor for exception org.apache.nemo.common.exception.UnsupportedExecutionPropertyException
-
UnsupportedExecutionPropertyException.
- UnsupportedMethodException - Exception in org.apache.nemo.common.exception
-
UnsupportedMethodException.
- UnsupportedMethodException(String) - Constructor for exception org.apache.nemo.common.exception.UnsupportedMethodException
-
UnsupportedMethodException.
- UnsupportedMetricException - Exception in org.apache.nemo.common.exception
-
UnsupportedMetricException.
- UnsupportedMetricException(Throwable) - Constructor for exception org.apache.nemo.common.exception.UnsupportedMetricException
-
UnsupportedMetricException.
- UnsupportedPartitionerException - Exception in org.apache.nemo.common.exception
-
UnsupportedPartitionerException.
- UnsupportedPartitionerException(Throwable) - Constructor for exception org.apache.nemo.common.exception.UnsupportedPartitionerException
-
UnsupportedPartitionerException.
- unwindowedFilename(int, int, FileBasedSink.OutputFileHints) - Method in class org.apache.nemo.examples.beam.WriteOneFilePerWindow.PerWindowFiles
- update(MutableAggregationBuffer, Row) - Method in class org.apache.nemo.examples.spark.sql.JavaUserDefinedUntypedAggregation.MyAverage
-
Updates the given aggregation buffer `buffer` with new input data from `input`.
- updatePlan(PhysicalPlan) - Method in class org.apache.nemo.runtime.master.scheduler.BatchScheduler
- updatePlan(PhysicalPlan) - Method in interface org.apache.nemo.runtime.master.scheduler.Scheduler
-
Receives and updates the scheduler with a new physical plan for a job.
- updatePlan(PhysicalPlan) - Method in class org.apache.nemo.runtime.master.scheduler.SimulationScheduler
- updatePlan(PhysicalPlan) - Method in class org.apache.nemo.runtime.master.scheduler.StreamingScheduler
- updatePlan(PhysicalPlan, int) - Method in class org.apache.nemo.runtime.master.PlanStateManager
-
Update the physical plan and maximum attempt.
- UpfrontCloningPass - Class in org.apache.nemo.compiler.optimizer.pass.compiletime.annotating
-
Set the ClonedScheduling property of source vertices, in an upfront manner.
- UpfrontCloningPass() - Constructor for class org.apache.nemo.compiler.optimizer.pass.compiletime.annotating.UpfrontCloningPass
-
Default constructor.
- UserApplicationRunner - Class in org.apache.nemo.driver
-
Compiles and runs User application.
- UserMainArguments() - Constructor for class org.apache.nemo.conf.JobConf.UserMainArguments
- UserMainClass() - Constructor for class org.apache.nemo.conf.JobConf.UserMainClass
- Util - Class in org.apache.nemo.common
-
Class to hold the utility methods.
V
- value() - Method in annotation type org.apache.nemo.common.ir.executionproperty.AssociatedProperty
- value() - Method in annotation type org.apache.nemo.compiler.optimizer.pass.compiletime.annotating.Annotates
- value() - Method in annotation type org.apache.nemo.compiler.optimizer.pass.compiletime.Requires
- VALUE_FIELD_NUMBER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageEntry
- ValueComparator() - Constructor for class org.apache.nemo.examples.beam.EDGARTop10BadRefererDocs.ValueComparator
- ValueComparator() - Constructor for class org.apache.nemo.examples.beam.EDGARTop10Documents.ValueComparator
- valueOf(int) - Static method in enum org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateFromExecutor
-
Deprecated.
- valueOf(int) - Static method in enum org.apache.nemo.runtime.common.comm.ControlMessage.BlockStore
-
Deprecated.
- valueOf(int) - Static method in enum org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferDataDirection
-
Deprecated.
- valueOf(int) - Static method in enum org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessageType
-
Deprecated.
- valueOf(int) - Static method in enum org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessageType
-
Deprecated.
- valueOf(int) - Static method in enum org.apache.nemo.runtime.common.comm.ControlMessage.MessageType
-
Deprecated.
- valueOf(int) - Static method in enum org.apache.nemo.runtime.common.comm.ControlMessage.OptimizationType
-
Deprecated.
- valueOf(int) - Static method in enum org.apache.nemo.runtime.common.comm.ControlMessage.RecoverableFailureCause
-
Deprecated.
- valueOf(int) - Static method in enum org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateFromExecutor
-
Deprecated.
- valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateFromExecutor
-
Returns the enum constant of this type with the specified name.
- valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.nemo.runtime.common.comm.ControlMessage.BlockStore
-
Returns the enum constant of this type with the specified name.
- valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferDataDirection
-
Returns the enum constant of this type with the specified name.
- valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessageType
-
Returns the enum constant of this type with the specified name.
- valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessageType
-
Returns the enum constant of this type with the specified name.
- valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.nemo.runtime.common.comm.ControlMessage.MessageType
-
Returns the enum constant of this type with the specified name.
- valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.nemo.runtime.common.comm.ControlMessage.OptimizationType
-
Returns the enum constant of this type with the specified name.
- valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.nemo.runtime.common.comm.ControlMessage.RecoverableFailureCause
-
Returns the enum constant of this type with the specified name.
- valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateFromExecutor
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.nemo.common.dag.DAGInterface.TraversalOrder
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.nemo.common.ir.edge.executionproperty.BlockFetchFailureProperty.Value
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.nemo.common.ir.edge.executionproperty.CommunicationPatternProperty.Value
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.nemo.common.ir.edge.executionproperty.CompressionProperty.Value
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.nemo.common.ir.edge.executionproperty.DataFlowProperty.Value
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.nemo.common.ir.edge.executionproperty.DataPersistenceProperty.Value
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.nemo.common.ir.edge.executionproperty.DataStoreProperty.Value
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.nemo.common.ir.edge.executionproperty.PartitionerProperty.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.nemo.common.ir.vertex.executionproperty.ResourceLambdaProperty.Value
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateFromExecutor
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.nemo.runtime.common.comm.ControlMessage.BlockStore
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferDataDirection
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessageType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessageType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.nemo.runtime.common.comm.ControlMessage.MessageType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.nemo.runtime.common.comm.ControlMessage.OptimizationType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.nemo.runtime.common.comm.ControlMessage.RecoverableFailureCause
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateFromExecutor
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.nemo.runtime.common.metric.DataTransferEvent.TransferType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.nemo.runtime.common.plan.TestPlanGenerator.PlanType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.nemo.runtime.common.state.BlockState.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.nemo.runtime.common.state.PlanState.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.nemo.runtime.common.state.StageState.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.nemo.runtime.common.state.TaskState.RecoverableTaskFailureCause
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.nemo.runtime.common.state.TaskState.State
-
Returns the enum constant of this type with the specified name.
- values() - Static method in enum org.apache.nemo.common.dag.DAGInterface.TraversalOrder
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.nemo.common.ir.edge.executionproperty.BlockFetchFailureProperty.Value
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.nemo.common.ir.edge.executionproperty.CommunicationPatternProperty.Value
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.nemo.common.ir.edge.executionproperty.CompressionProperty.Value
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.nemo.common.ir.edge.executionproperty.DataFlowProperty.Value
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.nemo.common.ir.edge.executionproperty.DataPersistenceProperty.Value
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.nemo.common.ir.edge.executionproperty.DataStoreProperty.Value
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.nemo.common.ir.edge.executionproperty.PartitionerProperty.Type
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.nemo.common.ir.vertex.executionproperty.ResourceLambdaProperty.Value
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateFromExecutor
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.nemo.runtime.common.comm.ControlMessage.BlockStore
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferDataDirection
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessageType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessageType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.nemo.runtime.common.comm.ControlMessage.MessageType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.nemo.runtime.common.comm.ControlMessage.OptimizationType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.nemo.runtime.common.comm.ControlMessage.RecoverableFailureCause
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateFromExecutor
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.nemo.runtime.common.metric.DataTransferEvent.TransferType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.nemo.runtime.common.plan.TestPlanGenerator.PlanType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.nemo.runtime.common.state.BlockState.State
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.nemo.runtime.common.state.PlanState.State
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.nemo.runtime.common.state.StageState.State
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.nemo.runtime.common.state.TaskState.RecoverableTaskFailureCause
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.nemo.runtime.common.state.TaskState.State
-
Returns an array containing the constants of this enum type, in the order they are declared.
- VARIABLE_FIELD_NUMBER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.InMasterBroadcastVariableMessage
- verifyDeterministic() - Method in class org.apache.nemo.compiler.frontend.beam.coder.SideInputCoder
- Vertex - Class in org.apache.nemo.common.dag
-
A vertex in DAG.
- Vertex(String) - Constructor for class org.apache.nemo.common.dag.Vertex
- VertexExecutionProperty<T extends java.io.Serializable> - Class in org.apache.nemo.common.ir.executionproperty
- VertexExecutionProperty(T) - Constructor for class org.apache.nemo.common.ir.executionproperty.VertexExecutionProperty
-
Default constructor.
- VERTEXPUTONHOLDID_FIELD_NUMBER - Static variable in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg
- viewExecutors(Consumer<Set<ExecutorRepresenter>>) - Method in class org.apache.nemo.runtime.master.scheduler.ExecutorRegistry
- visitPrimitiveTransform(TransformHierarchy.Node) - Method in class org.apache.nemo.compiler.frontend.beam.PipelineVisitor
W
- waitUntilFinish() - Method in class org.apache.nemo.client.beam.NemoPipelineResult
- waitUntilFinish() - Method in class org.apache.nemo.runtime.master.PlanStateManager
-
Wait for this plan to be finished and return the final state.
- waitUntilFinish(long, TimeUnit) - Method in class org.apache.nemo.runtime.master.PlanStateManager
-
Wait for this plan to be finished and return the final state.
- waitUntilFinish(Duration) - Method in class org.apache.nemo.client.beam.NemoPipelineResult
- waitUntilJobFinish() - Method in class org.apache.nemo.client.ClientEndpoint
-
Wait for this job to be finished and return the final state.
- waitUntilJobFinish(long, TimeUnit) - Method in class org.apache.nemo.client.ClientEndpoint
-
Wait for this job to be finished (complete or failed) and return the final state.
- Watermark - Class in org.apache.nemo.common.punctuation
-
Watermark event.
- Watermark(long) - Constructor for class org.apache.nemo.common.punctuation.Watermark
- WatermarkWithIndex - Class in org.apache.nemo.runtime.executor.datatransfer
-
This contains a watermark and the src task index.
- WatermarkWithIndex(Watermark, int) - Constructor for class org.apache.nemo.runtime.executor.datatransfer.WatermarkWithIndex
- WebSocketMetricAdapter - Class in org.apache.nemo.runtime.master.servlet
-
Adapter for WebSocket metric request and response.
- WebSocketMetricAdapter() - Constructor for class org.apache.nemo.runtime.master.servlet.WebSocketMetricAdapter
- WebSocketMetricServlet - Class in org.apache.nemo.runtime.master.servlet
-
Servlet which handles WebSocket HTTP request.
- WebSocketMetricServlet() - Constructor for class org.apache.nemo.runtime.master.servlet.WebSocketMetricServlet
- WindowedBroadcast - Class in org.apache.nemo.examples.beam
-
A Windowed WordCount application.
- windowedFilename(int, int, BoundedWindow, PaneInfo, FileBasedSink.OutputFileHints) - Method in class org.apache.nemo.examples.beam.WriteOneFilePerWindow.PerWindowFiles
- WindowedWordCount - Class in org.apache.nemo.examples.beam
-
A Windowed WordCount application.
- WindowFnTransform<T,W extends org.apache.beam.sdk.transforms.windowing.BoundedWindow> - Class in org.apache.nemo.compiler.frontend.beam.transform
-
Windowing transform implementation.
- WindowFnTransform(WindowFn, DisplayData) - Constructor for class org.apache.nemo.compiler.frontend.beam.transform.WindowFnTransform
-
Default Constructor.
- WordCount - Class in org.apache.nemo.examples.beam
-
WordCount application.
- WordCountTimeOut1Sec - Class in org.apache.nemo.examples.beam
-
WordCount application, but with a timeout of 1 second.
- wrapDoFn(DoFn) - Method in class org.apache.nemo.compiler.frontend.beam.transform.DoFnTransform
- wrapDoFn(DoFn) - Method in class org.apache.nemo.compiler.frontend.beam.transform.GBKTransform
-
This creates a new DoFn that groups elements by key and window.
- wrapDoFn(DoFn) - Method in class org.apache.nemo.compiler.frontend.beam.transform.PushBackDoFnTransform
- write(byte[]) - Method in class org.apache.nemo.runtime.executor.data.DirectByteBufferOutputStream
-
Writes
b.length
bytes from the specified byte array to this output stream. - write(byte[], int, int) - Method in class org.apache.nemo.runtime.executor.data.DirectByteBufferOutputStream
-
Writes
len
bytes from the specified byte array starting at offsetoff
to this output stream. - write(int) - Method in class org.apache.nemo.runtime.executor.data.DirectByteBufferOutputStream
-
Writes the specified byte to this output stream.
- write(Object) - Method in class org.apache.nemo.runtime.executor.data.partition.NonSerializedPartition
-
Writes an element to non-committed partition.
- write(Object) - Method in interface org.apache.nemo.runtime.executor.data.partition.Partition
-
Writes an element to non-committed partition.
- write(Object) - Method in class org.apache.nemo.runtime.executor.data.partition.SerializedPartition
-
Writes an element to non-committed partition.
- write(Object) - Method in class org.apache.nemo.runtime.executor.datatransfer.BlockOutputWriter
- write(Object) - Method in interface org.apache.nemo.runtime.executor.datatransfer.OutputWriter
-
Writes output element depending on the communication pattern of the edge.
- write(Object) - Method in class org.apache.nemo.runtime.executor.datatransfer.PipeOutputWriter
-
Writes output element.
- write(K, Object) - Method in interface org.apache.nemo.runtime.executor.data.block.Block
-
Writes an element to non-committed block.
- write(K, Object) - Method in class org.apache.nemo.runtime.executor.data.block.FileBlock
-
Writes an element to non-committed block.
- write(K, Object) - Method in class org.apache.nemo.runtime.executor.data.block.NonSerializedMemoryBlock
-
Writes an element to non-committed block.
- write(K, Object) - Method in class org.apache.nemo.runtime.executor.data.block.SerializedMemoryBlock
-
Writes an element to non-committed block.
- WRITE_END - org.apache.nemo.runtime.common.metric.DataTransferEvent.TransferType
- WRITE_START - org.apache.nemo.runtime.common.metric.DataTransferEvent.TransferType
- writeBlock(Block) - Method in interface org.apache.nemo.runtime.executor.data.stores.BlockStore
-
Writes a committed block to this store.
- writeBlock(Block) - Method in class org.apache.nemo.runtime.executor.data.stores.GlusterFileStore
-
Writes a committed block to this store.
- writeBlock(Block) - Method in class org.apache.nemo.runtime.executor.data.stores.LocalFileStore
-
Writes a committed block to this store.
- writeBlock(Block) - Method in class org.apache.nemo.runtime.executor.data.stores.MemoryStore
-
Writes a committed block to this store.
- writeBlock(Block) - Method in class org.apache.nemo.runtime.executor.data.stores.SerializedMemoryStore
-
Writes a committed block to this store.
- writeBlock(Block, DataStoreProperty.Value, int, DataPersistenceProperty.Value) - Method in class org.apache.nemo.runtime.executor.data.BlockManagerWorker
-
Writes a block to a store.
- writeElement(Object, Serializer) - Method in class org.apache.nemo.runtime.executor.transfer.ByteOutputContext.ByteOutputStream
-
Write an element to the channel.
- writeElement(Object, Serializer) - Method in interface org.apache.nemo.runtime.executor.transfer.TransferOutputStream
-
Write an element into the output stream.
- writeFileArea(FileArea) - Method in class org.apache.nemo.runtime.executor.transfer.ByteOutputContext.ByteOutputStream
-
Writes a data frame from
FileArea
. - writeLatencymark(LatencyMark) - Method in class org.apache.nemo.runtime.executor.datatransfer.BlockOutputWriter
- writeLatencymark(LatencyMark) - Method in interface org.apache.nemo.runtime.executor.datatransfer.OutputWriter
-
Writes latencymark to all edges.
- writeLatencymark(LatencyMark) - Method in class org.apache.nemo.runtime.executor.datatransfer.PipeOutputWriter
- WriteOneFilePerWindow - Class in org.apache.nemo.examples.beam
-
This class is brought from beam/examples/common/WriteOneFilePerWindow.java.
- WriteOneFilePerWindow(String, Integer) - Constructor for class org.apache.nemo.examples.beam.WriteOneFilePerWindow
-
Constructor.
- WriteOneFilePerWindow.PerWindowFiles - Class in org.apache.nemo.examples.beam
-
A
FileBasedSink.FilenamePolicy
produces a base file name for a write based on metadata about the data being written. - writePartitionMetadata(K, int) - Method in class org.apache.nemo.runtime.executor.data.metadata.FileMetadata
-
Writes the metadata for a partition.
- writePartitions(Iterable<NonSerializedPartition<K>>) - Method in interface org.apache.nemo.runtime.executor.data.block.Block
-
Stores
NonSerializedPartition
s to this block. - writePartitions(Iterable<NonSerializedPartition<K>>) - Method in class org.apache.nemo.runtime.executor.data.block.FileBlock
-
Writes
NonSerializedPartition
s to this block. - writePartitions(Iterable<NonSerializedPartition<K>>) - Method in class org.apache.nemo.runtime.executor.data.block.NonSerializedMemoryBlock
-
Stores
NonSerializedPartition
s to this block. - writePartitions(Iterable<NonSerializedPartition<K>>) - Method in class org.apache.nemo.runtime.executor.data.block.SerializedMemoryBlock
-
Serialized and stores
NonSerializedPartition
s to this block. - writeSerializedPartitionBuffer(SerializedPartition, boolean) - Method in class org.apache.nemo.runtime.executor.transfer.ByteOutputContext.ByteOutputStream
-
Writes
SerializedPartition
. - writeSerializedPartitions(Iterable<SerializedPartition<K>>) - Method in interface org.apache.nemo.runtime.executor.data.block.Block
-
Stores
SerializedPartition
s to this block. - writeSerializedPartitions(Iterable<SerializedPartition<K>>) - Method in class org.apache.nemo.runtime.executor.data.block.FileBlock
-
Writes
SerializedPartition
s to this block. - writeSerializedPartitions(Iterable<SerializedPartition<K>>) - Method in class org.apache.nemo.runtime.executor.data.block.NonSerializedMemoryBlock
-
Stores
SerializedPartition
s to this block. - writeSerializedPartitions(Iterable<SerializedPartition<K>>) - Method in class org.apache.nemo.runtime.executor.data.block.SerializedMemoryBlock
-
Stores
SerializedPartition
s to this block. - writeTo(CodedOutputStream) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockLocationInfoMsg
- writeTo(CodedOutputStream) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockStateChangedMsg
- writeTo(CodedOutputStream) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.BlockTransferContextDescriptor
- writeTo(CodedOutputStream) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ByteTransferContextSetupMessage
- writeTo(CodedOutputStream) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ClientToDriverMessage
- writeTo(CodedOutputStream) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ContainerFailedMsg
- writeTo(CodedOutputStream) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DataCollectMessage
- writeTo(CodedOutputStream) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.DriverToClientMessage
- writeTo(CodedOutputStream) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ExecutorFailedMsg
- writeTo(CodedOutputStream) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.InMasterBroadcastVariableMessage
- writeTo(CodedOutputStream) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.LaunchDAGMessage
- writeTo(CodedOutputStream) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Message
- writeTo(CodedOutputStream) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.Metric
- writeTo(CodedOutputStream) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.MetricMsg
- writeTo(CodedOutputStream) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.NotificationMessage
- writeTo(CodedOutputStream) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeInitMessage
- writeTo(CodedOutputStream) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeLocationInfoMessage
- writeTo(CodedOutputStream) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.PipeTransferContextDescriptor
- writeTo(CodedOutputStream) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBlockLocationMsg
- writeTo(CodedOutputStream) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestBroadcastVariableMessage
- writeTo(CodedOutputStream) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RequestPipeLocationMessage
- writeTo(CodedOutputStream) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageEntry
- writeTo(CodedOutputStream) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.RunTimePassMessageMsg
- writeTo(CodedOutputStream) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.ScheduleTaskMsg
- writeTo(CodedOutputStream) - Method in class org.apache.nemo.runtime.common.comm.ControlMessage.TaskStateChangedMsg
- writeTo(CodedOutputStream) - Method in class org.apache.nemo.runtime.common.comm.GrpcMessageService.Void
- writeWatermark(Watermark) - Method in class org.apache.nemo.runtime.executor.datatransfer.BlockOutputWriter
- writeWatermark(Watermark) - Method in interface org.apache.nemo.runtime.executor.datatransfer.OutputWriter
-
Writes watermarks to all edges.
- writeWatermark(Watermark) - Method in class org.apache.nemo.runtime.executor.datatransfer.PipeOutputWriter
X
- XGBoost - org.apache.nemo.runtime.common.comm.ControlMessage.OptimizationType
-
XGBoost = 0;
- XGBoost_VALUE - Static variable in enum org.apache.nemo.runtime.common.comm.ControlMessage.OptimizationType
-
XGBoost = 0;
- XGBoostPass - Class in org.apache.nemo.compiler.optimizer.pass.compiletime.annotating
-
Pass for applying XGBoost optimizations.
- XGBoostPass() - Constructor for class org.apache.nemo.compiler.optimizer.pass.compiletime.annotating.XGBoostPass
-
Default constructor.
- XGBoostPolicy - Class in org.apache.nemo.compiler.optimizer.policy
-
A policy that enforces values retrieved by an optimization by XGBoost.
- XGBoostPolicy() - Constructor for class org.apache.nemo.compiler.optimizer.policy.XGBoostPolicy
-
Default constructor.
Z
- zero() - Method in class org.apache.nemo.examples.spark.sql.JavaUserDefinedTypedAggregation.MyAverage
-
A zero value for this aggregation.
All Classes All Packages