Uses of Class
org.apache.flink.runtime.jobgraph.IntermediateDataSetID
-
-
Uses of IntermediateDataSetID in org.apache.flink.runtime.deployment
Methods in org.apache.flink.runtime.deployment that return IntermediateDataSetID Modifier and Type Method Description IntermediateDataSetID
InputGateDeploymentDescriptor. getConsumedResultId()
IntermediateDataSetID
ResultPartitionDeploymentDescriptor. getResultId()
-
Uses of IntermediateDataSetID in org.apache.flink.runtime.executiongraph
Methods in org.apache.flink.runtime.executiongraph that return IntermediateDataSetID Modifier and Type Method Description IntermediateDataSetID
IntermediateResult. getId()
IntermediateDataSetID
PartitionInfo. getIntermediateDataSetID()
IntermediateDataSetID
IntermediateResultInfo. getResultId()
Get the intermediate result id.Methods in org.apache.flink.runtime.executiongraph that return types with arguments of type IntermediateDataSetID Modifier and Type Method Description static Map<IntermediateDataSetID,JobVertexInputInfo>
VertexInputInfoComputationUtils. computeVertexInputInfos(int parallelism, List<? extends IntermediateResultInfo> inputs, boolean isDynamicGraph)
static Map<IntermediateDataSetID,JobVertexInputInfo>
VertexInputInfoComputationUtils. computeVertexInputInfos(ExecutionJobVertex ejv, Function<IntermediateDataSetID,IntermediateResult> intermediateResultRetriever)
Map<IntermediateDataSetID,IntermediateResult>
DefaultExecutionGraph. getAllIntermediateResults()
Map<IntermediateDataSetID,IntermediateResult>
ExecutionGraph. getAllIntermediateResults()
Map<IntermediateDataSetID,JobVertexInputInfo>
ParallelismAndInputInfos. getJobVertexInputInfos()
Methods in org.apache.flink.runtime.executiongraph with parameters of type IntermediateDataSetID Modifier and Type Method Description JobVertexInputInfo
VertexInputInfoStore. get(JobVertexID jobVertexId, IntermediateDataSetID resultId)
Get aJobVertexInputInfo
.List<ShuffleDescriptor>
DefaultExecutionGraph. getClusterPartitionShuffleDescriptors(IntermediateDataSetID intermediateDataSetID)
List<ShuffleDescriptor>
InternalExecutionGraphAccessor. getClusterPartitionShuffleDescriptors(IntermediateDataSetID intermediateResultPartition)
Get the shuffle descriptors of the cluster partitions ordered by partition number.ExecutionVertexInputInfo
ExecutionVertex. getExecutionVertexInputInfo(IntermediateDataSetID resultId)
JobVertexInputInfo
DefaultExecutionGraph. getJobVertexInputInfo(JobVertexID jobVertexId, IntermediateDataSetID resultId)
JobVertexInputInfo
InternalExecutionGraphAccessor. getJobVertexInputInfo(JobVertexID jobVertexId, IntermediateDataSetID resultId)
Get the input info of a certain input of a certain job vertex.void
VertexInputInfoStore. put(JobVertexID jobVertexId, IntermediateDataSetID resultId, JobVertexInputInfo info)
Put aJobVertexInputInfo
.Method parameters in org.apache.flink.runtime.executiongraph with type arguments of type IntermediateDataSetID Modifier and Type Method Description static Map<IntermediateDataSetID,JobVertexInputInfo>
VertexInputInfoComputationUtils. computeVertexInputInfos(ExecutionJobVertex ejv, Function<IntermediateDataSetID,IntermediateResult> intermediateResultRetriever)
void
ExecutionJobVertex. connectToPredecessors(Map<IntermediateDataSetID,IntermediateResult> intermediateDataSets)
void
DefaultExecutionGraph. initializeJobVertex(ExecutionJobVertex ejv, long createTimestamp, Map<IntermediateDataSetID,JobVertexInputInfo> jobVertexInputInfos)
void
ExecutionGraph. initializeJobVertex(ExecutionJobVertex ejv, long createTimestamp, Map<IntermediateDataSetID,JobVertexInputInfo> jobVertexInputInfos)
Initialize the given execution job vertex, mainly includes creating execution vertices according to the parallelism, and connecting to the predecessors.Constructors in org.apache.flink.runtime.executiongraph with parameters of type IntermediateDataSetID Constructor Description PartitionInfo(IntermediateDataSetID intermediateResultPartitionID, ShuffleDescriptor shuffleDescriptor)
Constructor parameters in org.apache.flink.runtime.executiongraph with type arguments of type IntermediateDataSetID Constructor Description ParallelismAndInputInfos(int parallelism, Map<IntermediateDataSetID,JobVertexInputInfo> jobVertexInputInfos)
-
Uses of IntermediateDataSetID in org.apache.flink.runtime.io.network.partition
Methods in org.apache.flink.runtime.io.network.partition that return IntermediateDataSetID Modifier and Type Method Description IntermediateDataSetID
TaskExecutorPartitionInfo. getIntermediateDataSetId()
Methods in org.apache.flink.runtime.io.network.partition that return types with arguments of type IntermediateDataSetID Modifier and Type Method Description CompletableFuture<Map<IntermediateDataSetID,DataSetMetaInfo>>
ClusterPartitionManager. listDataSets()
Returns all datasets for which partitions are being tracked.Map<IntermediateDataSetID,DataSetMetaInfo>
ResourceManagerPartitionTracker. listDataSets()
Returns all data sets for which partitions are being tracked.Map<IntermediateDataSetID,DataSetMetaInfo>
ResourceManagerPartitionTrackerImpl. listDataSets()
Methods in org.apache.flink.runtime.io.network.partition with parameters of type IntermediateDataSetID Modifier and Type Method Description List<ShuffleDescriptor>
JobMasterPartitionTracker. getClusterPartitionShuffleDescriptors(IntermediateDataSetID intermediateDataSetID)
Get the shuffle descriptors of the cluster partitions ordered by partition number.List<ShuffleDescriptor>
JobMasterPartitionTrackerImpl. getClusterPartitionShuffleDescriptors(IntermediateDataSetID intermediateDataSetID)
List<ShuffleDescriptor>
ResourceManagerPartitionTracker. getClusterPartitionShuffleDescriptors(IntermediateDataSetID dataSetID)
Returns all the shuffle descriptors of cluster partitions for the intermediate dataset.List<ShuffleDescriptor>
ResourceManagerPartitionTrackerImpl. getClusterPartitionShuffleDescriptors(IntermediateDataSetID dataSetID)
CompletableFuture<List<ShuffleDescriptor>>
ClusterPartitionManager. getClusterPartitionsShuffleDescriptors(IntermediateDataSetID intermediateDataSetID)
Get the shuffle descriptors of the cluster partitions ordered by partition number.CompletableFuture<Void>
ClusterPartitionManager. releaseClusterPartitions(IntermediateDataSetID dataSetToRelease)
Releases all partitions associated with the given dataset.CompletableFuture<Void>
ResourceManagerPartitionTracker. releaseClusterPartitions(IntermediateDataSetID dataSetId)
Issues a release calls to all task executors that are hosting partitions of the given data set.CompletableFuture<Void>
ResourceManagerPartitionTrackerImpl. releaseClusterPartitions(IntermediateDataSetID dataSetId)
void
PartitionProducerStateProvider. requestPartitionProducerState(IntermediateDataSetID intermediateDataSetId, ResultPartitionID resultPartitionId, Consumer<? super PartitionProducerStateProvider.ResponseHandle> responseConsumer)
Trigger the producer execution state request.Method parameters in org.apache.flink.runtime.io.network.partition with type arguments of type IntermediateDataSetID Modifier and Type Method Description void
TaskExecutorClusterPartitionReleaser. releaseClusterPartitions(ResourceID taskExecutorId, Set<IntermediateDataSetID> dataSetsToRelease)
void
TaskExecutorPartitionTracker. stopTrackingAndReleaseClusterPartitions(Collection<IntermediateDataSetID> dataSetsToRelease)
Releases partitions associated with the given datasets and stops tracking of partitions that were released.void
TaskExecutorPartitionTrackerImpl. stopTrackingAndReleaseClusterPartitions(Collection<IntermediateDataSetID> dataSetsToRelease)
Constructors in org.apache.flink.runtime.io.network.partition with parameters of type IntermediateDataSetID Constructor Description TaskExecutorPartitionInfo(ShuffleDescriptor shuffleDescriptor, IntermediateDataSetID intermediateDataSetId, int numberOfPartitions)
-
Uses of IntermediateDataSetID in org.apache.flink.runtime.io.network.partition.consumer
Methods in org.apache.flink.runtime.io.network.partition.consumer that return IntermediateDataSetID Modifier and Type Method Description IntermediateDataSetID
InputGateID. getConsumedResultID()
Constructors in org.apache.flink.runtime.io.network.partition.consumer with parameters of type IntermediateDataSetID Constructor Description InputGateID(IntermediateDataSetID consumedResultID, ExecutionAttemptID consumerID)
SingleInputGate(String owningTaskName, int gateIndex, IntermediateDataSetID consumedResultId, ResultPartitionType consumedPartitionType, int numberOfInputChannels, PartitionProducerStateProvider partitionProducerStateProvider, org.apache.flink.util.function.SupplierWithException<BufferPool,IOException> bufferPoolFactory, BufferDecompressor bufferDecompressor, org.apache.flink.core.memory.MemorySegmentProvider memorySegmentProvider, int segmentSize, ThroughputCalculator throughputCalculator, BufferDebloater bufferDebloater)
-
Uses of IntermediateDataSetID in org.apache.flink.runtime.io.network.partition.hybrid.tiered.common
Methods in org.apache.flink.runtime.io.network.partition.hybrid.tiered.common that return IntermediateDataSetID Modifier and Type Method Description static IntermediateDataSetID
TieredStorageIdMappingUtils. convertId(TieredStorageTopicId topicId)
Methods in org.apache.flink.runtime.io.network.partition.hybrid.tiered.common with parameters of type IntermediateDataSetID Modifier and Type Method Description static TieredStorageTopicId
TieredStorageIdMappingUtils. convertId(IntermediateDataSetID intermediateDataSetID)
-
Uses of IntermediateDataSetID in org.apache.flink.runtime.jobgraph
Methods in org.apache.flink.runtime.jobgraph that return IntermediateDataSetID Modifier and Type Method Description static IntermediateDataSetID
IntermediateDataSetID. fromByteBuf(org.apache.flink.shaded.netty4.io.netty.buffer.ByteBuf buf)
IntermediateDataSetID
IntermediateDataSet. getId()
IntermediateDataSetID
IntermediateResultPartitionID. getIntermediateDataSetID()
IntermediateDataSetID
JobEdge. getSourceId()
Gets the ID of the consumed data set.Methods in org.apache.flink.runtime.jobgraph that return types with arguments of type IntermediateDataSetID Modifier and Type Method Description List<IntermediateDataSetID>
JobVertex. getIntermediateDataSetIdsToConsume()
Methods in org.apache.flink.runtime.jobgraph with parameters of type IntermediateDataSetID Modifier and Type Method Description void
JobVertex. addIntermediateDataSetIdToConsume(IntermediateDataSetID intermediateDataSetId)
JobEdge
JobVertex. connectNewDataSetAsInput(JobVertex input, DistributionPattern distPattern, ResultPartitionType partitionType, IntermediateDataSetID intermediateDataSetId, boolean isBroadcast, boolean isForward)
JobEdge
JobVertex. connectNewDataSetAsInput(JobVertex input, DistributionPattern distPattern, ResultPartitionType partitionType, IntermediateDataSetID intermediateDataSetId, boolean isBroadcast, boolean isForward, int typeNumber, boolean interInputsKeysCorrelated, boolean intraInputKeyCorrelated)
IntermediateDataSet
JobVertex. getOrCreateResultDataSet(IntermediateDataSetID id, ResultPartitionType partitionType)
Constructors in org.apache.flink.runtime.jobgraph with parameters of type IntermediateDataSetID Constructor Description IntermediateDataSet(IntermediateDataSetID id, ResultPartitionType resultType, JobVertex producer)
IntermediateResultPartitionID(IntermediateDataSetID intermediateDataSetID, int partitionNum)
Creates an new intermediate result partition ID withIntermediateDataSetID
and the partitionNum. -
Uses of IntermediateDataSetID in org.apache.flink.runtime.jobgraph.topology
Methods in org.apache.flink.runtime.jobgraph.topology that return IntermediateDataSetID Modifier and Type Method Description IntermediateDataSetID
DefaultLogicalResult. getId()
-
Uses of IntermediateDataSetID in org.apache.flink.runtime.jobmaster
Methods in org.apache.flink.runtime.jobmaster with parameters of type IntermediateDataSetID Modifier and Type Method Description CompletableFuture<ExecutionState>
JobMaster. requestPartitionState(IntermediateDataSetID intermediateResultId, ResultPartitionID resultPartitionId)
CompletableFuture<ExecutionState>
JobMasterGateway. requestPartitionState(IntermediateDataSetID intermediateResultId, ResultPartitionID partitionId)
Requests the current state of the partition. -
Uses of IntermediateDataSetID in org.apache.flink.runtime.jobmaster.event
Methods in org.apache.flink.runtime.jobmaster.event that return types with arguments of type IntermediateDataSetID Modifier and Type Method Description Map<IntermediateDataSetID,JobVertexInputInfo>
ExecutionJobVertexInitializedEvent. getJobVertexInputInfos()
Map<IntermediateDataSetID,BlockingResultInfo>
ExecutionJobVertexFinishedEvent. getResultInfo()
Constructor parameters in org.apache.flink.runtime.jobmaster.event with type arguments of type IntermediateDataSetID Constructor Description ExecutionJobVertexFinishedEvent(JobVertexID vertexId, Map<IntermediateDataSetID,BlockingResultInfo> resultInfo)
ExecutionJobVertexInitializedEvent(JobVertexID jobVertexId, int parallelism, Map<IntermediateDataSetID,JobVertexInputInfo> jobVertexInputInfos)
-
Uses of IntermediateDataSetID in org.apache.flink.runtime.resourcemanager
Methods in org.apache.flink.runtime.resourcemanager that return types with arguments of type IntermediateDataSetID Modifier and Type Method Description CompletableFuture<Map<IntermediateDataSetID,DataSetMetaInfo>>
ResourceManager. listDataSets()
Methods in org.apache.flink.runtime.resourcemanager with parameters of type IntermediateDataSetID Modifier and Type Method Description CompletableFuture<List<ShuffleDescriptor>>
ResourceManager. getClusterPartitionsShuffleDescriptors(IntermediateDataSetID intermediateDataSetID)
CompletableFuture<Void>
ResourceManager. releaseClusterPartitions(IntermediateDataSetID dataSetId)
-
Uses of IntermediateDataSetID in org.apache.flink.runtime.rest.messages.dataset
Methods in org.apache.flink.runtime.rest.messages.dataset that return IntermediateDataSetID Modifier and Type Method Description protected IntermediateDataSetID
ClusterDataSetIdPathParameter. convertFromString(String value)
Methods in org.apache.flink.runtime.rest.messages.dataset with parameters of type IntermediateDataSetID Modifier and Type Method Description protected String
ClusterDataSetIdPathParameter. convertToString(IntermediateDataSetID value)
Method parameters in org.apache.flink.runtime.rest.messages.dataset with type arguments of type IntermediateDataSetID Modifier and Type Method Description static ClusterDataSetListResponseBody
ClusterDataSetListResponseBody. from(Map<IntermediateDataSetID,DataSetMetaInfo> dataSets)
-
Uses of IntermediateDataSetID in org.apache.flink.runtime.scheduler
Methods in org.apache.flink.runtime.scheduler that return types with arguments of type IntermediateDataSetID Modifier and Type Method Description List<IntermediateDataSetID>
ClusterDatasetCorruptedException. getCorruptedClusterDatasetIds()
Methods in org.apache.flink.runtime.scheduler with parameters of type IntermediateDataSetID Modifier and Type Method Description ExecutionState
ExecutionGraphHandler. requestPartitionState(IntermediateDataSetID intermediateResultId, ResultPartitionID resultPartitionId)
ExecutionState
SchedulerBase. requestPartitionState(IntermediateDataSetID intermediateResultId, ResultPartitionID resultPartitionId)
ExecutionState
SchedulerNG. requestPartitionState(IntermediateDataSetID intermediateResultId, ResultPartitionID resultPartitionId)
Constructor parameters in org.apache.flink.runtime.scheduler with type arguments of type IntermediateDataSetID Constructor Description ClusterDatasetCorruptedException(Throwable cause, List<IntermediateDataSetID> corruptedClusterDatasetIds)
-
Uses of IntermediateDataSetID in org.apache.flink.runtime.scheduler.adaptive
Methods in org.apache.flink.runtime.scheduler.adaptive with parameters of type IntermediateDataSetID Modifier and Type Method Description ExecutionState
AdaptiveScheduler. requestPartitionState(IntermediateDataSetID intermediateResultId, ResultPartitionID resultPartitionId)
-
Uses of IntermediateDataSetID in org.apache.flink.runtime.scheduler.adaptivebatch
Methods in org.apache.flink.runtime.scheduler.adaptivebatch that return IntermediateDataSetID Modifier and Type Method Description IntermediateDataSetID
BlockingInputInfo. getResultId()
Method parameters in org.apache.flink.runtime.scheduler.adaptivebatch with type arguments of type IntermediateDataSetID Modifier and Type Method Description void
BatchJobRecoveryContext. initializeJobVertex(ExecutionJobVertex jobVertex, int parallelism, Map<IntermediateDataSetID,JobVertexInputInfo> jobVertexInputInfos, long createTimestamp)
Initializes a given job vertex with the specified parallelism and input information.void
BatchJobRecoveryHandler. onExecutionJobVertexInitialization(JobVertexID jobVertexId, int parallelism, Map<IntermediateDataSetID,JobVertexInputInfo> jobVertexInputInfos)
Records the job vertex initialization event for use during future batch job recovery.void
DefaultBatchJobRecoveryHandler. onExecutionJobVertexInitialization(JobVertexID jobVertexId, int parallelism, Map<IntermediateDataSetID,JobVertexInputInfo> jobVertexInputInfos)
void
DummyBatchJobRecoveryHandler. onExecutionJobVertexInitialization(JobVertexID jobVertexId, int parallelism, Map<IntermediateDataSetID,JobVertexInputInfo> jobVertexInputInfos)
-
Uses of IntermediateDataSetID in org.apache.flink.runtime.scheduler.adaptivebatch.util
Methods in org.apache.flink.runtime.scheduler.adaptivebatch.util that return types with arguments of type IntermediateDataSetID Modifier and Type Method Description Map<IntermediateDataSetID,JobVertexInputInfo>
AllToAllVertexInputInfoComputer. compute(JobVertexID jobVertexId, List<BlockingInputInfo> inputInfos, int parallelism, int minParallelism, int maxParallelism, long dataVolumePerTask)
Decide parallelism and input infos, which will make the data be evenly distributed to downstream subtasks for ALL_TO_ALL, such that different downstream subtasks consume roughly the same amount of data.Map<IntermediateDataSetID,JobVertexInputInfo>
PointwiseVertexInputInfoComputer. compute(List<BlockingInputInfo> inputInfos, int parallelism, int minParallelism, int maxParallelism, long dataVolumePerTask)
Decide parallelism and input infos, which will make the data be evenly distributed to downstream subtasks for POINTWISE, such that different downstream subtasks consume roughly the same amount of data.static Map<IntermediateDataSetID,JobVertexInputInfo>
VertexParallelismAndInputInfosDeciderUtils. createJobVertexInputInfos(List<BlockingInputInfo> inputInfos, Map<Integer,List<SubpartitionSlice>> subpartitionSlices, List<IndexRange> subpartitionSliceRanges, Function<Integer,Integer> subpartitionSliceKeyResolver)
-
Uses of IntermediateDataSetID in org.apache.flink.runtime.scheduler.strategy
Methods in org.apache.flink.runtime.scheduler.strategy that return IntermediateDataSetID Modifier and Type Method Description IntermediateDataSetID
ConsumedPartitionGroup. getIntermediateDataSetID()
Get the ID of IntermediateDataSet this ConsumedPartitionGroup belongs to.IntermediateDataSetID
SchedulingResultPartition. getResultId()
Gets id of the intermediate result. -
Uses of IntermediateDataSetID in org.apache.flink.runtime.shuffle
Methods in org.apache.flink.runtime.shuffle that return IntermediateDataSetID Modifier and Type Method Description IntermediateDataSetID
PartitionDescriptor. getResultId()
Methods in org.apache.flink.runtime.shuffle that return types with arguments of type IntermediateDataSetID Modifier and Type Method Description Map<IntermediateDataSetID,Integer>
TaskInputsOutputsDescriptor. getInputChannelNums()
Map<IntermediateDataSetID,ResultPartitionType>
TaskInputsOutputsDescriptor. getInputPartitionTypes()
Map<IntermediateDataSetID,Integer>
TaskInputsOutputsDescriptor. getPartitionReuseCount()
Map<IntermediateDataSetID,ResultPartitionType>
TaskInputsOutputsDescriptor. getPartitionTypes()
Map<IntermediateDataSetID,Integer>
TaskInputsOutputsDescriptor. getSubpartitionNums()
Method parameters in org.apache.flink.runtime.shuffle with type arguments of type IntermediateDataSetID Modifier and Type Method Description static int
NettyShuffleUtils. computeNetworkBuffersForAnnouncing(int numBuffersPerChannel, int numFloatingBuffersPerGate, Optional<Integer> maxRequiredBuffersPerGate, int sortShuffleMinParallelism, int sortShuffleMinBuffers, Map<IntermediateDataSetID,Integer> inputChannelNums, Map<IntermediateDataSetID,Integer> partitionReuseCount, Map<IntermediateDataSetID,Integer> subpartitionNums, Map<IntermediateDataSetID,ResultPartitionType> inputPartitionTypes, Map<IntermediateDataSetID,ResultPartitionType> partitionTypes)
static TaskInputsOutputsDescriptor
TaskInputsOutputsDescriptor. from(int inputGateNums, Map<IntermediateDataSetID,Integer> inputChannelNums, Map<IntermediateDataSetID,Integer> partitionReuseCount, Map<IntermediateDataSetID,Integer> subpartitionNums, Map<IntermediateDataSetID,ResultPartitionType> inputPartitionTypes, Map<IntermediateDataSetID,ResultPartitionType> partitionTypes)
Constructors in org.apache.flink.runtime.shuffle with parameters of type IntermediateDataSetID Constructor Description PartitionDescriptor(IntermediateDataSetID resultId, int totalNumberOfPartitions, IntermediateResultPartitionID partitionId, ResultPartitionType partitionType, int numberOfSubpartitions, int connectionIndex, boolean isBroadcast, boolean isAllToAllDistribution, boolean isNumberOfPartitionConsumerUndefined)
-
Uses of IntermediateDataSetID in org.apache.flink.runtime.taskexecutor
Methods in org.apache.flink.runtime.taskexecutor with parameters of type IntermediateDataSetID Modifier and Type Method Description CompletableFuture<ExecutionState>
PartitionProducerStateChecker. requestPartitionProducerState(org.apache.flink.api.common.JobID jobId, IntermediateDataSetID intermediateDataSetId, ResultPartitionID resultPartitionId)
Requests the execution state of the execution producing a result partition.Method parameters in org.apache.flink.runtime.taskexecutor with type arguments of type IntermediateDataSetID Modifier and Type Method Description CompletableFuture<Acknowledge>
TaskExecutor. releaseClusterPartitions(Collection<IntermediateDataSetID> dataSetsToRelease, Duration timeout)
CompletableFuture<Acknowledge>
TaskExecutorGateway. releaseClusterPartitions(Collection<IntermediateDataSetID> dataSetsToRelease, Duration timeout)
Releases all cluster partitions belong to any of the given data sets.CompletableFuture<Acknowledge>
TaskExecutorGatewayDecoratorBase. releaseClusterPartitions(Collection<IntermediateDataSetID> dataSetsToRelease, Duration timeout)
-
Uses of IntermediateDataSetID in org.apache.flink.runtime.taskexecutor.partition
Methods in org.apache.flink.runtime.taskexecutor.partition that return IntermediateDataSetID Modifier and Type Method Description IntermediateDataSetID
ClusterPartitionReport.ClusterPartitionReportEntry. getDataSetId()
Constructors in org.apache.flink.runtime.taskexecutor.partition with parameters of type IntermediateDataSetID Constructor Description ClusterPartitionReportEntry(IntermediateDataSetID dataSetId, int numTotalPartitions, Map<ResultPartitionID,ShuffleDescriptor> shuffleDescriptors)
-
Uses of IntermediateDataSetID in org.apache.flink.runtime.taskexecutor.rpc
Methods in org.apache.flink.runtime.taskexecutor.rpc with parameters of type IntermediateDataSetID Modifier and Type Method Description CompletableFuture<ExecutionState>
RpcPartitionStateChecker. requestPartitionProducerState(org.apache.flink.api.common.JobID jobId, IntermediateDataSetID resultId, ResultPartitionID partitionId)
-
Uses of IntermediateDataSetID in org.apache.flink.runtime.taskmanager
Methods in org.apache.flink.runtime.taskmanager with parameters of type IntermediateDataSetID Modifier and Type Method Description void
Task. requestPartitionProducerState(IntermediateDataSetID intermediateDataSetId, ResultPartitionID resultPartitionId, Consumer<? super PartitionProducerStateProvider.ResponseHandle> responseConsumer)
-
Uses of IntermediateDataSetID in org.apache.flink.streaming.api.graph
Methods in org.apache.flink.streaming.api.graph that return IntermediateDataSetID Modifier and Type Method Description IntermediateDataSetID
StreamNode. getConsumeClusterDatasetId()
IntermediateDataSetID
DefaultStreamGraphContext. getConsumedIntermediateDataSetId(String edgeId)
IntermediateDataSetID
StreamGraphContext. getConsumedIntermediateDataSetId(String edgeId)
Retrieves the IntermediateDataSetID consumed by the specified edge.IntermediateDataSetID
NonChainedOutput. getDataSetId()
IntermediateDataSetID
StreamEdge. getIntermediateDatasetIdToProduce()
IntermediateDataSetID
NonChainedOutput. getPersistentDataSetId()
Methods in org.apache.flink.streaming.api.graph with parameters of type IntermediateDataSetID Modifier and Type Method Description void
StreamGraph. addEdge(Integer upStreamVertexID, Integer downStreamVertexID, int typeNumber, IntermediateDataSetID intermediateDataSetId)
List<StreamEdge>
AdaptiveGraphManager. getOutputStreamEdges(IntermediateDataSetID intermediateDataSetId)
Retrieves the stream edges that subscribe to the IntermediateDataSet.Integer
AdaptiveGraphManager. getProducerStreamNodeId(IntermediateDataSetID intermediateDataSetId)
Retrieves the ID of the stream node that produces the IntermediateDataSet.void
StreamNode. setConsumeClusterDatasetId(IntermediateDataSetID consumeClusterDatasetId)
Constructors in org.apache.flink.streaming.api.graph with parameters of type IntermediateDataSetID Constructor Description NonChainedOutput(boolean supportsUnalignedCheckpoints, int sourceNodeId, int consumerParallelism, int consumerMaxParallelism, long bufferTimeout, boolean isPersistentDataSet, IntermediateDataSetID dataSetId, org.apache.flink.util.OutputTag<?> outputTag, StreamPartitioner<?> partitioner, ResultPartitionType partitionType)
StreamEdge(StreamNode sourceVertex, StreamNode targetVertex, int typeNumber, long bufferTimeout, StreamPartitioner<?> outputPartitioner, org.apache.flink.util.OutputTag outputTag, StreamExchangeMode exchangeMode, int uniqueId, IntermediateDataSetID intermediateDatasetId)
StreamEdge(StreamNode sourceVertex, StreamNode targetVertex, int typeNumber, StreamPartitioner<?> outputPartitioner, org.apache.flink.util.OutputTag outputTag, StreamExchangeMode exchangeMode, int uniqueId, IntermediateDataSetID intermediateDatasetId)
-