Class | Description |
---|---|
FlinkFnApi | |
FlinkFnApi.CoderInfoDescriptor |
A representation of the coder
|
FlinkFnApi.CoderInfoDescriptor.ArrowType |
Protobuf type
org.apache.flink.fn_execution.v1.CoderInfoDescriptor.ArrowType |
FlinkFnApi.CoderInfoDescriptor.ArrowType.Builder |
Protobuf type
org.apache.flink.fn_execution.v1.CoderInfoDescriptor.ArrowType |
FlinkFnApi.CoderInfoDescriptor.Builder |
A representation of the coder
|
FlinkFnApi.CoderInfoDescriptor.FlattenRowType |
for Table & SQL
|
FlinkFnApi.CoderInfoDescriptor.FlattenRowType.Builder |
for Table & SQL
|
FlinkFnApi.CoderInfoDescriptor.OverWindowArrowType |
only used in batch over window
the data consists of [window data][arrow data]
|
FlinkFnApi.CoderInfoDescriptor.OverWindowArrowType.Builder |
only used in batch over window
the data consists of [window data][arrow data]
|
FlinkFnApi.CoderInfoDescriptor.RawType |
for DataStream
|
FlinkFnApi.CoderInfoDescriptor.RawType.Builder |
for DataStream
|
FlinkFnApi.CoderInfoDescriptor.RowType |
Protobuf type
org.apache.flink.fn_execution.v1.CoderInfoDescriptor.RowType |
FlinkFnApi.CoderInfoDescriptor.RowType.Builder |
Protobuf type
org.apache.flink.fn_execution.v1.CoderInfoDescriptor.RowType |
FlinkFnApi.GroupWindow |
Protobuf type
org.apache.flink.fn_execution.v1.GroupWindow |
FlinkFnApi.GroupWindow.Builder |
Protobuf type
org.apache.flink.fn_execution.v1.GroupWindow |
FlinkFnApi.Input |
Protobuf type
org.apache.flink.fn_execution.v1.Input |
FlinkFnApi.Input.Builder |
Protobuf type
org.apache.flink.fn_execution.v1.Input |
FlinkFnApi.OverWindow |
Used to describe the info of over window in pandas batch over window aggregation
|
FlinkFnApi.OverWindow.Builder |
Used to describe the info of over window in pandas batch over window aggregation
|
FlinkFnApi.Schema |
A representation of the data schema.
|
FlinkFnApi.Schema.BinaryInfo |
Protobuf type
org.apache.flink.fn_execution.v1.Schema.BinaryInfo |
FlinkFnApi.Schema.BinaryInfo.Builder |
Protobuf type
org.apache.flink.fn_execution.v1.Schema.BinaryInfo |
FlinkFnApi.Schema.Builder |
A representation of the data schema.
|
FlinkFnApi.Schema.CharInfo |
Protobuf type
org.apache.flink.fn_execution.v1.Schema.CharInfo |
FlinkFnApi.Schema.CharInfo.Builder |
Protobuf type
org.apache.flink.fn_execution.v1.Schema.CharInfo |
FlinkFnApi.Schema.DecimalInfo |
Protobuf type
org.apache.flink.fn_execution.v1.Schema.DecimalInfo |
FlinkFnApi.Schema.DecimalInfo.Builder |
Protobuf type
org.apache.flink.fn_execution.v1.Schema.DecimalInfo |
FlinkFnApi.Schema.Field |
Protobuf type
org.apache.flink.fn_execution.v1.Schema.Field |
FlinkFnApi.Schema.Field.Builder |
Protobuf type
org.apache.flink.fn_execution.v1.Schema.Field |
FlinkFnApi.Schema.FieldType |
Protobuf type
org.apache.flink.fn_execution.v1.Schema.FieldType |
FlinkFnApi.Schema.FieldType.Builder |
Protobuf type
org.apache.flink.fn_execution.v1.Schema.FieldType |
FlinkFnApi.Schema.LocalZonedTimestampInfo |
Protobuf type
org.apache.flink.fn_execution.v1.Schema.LocalZonedTimestampInfo |
FlinkFnApi.Schema.LocalZonedTimestampInfo.Builder |
Protobuf type
org.apache.flink.fn_execution.v1.Schema.LocalZonedTimestampInfo |
FlinkFnApi.Schema.MapInfo |
Protobuf type
org.apache.flink.fn_execution.v1.Schema.MapInfo |
FlinkFnApi.Schema.MapInfo.Builder |
Protobuf type
org.apache.flink.fn_execution.v1.Schema.MapInfo |
FlinkFnApi.Schema.TimeInfo |
Protobuf type
org.apache.flink.fn_execution.v1.Schema.TimeInfo |
FlinkFnApi.Schema.TimeInfo.Builder |
Protobuf type
org.apache.flink.fn_execution.v1.Schema.TimeInfo |
FlinkFnApi.Schema.TimestampInfo |
Protobuf type
org.apache.flink.fn_execution.v1.Schema.TimestampInfo |
FlinkFnApi.Schema.TimestampInfo.Builder |
Protobuf type
org.apache.flink.fn_execution.v1.Schema.TimestampInfo |
FlinkFnApi.Schema.VarBinaryInfo |
Protobuf type
org.apache.flink.fn_execution.v1.Schema.VarBinaryInfo |
FlinkFnApi.Schema.VarBinaryInfo.Builder |
Protobuf type
org.apache.flink.fn_execution.v1.Schema.VarBinaryInfo |
FlinkFnApi.Schema.VarCharInfo |
Protobuf type
org.apache.flink.fn_execution.v1.Schema.VarCharInfo |
FlinkFnApi.Schema.VarCharInfo.Builder |
Protobuf type
org.apache.flink.fn_execution.v1.Schema.VarCharInfo |
FlinkFnApi.Schema.ZonedTimestampInfo |
Protobuf type
org.apache.flink.fn_execution.v1.Schema.ZonedTimestampInfo |
FlinkFnApi.Schema.ZonedTimestampInfo.Builder |
Protobuf type
org.apache.flink.fn_execution.v1.Schema.ZonedTimestampInfo |
FlinkFnApi.StateDescriptor |
A representation of State
|
FlinkFnApi.StateDescriptor.Builder |
A representation of State
|
FlinkFnApi.StateDescriptor.StateTTLConfig |
Protobuf type
org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig |
FlinkFnApi.StateDescriptor.StateTTLConfig.Builder |
Protobuf type
org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig |
FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies |
TTL cleanup strategies.
|
FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.Builder |
TTL cleanup strategies.
|
FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategy |
Configuration of cleanup strategy while taking the full snapshot.
|
FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategy.Builder |
Configuration of cleanup strategy while taking the full snapshot.
|
FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry |
Protobuf type
org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry |
FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry.Builder |
Protobuf type
org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry |
FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.RocksdbCompactFilterCleanupStrategy |
Configuration of cleanup strategy using custom compaction filter in RocksDB.
|
FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.RocksdbCompactFilterCleanupStrategy.Builder |
Configuration of cleanup strategy using custom compaction filter in RocksDB.
|
FlinkFnApi.TypeInfo |
A representation of the data type information in DataStream.
|
FlinkFnApi.TypeInfo.AvroTypeInfo |
Protobuf type
org.apache.flink.fn_execution.v1.TypeInfo.AvroTypeInfo |
FlinkFnApi.TypeInfo.AvroTypeInfo.Builder |
Protobuf type
org.apache.flink.fn_execution.v1.TypeInfo.AvroTypeInfo |
FlinkFnApi.TypeInfo.Builder |
A representation of the data type information in DataStream.
|
FlinkFnApi.TypeInfo.MapTypeInfo |
Protobuf type
org.apache.flink.fn_execution.v1.TypeInfo.MapTypeInfo |
FlinkFnApi.TypeInfo.MapTypeInfo.Builder |
Protobuf type
org.apache.flink.fn_execution.v1.TypeInfo.MapTypeInfo |
FlinkFnApi.TypeInfo.RowTypeInfo |
Protobuf type
org.apache.flink.fn_execution.v1.TypeInfo.RowTypeInfo |
FlinkFnApi.TypeInfo.RowTypeInfo.Builder |
Protobuf type
org.apache.flink.fn_execution.v1.TypeInfo.RowTypeInfo |
FlinkFnApi.TypeInfo.RowTypeInfo.Field |
Protobuf type
org.apache.flink.fn_execution.v1.TypeInfo.RowTypeInfo.Field |
FlinkFnApi.TypeInfo.RowTypeInfo.Field.Builder |
Protobuf type
org.apache.flink.fn_execution.v1.TypeInfo.RowTypeInfo.Field |
FlinkFnApi.TypeInfo.TupleTypeInfo |
Protobuf type
org.apache.flink.fn_execution.v1.TypeInfo.TupleTypeInfo |
FlinkFnApi.TypeInfo.TupleTypeInfo.Builder |
Protobuf type
org.apache.flink.fn_execution.v1.TypeInfo.TupleTypeInfo |
FlinkFnApi.UserDefinedAggregateFunction |
Protobuf type
org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction |
FlinkFnApi.UserDefinedAggregateFunction.Builder |
Protobuf type
org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction |
FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec |
Protobuf type
org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction.DataViewSpec |
FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.Builder |
Protobuf type
org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction.DataViewSpec |
FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.ListView |
Protobuf type
org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction.DataViewSpec.ListView |
FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.ListView.Builder |
Protobuf type
org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction.DataViewSpec.ListView |
FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapView |
Protobuf type
org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction.DataViewSpec.MapView |
FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapView.Builder |
Protobuf type
org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction.DataViewSpec.MapView |
FlinkFnApi.UserDefinedAggregateFunctions |
A list of the user-defined aggregate functions to be executed in a group aggregate operation.
|
FlinkFnApi.UserDefinedAggregateFunctions.Builder |
A list of the user-defined aggregate functions to be executed in a group aggregate operation.
|
FlinkFnApi.UserDefinedDataStreamFunction |
User defined DataStream function definition.
|
FlinkFnApi.UserDefinedDataStreamFunction.Builder |
User defined DataStream function definition.
|
FlinkFnApi.UserDefinedDataStreamFunction.JobParameter |
Protobuf type
org.apache.flink.fn_execution.v1.UserDefinedDataStreamFunction.JobParameter |
FlinkFnApi.UserDefinedDataStreamFunction.JobParameter.Builder |
Protobuf type
org.apache.flink.fn_execution.v1.UserDefinedDataStreamFunction.JobParameter |
FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext |
Protobuf type
org.apache.flink.fn_execution.v1.UserDefinedDataStreamFunction.RuntimeContext |
FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder |
Protobuf type
org.apache.flink.fn_execution.v1.UserDefinedDataStreamFunction.RuntimeContext |
FlinkFnApi.UserDefinedFunction |
User-defined function definition.
|
FlinkFnApi.UserDefinedFunction.Builder |
User-defined function definition.
|
FlinkFnApi.UserDefinedFunctions |
A list of user-defined functions to be executed in a batch.
|
FlinkFnApi.UserDefinedFunctions.Builder |
A list of user-defined functions to be executed in a batch.
|
Enum | Description |
---|---|
FlinkFnApi.CoderInfoDescriptor.DataTypeCase | |
FlinkFnApi.CoderInfoDescriptor.Mode |
Protobuf enum
org.apache.flink.fn_execution.v1.CoderInfoDescriptor.Mode |
FlinkFnApi.GroupWindow.WindowProperty |
Protobuf enum
org.apache.flink.fn_execution.v1.GroupWindow.WindowProperty |
FlinkFnApi.GroupWindow.WindowType |
Protobuf enum
org.apache.flink.fn_execution.v1.GroupWindow.WindowType |
FlinkFnApi.Input.InputCase | |
FlinkFnApi.OverWindow.WindowType |
Protobuf enum
org.apache.flink.fn_execution.v1.OverWindow.WindowType |
FlinkFnApi.Schema.FieldType.TypeInfoCase | |
FlinkFnApi.Schema.TypeName |
Protobuf enum
org.apache.flink.fn_execution.v1.Schema.TypeName |
FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.EmptyCleanupStrategy |
Protobuf enum
org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies.EmptyCleanupStrategy |
FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry.CleanupStrategyCase | |
FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.Strategies |
Fixed strategies ordinals in strategies config field.
|
FlinkFnApi.StateDescriptor.StateTTLConfig.StateVisibility |
This option configures whether expired user value can be returned or not.
|
FlinkFnApi.StateDescriptor.StateTTLConfig.TtlTimeCharacteristic |
This option configures time scale to use for ttl.
|
FlinkFnApi.StateDescriptor.StateTTLConfig.UpdateType |
This option value configures when to update last access timestamp which prolongs state TTL.
|
FlinkFnApi.TypeInfo.TypeInfoCase | |
FlinkFnApi.TypeInfo.TypeName |
Protobuf enum
org.apache.flink.fn_execution.v1.TypeInfo.TypeName |
FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.DataViewCase | |
FlinkFnApi.UserDefinedDataStreamFunction.FunctionType |
Protobuf enum
org.apache.flink.fn_execution.v1.UserDefinedDataStreamFunction.FunctionType |
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.