protocol

package
v3.3.0 Latest Latest
Warning

This package is not in the latest version of its module.

Go to latest
Published: Sep 12, 2023 License: Apache-2.0 Imports: 4 Imported by: 0

Documentation

Index

Constants

This section is empty.

Variables

View Source
var (
	FromFunction_PersistedValueMutation_MutationType_name = map[int32]string{
		0: "DELETE",
		1: "MODIFY",
	}
	FromFunction_PersistedValueMutation_MutationType_value = map[string]int32{
		"DELETE": 0,
		"MODIFY": 1,
	}
)

Enum value maps for FromFunction_PersistedValueMutation_MutationType.

View Source
var (
	FromFunction_ExpirationSpec_ExpireMode_name = map[int32]string{
		0: "NONE",
		1: "AFTER_WRITE",
		2: "AFTER_INVOKE",
	}
	FromFunction_ExpirationSpec_ExpireMode_value = map[string]int32{
		"NONE":         0,
		"AFTER_WRITE":  1,
		"AFTER_INVOKE": 2,
	}
)

Enum value maps for FromFunction_ExpirationSpec_ExpireMode.

View Source
var File_kafka_egress_proto protoreflect.FileDescriptor
View Source
var File_kinesis_egress_proto protoreflect.FileDescriptor
View Source
var File_request_reply_proto protoreflect.FileDescriptor
View Source
var File_types_proto protoreflect.FileDescriptor

Functions

This section is empty.

Types

type Address

type Address struct {
	Namespace string `protobuf:"bytes,1,opt,name=namespace,proto3" json:"namespace,omitempty"`
	Type      string `protobuf:"bytes,2,opt,name=type,proto3" json:"type,omitempty"`
	Id        string `protobuf:"bytes,3,opt,name=id,proto3" json:"id,omitempty"`
	// contains filtered or unexported fields
}

An Address is the unique identity of an individual StatefulFunction, containing a function's type and an unique identifier within the type. The function's type denotes the "class" of function to invoke, while the unique identifier addresses the invocation to a specific function instance.

func (*Address) Descriptor deprecated

func (*Address) Descriptor() ([]byte, []int)

Deprecated: Use Address.ProtoReflect.Descriptor instead.

func (*Address) GetId

func (x *Address) GetId() string

func (*Address) GetNamespace

func (x *Address) GetNamespace() string

func (*Address) GetType

func (x *Address) GetType() string

func (*Address) ProtoMessage

func (*Address) ProtoMessage()

func (*Address) ProtoReflect

func (x *Address) ProtoReflect() protoreflect.Message

func (*Address) Reset

func (x *Address) Reset()

func (*Address) String

func (x *Address) String() string

type BooleanWrapper

type BooleanWrapper struct {
	Value bool `protobuf:"varint,1,opt,name=value,proto3" json:"value,omitempty"`
	// contains filtered or unexported fields
}

BooleanWrapper represents a StateFun primitive type of a boolean value. This is recognized as: io.statefun.types/bool

func (*BooleanWrapper) Descriptor deprecated

func (*BooleanWrapper) Descriptor() ([]byte, []int)

Deprecated: Use BooleanWrapper.ProtoReflect.Descriptor instead.

func (*BooleanWrapper) GetValue

func (x *BooleanWrapper) GetValue() bool

func (*BooleanWrapper) ProtoMessage

func (*BooleanWrapper) ProtoMessage()

func (*BooleanWrapper) ProtoReflect

func (x *BooleanWrapper) ProtoReflect() protoreflect.Message

func (*BooleanWrapper) Reset

func (x *BooleanWrapper) Reset()

func (*BooleanWrapper) String

func (x *BooleanWrapper) String() string

type DoubleWrapper

type DoubleWrapper struct {
	Value float64 `protobuf:"fixed64,1,opt,name=value,proto3" json:"value,omitempty"`
	// contains filtered or unexported fields
}

DoubleWrapper represents a StateFun primitive type of a double value. This is recognized as: io.statefun.types/double

func (*DoubleWrapper) Descriptor deprecated

func (*DoubleWrapper) Descriptor() ([]byte, []int)

Deprecated: Use DoubleWrapper.ProtoReflect.Descriptor instead.

func (*DoubleWrapper) GetValue

func (x *DoubleWrapper) GetValue() float64

func (*DoubleWrapper) ProtoMessage

func (*DoubleWrapper) ProtoMessage()

func (*DoubleWrapper) ProtoReflect

func (x *DoubleWrapper) ProtoReflect() protoreflect.Message

func (*DoubleWrapper) Reset

func (x *DoubleWrapper) Reset()

func (*DoubleWrapper) String

func (x *DoubleWrapper) String() string

type FloatWrapper

type FloatWrapper struct {
	Value float32 `protobuf:"fixed32,1,opt,name=value,proto3" json:"value,omitempty"`
	// contains filtered or unexported fields
}

FloatWrapper represents a StateFun primitive type of a signed float value. This is recognized as: io.statefun.types/float

func (*FloatWrapper) Descriptor deprecated

func (*FloatWrapper) Descriptor() ([]byte, []int)

Deprecated: Use FloatWrapper.ProtoReflect.Descriptor instead.

func (*FloatWrapper) GetValue

func (x *FloatWrapper) GetValue() float32

func (*FloatWrapper) ProtoMessage

func (*FloatWrapper) ProtoMessage()

func (*FloatWrapper) ProtoReflect

func (x *FloatWrapper) ProtoReflect() protoreflect.Message

func (*FloatWrapper) Reset

func (x *FloatWrapper) Reset()

func (*FloatWrapper) String

func (x *FloatWrapper) String() string

type FromFunction

type FromFunction struct {

	// Response sent from the function, as a result of an io.statefun.sdk.reqreply.ToFunction.InvocationBatchRequest.
	// It can be one of the following types:
	//   - io.statefun.sdk.reqreply.FromFunction.InvocationResponse
	//   - io.statefun.sdk.reqreply.FromFunction.IncompleteInvocationContext
	//
	// Types that are assignable to Response:
	//	*FromFunction_InvocationResult
	//	*FromFunction_IncompleteInvocationContext_
	Response isFromFunction_Response `protobuf_oneof:"response"`
	// contains filtered or unexported fields
}

The following section contains messages sent from a remote function back to Flink.

func (*FromFunction) Descriptor deprecated

func (*FromFunction) Descriptor() ([]byte, []int)

Deprecated: Use FromFunction.ProtoReflect.Descriptor instead.

func (*FromFunction) GetIncompleteInvocationContext

func (x *FromFunction) GetIncompleteInvocationContext() *FromFunction_IncompleteInvocationContext

func (*FromFunction) GetInvocationResult

func (x *FromFunction) GetInvocationResult() *FromFunction_InvocationResponse

func (*FromFunction) GetResponse

func (m *FromFunction) GetResponse() isFromFunction_Response

func (*FromFunction) ProtoMessage

func (*FromFunction) ProtoMessage()

func (*FromFunction) ProtoReflect

func (x *FromFunction) ProtoReflect() protoreflect.Message

func (*FromFunction) Reset

func (x *FromFunction) Reset()

func (*FromFunction) String

func (x *FromFunction) String() string

type FromFunction_DelayedInvocation

type FromFunction_DelayedInvocation struct {

	// a boolean value (default false) that indicates rather this is a regular delayed message, or (true) a message
	// cancellation request.
	// in case of a regular delayed message all other fields are expected to be preset, otherwise only the
	// cancellation_token is expected
	IsCancellationRequest bool `` /* 128-byte string literal not displayed */
	// an optional cancellation token that can be used to request the "unsending" of a delayed message.
	CancellationToken string `protobuf:"bytes,11,opt,name=cancellation_token,json=cancellationToken,proto3" json:"cancellation_token,omitempty"`
	// the amount of milliseconds to wait before sending this message
	DelayInMs int64 `protobuf:"varint,1,opt,name=delay_in_ms,json=delayInMs,proto3" json:"delay_in_ms,omitempty"`
	// the target address to send this message to
	Target *Address `protobuf:"bytes,2,opt,name=target,proto3" json:"target,omitempty"`
	// the invocation argument
	Argument *TypedValue `protobuf:"bytes,3,opt,name=argument,proto3" json:"argument,omitempty"`
	// contains filtered or unexported fields
}

DelayedInvocation represents a delayed remote function call with a target address, an argument and a delay in milliseconds, after which this message to be sent.

func (*FromFunction_DelayedInvocation) Descriptor deprecated

func (*FromFunction_DelayedInvocation) Descriptor() ([]byte, []int)

Deprecated: Use FromFunction_DelayedInvocation.ProtoReflect.Descriptor instead.

func (*FromFunction_DelayedInvocation) GetArgument

func (x *FromFunction_DelayedInvocation) GetArgument() *TypedValue

func (*FromFunction_DelayedInvocation) GetCancellationToken

func (x *FromFunction_DelayedInvocation) GetCancellationToken() string

func (*FromFunction_DelayedInvocation) GetDelayInMs

func (x *FromFunction_DelayedInvocation) GetDelayInMs() int64

func (*FromFunction_DelayedInvocation) GetIsCancellationRequest

func (x *FromFunction_DelayedInvocation) GetIsCancellationRequest() bool

func (*FromFunction_DelayedInvocation) GetTarget

func (x *FromFunction_DelayedInvocation) GetTarget() *Address

func (*FromFunction_DelayedInvocation) ProtoMessage

func (*FromFunction_DelayedInvocation) ProtoMessage()

func (*FromFunction_DelayedInvocation) ProtoReflect

func (*FromFunction_DelayedInvocation) Reset

func (x *FromFunction_DelayedInvocation) Reset()

func (*FromFunction_DelayedInvocation) String

type FromFunction_EgressMessage

type FromFunction_EgressMessage struct {

	// The target egress namespace
	EgressNamespace string `protobuf:"bytes,1,opt,name=egress_namespace,json=egressNamespace,proto3" json:"egress_namespace,omitempty"`
	// The target egress type
	EgressType string `protobuf:"bytes,2,opt,name=egress_type,json=egressType,proto3" json:"egress_type,omitempty"`
	// egress argument
	Argument *TypedValue `protobuf:"bytes,3,opt,name=argument,proto3" json:"argument,omitempty"`
	// contains filtered or unexported fields
}

EgressMessage an argument to forward to an egress. An egress is identified by a namespace and type (see EgressIdentifier SDK class). The argument is an io.statefun.sdk.reqreply.TypedValue.

func (*FromFunction_EgressMessage) Descriptor deprecated

func (*FromFunction_EgressMessage) Descriptor() ([]byte, []int)

Deprecated: Use FromFunction_EgressMessage.ProtoReflect.Descriptor instead.

func (*FromFunction_EgressMessage) GetArgument

func (x *FromFunction_EgressMessage) GetArgument() *TypedValue

func (*FromFunction_EgressMessage) GetEgressNamespace

func (x *FromFunction_EgressMessage) GetEgressNamespace() string

func (*FromFunction_EgressMessage) GetEgressType

func (x *FromFunction_EgressMessage) GetEgressType() string

func (*FromFunction_EgressMessage) ProtoMessage

func (*FromFunction_EgressMessage) ProtoMessage()

func (*FromFunction_EgressMessage) ProtoReflect

func (*FromFunction_EgressMessage) Reset

func (x *FromFunction_EgressMessage) Reset()

func (*FromFunction_EgressMessage) String

func (x *FromFunction_EgressMessage) String() string

type FromFunction_ExpirationSpec

type FromFunction_ExpirationSpec struct {
	Mode              FromFunction_ExpirationSpec_ExpireMode `` /* 131-byte string literal not displayed */
	ExpireAfterMillis int64                                  `protobuf:"varint,2,opt,name=expire_after_millis,json=expireAfterMillis,proto3" json:"expire_after_millis,omitempty"`
	// contains filtered or unexported fields
}

ExpirationSpec represents TTL (Time-To-Live) configuration for persisted states.

func (*FromFunction_ExpirationSpec) Descriptor deprecated

func (*FromFunction_ExpirationSpec) Descriptor() ([]byte, []int)

Deprecated: Use FromFunction_ExpirationSpec.ProtoReflect.Descriptor instead.

func (*FromFunction_ExpirationSpec) GetExpireAfterMillis

func (x *FromFunction_ExpirationSpec) GetExpireAfterMillis() int64

func (*FromFunction_ExpirationSpec) GetMode

func (*FromFunction_ExpirationSpec) ProtoMessage

func (*FromFunction_ExpirationSpec) ProtoMessage()

func (*FromFunction_ExpirationSpec) ProtoReflect

func (*FromFunction_ExpirationSpec) Reset

func (x *FromFunction_ExpirationSpec) Reset()

func (*FromFunction_ExpirationSpec) String

func (x *FromFunction_ExpirationSpec) String() string

type FromFunction_ExpirationSpec_ExpireMode

type FromFunction_ExpirationSpec_ExpireMode int32
const (
	FromFunction_ExpirationSpec_NONE         FromFunction_ExpirationSpec_ExpireMode = 0
	FromFunction_ExpirationSpec_AFTER_WRITE  FromFunction_ExpirationSpec_ExpireMode = 1
	FromFunction_ExpirationSpec_AFTER_INVOKE FromFunction_ExpirationSpec_ExpireMode = 2
)

func (FromFunction_ExpirationSpec_ExpireMode) Descriptor

func (FromFunction_ExpirationSpec_ExpireMode) Enum

func (FromFunction_ExpirationSpec_ExpireMode) EnumDescriptor deprecated

func (FromFunction_ExpirationSpec_ExpireMode) EnumDescriptor() ([]byte, []int)

Deprecated: Use FromFunction_ExpirationSpec_ExpireMode.Descriptor instead.

func (FromFunction_ExpirationSpec_ExpireMode) Number

func (FromFunction_ExpirationSpec_ExpireMode) String

func (FromFunction_ExpirationSpec_ExpireMode) Type

type FromFunction_IncompleteInvocationContext

type FromFunction_IncompleteInvocationContext struct {
	MissingValues []*FromFunction_PersistedValueSpec `protobuf:"bytes,1,rep,name=missing_values,json=missingValues,proto3" json:"missing_values,omitempty"`
	// contains filtered or unexported fields
}

IncompleteInvocationContext represents a result of an io.statefun.sdk.reqreply.ToFunction.InvocationBatchRequest, which should be used as the response if the InvocationBatchRequest provided incomplete information about the invocation, e.g. insufficient state values were provided.

func (*FromFunction_IncompleteInvocationContext) Descriptor deprecated

func (*FromFunction_IncompleteInvocationContext) Descriptor() ([]byte, []int)

Deprecated: Use FromFunction_IncompleteInvocationContext.ProtoReflect.Descriptor instead.

func (*FromFunction_IncompleteInvocationContext) GetMissingValues

func (*FromFunction_IncompleteInvocationContext) ProtoMessage

func (*FromFunction_IncompleteInvocationContext) ProtoReflect

func (*FromFunction_IncompleteInvocationContext) Reset

func (*FromFunction_IncompleteInvocationContext) String

type FromFunction_IncompleteInvocationContext_

type FromFunction_IncompleteInvocationContext_ struct {
	IncompleteInvocationContext *FromFunction_IncompleteInvocationContext `protobuf:"bytes,101,opt,name=incomplete_invocation_context,json=incompleteInvocationContext,proto3,oneof"`
}

type FromFunction_Invocation

type FromFunction_Invocation struct {

	// The target function to invoke
	Target *Address `protobuf:"bytes,1,opt,name=target,proto3" json:"target,omitempty"`
	// The invocation argument (aka the message sent to the target function)
	Argument *TypedValue `protobuf:"bytes,2,opt,name=argument,proto3" json:"argument,omitempty"`
	// contains filtered or unexported fields
}

Invocation represents a remote function call, it associated with a (mandatory) target address, and an argument.

func (*FromFunction_Invocation) Descriptor deprecated

func (*FromFunction_Invocation) Descriptor() ([]byte, []int)

Deprecated: Use FromFunction_Invocation.ProtoReflect.Descriptor instead.

func (*FromFunction_Invocation) GetArgument

func (x *FromFunction_Invocation) GetArgument() *TypedValue

func (*FromFunction_Invocation) GetTarget

func (x *FromFunction_Invocation) GetTarget() *Address

func (*FromFunction_Invocation) ProtoMessage

func (*FromFunction_Invocation) ProtoMessage()

func (*FromFunction_Invocation) ProtoReflect

func (x *FromFunction_Invocation) ProtoReflect() protoreflect.Message

func (*FromFunction_Invocation) Reset

func (x *FromFunction_Invocation) Reset()

func (*FromFunction_Invocation) String

func (x *FromFunction_Invocation) String() string

type FromFunction_InvocationResponse

type FromFunction_InvocationResponse struct {
	StateMutations     []*FromFunction_PersistedValueMutation `protobuf:"bytes,1,rep,name=state_mutations,json=stateMutations,proto3" json:"state_mutations,omitempty"`
	OutgoingMessages   []*FromFunction_Invocation             `protobuf:"bytes,2,rep,name=outgoing_messages,json=outgoingMessages,proto3" json:"outgoing_messages,omitempty"`
	DelayedInvocations []*FromFunction_DelayedInvocation      `protobuf:"bytes,3,rep,name=delayed_invocations,json=delayedInvocations,proto3" json:"delayed_invocations,omitempty"`
	OutgoingEgresses   []*FromFunction_EgressMessage          `protobuf:"bytes,4,rep,name=outgoing_egresses,json=outgoingEgresses,proto3" json:"outgoing_egresses,omitempty"`
	// contains filtered or unexported fields
}

InvocationResponse represents a result of an io.statefun.sdk.reqreply.ToFunction.InvocationBatchRequest it contains a list of state mutation to preform as a result of computing this batch, and a list of outgoing messages.

func (*FromFunction_InvocationResponse) Descriptor deprecated

func (*FromFunction_InvocationResponse) Descriptor() ([]byte, []int)

Deprecated: Use FromFunction_InvocationResponse.ProtoReflect.Descriptor instead.

func (*FromFunction_InvocationResponse) GetDelayedInvocations

func (*FromFunction_InvocationResponse) GetOutgoingEgresses

func (x *FromFunction_InvocationResponse) GetOutgoingEgresses() []*FromFunction_EgressMessage

func (*FromFunction_InvocationResponse) GetOutgoingMessages

func (x *FromFunction_InvocationResponse) GetOutgoingMessages() []*FromFunction_Invocation

func (*FromFunction_InvocationResponse) GetStateMutations

func (*FromFunction_InvocationResponse) ProtoMessage

func (*FromFunction_InvocationResponse) ProtoMessage()

func (*FromFunction_InvocationResponse) ProtoReflect

func (*FromFunction_InvocationResponse) Reset

func (*FromFunction_InvocationResponse) String

type FromFunction_InvocationResult

type FromFunction_InvocationResult struct {
	InvocationResult *FromFunction_InvocationResponse `protobuf:"bytes,100,opt,name=invocation_result,json=invocationResult,proto3,oneof"`
}

type FromFunction_PersistedValueMutation

type FromFunction_PersistedValueMutation struct {
	MutationType FromFunction_PersistedValueMutation_MutationType `` /* 177-byte string literal not displayed */
	StateName    string                                           `protobuf:"bytes,2,opt,name=state_name,json=stateName,proto3" json:"state_name,omitempty"`
	StateValue   *TypedValue                                      `protobuf:"bytes,3,opt,name=state_value,json=stateValue,proto3" json:"state_value,omitempty"`
	// contains filtered or unexported fields
}

MutatePersistedValueCommand represents a command sent from a remote function to Flink, requesting a change to a persisted value.

func (*FromFunction_PersistedValueMutation) Descriptor deprecated

func (*FromFunction_PersistedValueMutation) Descriptor() ([]byte, []int)

Deprecated: Use FromFunction_PersistedValueMutation.ProtoReflect.Descriptor instead.

func (*FromFunction_PersistedValueMutation) GetMutationType

func (*FromFunction_PersistedValueMutation) GetStateName

func (x *FromFunction_PersistedValueMutation) GetStateName() string

func (*FromFunction_PersistedValueMutation) GetStateValue

func (x *FromFunction_PersistedValueMutation) GetStateValue() *TypedValue

func (*FromFunction_PersistedValueMutation) ProtoMessage

func (*FromFunction_PersistedValueMutation) ProtoMessage()

func (*FromFunction_PersistedValueMutation) ProtoReflect

func (*FromFunction_PersistedValueMutation) Reset

func (*FromFunction_PersistedValueMutation) String

type FromFunction_PersistedValueMutation_MutationType

type FromFunction_PersistedValueMutation_MutationType int32
const (
	FromFunction_PersistedValueMutation_DELETE FromFunction_PersistedValueMutation_MutationType = 0
	FromFunction_PersistedValueMutation_MODIFY FromFunction_PersistedValueMutation_MutationType = 1
)

func (FromFunction_PersistedValueMutation_MutationType) Descriptor

func (FromFunction_PersistedValueMutation_MutationType) Enum

func (FromFunction_PersistedValueMutation_MutationType) EnumDescriptor deprecated

Deprecated: Use FromFunction_PersistedValueMutation_MutationType.Descriptor instead.

func (FromFunction_PersistedValueMutation_MutationType) Number

func (FromFunction_PersistedValueMutation_MutationType) String

func (FromFunction_PersistedValueMutation_MutationType) Type

type FromFunction_PersistedValueSpec

type FromFunction_PersistedValueSpec struct {
	StateName      string                       `protobuf:"bytes,1,opt,name=state_name,json=stateName,proto3" json:"state_name,omitempty"`
	ExpirationSpec *FromFunction_ExpirationSpec `protobuf:"bytes,2,opt,name=expiration_spec,json=expirationSpec,proto3" json:"expiration_spec,omitempty"`
	TypeTypename   string                       `protobuf:"bytes,3,opt,name=type_typename,json=typeTypename,proto3" json:"type_typename,omitempty"`
	// contains filtered or unexported fields
}

PersistedValueSpec represents specifications of a function's persisted value state.

func (*FromFunction_PersistedValueSpec) Descriptor deprecated

func (*FromFunction_PersistedValueSpec) Descriptor() ([]byte, []int)

Deprecated: Use FromFunction_PersistedValueSpec.ProtoReflect.Descriptor instead.

func (*FromFunction_PersistedValueSpec) GetExpirationSpec

func (*FromFunction_PersistedValueSpec) GetStateName

func (x *FromFunction_PersistedValueSpec) GetStateName() string

func (*FromFunction_PersistedValueSpec) GetTypeTypename

func (x *FromFunction_PersistedValueSpec) GetTypeTypename() string

func (*FromFunction_PersistedValueSpec) ProtoMessage

func (*FromFunction_PersistedValueSpec) ProtoMessage()

func (*FromFunction_PersistedValueSpec) ProtoReflect

func (*FromFunction_PersistedValueSpec) Reset

func (*FromFunction_PersistedValueSpec) String

type IntWrapper

type IntWrapper struct {
	Value int32 `protobuf:"fixed32,1,opt,name=value,proto3" json:"value,omitempty"`
	// contains filtered or unexported fields
}

IntWrapper represents a StateFun primitive type of an signed 32 bit integer value. This is recognized as: io.statefun.types/int

func (*IntWrapper) Descriptor deprecated

func (*IntWrapper) Descriptor() ([]byte, []int)

Deprecated: Use IntWrapper.ProtoReflect.Descriptor instead.

func (*IntWrapper) GetValue

func (x *IntWrapper) GetValue() int32

func (*IntWrapper) ProtoMessage

func (*IntWrapper) ProtoMessage()

func (*IntWrapper) ProtoReflect

func (x *IntWrapper) ProtoReflect() protoreflect.Message

func (*IntWrapper) Reset

func (x *IntWrapper) Reset()

func (*IntWrapper) String

func (x *IntWrapper) String() string

type KafkaProducerRecord

type KafkaProducerRecord struct {
	Key        string `protobuf:"bytes,1,opt,name=key,proto3" json:"key,omitempty"`
	ValueBytes []byte `protobuf:"bytes,2,opt,name=value_bytes,json=valueBytes,proto3" json:"value_bytes,omitempty"`
	Topic      string `protobuf:"bytes,3,opt,name=topic,proto3" json:"topic,omitempty"`
	// contains filtered or unexported fields
}

func (*KafkaProducerRecord) Descriptor deprecated

func (*KafkaProducerRecord) Descriptor() ([]byte, []int)

Deprecated: Use KafkaProducerRecord.ProtoReflect.Descriptor instead.

func (*KafkaProducerRecord) GetKey

func (x *KafkaProducerRecord) GetKey() string

func (*KafkaProducerRecord) GetTopic

func (x *KafkaProducerRecord) GetTopic() string

func (*KafkaProducerRecord) GetValueBytes

func (x *KafkaProducerRecord) GetValueBytes() []byte

func (*KafkaProducerRecord) ProtoMessage

func (*KafkaProducerRecord) ProtoMessage()

func (*KafkaProducerRecord) ProtoReflect

func (x *KafkaProducerRecord) ProtoReflect() protoreflect.Message

func (*KafkaProducerRecord) Reset

func (x *KafkaProducerRecord) Reset()

func (*KafkaProducerRecord) String

func (x *KafkaProducerRecord) String() string

type KinesisEgressRecord

type KinesisEgressRecord struct {
	PartitionKey    string `protobuf:"bytes,1,opt,name=partition_key,json=partitionKey,proto3" json:"partition_key,omitempty"`
	ValueBytes      []byte `protobuf:"bytes,2,opt,name=value_bytes,json=valueBytes,proto3" json:"value_bytes,omitempty"`
	Stream          string `protobuf:"bytes,3,opt,name=stream,proto3" json:"stream,omitempty"`
	ExplicitHashKey string `protobuf:"bytes,4,opt,name=explicit_hash_key,json=explicitHashKey,proto3" json:"explicit_hash_key,omitempty"`
	// contains filtered or unexported fields
}

func (*KinesisEgressRecord) Descriptor deprecated

func (*KinesisEgressRecord) Descriptor() ([]byte, []int)

Deprecated: Use KinesisEgressRecord.ProtoReflect.Descriptor instead.

func (*KinesisEgressRecord) GetExplicitHashKey

func (x *KinesisEgressRecord) GetExplicitHashKey() string

func (*KinesisEgressRecord) GetPartitionKey

func (x *KinesisEgressRecord) GetPartitionKey() string

func (*KinesisEgressRecord) GetStream

func (x *KinesisEgressRecord) GetStream() string

func (*KinesisEgressRecord) GetValueBytes

func (x *KinesisEgressRecord) GetValueBytes() []byte

func (*KinesisEgressRecord) ProtoMessage

func (*KinesisEgressRecord) ProtoMessage()

func (*KinesisEgressRecord) ProtoReflect

func (x *KinesisEgressRecord) ProtoReflect() protoreflect.Message

func (*KinesisEgressRecord) Reset

func (x *KinesisEgressRecord) Reset()

func (*KinesisEgressRecord) String

func (x *KinesisEgressRecord) String() string

type LongWrapper

type LongWrapper struct {
	Value int64 `protobuf:"fixed64,1,opt,name=value,proto3" json:"value,omitempty"`
	// contains filtered or unexported fields
}

LongWrapper represents a StateFun primitive type of a signed 64 bit long value. This is recognized as: io.statefun.types/long

func (*LongWrapper) Descriptor deprecated

func (*LongWrapper) Descriptor() ([]byte, []int)

Deprecated: Use LongWrapper.ProtoReflect.Descriptor instead.

func (*LongWrapper) GetValue

func (x *LongWrapper) GetValue() int64

func (*LongWrapper) ProtoMessage

func (*LongWrapper) ProtoMessage()

func (*LongWrapper) ProtoReflect

func (x *LongWrapper) ProtoReflect() protoreflect.Message

func (*LongWrapper) Reset

func (x *LongWrapper) Reset()

func (*LongWrapper) String

func (x *LongWrapper) String() string

type StringWrapper

type StringWrapper struct {
	Value string `protobuf:"bytes,1,opt,name=value,proto3" json:"value,omitempty"`
	// contains filtered or unexported fields
}

StringWrapper represents a StateFun string. This is recognized as: io.statefun.types/string

func (*StringWrapper) Descriptor deprecated

func (*StringWrapper) Descriptor() ([]byte, []int)

Deprecated: Use StringWrapper.ProtoReflect.Descriptor instead.

func (*StringWrapper) GetValue

func (x *StringWrapper) GetValue() string

func (*StringWrapper) ProtoMessage

func (*StringWrapper) ProtoMessage()

func (*StringWrapper) ProtoReflect

func (x *StringWrapper) ProtoReflect() protoreflect.Message

func (*StringWrapper) Reset

func (x *StringWrapper) Reset()

func (*StringWrapper) String

func (x *StringWrapper) String() string

type ToFunction

type ToFunction struct {

	// Types that are assignable to Request:
	//	*ToFunction_Invocation_
	Request isToFunction_Request `protobuf_oneof:"request"`
	// contains filtered or unexported fields
}

The following section contains all the message types that are sent from Flink to a remote function.

func (*ToFunction) Descriptor deprecated

func (*ToFunction) Descriptor() ([]byte, []int)

Deprecated: Use ToFunction.ProtoReflect.Descriptor instead.

func (*ToFunction) GetInvocation

func (x *ToFunction) GetInvocation() *ToFunction_InvocationBatchRequest

func (*ToFunction) GetRequest

func (m *ToFunction) GetRequest() isToFunction_Request

func (*ToFunction) ProtoMessage

func (*ToFunction) ProtoMessage()

func (*ToFunction) ProtoReflect

func (x *ToFunction) ProtoReflect() protoreflect.Message

func (*ToFunction) Reset

func (x *ToFunction) Reset()

func (*ToFunction) String

func (x *ToFunction) String() string

type ToFunction_Invocation

type ToFunction_Invocation struct {

	// The address of the function that requested the invocation (possibly absent)
	Caller *Address `protobuf:"bytes,1,opt,name=caller,proto3" json:"caller,omitempty"`
	// The invocation argument (aka the message sent to the target function)
	Argument *TypedValue `protobuf:"bytes,2,opt,name=argument,proto3" json:"argument,omitempty"`
	// contains filtered or unexported fields
}

Invocation represents a remote function call, it associated with an (optional) return address, and an argument.

func (*ToFunction_Invocation) Descriptor deprecated

func (*ToFunction_Invocation) Descriptor() ([]byte, []int)

Deprecated: Use ToFunction_Invocation.ProtoReflect.Descriptor instead.

func (*ToFunction_Invocation) GetArgument

func (x *ToFunction_Invocation) GetArgument() *TypedValue

func (*ToFunction_Invocation) GetCaller

func (x *ToFunction_Invocation) GetCaller() *Address

func (*ToFunction_Invocation) ProtoMessage

func (*ToFunction_Invocation) ProtoMessage()

func (*ToFunction_Invocation) ProtoReflect

func (x *ToFunction_Invocation) ProtoReflect() protoreflect.Message

func (*ToFunction_Invocation) Reset

func (x *ToFunction_Invocation) Reset()

func (*ToFunction_Invocation) String

func (x *ToFunction_Invocation) String() string

type ToFunction_InvocationBatchRequest

type ToFunction_InvocationBatchRequest struct {

	// The address of the function to invoke
	Target *Address `protobuf:"bytes,1,opt,name=target,proto3" json:"target,omitempty"`
	// A list of PersistedValues that were registered as a persisted state.
	State []*ToFunction_PersistedValue `protobuf:"bytes,2,rep,name=state,proto3" json:"state,omitempty"`
	// A non empty (at least one) list of invocations
	Invocations []*ToFunction_Invocation `protobuf:"bytes,3,rep,name=invocations,proto3" json:"invocations,omitempty"`
	// contains filtered or unexported fields
}

InvocationBatchRequest represents a request to invoke a remote function. It is always associated with a target address (the function to invoke), and a list of values for registered state.

func (*ToFunction_InvocationBatchRequest) Descriptor deprecated

func (*ToFunction_InvocationBatchRequest) Descriptor() ([]byte, []int)

Deprecated: Use ToFunction_InvocationBatchRequest.ProtoReflect.Descriptor instead.

func (*ToFunction_InvocationBatchRequest) GetInvocations

func (*ToFunction_InvocationBatchRequest) GetState

func (*ToFunction_InvocationBatchRequest) GetTarget

func (*ToFunction_InvocationBatchRequest) ProtoMessage

func (*ToFunction_InvocationBatchRequest) ProtoMessage()

func (*ToFunction_InvocationBatchRequest) ProtoReflect

func (*ToFunction_InvocationBatchRequest) Reset

func (*ToFunction_InvocationBatchRequest) String

type ToFunction_Invocation_

type ToFunction_Invocation_ struct {
	Invocation *ToFunction_InvocationBatchRequest `protobuf:"bytes,100,opt,name=invocation,proto3,oneof"`
}

type ToFunction_PersistedValue

type ToFunction_PersistedValue struct {

	// The unique name of the persisted state.
	StateName string `protobuf:"bytes,1,opt,name=state_name,json=stateName,proto3" json:"state_name,omitempty"`
	// The serialized state value
	StateValue *TypedValue `protobuf:"bytes,2,opt,name=state_value,json=stateValue,proto3" json:"state_value,omitempty"`
	// contains filtered or unexported fields
}

PersistedValue represents a PersistedValue's value that is managed by Flink on behalf of a remote function.

func (*ToFunction_PersistedValue) Descriptor deprecated

func (*ToFunction_PersistedValue) Descriptor() ([]byte, []int)

Deprecated: Use ToFunction_PersistedValue.ProtoReflect.Descriptor instead.

func (*ToFunction_PersistedValue) GetStateName

func (x *ToFunction_PersistedValue) GetStateName() string

func (*ToFunction_PersistedValue) GetStateValue

func (x *ToFunction_PersistedValue) GetStateValue() *TypedValue

func (*ToFunction_PersistedValue) ProtoMessage

func (*ToFunction_PersistedValue) ProtoMessage()

func (*ToFunction_PersistedValue) ProtoReflect

func (*ToFunction_PersistedValue) Reset

func (x *ToFunction_PersistedValue) Reset()

func (*ToFunction_PersistedValue) String

func (x *ToFunction_PersistedValue) String() string

type TypedValue

type TypedValue struct {
	Typename string `protobuf:"bytes,1,opt,name=typename,proto3" json:"typename,omitempty"`
	// has_value is set to differentiate a zero length value bytes explicitly set,
	// or a non existing value.
	HasValue bool   `protobuf:"varint,2,opt,name=has_value,json=hasValue,proto3" json:"has_value,omitempty"`
	Value    []byte `protobuf:"bytes,3,opt,name=value,proto3" json:"value,omitempty"`
	// contains filtered or unexported fields
}

func (*TypedValue) Descriptor deprecated

func (*TypedValue) Descriptor() ([]byte, []int)

Deprecated: Use TypedValue.ProtoReflect.Descriptor instead.

func (*TypedValue) GetHasValue

func (x *TypedValue) GetHasValue() bool

func (*TypedValue) GetTypename

func (x *TypedValue) GetTypename() string

func (*TypedValue) GetValue

func (x *TypedValue) GetValue() []byte

func (*TypedValue) ProtoMessage

func (*TypedValue) ProtoMessage()

func (*TypedValue) ProtoReflect

func (x *TypedValue) ProtoReflect() protoreflect.Message

func (*TypedValue) Reset

func (x *TypedValue) Reset()

func (*TypedValue) String

func (x *TypedValue) String() string

Jump to

Keyboard shortcuts

? : This menu
/ : Search site
f or F : Jump to
y or Y : Canonical URL