package org.apache.flink.fn_execution.v1

Mouse Melon logoGet desktop application:
View/edit binary Protocol Buffers messages

message CoderInfoDescriptor

flink-fn-execution.proto:493

A representation of the coder

message CoderInfoDescriptor.ArrowType

flink-fn-execution.proto:503

Used in: CoderInfoDescriptor

message CoderInfoDescriptor.FlattenRowType

flink-fn-execution.proto:495

for Table & SQL

Used in: CoderInfoDescriptor

enum CoderInfoDescriptor.Mode

flink-fn-execution.proto:518

Used in: CoderInfoDescriptor

message CoderInfoDescriptor.OverWindowArrowType

flink-fn-execution.proto:509

only used in batch over window the data consists of [window data][arrow data]

Used in: CoderInfoDescriptor

message CoderInfoDescriptor.RawType

flink-fn-execution.proto:514

for DataStream

Used in: CoderInfoDescriptor

message CoderInfoDescriptor.RowType

flink-fn-execution.proto:499

Used in: CoderInfoDescriptor

message GroupWindow

flink-fn-execution.proto:129

Used in: UserDefinedAggregateFunctions

enum GroupWindow.WindowProperty

flink-fn-execution.proto:136

Used in: GroupWindow

enum GroupWindow.WindowType

flink-fn-execution.proto:130

Used in: GroupWindow

message Input

flink-fn-execution.proto:37

Used in: UserDefinedAggregateFunction, UserDefinedFunction

message JobParameter

flink-fn-execution.proto:28

Used in: UserDefinedAggregateFunctions, UserDefinedDataStreamFunction.RuntimeContext, UserDefinedFunctions

message OverWindow

flink-fn-execution.proto:77

Used to describe the info of over window in pandas batch over window aggregation

Used in: UserDefinedFunctions

enum OverWindow.WindowType

flink-fn-execution.proto:78

Used in: OverWindow

message Schema

flink-fn-execution.proto:195

A representation of the data schema.

Used in: CoderInfoDescriptor.ArrowType, CoderInfoDescriptor.FlattenRowType, CoderInfoDescriptor.OverWindowArrowType, CoderInfoDescriptor.RowType, Schema.FieldType

message Schema.BinaryInfo

flink-fn-execution.proto:247

Used in: FieldType

message Schema.CharInfo

flink-fn-execution.proto:255

Used in: FieldType

message Schema.DecimalInfo

flink-fn-execution.proto:242

Used in: FieldType

message Schema.Field

flink-fn-execution.proto:282

Used in: Schema

message Schema.FieldType

flink-fn-execution.proto:263

Used in: Field, MapInfo, UserDefinedAggregateFunction.DataViewSpec.ListView, UserDefinedAggregateFunction.DataViewSpec.MapView, UserDefinedAggregateFunctions

message Schema.LocalZonedTimestampInfo

flink-fn-execution.proto:234

Used in: FieldType

message Schema.MapInfo

flink-fn-execution.proto:221

Used in: FieldType

message Schema.TimeInfo

flink-fn-execution.proto:226

Used in: FieldType

message Schema.TimestampInfo

flink-fn-execution.proto:230

Used in: FieldType

enum Schema.TypeName

flink-fn-execution.proto:196

Used in: FieldType

message Schema.VarBinaryInfo

flink-fn-execution.proto:251

Used in: FieldType

message Schema.VarCharInfo

flink-fn-execution.proto:259

Used in: FieldType

message Schema.ZonedTimestampInfo

flink-fn-execution.proto:238

Used in: FieldType

message StateDescriptor

flink-fn-execution.proto:400

A representation of State

message StateDescriptor.StateTTLConfig

flink-fn-execution.proto:401

Used in: StateDescriptor

message StateDescriptor.StateTTLConfig.CleanupStrategies

flink-fn-execution.proto:430

TTL cleanup strategies.

Used in: StateTTLConfig

enum StateDescriptor.StateTTLConfig.CleanupStrategies.EmptyCleanupStrategy

flink-fn-execution.proto:438

Used in: MapStrategiesEntry

message StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategy

flink-fn-execution.proto:443

Configuration of cleanup strategy while taking the full snapshot.

Used in: MapStrategiesEntry

message StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry

flink-fn-execution.proto:457

Used in: CleanupStrategies

message StateDescriptor.StateTTLConfig.CleanupStrategies.RocksdbCompactFilterCleanupStrategy

flink-fn-execution.proto:452

Configuration of cleanup strategy using custom compaction filter in RocksDB.

Used in: MapStrategiesEntry

enum StateDescriptor.StateTTLConfig.CleanupStrategies.Strategies

flink-fn-execution.proto:432

Fixed strategies ordinals in strategies config field.

Used in: MapStrategiesEntry

enum StateDescriptor.StateTTLConfig.StateVisibility

flink-fn-execution.proto:415

This option configures whether expired user value can be returned or not.

Used in: StateTTLConfig

enum StateDescriptor.StateTTLConfig.TtlTimeCharacteristic

flink-fn-execution.proto:424

This option configures time scale to use for ttl.

Used in: StateTTLConfig

enum StateDescriptor.StateTTLConfig.UpdateType

flink-fn-execution.proto:403

This option value configures when to update last access timestamp which prolongs state TTL.

Used in: StateTTLConfig

message TypeInfo

flink-fn-execution.proto:296

A representation of the data type information in DataStream.

Used in: CoderInfoDescriptor.RawType, TypeInfo.MapTypeInfo, TypeInfo.RowTypeInfo.Field, TypeInfo.TupleTypeInfo, UserDefinedDataStreamFunction

message TypeInfo.AvroTypeInfo

flink-fn-execution.proto:345

Used in: TypeInfo

message TypeInfo.MapTypeInfo

flink-fn-execution.proto:328

Used in: TypeInfo

message TypeInfo.RowTypeInfo

flink-fn-execution.proto:333

Used in: TypeInfo

message TypeInfo.RowTypeInfo.Field

flink-fn-execution.proto:334

Used in: RowTypeInfo

message TypeInfo.TupleTypeInfo

flink-fn-execution.proto:341

Used in: TypeInfo

enum TypeInfo.TypeName

flink-fn-execution.proto:297

Used in: TypeInfo

message UserDefinedAggregateFunction

flink-fn-execution.proto:93

Used in: UserDefinedAggregateFunctions

message UserDefinedAggregateFunction.DataViewSpec

flink-fn-execution.proto:94

Used in: UserDefinedAggregateFunction

message UserDefinedAggregateFunction.DataViewSpec.ListView

flink-fn-execution.proto:95

Used in: DataViewSpec

message UserDefinedAggregateFunction.DataViewSpec.MapView

flink-fn-execution.proto:98

Used in: DataViewSpec

message UserDefinedAggregateFunctions

flink-fn-execution.proto:165

A list of the user-defined aggregate functions to be executed in a group aggregate operation.

message UserDefinedDataStreamFunction

flink-fn-execution.proto:360

User defined DataStream function definition.

enum UserDefinedDataStreamFunction.FunctionType

flink-fn-execution.proto:361

Used in: UserDefinedDataStreamFunction

message UserDefinedDataStreamFunction.RuntimeContext

flink-fn-execution.proto:372

Used in: UserDefinedDataStreamFunction

message UserDefinedFunction

flink-fn-execution.proto:47

User-defined function definition. It supports chaining functions, that's, the execution result of one user-defined function as the input of another user-defined function.

Used in: Input, UserDefinedFunctions

message UserDefinedFunctions

flink-fn-execution.proto:68

A list of user-defined functions to be executed in a batch.