Modifier and Type | Field and Description |
---|---|
static IngressIdentifier<TypedValue> |
Constants.IN |
Modifier and Type | Method and Description |
---|---|
java.util.Map<IngressIdentifier<?>,IngressSpec<?>> |
StatefulFunctionsUniverse.ingress() |
java.util.Map<IngressIdentifier<?>,java.util.List<Router<?>>> |
StatefulFunctionsUniverse.routers() |
Modifier and Type | Method and Description |
---|---|
<T> void |
StatefulFunctionsUniverse.bindIngressRouter(IngressIdentifier<T> ingressIdentifier,
Router<T> router) |
Modifier and Type | Method and Description |
---|---|
<T> Harness |
Harness.withFlinkSourceFunction(IngressIdentifier<T> identifier,
org.apache.flink.streaming.api.functions.source.SourceFunction<T> supplier) |
<T> Harness |
Harness.withSupplyingIngress(IngressIdentifier<T> identifier,
SerializableSupplier<T> supplier) |
Modifier and Type | Method and Description |
---|---|
IngressIdentifier<T> |
SupplyingIngressSpec.id() |
Constructor and Description |
---|
SupplyingIngressSpec(IngressIdentifier<T> id,
SerializableSupplier<T> supplier,
long productionDelayInMilliseconds) |
Modifier and Type | Method and Description |
---|---|
IngressIdentifier<com.google.protobuf.Message> |
IngressIdentifierJsonDeserializer.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 |
---|---|
IngressIdentifier<T> |
SourceFunctionSpec.id() |
Constructor and Description |
---|
SourceFunctionSpec(IngressIdentifier<T> id,
org.apache.flink.streaming.api.functions.source.SourceFunction<T> delegate) |
Modifier and Type | Method and Description |
---|---|
IngressIdentifier<com.google.protobuf.Message> |
RoutableKinesisIngressSpec.id() |
Modifier and Type | Method and Description |
---|---|
IngressIdentifier<T> |
IngressSpec.id()
Returns the unique identifier of the ingress.
|
Modifier and Type | Method and Description |
---|---|
IngressIdentifier<T> |
KafkaIngressSpec.id() |
Modifier and Type | Method and Description |
---|---|
static <T> KafkaIngressBuilder<T> |
KafkaIngressBuilder.forIdentifier(IngressIdentifier<T> id) |
Modifier and Type | Method and Description |
---|---|
IngressIdentifier<T> |
KinesisIngressSpec.id() |
Modifier and Type | Method and Description |
---|---|
static <T> KinesisIngressBuilder<T> |
KinesisIngressBuilder.forIdentifier(IngressIdentifier<T> id) |
Modifier and Type | Method and Description |
---|---|
<T> void |
StatefulFunctionModule.Binder.bindIngressRouter(IngressIdentifier<T> id,
Router<T> router)
Binds a
Router for a given ingress to the Stateful Functions application. |
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.