Package | Description |
---|---|
org.apache.flink.cep.nfa | |
org.apache.flink.cep.nfa.sharedbuffer |
Modifier and Type | Method and Description |
---|---|
NodeId |
SharedBuffer.getNodeId(String prevState,
long timestamp,
int counter,
V event)
Deprecated.
|
NodeId |
ComputationState.getPreviousBufferEntry() |
Modifier and Type | Method and Description |
---|---|
Map<NodeId,Lockable<SharedBufferNode>> |
SharedBuffer.getPages()
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
static ComputationState |
ComputationState.createState(String currentState,
NodeId previousEntry,
DeweyNumber version,
long startTimestamp,
EventId startEventID) |
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 |
---|---|
NodeId |
NodeId.NodeIdSerializer.copy(NodeId from) |
NodeId |
NodeId.NodeIdSerializer.copy(NodeId from,
NodeId reuse) |
NodeId |
NodeId.NodeIdSerializer.createInstance() |
NodeId |
NodeId.NodeIdSerializer.deserialize(DataInputView source) |
NodeId |
NodeId.NodeIdSerializer.deserialize(NodeId reuse,
DataInputView source) |
NodeId |
SharedBufferAccessor.put(String stateName,
EventId eventId,
NodeId previousNodeId,
DeweyNumber version)
Stores given value (value + timestamp) under the given state.
|
Modifier and Type | Method and Description |
---|---|
TypeSerializerSnapshot<NodeId> |
NodeId.NodeIdSerializer.snapshotConfiguration() |
Modifier and Type | Method and Description |
---|---|
NodeId |
NodeId.NodeIdSerializer.copy(NodeId from) |
NodeId |
NodeId.NodeIdSerializer.copy(NodeId from,
NodeId reuse) |
NodeId |
NodeId.NodeIdSerializer.deserialize(NodeId reuse,
DataInputView source) |
List<Map<String,List<EventId>>> |
SharedBufferAccessor.extractPatterns(NodeId nodeId,
DeweyNumber version)
Returns all elements from the previous relation starting at the given entry.
|
void |
SharedBufferAccessor.lockNode(NodeId node)
Increases the reference counter for the given entry so that it is not accidentally removed.
|
NodeId |
SharedBufferAccessor.put(String stateName,
EventId eventId,
NodeId previousNodeId,
DeweyNumber version)
Stores given value (value + timestamp) under the given state.
|
void |
SharedBufferAccessor.releaseNode(NodeId node)
Decreases the reference counter for the given entry so that it can be removed once the
reference counter reaches 0.
|
void |
NodeId.NodeIdSerializer.serialize(NodeId 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!
|
Constructor and Description |
---|
SharedBufferEdge(NodeId target,
DeweyNumber deweyNumber)
Creates versioned (with
DeweyNumber ) edge that points to the target entry. |
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.