Package | Description |
---|---|
org.apache.flink.cep.nfa | |
org.apache.flink.cep.nfa.sharedbuffer |
Modifier and Type | Method and Description |
---|---|
Map<EventId,Lockable<V>> |
SharedBuffer.getEventsBuffer()
Deprecated.
|
Map<NodeId,Lockable<SharedBufferNode>> |
SharedBuffer.getPages()
Deprecated.
|
Constructor and Description |
---|
SharedBuffer(Map<EventId,Lockable<V>> eventsBuffer,
Map<NodeId,Lockable<SharedBufferNode>> pages,
Map<Tuple2<String,org.apache.flink.cep.nfa.SharedBuffer.ValueTimeWrapper<V>>,NodeId> mappingContext,
Map<Integer,EventId> starters)
Deprecated.
|
SharedBuffer(Map<EventId,Lockable<V>> eventsBuffer,
Map<NodeId,Lockable<SharedBufferNode>> pages,
Map<Tuple2<String,org.apache.flink.cep.nfa.SharedBuffer.ValueTimeWrapper<V>>,NodeId> mappingContext,
Map<Integer,EventId> starters)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
Lockable<E> |
Lockable.LockableTypeSerializer.copy(Lockable<E> from) |
Lockable<E> |
Lockable.LockableTypeSerializer.copy(Lockable<E> from,
Lockable<E> reuse) |
Lockable<E> |
Lockable.LockableTypeSerializer.createInstance() |
Lockable<E> |
Lockable.LockableTypeSerializer.deserialize(DataInputView source) |
Lockable<E> |
Lockable.LockableTypeSerializer.deserialize(Lockable<E> reuse,
DataInputView source) |
Modifier and Type | Method and Description |
---|---|
TypeSerializerSnapshot<Lockable<E>> |
Lockable.LockableTypeSerializer.snapshotConfiguration() |
<U> TypeSerializerSnapshot<Lockable<E>> |
Lockable.LockableTypeSerializer.transformLegacySerializerSnapshot(TypeSerializerSnapshot<U> legacySnapshot) |
Modifier and Type | Method and Description |
---|---|
Lockable<E> |
Lockable.LockableTypeSerializer.copy(Lockable<E> from) |
Lockable<E> |
Lockable.LockableTypeSerializer.copy(Lockable<E> from,
Lockable<E> reuse) |
Lockable<E> |
Lockable.LockableTypeSerializer.copy(Lockable<E> from,
Lockable<E> reuse) |
Lockable<E> |
Lockable.LockableTypeSerializer.deserialize(Lockable<E> reuse,
DataInputView source) |
void |
Lockable.LockableTypeSerializer.serialize(Lockable<E> record,
DataOutputView target) |
Modifier and Type | Method and Description |
---|---|
void |
SharedBuffer.init(Map<EventId,Lockable<V>> events,
Map<NodeId,Lockable<SharedBufferNode>> entries)
Deprecated.
Only for state migration!
|
void |
SharedBuffer.init(Map<EventId,Lockable<V>> events,
Map<NodeId,Lockable<SharedBufferNode>> entries)
Deprecated.
Only for state migration!
|
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.