Modifier and Type | Field and Description |
---|---|
static IngressIdentifier<TypedValue> |
Constants.IN |
static EgressIdentifier<TypedValue> |
Constants.OUT |
static EgressIdentifier<TypedValue> |
Constants.VERIFICATION_RESULT |
Modifier and Type | Method and Description |
---|---|
static TypedValue |
Types.packCommands(Commands commands) |
static TypedValue |
Types.packSourceCommand(SourceCommand sourceCommand) |
static TypedValue |
Types.packVerificationResult(VerificationResult verificationResult) |
Modifier and Type | Method and Description |
---|---|
static boolean |
Types.isTypeOf(TypedValue value,
TypeName type) |
void |
CommandRouter.route(TypedValue command,
Router.Downstream<TypedValue> downstream) |
static Commands |
Types.unpackCommands(TypedValue typedValue) |
static SourceCommand |
Types.unpackSourceCommand(TypedValue typedValue) |
static VerificationResult |
Types.unpackVerificationResult(TypedValue typedValue) |
Modifier and Type | Method and Description |
---|---|
void |
CommandRouter.route(TypedValue command,
Router.Downstream<TypedValue> downstream) |
Modifier and Type | Method and Description |
---|---|
static TypedValue |
TypedValueUtil.packProtobufMessage(com.google.protobuf.Message protobufMessage) |
Modifier and Type | Method and Description |
---|---|
static boolean |
TypedValueUtil.isProtobufTypeOf(TypedValue typedValue,
com.google.protobuf.Descriptors.Descriptor messageDescriptor) |
static <PB extends com.google.protobuf.Message> |
TypedValueUtil.unpackProtobufMessage(TypedValue typedValue,
com.google.protobuf.Parser<PB> protobufMessageParser) |
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 |
---|---|
org.apache.kafka.clients.producer.ProducerRecord<byte[],byte[]> |
GenericKafkaEgressSerializer.serialize(TypedValue message) |
Modifier and Type | Method and Description |
---|---|
EgressIdentifier<TypedValue> |
GenericKinesisEgressSpec.id() |
KinesisEgressSpec<TypedValue> |
GenericKinesisEgressSpec.toUniversalKinesisEgressSpec() |
Modifier and Type | Method and Description |
---|---|
EgressRecord |
GenericKinesisEgressSerializer.serialize(TypedValue value) |
Modifier and Type | Method and Description |
---|---|
TypedValue |
MessageWrapper.typedValue() |
TypedValue |
EgressMessageWrapper.typedValue() |
Constructor and Description |
---|
EgressMessageWrapper(TypeName targetEgressId,
TypedValue actualMessage) |
MessageWrapper(Address targetAddress,
TypedValue typedValue) |
Modifier and Type | Method and Description |
---|---|
TypedValue |
TypedValue.Builder.build() |
TypedValue |
TypedValue.Builder.buildPartial() |
TypedValue |
FromFunction.InvocationOrBuilder.getArgument()
The invocation argument (aka the message sent to the target function)
|
TypedValue |
FromFunction.Invocation.getArgument()
The invocation argument (aka the message sent to the target function)
|
TypedValue |
FromFunction.Invocation.Builder.getArgument()
The invocation argument (aka the message sent to the target function)
|
TypedValue |
FromFunction.DelayedInvocationOrBuilder.getArgument()
the invocation argument
|
TypedValue |
FromFunction.DelayedInvocation.getArgument()
the invocation argument
|
TypedValue |
FromFunction.DelayedInvocation.Builder.getArgument()
the invocation argument
|
TypedValue |
FromFunction.EgressMessageOrBuilder.getArgument()
egress argument
|
TypedValue |
FromFunction.EgressMessage.getArgument()
egress argument
|
TypedValue |
FromFunction.EgressMessage.Builder.getArgument()
egress argument
|
TypedValue |
ToFunction.InvocationOrBuilder.getArgument()
The invocation argument (aka the message sent to the target function)
|
TypedValue |
ToFunction.Invocation.getArgument()
The invocation argument (aka the message sent to the target function)
|
TypedValue |
ToFunction.Invocation.Builder.getArgument()
The invocation argument (aka the message sent to the target function)
|
static TypedValue |
TypedValue.getDefaultInstance() |
TypedValue |
TypedValue.getDefaultInstanceForType() |
TypedValue |
TypedValue.Builder.getDefaultInstanceForType() |
TypedValue |
FromFunction.PersistedValueMutationOrBuilder.getStateValue()
.io.statefun.sdk.reqreply.TypedValue state_value = 3; |
TypedValue |
FromFunction.PersistedValueMutation.getStateValue()
.io.statefun.sdk.reqreply.TypedValue state_value = 3; |
TypedValue |
FromFunction.PersistedValueMutation.Builder.getStateValue()
.io.statefun.sdk.reqreply.TypedValue state_value = 3; |
TypedValue |
ToFunction.PersistedValueOrBuilder.getStateValue()
The serialized state value
|
TypedValue |
ToFunction.PersistedValue.getStateValue()
The serialized state value
|
TypedValue |
ToFunction.PersistedValue.Builder.getStateValue()
The serialized state value
|
static TypedValue |
TypedValue.parseDelimitedFrom(java.io.InputStream input) |
static TypedValue |
TypedValue.parseDelimitedFrom(java.io.InputStream input,
ExtensionRegistryLite extensionRegistry) |
static TypedValue |
TypedValue.parseFrom(byte[] data) |
static TypedValue |
TypedValue.parseFrom(byte[] data,
ExtensionRegistryLite extensionRegistry) |
static TypedValue |
TypedValue.parseFrom(java.nio.ByteBuffer data) |
static TypedValue |
TypedValue.parseFrom(java.nio.ByteBuffer data,
ExtensionRegistryLite extensionRegistry) |
static TypedValue |
TypedValue.parseFrom(ByteString data) |
static TypedValue |
TypedValue.parseFrom(ByteString data,
ExtensionRegistryLite extensionRegistry) |
static TypedValue |
TypedValue.parseFrom(CodedInputStream input) |
static TypedValue |
TypedValue.parseFrom(CodedInputStream input,
ExtensionRegistryLite extensionRegistry) |
static TypedValue |
TypedValue.parseFrom(java.io.InputStream input) |
static TypedValue |
TypedValue.parseFrom(java.io.InputStream input,
ExtensionRegistryLite extensionRegistry) |
Modifier and Type | Method and Description |
---|---|
Parser<TypedValue> |
TypedValue.getParserForType() |
static Parser<TypedValue> |
TypedValue.parser() |
Modifier and Type | Method and Description |
---|---|
FromFunction.Invocation.Builder |
FromFunction.Invocation.Builder.mergeArgument(TypedValue value)
The invocation argument (aka the message sent to the target function)
|
FromFunction.DelayedInvocation.Builder |
FromFunction.DelayedInvocation.Builder.mergeArgument(TypedValue value)
the invocation argument
|
FromFunction.EgressMessage.Builder |
FromFunction.EgressMessage.Builder.mergeArgument(TypedValue value)
egress argument
|
ToFunction.Invocation.Builder |
ToFunction.Invocation.Builder.mergeArgument(TypedValue value)
The invocation argument (aka the message sent to the target function)
|
TypedValue.Builder |
TypedValue.Builder.mergeFrom(TypedValue other) |
FromFunction.PersistedValueMutation.Builder |
FromFunction.PersistedValueMutation.Builder.mergeStateValue(TypedValue value)
.io.statefun.sdk.reqreply.TypedValue state_value = 3; |
ToFunction.PersistedValue.Builder |
ToFunction.PersistedValue.Builder.mergeStateValue(TypedValue value)
The serialized state value
|
static TypedValue.Builder |
TypedValue.newBuilder(TypedValue prototype) |
FromFunction.Invocation.Builder |
FromFunction.Invocation.Builder.setArgument(TypedValue value)
The invocation argument (aka the message sent to the target function)
|
FromFunction.DelayedInvocation.Builder |
FromFunction.DelayedInvocation.Builder.setArgument(TypedValue value)
the invocation argument
|
FromFunction.EgressMessage.Builder |
FromFunction.EgressMessage.Builder.setArgument(TypedValue value)
egress argument
|
ToFunction.Invocation.Builder |
ToFunction.Invocation.Builder.setArgument(TypedValue value)
The invocation argument (aka the message sent to the target function)
|
FromFunction.PersistedValueMutation.Builder |
FromFunction.PersistedValueMutation.Builder.setStateValue(TypedValue value)
.io.statefun.sdk.reqreply.TypedValue state_value = 3; |
ToFunction.PersistedValue.Builder |
ToFunction.PersistedValue.Builder.setStateValue(TypedValue value)
The serialized state value
|
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.