Package org.apache.flink.api.common.io
Class SerializedOutputFormat<T extends IOReadableWritable>
- java.lang.Object
-
- org.apache.flink.api.common.io.RichOutputFormat<IT>
-
- org.apache.flink.api.common.io.FileOutputFormat<T>
-
- org.apache.flink.api.common.io.BinaryOutputFormat<T>
-
- org.apache.flink.api.common.io.SerializedOutputFormat<T>
-
- All Implemented Interfaces:
Serializable
,CleanupWhenUnsuccessful
,InitializeOnMaster
,OutputFormat<T>
@Public public class SerializedOutputFormat<T extends IOReadableWritable> extends BinaryOutputFormat<T>
Stores elements by serializing them with their regular serialization/deserialization functionality.- See Also:
SerializedInputFormat
, Serialized Form
-
-
Nested Class Summary
-
Nested classes/interfaces inherited from class org.apache.flink.api.common.io.BinaryOutputFormat
BinaryOutputFormat.BlockBasedOutput
-
Nested classes/interfaces inherited from class org.apache.flink.api.common.io.FileOutputFormat
FileOutputFormat.OutputDirectoryMode
-
Nested classes/interfaces inherited from interface org.apache.flink.api.common.io.OutputFormat
OutputFormat.InitializationContext
-
-
Field Summary
-
Fields inherited from class org.apache.flink.api.common.io.BinaryOutputFormat
NATIVE_BLOCK_SIZE
-
Fields inherited from class org.apache.flink.api.common.io.FileOutputFormat
outputFilePath, stream
-
-
Constructor Summary
Constructors Constructor Description SerializedOutputFormat()
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description protected void
serialize(T record, DataOutputView dataOutputView)
-
Methods inherited from class org.apache.flink.api.common.io.BinaryOutputFormat
close, complementBlockInfo, configure, createBlockInfo, open, writeRecord
-
Methods inherited from class org.apache.flink.api.common.io.FileOutputFormat
getDirectoryFileName, getOutputDirectoryMode, getOutputFilePath, getWriteMode, initDefaultsFromConfiguration, initializeGlobal, setOutputDirectoryMode, setOutputFilePath, setWriteMode, tryCleanupOnError
-
Methods inherited from class org.apache.flink.api.common.io.RichOutputFormat
getRuntimeContext, setRuntimeContext
-
-
-
-
Method Detail
-
serialize
protected void serialize(T record, DataOutputView dataOutputView) throws IOException
- Specified by:
serialize
in classBinaryOutputFormat<T extends IOReadableWritable>
- Throws:
IOException
-
-