Package | Description |
---|---|
org.apache.flink.statefun.flink.core.functions | |
org.apache.flink.statefun.flink.core.message | |
org.apache.flink.statefun.flink.core.translation |
Modifier and Type | Method and Description |
---|---|
<T extends org.apache.flink.streaming.api.operators.StreamOperator<Message>> |
FunctionGroupDispatchFactory.createStreamOperator(org.apache.flink.streaming.api.operators.StreamOperatorParameters<Message> streamOperatorParameters) |
Modifier and Type | Method and Description |
---|---|
void |
ApplyingContext.apply(org.apache.flink.statefun.flink.core.functions.LiveFunction function,
Message inMessage) |
Modifier and Type | Method and Description |
---|---|
<T extends org.apache.flink.streaming.api.operators.StreamOperator<Message>> |
FunctionGroupDispatchFactory.createStreamOperator(org.apache.flink.streaming.api.operators.StreamOperatorParameters<Message> streamOperatorParameters) |
void |
FunctionGroupOperator.processElement(org.apache.flink.streaming.runtime.streamrecord.StreamRecord<Message> record) |
Modifier and Type | Method and Description |
---|---|
Message |
MessageTypeSerializer.copy(Message message) |
Message |
Message.copy(MessageFactory context) |
Message |
MessageTypeSerializer.copy(Message message,
Message reuse) |
Message |
MessageTypeSerializer.createInstance() |
Message |
MessageTypeSerializer.deserialize(org.apache.flink.core.memory.DataInputView dataInputView) |
Message |
MessageTypeSerializer.deserialize(Message message,
org.apache.flink.core.memory.DataInputView dataInputView) |
Message |
MessageFactory.from(Address from,
Address to,
java.lang.Object payload) |
Message |
MessageFactory.from(Address from,
Address to,
java.lang.Object payload,
java.lang.String cancellationToken) |
Message |
MessageFactory.from(org.apache.flink.core.memory.DataInputView input) |
Message |
MessageFactory.from(long checkpointId) |
Modifier and Type | Method and Description |
---|---|
org.apache.flink.api.common.typeutils.TypeSerializer<Message> |
MessageTypeInformation.createSerializer(org.apache.flink.api.common.ExecutionConfig executionConfig) |
org.apache.flink.api.common.typeutils.TypeSerializer<Message> |
MessageTypeSerializer.duplicate() |
java.lang.Class<Message> |
MessageTypeInformation.getTypeClass() |
org.apache.flink.api.common.typeutils.TypeSerializerSchemaCompatibility<Message> |
MessageTypeSerializer.Snapshot.resolveSchemaCompatibility(org.apache.flink.api.common.typeutils.TypeSerializer<Message> typeSerializer) |
org.apache.flink.api.common.typeutils.TypeSerializer<Message> |
MessageTypeSerializer.Snapshot.restoreSerializer() |
org.apache.flink.api.common.typeutils.TypeSerializerSnapshot<Message> |
MessageTypeSerializer.snapshotConfiguration() |
Modifier and Type | Method and Description |
---|---|
Message |
MessageTypeSerializer.copy(Message message) |
Message |
MessageTypeSerializer.copy(Message message,
Message reuse) |
Message |
MessageTypeSerializer.deserialize(Message message,
org.apache.flink.core.memory.DataInputView dataInputView) |
java.lang.String |
MessageKeySelector.getKey(Message value) |
void |
MessageTypeSerializer.serialize(Message message,
org.apache.flink.core.memory.DataOutputView dataOutputView) |
Modifier and Type | Method and Description |
---|---|
org.apache.flink.api.common.typeutils.TypeSerializerSchemaCompatibility<Message> |
MessageTypeSerializer.Snapshot.resolveSchemaCompatibility(org.apache.flink.api.common.typeutils.TypeSerializer<Message> typeSerializer) |
Constructor and Description |
---|
EmbeddedTranslator(StatefulFunctionsConfig config,
FeedbackKey<Message> feedbackKey) |
FlinkUniverse(FeedbackKey<Message> feedbackKey,
StatefulFunctionsConfig configuration,
StatefulFunctionsUniverse universe) |
Copyright © 2014–2025 The Apache Software Foundation. All rights reserved.