All Classes Interface Summary Class Summary Enum Summary
Class |
Description |
AbstractArrowPythonAggregateFunctionOperator |
The Abstract class of Arrow Aggregate Operator for Pandas AggregateFunction .
|
AbstractBeamStateHandler<S> |
Abstract class extends BeamStateHandler , which implements the common handle logic.
|
AbstractEmbeddedDataStreamPythonFunctionOperator<OUT> |
Base class for all Python DataStream operators executed in embedded Python environment.
|
AbstractEmbeddedPythonFunctionOperator<OUT> |
Abstract class for all stream operators to execute Python functions in embedded Python
environment.
|
AbstractEmbeddedStatelessFunctionOperator |
Base class for all stream operators to execute Python Stateless Functions in embedded Python
environment.
|
AbstractExternalDataStreamPythonFunctionOperator<OUT> |
Base class for all Python DataStream operators executed in Python process.
|
AbstractExternalOneInputPythonFunctionOperator<IN,OUT> |
|
AbstractExternalPythonFunctionOperator<OUT> |
Abstract class for all stream operators to execute Python functions in external environment.
|
AbstractExternalTwoInputPythonFunctionOperator<IN1,IN2,OUT> |
|
AbstractOneInputEmbeddedPythonFunctionOperator<IN,OUT> |
|
AbstractOneInputPythonFunctionOperator<IN,OUT> |
Base class for all one input stream operators to execute Python functions.
|
AbstractPythonEnvironmentManager |
The base class of python environment manager which is used to create the PythonEnvironment object
used to execute Python functions.
|
AbstractPythonEnvironmentManager.PythonLeasedResource |
Python lease resource which includes environment variables and working directory of execution
python environment.
|
AbstractPythonFunctionOperator<OUT> |
Base class for all stream operators to execute Python functions.
|
AbstractPythonScalarFunctionOperator |
Base class for all stream operators to execute Python ScalarFunction s.
|
AbstractPythonStreamAggregateOperator |
|
AbstractPythonStreamGroupAggregateOperator |
|
AbstractStatelessFunctionOperator<IN,OUT,UDFIN> |
Base class for all stream operators to execute Python Stateless Functions.
|
AbstractStreamArrowPythonBoundedRangeOperator<K> |
The Abstract class of Stream Arrow Python AggregateFunction Operator for RANGE clause
bounded Over Window Aggregation.
|
AbstractStreamArrowPythonBoundedRowsOperator<K> |
The Abstract class of Stream Arrow Python AggregateFunction Operator for ROWS clause
bounded Over Window Aggregation.
|
AbstractStreamArrowPythonOverWindowAggregateFunctionOperator<K> |
The Abstract class of Stream Arrow Python AggregateFunction Operator for Over Window
Aggregation.
|
AbstractTwoInputEmbeddedPythonFunctionOperator<IN1,IN2,OUT> |
|
ArrayConstructor |
Creates arrays of objects.
|
ArrayDataSerializer |
A TypeSerializer for ArrayData .
|
ArrayDataSerializer.ArrayDataSerializerSnapshot |
|
ArrayWriter<T> |
|
ArrayWriter.ArrayWriterForArray |
|
ArrayWriter.ArrayWriterForRow |
|
ArrowArrayColumnVector |
Arrow column vector for Array.
|
ArrowBigIntColumnVector |
Arrow column vector for BigInt.
|
ArrowBinaryColumnVector |
Arrow column vector for Binary.
|
ArrowBooleanColumnVector |
Arrow column vector for Boolean.
|
ArrowDateColumnVector |
Arrow column vector for Date.
|
ArrowDecimalColumnVector |
Arrow column vector for DecimalData.
|
ArrowDoubleColumnVector |
Arrow column vector for Double.
|
ArrowFieldWriter<IN> |
Base class for arrow field writer which is used to convert a field to an Arrow format.
|
ArrowFloatColumnVector |
Arrow column vector for Float.
|
ArrowIntColumnVector |
Arrow column vector for Int.
|
ArrowMapColumnVector |
Arrow column vector for Map.
|
ArrowNullColumnVector |
Arrow column vector for Null.
|
ArrowPythonScalarFunctionOperator |
Arrow Python ScalarFunction operator.
|
ArrowReader |
ArrowReader which read the underlying Arrow format data as RowData .
|
ArrowRowColumnVector |
Arrow column vector for Row.
|
ArrowSerializer |
The base class ArrowSerializer which will serialize/deserialize RowType data to/from arrow bytes.
|
ArrowSmallIntColumnVector |
Arrow column vector for Int.
|
ArrowSourceFunction |
Deprecated.
|
ArrowTableSource |
A ScanTableSource for serialized arrow record batch data.
|
ArrowTableSourceFactory |
|
ArrowTableSourceOptions |
|
ArrowTimeColumnVector |
Arrow column vector for Time.
|
ArrowTimestampColumnVector |
Arrow column vector for Timestamp.
|
ArrowTinyIntColumnVector |
Arrow column vector for TinyInt.
|
ArrowUtils |
Utilities for Arrow.
|
ArrowVarBinaryColumnVector |
Arrow column vector for VarBinary.
|
ArrowVarCharColumnVector |
Arrow column vector for VarChar.
|
ArrowWriter<IN> |
Writer which serializes the Flink rows to Arrow format.
|
AvroRowDeserializationSchema |
Deserialization schema from Avro bytes to Row .
|
AvroRowSerializationSchema |
Serialization schema that serializes Row into Avro bytes.
|
BatchArrowPythonGroupAggregateFunctionOperator |
The Batch Arrow Python AggregateFunction Operator for Group Aggregation.
|
BatchArrowPythonGroupWindowAggregateFunctionOperator |
The Batch Arrow Python AggregateFunction Operator for Group Window Aggregation.
|
BatchArrowPythonOverWindowAggregateFunctionOperator |
The Batch Arrow Python AggregateFunction Operator for Over Window Aggregation.
|
BeamBagStateHandler |
BeamBagStateHandler handles operations on ListState , which backs Beam bag states.
|
BeamDataStreamPythonFunctionRunner |
|
BeamKeyedStateStore |
A BeamStateStore that returns keyed states based on BeamFnApi.StateRequest .
|
BeamMapStateHandler |
BeamMapStateHandler handles operations on a MapState .
|
BeamOperatorStateStore |
A BeamStateStore that returns operator states based on BeamFnApi.StateRequest .
|
BeamPythonFunctionRunner |
|
BeamStateHandler<S> |
Interface for doing actual operations on Flink state based on BeamFnApi.StateRequest .
|
BeamStateRequestHandler |
The handler for Beam state requests sent from Python side, which does actual operations on Flink
state.
|
BeamStateStore |
Interface for getting the underlying state based on Beam state request (keyed state or operator
state).
|
BeamTablePythonFunctionRunner |
|
BigDecSerializer |
We create the BigDecSerializer instead of using the BigDecSerializer of flink-core module for
performance reasons in Python deserialization.
|
BigDecSerializer.BigDecSerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
BigIntWriter<T> |
|
BigIntWriter.BigIntWriterForArray |
|
BigIntWriter.BigIntWriterForRow |
|
BinaryWriter<T> |
|
BinaryWriter.BinaryWriterForArray |
|
BinaryWriter.BinaryWriterForRow |
|
BooleanWriter<T> |
|
BooleanWriter.BooleanWriterForArray |
|
BooleanWriter.BooleanWriterForRow |
|
ByteArrayConstructor |
Creates byte arrays (byte[]).
|
ByteArrayUtils |
A utility class for converting byte[][] to String and String to byte[][].
|
ByteArrayWrapper |
A wrapper of the byte array.
|
ByteArrayWrapperSerializer |
|
ByteArrayWrapperSerializer.ByteArrayWrapperSerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
ChainingOptimizingExecutor |
Executor which will perform chaining optimization before generating the StreamGraph.
|
ClassLeakCleaner |
Utilities to clean up the leaking classes.
|
Constants |
constants.
|
CsvRowDeserializationSchema |
Deserialization schema from CSV to Flink types.
|
CsvRowDeserializationSchema.Builder |
|
CsvRowSerializationSchema |
Serialization schema that serializes an object of Flink types into a CSV bytes.
|
CsvRowSerializationSchema.Builder |
|
CustomTimestampAssigner<T> |
TimestampAssigner which extracts timestamp from the second field of the input element.
|
DataStreamPythonFunction |
DataStreamPythonFunction maintains the serialized python function which will be used in
BeamDataStreamPythonFunctionRunner.
|
DataStreamPythonFunctionInfo |
|
DataStreamPythonFunctionOperator<OUT> |
Interface for Python DataStream operators.
|
DateSerializer |
Takes int instead of long as the serialized value.
|
DateSerializer.DateSerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
DateWriter<T> |
|
DateWriter.DateWriterForArray |
|
DateWriter.DateWriterForRow |
|
DecimalDataSerializer |
We create the DecimalSerializer instead of using the DecimalSerializer of flink-table-runtime for
performance reasons in Python deserialization.
|
DecimalDataSerializer.DecimalSerializerSnapshot |
|
DecimalWriter<T> |
|
DecimalWriter.DecimalWriterForArray |
|
DecimalWriter.DecimalWriterForRow |
|
DefaultJobBundleFactory |
A JobBundleFactory for which the implementation can specify a custom EnvironmentFactory for environment management.
|
DefaultJobBundleFactory.ServerInfo |
A container for EnvironmentFactory and its corresponding Grpc servers.
|
DefaultJobBundleFactory.WrappedSdkHarnessClient |
Holder for an SdkHarnessClient along with its associated state and data servers.
|
DelegateOperatorTransformation<OUT> |
|
DelegateOperatorTransformation.DelegateOperator<OUT> |
|
DoubleWriter<T> |
|
DoubleWriter.DoubleWriterForArray |
|
DoubleWriter.DoubleWriterForRow |
|
EmbeddedPythonBatchCoBroadcastProcessOperator<IN1,IN2,OUT> |
|
EmbeddedPythonBatchKeyedCoBroadcastProcessOperator<K,IN1,IN2,OUT> |
|
EmbeddedPythonCoProcessOperator<IN1,IN2,OUT> |
|
EmbeddedPythonEnvironment |
|
EmbeddedPythonEnvironmentManager |
The base class of python environment manager which is used to create the PythonEnvironment
object.
|
EmbeddedPythonKeyedCoProcessOperator<K,IN1,IN2,OUT> |
|
EmbeddedPythonKeyedProcessOperator<K,IN,OUT> |
|
EmbeddedPythonProcessOperator<IN,OUT> |
|
EmbeddedPythonScalarFunctionOperator |
The Python ScalarFunction operator in embedded Python environment.
|
EmbeddedPythonTableFunctionOperator |
The Python TableFunction operator in embedded Python environment.
|
EmbeddedPythonWindowOperator<K,IN,OUT,W extends org.apache.flink.table.runtime.operators.window.Window> |
|
ExternalPythonBatchCoBroadcastProcessOperator<IN1,IN2,OUT> |
|
ExternalPythonBatchKeyedCoBroadcastProcessOperator<OUT> |
|
ExternalPythonCoProcessOperator<IN1,IN2,OUT> |
|
ExternalPythonKeyedCoProcessOperator<OUT> |
|
ExternalPythonKeyedProcessOperator<OUT> |
|
ExternalPythonProcessOperator<IN,OUT> |
ExternalPythonProcessOperator is responsible for launching beam runner which will start a
python harness to execute user defined python ProcessFunction.
|
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.ArrowTypeOrBuilder |
|
FlinkFnApi.CoderInfoDescriptor.Builder |
A representation of the coder
|
FlinkFnApi.CoderInfoDescriptor.DataTypeCase |
|
FlinkFnApi.CoderInfoDescriptor.FlattenRowType |
for Table & SQL
|
FlinkFnApi.CoderInfoDescriptor.FlattenRowType.Builder |
for Table & SQL
|
FlinkFnApi.CoderInfoDescriptor.FlattenRowTypeOrBuilder |
|
FlinkFnApi.CoderInfoDescriptor.Mode |
Protobuf enum org.apache.flink.fn_execution.v1.CoderInfoDescriptor.Mode
|
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.OverWindowArrowTypeOrBuilder |
|
FlinkFnApi.CoderInfoDescriptor.RawType |
for DataStream
|
FlinkFnApi.CoderInfoDescriptor.RawType.Builder |
for DataStream
|
FlinkFnApi.CoderInfoDescriptor.RawTypeOrBuilder |
|
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.CoderInfoDescriptor.RowTypeOrBuilder |
|
FlinkFnApi.CoderInfoDescriptorOrBuilder |
|
FlinkFnApi.GroupWindow |
Protobuf type org.apache.flink.fn_execution.v1.GroupWindow
|
FlinkFnApi.GroupWindow.Builder |
Protobuf type org.apache.flink.fn_execution.v1.GroupWindow
|
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.GroupWindowOrBuilder |
|
FlinkFnApi.Input |
Protobuf type org.apache.flink.fn_execution.v1.Input
|
FlinkFnApi.Input.Builder |
Protobuf type org.apache.flink.fn_execution.v1.Input
|
FlinkFnApi.Input.InputCase |
|
FlinkFnApi.InputOrBuilder |
|
FlinkFnApi.JobParameter |
Protobuf type org.apache.flink.fn_execution.v1.JobParameter
|
FlinkFnApi.JobParameter.Builder |
Protobuf type org.apache.flink.fn_execution.v1.JobParameter
|
FlinkFnApi.JobParameterOrBuilder |
|
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.OverWindow.WindowType |
Protobuf enum org.apache.flink.fn_execution.v1.OverWindow.WindowType
|
FlinkFnApi.OverWindowOrBuilder |
|
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.BinaryInfoOrBuilder |
|
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.CharInfoOrBuilder |
|
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.DecimalInfoOrBuilder |
|
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.FieldOrBuilder |
|
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.FieldType.TypeInfoCase |
|
FlinkFnApi.Schema.FieldTypeOrBuilder |
|
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.LocalZonedTimestampInfoOrBuilder |
|
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.MapInfoOrBuilder |
|
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.TimeInfoOrBuilder |
|
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.TimestampInfoOrBuilder |
|
FlinkFnApi.Schema.TypeName |
Protobuf enum org.apache.flink.fn_execution.v1.Schema.TypeName
|
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.VarBinaryInfoOrBuilder |
|
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.VarCharInfoOrBuilder |
|
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.Schema.ZonedTimestampInfoOrBuilder |
|
FlinkFnApi.SchemaOrBuilder |
|
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.EmptyCleanupStrategy |
Protobuf enum org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies.EmptyCleanupStrategy
|
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.IncrementalCleanupStrategyOrBuilder |
|
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.MapStrategiesEntry.CleanupStrategyCase |
|
FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntryOrBuilder |
|
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.StateDescriptor.StateTTLConfig.CleanupStrategies.RocksdbCompactFilterCleanupStrategyOrBuilder |
|
FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.Strategies |
Fixed strategies ordinals in strategies config field.
|
FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategiesOrBuilder |
|
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.StateDescriptor.StateTTLConfigOrBuilder |
|
FlinkFnApi.StateDescriptorOrBuilder |
|
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.AvroTypeInfoOrBuilder |
|
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.MapTypeInfoOrBuilder |
|
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.RowTypeInfo.FieldOrBuilder |
|
FlinkFnApi.TypeInfo.RowTypeInfoOrBuilder |
|
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.TypeInfo.TupleTypeInfoOrBuilder |
|
FlinkFnApi.TypeInfo.TypeInfoCase |
|
FlinkFnApi.TypeInfo.TypeName |
Protobuf enum org.apache.flink.fn_execution.v1.TypeInfo.TypeName
|
FlinkFnApi.TypeInfoOrBuilder |
|
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.DataViewCase |
|
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.ListViewOrBuilder |
|
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.UserDefinedAggregateFunction.DataViewSpec.MapViewOrBuilder |
|
FlinkFnApi.UserDefinedAggregateFunction.DataViewSpecOrBuilder |
|
FlinkFnApi.UserDefinedAggregateFunctionOrBuilder |
|
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.UserDefinedAggregateFunctionsOrBuilder |
|
FlinkFnApi.UserDefinedDataStreamFunction |
User defined DataStream function definition.
|
FlinkFnApi.UserDefinedDataStreamFunction.Builder |
User defined DataStream function definition.
|
FlinkFnApi.UserDefinedDataStreamFunction.FunctionType |
Protobuf enum org.apache.flink.fn_execution.v1.UserDefinedDataStreamFunction.FunctionType
|
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.UserDefinedDataStreamFunction.RuntimeContextOrBuilder |
|
FlinkFnApi.UserDefinedDataStreamFunctionOrBuilder |
|
FlinkFnApi.UserDefinedFunction |
User-defined function definition.
|
FlinkFnApi.UserDefinedFunction.Builder |
User-defined function definition.
|
FlinkFnApi.UserDefinedFunctionOrBuilder |
|
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.
|
FlinkFnApi.UserDefinedFunctionsOrBuilder |
|
FlinkMetricContainer |
Helper class for forwarding Python metrics to Java accumulators and metrics.
|
FlinkMetricContainer.FlinkDistributionGauge |
Flink Gauge for DistributionResult .
|
FlinkMetricContainer.FlinkGauge |
Flink Gauge for GaugeResult .
|
FloatWriter<T> |
|
FloatWriter.FloatWriterForArray |
|
FloatWriter.FloatWriterForRow |
|
GrpcStateService |
An implementation of the Beam Fn State service.
|
HashMapWrapper |
Helper class to create a HashMap taking Numeric data as key or value from Python side.
|
IdPartitioner |
Partitioner that partitions by id.
|
IntWriter<T> |
|
IntWriter.IntWriterForArray |
|
IntWriter.IntWriterForRow |
|
IterateType |
The type of the Python map state iterate request.
|
JsonRowDeserializationSchema |
Deserialization schema from JSON to Flink types.
|
JsonRowDeserializationSchema.Builder |
|
JsonRowSerializationSchema |
Serialization schema that serializes an object of Flink types into a JSON bytes.
|
JsonRowSerializationSchema.Builder |
|
KeyByKeySelector |
KeyByKeySelector is responsible for extracting the first field of the input row as key.
|
MapDataSerializer |
A TypeSerializer for MapData .
|
MapDataSerializer.BaseMapSerializerSnapshot |
|
MapWriter<T> |
|
MapWriter.MapWriterForArray |
|
MapWriter.MapWriterForRow |
|
MetricDistribution |
Flink Gauge for Python Distribution.
|
MetricGauge |
Flink Gauge for Python Gauge.
|
NullWriter<T> |
|
PartitionCustomKeySelector |
|
PickledByteArrayTypeInfo |
A PickledByteArrayTypeInfo indicates that the data of this type is a generated primitive byte
array by pickle.
|
ProcessPythonEnvironment |
|
ProcessPythonEnvironmentManager |
The ProcessPythonEnvironmentManager is used to prepare the working dir of python UDF worker and
create ProcessPythonEnvironment object of Beam Fn API.
|
ProtoUtils |
Utilities used to construct protobuf objects or construct objects from protobuf objects.
|
PythonBridgeUtils |
Utility class that contains helper methods to create a TableSource from a file which contains
Python objects.
|
PythonBroadcastStateTransformation<IN1,IN2,OUT> |
|
PythonBroadcastStateTransformationTranslator<IN1,IN2,OUT> |
|
PythonConfig |
Configurations for the Python job which are used at run time.
|
PythonConfigUtil |
A Util class to handle the configurations of Python jobs.
|
PythonConnectorUtils |
Utility class for using DataStream connectors in Python.
|
PythonConnectorUtils.FirstColumnTopicSelectorInvocationHandler |
|
PythonConnectorUtils.RowRowMapper |
A ProcessFunction that convert Row to RowData .
|
PythonConnectorUtils.SecondColumnSerializationSchema<T> |
|
PythonCsvUtils |
Utilities for using CSV format in PyFlink.
|
PythonDependencyInfo |
PythonDependencyInfo contains the information of third-party dependencies.
|
PythonDependencyUtils |
Utility class for Python dependency management.
|
PythonDriver |
A main class used to launch Python applications.
|
PythonDynamicTableFactory |
Table source factory for PythonDynamicTableSource.
|
PythonDynamicTableOptions |
Options for PythonDynamicTableSource.
|
PythonDynamicTableSource |
Implementation of ScanTableSource for python elements table.
|
PythonEnvironment |
The base interface of python environment for executing UDFs.
|
PythonEnvironmentManager |
The base interface of python environment manager which is used to create the PythonEnvironment
object used to execute Python functions.
|
PythonEnvironmentManagerUtils |
Utils used to prepare the python environment.
|
PythonFunctionFactory |
The factory which creates the PythonFunction objects from given module name and object name.
|
PythonFunctionFactory.CacheKey |
The cache key.
|
PythonFunctionFactoryImpl |
Default implementation of PythonFunctionFactory.
|
PythonFunctionRunner |
The base interface of runner which is responsible for the execution of Python functions.
|
PythonGatewayServer |
The Py4j Gateway Server provides RPC service for user's python process.
|
PythonGatewayServer.Watchdog |
A simple watch dog interface.
|
PythonKeyedBroadcastStateTransformation<OUT> |
|
PythonKeyedBroadcastStateTransformationTranslator<OUT> |
|
PythonOperatorChainingOptimizer |
A util class which attempts to chain all available Python functions.
|
PythonOperatorUtils |
Utilities used by Python operators.
|
PythonOptions |
Configuration options for the Python API.
|
PythonProgramOptions |
The class for command line options that refer to a Python program or JAR program with Python
command line options.
|
PythonScalarFunctionOperator |
The Python ScalarFunction operator.
|
PythonSharedResources |
The set of resources that can be shared by all the Python operators in a slot.
|
PythonShellParser |
Command line parser for Python shell.
|
PythonStreamGroupAggregateOperator |
The Python AggregateFunction operator.
|
PythonStreamGroupTableAggregateOperator |
The Python TableAggregateFunction operator.
|
PythonStreamGroupWindowAggregateOperator<K,W extends org.apache.flink.table.runtime.operators.window.Window> |
The Python Group Window AggregateFunction operator.
|
PythonTableFunctionOperator |
The Python TableFunction operator.
|
PythonTableUtils |
Python utilities.
|
PythonTypeUtils |
A util class for converting the given TypeInformation to other objects.
|
PythonTypeUtils |
Utilities for converting Flink logical types, such as convert it to the related TypeSerializer or
ProtoType.
|
PythonTypeUtils.ArrayDataConverter<T> |
The element in the Object Array will be converted to the corresponding Data through element
DataConverter.
|
PythonTypeUtils.ArrayDataConverter<T> |
The element in the Object Array will be converted to the corresponding Data through element
DataConverter.
|
PythonTypeUtils.ByteDataConverter |
Python Long will be converted to Long in PemJa, so we need ByteDataConverter to convert Java
Long to internal Byte.
|
PythonTypeUtils.ByteDataConverter |
Python Long will be converted to Long in PemJa, so we need ByteDataConverter to convert Java
Long to internal Byte.
|
PythonTypeUtils.DataConverter<IN,OUT> |
Data Converter that converts the data to the format data which can be used in PemJa.
|
PythonTypeUtils.DataConverter<IN,INTER,OUT> |
Data Converter that converts the data to the java format data which can be used in PemJa.
|
PythonTypeUtils.FloatDataConverter |
Python Float will be converted to Double in PemJa, so we need FloatDataConverter to convert
Java Double to internal Float.
|
PythonTypeUtils.FloatDataConverter |
Python Float will be converted to Double in PemJa, so we need FloatDataConverter to convert
Java Double to internal Float.
|
PythonTypeUtils.IdentityDataConverter<T> |
Identity data converter.
|
PythonTypeUtils.IdentityDataConverter<IN,OUT> |
Identity data converter.
|
PythonTypeUtils.IntDataConverter |
Python Long will be converted to Long in PemJa, so we need IntDataConverter to convert Java
Long to internal Integer.
|
PythonTypeUtils.IntDataConverter |
Python Long will be converted to Long in PemJa, so we need IntDataConverter to convert Java
Long to internal Integer.
|
PythonTypeUtils.ListDataConverter |
The element in the List will be converted to the corresponding Data through element
DataConverter.
|
PythonTypeUtils.LogicalTypeToProtoTypeConverter |
Converter That convert the logicalType to the related Prototype.
|
PythonTypeUtils.MapDataConverter |
The key/value in the Map will be converted to the corresponding Data through key/value
DataConverter.
|
PythonTypeUtils.MapDataConverter |
The key/value in the Map will be converted to the corresponding Data through key/value
DataConverter.
|
PythonTypeUtils.RowDataConverter |
Row Data will be converted to the Object Array [RowKind(as Long Object), Field Values(as
Object Array)].
|
PythonTypeUtils.RowDataConverter |
RowData will be converted to the Object Array [RowKind(as Long Object), Field Values(as
Object Array)].
|
PythonTypeUtils.RowDataDataConverter |
RowData Data will be converted to the Object Array [RowKind(as Long Object), Field Values(as
Object Array)].
|
PythonTypeUtils.ShortDataConverter |
Python Long will be converted to Long in PemJa, so we need ShortDataConverter to convert Java
Long to internal Short.
|
PythonTypeUtils.ShortDataConverter |
Python Long will be converted to Long in PemJa, so we need ShortDataConverter to convert Java
Long to internal Short.
|
PythonTypeUtils.TimeDataConverter |
Python datetime.time will be converted to Time in PemJa, so we need TimeDataConverter to
convert Java Double to internal Integer.
|
PythonTypeUtils.TupleDataConverter |
Tuple Data will be converted to the Object Array.
|
PythonTypeUtils.TypeInfoToDataConverter |
Get DataConverter according to the given typeInformation.
|
PythonTypeUtils.TypeInfoToProtoConverter |
Get coder proto according to the given type information.
|
PythonTypeUtils.TypeInfoToSerializerConverter |
Get serializers according to the given typeInformation.
|
RemoveTimestampMapFunction<T> |
MapFunction which removes the timestamp field from the input element.
|
RowDataSerializer |
A TypeSerializer for RowData .
|
RowDataSerializer.RowDataSerializerSnapshot |
|
RowWriter<T> |
|
RowWriter.RowWriterForArray |
|
RowWriter.RowWriterForRow |
|
RunnerOutputCollector<OUT> |
Output collector for Python UDF runner.
|
ServerFactory |
A gRPC server factory.
|
ServerFactory.InetSocketAddressServerFactory |
Creates a gRPC Server using the default server factory.
|
ServerFactory.UrlFactory |
Factory that constructs client-accessible URLs from a local server address and port.
|
SharedResourceHolder |
A holder for shared resource singletons.
|
SharedResourceHolder.Resource<T> |
Defines a resource, and the way to create and destroy instances of it.
|
SmallIntWriter<T> |
|
SmallIntWriter.SmallIntWriterForArray |
|
SmallIntWriter.SmallIntWriterForRow |
|
StreamArrowPythonGroupWindowAggregateFunctionOperator<K,W extends org.apache.flink.table.runtime.operators.window.Window> |
The Stream Arrow Python AggregateFunction Operator for Group Window Aggregation.
|
StreamArrowPythonProcTimeBoundedRangeOperator<K> |
The Stream Arrow Python AggregateFunction Operator for ROWS clause proc-time bounded OVER
window.
|
StreamArrowPythonProcTimeBoundedRowsOperator<K> |
The Stream Arrow Python AggregateFunction Operator for ROWS clause proc-time bounded OVER
window.
|
StreamArrowPythonRowTimeBoundedRangeOperator<K> |
The Stream Arrow Python AggregateFunction Operator for RANGE clause event-time bounded
OVER window.
|
StreamArrowPythonRowTimeBoundedRowsOperator<K> |
The Stream Arrow Python AggregateFunction Operator for RANGE clause event-time bounded
OVER window.
|
StreamRecordRowDataWrappingCollector |
The collector is used to convert a RowData to a StreamRecord .
|
StringSerializer |
We create the StringSerializer instead of using the StringSerializer of flink-core module because
the StringSerializer of flink-core module serialize every Char of String in serialize method and
deserialize the Char to build the String.
|
StringSerializer.StringSerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
TimerHandler |
Utilities to handle triggered timer.
|
TimerRegistration |
Handles the interaction with the Python worker for registering and deleting timers.
|
TimerRegistrationAction |
|
TimerUtils |
Utilities for timer.
|
TimeSerializer |
Uses int instead of long as the serialized value.
|
TimeSerializer.TimeSerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
TimestampSerializer |
Uses similar serialization/deserialization of SqlTimestampSerializer to serialize Timestamp.
|
TimestampSerializer.TimestampSerializerSnapshot |
|
TimestampWriter<T> |
|
TimestampWriter.TimestampWriterForArray |
|
TimestampWriter.TimestampWriterForRow |
|
TimeWriter<T> |
|
TimeWriter.TimeWriterForArray |
|
TimeWriter.TimeWriterForRow |
|
TinyIntWriter<T> |
|
TinyIntWriter.TinyIntWriterForArray |
|
TinyIntWriter.TinyIntWriterForRow |
|
VarBinaryWriter<T> |
|
VarBinaryWriter.VarBinaryWriterForArray |
|
VarBinaryWriter.VarBinaryWriterForRow |
|
VarCharWriter<T> |
|
VarCharWriter.VarCharWriterForArray |
|
VarCharWriter.VarCharWriterForRow |
|