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
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.