Class JobShuffleContextImpl

    • Constructor Detail

      • JobShuffleContextImpl

        public JobShuffleContextImpl​(org.apache.flink.api.common.JobID jobId,
                                     JobMasterGateway jobMasterGateway)
    • Method Detail

      • getJobId

        public org.apache.flink.api.common.JobID getJobId()
        Specified by:
        getJobId in interface JobShuffleContext
        Returns:
        the corresponding JobID.
      • getPartitionWithMetrics

        public CompletableFuture<Collection<PartitionWithMetrics>> getPartitionWithMetrics​(Duration timeout,
                                                                                           Set<ResultPartitionID> expectedPartitions)
        Description copied from interface: JobShuffleContext
        Retrieves specified partitions and their metrics (identified by expectedPartitions), the metrics include sizes of sub-partitions in a result partition.
        Specified by:
        getPartitionWithMetrics in interface JobShuffleContext
        Parameters:
        timeout - The timeout used for retrieve the specified partitions.
        expectedPartitions - The set of identifiers for the result partitions whose metrics are to be fetched.
        Returns:
        A future will contain a collection of the partitions with their metrics that could be retrieved from the expected partitions within the specified timeout period.