T
- The type to be represented as an IOReadableWritable.public class SerializationDelegate<T> extends Object implements org.apache.flink.core.io.IOReadableWritable
IOReadableWritable
for
serialization, with the help of a type serializer.构造器和说明 |
---|
SerializationDelegate(org.apache.flink.api.common.typeutils.TypeSerializer<T> serializer) |
限定符和类型 | 方法和说明 |
---|---|
T |
getInstance() |
void |
read(org.apache.flink.core.memory.DataInputView in) |
void |
setInstance(T instance) |
void |
write(org.apache.flink.core.memory.DataOutputView out) |
public SerializationDelegate(org.apache.flink.api.common.typeutils.TypeSerializer<T> serializer)
public void setInstance(T instance)
public T getInstance()
public void write(org.apache.flink.core.memory.DataOutputView out) throws IOException
write
在接口中 org.apache.flink.core.io.IOReadableWritable
IOException
public void read(org.apache.flink.core.memory.DataInputView in) throws IOException
read
在接口中 org.apache.flink.core.io.IOReadableWritable
IOException
Copyright © 2014–2019 The Apache Software Foundation. All rights reserved.