Modifier and Type | Field and Description |
---|---|
static String |
ITERATION_SINK_NAME_PREFIX |
static String |
ITERATION_SOURCE_NAME_PREFIX |
protected Map<Integer,String> |
vertexIDtoBrokerID |
protected Map<Integer,Long> |
vertexIDtoLoopTimeout |
Constructor and Description |
---|
StreamGraph(Configuration jobConfiguration,
ExecutionConfig executionConfig,
CheckpointConfig checkpointConfig,
SavepointRestoreSettings savepointRestoreSettings) |
public static final String ITERATION_SOURCE_NAME_PREFIX
public static final String ITERATION_SINK_NAME_PREFIX
public StreamGraph(Configuration jobConfiguration, ExecutionConfig executionConfig, CheckpointConfig checkpointConfig, SavepointRestoreSettings savepointRestoreSettings)
public void clear()
public ExecutionConfig getExecutionConfig()
public Configuration getJobConfiguration()
public CheckpointConfig getCheckpointConfig()
public void setSavepointRestoreSettings(SavepointRestoreSettings savepointRestoreSettings)
public SavepointRestoreSettings getSavepointRestoreSettings()
public String getJobName()
public void setJobName(String jobName)
public void setStateBackend(StateBackend backend)
public StateBackend getStateBackend()
public void setCheckpointStorage(CheckpointStorage checkpointStorage)
public CheckpointStorage getCheckpointStorage()
public InternalTimeServiceManager.Provider getTimerServiceProvider()
public void setTimerServiceProvider(InternalTimeServiceManager.Provider timerServiceProvider)
public Collection<Tuple2<String,DistributedCache.DistributedCacheEntry>> getUserArtifacts()
public TimeCharacteristic getTimeCharacteristic()
public void setTimeCharacteristic(TimeCharacteristic timeCharacteristic)
public GlobalStreamExchangeMode getGlobalStreamExchangeMode()
public void setGlobalStreamExchangeMode(GlobalStreamExchangeMode globalExchangeMode)
public void setSlotSharingGroupResource(Map<String,ResourceProfile> slotSharingGroupResources)
public Optional<ResourceProfile> getSlotSharingGroupResource(String groupId)
public boolean hasFineGrainedResource()
public void setAllVerticesInSameSlotSharingGroupByDefault(boolean allVerticesInSameSlotSharingGroupByDefault)
allVerticesInSameSlotSharingGroupByDefault
- indicates whether to put all vertices into
the same slot sharing group by default.public boolean isAllVerticesInSameSlotSharingGroupByDefault()
public boolean isEnableCheckpointsAfterTasksFinish()
public void setEnableCheckpointsAfterTasksFinish(boolean enableCheckpointsAfterTasksFinish)
public boolean isChainingEnabled()
public boolean isChainingOfOperatorsWithDifferentMaxParallelismEnabled()
public boolean isIterative()
public <IN,OUT> void addSource(Integer vertexID, @Nullable String slotSharingGroup, @Nullable String coLocationGroup, SourceOperatorFactory<OUT> operatorFactory, TypeInformation<IN> inTypeInfo, TypeInformation<OUT> outTypeInfo, String operatorName)
public <IN,OUT> void addLegacySource(Integer vertexID, @Nullable String slotSharingGroup, @Nullable String coLocationGroup, StreamOperatorFactory<OUT> operatorFactory, TypeInformation<IN> inTypeInfo, TypeInformation<OUT> outTypeInfo, String operatorName)
public <IN,OUT> void addSink(Integer vertexID, @Nullable String slotSharingGroup, @Nullable String coLocationGroup, StreamOperatorFactory<OUT> operatorFactory, TypeInformation<IN> inTypeInfo, TypeInformation<OUT> outTypeInfo, String operatorName)
public <IN,OUT> void addOperator(Integer vertexID, @Nullable String slotSharingGroup, @Nullable String coLocationGroup, StreamOperatorFactory<OUT> operatorFactory, TypeInformation<IN> inTypeInfo, TypeInformation<OUT> outTypeInfo, String operatorName)
public <IN1,IN2,OUT> void addCoOperator(Integer vertexID, String slotSharingGroup, @Nullable String coLocationGroup, StreamOperatorFactory<OUT> taskOperatorFactory, TypeInformation<IN1> in1TypeInfo, TypeInformation<IN2> in2TypeInfo, TypeInformation<OUT> outTypeInfo, String operatorName)
public <OUT> void addMultipleInputOperator(Integer vertexID, String slotSharingGroup, @Nullable String coLocationGroup, StreamOperatorFactory<OUT> operatorFactory, List<TypeInformation<?>> inTypeInfos, TypeInformation<OUT> outTypeInfo, String operatorName)
protected StreamNode addNode(Integer vertexID, @Nullable String slotSharingGroup, @Nullable String coLocationGroup, Class<? extends TaskInvokable> vertexClass, @Nullable StreamOperatorFactory<?> operatorFactory, String operatorName)
public void addVirtualSideOutputNode(Integer originalId, Integer virtualId, OutputTag outputTag)
OutputTag
.originalId
- ID of the node that should be connected to.virtualId
- ID of the virtual node.outputTag
- The selected side-output OutputTag
.public void addVirtualPartitionNode(Integer originalId, Integer virtualId, StreamPartitioner<?> partitioner, StreamExchangeMode exchangeMode)
When adding an edge from the virtual node to a downstream node the connection will be made to the original node, but with the partitioning given here.
originalId
- ID of the node that should be connected to.virtualId
- ID of the virtual node.partitioner
- The partitionerpublic String getSlotSharingGroup(Integer id)
public void addEdge(Integer upStreamVertexID, Integer downStreamVertexID, int typeNumber, IntermediateDataSetID intermediateDataSetId)
public void setParallelism(Integer vertexID, int parallelism)
public boolean isDynamic()
public void setParallelism(Integer vertexId, int parallelism, boolean parallelismConfigured)
public void setDynamic(boolean dynamic)
public void setMaxParallelism(int vertexID, int maxParallelism)
public void setResources(int vertexID, ResourceSpec minResources, ResourceSpec preferredResources)
public void setManagedMemoryUseCaseWeights(int vertexID, Map<ManagedMemoryUseCase,Integer> operatorScopeUseCaseWeights, Set<ManagedMemoryUseCase> slotScopeUseCases)
public void setOneInputStateKey(Integer vertexID, KeySelector<?,?> keySelector, TypeSerializer<?> keySerializer)
public void setTwoInputStateKey(Integer vertexID, KeySelector<?,?> keySelector1, KeySelector<?,?> keySelector2, TypeSerializer<?> keySerializer)
public void setMultipleInputStateKey(Integer vertexID, List<KeySelector<?,?>> keySelectors, TypeSerializer<?> keySerializer)
public void setBufferTimeout(Integer vertexID, long bufferTimeout)
public void setSerializers(Integer vertexID, TypeSerializer<?> in1, TypeSerializer<?> in2, TypeSerializer<?> out)
public void setInputFormat(Integer vertexID, InputFormat<?,?> inputFormat)
public void setOutputFormat(Integer vertexID, OutputFormat<?> outputFormat)
public StreamNode getStreamNode(Integer vertexID)
protected Collection<? extends Integer> getVertexIDs()
@VisibleForTesting public List<StreamEdge> getStreamEdges(int sourceId)
@VisibleForTesting public List<StreamEdge> getStreamEdges(int sourceId, int targetId)
@VisibleForTesting @Deprecated public List<StreamEdge> getStreamEdgesOrThrow(int sourceId, int targetId)
public Collection<Integer> getSourceIDs()
public Collection<Integer> getSinkIDs()
public Collection<StreamNode> getStreamNodes()
public long getLoopTimeout(Integer vertexID)
public Tuple2<StreamNode,StreamNode> createIterationSourceAndSink(int loopId, int sourceId, int sinkId, long timeout, int parallelism, int maxParallelism, ResourceSpec minResources, ResourceSpec preferredResources)
public Set<Tuple2<StreamNode,StreamNode>> getIterationSourceSinkPairs()
public StreamNode getSourceVertex(StreamEdge edge)
public StreamNode getTargetVertex(StreamEdge edge)
@VisibleForTesting public JobGraph getJobGraph()
public JobGraph getJobGraph(ClassLoader userClassLoader, @Nullable JobID jobID)
public String getStreamingPlanAsJSON()
public void setJobType(JobType jobType)
public JobType getJobType()
public boolean isAutoParallelismEnabled()
public void setAutoParallelismEnabled(boolean autoParallelismEnabled)
public PipelineOptions.VertexDescriptionMode getVertexDescriptionMode()
public void setVertexDescriptionMode(PipelineOptions.VertexDescriptionMode mode)
public void setVertexNameIncludeIndexPrefix(boolean includePrefix)
public boolean isVertexNameIncludeIndexPrefix()
public void registerJobStatusHook(JobStatusHook hook)
public List<JobStatusHook> getJobStatusHooks()
public void setSupportsConcurrentExecutionAttempts(Integer vertexId, boolean supportsConcurrentExecutionAttempts)
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.