Class SharedBufferNodeSerializer
- java.lang.Object
-
- org.apache.flink.api.common.typeutils.TypeSerializer<T>
-
- org.apache.flink.api.common.typeutils.base.TypeSerializerSingleton<SharedBufferNode>
-
- org.apache.flink.cep.nfa.sharedbuffer.SharedBufferNodeSerializer
-
- All Implemented Interfaces:
Serializable
public class SharedBufferNodeSerializer extends org.apache.flink.api.common.typeutils.base.TypeSerializerSingleton<SharedBufferNode>
Serializer forSharedBufferNode
.- See Also:
- Serialized Form
-
-
Constructor Summary
Constructors Constructor Description SharedBufferNodeSerializer()
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description SharedBufferNode
copy(SharedBufferNode from)
SharedBufferNode
copy(SharedBufferNode from, SharedBufferNode reuse)
void
copy(org.apache.flink.core.memory.DataInputView source, org.apache.flink.core.memory.DataOutputView target)
SharedBufferNode
createInstance()
SharedBufferNode
deserialize(SharedBufferNode reuse, org.apache.flink.core.memory.DataInputView source)
SharedBufferNode
deserialize(org.apache.flink.core.memory.DataInputView source)
org.apache.flink.api.common.typeutils.TypeSerializer<SharedBufferEdge>
getEdgeSerializer()
int
getLength()
boolean
isImmutableType()
void
serialize(SharedBufferNode record, org.apache.flink.core.memory.DataOutputView target)
org.apache.flink.api.common.typeutils.TypeSerializerSnapshot<SharedBufferNode>
snapshotConfiguration()
-
-
-
Method Detail
-
getEdgeSerializer
public org.apache.flink.api.common.typeutils.TypeSerializer<SharedBufferEdge> getEdgeSerializer()
-
isImmutableType
public boolean isImmutableType()
- Specified by:
isImmutableType
in classorg.apache.flink.api.common.typeutils.TypeSerializer<SharedBufferNode>
-
createInstance
public SharedBufferNode createInstance()
- Specified by:
createInstance
in classorg.apache.flink.api.common.typeutils.TypeSerializer<SharedBufferNode>
-
copy
public SharedBufferNode copy(SharedBufferNode from)
- Specified by:
copy
in classorg.apache.flink.api.common.typeutils.TypeSerializer<SharedBufferNode>
-
copy
public SharedBufferNode copy(SharedBufferNode from, SharedBufferNode reuse)
- Specified by:
copy
in classorg.apache.flink.api.common.typeutils.TypeSerializer<SharedBufferNode>
-
getLength
public int getLength()
- Specified by:
getLength
in classorg.apache.flink.api.common.typeutils.TypeSerializer<SharedBufferNode>
-
serialize
public void serialize(SharedBufferNode record, org.apache.flink.core.memory.DataOutputView target) throws IOException
- Specified by:
serialize
in classorg.apache.flink.api.common.typeutils.TypeSerializer<SharedBufferNode>
- Throws:
IOException
-
deserialize
public SharedBufferNode deserialize(org.apache.flink.core.memory.DataInputView source) throws IOException
- Specified by:
deserialize
in classorg.apache.flink.api.common.typeutils.TypeSerializer<SharedBufferNode>
- Throws:
IOException
-
deserialize
public SharedBufferNode deserialize(SharedBufferNode reuse, org.apache.flink.core.memory.DataInputView source) throws IOException
- Specified by:
deserialize
in classorg.apache.flink.api.common.typeutils.TypeSerializer<SharedBufferNode>
- Throws:
IOException
-
copy
public void copy(org.apache.flink.core.memory.DataInputView source, org.apache.flink.core.memory.DataOutputView target) throws IOException
- Specified by:
copy
in classorg.apache.flink.api.common.typeutils.TypeSerializer<SharedBufferNode>
- Throws:
IOException
-
snapshotConfiguration
public org.apache.flink.api.common.typeutils.TypeSerializerSnapshot<SharedBufferNode> snapshotConfiguration()
- Specified by:
snapshotConfiguration
in classorg.apache.flink.api.common.typeutils.TypeSerializer<SharedBufferNode>
-
-