T
- @Internal public final class BlockingShuffleOutputFormat<T> extends Object implements org.apache.flink.api.common.io.OutputFormat<T>
Modifier and Type | Method and Description |
---|---|
void |
close() |
void |
configure(org.apache.flink.configuration.Configuration parameters) |
static <T> BlockingShuffleOutputFormat<T> |
createOutputFormat(org.apache.flink.util.AbstractID intermediateDataSetId) |
org.apache.flink.util.AbstractID |
getIntermediateDataSetId() |
void |
open(int taskNumber,
int numTasks) |
void |
writeRecord(T record) |
public static <T> BlockingShuffleOutputFormat<T> createOutputFormat(org.apache.flink.util.AbstractID intermediateDataSetId)
public void configure(org.apache.flink.configuration.Configuration parameters)
configure
in interface org.apache.flink.api.common.io.OutputFormat<T>
public void open(int taskNumber, int numTasks) throws IOException
open
in interface org.apache.flink.api.common.io.OutputFormat<T>
IOException
public void writeRecord(T record) throws IOException
writeRecord
in interface org.apache.flink.api.common.io.OutputFormat<T>
IOException
public void close() throws IOException
close
in interface org.apache.flink.api.common.io.OutputFormat<T>
IOException
public org.apache.flink.util.AbstractID getIntermediateDataSetId()
Copyright © 2014–2020 The Apache Software Foundation. All rights reserved.