Uses of Class
org.apache.nemo.common.ir.vertex.IRVertex
-
-
Uses of IRVertex in org.apache.nemo.common
Methods in org.apache.nemo.common with parameters of type IRVertex Modifier and Type Method Description static IREdge
Util. cloneEdge(CommunicationPatternProperty.Value commPattern, IREdge edgeToClone, IRVertex newSrc, IRVertex newDst)
Creates a new edge with several execution properties same as the given edge.static IREdge
Util. cloneEdge(IREdge edgeToClone, IRVertex newSrc, IRVertex newDst)
static IREdge
Util. createControlEdge(IRVertex src, IRVertex dst)
A control edge enforces an execution ordering between the source vertex and the destination vertex.static boolean
Util. isUtilityVertex(IRVertex v)
Method parameters in org.apache.nemo.common with type arguments of type IRVertex Modifier and Type Method Description static java.lang.String
Util. stringifyIRVertexIds(java.util.Collection<IRVertex> vertices)
-
Uses of IRVertex in org.apache.nemo.common.ir
Methods in org.apache.nemo.common.ir that return IRVertex Modifier and Type Method Description IRVertex
IRDAG. getVertexById(java.lang.String id)
Methods in org.apache.nemo.common.ir that return types with arguments of type IRVertex Modifier and Type Method Description java.util.List<IRVertex>
IRDAG. filterVertices(java.util.function.Predicate<IRVertex> condition)
java.util.List<IRVertex>
IRDAG. getAncestors(java.lang.String vertexId)
java.util.List<IRVertex>
IRDAG. getChildren(java.lang.String vertexId)
java.util.List<IRVertex>
IRDAG. getDescendants(java.lang.String vertexId)
java.util.List<IRVertex>
IRDAG. getParents(java.lang.String vertexId)
java.util.List<IRVertex>
IRDAG. getRootVertices()
java.util.List<IRVertex>
IRDAG. getTopologicalSort()
java.util.List<IRVertex>
IRDAG. getVertices()
Methods in org.apache.nemo.common.ir with parameters of type IRVertex Modifier and Type Method Description void
IRDAG. delete(IRVertex vertexToDelete)
Deletes a previously inserted utility vertex.void
IRDAG. dfsDo(IRVertex vertex, java.util.function.Consumer<IRVertex> vertexConsumer, DAGInterface.TraversalOrder traversalOrder, java.util.Set<IRVertex> visited)
LoopVertex
IRDAG. getAssignedLoopVertexOf(IRVertex irVertex)
java.util.List<IREdge>
IRDAG. getIncomingEdgesOf(IRVertex v)
java.lang.Integer
IRDAG. getLoopStackDepthOf(IRVertex irVertex)
java.util.List<IREdge>
IRDAG. getOutgoingEdgesOf(IRVertex v)
java.lang.Boolean
IRDAG. isCompositeVertex(IRVertex irVertex)
java.lang.Boolean
IRDAG. pathExistsBetween(IRVertex v1, IRVertex v2)
Method parameters in org.apache.nemo.common.ir with type arguments of type IRVertex Modifier and Type Method Description IRDAGChecker.CheckerResult
IRDAGChecker.GlobalDAGChecker. check(DAG<IRVertex,IREdge> irdag)
void
IRDAG. dfsDo(IRVertex vertex, java.util.function.Consumer<IRVertex> vertexConsumer, DAGInterface.TraversalOrder traversalOrder, java.util.Set<IRVertex> visited)
void
IRDAG. dfsDo(IRVertex vertex, java.util.function.Consumer<IRVertex> vertexConsumer, DAGInterface.TraversalOrder traversalOrder, java.util.Set<IRVertex> visited)
void
IRDAG. dfsTraverse(java.util.function.Consumer<IRVertex> function, DAGInterface.TraversalOrder traversalOrder)
IRDAGChecker.CheckerResult
IRDAGChecker. doCheck(DAG<IRVertex,IREdge> underlyingDAG)
Applies all of the checkers on the DAG.java.util.List<IRVertex>
IRDAG. filterVertices(java.util.function.Predicate<IRVertex> condition)
void
IRDAG. reshapeUnsafely(java.util.function.Function<DAG<IRVertex,IREdge>,DAG<IRVertex,IREdge>> unsafeReshapingFunction)
Reshape unsafely, without guarantees on preserving application semantics.void
IRDAG. reshapeUnsafely(java.util.function.Function<DAG<IRVertex,IREdge>,DAG<IRVertex,IREdge>> unsafeReshapingFunction)
Reshape unsafely, without guarantees on preserving application semantics.void
IRDAG. topologicalDo(java.util.function.Consumer<IRVertex> function)
Constructor parameters in org.apache.nemo.common.ir with type arguments of type IRVertex Constructor Description IRDAG(DAG<IRVertex,IREdge> originalUserApplicationDAG)
-
Uses of IRVertex in org.apache.nemo.common.ir.edge
Constructors in org.apache.nemo.common.ir.edge with parameters of type IRVertex Constructor Description IREdge(CommunicationPatternProperty.Value commPattern, IRVertex src, IRVertex dst)
Constructor of IREdge. -
Uses of IRVertex in org.apache.nemo.common.ir.executionproperty
Methods in org.apache.nemo.common.ir.executionproperty with parameters of type IRVertex Modifier and Type Method Description static ExecutionPropertyMap<VertexExecutionProperty>
ExecutionPropertyMap. of(IRVertex irVertex)
Static initializer for irVertex. -
Uses of IRVertex in org.apache.nemo.common.ir.vertex
Subclasses of IRVertex in org.apache.nemo.common.ir.vertex Modifier and Type Class Description class
CachedSourceVertex<T>
Bounded source vertex for cached data.class
InMemorySourceVertex<T>
Source vertex with the data in memory.class
LoopVertex
IRVertex that contains a partial DAG that is iterative.class
OperatorVertex
IRVertex that transforms input data.class
SourceVertex<O>
IRVertex that reads data from an external source.Methods in org.apache.nemo.common.ir.vertex that return IRVertex Modifier and Type Method Description IRVertex
IRVertex. setProperty(VertexExecutionProperty<?> executionProperty)
Set an executionProperty of the IRVertex.IRVertex
IRVertex. setPropertyPermanently(VertexExecutionProperty<?> executionProperty)
Set an executionProperty of the IRVertex, permanently.Methods in org.apache.nemo.common.ir.vertex that return types with arguments of type IRVertex Modifier and Type Method Description DAGBuilder<IRVertex,IREdge>
LoopVertex. getBuilder()
DAG<IRVertex,IREdge>
LoopVertex. getDAG()
java.util.Map<IRVertex,java.util.Set<IREdge>>
LoopVertex. getDagIncomingEdges()
java.util.Map<IRVertex,java.util.Set<IREdge>>
LoopVertex. getDagOutgoingEdges()
java.util.Map<IRVertex,java.util.Set<IREdge>>
LoopVertex. getIterativeIncomingEdges()
java.util.Map<IRVertex,java.util.Set<IREdge>>
LoopVertex. getNonIterativeIncomingEdges()
Methods in org.apache.nemo.common.ir.vertex with parameters of type IRVertex Modifier and Type Method Description void
IRVertex. copyExecutionPropertiesTo(IRVertex thatVertex)
Static function to copy executionProperties from a vertex to the other.Method parameters in org.apache.nemo.common.ir.vertex with type arguments of type IRVertex Modifier and Type Method Description LoopVertex
LoopVertex. unRollIteration(DAGBuilder<IRVertex,IREdge> dagBuilder)
Method for unrolling an iteration of the LoopVertex.Constructors in org.apache.nemo.common.ir.vertex with parameters of type IRVertex Constructor Description IRVertex(IRVertex that)
Copy Constructor for IRVertex. -
Uses of IRVertex in org.apache.nemo.common.ir.vertex.utility
Subclasses of IRVertex in org.apache.nemo.common.ir.vertex.utility Modifier and Type Class Description class
RelayVertex
Relays input data from upstream vertex to downstream vertex promptly.class
SamplingVertex
Executes the original IRVertex using a subset of input data partitions.class
TaskSizeSplitterVertex
This vertex works as a partition-based sampling vertex of dynamic task sizing pass.Methods in org.apache.nemo.common.ir.vertex.utility that return IRVertex Modifier and Type Method Description IRVertex
SamplingVertex. getClone()
IRVertex
SamplingVertex. getCloneOfOriginalVertex()
Methods in org.apache.nemo.common.ir.vertex.utility that return types with arguments of type IRVertex Modifier and Type Method Description java.util.Set<IRVertex>
TaskSizeSplitterVertex. getGroupEndingVertices()
java.util.Set<IRVertex>
TaskSizeSplitterVertex. getGroupStartingVertices()
java.util.Set<IRVertex>
TaskSizeSplitterVertex. getOriginalVertices()
java.util.Set<IRVertex>
TaskSizeSplitterVertex. getVerticesWithGroupOutgoingEdges()
Method parameters in org.apache.nemo.common.ir.vertex.utility with type arguments of type IRVertex Modifier and Type Method Description java.util.Set<IREdge>
TaskSizeSplitterVertex. getEdgesFromOriginalToOutside(DAG<IRVertex,IREdge> dag)
Get edges which come from original vertices to outer destinations by observing the dag.java.util.Set<IREdge>
TaskSizeSplitterVertex. getEdgesFromOutsideToOriginal(DAG<IRVertex,IREdge> dag)
Get edges which come to original vertices from outer sources by observing the dag.java.util.Set<IREdge>
TaskSizeSplitterVertex. getEdgesFromOutsideToSplitter(DAG<IRVertex,IREdge> dag)
Get edges which come to splitter from outside sources.java.util.Set<IREdge>
TaskSizeSplitterVertex. getEdgesFromSplitterToOutside(DAG<IRVertex,IREdge> dag)
Get edges which come out from splitter to outside destinations.TaskSizeSplitterVertex
TaskSizeSplitterVertex. unRollIteration(DAGBuilder<IRVertex,IREdge> dagBuilder)
Need to be careful about Signal Vertex, because they do not appear in the last iteration.Constructors in org.apache.nemo.common.ir.vertex.utility with parameters of type IRVertex Constructor Description SamplingVertex(IRVertex originalVertex, float desiredSampleRate)
Constructor parameters in org.apache.nemo.common.ir.vertex.utility with type arguments of type IRVertex Constructor Description TaskSizeSplitterVertex(java.lang.String splitterVertexName, java.util.Set<IRVertex> originalVertices, java.util.Set<IRVertex> groupStartingVertices, java.util.Set<IRVertex> verticesWithGroupOutgoingEdges, java.util.Set<IRVertex> groupEndingVertices, java.util.Set<IREdge> edgesBetweenOriginalVertices, int partitionerProperty)
Default constructor of TaskSizeSplitterVertex. -
Uses of IRVertex in org.apache.nemo.common.ir.vertex.utility.runtimepass
Subclasses of IRVertex in org.apache.nemo.common.ir.vertex.utility.runtimepass Modifier and Type Class Description class
MessageAggregatorVertex<K,V,O>
Aggregates upstream messages.class
MessageGeneratorVertex<I,K,V>
Produces a message for run-time pass.class
SignalVertex
Signal vertex holding signal transform. -
Uses of IRVertex in org.apache.nemo.common.test
Subclasses of IRVertex in org.apache.nemo.common.test Modifier and Type Class Description static class
EmptyComponents.EmptySourceVertex<T>
An empty Source Vertex.Methods in org.apache.nemo.common.test with parameters of type IRVertex Modifier and Type Method Description static IREdge
EmptyComponents. newDummyShuffleEdge(IRVertex src, IRVertex dst)
-
Uses of IRVertex in org.apache.nemo.compiler.frontend.beam.source
Subclasses of IRVertex in org.apache.nemo.compiler.frontend.beam.source Modifier and Type Class Description class
BeamBoundedSourceVertex<O>
SourceVertex implementation for BoundedSource.class
BeamUnboundedSourceVertex<O,M extends org.apache.beam.sdk.io.UnboundedSource.CheckpointMark>
SourceVertex implementation for UnboundedSource.Methods in org.apache.nemo.compiler.frontend.beam.source that return IRVertex Modifier and Type Method Description IRVertex
BeamUnboundedSourceVertex. getClone()
-
Uses of IRVertex in org.apache.nemo.runtime.common.plan
Methods in org.apache.nemo.runtime.common.plan that return IRVertex Modifier and Type Method Description IRVertex
StageEdge. getDstIRVertex()
IRVertex
StageEdge. getSrcIRVertex()
Methods in org.apache.nemo.runtime.common.plan that return types with arguments of type IRVertex Modifier and Type Method Description java.util.Map<IRVertex,java.lang.Integer>
StagePartitioner. apply(IRDAG irDAG)
java.util.Map<java.lang.String,IRVertex>
PhysicalPlan. getIdToIRVertex()
DAG<IRVertex,RuntimeEdge<IRVertex>>
Stage. getIRDAG()
DAG<IRVertex,RuntimeEdge<IRVertex>>
Stage. getIRDAG()
Methods in org.apache.nemo.runtime.common.plan with parameters of type IRVertex Modifier and Type Method Description java.util.Set<VertexExecutionProperty>
StagePartitioner. getStageProperties(IRVertex vertex)
Constructors in org.apache.nemo.runtime.common.plan with parameters of type IRVertex Constructor Description StageEdge(java.lang.String runtimeEdgeId, ExecutionPropertyMap<EdgeExecutionProperty> edgeProperties, IRVertex srcVertex, IRVertex dstVertex, Stage srcStage, Stage dstStage)
Constructor.Constructor parameters in org.apache.nemo.runtime.common.plan with type arguments of type IRVertex Constructor Description Stage(java.lang.String stageId, java.util.List<java.lang.Integer> taskIndices, DAG<IRVertex,RuntimeEdge<IRVertex>> irDag, ExecutionPropertyMap<VertexExecutionProperty> executionProperties, java.util.List<java.util.Map<java.lang.String,Readable>> vertexIdToReadables)
Constructor.Stage(java.lang.String stageId, java.util.List<java.lang.Integer> taskIndices, DAG<IRVertex,RuntimeEdge<IRVertex>> irDag, ExecutionPropertyMap<VertexExecutionProperty> executionProperties, java.util.List<java.util.Map<java.lang.String,Readable>> vertexIdToReadables)
Constructor. -
Uses of IRVertex in org.apache.nemo.runtime.executor.datatransfer
Methods in org.apache.nemo.runtime.executor.datatransfer that return IRVertex Modifier and Type Method Description IRVertex
BlockInputReader. getSrcIrVertex()
IRVertex
InputReader. getSrcIrVertex()
IRVertex
PipeInputReader. getSrcIrVertex()
Methods in org.apache.nemo.runtime.executor.datatransfer with parameters of type IRVertex Modifier and Type Method Description InputReader
IntermediateDataIOFactory. createReader(java.lang.String dstTaskId, IRVertex srcIRVertex, RuntimeEdge runtimeEdge)
Creates anInputReader
between two stages.Constructors in org.apache.nemo.runtime.executor.datatransfer with parameters of type IRVertex Constructor Description OperatorVertexOutputCollector(IRVertex irVertex, java.util.List<NextIntraTaskOperatorInfo> internalMainOutputs, java.util.Map<java.lang.String,java.util.List<NextIntraTaskOperatorInfo>> internalAdditionalOutputs, java.util.List<OutputWriter> externalMainOutputs, java.util.Map<java.lang.String,java.util.List<OutputWriter>> externalAdditionalOutputs)
Constructor of the output collector.RunTimeMessageOutputCollector(java.lang.String taskId, IRVertex irVertex, PersistentConnectionToMasterMap connectionToMasterMap, TaskExecutor taskExecutor, boolean dataTransferNeeded)
-
Uses of IRVertex in org.apache.nemo.runtime.executor.task
Methods in org.apache.nemo.runtime.executor.task with parameters of type IRVertex Modifier and Type Method Description void
TaskExecutor. setIRVertexPutOnHold(IRVertex irVertex)
Constructor parameters in org.apache.nemo.runtime.executor.task with type arguments of type IRVertex Constructor Description TaskExecutor(Task task, DAG<IRVertex,RuntimeEdge<IRVertex>> irVertexDag, TaskStateManager taskStateManager, IntermediateDataIOFactory intermediateDataIOFactory, BroadcastManagerWorker broadcastManagerWorker, MetricMessageSender metricMessageSender, PersistentConnectionToMasterMap persistentConnectionToMasterMap, int latencyMarkPeriod)
Constructor.TaskExecutor(Task task, DAG<IRVertex,RuntimeEdge<IRVertex>> irVertexDag, TaskStateManager taskStateManager, IntermediateDataIOFactory intermediateDataIOFactory, BroadcastManagerWorker broadcastManagerWorker, MetricMessageSender metricMessageSender, PersistentConnectionToMasterMap persistentConnectionToMasterMap, int latencyMarkPeriod)
Constructor.
-