Modifier and Type | Field and Description |
---|---|
static EgressIdentifier<TypedValue> |
Constants.OUT |
static EgressIdentifier<TypedValue> |
Constants.VERIFICATION_RESULT |
Modifier and Type | Method and Description |
---|---|
java.util.Map<EgressIdentifier<?>,EgressSpec<?>> |
StatefulFunctionsUniverse.egress() |
Constructor and Description |
---|
FunctionGroupDispatchFactory(StatefulFunctionsConfig configuration,
java.util.Map<EgressIdentifier<?>,org.apache.flink.util.OutputTag<java.lang.Object>> sideOutputs) |
Modifier and Type | Method and Description |
---|---|
<T extends StatefulFunctionProvider & java.io.Serializable> |
EmbeddedTranslator.translate(java.util.List<org.apache.flink.streaming.api.datastream.DataStream<RoutableMessage>> ingresses,
java.lang.Iterable<EgressIdentifier<?>> egressesIds,
java.util.Map<FunctionType,T> functions) |
Modifier and Type | Method and Description |
---|---|
<T extends StatefulFunctionProvider & java.io.Serializable> |
EmbeddedTranslator.translate(java.util.List<org.apache.flink.streaming.api.datastream.DataStream<RoutableMessage>> ingresses,
java.lang.Iterable<EgressIdentifier<?>> egressesIds,
java.util.Map<FunctionType,T> functions) |
Modifier and Type | Method and Description |
---|---|
<T> org.apache.flink.streaming.api.datastream.DataStream<T> |
StatefulFunctionEgressStreams.getDataStreamForEgressId(EgressIdentifier<T> id)
Returns the
DataStream that represents a stateful functions egress for an EgressIdentifier . |
StatefulFunctionDataStreamBuilder |
StatefulFunctionDataStreamBuilder.withEgressId(EgressIdentifier<?> egressId)
Registers an
EgressIdentifier . |
Modifier and Type | Method and Description |
---|---|
<T> Harness |
Harness.withConsumingEgress(EgressIdentifier<T> identifier,
SerializableConsumer<T> consumer) |
<T> Harness |
Harness.withPrintingEgress(EgressIdentifier<T> identifier) |
Modifier and Type | Method and Description |
---|---|
EgressIdentifier<T> |
ConsumingEgressSpec.id() |
Constructor and Description |
---|
ConsumingEgressSpec(EgressIdentifier<T> id,
SerializableConsumer<T> consumer) |
Modifier and Type | Method and Description |
---|---|
EgressIdentifier<TypedValue> |
EgressIdentifierJsonDeserializer.deserialize(org.apache.flink.shaded.jackson2.com.fasterxml.jackson.core.JsonParser jsonParser,
org.apache.flink.shaded.jackson2.com.fasterxml.jackson.databind.DeserializationContext deserializationContext) |
Modifier and Type | Method and Description |
---|---|
EgressIdentifier<T> |
SinkFunctionSpec.id() |
Constructor and Description |
---|
SinkFunctionSpec(EgressIdentifier<T> id,
org.apache.flink.streaming.api.functions.sink.SinkFunction<T> delegate) |
Modifier and Type | Method and Description |
---|---|
EgressIdentifier<TypedValue> |
GenericKinesisEgressSpec.id() |
Modifier and Type | Method and Description |
---|---|
<T> void |
Context.send(EgressIdentifier<T> egress,
T message)
Sends an output to an egress, identified by the egress'
EgressIdentifier . |
Modifier and Type | Method and Description |
---|---|
EgressIdentifier<T> |
EgressSpec.id()
Returns the unique identifier of the egress.
|
Modifier and Type | Method and Description |
---|---|
EgressIdentifier<OutT> |
KafkaEgressSpec.id() |
Modifier and Type | Method and Description |
---|---|
static <OutT> KafkaEgressBuilder<OutT> |
KafkaEgressBuilder.forIdentifier(EgressIdentifier<OutT> egressIdentifier) |
Modifier and Type | Method and Description |
---|---|
EgressIdentifier<T> |
KinesisEgressSpec.id() |
Modifier and Type | Method and Description |
---|---|
static <T> KinesisEgressBuilder<T> |
KinesisEgressBuilder.forIdentifier(EgressIdentifier<T> id) |
Modifier and Type | Method and Description |
---|---|
<T> java.util.List<T> |
FunctionTestHarness.getEgress(EgressIdentifier<T> identifier) |
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.