Package org.apache.flink.core.io
Interface IOReadableWritable
-
- All Known Subinterfaces:
CopyableValue<T>
,DataDistribution
,DeserializationDelegate<T>
,Key<T>
,ResettableValue<T>
,Value
- All Known Implementing Classes:
AbstractEvent
,AllWorkersDoneEvent
,BlockInfo
,BooleanValue
,ByteValue
,CancelCheckpointMarker
,CharValue
,CheckpointBarrier
,Configuration
,DelegatingConfiguration
,DoubleValue
,EndOfChannelStateEvent
,EndOfData
,EndOfPartitionEvent
,EndOfSegmentEvent
,EndOfSuperstepEvent
,EventAnnouncement
,FloatValue
,InternalTimerServiceSerializationProxy
,IntValue
,IterationEventWithAggregators
,KeyedBackendSerializationProxy
,ListValue
,LongValue
,MapValue
,NonReusingDeserializationDelegate
,NullValue
,OperatorBackendSerializationProxy
,PostVersionedIOReadableWritable
,Record
,RecoveryMetadata
,ReusingDeserializationDelegate
,RuntimeEvent
,SerializationDelegate
,ShortValue
,StringValue
,SubtaskConnectionDescriptor
,TaskEvent
,TerminationEvent
,UnmodifiableConfiguration
,VersionedIOReadableWritable
,WorkerDoneEvent
@Public public interface IOReadableWritable
This interface must be implemented by every class whose objects have to be serialized to their binary representation and vice-versa. In particular, records have to implement this interface in order to specify how their data can be transferred to a binary representation.When implementing this Interface make sure that the implementing class has a default (zero-argument) constructor!
-
-
Method Summary
All Methods Instance Methods Abstract Methods Modifier and Type Method Description void
read(DataInputView in)
Reads the object's internal data from the given data input view.void
write(DataOutputView out)
Writes the object's internal data to the given data output view.
-
-
-
Method Detail
-
write
void write(DataOutputView out) throws IOException
Writes the object's internal data to the given data output view.- Parameters:
out
- the output view to receive the data.- Throws:
IOException
- thrown if any error occurs while writing to the output stream
-
read
void read(DataInputView in) throws IOException
Reads the object's internal data from the given data input view.- Parameters:
in
- the input view to read the data from- Throws:
IOException
- thrown if any error occurs while reading from the input stream
-
-