Package | Description |
---|---|
org.apache.flink.statefun.flink.state.processor.operator | |
org.apache.flink.statefun.flink.state.processor.union |
Modifier and Type | Method and Description |
---|---|
void |
FunctionsStateBootstrapOperator.processElement(org.apache.flink.streaming.runtime.streamrecord.StreamRecord<TaggedBootstrapData> streamRecord) |
Modifier and Type | Method and Description |
---|---|
TaggedBootstrapData |
TaggedBootstrapDataSerializer.copy(TaggedBootstrapData bootstrapData) |
TaggedBootstrapData |
TaggedBootstrapDataSerializer.copy(TaggedBootstrapData bootstrapData,
TaggedBootstrapData reuse) |
TaggedBootstrapData |
TaggedBootstrapData.copy(org.apache.flink.api.common.typeutils.TypeSerializer<java.lang.Object> payloadSerializer) |
static TaggedBootstrapData |
TaggedBootstrapData.createDefaultInstance() |
TaggedBootstrapData |
TaggedBootstrapDataSerializer.createInstance() |
TaggedBootstrapData |
TaggedBootstrapDataSerializer.deserialize(org.apache.flink.core.memory.DataInputView dataInputView) |
TaggedBootstrapData |
TaggedBootstrapDataSerializer.deserialize(TaggedBootstrapData reuse,
org.apache.flink.core.memory.DataInputView dataInputView) |
Modifier and Type | Method and Description |
---|---|
static org.apache.flink.api.java.DataSet<TaggedBootstrapData> |
BootstrapDatasetUnion.apply(java.util.List<BootstrapDataset<?>> bootstrapDatasets)
Unions multiple
BootstrapDataset s to a single, tagged Flink dataset. |
org.apache.flink.api.common.typeutils.TypeSerializer<TaggedBootstrapData> |
TaggedBootstrapDataTypeInfo.createSerializer(org.apache.flink.api.common.ExecutionConfig executionConfig) |
org.apache.flink.api.common.typeutils.TypeSerializer<TaggedBootstrapData> |
TaggedBootstrapDataSerializer.duplicate() |
java.lang.Class<TaggedBootstrapData> |
TaggedBootstrapDataTypeInfo.getTypeClass() |
org.apache.flink.api.common.typeutils.TypeSerializerSnapshot<TaggedBootstrapData> |
TaggedBootstrapDataSerializer.snapshotConfiguration() |
Modifier and Type | Method and Description |
---|---|
TaggedBootstrapData |
TaggedBootstrapDataSerializer.copy(TaggedBootstrapData bootstrapData) |
TaggedBootstrapData |
TaggedBootstrapDataSerializer.copy(TaggedBootstrapData bootstrapData,
TaggedBootstrapData reuse) |
TaggedBootstrapData |
TaggedBootstrapDataSerializer.deserialize(TaggedBootstrapData reuse,
org.apache.flink.core.memory.DataInputView dataInputView) |
void |
TaggedBootstrapDataSerializer.serialize(TaggedBootstrapData bootstrapData,
org.apache.flink.core.memory.DataOutputView dataOutputView) |
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.