A B C D E F G H I J K L M N O P Q R S T U V W Z
All Classes All Packages
All Classes All Packages
All Classes All Packages
A
- AbstractArrowPythonAggregateFunctionOperator - Class in org.apache.flink.table.runtime.operators.python.aggregate.arrow
-
The Abstract class of Arrow Aggregate Operator for Pandas
AggregateFunction
. - AbstractArrowPythonAggregateFunctionOperator(Configuration, PythonFunctionInfo[], RowType, RowType, RowType, GeneratedProjection) - Constructor for class org.apache.flink.table.runtime.operators.python.aggregate.arrow.AbstractArrowPythonAggregateFunctionOperator
- AbstractBeamStateHandler<S> - Class in org.apache.flink.streaming.api.runners.python.beam.state
-
Abstract class extends
BeamStateHandler
, which implements the common handle logic. - AbstractBeamStateHandler() - Constructor for class org.apache.flink.streaming.api.runners.python.beam.state.AbstractBeamStateHandler
- AbstractEmbeddedDataStreamPythonFunctionOperator<OUT> - Class in org.apache.flink.streaming.api.operators.python.embedded
-
Base class for all Python DataStream operators executed in embedded Python environment.
- AbstractEmbeddedDataStreamPythonFunctionOperator(Configuration, DataStreamPythonFunctionInfo, TypeInformation<OUT>) - Constructor for class org.apache.flink.streaming.api.operators.python.embedded.AbstractEmbeddedDataStreamPythonFunctionOperator
- AbstractEmbeddedPythonFunctionOperator<OUT> - Class in org.apache.flink.streaming.api.operators.python.embedded
-
Abstract class for all stream operators to execute Python functions in embedded Python environment.
- AbstractEmbeddedPythonFunctionOperator(Configuration) - Constructor for class org.apache.flink.streaming.api.operators.python.embedded.AbstractEmbeddedPythonFunctionOperator
- AbstractEmbeddedStatelessFunctionOperator - Class in org.apache.flink.table.runtime.operators.python
-
Base class for all stream operators to execute Python Stateless Functions in embedded Python environment.
- AbstractEmbeddedStatelessFunctionOperator(Configuration, RowType, RowType, RowType, int[]) - Constructor for class org.apache.flink.table.runtime.operators.python.AbstractEmbeddedStatelessFunctionOperator
- AbstractExternalDataStreamPythonFunctionOperator<OUT> - Class in org.apache.flink.streaming.api.operators.python.process
-
Base class for all Python DataStream operators executed in Python process.
- AbstractExternalDataStreamPythonFunctionOperator(Configuration, DataStreamPythonFunctionInfo, TypeInformation<OUT>) - Constructor for class org.apache.flink.streaming.api.operators.python.process.AbstractExternalDataStreamPythonFunctionOperator
- AbstractExternalOneInputPythonFunctionOperator<IN,OUT> - Class in org.apache.flink.streaming.api.operators.python.process
-
AbstractExternalOneInputPythonFunctionOperator
is responsible for launching beam runner which will start a python harness to execute user defined python function. - AbstractExternalOneInputPythonFunctionOperator(Configuration, DataStreamPythonFunctionInfo, TypeInformation<IN>, TypeInformation<OUT>) - Constructor for class org.apache.flink.streaming.api.operators.python.process.AbstractExternalOneInputPythonFunctionOperator
- AbstractExternalPythonFunctionOperator<OUT> - Class in org.apache.flink.streaming.api.operators.python.process
-
Abstract class for all stream operators to execute Python functions in external environment.
- AbstractExternalPythonFunctionOperator(Configuration) - Constructor for class org.apache.flink.streaming.api.operators.python.process.AbstractExternalPythonFunctionOperator
- AbstractExternalTwoInputPythonFunctionOperator<IN1,IN2,OUT> - Class in org.apache.flink.streaming.api.operators.python.process
-
AbstractExternalTwoInputPythonFunctionOperator
is responsible for launching beam runner which will start a python harness to execute two-input user defined python function. - AbstractExternalTwoInputPythonFunctionOperator(Configuration, DataStreamPythonFunctionInfo, TypeInformation<IN1>, TypeInformation<IN2>, TypeInformation<OUT>) - Constructor for class org.apache.flink.streaming.api.operators.python.process.AbstractExternalTwoInputPythonFunctionOperator
- AbstractOneInputEmbeddedPythonFunctionOperator<IN,OUT> - Class in org.apache.flink.streaming.api.operators.python.embedded
-
AbstractOneInputEmbeddedPythonFunctionOperator
is responsible for run Python DataStream operators with one input in Embedded Python environment. - AbstractOneInputEmbeddedPythonFunctionOperator(Configuration, DataStreamPythonFunctionInfo, TypeInformation<IN>, TypeInformation<OUT>) - Constructor for class org.apache.flink.streaming.api.operators.python.embedded.AbstractOneInputEmbeddedPythonFunctionOperator
- AbstractOneInputPythonFunctionOperator<IN,OUT> - Class in org.apache.flink.table.runtime.operators.python
-
Base class for all one input stream operators to execute Python functions.
- AbstractOneInputPythonFunctionOperator(Configuration) - Constructor for class org.apache.flink.table.runtime.operators.python.AbstractOneInputPythonFunctionOperator
- AbstractPythonEnvironmentManager - Class in org.apache.flink.python.env
-
The base class of python environment manager which is used to create the PythonEnvironment object used to execute Python functions.
- AbstractPythonEnvironmentManager(PythonDependencyInfo, String[], Map<String, String>, JobID) - Constructor for class org.apache.flink.python.env.AbstractPythonEnvironmentManager
- AbstractPythonEnvironmentManager.PythonLeasedResource - Class in org.apache.flink.python.env
-
Python lease resource which includes environment variables and working directory of execution python environment.
- AbstractPythonFunctionOperator<OUT> - Class in org.apache.flink.streaming.api.operators.python
-
Base class for all stream operators to execute Python functions.
- AbstractPythonFunctionOperator(Configuration) - Constructor for class org.apache.flink.streaming.api.operators.python.AbstractPythonFunctionOperator
- AbstractPythonScalarFunctionOperator - Class in org.apache.flink.table.runtime.operators.python.scalar
-
Base class for all stream operators to execute Python
ScalarFunction
s. - AbstractPythonScalarFunctionOperator(Configuration, PythonFunctionInfo[], RowType, RowType, RowType, GeneratedProjection, GeneratedProjection) - Constructor for class org.apache.flink.table.runtime.operators.python.scalar.AbstractPythonScalarFunctionOperator
- AbstractPythonStreamAggregateOperator - Class in org.apache.flink.table.runtime.operators.python.aggregate
-
Base class for
AbstractPythonStreamGroupAggregateOperator
andPythonStreamGroupWindowAggregateOperator
. - AbstractPythonStreamAggregateOperator(Configuration, RowType, RowType, PythonAggregateFunctionInfo[], DataViewSpec[][], int[], int, boolean) - Constructor for class org.apache.flink.table.runtime.operators.python.aggregate.AbstractPythonStreamAggregateOperator
- AbstractPythonStreamGroupAggregateOperator - Class in org.apache.flink.table.runtime.operators.python.aggregate
-
Base class for
PythonStreamGroupAggregateOperator
andPythonStreamGroupTableAggregateOperator
. - AbstractPythonStreamGroupAggregateOperator(Configuration, RowType, RowType, PythonAggregateFunctionInfo[], DataViewSpec[][], int[], int, boolean, long, long) - Constructor for class org.apache.flink.table.runtime.operators.python.aggregate.AbstractPythonStreamGroupAggregateOperator
- AbstractStatelessFunctionOperator<IN,OUT,UDFIN> - Class in org.apache.flink.table.runtime.operators.python
-
Base class for all stream operators to execute Python Stateless Functions.
- AbstractStatelessFunctionOperator(Configuration, RowType, RowType, RowType) - Constructor for class org.apache.flink.table.runtime.operators.python.AbstractStatelessFunctionOperator
- AbstractStreamArrowPythonBoundedRangeOperator<K> - Class in org.apache.flink.table.runtime.operators.python.aggregate.arrow.stream
-
The Abstract class of Stream Arrow Python
AggregateFunction
Operator for RANGE clause bounded Over Window Aggregation. - AbstractStreamArrowPythonBoundedRangeOperator(Configuration, PythonFunctionInfo[], RowType, RowType, RowType, int, long, GeneratedProjection) - Constructor for class org.apache.flink.table.runtime.operators.python.aggregate.arrow.stream.AbstractStreamArrowPythonBoundedRangeOperator
- AbstractStreamArrowPythonBoundedRowsOperator<K> - Class in org.apache.flink.table.runtime.operators.python.aggregate.arrow.stream
-
The Abstract class of Stream Arrow Python
AggregateFunction
Operator for ROWS clause bounded Over Window Aggregation. - AbstractStreamArrowPythonBoundedRowsOperator(Configuration, long, long, PythonFunctionInfo[], RowType, RowType, RowType, int, long, GeneratedProjection) - Constructor for class org.apache.flink.table.runtime.operators.python.aggregate.arrow.stream.AbstractStreamArrowPythonBoundedRowsOperator
- AbstractStreamArrowPythonOverWindowAggregateFunctionOperator<K> - Class in org.apache.flink.table.runtime.operators.python.aggregate.arrow.stream
-
The Abstract class of Stream Arrow Python
AggregateFunction
Operator for Over Window Aggregation. - AbstractStreamArrowPythonOverWindowAggregateFunctionOperator(Configuration, PythonFunctionInfo[], RowType, RowType, RowType, int, long, GeneratedProjection) - Constructor for class org.apache.flink.table.runtime.operators.python.aggregate.arrow.stream.AbstractStreamArrowPythonOverWindowAggregateFunctionOperator
- AbstractTwoInputEmbeddedPythonFunctionOperator<IN1,IN2,OUT> - Class in org.apache.flink.streaming.api.operators.python.embedded
-
AbstractTwoInputEmbeddedPythonFunctionOperator
is responsible for run Python DataStream operators with two input user defined python function in Embedded Python environment. - AbstractTwoInputEmbeddedPythonFunctionOperator(Configuration, DataStreamPythonFunctionInfo, TypeInformation<IN1>, TypeInformation<IN2>, TypeInformation<OUT>) - Constructor for class org.apache.flink.streaming.api.operators.python.embedded.AbstractTwoInputEmbeddedPythonFunctionOperator
- addAllFields(Iterable<? extends FlinkFnApi.Schema.Field>) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Builder
-
repeated .org.apache.flink.fn_execution.v1.Schema.Field fields = 1;
- addAllFields(Iterable<? extends FlinkFnApi.TypeInfo.RowTypeInfo.Field>) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Builder
-
repeated .org.apache.flink.fn_execution.v1.TypeInfo.RowTypeInfo.Field fields = 1;
- addAllFieldTypes(Iterable<? extends FlinkFnApi.TypeInfo>) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TupleTypeInfo.Builder
-
repeated .org.apache.flink.fn_execution.v1.TypeInfo field_types = 1;
- addAllGrouping(Iterable<? extends Integer>) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
-
The array of the key indexes.
- addAllInputs(Iterable<? extends FlinkFnApi.Input>) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.Builder
-
The input arguments of the user-defined function, it could be one of the following: 1.
- addAllInputs(Iterable<? extends FlinkFnApi.Input>) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction.Builder
-
The input arguments of the user-defined function, it could be one of the following: 1.
- addAllJobParameters(Iterable<? extends FlinkFnApi.JobParameter>) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 14;
- addAllJobParameters(Iterable<? extends FlinkFnApi.JobParameter>) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder
-
repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 7;
- addAllJobParameters(Iterable<? extends FlinkFnApi.JobParameter>) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 5;
- addAllNamedProperties(Iterable<? extends FlinkFnApi.GroupWindow.WindowProperty>) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.Builder
-
repeated .org.apache.flink.fn_execution.v1.GroupWindow.WindowProperty namedProperties = 9;
- addAllNamedPropertiesValue(Iterable<Integer>) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.Builder
-
repeated .org.apache.flink.fn_execution.v1.GroupWindow.WindowProperty namedProperties = 9;
- addAllSpecs(Iterable<? extends FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec>) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.Builder
-
repeated .org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction.DataViewSpec specs = 3;
- addAllStrategies(Iterable<? extends FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry>) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.Builder
-
repeated .org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry strategies = 2;
- addAllUdfs(Iterable<? extends FlinkFnApi.UserDefinedAggregateFunction>) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction udfs = 1;
- addAllUdfs(Iterable<? extends FlinkFnApi.UserDefinedFunction>) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.UserDefinedFunction udfs = 1;
- addAllWindows(Iterable<? extends FlinkFnApi.OverWindow>) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.OverWindow windows = 3;
- addFields(int, FlinkFnApi.Schema.Field) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Builder
-
repeated .org.apache.flink.fn_execution.v1.Schema.Field fields = 1;
- addFields(int, FlinkFnApi.Schema.Field.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Builder
-
repeated .org.apache.flink.fn_execution.v1.Schema.Field fields = 1;
- addFields(int, FlinkFnApi.TypeInfo.RowTypeInfo.Field) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Builder
-
repeated .org.apache.flink.fn_execution.v1.TypeInfo.RowTypeInfo.Field fields = 1;
- addFields(int, FlinkFnApi.TypeInfo.RowTypeInfo.Field.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Builder
-
repeated .org.apache.flink.fn_execution.v1.TypeInfo.RowTypeInfo.Field fields = 1;
- addFields(FlinkFnApi.Schema.Field) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Builder
-
repeated .org.apache.flink.fn_execution.v1.Schema.Field fields = 1;
- addFields(FlinkFnApi.Schema.Field.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Builder
-
repeated .org.apache.flink.fn_execution.v1.Schema.Field fields = 1;
- addFields(FlinkFnApi.TypeInfo.RowTypeInfo.Field) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Builder
-
repeated .org.apache.flink.fn_execution.v1.TypeInfo.RowTypeInfo.Field fields = 1;
- addFields(FlinkFnApi.TypeInfo.RowTypeInfo.Field.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Builder
-
repeated .org.apache.flink.fn_execution.v1.TypeInfo.RowTypeInfo.Field fields = 1;
- addFieldsBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Builder
-
repeated .org.apache.flink.fn_execution.v1.Schema.Field fields = 1;
- addFieldsBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Builder
-
repeated .org.apache.flink.fn_execution.v1.TypeInfo.RowTypeInfo.Field fields = 1;
- addFieldsBuilder(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Builder
-
repeated .org.apache.flink.fn_execution.v1.Schema.Field fields = 1;
- addFieldsBuilder(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Builder
-
repeated .org.apache.flink.fn_execution.v1.TypeInfo.RowTypeInfo.Field fields = 1;
- addFieldTypes(int, FlinkFnApi.TypeInfo) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TupleTypeInfo.Builder
-
repeated .org.apache.flink.fn_execution.v1.TypeInfo field_types = 1;
- addFieldTypes(int, FlinkFnApi.TypeInfo.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TupleTypeInfo.Builder
-
repeated .org.apache.flink.fn_execution.v1.TypeInfo field_types = 1;
- addFieldTypes(FlinkFnApi.TypeInfo) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TupleTypeInfo.Builder
-
repeated .org.apache.flink.fn_execution.v1.TypeInfo field_types = 1;
- addFieldTypes(FlinkFnApi.TypeInfo.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TupleTypeInfo.Builder
-
repeated .org.apache.flink.fn_execution.v1.TypeInfo field_types = 1;
- addFieldTypesBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TupleTypeInfo.Builder
-
repeated .org.apache.flink.fn_execution.v1.TypeInfo field_types = 1;
- addFieldTypesBuilder(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TupleTypeInfo.Builder
-
repeated .org.apache.flink.fn_execution.v1.TypeInfo field_types = 1;
- addGrouping(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
-
The array of the key indexes.
- addInputs(int, FlinkFnApi.Input) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.Builder
-
The input arguments of the user-defined function, it could be one of the following: 1.
- addInputs(int, FlinkFnApi.Input) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction.Builder
-
The input arguments of the user-defined function, it could be one of the following: 1.
- addInputs(int, FlinkFnApi.Input.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.Builder
-
The input arguments of the user-defined function, it could be one of the following: 1.
- addInputs(int, FlinkFnApi.Input.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction.Builder
-
The input arguments of the user-defined function, it could be one of the following: 1.
- addInputs(FlinkFnApi.Input) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.Builder
-
The input arguments of the user-defined function, it could be one of the following: 1.
- addInputs(FlinkFnApi.Input) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction.Builder
-
The input arguments of the user-defined function, it could be one of the following: 1.
- addInputs(FlinkFnApi.Input.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.Builder
-
The input arguments of the user-defined function, it could be one of the following: 1.
- addInputs(FlinkFnApi.Input.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction.Builder
-
The input arguments of the user-defined function, it could be one of the following: 1.
- addInputsBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.Builder
-
The input arguments of the user-defined function, it could be one of the following: 1.
- addInputsBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction.Builder
-
The input arguments of the user-defined function, it could be one of the following: 1.
- addInputsBuilder(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.Builder
-
The input arguments of the user-defined function, it could be one of the following: 1.
- addInputsBuilder(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction.Builder
-
The input arguments of the user-defined function, it could be one of the following: 1.
- addJobParameters(int, FlinkFnApi.JobParameter) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 14;
- addJobParameters(int, FlinkFnApi.JobParameter) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder
-
repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 7;
- addJobParameters(int, FlinkFnApi.JobParameter) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 5;
- addJobParameters(int, FlinkFnApi.JobParameter.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 14;
- addJobParameters(int, FlinkFnApi.JobParameter.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder
-
repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 7;
- addJobParameters(int, FlinkFnApi.JobParameter.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 5;
- addJobParameters(FlinkFnApi.JobParameter) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 14;
- addJobParameters(FlinkFnApi.JobParameter) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder
-
repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 7;
- addJobParameters(FlinkFnApi.JobParameter) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 5;
- addJobParameters(FlinkFnApi.JobParameter.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 14;
- addJobParameters(FlinkFnApi.JobParameter.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder
-
repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 7;
- addJobParameters(FlinkFnApi.JobParameter.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 5;
- addJobParametersBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 14;
- addJobParametersBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder
-
repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 7;
- addJobParametersBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 5;
- addJobParametersBuilder(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 14;
- addJobParametersBuilder(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder
-
repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 7;
- addJobParametersBuilder(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 5;
- addNamedProperties(FlinkFnApi.GroupWindow.WindowProperty) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.Builder
-
repeated .org.apache.flink.fn_execution.v1.GroupWindow.WindowProperty namedProperties = 9;
- addNamedPropertiesValue(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.Builder
-
repeated .org.apache.flink.fn_execution.v1.GroupWindow.WindowProperty namedProperties = 9;
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.ArrowType.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.FlattenRowType.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.OverWindowArrowType.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RawType.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RowType.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.JobParameter.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.BinaryInfo.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.CharInfo.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.DecimalInfo.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Field.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.LocalZonedTimestampInfo.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.MapInfo.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimeInfo.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimestampInfo.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarBinaryInfo.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarCharInfo.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.ZonedTimestampInfo.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategy.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.RocksdbCompactFilterCleanupStrategy.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.AvroTypeInfo.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.MapTypeInfo.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Field.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TupleTypeInfo.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.ListView.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapView.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions.Builder
- addSideOutputTags(Collection<OutputTag<?>>) - Method in interface org.apache.flink.streaming.api.operators.python.DataStreamPythonFunctionOperator
-
Add a collection of
OutputTag
s to the operator. - addSideOutputTags(Collection<OutputTag<?>>) - Method in class org.apache.flink.streaming.api.operators.python.embedded.AbstractEmbeddedDataStreamPythonFunctionOperator
- addSideOutputTags(Collection<OutputTag<?>>) - Method in class org.apache.flink.streaming.api.operators.python.process.AbstractExternalDataStreamPythonFunctionOperator
- addSideOutputTags(Collection<OutputTag<?>>) - Method in class org.apache.flink.streaming.api.transformations.python.DelegateOperatorTransformation.DelegateOperator
- addSpecs(int, FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.Builder
-
repeated .org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction.DataViewSpec specs = 3;
- addSpecs(int, FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.Builder
-
repeated .org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction.DataViewSpec specs = 3;
- addSpecs(FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.Builder
-
repeated .org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction.DataViewSpec specs = 3;
- addSpecs(FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.Builder
-
repeated .org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction.DataViewSpec specs = 3;
- addSpecsBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.Builder
-
repeated .org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction.DataViewSpec specs = 3;
- addSpecsBuilder(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.Builder
-
repeated .org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction.DataViewSpec specs = 3;
- addStrategies(int, FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.Builder
-
repeated .org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry strategies = 2;
- addStrategies(int, FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.Builder
-
repeated .org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry strategies = 2;
- addStrategies(FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.Builder
-
repeated .org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry strategies = 2;
- addStrategies(FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.Builder
-
repeated .org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry strategies = 2;
- addStrategiesBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.Builder
-
repeated .org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry strategies = 2;
- addStrategiesBuilder(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.Builder
-
repeated .org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry strategies = 2;
- addUdfs(int, FlinkFnApi.UserDefinedAggregateFunction) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction udfs = 1;
- addUdfs(int, FlinkFnApi.UserDefinedAggregateFunction.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction udfs = 1;
- addUdfs(int, FlinkFnApi.UserDefinedFunction) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.UserDefinedFunction udfs = 1;
- addUdfs(int, FlinkFnApi.UserDefinedFunction.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.UserDefinedFunction udfs = 1;
- addUdfs(FlinkFnApi.UserDefinedAggregateFunction) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction udfs = 1;
- addUdfs(FlinkFnApi.UserDefinedAggregateFunction.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction udfs = 1;
- addUdfs(FlinkFnApi.UserDefinedFunction) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.UserDefinedFunction udfs = 1;
- addUdfs(FlinkFnApi.UserDefinedFunction.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.UserDefinedFunction udfs = 1;
- addUdfsBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction udfs = 1;
- addUdfsBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.UserDefinedFunction udfs = 1;
- addUdfsBuilder(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction udfs = 1;
- addUdfsBuilder(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.UserDefinedFunction udfs = 1;
- addWindows(int, FlinkFnApi.OverWindow) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.OverWindow windows = 3;
- addWindows(int, FlinkFnApi.OverWindow.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.OverWindow windows = 3;
- addWindows(FlinkFnApi.OverWindow) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.OverWindow windows = 3;
- addWindows(FlinkFnApi.OverWindow.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.OverWindow windows = 3;
- addWindowsBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.OverWindow windows = 3;
- addWindowsBuilder(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.OverWindow windows = 3;
- allocateAddressAndCreate(List<BindableService>, Endpoints.ApiServiceDescriptor.Builder) - Method in class org.apache.beam.sdk.fn.server.ServerFactory
-
Creates an instance of this server using an ephemeral address.
- allocateAddressAndCreate(List<BindableService>, Endpoints.ApiServiceDescriptor.Builder) - Method in class org.apache.beam.sdk.fn.server.ServerFactory.InetSocketAddressServerFactory
- ALLOWEDLATENESS_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow
- apply(StreamExecutionEnvironment) - Static method in class org.apache.flink.python.chain.PythonOperatorChainingOptimizer
-
Perform chaining optimization.
- apply(StreamExecutionEnvironment, Transformation<?>) - Static method in class org.apache.flink.python.chain.PythonOperatorChainingOptimizer
-
Perform chaining optimization.
- applyToConfiguration(Configuration) - Method in class org.apache.flink.client.cli.PythonProgramOptions
- ArrayConstructor - Class in org.apache.flink.api.common.python.pickle
-
Creates arrays of objects.
- ArrayConstructor() - Constructor for class org.apache.flink.api.common.python.pickle.ArrayConstructor
- ArrayDataSerializer - Class in org.apache.flink.table.runtime.typeutils.serializers.python
-
A
TypeSerializer
forArrayData
. - ArrayDataSerializer(LogicalType, TypeSerializer) - Constructor for class org.apache.flink.table.runtime.typeutils.serializers.python.ArrayDataSerializer
- ArrayDataSerializer.ArrayDataSerializerSnapshot - Class in org.apache.flink.table.runtime.typeutils.serializers.python
-
TypeSerializerSnapshot
forArrayDataSerializer
. - ArrayDataSerializerSnapshot() - Constructor for class org.apache.flink.table.runtime.typeutils.serializers.python.ArrayDataSerializer.ArrayDataSerializerSnapshot
- ArrayWriter<T> - Class in org.apache.flink.table.runtime.arrow.writers
-
ArrowFieldWriter
for Array. - ArrayWriter.ArrayWriterForArray - Class in org.apache.flink.table.runtime.arrow.writers
-
ArrayWriter
forArrayData
input. - ArrayWriter.ArrayWriterForRow - Class in org.apache.flink.table.runtime.arrow.writers
-
ArrayWriter
forRowData
input. - ARROW_TYPE - org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.DataTypeCase
- ARROW_TYPE_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor
- ArrowArrayColumnVector - Class in org.apache.flink.table.runtime.arrow.vectors
-
Arrow column vector for Array.
- ArrowArrayColumnVector(ListVector, ColumnVector) - Constructor for class org.apache.flink.table.runtime.arrow.vectors.ArrowArrayColumnVector
- ArrowBigIntColumnVector - Class in org.apache.flink.table.runtime.arrow.vectors
-
Arrow column vector for BigInt.
- ArrowBigIntColumnVector(BigIntVector) - Constructor for class org.apache.flink.table.runtime.arrow.vectors.ArrowBigIntColumnVector
- ArrowBinaryColumnVector - Class in org.apache.flink.table.runtime.arrow.vectors
-
Arrow column vector for Binary.
- ArrowBinaryColumnVector(FixedSizeBinaryVector) - Constructor for class org.apache.flink.table.runtime.arrow.vectors.ArrowBinaryColumnVector
- ArrowBooleanColumnVector - Class in org.apache.flink.table.runtime.arrow.vectors
-
Arrow column vector for Boolean.
- ArrowBooleanColumnVector(BitVector) - Constructor for class org.apache.flink.table.runtime.arrow.vectors.ArrowBooleanColumnVector
- ArrowDateColumnVector - Class in org.apache.flink.table.runtime.arrow.vectors
-
Arrow column vector for Date.
- ArrowDateColumnVector(DateDayVector) - Constructor for class org.apache.flink.table.runtime.arrow.vectors.ArrowDateColumnVector
- ArrowDecimalColumnVector - Class in org.apache.flink.table.runtime.arrow.vectors
-
Arrow column vector for DecimalData.
- ArrowDecimalColumnVector(DecimalVector) - Constructor for class org.apache.flink.table.runtime.arrow.vectors.ArrowDecimalColumnVector
- ArrowDoubleColumnVector - Class in org.apache.flink.table.runtime.arrow.vectors
-
Arrow column vector for Double.
- ArrowDoubleColumnVector(Float8Vector) - Constructor for class org.apache.flink.table.runtime.arrow.vectors.ArrowDoubleColumnVector
- ArrowFieldWriter<IN> - Class in org.apache.flink.table.runtime.arrow.writers
-
Base class for arrow field writer which is used to convert a field to an Arrow format.
- ArrowFieldWriter(ValueVector) - Constructor for class org.apache.flink.table.runtime.arrow.writers.ArrowFieldWriter
- ArrowFloatColumnVector - Class in org.apache.flink.table.runtime.arrow.vectors
-
Arrow column vector for Float.
- ArrowFloatColumnVector(Float4Vector) - Constructor for class org.apache.flink.table.runtime.arrow.vectors.ArrowFloatColumnVector
- ArrowIntColumnVector - Class in org.apache.flink.table.runtime.arrow.vectors
-
Arrow column vector for Int.
- ArrowIntColumnVector(IntVector) - Constructor for class org.apache.flink.table.runtime.arrow.vectors.ArrowIntColumnVector
- ArrowMapColumnVector - Class in org.apache.flink.table.runtime.arrow.vectors
-
Arrow column vector for Map.
- ArrowMapColumnVector(MapVector, ColumnVector, ColumnVector) - Constructor for class org.apache.flink.table.runtime.arrow.vectors.ArrowMapColumnVector
- ArrowNullColumnVector - Class in org.apache.flink.table.runtime.arrow.vectors
-
Arrow column vector for Null.
- ArrowPythonScalarFunctionOperator - Class in org.apache.flink.table.runtime.operators.python.scalar.arrow
-
Arrow Python
ScalarFunction
operator. - ArrowPythonScalarFunctionOperator(Configuration, PythonFunctionInfo[], RowType, RowType, RowType, GeneratedProjection, GeneratedProjection) - Constructor for class org.apache.flink.table.runtime.operators.python.scalar.arrow.ArrowPythonScalarFunctionOperator
- ArrowReader - Class in org.apache.flink.table.runtime.arrow
-
ArrowReader
which read the underlying Arrow format data asRowData
. - ArrowReader(ColumnVector[]) - Constructor for class org.apache.flink.table.runtime.arrow.ArrowReader
- ArrowRowColumnVector - Class in org.apache.flink.table.runtime.arrow.vectors
-
Arrow column vector for Row.
- ArrowRowColumnVector(StructVector, ColumnVector[]) - Constructor for class org.apache.flink.table.runtime.arrow.vectors.ArrowRowColumnVector
- arrowSerializer - Variable in class org.apache.flink.table.runtime.operators.python.aggregate.arrow.AbstractArrowPythonAggregateFunctionOperator
- ArrowSerializer - Class in org.apache.flink.table.runtime.arrow.serializers
-
The base class ArrowSerializer which will serialize/deserialize RowType data to/from arrow bytes.
- ArrowSerializer(RowType, RowType) - Constructor for class org.apache.flink.table.runtime.arrow.serializers.ArrowSerializer
- ArrowSmallIntColumnVector - Class in org.apache.flink.table.runtime.arrow.vectors
-
Arrow column vector for Int.
- ArrowSmallIntColumnVector(SmallIntVector) - Constructor for class org.apache.flink.table.runtime.arrow.vectors.ArrowSmallIntColumnVector
- ArrowSourceFunction - Class in org.apache.flink.table.runtime.arrow.sources
-
Deprecated.This class is based on the
SourceFunction
API, which is due to be removed. Use the newSource
API instead. - ArrowTableSource - Class in org.apache.flink.table.runtime.arrow.sources
-
A
ScanTableSource
for serialized arrow record batch data. - ArrowTableSource(DataType, String) - Constructor for class org.apache.flink.table.runtime.arrow.sources.ArrowTableSource
- ArrowTableSourceFactory - Class in org.apache.flink.table.runtime.arrow.sources
-
Factory for creating configured instances of
ArrowTableSource
.. - ArrowTableSourceFactory() - Constructor for class org.apache.flink.table.runtime.arrow.sources.ArrowTableSourceFactory
- ArrowTableSourceOptions - Class in org.apache.flink.table.runtime.arrow.sources
-
Table options for the
ArrowTableSource
. - ArrowTableSourceOptions() - Constructor for class org.apache.flink.table.runtime.arrow.sources.ArrowTableSourceOptions
- ArrowTimeColumnVector - Class in org.apache.flink.table.runtime.arrow.vectors
-
Arrow column vector for Time.
- ArrowTimeColumnVector(ValueVector) - Constructor for class org.apache.flink.table.runtime.arrow.vectors.ArrowTimeColumnVector
- ArrowTimestampColumnVector - Class in org.apache.flink.table.runtime.arrow.vectors
-
Arrow column vector for Timestamp.
- ArrowTimestampColumnVector(ValueVector) - Constructor for class org.apache.flink.table.runtime.arrow.vectors.ArrowTimestampColumnVector
- ArrowTinyIntColumnVector - Class in org.apache.flink.table.runtime.arrow.vectors
-
Arrow column vector for TinyInt.
- ArrowTinyIntColumnVector(TinyIntVector) - Constructor for class org.apache.flink.table.runtime.arrow.vectors.ArrowTinyIntColumnVector
- ArrowUtils - Class in org.apache.flink.table.runtime.arrow
-
Utilities for Arrow.
- ArrowUtils() - Constructor for class org.apache.flink.table.runtime.arrow.ArrowUtils
- ArrowVarBinaryColumnVector - Class in org.apache.flink.table.runtime.arrow.vectors
-
Arrow column vector for VarBinary.
- ArrowVarBinaryColumnVector(VarBinaryVector) - Constructor for class org.apache.flink.table.runtime.arrow.vectors.ArrowVarBinaryColumnVector
- ArrowVarCharColumnVector - Class in org.apache.flink.table.runtime.arrow.vectors
-
Arrow column vector for VarChar.
- ArrowVarCharColumnVector(VarCharVector) - Constructor for class org.apache.flink.table.runtime.arrow.vectors.ArrowVarCharColumnVector
- ArrowWriter<IN> - Class in org.apache.flink.table.runtime.arrow
-
Writer which serializes the Flink rows to Arrow format.
- ArrowWriter(VectorSchemaRoot, ArrowFieldWriter<IN>[]) - Constructor for class org.apache.flink.table.runtime.arrow.ArrowWriter
- asMap() - Method in class org.apache.flink.python.util.HashMapWrapper
- asSummaryString() - Method in class org.apache.flink.table.runtime.arrow.sources.ArrowTableSource
- asSummaryString() - Method in class org.apache.flink.table.utils.python.PythonDynamicTableSource
- ATTEMPT_NUMBER_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext
- AVRO - org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TypeName
-
AVRO = 23;
- AVRO_TYPE_INFO - org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TypeInfoCase
- AVRO_TYPE_INFO_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo
- AVRO_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TypeName
-
AVRO = 23;
- AvroRowDeserializationSchema - Class in org.apache.flink.formats.avro
-
Deserialization schema from Avro bytes to
Row
. - AvroRowDeserializationSchema(Class<? extends SpecificRecord>) - Constructor for class org.apache.flink.formats.avro.AvroRowDeserializationSchema
-
Creates a Avro deserialization schema for the given specific record class.
- AvroRowDeserializationSchema(String) - Constructor for class org.apache.flink.formats.avro.AvroRowDeserializationSchema
-
Creates a Avro deserialization schema for the given Avro schema string.
- AvroRowSerializationSchema - Class in org.apache.flink.formats.avro
-
Serialization schema that serializes
Row
into Avro bytes. - AvroRowSerializationSchema(Class<? extends SpecificRecord>) - Constructor for class org.apache.flink.formats.avro.AvroRowSerializationSchema
-
Creates an Avro serialization schema for the given specific record class.
- AvroRowSerializationSchema(String) - Constructor for class org.apache.flink.formats.avro.AvroRowSerializationSchema
-
Creates an Avro serialization schema for the given Avro schema string.
B
- bais - Variable in class org.apache.flink.table.runtime.operators.python.AbstractStatelessFunctionOperator
-
Reusable InputStream used to holding the execution results to be deserialized.
- bais - Variable in class org.apache.flink.table.runtime.operators.python.aggregate.AbstractPythonStreamAggregateOperator
-
Reusable InputStream used to holding the execution results to be deserialized.
- baisWrapper - Variable in class org.apache.flink.table.runtime.operators.python.AbstractStatelessFunctionOperator
-
InputStream Wrapper.
- baisWrapper - Variable in class org.apache.flink.table.runtime.operators.python.aggregate.AbstractPythonStreamAggregateOperator
-
InputStream Wrapper.
- baos - Variable in class org.apache.flink.streaming.api.operators.python.process.AbstractExternalOneInputPythonFunctionOperator
-
Reusable OutputStream used to holding the serialized input elements.
- baos - Variable in class org.apache.flink.streaming.api.operators.python.process.AbstractExternalTwoInputPythonFunctionOperator
- baos - Variable in class org.apache.flink.table.runtime.operators.python.AbstractStatelessFunctionOperator
-
Reusable OutputStream used to holding the serialized input elements.
- baos - Variable in class org.apache.flink.table.runtime.operators.python.aggregate.AbstractPythonStreamAggregateOperator
-
Reusable OutputStream used to holding the serialized input elements.
- baosWrapper - Variable in class org.apache.flink.streaming.api.operators.python.process.AbstractExternalOneInputPythonFunctionOperator
-
OutputStream Wrapper.
- baosWrapper - Variable in class org.apache.flink.streaming.api.operators.python.process.AbstractExternalTwoInputPythonFunctionOperator
- baosWrapper - Variable in class org.apache.flink.table.runtime.operators.python.AbstractStatelessFunctionOperator
-
OutputStream Wrapper.
- baosWrapper - Variable in class org.apache.flink.table.runtime.operators.python.aggregate.AbstractPythonStreamAggregateOperator
-
OutputStream Wrapper.
- baseDirectory - Variable in class org.apache.flink.python.env.AbstractPythonEnvironmentManager.PythonLeasedResource
-
The base directory of the Python Environment.
- BaseMapSerializerSnapshot() - Constructor for class org.apache.flink.table.runtime.typeutils.serializers.python.MapDataSerializer.BaseMapSerializerSnapshot
- BASIC_ARRAY - org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TypeName
-
BASIC_ARRAY = 16;
- BASIC_ARRAY - org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TypeName
-
BASIC_ARRAY = 15;
- BASIC_ARRAY_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TypeName
-
BASIC_ARRAY = 16;
- BASIC_ARRAY_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TypeName
-
BASIC_ARRAY = 15;
- BATCH_MODE - Static variable in class org.apache.flink.table.utils.python.PythonDynamicTableOptions
- BatchArrowPythonGroupAggregateFunctionOperator - Class in org.apache.flink.table.runtime.operators.python.aggregate.arrow.batch
-
The Batch Arrow Python
AggregateFunction
Operator for Group Aggregation. - BatchArrowPythonGroupAggregateFunctionOperator(Configuration, PythonFunctionInfo[], RowType, RowType, RowType, GeneratedProjection, GeneratedProjection, GeneratedProjection) - Constructor for class org.apache.flink.table.runtime.operators.python.aggregate.arrow.batch.BatchArrowPythonGroupAggregateFunctionOperator
- BatchArrowPythonGroupWindowAggregateFunctionOperator - Class in org.apache.flink.table.runtime.operators.python.aggregate.arrow.batch
-
The Batch Arrow Python
AggregateFunction
Operator for Group Window Aggregation. - BatchArrowPythonGroupWindowAggregateFunctionOperator(Configuration, PythonFunctionInfo[], RowType, RowType, RowType, int, int, long, long, int[], GeneratedProjection, GeneratedProjection, GeneratedProjection) - Constructor for class org.apache.flink.table.runtime.operators.python.aggregate.arrow.batch.BatchArrowPythonGroupWindowAggregateFunctionOperator
- BatchArrowPythonOverWindowAggregateFunctionOperator - Class in org.apache.flink.table.runtime.operators.python.aggregate.arrow.batch
-
The Batch Arrow Python
AggregateFunction
Operator for Over Window Aggregation. - BatchArrowPythonOverWindowAggregateFunctionOperator(Configuration, PythonFunctionInfo[], RowType, RowType, RowType, long[], long[], boolean[], int[], int, boolean, GeneratedProjection, GeneratedProjection, GeneratedProjection) - Constructor for class org.apache.flink.table.runtime.operators.python.aggregate.arrow.batch.BatchArrowPythonOverWindowAggregateFunctionOperator
- BeamBagStateHandler - Class in org.apache.flink.streaming.api.runners.python.beam.state
-
BeamBagStateHandler handles operations on
ListState
, which backs Beam bag states. - BeamBagStateHandler(TypeSerializer<?>) - Constructor for class org.apache.flink.streaming.api.runners.python.beam.state.BeamBagStateHandler
- BeamDataStreamPythonFunctionRunner - Class in org.apache.flink.streaming.api.runners.python.beam
-
BeamDataStreamPythonFunctionRunner
is responsible for starting a beam python harness to execute user defined python function. - BeamDataStreamPythonFunctionRunner(Environment, String, ProcessPythonEnvironmentManager, String, List<FlinkFnApi.UserDefinedDataStreamFunction>, FlinkMetricContainer, KeyedStateBackend<?>, OperatorStateBackend, TypeSerializer<?>, TypeSerializer<?>, TimerRegistration, MemoryManager, double, FlinkFnApi.CoderInfoDescriptor, FlinkFnApi.CoderInfoDescriptor, FlinkFnApi.CoderInfoDescriptor, Map<String, FlinkFnApi.CoderInfoDescriptor>) - Constructor for class org.apache.flink.streaming.api.runners.python.beam.BeamDataStreamPythonFunctionRunner
- BeamKeyedStateStore - Class in org.apache.flink.streaming.api.runners.python.beam.state
-
A
BeamStateStore
that returns keyed states based onBeamFnApi.StateRequest
. - BeamKeyedStateStore(KeyedStateBackend<?>, TypeSerializer<?>, TypeSerializer<?>) - Constructor for class org.apache.flink.streaming.api.runners.python.beam.state.BeamKeyedStateStore
- BeamMapStateHandler - Class in org.apache.flink.streaming.api.runners.python.beam.state
-
BeamMapStateHandler handles operations on a
MapState
. - BeamMapStateHandler(ReadableConfig) - Constructor for class org.apache.flink.streaming.api.runners.python.beam.state.BeamMapStateHandler
- BeamOperatorStateStore - Class in org.apache.flink.streaming.api.runners.python.beam.state
-
A
BeamStateStore
that returns operator states based onBeamFnApi.StateRequest
. - BeamOperatorStateStore(OperatorStateBackend) - Constructor for class org.apache.flink.streaming.api.runners.python.beam.state.BeamOperatorStateStore
- BeamPythonFunctionRunner - Class in org.apache.flink.streaming.api.runners.python.beam
-
A
BeamPythonFunctionRunner
used to execute Python functions. - BeamPythonFunctionRunner(Environment, String, ProcessPythonEnvironmentManager, FlinkMetricContainer, KeyedStateBackend<?>, OperatorStateBackend, TypeSerializer<?>, TypeSerializer<?>, TimerRegistration, MemoryManager, double, FlinkFnApi.CoderInfoDescriptor, FlinkFnApi.CoderInfoDescriptor, Map<String, FlinkFnApi.CoderInfoDescriptor>) - Constructor for class org.apache.flink.streaming.api.runners.python.beam.BeamPythonFunctionRunner
- BeamStateHandler<S> - Interface in org.apache.flink.streaming.api.runners.python.beam.state
-
Interface for doing actual operations on Flink state based on
BeamFnApi.StateRequest
. - BeamStateRequestHandler - Class in org.apache.flink.streaming.api.runners.python.beam.state
-
The handler for Beam state requests sent from Python side, which does actual operations on Flink state.
- BeamStateRequestHandler(BeamStateStore, BeamStateStore, BeamStateHandler<ListState<byte[]>>, BeamStateHandler<MapState<ByteArrayWrapper, byte[]>>) - Constructor for class org.apache.flink.streaming.api.runners.python.beam.state.BeamStateRequestHandler
- BeamStateStore - Interface in org.apache.flink.streaming.api.runners.python.beam.state
-
Interface for getting the underlying state based on Beam state request (keyed state or operator state).
- BeamTablePythonFunctionRunner - Class in org.apache.flink.table.runtime.runners.python.beam
-
A
BeamTablePythonFunctionRunner
used to execute Python functions in Table API. - BeamTablePythonFunctionRunner(Environment, String, ProcessPythonEnvironmentManager, String, GeneratedMessageV3, FlinkMetricContainer, KeyedStateBackend<?>, TypeSerializer<?>, TypeSerializer<?>, MemoryManager, double, FlinkFnApi.CoderInfoDescriptor, FlinkFnApi.CoderInfoDescriptor) - Constructor for class org.apache.flink.table.runtime.runners.python.beam.BeamTablePythonFunctionRunner
- BIG_DEC - org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TypeName
-
BIG_DEC = 11;
- BIG_DEC_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TypeName
-
BIG_DEC = 11;
- BIG_INT - org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TypeName
-
BIG_INT = 10;
- BIG_INT_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TypeName
-
BIG_INT = 10;
- BigDecSerializer - Class in org.apache.flink.table.runtime.typeutils.serializers.python
-
We create the BigDecSerializer instead of using the BigDecSerializer of flink-core module for performance reasons in Python deserialization.
- BigDecSerializer() - Constructor for class org.apache.flink.table.runtime.typeutils.serializers.python.BigDecSerializer
- BigDecSerializer.BigDecSerializerSnapshot - Class in org.apache.flink.table.runtime.typeutils.serializers.python
-
Serializer configuration snapshot for compatibility and format evolution.
- BigDecSerializerSnapshot() - Constructor for class org.apache.flink.table.runtime.typeutils.serializers.python.BigDecSerializer.BigDecSerializerSnapshot
- BIGINT - org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TypeName
-
BIGINT = 4;
- BIGINT_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TypeName
-
BIGINT = 4;
- BigIntWriter<T> - Class in org.apache.flink.table.runtime.arrow.writers
-
ArrowFieldWriter
for BigInt. - BigIntWriter.BigIntWriterForArray - Class in org.apache.flink.table.runtime.arrow.writers
-
BigIntWriter
forArrayData
input. - BigIntWriter.BigIntWriterForRow - Class in org.apache.flink.table.runtime.arrow.writers
-
BigIntWriter
forRowData
input. - BINARY - org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TypeName
-
BINARY = 12;
- BINARY_INFO - org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.TypeInfoCase
- BINARY_INFO_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
- BINARY_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TypeName
-
BINARY = 12;
- BinaryWriter<T> - Class in org.apache.flink.table.runtime.arrow.writers
-
ArrowFieldWriter
for Binary. - BinaryWriter.BinaryWriterForArray - Class in org.apache.flink.table.runtime.arrow.writers
-
BinaryWriter
forArrayData
input. - BinaryWriter.BinaryWriterForRow - Class in org.apache.flink.table.runtime.arrow.writers
-
BinaryWriter
forRowData
input. - BOOLEAN - org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TypeName
-
BOOLEAN = 11;
- BOOLEAN - org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TypeName
-
BOOLEAN = 3;
- BOOLEAN_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TypeName
-
BOOLEAN = 11;
- BOOLEAN_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TypeName
-
BOOLEAN = 3;
- BooleanWriter<T> - Class in org.apache.flink.table.runtime.arrow.writers
-
ArrowFieldWriter
for Boolean. - BooleanWriter.BooleanWriterForArray - Class in org.apache.flink.table.runtime.arrow.writers
-
BooleanWriter
forArrayData
input. - BooleanWriter.BooleanWriterForRow - Class in org.apache.flink.table.runtime.arrow.writers
-
BooleanWriter
forRowData
input. - bufferInput(IN) - Method in class org.apache.flink.table.runtime.operators.python.AbstractStatelessFunctionOperator
-
Buffers the specified input, it will be used to construct the operator result together with the user-defined function execution result.
- bufferInput(RowData) - Method in class org.apache.flink.table.runtime.operators.python.aggregate.arrow.batch.BatchArrowPythonGroupAggregateFunctionOperator
- bufferInput(RowData) - Method in class org.apache.flink.table.runtime.operators.python.aggregate.arrow.batch.BatchArrowPythonGroupWindowAggregateFunctionOperator
- bufferInput(RowData) - Method in class org.apache.flink.table.runtime.operators.python.aggregate.arrow.batch.BatchArrowPythonOverWindowAggregateFunctionOperator
- bufferInput(RowData) - Method in class org.apache.flink.table.runtime.operators.python.aggregate.arrow.stream.StreamArrowPythonGroupWindowAggregateFunctionOperator
- bufferInput(RowData) - Method in class org.apache.flink.table.runtime.operators.python.aggregate.arrow.stream.StreamArrowPythonProcTimeBoundedRangeOperator
- bufferInput(RowData) - Method in class org.apache.flink.table.runtime.operators.python.aggregate.arrow.stream.StreamArrowPythonProcTimeBoundedRowsOperator
- bufferInput(RowData) - Method in class org.apache.flink.table.runtime.operators.python.aggregate.arrow.stream.StreamArrowPythonRowTimeBoundedRangeOperator
- bufferInput(RowData) - Method in class org.apache.flink.table.runtime.operators.python.aggregate.arrow.stream.StreamArrowPythonRowTimeBoundedRowsOperator
- bufferInput(RowData) - Method in class org.apache.flink.table.runtime.operators.python.scalar.AbstractPythonScalarFunctionOperator
- bufferInput(RowData) - Method in class org.apache.flink.table.runtime.operators.python.table.PythonTableFunctionOperator
- build() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.ArrowType.Builder
- build() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.Builder
- build() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.FlattenRowType.Builder
- build() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.OverWindowArrowType.Builder
- build() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RawType.Builder
- build() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RowType.Builder
- build() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.Builder
- build() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input.Builder
- build() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.JobParameter.Builder
- build() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow.Builder
- build() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.BinaryInfo.Builder
- build() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Builder
- build() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.CharInfo.Builder
- build() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.DecimalInfo.Builder
- build() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Field.Builder
- build() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
- build() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.LocalZonedTimestampInfo.Builder
- build() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.MapInfo.Builder
- build() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimeInfo.Builder
- build() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimestampInfo.Builder
- build() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarBinaryInfo.Builder
- build() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarCharInfo.Builder
- build() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.ZonedTimestampInfo.Builder
- build() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.Builder
- build() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.Builder
- build() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.Builder
- build() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategy.Builder
- build() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry.Builder
- build() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.RocksdbCompactFilterCleanupStrategy.Builder
- build() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.AvroTypeInfo.Builder
- build() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.Builder
- build() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.MapTypeInfo.Builder
- build() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Builder
- build() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Field.Builder
- build() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TupleTypeInfo.Builder
- build() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.Builder
- build() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.Builder
- build() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.ListView.Builder
- build() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapView.Builder
- build() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
- build() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.Builder
- build() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder
- build() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction.Builder
- build() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions.Builder
- build() - Method in class org.apache.flink.formats.csv.CsvRowDeserializationSchema.Builder
- build() - Method in class org.apache.flink.formats.csv.CsvRowSerializationSchema.Builder
- build() - Method in class org.apache.flink.formats.json.JsonRowDeserializationSchema.Builder
- build() - Method in class org.apache.flink.formats.json.JsonRowSerializationSchema.Builder
-
Finalizes the configuration and checks validity.
- builder() - Static method in class org.apache.flink.formats.json.JsonRowSerializationSchema
-
Creates a builder for
JsonRowSerializationSchema.Builder
. - Builder(String) - Constructor for class org.apache.flink.formats.json.JsonRowDeserializationSchema.Builder
-
Creates a JSON deserialization schema for the given JSON schema.
- Builder(String) - Constructor for class org.apache.flink.formats.json.JsonRowSerializationSchema.Builder
-
Creates a JSON serialization schema for the given JSON schema.
- Builder(TypeInformation<Row>) - Constructor for class org.apache.flink.formats.csv.CsvRowDeserializationSchema.Builder
-
Creates a CSV deserialization schema for the given
TypeInformation
with optional parameters. - Builder(TypeInformation<Row>) - Constructor for class org.apache.flink.formats.csv.CsvRowSerializationSchema.Builder
-
Creates a
CsvRowSerializationSchema
expecting the givenTypeInformation
. - Builder(TypeInformation<Row>) - Constructor for class org.apache.flink.formats.json.JsonRowDeserializationSchema.Builder
-
Creates a JSON deserialization schema for the given type information.
- Builder(TypeInformation<Row>) - Constructor for class org.apache.flink.formats.json.JsonRowSerializationSchema.Builder
-
Creates a JSON serialization schema for the given type information.
- buildPartial() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.ArrowType.Builder
- buildPartial() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.Builder
- buildPartial() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.FlattenRowType.Builder
- buildPartial() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.OverWindowArrowType.Builder
- buildPartial() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RawType.Builder
- buildPartial() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RowType.Builder
- buildPartial() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.Builder
- buildPartial() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input.Builder
- buildPartial() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.JobParameter.Builder
- buildPartial() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow.Builder
- buildPartial() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.BinaryInfo.Builder
- buildPartial() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Builder
- buildPartial() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.CharInfo.Builder
- buildPartial() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.DecimalInfo.Builder
- buildPartial() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Field.Builder
- buildPartial() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
- buildPartial() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.LocalZonedTimestampInfo.Builder
- buildPartial() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.MapInfo.Builder
- buildPartial() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimeInfo.Builder
- buildPartial() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimestampInfo.Builder
- buildPartial() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarBinaryInfo.Builder
- buildPartial() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarCharInfo.Builder
- buildPartial() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.ZonedTimestampInfo.Builder
- buildPartial() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.Builder
- buildPartial() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.Builder
- buildPartial() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.Builder
- buildPartial() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategy.Builder
- buildPartial() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry.Builder
- buildPartial() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.RocksdbCompactFilterCleanupStrategy.Builder
- buildPartial() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.AvroTypeInfo.Builder
- buildPartial() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.Builder
- buildPartial() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.MapTypeInfo.Builder
- buildPartial() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Builder
- buildPartial() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Field.Builder
- buildPartial() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TupleTypeInfo.Builder
- buildPartial() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.Builder
- buildPartial() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.Builder
- buildPartial() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.ListView.Builder
- buildPartial() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapView.Builder
- buildPartial() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
- buildPartial() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.Builder
- buildPartial() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder
- buildPartial() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction.Builder
- buildPartial() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions.Builder
- buildTimerData(TimeDomain, long, long, Row, byte[]) - Method in class org.apache.flink.streaming.api.operators.python.process.timer.TimerHandler
- buildTransforms(RunnerApi.Components.Builder) - Method in class org.apache.flink.streaming.api.runners.python.beam.BeamDataStreamPythonFunctionRunner
- buildTransforms(RunnerApi.Components.Builder) - Method in class org.apache.flink.streaming.api.runners.python.beam.BeamPythonFunctionRunner
- buildTransforms(RunnerApi.Components.Builder) - Method in class org.apache.flink.table.runtime.runners.python.beam.BeamTablePythonFunctionRunner
- bundleFinishedCallback - Variable in class org.apache.flink.streaming.api.operators.python.AbstractPythonFunctionOperator
-
Callback to be executed after the current bundle was finished.
- BYTE - org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TypeName
-
BYTE = 2;
- BYTE_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TypeName
-
BYTE = 2;
- ByteArrayConstructor - Class in org.apache.flink.api.common.python.pickle
-
Creates byte arrays (byte[]).
- ByteArrayConstructor() - Constructor for class org.apache.flink.api.common.python.pickle.ByteArrayConstructor
- ByteArrayUtils - Class in org.apache.flink.table.runtime.arrow
-
A utility class for converting byte[][] to String and String to byte[][].
- ByteArrayUtils() - Constructor for class org.apache.flink.table.runtime.arrow.ByteArrayUtils
- ByteArrayWrapper - Class in org.apache.flink.streaming.api.utils
-
A wrapper of the byte array.
- ByteArrayWrapper(byte[]) - Constructor for class org.apache.flink.streaming.api.utils.ByteArrayWrapper
- ByteArrayWrapper(byte[], int) - Constructor for class org.apache.flink.streaming.api.utils.ByteArrayWrapper
- ByteArrayWrapper(byte[], int, int) - Constructor for class org.apache.flink.streaming.api.utils.ByteArrayWrapper
- ByteArrayWrapperSerializer - Class in org.apache.flink.streaming.api.utils
-
The serializer of
ByteArrayWrapper
. - ByteArrayWrapperSerializer() - Constructor for class org.apache.flink.streaming.api.utils.ByteArrayWrapperSerializer
- ByteArrayWrapperSerializer.ByteArrayWrapperSerializerSnapshot - Class in org.apache.flink.streaming.api.utils
-
Serializer configuration snapshot for compatibility and format evolution.
- ByteArrayWrapperSerializerSnapshot() - Constructor for class org.apache.flink.streaming.api.utils.ByteArrayWrapperSerializer.ByteArrayWrapperSerializerSnapshot
- ByteDataConverter() - Constructor for class org.apache.flink.streaming.api.utils.PythonTypeUtils.ByteDataConverter
C
- CACHE - Static variable in class org.apache.flink.python.util.PythonDependencyUtils
- CACHE_CLEANUP_EXECUTOR_SERVICE - Static variable in interface org.apache.flink.client.python.PythonFunctionFactory
- CACHE_CLEANUP_EXECUTOR_SERVICE_STARTED - Static variable in interface org.apache.flink.client.python.PythonFunctionFactory
- cancel() - Method in class org.apache.flink.table.runtime.arrow.sources.ArrowSourceFunction
-
Deprecated.
- canEqual(Object) - Method in class org.apache.flink.streaming.api.typeinfo.python.PickledByteArrayTypeInfo
- ChainingOptimizingExecutor - Class in org.apache.flink.table.executor.python
-
Executor
which will perform chaining optimization before generating the StreamGraph. - ChainingOptimizingExecutor(Executor) - Constructor for class org.apache.flink.table.executor.python.ChainingOptimizingExecutor
- CHAR - org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TypeName
-
CHAR = 14;
- CHAR - org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TypeName
-
CHAR = 9;
- CHAR_INFO - org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.TypeInfoCase
- CHAR_INFO_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
- CHAR_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TypeName
-
CHAR = 14;
- CHAR_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TypeName
-
CHAR = 9;
- checkArrowUsable() - Static method in class org.apache.flink.table.runtime.arrow.ArrowUtils
- checkInvokeFinishBundleByCount() - Method in class org.apache.flink.streaming.api.operators.python.AbstractPythonFunctionOperator
-
Checks whether to invoke finishBundle by elements count.
- ClassLeakCleaner - Class in org.apache.flink.streaming.api.utils
-
Utilities to clean up the leaking classes.
- ClassLeakCleaner() - Constructor for class org.apache.flink.streaming.api.utils.ClassLeakCleaner
- CLEANUP_SIZE_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategy
- CLEANUP_STRATEGIES_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig
- cleanUpLeakingClasses(ClassLoader) - Static method in class org.apache.flink.streaming.api.utils.ClassLeakCleaner
-
Clean up the soft references of the classes under the specified class loader.
- CLEANUPSTRATEGY_NOT_SET - org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry.CleanupStrategyCase
- clear() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.ArrowType.Builder
- clear() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.Builder
- clear() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.FlattenRowType.Builder
- clear() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.OverWindowArrowType.Builder
- clear() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RawType.Builder
- clear() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RowType.Builder
- clear() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.Builder
- clear() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input.Builder
- clear() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.JobParameter.Builder
- clear() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow.Builder
- clear() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.BinaryInfo.Builder
- clear() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Builder
- clear() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.CharInfo.Builder
- clear() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.DecimalInfo.Builder
- clear() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Field.Builder
- clear() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
- clear() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.LocalZonedTimestampInfo.Builder
- clear() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.MapInfo.Builder
- clear() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimeInfo.Builder
- clear() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimestampInfo.Builder
- clear() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarBinaryInfo.Builder
- clear() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarCharInfo.Builder
- clear() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.ZonedTimestampInfo.Builder
- clear() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.Builder
- clear() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.Builder
- clear() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.Builder
- clear() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategy.Builder
- clear() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry.Builder
- clear() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.RocksdbCompactFilterCleanupStrategy.Builder
- clear() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.AvroTypeInfo.Builder
- clear() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.Builder
- clear() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.MapTypeInfo.Builder
- clear() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Builder
- clear() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Field.Builder
- clear() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TupleTypeInfo.Builder
- clear() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.Builder
- clear() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.Builder
- clear() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.ListView.Builder
- clear() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapView.Builder
- clear() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
- clear() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.Builder
- clear() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder
- clear() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction.Builder
- clear() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions.Builder
- clearAllowedLateness() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.Builder
-
int64 allowedLateness = 8;
- clearArrowType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.Builder
-
.org.apache.flink.fn_execution.v1.CoderInfoDescriptor.ArrowType arrow_type = 3;
- clearAttemptNumber() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder
-
int32 attempt_number = 6;
- clearAvroTypeInfo() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.Builder
-
.org.apache.flink.fn_execution.v1.TypeInfo.AvroTypeInfo avro_type_info = 6;
- clearBinaryInfo() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.BinaryInfo binary_info = 11;
- clearCharInfo() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.CharInfo char_info = 13;
- clearCleanupSize() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategy.Builder
-
Max number of keys pulled from queue for clean up upon state touch for any key.
- clearCleanupStrategies() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.Builder
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies cleanup_strategies = 5;
- clearCleanupStrategy() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry.Builder
- clearCollectionElementType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.FieldType collection_element_type = 3;
- clearCollectionElementType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.Builder
-
.org.apache.flink.fn_execution.v1.TypeInfo collection_element_type = 2;
- clearCountStarInserted() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
-
True if the count(*) agg is inserted by the planner.
- clearDataType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.Builder
- clearDataView() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.Builder
- clearDecimalInfo() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.DecimalInfo decimal_info = 6;
- clearDescription() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Field.Builder
-
string description = 2;
- clearDistinct() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.Builder
-
bool distinct = 5;
- clearElementType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.ListView.Builder
-
.org.apache.flink.fn_execution.v1.Schema.FieldType element_type = 1;
- clearEmptyStrategy() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry.Builder
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies.EmptyCleanupStrategy empty_strategy = 2;
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.ArrowType.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.FlattenRowType.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.OverWindowArrowType.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RawType.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RowType.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.JobParameter.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.BinaryInfo.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.CharInfo.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.DecimalInfo.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Field.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.LocalZonedTimestampInfo.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.MapInfo.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimeInfo.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimestampInfo.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarBinaryInfo.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarCharInfo.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.ZonedTimestampInfo.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategy.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.RocksdbCompactFilterCleanupStrategy.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.AvroTypeInfo.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.MapTypeInfo.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Field.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TupleTypeInfo.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.ListView.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapView.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions.Builder
- clearFieldIndex() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.Builder
-
int32 field_index = 2;
- clearFieldName() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Field.Builder
-
string field_name = 1;
- clearFields() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Builder
-
repeated .org.apache.flink.fn_execution.v1.Schema.Field fields = 1;
- clearFields() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Builder
-
repeated .org.apache.flink.fn_execution.v1.TypeInfo.RowTypeInfo.Field fields = 1;
- clearFieldType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Field.Builder
-
.org.apache.flink.fn_execution.v1.TypeInfo field_type = 2;
- clearFieldTypes() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TupleTypeInfo.Builder
-
repeated .org.apache.flink.fn_execution.v1.TypeInfo field_types = 1;
- clearFilterArg() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.Builder
-
int32 filter_arg = 4;
- clearFlattenRowType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.Builder
-
for Table & SQL
- clearFunctionType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.Builder
-
.org.apache.flink.fn_execution.v1.UserDefinedDataStreamFunction.FunctionType function_type = 1;
- clearGenerateUpdateBefore() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
-
Generate retract messages if true.
- clearGrouping() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
-
The array of the key indexes.
- clearGroupWindow() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
-
Group Window.
- clearHasSideOutput() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.Builder
-
bool has_side_output = 7;
- clearInBatchExecutionMode() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder
-
bool in_batch_execution_mode = 8;
- clearIncrementalCleanupStrategy() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry.Builder
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategy incremental_cleanup_strategy = 3;
- clearIndexOfCountStar() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
-
The index of a count aggregate used to calculate the number of accumulated rows.
- clearIndexOfThisSubtask() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder
-
int32 index_of_this_subtask = 5;
- clearInput() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input.Builder
- clearInputConstant() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input.Builder
-
bytes inputConstant = 3;
- clearInputOffset() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input.Builder
-
int32 inputOffset = 2;
- clearInputs() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.Builder
-
The input arguments of the user-defined function, it could be one of the following: 1.
- clearInputs() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction.Builder
-
The input arguments of the user-defined function, it could be one of the following: 1.
- clearIsCleanupInBackground() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.Builder
-
bool is_cleanup_in_background = 1;
- clearIsPandasUdf() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction.Builder
-
Whether it's pandas UDF
- clearIsRowTime() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.Builder
-
bool is_row_time = 6;
- clearIsTimeWindow() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.Builder
-
bool is_time_window = 2;
- clearJobParameters() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 14;
- clearJobParameters() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder
-
repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 7;
- clearJobParameters() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 5;
- clearKey() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.JobParameter.Builder
-
string key = 1;
- clearKeyType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.MapInfo.Builder
-
.org.apache.flink.fn_execution.v1.Schema.FieldType key_type = 1;
- clearKeyType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.MapTypeInfo.Builder
-
.org.apache.flink.fn_execution.v1.TypeInfo key_type = 1;
- clearKeyType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapView.Builder
-
.org.apache.flink.fn_execution.v1.Schema.FieldType key_type = 1;
- clearKeyType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
-
The schema of the grouping keys.
- clearKeyTypeInfo() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.Builder
-
.org.apache.flink.fn_execution.v1.TypeInfo key_type_info = 5;
- clearLength() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.BinaryInfo.Builder
-
int32 length = 1;
- clearLength() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.CharInfo.Builder
-
int32 length = 1;
- clearLength() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarBinaryInfo.Builder
-
int32 length = 1;
- clearLength() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarCharInfo.Builder
-
int32 length = 1;
- clearListView() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.Builder
-
.org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction.DataViewSpec.ListView list_view = 3;
- clearLocalZonedTimestampInfo() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.LocalZonedTimestampInfo local_zoned_timestamp_info = 9;
- clearLowerBoundary() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow.Builder
-
int64 lower_boundary = 2;
- clearMapInfo() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.MapInfo map_info = 4;
- clearMapStateReadCacheSize() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
-
The map state read cache size.
- clearMapStateReadCacheSize() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.Builder
-
The map state read cache size.
- clearMapStateWriteCacheSize() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
-
The map_state_write_cache_size.
- clearMapStateWriteCacheSize() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.Builder
-
The map_state_write_cache_size.
- clearMapTypeInfo() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.Builder
-
.org.apache.flink.fn_execution.v1.TypeInfo.MapTypeInfo map_type_info = 5;
- clearMapView() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.Builder
-
.org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction.DataViewSpec.MapView map_view = 4;
- clearMaxNumberOfParallelSubtasks() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder
-
int32 max_number_of_parallel_subtasks = 4;
- clearMetricEnabled() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
-
bool metric_enabled = 2;
- clearMetricEnabled() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.Builder
-
bool metric_enabled = 4;
- clearMetricEnabled() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions.Builder
-
bool metric_enabled = 2;
- clearMode() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.Builder
-
.org.apache.flink.fn_execution.v1.CoderInfoDescriptor.Mode mode = 6;
- clearName() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Field.Builder
-
string name = 1;
- clearName() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.Builder
-
string name = 1;
- clearNamedProperties() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.Builder
-
repeated .org.apache.flink.fn_execution.v1.GroupWindow.WindowProperty namedProperties = 9;
- clearNullable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
bool nullable = 2;
- clearNumberOfParallelSubtasks() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder
-
int32 number_of_parallel_subtasks = 3;
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.ArrowType.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.FlattenRowType.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.OverWindowArrowType.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RawType.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RowType.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.JobParameter.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.BinaryInfo.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.CharInfo.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.DecimalInfo.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Field.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.LocalZonedTimestampInfo.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.MapInfo.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimeInfo.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimestampInfo.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarBinaryInfo.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarCharInfo.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.ZonedTimestampInfo.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategy.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.RocksdbCompactFilterCleanupStrategy.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.AvroTypeInfo.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.MapTypeInfo.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Field.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TupleTypeInfo.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.ListView.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapView.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions.Builder
- clearOverWindowArrowType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.Builder
-
.org.apache.flink.fn_execution.v1.CoderInfoDescriptor.OverWindowArrowType over_window_arrow_type = 4;
- clearPayload() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.Builder
-
The serialized representation of the user-defined function
- clearPayload() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.Builder
-
bytes payload = 3;
- clearPayload() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction.Builder
-
The serialized representation of the user-defined function
- clearPrecision() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.DecimalInfo.Builder
-
int32 precision = 1;
- clearPrecision() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.LocalZonedTimestampInfo.Builder
-
int32 precision = 1;
- clearPrecision() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimeInfo.Builder
-
int32 precision = 1;
- clearPrecision() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimestampInfo.Builder
-
int32 precision = 1;
- clearPrecision() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.ZonedTimestampInfo.Builder
-
int32 precision = 1;
- clearProfileEnabled() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
-
bool profile_enabled = 13;
- clearProfileEnabled() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.Builder
-
bool profile_enabled = 6;
- clearProfileEnabled() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions.Builder
-
bool profile_enabled = 4;
- clearQueryTimeAfterNumEntries() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.RocksdbCompactFilterCleanupStrategy.Builder
-
Number of state entries to process by compaction filter before updating current timestamp.
- clearRawType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.Builder
-
for DataStream
- clearRocksdbCompactFilterCleanupStrategy() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry.Builder
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies.RocksdbCompactFilterCleanupStrategy rocksdb_compact_filter_cleanup_strategy = 4;
- clearRowSchema() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema row_schema = 5;
- clearRowType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.Builder
-
.org.apache.flink.fn_execution.v1.CoderInfoDescriptor.RowType row_type = 2;
- clearRowTypeInfo() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.Builder
-
.org.apache.flink.fn_execution.v1.TypeInfo.RowTypeInfo row_type_info = 3;
- clearRunCleanupForEveryRecord() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategy.Builder
-
Whether to run incremental cleanup per each processed record.
- clearRuntimeContext() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.Builder
-
.org.apache.flink.fn_execution.v1.UserDefinedDataStreamFunction.RuntimeContext runtime_context = 2;
- clearScale() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.DecimalInfo.Builder
-
int32 scale = 2;
- clearSchema() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.ArrowType.Builder
-
.org.apache.flink.fn_execution.v1.Schema schema = 1;
- clearSchema() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.FlattenRowType.Builder
-
.org.apache.flink.fn_execution.v1.Schema schema = 1;
- clearSchema() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.OverWindowArrowType.Builder
-
.org.apache.flink.fn_execution.v1.Schema schema = 1;
- clearSchema() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RowType.Builder
-
.org.apache.flink.fn_execution.v1.Schema schema = 1;
- clearSchema() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.AvroTypeInfo.Builder
-
string schema = 1;
- clearSeparatedWithEndMessage() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.Builder
-
append an end message (0x00) after serializing the records belonging to the same batch.
- clearShiftTimezone() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.Builder
-
string shift_timezone = 10;
- clearSpecs() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.Builder
-
repeated .org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction.DataViewSpec specs = 3;
- clearStateCacheSize() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
-
The state cache size.
- clearStateCacheSize() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.Builder
-
The state cache size.
- clearStateCleaningEnabled() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
-
Cleanup the expired state if true.
- clearStateName() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.Builder
-
string state_name = 1;
- clearStateTtlConfig() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.Builder
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig state_ttl_config = 2;
- clearStateVisibility() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.Builder
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.StateVisibility state_visibility = 2;
- clearStrategies() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.Builder
-
repeated .org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry strategies = 2;
- clearStrategy() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry.Builder
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies.Strategies strategy = 1;
- clearTakesRowAsInput() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.Builder
-
Whether the UDF takes row as input instead of each columns of a row
- clearTakesRowAsInput() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction.Builder
-
Whether the UDF takes row as input instead of each columns of a row
- clearTaskName() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder
-
string task_name = 1;
- clearTaskNameWithSubtasks() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder
-
string task_name_with_subtasks = 2;
- clearTimeFieldIndex() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.Builder
-
int32 time_field_index = 7;
- clearTimeInfo() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.TimeInfo time_info = 7;
- clearTimestampInfo() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.TimestampInfo timestamp_info = 8;
- clearTtl() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.Builder
-
int64 ttl = 4;
- clearTtlTimeCharacteristic() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.Builder
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.TtlTimeCharacteristic ttl_time_characteristic = 3;
- clearTupleTypeInfo() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.Builder
-
.org.apache.flink.fn_execution.v1.TypeInfo.TupleTypeInfo tuple_type_info = 4;
- clearType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Field.Builder
-
.org.apache.flink.fn_execution.v1.Schema.FieldType type = 3;
- clearTypeInfo() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RawType.Builder
-
.org.apache.flink.fn_execution.v1.TypeInfo type_info = 1;
- clearTypeInfo() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
- clearTypeInfo() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.Builder
- clearTypeName() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.TypeName type_name = 1;
- clearTypeName() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.Builder
-
.org.apache.flink.fn_execution.v1.TypeInfo.TypeName type_name = 1;
- clearUdf() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input.Builder
-
.org.apache.flink.fn_execution.v1.UserDefinedFunction udf = 1;
- clearUdfs() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction udfs = 1;
- clearUdfs() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.UserDefinedFunction udfs = 1;
- clearUpdateType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.Builder
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.UpdateType update_type = 1;
- clearUpperBoundary() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow.Builder
-
int64 upper_boundary = 3;
- clearValue() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.JobParameter.Builder
-
string value = 2;
- clearValueType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.MapInfo.Builder
-
.org.apache.flink.fn_execution.v1.Schema.FieldType value_type = 2;
- clearValueType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.MapTypeInfo.Builder
-
.org.apache.flink.fn_execution.v1.TypeInfo value_type = 2;
- clearValueType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapView.Builder
-
.org.apache.flink.fn_execution.v1.Schema.FieldType value_type = 2;
- clearVarBinaryInfo() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.VarBinaryInfo var_binary_info = 12;
- clearVarCharInfo() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.VarCharInfo var_char_info = 14;
- clearWindowGap() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.Builder
-
int64 window_gap = 5;
- clearWindowIndex() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction.Builder
-
The index of the over window used in pandas batch over window aggregation
- clearWindows() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.OverWindow windows = 3;
- clearWindowSize() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.Builder
-
int64 window_size = 4;
- clearWindowSlide() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.Builder
-
int64 window_slide = 3;
- clearWindowType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.Builder
-
.org.apache.flink.fn_execution.v1.GroupWindow.WindowType window_type = 1;
- clearWindowType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow.Builder
-
.org.apache.flink.fn_execution.v1.OverWindow.WindowType window_type = 1;
- clearZonedTimestampInfo() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.ZonedTimestampInfo zoned_timestamp_info = 10;
- clone() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.ArrowType.Builder
- clone() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.Builder
- clone() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.FlattenRowType.Builder
- clone() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.OverWindowArrowType.Builder
- clone() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RawType.Builder
- clone() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RowType.Builder
- clone() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.Builder
- clone() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input.Builder
- clone() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.JobParameter.Builder
- clone() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow.Builder
- clone() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.BinaryInfo.Builder
- clone() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Builder
- clone() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.CharInfo.Builder
- clone() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.DecimalInfo.Builder
- clone() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Field.Builder
- clone() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
- clone() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.LocalZonedTimestampInfo.Builder
- clone() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.MapInfo.Builder
- clone() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimeInfo.Builder
- clone() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimestampInfo.Builder
- clone() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarBinaryInfo.Builder
- clone() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarCharInfo.Builder
- clone() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.ZonedTimestampInfo.Builder
- clone() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.Builder
- clone() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.Builder
- clone() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.Builder
- clone() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategy.Builder
- clone() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry.Builder
- clone() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.RocksdbCompactFilterCleanupStrategy.Builder
- clone() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.AvroTypeInfo.Builder
- clone() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.Builder
- clone() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.MapTypeInfo.Builder
- clone() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Builder
- clone() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Field.Builder
- clone() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TupleTypeInfo.Builder
- clone() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.Builder
- clone() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.Builder
- clone() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.ListView.Builder
- clone() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapView.Builder
- clone() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
- clone() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.Builder
- clone() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder
- clone() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction.Builder
- clone() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions.Builder
- close() - Method in class org.apache.beam.runners.fnexecution.control.DefaultJobBundleFactory
- close() - Method in class org.apache.beam.runners.fnexecution.control.DefaultJobBundleFactory.WrappedSdkHarnessClient
- close() - Method in class org.apache.beam.runners.fnexecution.state.GrpcStateService
- close() - Method in class org.apache.flink.client.python.PythonFunctionFactoryImpl
- close() - Method in class org.apache.flink.python.env.AbstractPythonEnvironmentManager
- close() - Method in class org.apache.flink.python.env.AbstractPythonEnvironmentManager.PythonLeasedResource
- close() - Method in interface org.apache.flink.python.PythonFunctionRunner
-
Tear-down the Python function runner.
- close() - Method in class org.apache.flink.streaming.api.operators.python.AbstractPythonFunctionOperator
- close() - Method in class org.apache.flink.streaming.api.operators.python.embedded.AbstractEmbeddedPythonFunctionOperator
- close() - Method in class org.apache.flink.streaming.api.operators.python.embedded.AbstractTwoInputEmbeddedPythonFunctionOperator
- close() - Method in class org.apache.flink.streaming.api.operators.python.process.AbstractExternalPythonFunctionOperator
- close() - Method in class org.apache.flink.streaming.api.operators.python.process.collector.RunnerOutputCollector
- close() - Method in class org.apache.flink.streaming.api.runners.python.beam.BeamPythonFunctionRunner
- close() - Method in class org.apache.flink.streaming.api.runners.python.beam.PythonSharedResources
- close() - Method in class org.apache.flink.table.runtime.arrow.serializers.ArrowSerializer
- close() - Method in class org.apache.flink.table.runtime.arrow.sources.ArrowSourceFunction
-
Deprecated.
- close() - Method in class org.apache.flink.table.runtime.operators.python.aggregate.arrow.AbstractArrowPythonAggregateFunctionOperator
- close() - Method in class org.apache.flink.table.runtime.operators.python.aggregate.arrow.batch.BatchArrowPythonGroupWindowAggregateFunctionOperator
- close() - Method in class org.apache.flink.table.runtime.operators.python.scalar.arrow.ArrowPythonScalarFunctionOperator
- close() - Method in class org.apache.flink.table.runtime.operators.python.utils.StreamRecordRowDataWrappingCollector
- close(T) - Method in interface org.apache.beam.vendor.grpc.v1p60p1.io.grpc.internal.SharedResourceHolder.Resource
-
Destroy the given instance.
- CO_BROADCAST_PROCESS - org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.FunctionType
-
CO_BROADCAST_PROCESS = 5;
- CO_BROADCAST_PROCESS_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.FunctionType
-
CO_BROADCAST_PROCESS = 5;
- CO_PROCESS - org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.FunctionType
-
CO_PROCESS = 1;
- CO_PROCESS_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.FunctionType
-
CO_PROCESS = 1;
- collect(RowData) - Method in class org.apache.flink.table.runtime.operators.python.utils.StreamRecordRowDataWrappingCollector
- collect(Row) - Method in class org.apache.flink.streaming.api.operators.python.process.collector.RunnerOutputCollector
- collect(OutputTag<X>, Row) - Method in class org.apache.flink.streaming.api.operators.python.process.collector.RunnerOutputCollector
- collectAsPandasDataFrame(Table, int) - Static method in class org.apache.flink.table.runtime.arrow.ArrowUtils
-
Convert Flink table to Pandas DataFrame.
- COLLECTION_ELEMENT_TYPE - org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.TypeInfoCase
- COLLECTION_ELEMENT_TYPE - org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TypeInfoCase
- COLLECTION_ELEMENT_TYPE_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
- COLLECTION_ELEMENT_TYPE_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo
- collector - Variable in class org.apache.flink.streaming.api.operators.python.embedded.AbstractEmbeddedDataStreamPythonFunctionOperator
- config - Variable in class org.apache.flink.streaming.api.operators.python.AbstractPythonFunctionOperator
- configPythonOperator(StreamExecutionEnvironment) - Static method in class org.apache.flink.python.util.PythonConfigUtil
- configureOperator(DelegateOperatorTransformation<?>, AbstractPythonFunctionOperator<?>) - Static method in interface org.apache.flink.streaming.api.transformations.python.DelegateOperatorTransformation
- configurePythonDependencies(ReadableConfig) - Static method in class org.apache.flink.python.util.PythonDependencyUtils
-
Adds python dependencies to registered cache file list according to given configuration and returns a new configuration which contains the metadata of the registered python dependencies.
- Constants - Class in org.apache.flink.python
-
constants.
- Constants() - Constructor for class org.apache.flink.python.Constants
- construct(Object[]) - Method in class org.apache.flink.api.common.python.pickle.ArrayConstructor
- construct(Object[]) - Method in class org.apache.flink.api.common.python.pickle.ByteArrayConstructor
- constructEnvironmentVariables(String) - Method in class org.apache.flink.python.env.AbstractPythonEnvironmentManager
-
Constructs the environment variables which is used to launch the python UDF worker.
- convertStateNamesToStateDescriptors(String[]) - Static method in class org.apache.flink.python.util.PythonConfigUtil
- copy() - Method in class org.apache.flink.streaming.api.functions.python.DataStreamPythonFunctionInfo
- copy() - Method in class org.apache.flink.streaming.api.utils.ByteArrayWrapper
- copy() - Method in class org.apache.flink.table.runtime.arrow.sources.ArrowTableSource
- copy() - Method in class org.apache.flink.table.utils.python.PythonDynamicTableSource
- copy(String) - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.StringSerializer
- copy(String, String) - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.StringSerializer
- copy(BigDecimal) - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.BigDecSerializer
- copy(BigDecimal, BigDecimal) - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.BigDecSerializer
- copy(Date) - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.DateSerializer
- copy(Date, Date) - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.DateSerializer
- copy(Time) - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.TimeSerializer
- copy(Time, Time) - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.TimeSerializer
- copy(Timestamp) - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.TimestampSerializer
- copy(Timestamp, Timestamp) - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.TimestampSerializer
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.streaming.api.utils.ByteArrayWrapperSerializer
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.ArrayDataSerializer
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.BigDecSerializer
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.DateSerializer
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.DecimalDataSerializer
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.MapDataSerializer
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.RowDataSerializer
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.StringSerializer
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.TimeSerializer
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.TimestampSerializer
- copy(DataStreamPythonFunctionInfo, TypeInformation<T>) - Method in interface org.apache.flink.streaming.api.operators.python.DataStreamPythonFunctionOperator
-
Make a copy of the DataStreamPythonFunctionOperator with the given pythonFunctionInfo and outputTypeInfo.
- copy(DataStreamPythonFunctionInfo, TypeInformation<T>) - Method in class org.apache.flink.streaming.api.operators.python.embedded.EmbeddedPythonCoProcessOperator
- copy(DataStreamPythonFunctionInfo, TypeInformation<T>) - Method in class org.apache.flink.streaming.api.operators.python.embedded.EmbeddedPythonKeyedCoProcessOperator
- copy(DataStreamPythonFunctionInfo, TypeInformation<T>) - Method in class org.apache.flink.streaming.api.operators.python.embedded.EmbeddedPythonKeyedProcessOperator
- copy(DataStreamPythonFunctionInfo, TypeInformation<T>) - Method in class org.apache.flink.streaming.api.operators.python.embedded.EmbeddedPythonProcessOperator
- copy(DataStreamPythonFunctionInfo, TypeInformation<T>) - Method in class org.apache.flink.streaming.api.operators.python.embedded.EmbeddedPythonWindowOperator
- copy(DataStreamPythonFunctionInfo, TypeInformation<T>) - Method in class org.apache.flink.streaming.api.operators.python.process.ExternalPythonCoProcessOperator
- copy(DataStreamPythonFunctionInfo, TypeInformation<T>) - Method in class org.apache.flink.streaming.api.operators.python.process.ExternalPythonKeyedCoProcessOperator
- copy(DataStreamPythonFunctionInfo, TypeInformation<T>) - Method in class org.apache.flink.streaming.api.operators.python.process.ExternalPythonKeyedProcessOperator
- copy(DataStreamPythonFunctionInfo, TypeInformation<T>) - Method in class org.apache.flink.streaming.api.operators.python.process.ExternalPythonProcessOperator
- copy(DataStreamPythonFunctionInfo, TypeInformation<T>) - Method in class org.apache.flink.streaming.api.transformations.python.DelegateOperatorTransformation.DelegateOperator
- copy(ByteArrayWrapper) - Method in class org.apache.flink.streaming.api.utils.ByteArrayWrapperSerializer
- copy(ByteArrayWrapper, ByteArrayWrapper) - Method in class org.apache.flink.streaming.api.utils.ByteArrayWrapperSerializer
- copy(DecimalData) - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.DecimalDataSerializer
- copy(DecimalData, DecimalData) - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.DecimalDataSerializer
- COUNT_STAR_INSERTED_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions
- create() - Static method in class org.apache.beam.runners.fnexecution.state.GrpcStateService
-
Create a new
GrpcStateService
. - create() - Method in interface org.apache.beam.vendor.grpc.v1p60p1.io.grpc.internal.SharedResourceHolder.Resource
-
Create a new instance of the resource.
- create(List<BindableService>, Endpoints.ApiServiceDescriptor) - Method in class org.apache.beam.sdk.fn.server.ServerFactory
-
Creates an instance of this server at the address specified by the given service descriptor and bound to multiple services.
- create(List<BindableService>, Endpoints.ApiServiceDescriptor) - Method in class org.apache.beam.sdk.fn.server.ServerFactory.InetSocketAddressServerFactory
- create(JobInfo) - Static method in class org.apache.beam.runners.fnexecution.control.DefaultJobBundleFactory
- create(JobInfo, Map<String, EnvironmentFactory.Provider>) - Static method in class org.apache.beam.runners.fnexecution.control.DefaultJobBundleFactory
- create(ReadableConfig, DistributedCache) - Static method in class org.apache.flink.python.env.PythonDependencyInfo
-
Creates PythonDependencyInfo from GlobalJobParameters and DistributedCache.
- createArrowReader(VectorSchemaRoot) - Method in class org.apache.flink.table.runtime.arrow.serializers.ArrowSerializer
- createArrowReader(VectorSchemaRoot, RowType) - Static method in class org.apache.flink.table.runtime.arrow.ArrowUtils
-
Creates an
ArrowReader
for the specifiedVectorSchemaRoot
. - createArrowTableSourceDesc(DataType, String) - Static method in class org.apache.flink.table.runtime.arrow.ArrowUtils
- createArrowTypeCoderInfoDescriptorProto(RowType, FlinkFnApi.CoderInfoDescriptor.Mode, boolean) - Static method in enum org.apache.flink.python.util.ProtoUtils
- createArrowWriter() - Method in class org.apache.flink.table.runtime.arrow.serializers.ArrowSerializer
-
Creates an
ArrowWriter
. - createCoderProto(FlinkFnApi.CoderInfoDescriptor) - Static method in enum org.apache.flink.python.util.ProtoUtils
- createColumnVector(ValueVector, LogicalType) - Static method in class org.apache.flink.table.runtime.arrow.ArrowUtils
- createCsvBulkWriterFactory(CsvSchema, DataType) - Static method in class org.apache.flink.formats.csv.PythonCsvUtils
-
Util for creating a
BulkWriter.Factory
that wrapsCsvBulkWriter.forSchema(org.apache.flink.shaded.jackson2.com.fasterxml.jackson.dataformat.csv.CsvMapper, org.apache.flink.shaded.jackson2.com.fasterxml.jackson.dataformat.csv.CsvSchema, org.apache.flink.formats.common.Converter<T, R, C>, C, org.apache.flink.core.fs.FSDataOutputStream)
. - createCsvReaderFormat(CsvSchema, DataType) - Static method in class org.apache.flink.formats.csv.PythonCsvUtils
-
Util for creating a
CsvReaderFormat
. - createDefault() - Static method in class org.apache.beam.sdk.fn.server.ServerFactory
-
Create a default
ServerFactory.InetSocketAddressServerFactory
. - createDefault() - Static method in interface org.apache.beam.sdk.fn.server.ServerFactory.UrlFactory
- createDynamicTableSource(DynamicTableFactory.Context) - Method in class org.apache.flink.table.runtime.arrow.sources.ArrowTableSourceFactory
- createDynamicTableSource(DynamicTableFactory.Context) - Method in class org.apache.flink.table.utils.python.PythonDynamicTableFactory
- createEnvironment() - Method in class org.apache.flink.python.env.embedded.EmbeddedPythonEnvironmentManager
- createEnvironment() - Method in class org.apache.flink.python.env.process.ProcessPythonEnvironmentManager
- createEnvironment() - Method in interface org.apache.flink.python.env.PythonEnvironmentManager
-
Creates the PythonEnvironment object used to execute Python functions.
- createEpollDomainSocket() - Static method in class org.apache.beam.sdk.fn.server.ServerFactory
-
Create a
ServerFactory.EpollDomainSocket
. - createEpollSocket() - Static method in class org.apache.beam.sdk.fn.server.ServerFactory
-
Create a
ServerFactory.EpollSocket
. - createFirstColumnTopicSelector(Class<T>) - Static method in class org.apache.flink.python.util.PythonConnectorUtils
-
Creates a selector that returns the first column of a row, and cast it to
clazz
. - createFlattenRowTypeCoderInfoDescriptorProto(RowType, FlinkFnApi.CoderInfoDescriptor.Mode, boolean) - Static method in enum org.apache.flink.python.util.ProtoUtils
- createInputCoderInfoDescriptor() - Method in class org.apache.flink.streaming.api.operators.python.process.AbstractExternalOneInputPythonFunctionOperator
- createInputCoderInfoDescriptor() - Method in class org.apache.flink.streaming.api.operators.python.process.AbstractExternalTwoInputPythonFunctionOperator
- createInputCoderInfoDescriptor(RowType) - Method in class org.apache.flink.table.runtime.operators.python.AbstractStatelessFunctionOperator
- createInputCoderInfoDescriptor(RowType) - Method in class org.apache.flink.table.runtime.operators.python.aggregate.AbstractPythonStreamAggregateOperator
- createInputCoderInfoDescriptor(RowType) - Method in class org.apache.flink.table.runtime.operators.python.aggregate.arrow.AbstractArrowPythonAggregateFunctionOperator
- createInputCoderInfoDescriptor(RowType) - Method in class org.apache.flink.table.runtime.operators.python.aggregate.arrow.batch.BatchArrowPythonOverWindowAggregateFunctionOperator
- createInputCoderInfoDescriptor(RowType) - Method in class org.apache.flink.table.runtime.operators.python.aggregate.PythonStreamGroupWindowAggregateOperator
- createInputCoderInfoDescriptor(RowType) - Method in class org.apache.flink.table.runtime.operators.python.scalar.arrow.ArrowPythonScalarFunctionOperator
- createInputCoderInfoDescriptor(RowType) - Method in class org.apache.flink.table.runtime.operators.python.scalar.PythonScalarFunctionOperator
- createInputCoderInfoDescriptor(RowType) - Method in class org.apache.flink.table.runtime.operators.python.table.PythonTableFunctionOperator
- createInstance() - Method in class org.apache.flink.streaming.api.utils.ByteArrayWrapperSerializer
- createInstance() - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.BigDecSerializer
- createInstance() - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.DateSerializer
- createInstance() - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.DecimalDataSerializer
- createInstance() - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.StringSerializer
- createInstance() - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.TimeSerializer
- createInstance() - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.TimestampSerializer
- createJobBundleFactory(Struct) - Method in class org.apache.flink.streaming.api.runners.python.beam.BeamPythonFunctionRunner
- createOutputCoderInfoDescriptor() - Method in class org.apache.flink.streaming.api.operators.python.process.AbstractExternalOneInputPythonFunctionOperator
- createOutputCoderInfoDescriptor() - Method in class org.apache.flink.streaming.api.operators.python.process.AbstractExternalTwoInputPythonFunctionOperator
- createOutputCoderInfoDescriptor(RowType) - Method in class org.apache.flink.table.runtime.operators.python.AbstractStatelessFunctionOperator
- createOutputCoderInfoDescriptor(RowType) - Method in class org.apache.flink.table.runtime.operators.python.aggregate.AbstractPythonStreamAggregateOperator
- createOutputCoderInfoDescriptor(RowType) - Method in class org.apache.flink.table.runtime.operators.python.aggregate.arrow.AbstractArrowPythonAggregateFunctionOperator
- createOutputCoderInfoDescriptor(RowType) - Method in class org.apache.flink.table.runtime.operators.python.aggregate.PythonStreamGroupWindowAggregateOperator
- createOutputCoderInfoDescriptor(RowType) - Method in class org.apache.flink.table.runtime.operators.python.scalar.arrow.ArrowPythonScalarFunctionOperator
- createOutputCoderInfoDescriptor(RowType) - Method in class org.apache.flink.table.runtime.operators.python.scalar.PythonScalarFunctionOperator
- createOutputCoderInfoDescriptor(RowType) - Method in class org.apache.flink.table.runtime.operators.python.table.PythonTableFunctionOperator
- createOverWindowArrowTypeCoderInfoDescriptorProto(RowType, FlinkFnApi.CoderInfoDescriptor.Mode, boolean) - Static method in enum org.apache.flink.python.util.ProtoUtils
- createPipeline(List<Transformation<?>>, ReadableConfig, String) - Method in class org.apache.flink.table.executor.python.ChainingOptimizingExecutor
- createPipeline(List<Transformation<?>>, ReadableConfig, String, List<JobStatusHook>) - Method in class org.apache.flink.table.executor.python.ChainingOptimizingExecutor
- createPythonEnvironmentManager() - Method in class org.apache.flink.streaming.api.operators.python.AbstractPythonFunctionOperator
- createPythonEnvironmentManager() - Method in class org.apache.flink.streaming.api.operators.python.embedded.AbstractEmbeddedPythonFunctionOperator
- createPythonEnvironmentManager() - Method in class org.apache.flink.streaming.api.operators.python.process.AbstractExternalPythonFunctionOperator
- createPythonEnvironmentManager() - Method in class org.apache.flink.streaming.api.transformations.python.DelegateOperatorTransformation.DelegateOperator
- createPythonFunctionFactory(ReadableConfig) - Static method in interface org.apache.flink.client.python.PythonFunctionFactory
- createPythonFunctionRunner() - Method in class org.apache.flink.streaming.api.operators.python.process.AbstractExternalPythonFunctionOperator
-
Creates the
PythonFunctionRunner
which is responsible for Python user-defined function execution. - createPythonFunctionRunner() - Method in class org.apache.flink.streaming.api.operators.python.process.ExternalPythonCoProcessOperator
- createPythonFunctionRunner() - Method in class org.apache.flink.streaming.api.operators.python.process.ExternalPythonKeyedCoProcessOperator
- createPythonFunctionRunner() - Method in class org.apache.flink.streaming.api.operators.python.process.ExternalPythonKeyedProcessOperator
- createPythonFunctionRunner() - Method in class org.apache.flink.streaming.api.operators.python.process.ExternalPythonProcessOperator
- createPythonFunctionRunner() - Method in class org.apache.flink.table.runtime.operators.python.AbstractStatelessFunctionOperator
- createPythonFunctionRunner() - Method in class org.apache.flink.table.runtime.operators.python.aggregate.AbstractPythonStreamAggregateOperator
- createRawTypeCoderInfoDescriptorProto(TypeInformation<?>, FlinkFnApi.CoderInfoDescriptor.Mode, boolean, ClassLoader) - Static method in enum org.apache.flink.python.util.ProtoUtils
- createRetrievalToken() - Method in class org.apache.flink.python.env.process.ProcessPythonEnvironmentManager
-
Returns an empty RetrievalToken because no files will be transmit via ArtifactService in process mode.
- createReviseOutputDataStreamFunctionProto() - Static method in enum org.apache.flink.python.util.ProtoUtils
- createRowDataArrowWriter(VectorSchemaRoot, RowType) - Static method in class org.apache.flink.table.runtime.arrow.ArrowUtils
-
Creates an
ArrowWriter
for the specifiedVectorSchemaRoot
. - createRowDataToCsvFormatConverterContext(CsvMapper, ContainerNode<?>) - Static method in class org.apache.flink.formats.csv.PythonCsvUtils
-
Util for creating a
RowDataToCsvConverters.RowDataToCsvConverter.RowDataToCsvFormatConverterContext
. - createRowTypeCoderInfoDescriptorProto(RowType, FlinkFnApi.CoderInfoDescriptor.Mode, boolean) - Static method in enum org.apache.flink.python.util.ProtoUtils
- createSerializer(SerializerConfig) - Method in class org.apache.flink.streaming.api.typeinfo.python.PickledByteArrayTypeInfo
- createSessionGroupWindowAggregateOperator(Configuration, RowType, RowType, PythonAggregateFunctionInfo[], DataViewSpec[][], int[], int, boolean, boolean, int, GroupWindowAssigner<W>, boolean, long, long, NamedWindowProperty[], ZoneId) - Static method in class org.apache.flink.table.runtime.operators.python.aggregate.PythonStreamGroupWindowAggregateOperator
- createSideOutputCoderDescriptors() - Method in class org.apache.flink.streaming.api.operators.python.process.AbstractExternalDataStreamPythonFunctionOperator
- createSingleOutputStreamOperator(StreamExecutionEnvironment, Transformation<?>) - Static method in class org.apache.flink.python.util.PythonConfigUtil
- createSlidingGroupWindowAggregateOperator(Configuration, RowType, RowType, PythonAggregateFunctionInfo[], DataViewSpec[][], int[], int, boolean, boolean, int, GroupWindowAssigner<W>, boolean, boolean, long, long, long, NamedWindowProperty[], ZoneId) - Static method in class org.apache.flink.table.runtime.operators.python.aggregate.PythonStreamGroupWindowAggregateOperator
- createTableFromElement(TableEnvironment, String, DataType, boolean) - Static method in class org.apache.flink.table.utils.python.PythonTableUtils
-
Create a table from
PythonDynamicTableSource
that read data from input file with specificDataType
. - createTimerDataCoderInfoDescriptorProto(TypeInformation<Row>) - Static method in class org.apache.flink.streaming.api.operators.python.process.timer.TimerUtils
- createTimerDataTypeInfo(TypeInformation<Row>) - Static method in class org.apache.flink.streaming.api.operators.python.process.timer.TimerUtils
- createTumblingGroupWindowAggregateOperator(Configuration, RowType, RowType, PythonAggregateFunctionInfo[], DataViewSpec[][], int[], int, boolean, boolean, int, GroupWindowAssigner<W>, boolean, boolean, long, long, NamedWindowProperty[], ZoneId) - Static method in class org.apache.flink.table.runtime.operators.python.aggregate.PythonStreamGroupWindowAggregateOperator
- createUrl(String, int) - Method in interface org.apache.beam.sdk.fn.server.ServerFactory.UrlFactory
- createUserDefinedAggregateFunctionProto(PythonAggregateFunctionInfo, DataViewSpec[]) - Static method in enum org.apache.flink.python.util.ProtoUtils
- createUserDefinedDataStreamFunctionProto(DataStreamPythonFunctionInfo, RuntimeContext, Map<String, String>, boolean, boolean, boolean, boolean, int, int, int) - Static method in enum org.apache.flink.python.util.ProtoUtils
- createUserDefinedDataStreamFunctionProtos(DataStreamPythonFunctionInfo, RuntimeContext, Map<String, String>, boolean, boolean, boolean, boolean, int, int, int) - Static method in enum org.apache.flink.python.util.ProtoUtils
- createUserDefinedDataStreamStatefulFunctionProtos(DataStreamPythonFunctionInfo, RuntimeContext, Map<String, String>, TypeInformation<?>, boolean, boolean, boolean, boolean, int, int, int) - Static method in enum org.apache.flink.python.util.ProtoUtils
- createUserDefinedFunctionInputType() - Method in class org.apache.flink.table.runtime.operators.python.aggregate.AbstractPythonStreamAggregateOperator
- createUserDefinedFunctionInputType() - Method in class org.apache.flink.table.runtime.operators.python.aggregate.AbstractPythonStreamGroupAggregateOperator
- createUserDefinedFunctionInputType() - Method in class org.apache.flink.table.runtime.operators.python.aggregate.PythonStreamGroupWindowAggregateOperator
- createUserDefinedFunctionOutputType() - Method in class org.apache.flink.table.runtime.operators.python.aggregate.AbstractPythonStreamAggregateOperator
- createUserDefinedFunctionOutputType() - Method in class org.apache.flink.table.runtime.operators.python.aggregate.AbstractPythonStreamGroupAggregateOperator
- createUserDefinedFunctionOutputType() - Method in class org.apache.flink.table.runtime.operators.python.aggregate.PythonStreamGroupWindowAggregateOperator
- createUserDefinedFunctionProto(PythonFunctionInfo) - Static method in enum org.apache.flink.python.util.ProtoUtils
- createUserDefinedFunctionsProto() - Method in class org.apache.flink.streaming.api.operators.python.embedded.AbstractOneInputEmbeddedPythonFunctionOperator
-
Gets the proto representation of the Python user-defined functions to be executed.
- createUserDefinedFunctionsProto() - Method in class org.apache.flink.streaming.api.operators.python.embedded.AbstractTwoInputEmbeddedPythonFunctionOperator
-
Gets the proto representation of the Python user-defined functions to be executed.
- createUserDefinedFunctionsProto() - Method in class org.apache.flink.streaming.api.operators.python.embedded.EmbeddedPythonCoProcessOperator
- createUserDefinedFunctionsProto() - Method in class org.apache.flink.streaming.api.operators.python.embedded.EmbeddedPythonKeyedCoProcessOperator
- createUserDefinedFunctionsProto() - Method in class org.apache.flink.streaming.api.operators.python.embedded.EmbeddedPythonKeyedProcessOperator
- createUserDefinedFunctionsProto() - Method in class org.apache.flink.streaming.api.operators.python.embedded.EmbeddedPythonProcessOperator
- createUserDefinedFunctionsProto() - Method in class org.apache.flink.streaming.api.operators.python.embedded.EmbeddedPythonWindowOperator
- createUserDefinedFunctionsProto() - Method in class org.apache.flink.table.runtime.operators.python.AbstractStatelessFunctionOperator
-
Gets the proto representation of the Python user-defined functions to be executed.
- createUserDefinedFunctionsProto() - Method in class org.apache.flink.table.runtime.operators.python.aggregate.arrow.AbstractArrowPythonAggregateFunctionOperator
- createUserDefinedFunctionsProto() - Method in class org.apache.flink.table.runtime.operators.python.aggregate.arrow.batch.BatchArrowPythonOverWindowAggregateFunctionOperator
- createUserDefinedFunctionsProto() - Method in class org.apache.flink.table.runtime.operators.python.scalar.AbstractPythonScalarFunctionOperator
-
Gets the proto representation of the Python user-defined functions to be executed.
- createUserDefinedFunctionsProto() - Method in class org.apache.flink.table.runtime.operators.python.table.PythonTableFunctionOperator
- createUserDefinedFunctionsProto(RuntimeContext, PythonFunctionInfo[], boolean, boolean) - Static method in enum org.apache.flink.python.util.ProtoUtils
- createWithPortSupplier(Supplier<Integer>) - Static method in class org.apache.beam.sdk.fn.server.ServerFactory
-
Create a
ServerFactory.InetSocketAddressServerFactory
that uses ports from a supplier. - createWithUrlFactory(ServerFactory.UrlFactory) - Static method in class org.apache.beam.sdk.fn.server.ServerFactory
-
Create a
ServerFactory.InetSocketAddressServerFactory
that uses the given url factory. - createWithUrlFactoryAndPortSupplier(ServerFactory.UrlFactory, Supplier<Integer>) - Static method in class org.apache.beam.sdk.fn.server.ServerFactory
-
Create a
ServerFactory.InetSocketAddressServerFactory
that uses the given url factory and ports from a supplier. - CsvRowDeserializationSchema - Class in org.apache.flink.formats.csv
-
Deserialization schema from CSV to Flink types.
- CsvRowDeserializationSchema.Builder - Class in org.apache.flink.formats.csv
-
A builder for creating a
CsvRowDeserializationSchema
. - CsvRowSerializationSchema - Class in org.apache.flink.formats.csv
-
Serialization schema that serializes an object of Flink types into a CSV bytes.
- CsvRowSerializationSchema.Builder - Class in org.apache.flink.formats.csv
-
A builder for creating a
CsvRowSerializationSchema
. - currentBatchCount - Variable in class org.apache.flink.table.runtime.operators.python.aggregate.arrow.AbstractArrowPythonAggregateFunctionOperator
-
The current number of elements to be included in an arrow batch.
- CustomTimestampAssigner<T> - Class in org.apache.flink.streaming.api.functions.python.eventtime
-
TimestampAssigner which extracts timestamp from the second field of the input element.
- CustomTimestampAssigner() - Constructor for class org.apache.flink.streaming.api.functions.python.eventtime.CustomTimestampAssigner
D
- DATA - Static variable in class org.apache.flink.table.runtime.arrow.sources.ArrowTableSourceOptions
- DataConverter() - Constructor for class org.apache.flink.streaming.api.utils.PythonTypeUtils.DataConverter
- DataConverter(DataFormatConverters.DataFormatConverter<IN, INTER>) - Constructor for class org.apache.flink.table.runtime.typeutils.PythonTypeUtils.DataConverter
- DataStreamPythonFunction - Class in org.apache.flink.streaming.api.functions.python
-
DataStreamPythonFunction
maintains the serialized python function which will be used in BeamDataStreamPythonFunctionRunner. - DataStreamPythonFunction(byte[], PythonEnv) - Constructor for class org.apache.flink.streaming.api.functions.python.DataStreamPythonFunction
- DataStreamPythonFunctionInfo - Class in org.apache.flink.streaming.api.functions.python
-
DataStreamPythonFunctionInfo
holds a PythonFunction and its function type. - DataStreamPythonFunctionInfo(PythonFunction, int) - Constructor for class org.apache.flink.streaming.api.functions.python.DataStreamPythonFunctionInfo
- DataStreamPythonFunctionInfo(PythonFunction, DataStreamPythonFunctionInfo, int) - Constructor for class org.apache.flink.streaming.api.functions.python.DataStreamPythonFunctionInfo
- DataStreamPythonFunctionOperator<OUT> - Interface in org.apache.flink.streaming.api.operators.python
-
Interface for Python DataStream operators.
- DATATYPE_NOT_SET - org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.DataTypeCase
- DATAVIEW_NOT_SET - org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.DataViewCase
- DATE - org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TypeName
-
DATE = 8;
- DATE_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TypeName
-
DATE = 8;
- DateSerializer - Class in org.apache.flink.table.runtime.typeutils.serializers.python
-
Takes int instead of long as the serialized value.
- DateSerializer() - Constructor for class org.apache.flink.table.runtime.typeutils.serializers.python.DateSerializer
- DateSerializer.DateSerializerSnapshot - Class in org.apache.flink.table.runtime.typeutils.serializers.python
-
Serializer configuration snapshot for compatibility and format evolution.
- DateSerializerSnapshot() - Constructor for class org.apache.flink.table.runtime.typeutils.serializers.python.DateSerializer.DateSerializerSnapshot
- DateWriter<T> - Class in org.apache.flink.table.runtime.arrow.writers
-
ArrowFieldWriter
for Date. - DateWriter.DateWriterForArray - Class in org.apache.flink.table.runtime.arrow.writers
-
DateWriter
forArrayData
input. - DateWriter.DateWriterForRow - Class in org.apache.flink.table.runtime.arrow.writers
-
DateWriter
forRowData
input. - DECIMAL - org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TypeName
-
DECIMAL = 5;
- DECIMAL_INFO - org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.TypeInfoCase
- DECIMAL_INFO_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
- DECIMAL_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TypeName
-
DECIMAL = 5;
- DecimalDataSerializer - Class in org.apache.flink.table.runtime.typeutils.serializers.python
-
We create the DecimalSerializer instead of using the DecimalSerializer of flink-table-runtime for performance reasons in Python deserialization.
- DecimalDataSerializer(int, int) - Constructor for class org.apache.flink.table.runtime.typeutils.serializers.python.DecimalDataSerializer
- DecimalDataSerializer.DecimalSerializerSnapshot - Class in org.apache.flink.table.runtime.typeutils.serializers.python
-
TypeSerializerSnapshot
forDecimalDataSerializer
. - DecimalSerializerSnapshot() - Constructor for class org.apache.flink.table.runtime.typeutils.serializers.python.DecimalDataSerializer.DecimalSerializerSnapshot
- DecimalWriter<T> - Class in org.apache.flink.table.runtime.arrow.writers
-
ArrowFieldWriter
for Decimal. - DecimalWriter.DecimalWriterForArray - Class in org.apache.flink.table.runtime.arrow.writers
-
DecimalWriter
forArrayData
input. - DecimalWriter.DecimalWriterForRow - Class in org.apache.flink.table.runtime.arrow.writers
-
DecimalWriter
forRowData
input. - DefaultJobBundleFactory - Class in org.apache.beam.runners.fnexecution.control
-
A
JobBundleFactory
for which the implementation can specify a customEnvironmentFactory
for environment management. - DefaultJobBundleFactory.ServerInfo - Class in org.apache.beam.runners.fnexecution.control
-
A container for EnvironmentFactory and its corresponding Grpc servers.
- DefaultJobBundleFactory.WrappedSdkHarnessClient - Class in org.apache.beam.runners.fnexecution.control
-
Holder for an
SdkHarnessClient
along with its associated state and data servers. - defaultMethod(LogicalType) - Method in class org.apache.flink.table.runtime.typeutils.PythonTypeUtils.LogicalTypeToProtoTypeConverter
- DelegateOperator() - Constructor for class org.apache.flink.streaming.api.transformations.python.DelegateOperatorTransformation.DelegateOperator
- DelegateOperatorTransformation<OUT> - Interface in org.apache.flink.streaming.api.transformations.python
-
For those
Transformation
that don't have an operator entity,DelegateOperatorTransformation
provides aSimpleOperatorFactory
containing aDelegateOperatorTransformation.DelegateOperator
, which can hold special configurations during transformation preprocessing for Python jobs, and later be queried at translation stage. - DelegateOperatorTransformation.DelegateOperator<OUT> - Class in org.apache.flink.streaming.api.transformations.python
-
DelegateOperatorTransformation.DelegateOperator
holds configurations, e.g. - dependencyInfo - Variable in class org.apache.flink.python.env.AbstractPythonEnvironmentManager
- DESCRIPTION_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Field
- deserialize(byte[]) - Method in class org.apache.flink.formats.avro.AvroRowDeserializationSchema
- deserialize(byte[]) - Method in class org.apache.flink.formats.csv.CsvRowDeserializationSchema
- deserialize(byte[]) - Method in class org.apache.flink.formats.json.JsonRowDeserializationSchema
- deserialize(String, DataInputView) - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.StringSerializer
- deserialize(BigDecimal, DataInputView) - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.BigDecSerializer
- deserialize(Date, DataInputView) - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.DateSerializer
- deserialize(Time, DataInputView) - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.TimeSerializer
- deserialize(Timestamp, DataInputView) - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.TimestampSerializer
- deserialize(DataInputView) - Method in class org.apache.flink.streaming.api.utils.ByteArrayWrapperSerializer
- deserialize(DataInputView) - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.ArrayDataSerializer
- deserialize(DataInputView) - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.BigDecSerializer
- deserialize(DataInputView) - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.DateSerializer
- deserialize(DataInputView) - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.DecimalDataSerializer
- deserialize(DataInputView) - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.MapDataSerializer
- deserialize(DataInputView) - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.RowDataSerializer
- deserialize(DataInputView) - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.StringSerializer
- deserialize(DataInputView) - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.TimeSerializer
- deserialize(DataInputView) - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.TimestampSerializer
- deserialize(ByteArrayWrapper, DataInputView) - Method in class org.apache.flink.streaming.api.utils.ByteArrayWrapperSerializer
- deserialize(ArrayData, DataInputView) - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.ArrayDataSerializer
- deserialize(DecimalData, DataInputView) - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.DecimalDataSerializer
- deserialize(MapData, DataInputView) - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.MapDataSerializer
- deserialize(RowData, DataInputView) - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.RowDataSerializer
- Disabled - org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.UpdateType
-
TTL is disabled.
- Disabled_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.UpdateType
-
TTL is disabled.
- disableQuoteCharacter() - Method in class org.apache.flink.formats.csv.CsvRowSerializationSchema.Builder
- DISTINCT_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction
- DOUBLE - org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TypeName
-
DOUBLE = 7;
- DOUBLE - org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TypeName
-
DOUBLE = 8;
- DOUBLE_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TypeName
-
DOUBLE = 7;
- DOUBLE_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TypeName
-
DOUBLE = 8;
- DoubleWriter<T> - Class in org.apache.flink.table.runtime.arrow.writers
-
ArrowFieldWriter
for Double. - DoubleWriter.DoubleWriterForArray - Class in org.apache.flink.table.runtime.arrow.writers
-
DoubleWriter
forArrayData
input. - DoubleWriter.DoubleWriterForRow - Class in org.apache.flink.table.runtime.arrow.writers
-
DoubleWriter
forRowData
input. - doWrite(IN, int) - Method in class org.apache.flink.table.runtime.arrow.writers.ArrowFieldWriter
-
Sets the field value as the field at the specified ordinal of the specified row.
- doWrite(T, int) - Method in class org.apache.flink.table.runtime.arrow.writers.ArrayWriter
- doWrite(T, int) - Method in class org.apache.flink.table.runtime.arrow.writers.BigIntWriter
- doWrite(T, int) - Method in class org.apache.flink.table.runtime.arrow.writers.BinaryWriter
- doWrite(T, int) - Method in class org.apache.flink.table.runtime.arrow.writers.BooleanWriter
- doWrite(T, int) - Method in class org.apache.flink.table.runtime.arrow.writers.DateWriter
- doWrite(T, int) - Method in class org.apache.flink.table.runtime.arrow.writers.DecimalWriter
- doWrite(T, int) - Method in class org.apache.flink.table.runtime.arrow.writers.DoubleWriter
- doWrite(T, int) - Method in class org.apache.flink.table.runtime.arrow.writers.FloatWriter
- doWrite(T, int) - Method in class org.apache.flink.table.runtime.arrow.writers.IntWriter
- doWrite(T, int) - Method in class org.apache.flink.table.runtime.arrow.writers.MapWriter
- doWrite(T, int) - Method in class org.apache.flink.table.runtime.arrow.writers.NullWriter
- doWrite(T, int) - Method in class org.apache.flink.table.runtime.arrow.writers.RowWriter
- doWrite(T, int) - Method in class org.apache.flink.table.runtime.arrow.writers.SmallIntWriter
- doWrite(T, int) - Method in class org.apache.flink.table.runtime.arrow.writers.TimestampWriter
- doWrite(T, int) - Method in class org.apache.flink.table.runtime.arrow.writers.TimeWriter
- doWrite(T, int) - Method in class org.apache.flink.table.runtime.arrow.writers.TinyIntWriter
- doWrite(T, int) - Method in class org.apache.flink.table.runtime.arrow.writers.VarBinaryWriter
- doWrite(T, int) - Method in class org.apache.flink.table.runtime.arrow.writers.VarCharWriter
- drainUnregisteredTimers() - Method in interface org.apache.flink.python.PythonFunctionRunner
- drainUnregisteredTimers() - Method in class org.apache.flink.streaming.api.operators.python.AbstractPythonFunctionOperator
- drainUnregisteredTimers() - Method in class org.apache.flink.streaming.api.operators.python.process.AbstractExternalPythonFunctionOperator
- drainUnregisteredTimers() - Method in class org.apache.flink.streaming.api.runners.python.beam.BeamPythonFunctionRunner
- duplicate() - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.ArrayDataSerializer
- duplicate() - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.DecimalDataSerializer
- duplicate() - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.MapDataSerializer
E
- ELEMENT_TYPE_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.ListView
- elementCount - Variable in class org.apache.flink.streaming.api.operators.python.AbstractPythonFunctionOperator
-
Number of processed elements in the current bundle.
- EmbeddedPythonBatchCoBroadcastProcessOperator<IN1,IN2,OUT> - Class in org.apache.flink.streaming.api.operators.python.embedded
-
The
EmbeddedPythonBatchCoBroadcastProcessOperator
is responsible for executing the Python CoBroadcastProcess Function under BATCH mode,EmbeddedPythonCoProcessOperator
is used under STREAMING mode. - EmbeddedPythonBatchCoBroadcastProcessOperator(Configuration, DataStreamPythonFunctionInfo, TypeInformation<IN1>, TypeInformation<IN2>, TypeInformation<OUT>) - Constructor for class org.apache.flink.streaming.api.operators.python.embedded.EmbeddedPythonBatchCoBroadcastProcessOperator
- EmbeddedPythonBatchKeyedCoBroadcastProcessOperator<K,IN1,IN2,OUT> - Class in org.apache.flink.streaming.api.operators.python.embedded
-
The
EmbeddedPythonBatchKeyedCoBroadcastProcessOperator
is responsible for executing the Python CoBroadcastProcess function under BATCH mode,EmbeddedPythonKeyedCoProcessOperator
is used under STREAMING mode. - EmbeddedPythonBatchKeyedCoBroadcastProcessOperator(Configuration, DataStreamPythonFunctionInfo, TypeInformation<IN1>, TypeInformation<IN2>, TypeInformation<OUT>) - Constructor for class org.apache.flink.streaming.api.operators.python.embedded.EmbeddedPythonBatchKeyedCoBroadcastProcessOperator
- EmbeddedPythonCoProcessOperator<IN1,IN2,OUT> - Class in org.apache.flink.streaming.api.operators.python.embedded
-
EmbeddedPythonCoProcessOperator
is responsible for executing Python CoProcessFunction in embedded Python environment. - EmbeddedPythonCoProcessOperator(Configuration, DataStreamPythonFunctionInfo, TypeInformation<IN1>, TypeInformation<IN2>, TypeInformation<OUT>) - Constructor for class org.apache.flink.streaming.api.operators.python.embedded.EmbeddedPythonCoProcessOperator
- EmbeddedPythonEnvironment - Class in org.apache.flink.python.env.embedded
-
A
PythonEnvironment
for executing UDFs in embedded environment. - EmbeddedPythonEnvironment(PythonInterpreterConfig, Map<String, String>) - Constructor for class org.apache.flink.python.env.embedded.EmbeddedPythonEnvironment
- EmbeddedPythonEnvironmentManager - Class in org.apache.flink.python.env.embedded
-
The base class of python environment manager which is used to create the PythonEnvironment object.
- EmbeddedPythonEnvironmentManager(PythonDependencyInfo, String[], Map<String, String>, JobID) - Constructor for class org.apache.flink.python.env.embedded.EmbeddedPythonEnvironmentManager
- EmbeddedPythonKeyedCoProcessOperator<K,IN1,IN2,OUT> - Class in org.apache.flink.streaming.api.operators.python.embedded
-
EmbeddedPythonKeyedCoProcessOperator
is responsible for executing user defined python KeyedCoProcessFunction in embedded Python environment. - EmbeddedPythonKeyedCoProcessOperator(Configuration, DataStreamPythonFunctionInfo, TypeInformation<IN1>, TypeInformation<IN2>, TypeInformation<OUT>) - Constructor for class org.apache.flink.streaming.api.operators.python.embedded.EmbeddedPythonKeyedCoProcessOperator
- EmbeddedPythonKeyedProcessOperator<K,IN,OUT> - Class in org.apache.flink.streaming.api.operators.python.embedded
-
EmbeddedPythonKeyedProcessOperator
is responsible for executing user defined python KeyedProcessFunction in embedded Python environment. - EmbeddedPythonKeyedProcessOperator(Configuration, DataStreamPythonFunctionInfo, TypeInformation<IN>, TypeInformation<OUT>) - Constructor for class org.apache.flink.streaming.api.operators.python.embedded.EmbeddedPythonKeyedProcessOperator
- EmbeddedPythonProcessOperator<IN,OUT> - Class in org.apache.flink.streaming.api.operators.python.embedded
-
EmbeddedPythonProcessOperator
is responsible for executing Python ProcessFunction in embedded Python environment. - EmbeddedPythonProcessOperator(Configuration, DataStreamPythonFunctionInfo, TypeInformation<IN>, TypeInformation<OUT>) - Constructor for class org.apache.flink.streaming.api.operators.python.embedded.EmbeddedPythonProcessOperator
- EmbeddedPythonScalarFunctionOperator - Class in org.apache.flink.table.runtime.operators.python.scalar
-
The Python
ScalarFunction
operator in embedded Python environment. - EmbeddedPythonScalarFunctionOperator(Configuration, PythonFunctionInfo[], RowType, RowType, RowType, int[], GeneratedProjection) - Constructor for class org.apache.flink.table.runtime.operators.python.scalar.EmbeddedPythonScalarFunctionOperator
- EmbeddedPythonTableFunctionOperator - Class in org.apache.flink.table.runtime.operators.python.table
-
The Python
TableFunction
operator in embedded Python environment. - EmbeddedPythonTableFunctionOperator(Configuration, PythonFunctionInfo, RowType, RowType, RowType, FlinkJoinType, int[]) - Constructor for class org.apache.flink.table.runtime.operators.python.table.EmbeddedPythonTableFunctionOperator
- EmbeddedPythonWindowOperator<K,IN,OUT,W extends org.apache.flink.table.runtime.operators.window.Window> - Class in org.apache.flink.streaming.api.operators.python.embedded
-
EmbeddedPythonWindowOperator
is responsible for executing user defined python ProcessWindowFunction in embedded Python environment. - EmbeddedPythonWindowOperator(Configuration, DataStreamPythonFunctionInfo, TypeInformation<IN>, TypeInformation<OUT>, TypeSerializer<W>) - Constructor for class org.apache.flink.streaming.api.operators.python.embedded.EmbeddedPythonWindowOperator
- emitResult(Tuple3<String, byte[], Integer>) - Method in class org.apache.flink.streaming.api.operators.python.process.AbstractExternalOneInputPythonFunctionOperator
- emitResult(Tuple3<String, byte[], Integer>) - Method in class org.apache.flink.streaming.api.operators.python.process.AbstractExternalPythonFunctionOperator
-
Sends the execution result to the downstream operator.
- emitResult(Tuple3<String, byte[], Integer>) - Method in class org.apache.flink.streaming.api.operators.python.process.AbstractExternalTwoInputPythonFunctionOperator
- emitResult(Tuple3<String, byte[], Integer>) - Method in class org.apache.flink.table.runtime.operators.python.aggregate.AbstractPythonStreamGroupAggregateOperator
- emitResult(Tuple3<String, byte[], Integer>) - Method in class org.apache.flink.table.runtime.operators.python.aggregate.arrow.batch.BatchArrowPythonGroupAggregateFunctionOperator
- emitResult(Tuple3<String, byte[], Integer>) - Method in class org.apache.flink.table.runtime.operators.python.aggregate.arrow.batch.BatchArrowPythonGroupWindowAggregateFunctionOperator
- emitResult(Tuple3<String, byte[], Integer>) - Method in class org.apache.flink.table.runtime.operators.python.aggregate.arrow.batch.BatchArrowPythonOverWindowAggregateFunctionOperator
- emitResult(Tuple3<String, byte[], Integer>) - Method in class org.apache.flink.table.runtime.operators.python.aggregate.arrow.stream.AbstractStreamArrowPythonBoundedRangeOperator
- emitResult(Tuple3<String, byte[], Integer>) - Method in class org.apache.flink.table.runtime.operators.python.aggregate.arrow.stream.AbstractStreamArrowPythonBoundedRowsOperator
- emitResult(Tuple3<String, byte[], Integer>) - Method in class org.apache.flink.table.runtime.operators.python.aggregate.arrow.stream.StreamArrowPythonGroupWindowAggregateFunctionOperator
- emitResult(Tuple3<String, byte[], Integer>) - Method in class org.apache.flink.table.runtime.operators.python.aggregate.PythonStreamGroupWindowAggregateOperator
- emitResult(Tuple3<String, byte[], Integer>) - Method in class org.apache.flink.table.runtime.operators.python.scalar.arrow.ArrowPythonScalarFunctionOperator
- emitResult(Tuple3<String, byte[], Integer>) - Method in class org.apache.flink.table.runtime.operators.python.scalar.PythonScalarFunctionOperator
- emitResult(Tuple3<String, byte[], Integer>) - Method in class org.apache.flink.table.runtime.operators.python.table.PythonTableFunctionOperator
- emitResults() - Method in class org.apache.flink.streaming.api.operators.python.process.AbstractExternalPythonFunctionOperator
- EMPTY_STRATEGY - org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.EmptyCleanupStrategy
-
EMPTY_STRATEGY = 0;
- EMPTY_STRATEGY - org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry.CleanupStrategyCase
- EMPTY_STRATEGY_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry
- EMPTY_STRATEGY_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.EmptyCleanupStrategy
-
EMPTY_STRATEGY = 0;
- endInput() - Method in class org.apache.flink.streaming.api.operators.python.embedded.AbstractOneInputEmbeddedPythonFunctionOperator
- endInput() - Method in class org.apache.flink.streaming.api.operators.python.process.AbstractExternalOneInputPythonFunctionOperator
- endInput() - Method in class org.apache.flink.table.runtime.operators.python.AbstractOneInputPythonFunctionOperator
- endInput() - Method in class org.apache.flink.table.runtime.operators.python.scalar.arrow.ArrowPythonScalarFunctionOperator
- endInput() - Method in class org.apache.flink.table.runtime.operators.python.scalar.EmbeddedPythonScalarFunctionOperator
- endInput() - Method in class org.apache.flink.table.runtime.operators.python.table.EmbeddedPythonTableFunctionOperator
- endInput(int) - Method in class org.apache.flink.streaming.api.operators.python.embedded.AbstractTwoInputEmbeddedPythonFunctionOperator
- endInput(int) - Method in class org.apache.flink.streaming.api.operators.python.embedded.EmbeddedPythonBatchCoBroadcastProcessOperator
- endInput(int) - Method in class org.apache.flink.streaming.api.operators.python.embedded.EmbeddedPythonBatchKeyedCoBroadcastProcessOperator
- endInput(int) - Method in class org.apache.flink.streaming.api.operators.python.process.AbstractExternalTwoInputPythonFunctionOperator
- endInput(int) - Method in class org.apache.flink.streaming.api.operators.python.process.ExternalPythonBatchCoBroadcastProcessOperator
- endInput(int) - Method in class org.apache.flink.streaming.api.operators.python.process.ExternalPythonBatchKeyedCoBroadcastProcessOperator
- ensureCacheCleanupExecutorServiceStarted() - Static method in interface org.apache.flink.client.python.PythonFunctionFactory
- env - Variable in class org.apache.flink.python.env.AbstractPythonEnvironmentManager.PythonLeasedResource
- equals(Object) - Method in class org.apache.flink.client.python.PythonFunctionFactory.CacheKey
- equals(Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.ArrowType
- equals(Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor
- equals(Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.FlattenRowType
- equals(Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.OverWindowArrowType
- equals(Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RawType
- equals(Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RowType
- equals(Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow
- equals(Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input
- equals(Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.JobParameter
- equals(Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow
- equals(Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.BinaryInfo
- equals(Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.CharInfo
- equals(Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.DecimalInfo
- equals(Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema
- equals(Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Field
- equals(Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
- equals(Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.LocalZonedTimestampInfo
- equals(Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.MapInfo
- equals(Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimeInfo
- equals(Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimestampInfo
- equals(Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarBinaryInfo
- equals(Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarCharInfo
- equals(Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.ZonedTimestampInfo
- equals(Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor
- equals(Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies
- equals(Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategy
- equals(Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry
- equals(Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.RocksdbCompactFilterCleanupStrategy
- equals(Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig
- equals(Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.AvroTypeInfo
- equals(Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo
- equals(Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.MapTypeInfo
- equals(Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo
- equals(Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Field
- equals(Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TupleTypeInfo
- equals(Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec
- equals(Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.ListView
- equals(Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapView
- equals(Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction
- equals(Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions
- equals(Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction
- equals(Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext
- equals(Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction
- equals(Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions
- equals(Object) - Method in class org.apache.flink.formats.avro.AvroRowDeserializationSchema
- equals(Object) - Method in class org.apache.flink.formats.avro.AvroRowSerializationSchema
- equals(Object) - Method in class org.apache.flink.formats.csv.CsvRowDeserializationSchema
- equals(Object) - Method in class org.apache.flink.formats.csv.CsvRowSerializationSchema
- equals(Object) - Method in class org.apache.flink.formats.json.JsonRowDeserializationSchema
- equals(Object) - Method in class org.apache.flink.formats.json.JsonRowSerializationSchema
- equals(Object) - Method in class org.apache.flink.streaming.api.typeinfo.python.PickledByteArrayTypeInfo
- equals(Object) - Method in class org.apache.flink.streaming.api.utils.ByteArrayWrapper
- equals(Object) - Method in class org.apache.flink.streaming.api.utils.PythonTypeUtils.ArrayDataConverter
- equals(Object) - Method in class org.apache.flink.streaming.api.utils.PythonTypeUtils.ListDataConverter
- equals(Object) - Method in class org.apache.flink.streaming.api.utils.PythonTypeUtils.MapDataConverter
- equals(Object) - Method in class org.apache.flink.streaming.api.utils.PythonTypeUtils.RowDataConverter
- equals(Object) - Method in class org.apache.flink.streaming.api.utils.PythonTypeUtils.RowDataDataConverter
- equals(Object) - Method in class org.apache.flink.streaming.api.utils.PythonTypeUtils.TupleDataConverter
- equals(Object) - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.DecimalDataSerializer
- execute(Pipeline) - Method in class org.apache.flink.table.executor.python.ChainingOptimizingExecutor
- executeAsync(Pipeline) - Method in class org.apache.flink.table.executor.python.ChainingOptimizingExecutor
- ExternalPythonBatchCoBroadcastProcessOperator<IN1,IN2,OUT> - Class in org.apache.flink.streaming.api.operators.python.process
-
The
ExternalPythonBatchCoBroadcastProcessOperator
is responsible for executing the Python CoBroadcastProcess Function under BATCH mode,ExternalPythonCoProcessOperator
is used under STREAMING mode. - ExternalPythonBatchCoBroadcastProcessOperator(Configuration, DataStreamPythonFunctionInfo, TypeInformation<IN1>, TypeInformation<IN2>, TypeInformation<OUT>) - Constructor for class org.apache.flink.streaming.api.operators.python.process.ExternalPythonBatchCoBroadcastProcessOperator
- ExternalPythonBatchKeyedCoBroadcastProcessOperator<OUT> - Class in org.apache.flink.streaming.api.operators.python.process
-
The
ExternalPythonBatchKeyedCoBroadcastProcessOperator
is responsible for executing the Python CoBroadcastProcess function under BATCH mode,ExternalPythonKeyedCoProcessOperator
is used under STREAMING mode. - ExternalPythonBatchKeyedCoBroadcastProcessOperator(Configuration, DataStreamPythonFunctionInfo, TypeInformation<Row>, TypeInformation<Row>, TypeInformation<OUT>) - Constructor for class org.apache.flink.streaming.api.operators.python.process.ExternalPythonBatchKeyedCoBroadcastProcessOperator
- ExternalPythonCoProcessOperator<IN1,IN2,OUT> - Class in org.apache.flink.streaming.api.operators.python.process
-
The
ExternalPythonCoProcessOperator
is responsible for executing the Python CoProcess Function. - ExternalPythonCoProcessOperator(Configuration, DataStreamPythonFunctionInfo, TypeInformation<IN1>, TypeInformation<IN2>, TypeInformation<OUT>) - Constructor for class org.apache.flink.streaming.api.operators.python.process.ExternalPythonCoProcessOperator
- ExternalPythonKeyedCoProcessOperator<OUT> - Class in org.apache.flink.streaming.api.operators.python.process
-
ExternalPythonKeyedCoProcessOperator
is responsible for launching beam runner which will start a python harness to execute user defined python CoProcess function. - ExternalPythonKeyedCoProcessOperator(Configuration, DataStreamPythonFunctionInfo, TypeInformation<Row>, TypeInformation<Row>, TypeInformation<OUT>) - Constructor for class org.apache.flink.streaming.api.operators.python.process.ExternalPythonKeyedCoProcessOperator
- ExternalPythonKeyedProcessOperator<OUT> - Class in org.apache.flink.streaming.api.operators.python.process
-
ExternalPythonKeyedProcessOperator
is responsible for launching beam runner which will start a python harness to execute user defined python function. - ExternalPythonKeyedProcessOperator(Configuration, DataStreamPythonFunctionInfo, RowTypeInfo, TypeInformation<OUT>) - Constructor for class org.apache.flink.streaming.api.operators.python.process.ExternalPythonKeyedProcessOperator
- ExternalPythonKeyedProcessOperator(Configuration, DataStreamPythonFunctionInfo, RowTypeInfo, TypeInformation<OUT>, TypeSerializer) - Constructor for class org.apache.flink.streaming.api.operators.python.process.ExternalPythonKeyedProcessOperator
- ExternalPythonProcessOperator<IN,OUT> - Class in org.apache.flink.streaming.api.operators.python.process
-
ExternalPythonProcessOperator
is responsible for launching beam runner which will start a python harness to execute user defined python ProcessFunction. - ExternalPythonProcessOperator(Configuration, DataStreamPythonFunctionInfo, TypeInformation<IN>, TypeInformation<OUT>) - Constructor for class org.apache.flink.streaming.api.operators.python.process.ExternalPythonProcessOperator
- extractProgramArgs(CommandLine) - Method in class org.apache.flink.client.cli.PythonProgramOptions
- extractPythonConfiguration(ReadableConfig) - Static method in class org.apache.flink.python.util.PythonConfigUtil
-
Extract the configurations which is used in the Python operators.
- extractTimestamp(Tuple2<T, Long>, long) - Method in class org.apache.flink.streaming.api.functions.python.eventtime.CustomTimestampAssigner
F
- factoryIdentifier() - Method in class org.apache.flink.table.runtime.arrow.sources.ArrowTableSourceFactory
- factoryIdentifier() - Method in class org.apache.flink.table.utils.python.PythonDynamicTableFactory
- failOnMissingField() - Method in class org.apache.flink.formats.json.JsonRowDeserializationSchema.Builder
-
Configures schema to fail if a JSON field is missing.
- FIELD_INDEX_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec
- FIELD_NAME_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Field
- FIELD_TYPE_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Field
- FIELD_TYPES_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TupleTypeInfo
- FIELDS_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema
- FIELDS_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo
- fieldsWriters - Variable in class org.apache.flink.table.runtime.arrow.writers.RowWriter
- FILE - Static variable in class org.apache.flink.python.util.PythonDependencyUtils
- FILE_DELIMITER - Static variable in class org.apache.flink.python.util.PythonDependencyUtils
- FILTER_ARG_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction
- finish() - Method in class org.apache.flink.streaming.api.operators.python.AbstractPythonFunctionOperator
- finish() - Method in class org.apache.flink.table.runtime.arrow.ArrowWriter
-
Finishes the writing of the current row batch.
- finish() - Method in class org.apache.flink.table.runtime.arrow.writers.ArrayWriter
- finish() - Method in class org.apache.flink.table.runtime.arrow.writers.ArrowFieldWriter
-
Finishes the writing of the current row batch.
- finish() - Method in class org.apache.flink.table.runtime.arrow.writers.RowWriter
- finish() - Method in class org.apache.flink.table.runtime.operators.python.scalar.arrow.ArrowPythonScalarFunctionOperator
- finishCurrentBatch() - Method in class org.apache.flink.table.runtime.arrow.serializers.ArrowSerializer
-
Forces to finish the processing of the current batch of elements.
- FirstColumnTopicSelectorInvocationHandler() - Constructor for class org.apache.flink.python.util.PythonConnectorUtils.FirstColumnTopicSelectorInvocationHandler
- FLATTEN_ROW_TYPE - org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.DataTypeCase
- FLATTEN_ROW_TYPE_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor
- FLINK_CODER_URN - Static variable in class org.apache.flink.python.Constants
- FlinkFnApi - Class in org.apache.flink.fnexecution.v1
- FlinkFnApi.CoderInfoDescriptor - Class in org.apache.flink.fnexecution.v1
-
A representation of the coder
- FlinkFnApi.CoderInfoDescriptor.ArrowType - Class in org.apache.flink.fnexecution.v1
-
Protobuf type
org.apache.flink.fn_execution.v1.CoderInfoDescriptor.ArrowType
- FlinkFnApi.CoderInfoDescriptor.ArrowType.Builder - Class in org.apache.flink.fnexecution.v1
-
Protobuf type
org.apache.flink.fn_execution.v1.CoderInfoDescriptor.ArrowType
- FlinkFnApi.CoderInfoDescriptor.ArrowTypeOrBuilder - Interface in org.apache.flink.fnexecution.v1
- FlinkFnApi.CoderInfoDescriptor.Builder - Class in org.apache.flink.fnexecution.v1
-
A representation of the coder
- FlinkFnApi.CoderInfoDescriptor.DataTypeCase - Enum in org.apache.flink.fnexecution.v1
- FlinkFnApi.CoderInfoDescriptor.FlattenRowType - Class in org.apache.flink.fnexecution.v1
-
for Table & SQL
- FlinkFnApi.CoderInfoDescriptor.FlattenRowType.Builder - Class in org.apache.flink.fnexecution.v1
-
for Table & SQL
- FlinkFnApi.CoderInfoDescriptor.FlattenRowTypeOrBuilder - Interface in org.apache.flink.fnexecution.v1
- FlinkFnApi.CoderInfoDescriptor.Mode - Enum in org.apache.flink.fnexecution.v1
-
Protobuf enum
org.apache.flink.fn_execution.v1.CoderInfoDescriptor.Mode
- FlinkFnApi.CoderInfoDescriptor.OverWindowArrowType - Class in org.apache.flink.fnexecution.v1
-
only used in batch over window the data consists of [window data][arrow data]
- FlinkFnApi.CoderInfoDescriptor.OverWindowArrowType.Builder - Class in org.apache.flink.fnexecution.v1
-
only used in batch over window the data consists of [window data][arrow data]
- FlinkFnApi.CoderInfoDescriptor.OverWindowArrowTypeOrBuilder - Interface in org.apache.flink.fnexecution.v1
- FlinkFnApi.CoderInfoDescriptor.RawType - Class in org.apache.flink.fnexecution.v1
-
for DataStream
- FlinkFnApi.CoderInfoDescriptor.RawType.Builder - Class in org.apache.flink.fnexecution.v1
-
for DataStream
- FlinkFnApi.CoderInfoDescriptor.RawTypeOrBuilder - Interface in org.apache.flink.fnexecution.v1
- FlinkFnApi.CoderInfoDescriptor.RowType - Class in org.apache.flink.fnexecution.v1
-
Protobuf type
org.apache.flink.fn_execution.v1.CoderInfoDescriptor.RowType
- FlinkFnApi.CoderInfoDescriptor.RowType.Builder - Class in org.apache.flink.fnexecution.v1
-
Protobuf type
org.apache.flink.fn_execution.v1.CoderInfoDescriptor.RowType
- FlinkFnApi.CoderInfoDescriptor.RowTypeOrBuilder - Interface in org.apache.flink.fnexecution.v1
- FlinkFnApi.CoderInfoDescriptorOrBuilder - Interface in org.apache.flink.fnexecution.v1
- FlinkFnApi.GroupWindow - Class in org.apache.flink.fnexecution.v1
-
Protobuf type
org.apache.flink.fn_execution.v1.GroupWindow
- FlinkFnApi.GroupWindow.Builder - Class in org.apache.flink.fnexecution.v1
-
Protobuf type
org.apache.flink.fn_execution.v1.GroupWindow
- FlinkFnApi.GroupWindow.WindowProperty - Enum in org.apache.flink.fnexecution.v1
-
Protobuf enum
org.apache.flink.fn_execution.v1.GroupWindow.WindowProperty
- FlinkFnApi.GroupWindow.WindowType - Enum in org.apache.flink.fnexecution.v1
-
Protobuf enum
org.apache.flink.fn_execution.v1.GroupWindow.WindowType
- FlinkFnApi.GroupWindowOrBuilder - Interface in org.apache.flink.fnexecution.v1
- FlinkFnApi.Input - Class in org.apache.flink.fnexecution.v1
-
Protobuf type
org.apache.flink.fn_execution.v1.Input
- FlinkFnApi.Input.Builder - Class in org.apache.flink.fnexecution.v1
-
Protobuf type
org.apache.flink.fn_execution.v1.Input
- FlinkFnApi.Input.InputCase - Enum in org.apache.flink.fnexecution.v1
- FlinkFnApi.InputOrBuilder - Interface in org.apache.flink.fnexecution.v1
- FlinkFnApi.JobParameter - Class in org.apache.flink.fnexecution.v1
-
Protobuf type
org.apache.flink.fn_execution.v1.JobParameter
- FlinkFnApi.JobParameter.Builder - Class in org.apache.flink.fnexecution.v1
-
Protobuf type
org.apache.flink.fn_execution.v1.JobParameter
- FlinkFnApi.JobParameterOrBuilder - Interface in org.apache.flink.fnexecution.v1
- FlinkFnApi.OverWindow - Class in org.apache.flink.fnexecution.v1
-
Used to describe the info of over window in pandas batch over window aggregation
- FlinkFnApi.OverWindow.Builder - Class in org.apache.flink.fnexecution.v1
-
Used to describe the info of over window in pandas batch over window aggregation
- FlinkFnApi.OverWindow.WindowType - Enum in org.apache.flink.fnexecution.v1
-
Protobuf enum
org.apache.flink.fn_execution.v1.OverWindow.WindowType
- FlinkFnApi.OverWindowOrBuilder - Interface in org.apache.flink.fnexecution.v1
- FlinkFnApi.Schema - Class in org.apache.flink.fnexecution.v1
-
A representation of the data schema.
- FlinkFnApi.Schema.BinaryInfo - Class in org.apache.flink.fnexecution.v1
-
Protobuf type
org.apache.flink.fn_execution.v1.Schema.BinaryInfo
- FlinkFnApi.Schema.BinaryInfo.Builder - Class in org.apache.flink.fnexecution.v1
-
Protobuf type
org.apache.flink.fn_execution.v1.Schema.BinaryInfo
- FlinkFnApi.Schema.BinaryInfoOrBuilder - Interface in org.apache.flink.fnexecution.v1
- FlinkFnApi.Schema.Builder - Class in org.apache.flink.fnexecution.v1
-
A representation of the data schema.
- FlinkFnApi.Schema.CharInfo - Class in org.apache.flink.fnexecution.v1
-
Protobuf type
org.apache.flink.fn_execution.v1.Schema.CharInfo
- FlinkFnApi.Schema.CharInfo.Builder - Class in org.apache.flink.fnexecution.v1
-
Protobuf type
org.apache.flink.fn_execution.v1.Schema.CharInfo
- FlinkFnApi.Schema.CharInfoOrBuilder - Interface in org.apache.flink.fnexecution.v1
- FlinkFnApi.Schema.DecimalInfo - Class in org.apache.flink.fnexecution.v1
-
Protobuf type
org.apache.flink.fn_execution.v1.Schema.DecimalInfo
- FlinkFnApi.Schema.DecimalInfo.Builder - Class in org.apache.flink.fnexecution.v1
-
Protobuf type
org.apache.flink.fn_execution.v1.Schema.DecimalInfo
- FlinkFnApi.Schema.DecimalInfoOrBuilder - Interface in org.apache.flink.fnexecution.v1
- FlinkFnApi.Schema.Field - Class in org.apache.flink.fnexecution.v1
-
Protobuf type
org.apache.flink.fn_execution.v1.Schema.Field
- FlinkFnApi.Schema.Field.Builder - Class in org.apache.flink.fnexecution.v1
-
Protobuf type
org.apache.flink.fn_execution.v1.Schema.Field
- FlinkFnApi.Schema.FieldOrBuilder - Interface in org.apache.flink.fnexecution.v1
- FlinkFnApi.Schema.FieldType - Class in org.apache.flink.fnexecution.v1
-
Protobuf type
org.apache.flink.fn_execution.v1.Schema.FieldType
- FlinkFnApi.Schema.FieldType.Builder - Class in org.apache.flink.fnexecution.v1
-
Protobuf type
org.apache.flink.fn_execution.v1.Schema.FieldType
- FlinkFnApi.Schema.FieldType.TypeInfoCase - Enum in org.apache.flink.fnexecution.v1
- FlinkFnApi.Schema.FieldTypeOrBuilder - Interface in org.apache.flink.fnexecution.v1
- FlinkFnApi.Schema.LocalZonedTimestampInfo - Class in org.apache.flink.fnexecution.v1
-
Protobuf type
org.apache.flink.fn_execution.v1.Schema.LocalZonedTimestampInfo
- FlinkFnApi.Schema.LocalZonedTimestampInfo.Builder - Class in org.apache.flink.fnexecution.v1
-
Protobuf type
org.apache.flink.fn_execution.v1.Schema.LocalZonedTimestampInfo
- FlinkFnApi.Schema.LocalZonedTimestampInfoOrBuilder - Interface in org.apache.flink.fnexecution.v1
- FlinkFnApi.Schema.MapInfo - Class in org.apache.flink.fnexecution.v1
-
Protobuf type
org.apache.flink.fn_execution.v1.Schema.MapInfo
- FlinkFnApi.Schema.MapInfo.Builder - Class in org.apache.flink.fnexecution.v1
-
Protobuf type
org.apache.flink.fn_execution.v1.Schema.MapInfo
- FlinkFnApi.Schema.MapInfoOrBuilder - Interface in org.apache.flink.fnexecution.v1
- FlinkFnApi.Schema.TimeInfo - Class in org.apache.flink.fnexecution.v1
-
Protobuf type
org.apache.flink.fn_execution.v1.Schema.TimeInfo
- FlinkFnApi.Schema.TimeInfo.Builder - Class in org.apache.flink.fnexecution.v1
-
Protobuf type
org.apache.flink.fn_execution.v1.Schema.TimeInfo
- FlinkFnApi.Schema.TimeInfoOrBuilder - Interface in org.apache.flink.fnexecution.v1
- FlinkFnApi.Schema.TimestampInfo - Class in org.apache.flink.fnexecution.v1
-
Protobuf type
org.apache.flink.fn_execution.v1.Schema.TimestampInfo
- FlinkFnApi.Schema.TimestampInfo.Builder - Class in org.apache.flink.fnexecution.v1
-
Protobuf type
org.apache.flink.fn_execution.v1.Schema.TimestampInfo
- FlinkFnApi.Schema.TimestampInfoOrBuilder - Interface in org.apache.flink.fnexecution.v1
- FlinkFnApi.Schema.TypeName - Enum in org.apache.flink.fnexecution.v1
-
Protobuf enum
org.apache.flink.fn_execution.v1.Schema.TypeName
- FlinkFnApi.Schema.VarBinaryInfo - Class in org.apache.flink.fnexecution.v1
-
Protobuf type
org.apache.flink.fn_execution.v1.Schema.VarBinaryInfo
- FlinkFnApi.Schema.VarBinaryInfo.Builder - Class in org.apache.flink.fnexecution.v1
-
Protobuf type
org.apache.flink.fn_execution.v1.Schema.VarBinaryInfo
- FlinkFnApi.Schema.VarBinaryInfoOrBuilder - Interface in org.apache.flink.fnexecution.v1
- FlinkFnApi.Schema.VarCharInfo - Class in org.apache.flink.fnexecution.v1
-
Protobuf type
org.apache.flink.fn_execution.v1.Schema.VarCharInfo
- FlinkFnApi.Schema.VarCharInfo.Builder - Class in org.apache.flink.fnexecution.v1
-
Protobuf type
org.apache.flink.fn_execution.v1.Schema.VarCharInfo
- FlinkFnApi.Schema.VarCharInfoOrBuilder - Interface in org.apache.flink.fnexecution.v1
- FlinkFnApi.Schema.ZonedTimestampInfo - Class in org.apache.flink.fnexecution.v1
-
Protobuf type
org.apache.flink.fn_execution.v1.Schema.ZonedTimestampInfo
- FlinkFnApi.Schema.ZonedTimestampInfo.Builder - Class in org.apache.flink.fnexecution.v1
-
Protobuf type
org.apache.flink.fn_execution.v1.Schema.ZonedTimestampInfo
- FlinkFnApi.Schema.ZonedTimestampInfoOrBuilder - Interface in org.apache.flink.fnexecution.v1
- FlinkFnApi.SchemaOrBuilder - Interface in org.apache.flink.fnexecution.v1
- FlinkFnApi.StateDescriptor - Class in org.apache.flink.fnexecution.v1
-
A representation of State
- FlinkFnApi.StateDescriptor.Builder - Class in org.apache.flink.fnexecution.v1
-
A representation of State
- FlinkFnApi.StateDescriptor.StateTTLConfig - Class in org.apache.flink.fnexecution.v1
-
Protobuf type
org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig
- FlinkFnApi.StateDescriptor.StateTTLConfig.Builder - Class in org.apache.flink.fnexecution.v1
-
Protobuf type
org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig
- FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies - Class in org.apache.flink.fnexecution.v1
-
TTL cleanup strategies.
- FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.Builder - Class in org.apache.flink.fnexecution.v1
-
TTL cleanup strategies.
- FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.EmptyCleanupStrategy - Enum in org.apache.flink.fnexecution.v1
-
Protobuf enum
org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies.EmptyCleanupStrategy
- FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategy - Class in org.apache.flink.fnexecution.v1
-
Configuration of cleanup strategy while taking the full snapshot.
- FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategy.Builder - Class in org.apache.flink.fnexecution.v1
-
Configuration of cleanup strategy while taking the full snapshot.
- FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategyOrBuilder - Interface in org.apache.flink.fnexecution.v1
- FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry - Class in org.apache.flink.fnexecution.v1
-
Protobuf type
org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry
- FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry.Builder - Class in org.apache.flink.fnexecution.v1
-
Protobuf type
org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry
- FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry.CleanupStrategyCase - Enum in org.apache.flink.fnexecution.v1
- FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntryOrBuilder - Interface in org.apache.flink.fnexecution.v1
- FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.RocksdbCompactFilterCleanupStrategy - Class in org.apache.flink.fnexecution.v1
-
Configuration of cleanup strategy using custom compaction filter in RocksDB.
- FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.RocksdbCompactFilterCleanupStrategy.Builder - Class in org.apache.flink.fnexecution.v1
-
Configuration of cleanup strategy using custom compaction filter in RocksDB.
- FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.RocksdbCompactFilterCleanupStrategyOrBuilder - Interface in org.apache.flink.fnexecution.v1
- FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.Strategies - Enum in org.apache.flink.fnexecution.v1
-
Fixed strategies ordinals in strategies config field.
- FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategiesOrBuilder - Interface in org.apache.flink.fnexecution.v1
- FlinkFnApi.StateDescriptor.StateTTLConfig.StateVisibility - Enum in org.apache.flink.fnexecution.v1
-
This option configures whether expired user value can be returned or not.
- FlinkFnApi.StateDescriptor.StateTTLConfig.TtlTimeCharacteristic - Enum in org.apache.flink.fnexecution.v1
-
This option configures time scale to use for ttl.
- FlinkFnApi.StateDescriptor.StateTTLConfig.UpdateType - Enum in org.apache.flink.fnexecution.v1
-
This option value configures when to update last access timestamp which prolongs state TTL.
- FlinkFnApi.StateDescriptor.StateTTLConfigOrBuilder - Interface in org.apache.flink.fnexecution.v1
- FlinkFnApi.StateDescriptorOrBuilder - Interface in org.apache.flink.fnexecution.v1
- FlinkFnApi.TypeInfo - Class in org.apache.flink.fnexecution.v1
-
A representation of the data type information in DataStream.
- FlinkFnApi.TypeInfo.AvroTypeInfo - Class in org.apache.flink.fnexecution.v1
-
Protobuf type
org.apache.flink.fn_execution.v1.TypeInfo.AvroTypeInfo
- FlinkFnApi.TypeInfo.AvroTypeInfo.Builder - Class in org.apache.flink.fnexecution.v1
-
Protobuf type
org.apache.flink.fn_execution.v1.TypeInfo.AvroTypeInfo
- FlinkFnApi.TypeInfo.AvroTypeInfoOrBuilder - Interface in org.apache.flink.fnexecution.v1
- FlinkFnApi.TypeInfo.Builder - Class in org.apache.flink.fnexecution.v1
-
A representation of the data type information in DataStream.
- FlinkFnApi.TypeInfo.MapTypeInfo - Class in org.apache.flink.fnexecution.v1
-
Protobuf type
org.apache.flink.fn_execution.v1.TypeInfo.MapTypeInfo
- FlinkFnApi.TypeInfo.MapTypeInfo.Builder - Class in org.apache.flink.fnexecution.v1
-
Protobuf type
org.apache.flink.fn_execution.v1.TypeInfo.MapTypeInfo
- FlinkFnApi.TypeInfo.MapTypeInfoOrBuilder - Interface in org.apache.flink.fnexecution.v1
- FlinkFnApi.TypeInfo.RowTypeInfo - Class in org.apache.flink.fnexecution.v1
-
Protobuf type
org.apache.flink.fn_execution.v1.TypeInfo.RowTypeInfo
- FlinkFnApi.TypeInfo.RowTypeInfo.Builder - Class in org.apache.flink.fnexecution.v1
-
Protobuf type
org.apache.flink.fn_execution.v1.TypeInfo.RowTypeInfo
- FlinkFnApi.TypeInfo.RowTypeInfo.Field - Class in org.apache.flink.fnexecution.v1
-
Protobuf type
org.apache.flink.fn_execution.v1.TypeInfo.RowTypeInfo.Field
- FlinkFnApi.TypeInfo.RowTypeInfo.Field.Builder - Class in org.apache.flink.fnexecution.v1
-
Protobuf type
org.apache.flink.fn_execution.v1.TypeInfo.RowTypeInfo.Field
- FlinkFnApi.TypeInfo.RowTypeInfo.FieldOrBuilder - Interface in org.apache.flink.fnexecution.v1
- FlinkFnApi.TypeInfo.RowTypeInfoOrBuilder - Interface in org.apache.flink.fnexecution.v1
- FlinkFnApi.TypeInfo.TupleTypeInfo - Class in org.apache.flink.fnexecution.v1
-
Protobuf type
org.apache.flink.fn_execution.v1.TypeInfo.TupleTypeInfo
- FlinkFnApi.TypeInfo.TupleTypeInfo.Builder - Class in org.apache.flink.fnexecution.v1
-
Protobuf type
org.apache.flink.fn_execution.v1.TypeInfo.TupleTypeInfo
- FlinkFnApi.TypeInfo.TupleTypeInfoOrBuilder - Interface in org.apache.flink.fnexecution.v1
- FlinkFnApi.TypeInfo.TypeInfoCase - Enum in org.apache.flink.fnexecution.v1
- FlinkFnApi.TypeInfo.TypeName - Enum in org.apache.flink.fnexecution.v1
-
Protobuf enum
org.apache.flink.fn_execution.v1.TypeInfo.TypeName
- FlinkFnApi.TypeInfoOrBuilder - Interface in org.apache.flink.fnexecution.v1
- FlinkFnApi.UserDefinedAggregateFunction - Class in org.apache.flink.fnexecution.v1
-
Protobuf type
org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction
- FlinkFnApi.UserDefinedAggregateFunction.Builder - Class in org.apache.flink.fnexecution.v1
-
Protobuf type
org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction
- FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec - Class in org.apache.flink.fnexecution.v1
-
Protobuf type
org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction.DataViewSpec
- FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.Builder - Class in org.apache.flink.fnexecution.v1
-
Protobuf type
org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction.DataViewSpec
- FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.DataViewCase - Enum in org.apache.flink.fnexecution.v1
- FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.ListView - Class in org.apache.flink.fnexecution.v1
-
Protobuf type
org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction.DataViewSpec.ListView
- FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.ListView.Builder - Class in org.apache.flink.fnexecution.v1
-
Protobuf type
org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction.DataViewSpec.ListView
- FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.ListViewOrBuilder - Interface in org.apache.flink.fnexecution.v1
- FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapView - Class in org.apache.flink.fnexecution.v1
-
Protobuf type
org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction.DataViewSpec.MapView
- FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapView.Builder - Class in org.apache.flink.fnexecution.v1
-
Protobuf type
org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction.DataViewSpec.MapView
- FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapViewOrBuilder - Interface in org.apache.flink.fnexecution.v1
- FlinkFnApi.UserDefinedAggregateFunction.DataViewSpecOrBuilder - Interface in org.apache.flink.fnexecution.v1
- FlinkFnApi.UserDefinedAggregateFunctionOrBuilder - Interface in org.apache.flink.fnexecution.v1
- FlinkFnApi.UserDefinedAggregateFunctions - Class in org.apache.flink.fnexecution.v1
-
A list of the user-defined aggregate functions to be executed in a group aggregate operation.
- FlinkFnApi.UserDefinedAggregateFunctions.Builder - Class in org.apache.flink.fnexecution.v1
-
A list of the user-defined aggregate functions to be executed in a group aggregate operation.
- FlinkFnApi.UserDefinedAggregateFunctionsOrBuilder - Interface in org.apache.flink.fnexecution.v1
- FlinkFnApi.UserDefinedDataStreamFunction - Class in org.apache.flink.fnexecution.v1
-
User defined DataStream function definition.
- FlinkFnApi.UserDefinedDataStreamFunction.Builder - Class in org.apache.flink.fnexecution.v1
-
User defined DataStream function definition.
- FlinkFnApi.UserDefinedDataStreamFunction.FunctionType - Enum in org.apache.flink.fnexecution.v1
-
Protobuf enum
org.apache.flink.fn_execution.v1.UserDefinedDataStreamFunction.FunctionType
- FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext - Class in org.apache.flink.fnexecution.v1
-
Protobuf type
org.apache.flink.fn_execution.v1.UserDefinedDataStreamFunction.RuntimeContext
- FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder - Class in org.apache.flink.fnexecution.v1
-
Protobuf type
org.apache.flink.fn_execution.v1.UserDefinedDataStreamFunction.RuntimeContext
- FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContextOrBuilder - Interface in org.apache.flink.fnexecution.v1
- FlinkFnApi.UserDefinedDataStreamFunctionOrBuilder - Interface in org.apache.flink.fnexecution.v1
- FlinkFnApi.UserDefinedFunction - Class in org.apache.flink.fnexecution.v1
-
User-defined function definition.
- FlinkFnApi.UserDefinedFunction.Builder - Class in org.apache.flink.fnexecution.v1
-
User-defined function definition.
- FlinkFnApi.UserDefinedFunctionOrBuilder - Interface in org.apache.flink.fnexecution.v1
- FlinkFnApi.UserDefinedFunctions - Class in org.apache.flink.fnexecution.v1
-
A list of user-defined functions to be executed in a batch.
- FlinkFnApi.UserDefinedFunctions.Builder - Class in org.apache.flink.fnexecution.v1
-
A list of user-defined functions to be executed in a batch.
- FlinkFnApi.UserDefinedFunctionsOrBuilder - Interface in org.apache.flink.fnexecution.v1
- FlinkMetricContainer - Class in org.apache.flink.python.metric.process
-
Helper class for forwarding Python metrics to Java accumulators and metrics.
- FlinkMetricContainer(MetricGroup) - Constructor for class org.apache.flink.python.metric.process.FlinkMetricContainer
- FlinkMetricContainer.FlinkDistributionGauge - Class in org.apache.flink.python.metric.process
-
Flink
Gauge
forDistributionResult
. - FlinkMetricContainer.FlinkGauge - Class in org.apache.flink.python.metric.process
-
Flink
Gauge
forGaugeResult
. - FLOAT - org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TypeName
-
FLOAT = 6;
- FLOAT - org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TypeName
-
FLOAT = 7;
- FLOAT_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TypeName
-
FLOAT = 6;
- FLOAT_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TypeName
-
FLOAT = 7;
- FloatDataConverter() - Constructor for class org.apache.flink.streaming.api.utils.PythonTypeUtils.FloatDataConverter
- FloatWriter<T> - Class in org.apache.flink.table.runtime.arrow.writers
-
ArrowFieldWriter
for Float. - FloatWriter.FloatWriterForArray - Class in org.apache.flink.table.runtime.arrow.writers
-
FloatWriter
forArrayData
input. - FloatWriter.FloatWriterForRow - Class in org.apache.flink.table.runtime.arrow.writers
-
FloatWriter
forRowData
input. - flush() - Method in interface org.apache.flink.python.PythonFunctionRunner
-
Forces to finish the processing of the current bundle of elements.
- flush() - Method in class org.apache.flink.streaming.api.runners.python.beam.BeamPythonFunctionRunner
- forArray(BigIntVector) - Static method in class org.apache.flink.table.runtime.arrow.writers.BigIntWriter
- forArray(BitVector) - Static method in class org.apache.flink.table.runtime.arrow.writers.BooleanWriter
- forArray(ListVector, ArrowFieldWriter<ArrayData>) - Static method in class org.apache.flink.table.runtime.arrow.writers.ArrayWriter
- forArray(MapVector, ArrowFieldWriter<ArrayData>, ArrowFieldWriter<ArrayData>) - Static method in class org.apache.flink.table.runtime.arrow.writers.MapWriter
- forArray(StructVector, ArrowFieldWriter<RowData>[]) - Static method in class org.apache.flink.table.runtime.arrow.writers.RowWriter
- forArray(DateDayVector) - Static method in class org.apache.flink.table.runtime.arrow.writers.DateWriter
- forArray(DecimalVector, int, int) - Static method in class org.apache.flink.table.runtime.arrow.writers.DecimalWriter
- forArray(FixedSizeBinaryVector) - Static method in class org.apache.flink.table.runtime.arrow.writers.BinaryWriter
- forArray(Float4Vector) - Static method in class org.apache.flink.table.runtime.arrow.writers.FloatWriter
- forArray(Float8Vector) - Static method in class org.apache.flink.table.runtime.arrow.writers.DoubleWriter
- forArray(IntVector) - Static method in class org.apache.flink.table.runtime.arrow.writers.IntWriter
- forArray(SmallIntVector) - Static method in class org.apache.flink.table.runtime.arrow.writers.SmallIntWriter
- forArray(TinyIntVector) - Static method in class org.apache.flink.table.runtime.arrow.writers.TinyIntWriter
- forArray(ValueVector) - Static method in class org.apache.flink.table.runtime.arrow.writers.TimeWriter
- forArray(ValueVector, int) - Static method in class org.apache.flink.table.runtime.arrow.writers.TimestampWriter
- forArray(VarBinaryVector) - Static method in class org.apache.flink.table.runtime.arrow.writers.VarBinaryWriter
- forArray(VarCharVector) - Static method in class org.apache.flink.table.runtime.arrow.writers.VarCharWriter
- forNumber(int) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.DataTypeCase
- forNumber(int) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.Mode
- forNumber(int) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.WindowProperty
- forNumber(int) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.WindowType
- forNumber(int) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.Input.InputCase
- forNumber(int) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow.WindowType
- forNumber(int) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.TypeInfoCase
- forNumber(int) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TypeName
- forNumber(int) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.EmptyCleanupStrategy
- forNumber(int) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry.CleanupStrategyCase
- forNumber(int) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.Strategies
- forNumber(int) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.StateVisibility
- forNumber(int) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.TtlTimeCharacteristic
- forNumber(int) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.UpdateType
- forNumber(int) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TypeInfoCase
- forNumber(int) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TypeName
- forNumber(int) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.DataViewCase
- forNumber(int) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.FunctionType
- forRow(BigIntVector) - Static method in class org.apache.flink.table.runtime.arrow.writers.BigIntWriter
- forRow(BitVector) - Static method in class org.apache.flink.table.runtime.arrow.writers.BooleanWriter
- forRow(ListVector, ArrowFieldWriter<ArrayData>) - Static method in class org.apache.flink.table.runtime.arrow.writers.ArrayWriter
- forRow(MapVector, ArrowFieldWriter<ArrayData>, ArrowFieldWriter<ArrayData>) - Static method in class org.apache.flink.table.runtime.arrow.writers.MapWriter
- forRow(StructVector, ArrowFieldWriter<RowData>[]) - Static method in class org.apache.flink.table.runtime.arrow.writers.RowWriter
- forRow(DateDayVector) - Static method in class org.apache.flink.table.runtime.arrow.writers.DateWriter
- forRow(DecimalVector, int, int) - Static method in class org.apache.flink.table.runtime.arrow.writers.DecimalWriter
- forRow(FixedSizeBinaryVector) - Static method in class org.apache.flink.table.runtime.arrow.writers.BinaryWriter
- forRow(Float4Vector) - Static method in class org.apache.flink.table.runtime.arrow.writers.FloatWriter
- forRow(Float8Vector) - Static method in class org.apache.flink.table.runtime.arrow.writers.DoubleWriter
- forRow(IntVector) - Static method in class org.apache.flink.table.runtime.arrow.writers.IntWriter
- forRow(SmallIntVector) - Static method in class org.apache.flink.table.runtime.arrow.writers.SmallIntWriter
- forRow(TinyIntVector) - Static method in class org.apache.flink.table.runtime.arrow.writers.TinyIntWriter
- forRow(ValueVector) - Static method in class org.apache.flink.table.runtime.arrow.writers.TimeWriter
- forRow(ValueVector, int) - Static method in class org.apache.flink.table.runtime.arrow.writers.TimestampWriter
- forRow(VarBinaryVector) - Static method in class org.apache.flink.table.runtime.arrow.writers.VarBinaryWriter
- forRow(VarCharVector) - Static method in class org.apache.flink.table.runtime.arrow.writers.VarCharWriter
- forStage(ExecutableStage) - Method in class org.apache.beam.runners.fnexecution.control.DefaultJobBundleFactory
- forwardedInputQueue - Variable in class org.apache.flink.table.runtime.operators.python.AbstractStatelessFunctionOperator
-
The queue holding the input elements for which the execution results have not been received.
- fromBigDecimal(BigDecimal, int, int) - Static method in class org.apache.flink.table.runtime.typeutils.PythonTypeUtils
-
Convert the specified bigDecimal according to the specified precision and scale.
- fromOrd(byte) - Static method in enum org.apache.flink.streaming.api.runners.python.beam.state.IterateType
- FULL_STATE_SCAN_SNAPSHOT - org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.Strategies
-
FULL_STATE_SCAN_SNAPSHOT = 0;
- FULL_STATE_SCAN_SNAPSHOT_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.Strategies
-
FULL_STATE_SCAN_SNAPSHOT = 0;
- FUNCTION_TYPE_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction
G
- GENERATE_UPDATE_BEFORE_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions
- get(int) - Method in class org.apache.flink.streaming.api.utils.ByteArrayWrapper
- get(SharedResourceHolder.Resource<T>) - Static method in class org.apache.beam.vendor.grpc.v1p60p1.io.grpc.internal.SharedResourceHolder
-
Try to get an existing instance of the given resource.
- get(ConfigOption<T>) - Method in class org.apache.flink.python.PythonConfig
- getAllowedLateness() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.Builder
-
int64 allowedLateness = 8;
- getAllowedLateness() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow
-
int64 allowedLateness = 8;
- getAllowedLateness() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindowOrBuilder
-
int64 allowedLateness = 8;
- getArchives() - Method in class org.apache.flink.python.env.PythonDependencyInfo
- getArity() - Method in class org.apache.flink.streaming.api.typeinfo.python.PickledByteArrayTypeInfo
- getArray(int) - Method in class org.apache.flink.table.runtime.arrow.vectors.ArrowArrayColumnVector
- getArrowType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.Builder
-
.org.apache.flink.fn_execution.v1.CoderInfoDescriptor.ArrowType arrow_type = 3;
- getArrowType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor
-
.org.apache.flink.fn_execution.v1.CoderInfoDescriptor.ArrowType arrow_type = 3;
- getArrowType() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptorOrBuilder
-
.org.apache.flink.fn_execution.v1.CoderInfoDescriptor.ArrowType arrow_type = 3;
- getArrowTypeBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.Builder
-
.org.apache.flink.fn_execution.v1.CoderInfoDescriptor.ArrowType arrow_type = 3;
- getArrowTypeOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.Builder
-
.org.apache.flink.fn_execution.v1.CoderInfoDescriptor.ArrowType arrow_type = 3;
- getArrowTypeOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor
-
.org.apache.flink.fn_execution.v1.CoderInfoDescriptor.ArrowType arrow_type = 3;
- getArrowTypeOrBuilder() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptorOrBuilder
-
.org.apache.flink.fn_execution.v1.CoderInfoDescriptor.ArrowType arrow_type = 3;
- getAttemptNumber() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder
-
int32 attempt_number = 6;
- getAttemptNumber() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext
-
int32 attempt_number = 6;
- getAttemptNumber() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContextOrBuilder
-
int32 attempt_number = 6;
- getAvroTypeInfo() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.Builder
-
.org.apache.flink.fn_execution.v1.TypeInfo.AvroTypeInfo avro_type_info = 6;
- getAvroTypeInfo() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo
-
.org.apache.flink.fn_execution.v1.TypeInfo.AvroTypeInfo avro_type_info = 6;
- getAvroTypeInfo() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfoOrBuilder
-
.org.apache.flink.fn_execution.v1.TypeInfo.AvroTypeInfo avro_type_info = 6;
- getAvroTypeInfoBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.Builder
-
.org.apache.flink.fn_execution.v1.TypeInfo.AvroTypeInfo avro_type_info = 6;
- getAvroTypeInfoOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.Builder
-
.org.apache.flink.fn_execution.v1.TypeInfo.AvroTypeInfo avro_type_info = 6;
- getAvroTypeInfoOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo
-
.org.apache.flink.fn_execution.v1.TypeInfo.AvroTypeInfo avro_type_info = 6;
- getAvroTypeInfoOrBuilder() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfoOrBuilder
-
.org.apache.flink.fn_execution.v1.TypeInfo.AvroTypeInfo avro_type_info = 6;
- getBaseDirectory() - Method in class org.apache.flink.python.env.AbstractPythonEnvironmentManager
- getBinaryInfo() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.BinaryInfo binary_info = 11;
- getBinaryInfo() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
-
.org.apache.flink.fn_execution.v1.Schema.BinaryInfo binary_info = 11;
- getBinaryInfo() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldTypeOrBuilder
-
.org.apache.flink.fn_execution.v1.Schema.BinaryInfo binary_info = 11;
- getBinaryInfoBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.BinaryInfo binary_info = 11;
- getBinaryInfoOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.BinaryInfo binary_info = 11;
- getBinaryInfoOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
-
.org.apache.flink.fn_execution.v1.Schema.BinaryInfo binary_info = 11;
- getBinaryInfoOrBuilder() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldTypeOrBuilder
-
.org.apache.flink.fn_execution.v1.Schema.BinaryInfo binary_info = 11;
- getBoolean(int) - Method in class org.apache.flink.table.runtime.arrow.vectors.ArrowBooleanColumnVector
- getBootLog() - Method in class org.apache.flink.python.env.process.ProcessPythonEnvironmentManager
-
Returns the boot log of the Python Environment.
- getByte(int) - Method in class org.apache.flink.table.runtime.arrow.vectors.ArrowTinyIntColumnVector
- getBytes(int) - Method in class org.apache.flink.table.runtime.arrow.vectors.ArrowBinaryColumnVector
- getBytes(int) - Method in class org.apache.flink.table.runtime.arrow.vectors.ArrowVarBinaryColumnVector
- getBytes(int) - Method in class org.apache.flink.table.runtime.arrow.vectors.ArrowVarCharColumnVector
- getCacheTokens() - Method in class org.apache.flink.streaming.api.runners.python.beam.state.BeamStateRequestHandler
- getChangelogMode() - Method in class org.apache.flink.table.runtime.arrow.sources.ArrowTableSource
- getChangelogMode() - Method in class org.apache.flink.table.utils.python.PythonDynamicTableSource
- getCharInfo() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.CharInfo char_info = 13;
- getCharInfo() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
-
.org.apache.flink.fn_execution.v1.Schema.CharInfo char_info = 13;
- getCharInfo() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldTypeOrBuilder
-
.org.apache.flink.fn_execution.v1.Schema.CharInfo char_info = 13;
- getCharInfoBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.CharInfo char_info = 13;
- getCharInfoOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.CharInfo char_info = 13;
- getCharInfoOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
-
.org.apache.flink.fn_execution.v1.Schema.CharInfo char_info = 13;
- getCharInfoOrBuilder() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldTypeOrBuilder
-
.org.apache.flink.fn_execution.v1.Schema.CharInfo char_info = 13;
- getCleanupSize() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategy.Builder
-
Max number of keys pulled from queue for clean up upon state touch for any key.
- getCleanupSize() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategy
-
Max number of keys pulled from queue for clean up upon state touch for any key.
- getCleanupSize() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategyOrBuilder
-
Max number of keys pulled from queue for clean up upon state touch for any key.
- getCleanupStrategies() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.Builder
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies cleanup_strategies = 5;
- getCleanupStrategies() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies cleanup_strategies = 5;
- getCleanupStrategies() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfigOrBuilder
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies cleanup_strategies = 5;
- getCleanupStrategiesBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.Builder
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies cleanup_strategies = 5;
- getCleanupStrategiesOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.Builder
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies cleanup_strategies = 5;
- getCleanupStrategiesOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies cleanup_strategies = 5;
- getCleanupStrategiesOrBuilder() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfigOrBuilder
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies cleanup_strategies = 5;
- getCleanupStrategyCase() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry.Builder
- getCleanupStrategyCase() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry
- getCleanupStrategyCase() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntryOrBuilder
- getCollectionElementType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.FieldType collection_element_type = 3;
- getCollectionElementType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
-
.org.apache.flink.fn_execution.v1.Schema.FieldType collection_element_type = 3;
- getCollectionElementType() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldTypeOrBuilder
-
.org.apache.flink.fn_execution.v1.Schema.FieldType collection_element_type = 3;
- getCollectionElementType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.Builder
-
.org.apache.flink.fn_execution.v1.TypeInfo collection_element_type = 2;
- getCollectionElementType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo
-
.org.apache.flink.fn_execution.v1.TypeInfo collection_element_type = 2;
- getCollectionElementType() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfoOrBuilder
-
.org.apache.flink.fn_execution.v1.TypeInfo collection_element_type = 2;
- getCollectionElementTypeBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.FieldType collection_element_type = 3;
- getCollectionElementTypeBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.Builder
-
.org.apache.flink.fn_execution.v1.TypeInfo collection_element_type = 2;
- getCollectionElementTypeOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.FieldType collection_element_type = 3;
- getCollectionElementTypeOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
-
.org.apache.flink.fn_execution.v1.Schema.FieldType collection_element_type = 3;
- getCollectionElementTypeOrBuilder() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldTypeOrBuilder
-
.org.apache.flink.fn_execution.v1.Schema.FieldType collection_element_type = 3;
- getCollectionElementTypeOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.Builder
-
.org.apache.flink.fn_execution.v1.TypeInfo collection_element_type = 2;
- getCollectionElementTypeOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo
-
.org.apache.flink.fn_execution.v1.TypeInfo collection_element_type = 2;
- getCollectionElementTypeOrBuilder() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfoOrBuilder
-
.org.apache.flink.fn_execution.v1.TypeInfo collection_element_type = 2;
- getCollectionInputFormat(List<T>, TypeInformation<T>, ExecutionConfig) - Static method in class org.apache.flink.streaming.api.utils.PythonTypeUtils
-
Wrap the unpickled python data with an InputFormat.
- getColumnVectors() - Method in class org.apache.flink.table.runtime.arrow.ArrowReader
-
Gets the column vectors.
- getCommand() - Method in class org.apache.flink.python.env.process.ProcessPythonEnvironment
- getConfig() - Method in class org.apache.flink.python.env.embedded.EmbeddedPythonEnvironment
- getConfiguration() - Method in class org.apache.flink.streaming.api.operators.python.AbstractPythonFunctionOperator
-
Returns the
Configuration
. - getConfiguration() - Method in class org.apache.flink.streaming.api.transformations.python.PythonBroadcastStateTransformation
- getConfiguration() - Method in class org.apache.flink.streaming.api.transformations.python.PythonKeyedBroadcastStateTransformation
- getConfiguration() - Method in class org.apache.flink.table.executor.python.ChainingOptimizingExecutor
- getCount() - Method in class org.apache.flink.table.runtime.arrow.writers.ArrowFieldWriter
-
Returns the current count of elements written.
- getCountStarInserted() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
-
True if the count(*) agg is inserted by the planner.
- getCountStarInserted() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions
-
True if the count(*) agg is inserted by the planner.
- getCountStarInserted() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctionsOrBuilder
-
True if the count(*) agg is inserted by the planner.
- getCurrentKey() - Method in class org.apache.flink.streaming.api.operators.python.process.ExternalPythonKeyedCoProcessOperator
- getCurrentKey() - Method in class org.apache.flink.streaming.api.operators.python.process.ExternalPythonKeyedProcessOperator
- getCurrentKey() - Method in class org.apache.flink.table.runtime.operators.python.aggregate.AbstractPythonStreamAggregateOperator
- getCurrentVersion() - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.ArrayDataSerializer.ArrayDataSerializerSnapshot
- getCurrentVersion() - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.DecimalDataSerializer.DecimalSerializerSnapshot
- getCurrentVersion() - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.MapDataSerializer.BaseMapSerializerSnapshot
- getCurrentVersion() - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.RowDataSerializer.RowDataSerializerSnapshot
- getCurrentVersion() - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.TimestampSerializer.TimestampSerializerSnapshot
- getData() - Method in class org.apache.flink.streaming.api.utils.ByteArrayWrapper
- getDataStreamPythonFunctionInfo() - Method in class org.apache.flink.streaming.api.transformations.python.PythonBroadcastStateTransformation
- getDataStreamPythonFunctionInfo() - Method in class org.apache.flink.streaming.api.transformations.python.PythonKeyedBroadcastStateTransformation
- getDataTypeCase() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.Builder
- getDataTypeCase() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor
- getDataTypeCase() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptorOrBuilder
- getDataViewCase() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.Builder
- getDataViewCase() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec
- getDataViewCase() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpecOrBuilder
- getDecimal(int, int, int) - Method in class org.apache.flink.table.runtime.arrow.vectors.ArrowDecimalColumnVector
- getDecimalInfo() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.DecimalInfo decimal_info = 6;
- getDecimalInfo() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
-
.org.apache.flink.fn_execution.v1.Schema.DecimalInfo decimal_info = 6;
- getDecimalInfo() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldTypeOrBuilder
-
.org.apache.flink.fn_execution.v1.Schema.DecimalInfo decimal_info = 6;
- getDecimalInfoBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.DecimalInfo decimal_info = 6;
- getDecimalInfoOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.DecimalInfo decimal_info = 6;
- getDecimalInfoOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
-
.org.apache.flink.fn_execution.v1.Schema.DecimalInfo decimal_info = 6;
- getDecimalInfoOrBuilder() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldTypeOrBuilder
-
.org.apache.flink.fn_execution.v1.Schema.DecimalInfo decimal_info = 6;
- getDefaultInstance() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.ArrowType
- getDefaultInstance() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.FlattenRowType
- getDefaultInstance() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor
- getDefaultInstance() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.OverWindowArrowType
- getDefaultInstance() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RawType
- getDefaultInstance() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RowType
- getDefaultInstance() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow
- getDefaultInstance() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input
- getDefaultInstance() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.JobParameter
- getDefaultInstance() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow
- getDefaultInstance() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.BinaryInfo
- getDefaultInstance() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.CharInfo
- getDefaultInstance() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.DecimalInfo
- getDefaultInstance() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Field
- getDefaultInstance() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
- getDefaultInstance() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema
- getDefaultInstance() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.LocalZonedTimestampInfo
- getDefaultInstance() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.MapInfo
- getDefaultInstance() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimeInfo
- getDefaultInstance() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimestampInfo
- getDefaultInstance() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarBinaryInfo
- getDefaultInstance() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarCharInfo
- getDefaultInstance() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.ZonedTimestampInfo
- getDefaultInstance() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor
- getDefaultInstance() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies
- getDefaultInstance() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategy
- getDefaultInstance() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry
- getDefaultInstance() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.RocksdbCompactFilterCleanupStrategy
- getDefaultInstance() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig
- getDefaultInstance() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.AvroTypeInfo
- getDefaultInstance() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo
- getDefaultInstance() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.MapTypeInfo
- getDefaultInstance() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Field
- getDefaultInstance() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo
- getDefaultInstance() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TupleTypeInfo
- getDefaultInstance() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec
- getDefaultInstance() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.ListView
- getDefaultInstance() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapView
- getDefaultInstance() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction
- getDefaultInstance() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions
- getDefaultInstance() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction
- getDefaultInstance() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext
- getDefaultInstance() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction
- getDefaultInstance() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.ArrowType.Builder
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.ArrowType
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.Builder
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.FlattenRowType.Builder
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.FlattenRowType
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.OverWindowArrowType.Builder
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.OverWindowArrowType
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RawType.Builder
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RawType
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RowType.Builder
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RowType
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.Builder
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input.Builder
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.JobParameter.Builder
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.JobParameter
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow.Builder
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.BinaryInfo.Builder
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.BinaryInfo
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Builder
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.CharInfo.Builder
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.CharInfo
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.DecimalInfo.Builder
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.DecimalInfo
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Field.Builder
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Field
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.LocalZonedTimestampInfo.Builder
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.LocalZonedTimestampInfo
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.MapInfo.Builder
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.MapInfo
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimeInfo.Builder
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimeInfo
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimestampInfo.Builder
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimestampInfo
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarBinaryInfo.Builder
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarBinaryInfo
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarCharInfo.Builder
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarCharInfo
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.ZonedTimestampInfo.Builder
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.ZonedTimestampInfo
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.Builder
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.Builder
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.Builder
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategy.Builder
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategy
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry.Builder
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.RocksdbCompactFilterCleanupStrategy.Builder
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.RocksdbCompactFilterCleanupStrategy
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.AvroTypeInfo.Builder
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.AvroTypeInfo
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.Builder
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.MapTypeInfo.Builder
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.MapTypeInfo
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Builder
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Field.Builder
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Field
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TupleTypeInfo.Builder
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TupleTypeInfo
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.Builder
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.Builder
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.ListView.Builder
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.ListView
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapView.Builder
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapView
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.Builder
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction.Builder
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions.Builder
- getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions
- getDescription() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Field.Builder
-
string description = 2;
- getDescription() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Field
-
string description = 2;
- getDescription() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldOrBuilder
-
string description = 2;
- getDescriptionBytes() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Field.Builder
-
string description = 2;
- getDescriptionBytes() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Field
-
string description = 2;
- getDescriptionBytes() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldOrBuilder
-
string description = 2;
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.ArrowType.Builder
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.ArrowType
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.Builder
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.FlattenRowType.Builder
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.FlattenRowType
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor
- getDescriptor() - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.Mode
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.OverWindowArrowType.Builder
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.OverWindowArrowType
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RawType.Builder
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RawType
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RowType.Builder
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RowType
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.Builder
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow
- getDescriptor() - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.WindowProperty
- getDescriptor() - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.WindowType
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input.Builder
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.JobParameter.Builder
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.JobParameter
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow.Builder
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow
- getDescriptor() - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow.WindowType
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.BinaryInfo.Builder
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.BinaryInfo
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Builder
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.CharInfo.Builder
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.CharInfo
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.DecimalInfo.Builder
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.DecimalInfo
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Field.Builder
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Field
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.LocalZonedTimestampInfo.Builder
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.LocalZonedTimestampInfo
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.MapInfo.Builder
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.MapInfo
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimeInfo.Builder
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimeInfo
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimestampInfo.Builder
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimestampInfo
- getDescriptor() - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TypeName
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarBinaryInfo.Builder
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarBinaryInfo
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarCharInfo.Builder
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarCharInfo
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.ZonedTimestampInfo.Builder
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.ZonedTimestampInfo
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.Builder
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.Builder
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.Builder
- getDescriptor() - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.EmptyCleanupStrategy
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategy.Builder
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategy
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry.Builder
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.RocksdbCompactFilterCleanupStrategy.Builder
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.RocksdbCompactFilterCleanupStrategy
- getDescriptor() - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.Strategies
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig
- getDescriptor() - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.StateVisibility
- getDescriptor() - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.TtlTimeCharacteristic
- getDescriptor() - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.UpdateType
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.AvroTypeInfo.Builder
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.AvroTypeInfo
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.Builder
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.MapTypeInfo.Builder
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.MapTypeInfo
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Builder
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Field.Builder
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Field
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TupleTypeInfo.Builder
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TupleTypeInfo
- getDescriptor() - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TypeName
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.Builder
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.Builder
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.ListView.Builder
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.ListView
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapView.Builder
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapView
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.Builder
- getDescriptor() - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.FunctionType
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction.Builder
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions.Builder
- getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions
- getDescriptorForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.ArrowType.Builder
- getDescriptorForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.Builder
- getDescriptorForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.FlattenRowType.Builder
- getDescriptorForType() - Method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.Mode
- getDescriptorForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.OverWindowArrowType.Builder
- getDescriptorForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RawType.Builder
- getDescriptorForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RowType.Builder
- getDescriptorForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.Builder
- getDescriptorForType() - Method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.WindowProperty
- getDescriptorForType() - Method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.WindowType
- getDescriptorForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input.Builder
- getDescriptorForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.JobParameter.Builder
- getDescriptorForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow.Builder
- getDescriptorForType() - Method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow.WindowType
- getDescriptorForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.BinaryInfo.Builder
- getDescriptorForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Builder
- getDescriptorForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.CharInfo.Builder
- getDescriptorForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.DecimalInfo.Builder
- getDescriptorForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Field.Builder
- getDescriptorForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
- getDescriptorForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.LocalZonedTimestampInfo.Builder
- getDescriptorForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.MapInfo.Builder
- getDescriptorForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimeInfo.Builder
- getDescriptorForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimestampInfo.Builder
- getDescriptorForType() - Method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TypeName
- getDescriptorForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarBinaryInfo.Builder
- getDescriptorForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarCharInfo.Builder
- getDescriptorForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.ZonedTimestampInfo.Builder
- getDescriptorForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.Builder
- getDescriptorForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.Builder
- getDescriptorForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.Builder
- getDescriptorForType() - Method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.EmptyCleanupStrategy
- getDescriptorForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategy.Builder
- getDescriptorForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry.Builder
- getDescriptorForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.RocksdbCompactFilterCleanupStrategy.Builder
- getDescriptorForType() - Method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.Strategies
- getDescriptorForType() - Method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.StateVisibility
- getDescriptorForType() - Method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.TtlTimeCharacteristic
- getDescriptorForType() - Method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.UpdateType
- getDescriptorForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.AvroTypeInfo.Builder
- getDescriptorForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.Builder
- getDescriptorForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.MapTypeInfo.Builder
- getDescriptorForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Builder
- getDescriptorForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Field.Builder
- getDescriptorForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TupleTypeInfo.Builder
- getDescriptorForType() - Method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TypeName
- getDescriptorForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.Builder
- getDescriptorForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.Builder
- getDescriptorForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.ListView.Builder
- getDescriptorForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapView.Builder
- getDescriptorForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
- getDescriptorForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.Builder
- getDescriptorForType() - Method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.FunctionType
- getDescriptorForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder
- getDescriptorForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction.Builder
- getDescriptorForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions.Builder
- getDistinct() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.Builder
-
bool distinct = 5;
- getDistinct() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction
-
bool distinct = 5;
- getDistinct() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctionOrBuilder
-
bool distinct = 5;
- getDouble(int) - Method in class org.apache.flink.table.runtime.arrow.vectors.ArrowDoubleColumnVector
- getElementType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.ListView.Builder
-
.org.apache.flink.fn_execution.v1.Schema.FieldType element_type = 1;
- getElementType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.ListView
-
.org.apache.flink.fn_execution.v1.Schema.FieldType element_type = 1;
- getElementType() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.ListViewOrBuilder
-
.org.apache.flink.fn_execution.v1.Schema.FieldType element_type = 1;
- getElementTypeBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.ListView.Builder
-
.org.apache.flink.fn_execution.v1.Schema.FieldType element_type = 1;
- getElementTypeOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.ListView.Builder
-
.org.apache.flink.fn_execution.v1.Schema.FieldType element_type = 1;
- getElementTypeOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.ListView
-
.org.apache.flink.fn_execution.v1.Schema.FieldType element_type = 1;
- getElementTypeOrBuilder() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.ListViewOrBuilder
-
.org.apache.flink.fn_execution.v1.Schema.FieldType element_type = 1;
- getEmptyStrategy() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry.Builder
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies.EmptyCleanupStrategy empty_strategy = 2;
- getEmptyStrategy() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies.EmptyCleanupStrategy empty_strategy = 2;
- getEmptyStrategy() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntryOrBuilder
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies.EmptyCleanupStrategy empty_strategy = 2;
- getEmptyStrategyValue() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry.Builder
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies.EmptyCleanupStrategy empty_strategy = 2;
- getEmptyStrategyValue() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies.EmptyCleanupStrategy empty_strategy = 2;
- getEmptyStrategyValue() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntryOrBuilder
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies.EmptyCleanupStrategy empty_strategy = 2;
- getEnv() - Method in class org.apache.flink.python.env.embedded.EmbeddedPythonEnvironment
- getEnv() - Method in class org.apache.flink.python.env.process.ProcessPythonEnvironment
- getEnvironmentConfig(StreamExecutionEnvironment) - Static method in class org.apache.flink.python.util.PythonConfigUtil
- getExecutionMode() - Method in class org.apache.flink.python.env.PythonDependencyInfo
- getFieldIndex() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.Builder
-
int32 field_index = 2;
- getFieldIndex() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec
-
int32 field_index = 2;
- getFieldIndex() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpecOrBuilder
-
int32 field_index = 2;
- getFieldName() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Field.Builder
-
string field_name = 1;
- getFieldName() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Field
-
string field_name = 1;
- getFieldName() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.FieldOrBuilder
-
string field_name = 1;
- getFieldNameBytes() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Field.Builder
-
string field_name = 1;
- getFieldNameBytes() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Field
-
string field_name = 1;
- getFieldNameBytes() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.FieldOrBuilder
-
string field_name = 1;
- getFields(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Builder
-
repeated .org.apache.flink.fn_execution.v1.Schema.Field fields = 1;
- getFields(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema
-
repeated .org.apache.flink.fn_execution.v1.Schema.Field fields = 1;
- getFields(int) - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.SchemaOrBuilder
-
repeated .org.apache.flink.fn_execution.v1.Schema.Field fields = 1;
- getFields(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Builder
-
repeated .org.apache.flink.fn_execution.v1.TypeInfo.RowTypeInfo.Field fields = 1;
- getFields(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo
-
repeated .org.apache.flink.fn_execution.v1.TypeInfo.RowTypeInfo.Field fields = 1;
- getFields(int) - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfoOrBuilder
-
repeated .org.apache.flink.fn_execution.v1.TypeInfo.RowTypeInfo.Field fields = 1;
- getFieldsBuilder(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Builder
-
repeated .org.apache.flink.fn_execution.v1.Schema.Field fields = 1;
- getFieldsBuilder(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Builder
-
repeated .org.apache.flink.fn_execution.v1.TypeInfo.RowTypeInfo.Field fields = 1;
- getFieldsBuilderList() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Builder
-
repeated .org.apache.flink.fn_execution.v1.Schema.Field fields = 1;
- getFieldsBuilderList() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Builder
-
repeated .org.apache.flink.fn_execution.v1.TypeInfo.RowTypeInfo.Field fields = 1;
- getFieldsCount() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Builder
-
repeated .org.apache.flink.fn_execution.v1.Schema.Field fields = 1;
- getFieldsCount() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema
-
repeated .org.apache.flink.fn_execution.v1.Schema.Field fields = 1;
- getFieldsCount() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.SchemaOrBuilder
-
repeated .org.apache.flink.fn_execution.v1.Schema.Field fields = 1;
- getFieldsCount() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Builder
-
repeated .org.apache.flink.fn_execution.v1.TypeInfo.RowTypeInfo.Field fields = 1;
- getFieldsCount() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo
-
repeated .org.apache.flink.fn_execution.v1.TypeInfo.RowTypeInfo.Field fields = 1;
- getFieldsCount() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfoOrBuilder
-
repeated .org.apache.flink.fn_execution.v1.TypeInfo.RowTypeInfo.Field fields = 1;
- getFieldsList() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Builder
-
repeated .org.apache.flink.fn_execution.v1.Schema.Field fields = 1;
- getFieldsList() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema
-
repeated .org.apache.flink.fn_execution.v1.Schema.Field fields = 1;
- getFieldsList() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.SchemaOrBuilder
-
repeated .org.apache.flink.fn_execution.v1.Schema.Field fields = 1;
- getFieldsList() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Builder
-
repeated .org.apache.flink.fn_execution.v1.TypeInfo.RowTypeInfo.Field fields = 1;
- getFieldsList() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo
-
repeated .org.apache.flink.fn_execution.v1.TypeInfo.RowTypeInfo.Field fields = 1;
- getFieldsList() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfoOrBuilder
-
repeated .org.apache.flink.fn_execution.v1.TypeInfo.RowTypeInfo.Field fields = 1;
- getFieldsOrBuilder(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Builder
-
repeated .org.apache.flink.fn_execution.v1.Schema.Field fields = 1;
- getFieldsOrBuilder(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema
-
repeated .org.apache.flink.fn_execution.v1.Schema.Field fields = 1;
- getFieldsOrBuilder(int) - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.SchemaOrBuilder
-
repeated .org.apache.flink.fn_execution.v1.Schema.Field fields = 1;
- getFieldsOrBuilder(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Builder
-
repeated .org.apache.flink.fn_execution.v1.TypeInfo.RowTypeInfo.Field fields = 1;
- getFieldsOrBuilder(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo
-
repeated .org.apache.flink.fn_execution.v1.TypeInfo.RowTypeInfo.Field fields = 1;
- getFieldsOrBuilder(int) - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfoOrBuilder
-
repeated .org.apache.flink.fn_execution.v1.TypeInfo.RowTypeInfo.Field fields = 1;
- getFieldsOrBuilderList() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Builder
-
repeated .org.apache.flink.fn_execution.v1.Schema.Field fields = 1;
- getFieldsOrBuilderList() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema
-
repeated .org.apache.flink.fn_execution.v1.Schema.Field fields = 1;
- getFieldsOrBuilderList() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.SchemaOrBuilder
-
repeated .org.apache.flink.fn_execution.v1.Schema.Field fields = 1;
- getFieldsOrBuilderList() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Builder
-
repeated .org.apache.flink.fn_execution.v1.TypeInfo.RowTypeInfo.Field fields = 1;
- getFieldsOrBuilderList() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo
-
repeated .org.apache.flink.fn_execution.v1.TypeInfo.RowTypeInfo.Field fields = 1;
- getFieldsOrBuilderList() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfoOrBuilder
-
repeated .org.apache.flink.fn_execution.v1.TypeInfo.RowTypeInfo.Field fields = 1;
- getFieldType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Field.Builder
-
.org.apache.flink.fn_execution.v1.TypeInfo field_type = 2;
- getFieldType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Field
-
.org.apache.flink.fn_execution.v1.TypeInfo field_type = 2;
- getFieldType() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.FieldOrBuilder
-
.org.apache.flink.fn_execution.v1.TypeInfo field_type = 2;
- getFieldTypeBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Field.Builder
-
.org.apache.flink.fn_execution.v1.TypeInfo field_type = 2;
- getFieldTypeOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Field.Builder
-
.org.apache.flink.fn_execution.v1.TypeInfo field_type = 2;
- getFieldTypeOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Field
-
.org.apache.flink.fn_execution.v1.TypeInfo field_type = 2;
- getFieldTypeOrBuilder() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.FieldOrBuilder
-
.org.apache.flink.fn_execution.v1.TypeInfo field_type = 2;
- getFieldTypes(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TupleTypeInfo.Builder
-
repeated .org.apache.flink.fn_execution.v1.TypeInfo field_types = 1;
- getFieldTypes(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TupleTypeInfo
-
repeated .org.apache.flink.fn_execution.v1.TypeInfo field_types = 1;
- getFieldTypes(int) - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TupleTypeInfoOrBuilder
-
repeated .org.apache.flink.fn_execution.v1.TypeInfo field_types = 1;
- getFieldTypesBuilder(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TupleTypeInfo.Builder
-
repeated .org.apache.flink.fn_execution.v1.TypeInfo field_types = 1;
- getFieldTypesBuilderList() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TupleTypeInfo.Builder
-
repeated .org.apache.flink.fn_execution.v1.TypeInfo field_types = 1;
- getFieldTypesCount() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TupleTypeInfo.Builder
-
repeated .org.apache.flink.fn_execution.v1.TypeInfo field_types = 1;
- getFieldTypesCount() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TupleTypeInfo
-
repeated .org.apache.flink.fn_execution.v1.TypeInfo field_types = 1;
- getFieldTypesCount() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TupleTypeInfoOrBuilder
-
repeated .org.apache.flink.fn_execution.v1.TypeInfo field_types = 1;
- getFieldTypesList() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TupleTypeInfo.Builder
-
repeated .org.apache.flink.fn_execution.v1.TypeInfo field_types = 1;
- getFieldTypesList() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TupleTypeInfo
-
repeated .org.apache.flink.fn_execution.v1.TypeInfo field_types = 1;
- getFieldTypesList() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TupleTypeInfoOrBuilder
-
repeated .org.apache.flink.fn_execution.v1.TypeInfo field_types = 1;
- getFieldTypesOrBuilder(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TupleTypeInfo.Builder
-
repeated .org.apache.flink.fn_execution.v1.TypeInfo field_types = 1;
- getFieldTypesOrBuilder(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TupleTypeInfo
-
repeated .org.apache.flink.fn_execution.v1.TypeInfo field_types = 1;
- getFieldTypesOrBuilder(int) - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TupleTypeInfoOrBuilder
-
repeated .org.apache.flink.fn_execution.v1.TypeInfo field_types = 1;
- getFieldTypesOrBuilderList() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TupleTypeInfo.Builder
-
repeated .org.apache.flink.fn_execution.v1.TypeInfo field_types = 1;
- getFieldTypesOrBuilderList() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TupleTypeInfo
-
repeated .org.apache.flink.fn_execution.v1.TypeInfo field_types = 1;
- getFieldTypesOrBuilderList() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TupleTypeInfoOrBuilder
-
repeated .org.apache.flink.fn_execution.v1.TypeInfo field_types = 1;
- getFieldWriters() - Method in class org.apache.flink.table.runtime.arrow.ArrowWriter
-
Gets the field writers.
- getFilterArg() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.Builder
-
int32 filter_arg = 4;
- getFilterArg() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction
-
int32 filter_arg = 4;
- getFilterArg() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctionOrBuilder
-
int32 filter_arg = 4;
- getFlattenRowType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.Builder
-
for Table & SQL
- getFlattenRowType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor
-
for Table & SQL
- getFlattenRowType() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptorOrBuilder
-
for Table & SQL
- getFlattenRowTypeBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.Builder
-
for Table & SQL
- getFlattenRowTypeOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.Builder
-
for Table & SQL
- getFlattenRowTypeOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor
-
for Table & SQL
- getFlattenRowTypeOrBuilder() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptorOrBuilder
-
for Table & SQL
- getFlinkMetricContainer() - Method in class org.apache.flink.streaming.api.operators.python.AbstractPythonFunctionOperator
- getFloat(int) - Method in class org.apache.flink.table.runtime.arrow.vectors.ArrowFloatColumnVector
- getFunctionContext() - Method in class org.apache.flink.streaming.api.operators.python.embedded.AbstractOneInputEmbeddedPythonFunctionOperator
-
Gets The function context.
- getFunctionContext() - Method in class org.apache.flink.streaming.api.operators.python.embedded.AbstractTwoInputEmbeddedPythonFunctionOperator
-
Gets The function context.
- getFunctionContext() - Method in class org.apache.flink.streaming.api.operators.python.embedded.EmbeddedPythonCoProcessOperator
- getFunctionContext() - Method in class org.apache.flink.streaming.api.operators.python.embedded.EmbeddedPythonKeyedCoProcessOperator
- getFunctionContext() - Method in class org.apache.flink.streaming.api.operators.python.embedded.EmbeddedPythonKeyedProcessOperator
- getFunctionContext() - Method in class org.apache.flink.streaming.api.operators.python.embedded.EmbeddedPythonProcessOperator
- getFunctionContext() - Method in class org.apache.flink.streaming.api.operators.python.embedded.EmbeddedPythonWindowOperator
- getFunctionInput(IN) - Method in class org.apache.flink.table.runtime.operators.python.AbstractStatelessFunctionOperator
- getFunctionInput(RowData) - Method in class org.apache.flink.table.runtime.operators.python.aggregate.arrow.AbstractArrowPythonAggregateFunctionOperator
- getFunctionInput(RowData) - Method in class org.apache.flink.table.runtime.operators.python.scalar.AbstractPythonScalarFunctionOperator
- getFunctionInput(RowData) - Method in class org.apache.flink.table.runtime.operators.python.table.PythonTableFunctionOperator
- getFunctionType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.Builder
-
.org.apache.flink.fn_execution.v1.UserDefinedDataStreamFunction.FunctionType function_type = 1;
- getFunctionType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction
-
.org.apache.flink.fn_execution.v1.UserDefinedDataStreamFunction.FunctionType function_type = 1;
- getFunctionType() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunctionOrBuilder
-
.org.apache.flink.fn_execution.v1.UserDefinedDataStreamFunction.FunctionType function_type = 1;
- getFunctionType() - Method in class org.apache.flink.streaming.api.functions.python.DataStreamPythonFunctionInfo
- getFunctionTypeValue() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.Builder
-
.org.apache.flink.fn_execution.v1.UserDefinedDataStreamFunction.FunctionType function_type = 1;
- getFunctionTypeValue() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction
-
.org.apache.flink.fn_execution.v1.UserDefinedDataStreamFunction.FunctionType function_type = 1;
- getFunctionTypeValue() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunctionOrBuilder
-
.org.apache.flink.fn_execution.v1.UserDefinedDataStreamFunction.FunctionType function_type = 1;
- getFunctionUrn() - Method in class org.apache.flink.table.runtime.operators.python.AbstractStatelessFunctionOperator
- getFunctionUrn() - Method in class org.apache.flink.table.runtime.operators.python.aggregate.AbstractPythonStreamAggregateOperator
- getFunctionUrn() - Method in class org.apache.flink.table.runtime.operators.python.aggregate.arrow.AbstractArrowPythonAggregateFunctionOperator
- getFunctionUrn() - Method in class org.apache.flink.table.runtime.operators.python.aggregate.arrow.batch.BatchArrowPythonOverWindowAggregateFunctionOperator
- getFunctionUrn() - Method in class org.apache.flink.table.runtime.operators.python.aggregate.PythonStreamGroupAggregateOperator
- getFunctionUrn() - Method in class org.apache.flink.table.runtime.operators.python.aggregate.PythonStreamGroupTableAggregateOperator
- getFunctionUrn() - Method in class org.apache.flink.table.runtime.operators.python.aggregate.PythonStreamGroupWindowAggregateOperator
- getFunctionUrn() - Method in class org.apache.flink.table.runtime.operators.python.scalar.AbstractPythonScalarFunctionOperator
- getFunctionUrn() - Method in class org.apache.flink.table.runtime.operators.python.table.PythonTableFunctionOperator
- getGenerateUpdateBefore() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
-
Generate retract messages if true.
- getGenerateUpdateBefore() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions
-
Generate retract messages if true.
- getGenerateUpdateBefore() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctionsOrBuilder
-
Generate retract messages if true.
- getGrouping(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
-
The array of the key indexes.
- getGrouping(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions
-
The array of the key indexes.
- getGrouping(int) - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctionsOrBuilder
-
The array of the key indexes.
- getGroupingCount() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
-
The array of the key indexes.
- getGroupingCount() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions
-
The array of the key indexes.
- getGroupingCount() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctionsOrBuilder
-
The array of the key indexes.
- getGroupingList() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
-
The array of the key indexes.
- getGroupingList() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions
-
The array of the key indexes.
- getGroupingList() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctionsOrBuilder
-
The array of the key indexes.
- getGroupWindow() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
-
Group Window.
- getGroupWindow() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions
-
Group Window.
- getGroupWindow() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctionsOrBuilder
-
Group Window.
- getGroupWindowBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
-
Group Window.
- getGroupWindowOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
-
Group Window.
- getGroupWindowOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions
-
Group Window.
- getGroupWindowOrBuilder() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctionsOrBuilder
-
Group Window.
- getHasSideOutput() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.Builder
-
bool has_side_output = 7;
- getHasSideOutput() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction
-
bool has_side_output = 7;
- getHasSideOutput() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunctionOrBuilder
-
bool has_side_output = 7;
- getInBatchExecutionMode() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder
-
bool in_batch_execution_mode = 8;
- getInBatchExecutionMode() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext
-
bool in_batch_execution_mode = 8;
- getInBatchExecutionMode() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContextOrBuilder
-
bool in_batch_execution_mode = 8;
- getIncrementalCleanupStrategy() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry.Builder
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategy incremental_cleanup_strategy = 3;
- getIncrementalCleanupStrategy() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategy incremental_cleanup_strategy = 3;
- getIncrementalCleanupStrategy() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntryOrBuilder
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategy incremental_cleanup_strategy = 3;
- getIncrementalCleanupStrategyBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry.Builder
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategy incremental_cleanup_strategy = 3;
- getIncrementalCleanupStrategyOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry.Builder
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategy incremental_cleanup_strategy = 3;
- getIncrementalCleanupStrategyOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategy incremental_cleanup_strategy = 3;
- getIncrementalCleanupStrategyOrBuilder() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntryOrBuilder
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategy incremental_cleanup_strategy = 3;
- getIndexOfCountStar() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
-
The index of a count aggregate used to calculate the number of accumulated rows.
- getIndexOfCountStar() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions
-
The index of a count aggregate used to calculate the number of accumulated rows.
- getIndexOfCountStar() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctionsOrBuilder
-
The index of a count aggregate used to calculate the number of accumulated rows.
- getIndexOfThisSubtask() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder
-
int32 index_of_this_subtask = 5;
- getIndexOfThisSubtask() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext
-
int32 index_of_this_subtask = 5;
- getIndexOfThisSubtask() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContextOrBuilder
-
int32 index_of_this_subtask = 5;
- getInputCase() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input.Builder
- getInputCase() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input
- getInputCase() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.InputOrBuilder
- getInputConstant() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input.Builder
-
bytes inputConstant = 3;
- getInputConstant() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input
-
bytes inputConstant = 3;
- getInputConstant() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.InputOrBuilder
-
bytes inputConstant = 3;
- getInputFormat(List<Object[]>, DataType) - Static method in class org.apache.flink.table.utils.python.PythonTableUtils
-
Wrap the unpickled python data with an InputFormat.
- getInputOffset() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input.Builder
-
int32 inputOffset = 2;
- getInputOffset() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input
-
int32 inputOffset = 2;
- getInputOffset() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.InputOrBuilder
-
int32 inputOffset = 2;
- getInputs(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.Builder
-
The input arguments of the user-defined function, it could be one of the following: 1.
- getInputs(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction
-
The input arguments of the user-defined function, it could be one of the following: 1.
- getInputs(int) - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctionOrBuilder
-
The input arguments of the user-defined function, it could be one of the following: 1.
- getInputs(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction.Builder
-
The input arguments of the user-defined function, it could be one of the following: 1.
- getInputs(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction
-
The input arguments of the user-defined function, it could be one of the following: 1.
- getInputs(int) - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctionOrBuilder
-
The input arguments of the user-defined function, it could be one of the following: 1.
- getInputsBuilder(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.Builder
-
The input arguments of the user-defined function, it could be one of the following: 1.
- getInputsBuilder(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction.Builder
-
The input arguments of the user-defined function, it could be one of the following: 1.
- getInputsBuilderList() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.Builder
-
The input arguments of the user-defined function, it could be one of the following: 1.
- getInputsBuilderList() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction.Builder
-
The input arguments of the user-defined function, it could be one of the following: 1.
- getInputsCount() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.Builder
-
The input arguments of the user-defined function, it could be one of the following: 1.
- getInputsCount() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction
-
The input arguments of the user-defined function, it could be one of the following: 1.
- getInputsCount() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctionOrBuilder
-
The input arguments of the user-defined function, it could be one of the following: 1.
- getInputsCount() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction.Builder
-
The input arguments of the user-defined function, it could be one of the following: 1.
- getInputsCount() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction
-
The input arguments of the user-defined function, it could be one of the following: 1.
- getInputsCount() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctionOrBuilder
-
The input arguments of the user-defined function, it could be one of the following: 1.
- getInputsList() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.Builder
-
The input arguments of the user-defined function, it could be one of the following: 1.
- getInputsList() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction
-
The input arguments of the user-defined function, it could be one of the following: 1.
- getInputsList() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctionOrBuilder
-
The input arguments of the user-defined function, it could be one of the following: 1.
- getInputsList() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction.Builder
-
The input arguments of the user-defined function, it could be one of the following: 1.
- getInputsList() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction
-
The input arguments of the user-defined function, it could be one of the following: 1.
- getInputsList() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctionOrBuilder
-
The input arguments of the user-defined function, it could be one of the following: 1.
- getInputsOrBuilder(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.Builder
-
The input arguments of the user-defined function, it could be one of the following: 1.
- getInputsOrBuilder(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction
-
The input arguments of the user-defined function, it could be one of the following: 1.
- getInputsOrBuilder(int) - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctionOrBuilder
-
The input arguments of the user-defined function, it could be one of the following: 1.
- getInputsOrBuilder(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction.Builder
-
The input arguments of the user-defined function, it could be one of the following: 1.
- getInputsOrBuilder(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction
-
The input arguments of the user-defined function, it could be one of the following: 1.
- getInputsOrBuilder(int) - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctionOrBuilder
-
The input arguments of the user-defined function, it could be one of the following: 1.
- getInputsOrBuilderList() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.Builder
-
The input arguments of the user-defined function, it could be one of the following: 1.
- getInputsOrBuilderList() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction
-
The input arguments of the user-defined function, it could be one of the following: 1.
- getInputsOrBuilderList() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctionOrBuilder
-
The input arguments of the user-defined function, it could be one of the following: 1.
- getInputsOrBuilderList() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction.Builder
-
The input arguments of the user-defined function, it could be one of the following: 1.
- getInputsOrBuilderList() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction
-
The input arguments of the user-defined function, it could be one of the following: 1.
- getInputsOrBuilderList() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctionOrBuilder
-
The input arguments of the user-defined function, it could be one of the following: 1.
- getInputTypeInfo() - Method in class org.apache.flink.streaming.api.operators.python.process.AbstractExternalOneInputPythonFunctionOperator
- getInt(int) - Method in class org.apache.flink.table.runtime.arrow.vectors.ArrowDateColumnVector
- getInt(int) - Method in class org.apache.flink.table.runtime.arrow.vectors.ArrowIntColumnVector
- getInt(int) - Method in class org.apache.flink.table.runtime.arrow.vectors.ArrowTimeColumnVector
- getInternalParameters() - Method in class org.apache.flink.streaming.api.operators.python.process.AbstractExternalDataStreamPythonFunctionOperator
- getIsCleanupInBackground() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.Builder
-
bool is_cleanup_in_background = 1;
- getIsCleanupInBackground() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies
-
bool is_cleanup_in_background = 1;
- getIsCleanupInBackground() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategiesOrBuilder
-
bool is_cleanup_in_background = 1;
- getIsPandasUdf() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction.Builder
-
Whether it's pandas UDF
- getIsPandasUdf() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction
-
Whether it's pandas UDF
- getIsPandasUdf() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctionOrBuilder
-
Whether it's pandas UDF
- getIsRowTime() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.Builder
-
bool is_row_time = 6;
- getIsRowTime() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow
-
bool is_row_time = 6;
- getIsRowTime() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindowOrBuilder
-
bool is_row_time = 6;
- getIsTimeWindow() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.Builder
-
bool is_time_window = 2;
- getIsTimeWindow() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow
-
bool is_time_window = 2;
- getIsTimeWindow() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindowOrBuilder
-
bool is_time_window = 2;
- getJobParameters() - Method in class org.apache.flink.streaming.api.operators.python.embedded.AbstractEmbeddedDataStreamPythonFunctionOperator
- getJobParameters(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 14;
- getJobParameters(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions
-
repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 14;
- getJobParameters(int) - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctionsOrBuilder
-
repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 14;
- getJobParameters(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder
-
repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 7;
- getJobParameters(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext
-
repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 7;
- getJobParameters(int) - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContextOrBuilder
-
repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 7;
- getJobParameters(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 5;
- getJobParameters(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions
-
repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 5;
- getJobParameters(int) - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctionsOrBuilder
-
repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 5;
- getJobParametersBuilder(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 14;
- getJobParametersBuilder(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder
-
repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 7;
- getJobParametersBuilder(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 5;
- getJobParametersBuilderList() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 14;
- getJobParametersBuilderList() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder
-
repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 7;
- getJobParametersBuilderList() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 5;
- getJobParametersCount() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 14;
- getJobParametersCount() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions
-
repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 14;
- getJobParametersCount() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctionsOrBuilder
-
repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 14;
- getJobParametersCount() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder
-
repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 7;
- getJobParametersCount() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext
-
repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 7;
- getJobParametersCount() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContextOrBuilder
-
repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 7;
- getJobParametersCount() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 5;
- getJobParametersCount() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions
-
repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 5;
- getJobParametersCount() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctionsOrBuilder
-
repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 5;
- getJobParametersList() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 14;
- getJobParametersList() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions
-
repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 14;
- getJobParametersList() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctionsOrBuilder
-
repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 14;
- getJobParametersList() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder
-
repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 7;
- getJobParametersList() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext
-
repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 7;
- getJobParametersList() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContextOrBuilder
-
repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 7;
- getJobParametersList() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 5;
- getJobParametersList() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions
-
repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 5;
- getJobParametersList() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctionsOrBuilder
-
repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 5;
- getJobParametersOrBuilder(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 14;
- getJobParametersOrBuilder(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions
-
repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 14;
- getJobParametersOrBuilder(int) - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctionsOrBuilder
-
repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 14;
- getJobParametersOrBuilder(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder
-
repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 7;
- getJobParametersOrBuilder(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext
-
repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 7;
- getJobParametersOrBuilder(int) - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContextOrBuilder
-
repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 7;
- getJobParametersOrBuilder(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 5;
- getJobParametersOrBuilder(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions
-
repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 5;
- getJobParametersOrBuilder(int) - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctionsOrBuilder
-
repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 5;
- getJobParametersOrBuilderList() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 14;
- getJobParametersOrBuilderList() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions
-
repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 14;
- getJobParametersOrBuilderList() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctionsOrBuilder
-
repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 14;
- getJobParametersOrBuilderList() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder
-
repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 7;
- getJobParametersOrBuilderList() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext
-
repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 7;
- getJobParametersOrBuilderList() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContextOrBuilder
-
repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 7;
- getJobParametersOrBuilderList() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 5;
- getJobParametersOrBuilderList() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions
-
repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 5;
- getJobParametersOrBuilderList() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctionsOrBuilder
-
repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 5;
- getKey() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.JobParameter.Builder
-
string key = 1;
- getKey() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.JobParameter
-
string key = 1;
- getKey() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.JobParameterOrBuilder
-
string key = 1;
- getKey(Row) - Method in class org.apache.flink.streaming.api.functions.python.KeyByKeySelector
- getKey(Row) - Method in class org.apache.flink.streaming.api.functions.python.PartitionCustomKeySelector
- getKeyBytes() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.JobParameter.Builder
-
string key = 1;
- getKeyBytes() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.JobParameter
-
string key = 1;
- getKeyBytes() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.JobParameterOrBuilder
-
string key = 1;
- getKeySelector() - Method in class org.apache.flink.streaming.api.transformations.python.PythonKeyedBroadcastStateTransformation
- getKeyType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.MapInfo.Builder
-
.org.apache.flink.fn_execution.v1.Schema.FieldType key_type = 1;
- getKeyType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.MapInfo
-
.org.apache.flink.fn_execution.v1.Schema.FieldType key_type = 1;
- getKeyType() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.MapInfoOrBuilder
-
.org.apache.flink.fn_execution.v1.Schema.FieldType key_type = 1;
- getKeyType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.MapTypeInfo.Builder
-
.org.apache.flink.fn_execution.v1.TypeInfo key_type = 1;
- getKeyType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.MapTypeInfo
-
.org.apache.flink.fn_execution.v1.TypeInfo key_type = 1;
- getKeyType() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.MapTypeInfoOrBuilder
-
.org.apache.flink.fn_execution.v1.TypeInfo key_type = 1;
- getKeyType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapView.Builder
-
.org.apache.flink.fn_execution.v1.Schema.FieldType key_type = 1;
- getKeyType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapView
-
.org.apache.flink.fn_execution.v1.Schema.FieldType key_type = 1;
- getKeyType() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapViewOrBuilder
-
.org.apache.flink.fn_execution.v1.Schema.FieldType key_type = 1;
- getKeyType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
-
The schema of the grouping keys.
- getKeyType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions
-
The schema of the grouping keys.
- getKeyType() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctionsOrBuilder
-
The schema of the grouping keys.
- getKeyType() - Method in class org.apache.flink.table.runtime.operators.python.aggregate.AbstractPythonStreamAggregateOperator
- getKeyTypeBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.MapInfo.Builder
-
.org.apache.flink.fn_execution.v1.Schema.FieldType key_type = 1;
- getKeyTypeBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.MapTypeInfo.Builder
-
.org.apache.flink.fn_execution.v1.TypeInfo key_type = 1;
- getKeyTypeBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapView.Builder
-
.org.apache.flink.fn_execution.v1.Schema.FieldType key_type = 1;
- getKeyTypeBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
-
The schema of the grouping keys.
- getKeyTypeInfo() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.Builder
-
.org.apache.flink.fn_execution.v1.TypeInfo key_type_info = 5;
- getKeyTypeInfo() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction
-
.org.apache.flink.fn_execution.v1.TypeInfo key_type_info = 5;
- getKeyTypeInfo() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunctionOrBuilder
-
.org.apache.flink.fn_execution.v1.TypeInfo key_type_info = 5;
- getKeyTypeInfoBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.Builder
-
.org.apache.flink.fn_execution.v1.TypeInfo key_type_info = 5;
- getKeyTypeInfoOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.Builder
-
.org.apache.flink.fn_execution.v1.TypeInfo key_type_info = 5;
- getKeyTypeInfoOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction
-
.org.apache.flink.fn_execution.v1.TypeInfo key_type_info = 5;
- getKeyTypeInfoOrBuilder() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunctionOrBuilder
-
.org.apache.flink.fn_execution.v1.TypeInfo key_type_info = 5;
- getKeyTypeOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.MapInfo.Builder
-
.org.apache.flink.fn_execution.v1.Schema.FieldType key_type = 1;
- getKeyTypeOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.MapInfo
-
.org.apache.flink.fn_execution.v1.Schema.FieldType key_type = 1;
- getKeyTypeOrBuilder() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.MapInfoOrBuilder
-
.org.apache.flink.fn_execution.v1.Schema.FieldType key_type = 1;
- getKeyTypeOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.MapTypeInfo.Builder
-
.org.apache.flink.fn_execution.v1.TypeInfo key_type = 1;
- getKeyTypeOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.MapTypeInfo
-
.org.apache.flink.fn_execution.v1.TypeInfo key_type = 1;
- getKeyTypeOrBuilder() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.MapTypeInfoOrBuilder
-
.org.apache.flink.fn_execution.v1.TypeInfo key_type = 1;
- getKeyTypeOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapView.Builder
-
.org.apache.flink.fn_execution.v1.Schema.FieldType key_type = 1;
- getKeyTypeOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapView
-
.org.apache.flink.fn_execution.v1.Schema.FieldType key_type = 1;
- getKeyTypeOrBuilder() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapViewOrBuilder
-
.org.apache.flink.fn_execution.v1.Schema.FieldType key_type = 1;
- getKeyTypeOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
-
The schema of the grouping keys.
- getKeyTypeOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions
-
The schema of the grouping keys.
- getKeyTypeOrBuilder() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctionsOrBuilder
-
The schema of the grouping keys.
- getLeftInputType() - Method in class org.apache.flink.streaming.api.operators.python.process.AbstractExternalTwoInputPythonFunctionOperator
- getLength() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.BinaryInfo.Builder
-
int32 length = 1;
- getLength() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.BinaryInfo
-
int32 length = 1;
- getLength() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.BinaryInfoOrBuilder
-
int32 length = 1;
- getLength() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.CharInfo.Builder
-
int32 length = 1;
- getLength() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.CharInfo
-
int32 length = 1;
- getLength() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.CharInfoOrBuilder
-
int32 length = 1;
- getLength() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarBinaryInfo.Builder
-
int32 length = 1;
- getLength() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarBinaryInfo
-
int32 length = 1;
- getLength() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarBinaryInfoOrBuilder
-
int32 length = 1;
- getLength() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarCharInfo.Builder
-
int32 length = 1;
- getLength() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarCharInfo
-
int32 length = 1;
- getLength() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarCharInfoOrBuilder
-
int32 length = 1;
- getLength() - Method in class org.apache.flink.streaming.api.utils.ByteArrayWrapperSerializer
- getLength() - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.BigDecSerializer
- getLength() - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.DateSerializer
- getLength() - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.DecimalDataSerializer
- getLength() - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.StringSerializer
- getLength() - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.TimeSerializer
- getLength() - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.TimestampSerializer
- getLimit() - Method in class org.apache.flink.streaming.api.utils.ByteArrayWrapper
- getListState(BeamFnApi.StateRequest) - Method in class org.apache.flink.streaming.api.runners.python.beam.state.BeamKeyedStateStore
- getListState(BeamFnApi.StateRequest) - Method in class org.apache.flink.streaming.api.runners.python.beam.state.BeamOperatorStateStore
-
Currently list state and union-list state is not supported.
- getListState(BeamFnApi.StateRequest) - Method in interface org.apache.flink.streaming.api.runners.python.beam.state.BeamStateStore
-
Parse
BeamFnApi.StateRequest
and return the correspondingListState
. - getListView() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.Builder
-
.org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction.DataViewSpec.ListView list_view = 3;
- getListView() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec
-
.org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction.DataViewSpec.ListView list_view = 3;
- getListView() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpecOrBuilder
-
.org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction.DataViewSpec.ListView list_view = 3;
- getListViewBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.Builder
-
.org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction.DataViewSpec.ListView list_view = 3;
- getListViewOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.Builder
-
.org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction.DataViewSpec.ListView list_view = 3;
- getListViewOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec
-
.org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction.DataViewSpec.ListView list_view = 3;
- getListViewOrBuilder() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpecOrBuilder
-
.org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction.DataViewSpec.ListView list_view = 3;
- getLocalZonedTimestampInfo() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.LocalZonedTimestampInfo local_zoned_timestamp_info = 9;
- getLocalZonedTimestampInfo() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
-
.org.apache.flink.fn_execution.v1.Schema.LocalZonedTimestampInfo local_zoned_timestamp_info = 9;
- getLocalZonedTimestampInfo() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldTypeOrBuilder
-
.org.apache.flink.fn_execution.v1.Schema.LocalZonedTimestampInfo local_zoned_timestamp_info = 9;
- getLocalZonedTimestampInfoBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.LocalZonedTimestampInfo local_zoned_timestamp_info = 9;
- getLocalZonedTimestampInfoOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.LocalZonedTimestampInfo local_zoned_timestamp_info = 9;
- getLocalZonedTimestampInfoOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
-
.org.apache.flink.fn_execution.v1.Schema.LocalZonedTimestampInfo local_zoned_timestamp_info = 9;
- getLocalZonedTimestampInfoOrBuilder() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldTypeOrBuilder
-
.org.apache.flink.fn_execution.v1.Schema.LocalZonedTimestampInfo local_zoned_timestamp_info = 9;
- getLong(int) - Method in class org.apache.flink.table.runtime.arrow.vectors.ArrowBigIntColumnVector
- getLowerBoundary() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow.Builder
-
int64 lower_boundary = 2;
- getLowerBoundary() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow
-
int64 lower_boundary = 2;
- getLowerBoundary() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindowOrBuilder
-
int64 lower_boundary = 2;
- getMap(int) - Method in class org.apache.flink.table.runtime.arrow.vectors.ArrowMapColumnVector
- getMapInfo() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.MapInfo map_info = 4;
- getMapInfo() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
-
.org.apache.flink.fn_execution.v1.Schema.MapInfo map_info = 4;
- getMapInfo() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldTypeOrBuilder
-
.org.apache.flink.fn_execution.v1.Schema.MapInfo map_info = 4;
- getMapInfoBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.MapInfo map_info = 4;
- getMapInfoOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.MapInfo map_info = 4;
- getMapInfoOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
-
.org.apache.flink.fn_execution.v1.Schema.MapInfo map_info = 4;
- getMapInfoOrBuilder() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldTypeOrBuilder
-
.org.apache.flink.fn_execution.v1.Schema.MapInfo map_info = 4;
- getMapState(BeamFnApi.StateRequest) - Method in class org.apache.flink.streaming.api.runners.python.beam.state.BeamKeyedStateStore
- getMapState(BeamFnApi.StateRequest) - Method in class org.apache.flink.streaming.api.runners.python.beam.state.BeamOperatorStateStore
-
Returns a
BroadcastState
wrapped inMapState
interface. - getMapState(BeamFnApi.StateRequest) - Method in interface org.apache.flink.streaming.api.runners.python.beam.state.BeamStateStore
-
Parse
BeamFnApi.StateRequest
and return the correspondingMapState
. - getMapStateReadCacheSize() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
-
The map state read cache size.
- getMapStateReadCacheSize() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions
-
The map state read cache size.
- getMapStateReadCacheSize() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctionsOrBuilder
-
The map state read cache size.
- getMapStateReadCacheSize() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.Builder
-
The map state read cache size.
- getMapStateReadCacheSize() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction
-
The map state read cache size.
- getMapStateReadCacheSize() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunctionOrBuilder
-
The map state read cache size.
- getMapStateWriteCacheSize() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
-
The map_state_write_cache_size.
- getMapStateWriteCacheSize() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions
-
The map_state_write_cache_size.
- getMapStateWriteCacheSize() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctionsOrBuilder
-
The map_state_write_cache_size.
- getMapStateWriteCacheSize() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.Builder
-
The map_state_write_cache_size.
- getMapStateWriteCacheSize() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction
-
The map_state_write_cache_size.
- getMapStateWriteCacheSize() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunctionOrBuilder
-
The map_state_write_cache_size.
- getMapTypeInfo() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.Builder
-
.org.apache.flink.fn_execution.v1.TypeInfo.MapTypeInfo map_type_info = 5;
- getMapTypeInfo() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo
-
.org.apache.flink.fn_execution.v1.TypeInfo.MapTypeInfo map_type_info = 5;
- getMapTypeInfo() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfoOrBuilder
-
.org.apache.flink.fn_execution.v1.TypeInfo.MapTypeInfo map_type_info = 5;
- getMapTypeInfoBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.Builder
-
.org.apache.flink.fn_execution.v1.TypeInfo.MapTypeInfo map_type_info = 5;
- getMapTypeInfoOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.Builder
-
.org.apache.flink.fn_execution.v1.TypeInfo.MapTypeInfo map_type_info = 5;
- getMapTypeInfoOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo
-
.org.apache.flink.fn_execution.v1.TypeInfo.MapTypeInfo map_type_info = 5;
- getMapTypeInfoOrBuilder() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfoOrBuilder
-
.org.apache.flink.fn_execution.v1.TypeInfo.MapTypeInfo map_type_info = 5;
- getMapView() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.Builder
-
.org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction.DataViewSpec.MapView map_view = 4;
- getMapView() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec
-
.org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction.DataViewSpec.MapView map_view = 4;
- getMapView() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpecOrBuilder
-
.org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction.DataViewSpec.MapView map_view = 4;
- getMapViewBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.Builder
-
.org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction.DataViewSpec.MapView map_view = 4;
- getMapViewOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.Builder
-
.org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction.DataViewSpec.MapView map_view = 4;
- getMapViewOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec
-
.org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction.DataViewSpec.MapView map_view = 4;
- getMapViewOrBuilder() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpecOrBuilder
-
.org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction.DataViewSpec.MapView map_view = 4;
- getMaxNumberOfParallelSubtasks() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder
-
int32 max_number_of_parallel_subtasks = 4;
- getMaxNumberOfParallelSubtasks() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext
-
int32 max_number_of_parallel_subtasks = 4;
- getMaxNumberOfParallelSubtasks() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContextOrBuilder
-
int32 max_number_of_parallel_subtasks = 4;
- getMetricEnabled() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
-
bool metric_enabled = 2;
- getMetricEnabled() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions
-
bool metric_enabled = 2;
- getMetricEnabled() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctionsOrBuilder
-
bool metric_enabled = 2;
- getMetricEnabled() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.Builder
-
bool metric_enabled = 4;
- getMetricEnabled() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction
-
bool metric_enabled = 4;
- getMetricEnabled() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunctionOrBuilder
-
bool metric_enabled = 4;
- getMetricEnabled() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions.Builder
-
bool metric_enabled = 2;
- getMetricEnabled() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions
-
bool metric_enabled = 2;
- getMetricEnabled() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctionsOrBuilder
-
bool metric_enabled = 2;
- getMode() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.Builder
-
.org.apache.flink.fn_execution.v1.CoderInfoDescriptor.Mode mode = 6;
- getMode() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor
-
.org.apache.flink.fn_execution.v1.CoderInfoDescriptor.Mode mode = 6;
- getMode() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptorOrBuilder
-
.org.apache.flink.fn_execution.v1.CoderInfoDescriptor.Mode mode = 6;
- getModeValue() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.Builder
-
.org.apache.flink.fn_execution.v1.CoderInfoDescriptor.Mode mode = 6;
- getModeValue() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor
-
.org.apache.flink.fn_execution.v1.CoderInfoDescriptor.Mode mode = 6;
- getModeValue() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptorOrBuilder
-
.org.apache.flink.fn_execution.v1.CoderInfoDescriptor.Mode mode = 6;
- getName() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Field.Builder
-
string name = 1;
- getName() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Field
-
string name = 1;
- getName() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldOrBuilder
-
string name = 1;
- getName() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.Builder
-
string name = 1;
- getName() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec
-
string name = 1;
- getName() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpecOrBuilder
-
string name = 1;
- getNameBytes() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Field.Builder
-
string name = 1;
- getNameBytes() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Field
-
string name = 1;
- getNameBytes() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldOrBuilder
-
string name = 1;
- getNameBytes() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.Builder
-
string name = 1;
- getNameBytes() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec
-
string name = 1;
- getNameBytes() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpecOrBuilder
-
string name = 1;
- getNamedProperties(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.Builder
-
repeated .org.apache.flink.fn_execution.v1.GroupWindow.WindowProperty namedProperties = 9;
- getNamedProperties(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow
-
repeated .org.apache.flink.fn_execution.v1.GroupWindow.WindowProperty namedProperties = 9;
- getNamedProperties(int) - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindowOrBuilder
-
repeated .org.apache.flink.fn_execution.v1.GroupWindow.WindowProperty namedProperties = 9;
- getNamedPropertiesCount() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.Builder
-
repeated .org.apache.flink.fn_execution.v1.GroupWindow.WindowProperty namedProperties = 9;
- getNamedPropertiesCount() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow
-
repeated .org.apache.flink.fn_execution.v1.GroupWindow.WindowProperty namedProperties = 9;
- getNamedPropertiesCount() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindowOrBuilder
-
repeated .org.apache.flink.fn_execution.v1.GroupWindow.WindowProperty namedProperties = 9;
- getNamedPropertiesList() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.Builder
-
repeated .org.apache.flink.fn_execution.v1.GroupWindow.WindowProperty namedProperties = 9;
- getNamedPropertiesList() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow
-
repeated .org.apache.flink.fn_execution.v1.GroupWindow.WindowProperty namedProperties = 9;
- getNamedPropertiesList() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindowOrBuilder
-
repeated .org.apache.flink.fn_execution.v1.GroupWindow.WindowProperty namedProperties = 9;
- getNamedPropertiesValue(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.Builder
-
repeated .org.apache.flink.fn_execution.v1.GroupWindow.WindowProperty namedProperties = 9;
- getNamedPropertiesValue(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow
-
repeated .org.apache.flink.fn_execution.v1.GroupWindow.WindowProperty namedProperties = 9;
- getNamedPropertiesValue(int) - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindowOrBuilder
-
repeated .org.apache.flink.fn_execution.v1.GroupWindow.WindowProperty namedProperties = 9;
- getNamedPropertiesValueList() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.Builder
-
repeated .org.apache.flink.fn_execution.v1.GroupWindow.WindowProperty namedProperties = 9;
- getNamedPropertiesValueList() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow
-
repeated .org.apache.flink.fn_execution.v1.GroupWindow.WindowProperty namedProperties = 9;
- getNamedPropertiesValueList() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindowOrBuilder
-
repeated .org.apache.flink.fn_execution.v1.GroupWindow.WindowProperty namedProperties = 9;
- getNullable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
bool nullable = 2;
- getNullable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
-
bool nullable = 2;
- getNullable() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldTypeOrBuilder
-
bool nullable = 2;
- getNumber() - Method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.DataTypeCase
- getNumber() - Method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.Mode
- getNumber() - Method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.WindowProperty
- getNumber() - Method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.WindowType
- getNumber() - Method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.Input.InputCase
- getNumber() - Method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow.WindowType
- getNumber() - Method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.TypeInfoCase
- getNumber() - Method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TypeName
- getNumber() - Method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.EmptyCleanupStrategy
- getNumber() - Method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry.CleanupStrategyCase
- getNumber() - Method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.Strategies
- getNumber() - Method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.StateVisibility
- getNumber() - Method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.TtlTimeCharacteristic
- getNumber() - Method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.UpdateType
- getNumber() - Method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TypeInfoCase
- getNumber() - Method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TypeName
- getNumber() - Method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.DataViewCase
- getNumber() - Method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.FunctionType
- getNumberOfParallelSubtasks() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder
-
int32 number_of_parallel_subtasks = 3;
- getNumberOfParallelSubtasks() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext
-
int32 number_of_parallel_subtasks = 3;
- getNumberOfParallelSubtasks() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContextOrBuilder
-
int32 number_of_parallel_subtasks = 3;
- getNumPartitions() - Method in class org.apache.flink.streaming.api.transformations.python.DelegateOperatorTransformation.DelegateOperator
- getOffset() - Method in class org.apache.flink.streaming.api.utils.ByteArrayWrapper
- getOperatorFactory() - Method in interface org.apache.flink.streaming.api.transformations.python.DelegateOperatorTransformation
- getOperatorFactory() - Method in class org.apache.flink.streaming.api.transformations.python.PythonBroadcastStateTransformation
- getOperatorFactory() - Method in class org.apache.flink.streaming.api.transformations.python.PythonKeyedBroadcastStateTransformation
- getOperatorFactory(Transformation<?>) - Static method in class org.apache.flink.python.util.PythonConfigUtil
- getOptional(ConfigOption<T>) - Method in class org.apache.flink.python.PythonConfig
- getOptionalTimerCoderProto() - Method in class org.apache.flink.streaming.api.runners.python.beam.BeamDataStreamPythonFunctionRunner
- getOptionalTimerCoderProto() - Method in class org.apache.flink.streaming.api.runners.python.beam.BeamPythonFunctionRunner
- getOptionalTimerCoderProto() - Method in class org.apache.flink.table.runtime.runners.python.beam.BeamTablePythonFunctionRunner
- getOrd() - Method in enum org.apache.flink.streaming.api.runners.python.beam.state.IterateType
- getOutputTagById(String) - Method in class org.apache.flink.streaming.api.operators.python.process.AbstractExternalDataStreamPythonFunctionOperator
- getOverWindowArrowType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.Builder
-
.org.apache.flink.fn_execution.v1.CoderInfoDescriptor.OverWindowArrowType over_window_arrow_type = 4;
- getOverWindowArrowType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor
-
.org.apache.flink.fn_execution.v1.CoderInfoDescriptor.OverWindowArrowType over_window_arrow_type = 4;
- getOverWindowArrowType() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptorOrBuilder
-
.org.apache.flink.fn_execution.v1.CoderInfoDescriptor.OverWindowArrowType over_window_arrow_type = 4;
- getOverWindowArrowTypeBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.Builder
-
.org.apache.flink.fn_execution.v1.CoderInfoDescriptor.OverWindowArrowType over_window_arrow_type = 4;
- getOverWindowArrowTypeOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.Builder
-
.org.apache.flink.fn_execution.v1.CoderInfoDescriptor.OverWindowArrowType over_window_arrow_type = 4;
- getOverWindowArrowTypeOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor
-
.org.apache.flink.fn_execution.v1.CoderInfoDescriptor.OverWindowArrowType over_window_arrow_type = 4;
- getOverWindowArrowTypeOrBuilder() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptorOrBuilder
-
.org.apache.flink.fn_execution.v1.CoderInfoDescriptor.OverWindowArrowType over_window_arrow_type = 4;
- getParserForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.ArrowType
- getParserForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.FlattenRowType
- getParserForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor
- getParserForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.OverWindowArrowType
- getParserForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RawType
- getParserForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RowType
- getParserForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow
- getParserForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input
- getParserForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.JobParameter
- getParserForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow
- getParserForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.BinaryInfo
- getParserForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.CharInfo
- getParserForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.DecimalInfo
- getParserForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Field
- getParserForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
- getParserForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema
- getParserForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.LocalZonedTimestampInfo
- getParserForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.MapInfo
- getParserForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimeInfo
- getParserForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimestampInfo
- getParserForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarBinaryInfo
- getParserForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarCharInfo
- getParserForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.ZonedTimestampInfo
- getParserForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor
- getParserForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies
- getParserForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategy
- getParserForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry
- getParserForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.RocksdbCompactFilterCleanupStrategy
- getParserForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig
- getParserForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.AvroTypeInfo
- getParserForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo
- getParserForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.MapTypeInfo
- getParserForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Field
- getParserForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo
- getParserForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TupleTypeInfo
- getParserForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec
- getParserForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.ListView
- getParserForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapView
- getParserForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction
- getParserForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions
- getParserForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction
- getParserForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext
- getParserForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction
- getParserForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions
- getPayload() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.Builder
-
The serialized representation of the user-defined function
- getPayload() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction
-
The serialized representation of the user-defined function
- getPayload() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctionOrBuilder
-
The serialized representation of the user-defined function
- getPayload() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.Builder
-
bytes payload = 3;
- getPayload() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction
-
bytes payload = 3;
- getPayload() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunctionOrBuilder
-
bytes payload = 3;
- getPayload() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction.Builder
-
The serialized representation of the user-defined function
- getPayload() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction
-
The serialized representation of the user-defined function
- getPayload() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctionOrBuilder
-
The serialized representation of the user-defined function
- getPickledBytesFromJavaObject(Object, TypeInformation<?>) - Static method in class org.apache.flink.api.common.python.PythonBridgeUtils
- getPickledBytesFromRow(Row, DataType[]) - Static method in class org.apache.flink.api.common.python.PythonBridgeUtils
- getPrecision() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.DecimalInfo.Builder
-
int32 precision = 1;
- getPrecision() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.DecimalInfo
-
int32 precision = 1;
- getPrecision() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.DecimalInfoOrBuilder
-
int32 precision = 1;
- getPrecision() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.LocalZonedTimestampInfo.Builder
-
int32 precision = 1;
- getPrecision() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.LocalZonedTimestampInfo
-
int32 precision = 1;
- getPrecision() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.LocalZonedTimestampInfoOrBuilder
-
int32 precision = 1;
- getPrecision() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimeInfo.Builder
-
int32 precision = 1;
- getPrecision() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimeInfo
-
int32 precision = 1;
- getPrecision() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimeInfoOrBuilder
-
int32 precision = 1;
- getPrecision() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimestampInfo.Builder
-
int32 precision = 1;
- getPrecision() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimestampInfo
-
int32 precision = 1;
- getPrecision() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimestampInfoOrBuilder
-
int32 precision = 1;
- getPrecision() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.ZonedTimestampInfo.Builder
-
int32 precision = 1;
- getPrecision() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.ZonedTimestampInfo
-
int32 precision = 1;
- getPrecision() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.ZonedTimestampInfoOrBuilder
-
int32 precision = 1;
- getProducedType() - Method in class org.apache.flink.formats.avro.AvroRowDeserializationSchema
- getProducedType() - Method in class org.apache.flink.formats.csv.CsvRowDeserializationSchema
- getProducedType() - Method in class org.apache.flink.formats.json.JsonRowDeserializationSchema
- getProducedType() - Method in class org.apache.flink.streaming.api.operators.python.embedded.AbstractEmbeddedDataStreamPythonFunctionOperator
- getProducedType() - Method in class org.apache.flink.streaming.api.operators.python.process.AbstractExternalDataStreamPythonFunctionOperator
- getProducedType() - Method in class org.apache.flink.streaming.api.transformations.python.DelegateOperatorTransformation.DelegateOperator
- getProducedType() - Method in class org.apache.flink.table.runtime.arrow.sources.ArrowSourceFunction
-
Deprecated.
- getProfileEnabled() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
-
bool profile_enabled = 13;
- getProfileEnabled() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions
-
bool profile_enabled = 13;
- getProfileEnabled() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctionsOrBuilder
-
bool profile_enabled = 13;
- getProfileEnabled() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.Builder
-
bool profile_enabled = 6;
- getProfileEnabled() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction
-
bool profile_enabled = 6;
- getProfileEnabled() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunctionOrBuilder
-
bool profile_enabled = 6;
- getProfileEnabled() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions.Builder
-
bool profile_enabled = 4;
- getProfileEnabled() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions
-
bool profile_enabled = 4;
- getProfileEnabled() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctionsOrBuilder
-
bool profile_enabled = 4;
- getPythonEnv() - Method in class org.apache.flink.python.env.AbstractPythonEnvironmentManager
- getPythonEnv() - Method in class org.apache.flink.streaming.api.functions.python.DataStreamPythonFunction
- getPythonEnv() - Method in class org.apache.flink.streaming.api.operators.python.process.AbstractExternalDataStreamPythonFunctionOperator
- getPythonEnv() - Method in class org.apache.flink.streaming.api.operators.python.process.AbstractExternalPythonFunctionOperator
-
Returns the
PythonEnv
used to create PythonEnvironmentManager.. - getPythonEnv() - Method in class org.apache.flink.table.runtime.operators.python.aggregate.AbstractPythonStreamAggregateOperator
- getPythonEnv() - Method in class org.apache.flink.table.runtime.operators.python.aggregate.arrow.AbstractArrowPythonAggregateFunctionOperator
- getPythonEnv() - Method in class org.apache.flink.table.runtime.operators.python.scalar.AbstractPythonScalarFunctionOperator
- getPythonEnv() - Method in class org.apache.flink.table.runtime.operators.python.table.PythonTableFunctionOperator
- getPythonExec() - Method in class org.apache.flink.python.env.PythonDependencyInfo
- getPythonFiles() - Method in class org.apache.flink.python.env.PythonDependencyInfo
- getPythonFunction(String, String) - Method in interface org.apache.flink.client.python.PythonFunctionFactory
-
Returns PythonFunction according to moduleName and objectName.
- getPythonFunction(String, String) - Method in class org.apache.flink.client.python.PythonFunctionFactoryImpl
- getPythonFunction(String, ReadableConfig, ClassLoader) - Static method in interface org.apache.flink.client.python.PythonFunctionFactory
-
Returns PythonFunction according to the fully qualified name of the Python UDF i.e ${moduleName}.
- getPythonFunctionInfo() - Method in interface org.apache.flink.streaming.api.operators.python.DataStreamPythonFunctionOperator
-
Returns the underlying
DataStreamPythonFunctionInfo
. - getPythonFunctionInfo() - Method in class org.apache.flink.streaming.api.operators.python.embedded.AbstractEmbeddedDataStreamPythonFunctionOperator
- getPythonFunctionInfo() - Method in class org.apache.flink.streaming.api.operators.python.process.AbstractExternalDataStreamPythonFunctionOperator
- getPythonFunctionInfo() - Method in class org.apache.flink.streaming.api.transformations.python.DelegateOperatorTransformation.DelegateOperator
- getPythonPath() - Method in class org.apache.flink.python.env.PythonDependencyInfo
- getPythonUdfRunnerScript(String, Map<String, String>) - Static method in class org.apache.flink.python.util.PythonEnvironmentManagerUtils
- getPythonVersion(String) - Static method in class org.apache.flink.python.util.PythonEnvironmentManagerUtils
- getQueryTimeAfterNumEntries() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.RocksdbCompactFilterCleanupStrategy.Builder
-
Number of state entries to process by compaction filter before updating current timestamp.
- getQueryTimeAfterNumEntries() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.RocksdbCompactFilterCleanupStrategy
-
Number of state entries to process by compaction filter before updating current timestamp.
- getQueryTimeAfterNumEntries() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.RocksdbCompactFilterCleanupStrategyOrBuilder
-
Number of state entries to process by compaction filter before updating current timestamp.
- getRawType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.Builder
-
for DataStream
- getRawType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor
-
for DataStream
- getRawType() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptorOrBuilder
-
for DataStream
- getRawTypeBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.Builder
-
for DataStream
- getRawTypeOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.Builder
-
for DataStream
- getRawTypeOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor
-
for DataStream
- getRawTypeOrBuilder() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptorOrBuilder
-
for DataStream
- getRequirementsCacheDir() - Method in class org.apache.flink.python.env.PythonDependencyInfo
- getRequirementsFilePath() - Method in class org.apache.flink.python.env.PythonDependencyInfo
- getRightInputType() - Method in class org.apache.flink.streaming.api.operators.python.process.AbstractExternalTwoInputPythonFunctionOperator
- getRocksdbCompactFilterCleanupStrategy() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry.Builder
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies.RocksdbCompactFilterCleanupStrategy rocksdb_compact_filter_cleanup_strategy = 4;
- getRocksdbCompactFilterCleanupStrategy() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies.RocksdbCompactFilterCleanupStrategy rocksdb_compact_filter_cleanup_strategy = 4;
- getRocksdbCompactFilterCleanupStrategy() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntryOrBuilder
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies.RocksdbCompactFilterCleanupStrategy rocksdb_compact_filter_cleanup_strategy = 4;
- getRocksdbCompactFilterCleanupStrategyBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry.Builder
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies.RocksdbCompactFilterCleanupStrategy rocksdb_compact_filter_cleanup_strategy = 4;
- getRocksdbCompactFilterCleanupStrategyOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry.Builder
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies.RocksdbCompactFilterCleanupStrategy rocksdb_compact_filter_cleanup_strategy = 4;
- getRocksdbCompactFilterCleanupStrategyOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies.RocksdbCompactFilterCleanupStrategy rocksdb_compact_filter_cleanup_strategy = 4;
- getRocksdbCompactFilterCleanupStrategyOrBuilder() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntryOrBuilder
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies.RocksdbCompactFilterCleanupStrategy rocksdb_compact_filter_cleanup_strategy = 4;
- getRootAllocator() - Static method in class org.apache.flink.table.runtime.arrow.ArrowUtils
- getRow(int) - Method in class org.apache.flink.table.runtime.arrow.vectors.ArrowRowColumnVector
- getRowSchema() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema row_schema = 5;
- getRowSchema() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
-
.org.apache.flink.fn_execution.v1.Schema row_schema = 5;
- getRowSchema() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldTypeOrBuilder
-
.org.apache.flink.fn_execution.v1.Schema row_schema = 5;
- getRowSchemaBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema row_schema = 5;
- getRowSchemaOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema row_schema = 5;
- getRowSchemaOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
-
.org.apache.flink.fn_execution.v1.Schema row_schema = 5;
- getRowSchemaOrBuilder() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldTypeOrBuilder
-
.org.apache.flink.fn_execution.v1.Schema row_schema = 5;
- getRowType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.Builder
-
.org.apache.flink.fn_execution.v1.CoderInfoDescriptor.RowType row_type = 2;
- getRowType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor
-
.org.apache.flink.fn_execution.v1.CoderInfoDescriptor.RowType row_type = 2;
- getRowType() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptorOrBuilder
-
.org.apache.flink.fn_execution.v1.CoderInfoDescriptor.RowType row_type = 2;
- getRowTypeBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.Builder
-
.org.apache.flink.fn_execution.v1.CoderInfoDescriptor.RowType row_type = 2;
- getRowTypeInfo() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.Builder
-
.org.apache.flink.fn_execution.v1.TypeInfo.RowTypeInfo row_type_info = 3;
- getRowTypeInfo() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo
-
.org.apache.flink.fn_execution.v1.TypeInfo.RowTypeInfo row_type_info = 3;
- getRowTypeInfo() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfoOrBuilder
-
.org.apache.flink.fn_execution.v1.TypeInfo.RowTypeInfo row_type_info = 3;
- getRowTypeInfoBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.Builder
-
.org.apache.flink.fn_execution.v1.TypeInfo.RowTypeInfo row_type_info = 3;
- getRowTypeInfoOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.Builder
-
.org.apache.flink.fn_execution.v1.TypeInfo.RowTypeInfo row_type_info = 3;
- getRowTypeInfoOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo
-
.org.apache.flink.fn_execution.v1.TypeInfo.RowTypeInfo row_type_info = 3;
- getRowTypeInfoOrBuilder() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfoOrBuilder
-
.org.apache.flink.fn_execution.v1.TypeInfo.RowTypeInfo row_type_info = 3;
- getRowTypeOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.Builder
-
.org.apache.flink.fn_execution.v1.CoderInfoDescriptor.RowType row_type = 2;
- getRowTypeOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor
-
.org.apache.flink.fn_execution.v1.CoderInfoDescriptor.RowType row_type = 2;
- getRowTypeOrBuilder() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptorOrBuilder
-
.org.apache.flink.fn_execution.v1.CoderInfoDescriptor.RowType row_type = 2;
- getRunCleanupForEveryRecord() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategy.Builder
-
Whether to run incremental cleanup per each processed record.
- getRunCleanupForEveryRecord() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategy
-
Whether to run incremental cleanup per each processed record.
- getRunCleanupForEveryRecord() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategyOrBuilder
-
Whether to run incremental cleanup per each processed record.
- getRunnerOutputTypeInfo(TypeInformation<?>) - Static method in class org.apache.flink.streaming.api.operators.python.process.collector.RunnerOutputCollector
- getRuntimeContext() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.Builder
-
.org.apache.flink.fn_execution.v1.UserDefinedDataStreamFunction.RuntimeContext runtime_context = 2;
- getRuntimeContext() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction
-
.org.apache.flink.fn_execution.v1.UserDefinedDataStreamFunction.RuntimeContext runtime_context = 2;
- getRuntimeContext() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunctionOrBuilder
-
.org.apache.flink.fn_execution.v1.UserDefinedDataStreamFunction.RuntimeContext runtime_context = 2;
- getRuntimeContextBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.Builder
-
.org.apache.flink.fn_execution.v1.UserDefinedDataStreamFunction.RuntimeContext runtime_context = 2;
- getRuntimeContextOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.Builder
-
.org.apache.flink.fn_execution.v1.UserDefinedDataStreamFunction.RuntimeContext runtime_context = 2;
- getRuntimeContextOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction
-
.org.apache.flink.fn_execution.v1.UserDefinedDataStreamFunction.RuntimeContext runtime_context = 2;
- getRuntimeContextOrBuilder() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunctionOrBuilder
-
.org.apache.flink.fn_execution.v1.UserDefinedDataStreamFunction.RuntimeContext runtime_context = 2;
- getScale() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.DecimalInfo.Builder
-
int32 scale = 2;
- getScale() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.DecimalInfo
-
int32 scale = 2;
- getScale() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.DecimalInfoOrBuilder
-
int32 scale = 2;
- getScanRuntimeProvider(ScanTableSource.ScanContext) - Method in class org.apache.flink.table.runtime.arrow.sources.ArrowTableSource
- getScanRuntimeProvider(ScanTableSource.ScanContext) - Method in class org.apache.flink.table.utils.python.PythonDynamicTableSource
- getSchema() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.ArrowType.Builder
-
.org.apache.flink.fn_execution.v1.Schema schema = 1;
- getSchema() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.ArrowType
-
.org.apache.flink.fn_execution.v1.Schema schema = 1;
- getSchema() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.ArrowTypeOrBuilder
-
.org.apache.flink.fn_execution.v1.Schema schema = 1;
- getSchema() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.FlattenRowType.Builder
-
.org.apache.flink.fn_execution.v1.Schema schema = 1;
- getSchema() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.FlattenRowType
-
.org.apache.flink.fn_execution.v1.Schema schema = 1;
- getSchema() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.FlattenRowTypeOrBuilder
-
.org.apache.flink.fn_execution.v1.Schema schema = 1;
- getSchema() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.OverWindowArrowType.Builder
-
.org.apache.flink.fn_execution.v1.Schema schema = 1;
- getSchema() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.OverWindowArrowType
-
.org.apache.flink.fn_execution.v1.Schema schema = 1;
- getSchema() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.OverWindowArrowTypeOrBuilder
-
.org.apache.flink.fn_execution.v1.Schema schema = 1;
- getSchema() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RowType.Builder
-
.org.apache.flink.fn_execution.v1.Schema schema = 1;
- getSchema() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RowType
-
.org.apache.flink.fn_execution.v1.Schema schema = 1;
- getSchema() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RowTypeOrBuilder
-
.org.apache.flink.fn_execution.v1.Schema schema = 1;
- getSchema() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.AvroTypeInfo.Builder
-
string schema = 1;
- getSchema() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.AvroTypeInfo
-
string schema = 1;
- getSchema() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.AvroTypeInfoOrBuilder
-
string schema = 1;
- getSchemaBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.ArrowType.Builder
-
.org.apache.flink.fn_execution.v1.Schema schema = 1;
- getSchemaBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.FlattenRowType.Builder
-
.org.apache.flink.fn_execution.v1.Schema schema = 1;
- getSchemaBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.OverWindowArrowType.Builder
-
.org.apache.flink.fn_execution.v1.Schema schema = 1;
- getSchemaBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RowType.Builder
-
.org.apache.flink.fn_execution.v1.Schema schema = 1;
- getSchemaBytes() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.AvroTypeInfo.Builder
-
string schema = 1;
- getSchemaBytes() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.AvroTypeInfo
-
string schema = 1;
- getSchemaBytes() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.AvroTypeInfoOrBuilder
-
string schema = 1;
- getSchemaOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.ArrowType.Builder
-
.org.apache.flink.fn_execution.v1.Schema schema = 1;
- getSchemaOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.ArrowType
-
.org.apache.flink.fn_execution.v1.Schema schema = 1;
- getSchemaOrBuilder() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.ArrowTypeOrBuilder
-
.org.apache.flink.fn_execution.v1.Schema schema = 1;
- getSchemaOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.FlattenRowType.Builder
-
.org.apache.flink.fn_execution.v1.Schema schema = 1;
- getSchemaOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.FlattenRowType
-
.org.apache.flink.fn_execution.v1.Schema schema = 1;
- getSchemaOrBuilder() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.FlattenRowTypeOrBuilder
-
.org.apache.flink.fn_execution.v1.Schema schema = 1;
- getSchemaOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.OverWindowArrowType.Builder
-
.org.apache.flink.fn_execution.v1.Schema schema = 1;
- getSchemaOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.OverWindowArrowType
-
.org.apache.flink.fn_execution.v1.Schema schema = 1;
- getSchemaOrBuilder() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.OverWindowArrowTypeOrBuilder
-
.org.apache.flink.fn_execution.v1.Schema schema = 1;
- getSchemaOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RowType.Builder
-
.org.apache.flink.fn_execution.v1.Schema schema = 1;
- getSchemaOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RowType
-
.org.apache.flink.fn_execution.v1.Schema schema = 1;
- getSchemaOrBuilder() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RowTypeOrBuilder
-
.org.apache.flink.fn_execution.v1.Schema schema = 1;
- getSeparatedWithEndMessage() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.Builder
-
append an end message (0x00) after serializing the records belonging to the same batch.
- getSeparatedWithEndMessage() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor
-
append an end message (0x00) after serializing the records belonging to the same batch.
- getSeparatedWithEndMessage() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptorOrBuilder
-
append an end message (0x00) after serializing the records belonging to the same batch.
- getSerializedPythonFunction() - Method in class org.apache.flink.streaming.api.functions.python.DataStreamPythonFunction
- getSerializedSize() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.ArrowType
- getSerializedSize() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.FlattenRowType
- getSerializedSize() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor
- getSerializedSize() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.OverWindowArrowType
- getSerializedSize() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RawType
- getSerializedSize() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RowType
- getSerializedSize() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow
- getSerializedSize() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input
- getSerializedSize() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.JobParameter
- getSerializedSize() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow
- getSerializedSize() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.BinaryInfo
- getSerializedSize() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.CharInfo
- getSerializedSize() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.DecimalInfo
- getSerializedSize() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Field
- getSerializedSize() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
- getSerializedSize() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema
- getSerializedSize() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.LocalZonedTimestampInfo
- getSerializedSize() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.MapInfo
- getSerializedSize() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimeInfo
- getSerializedSize() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimestampInfo
- getSerializedSize() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarBinaryInfo
- getSerializedSize() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarCharInfo
- getSerializedSize() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.ZonedTimestampInfo
- getSerializedSize() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor
- getSerializedSize() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies
- getSerializedSize() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategy
- getSerializedSize() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry
- getSerializedSize() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.RocksdbCompactFilterCleanupStrategy
- getSerializedSize() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig
- getSerializedSize() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.AvroTypeInfo
- getSerializedSize() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo
- getSerializedSize() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.MapTypeInfo
- getSerializedSize() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Field
- getSerializedSize() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo
- getSerializedSize() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TupleTypeInfo
- getSerializedSize() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec
- getSerializedSize() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.ListView
- getSerializedSize() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapView
- getSerializedSize() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction
- getSerializedSize() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions
- getSerializedSize() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction
- getSerializedSize() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext
- getSerializedSize() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction
- getSerializedSize() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions
- getShiftTimezone() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.Builder
-
string shift_timezone = 10;
- getShiftTimezone() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow
-
string shift_timezone = 10;
- getShiftTimezone() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindowOrBuilder
-
string shift_timezone = 10;
- getShiftTimezoneBytes() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.Builder
-
string shift_timezone = 10;
- getShiftTimezoneBytes() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow
-
string shift_timezone = 10;
- getShiftTimezoneBytes() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindowOrBuilder
-
string shift_timezone = 10;
- getShort(int) - Method in class org.apache.flink.table.runtime.arrow.vectors.ArrowSmallIntColumnVector
- getSideOutputTags() - Method in interface org.apache.flink.streaming.api.operators.python.DataStreamPythonFunctionOperator
-
Gets the
OutputTag
s belongs to the operator. - getSideOutputTags() - Method in class org.apache.flink.streaming.api.operators.python.embedded.AbstractEmbeddedDataStreamPythonFunctionOperator
- getSideOutputTags() - Method in class org.apache.flink.streaming.api.operators.python.process.AbstractExternalDataStreamPythonFunctionOperator
- getSideOutputTags() - Method in class org.apache.flink.streaming.api.transformations.python.DelegateOperatorTransformation.DelegateOperator
- getSideOutputTypeSerializerById(String) - Method in class org.apache.flink.streaming.api.operators.python.process.AbstractExternalDataStreamPythonFunctionOperator
- getSpecs(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.Builder
-
repeated .org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction.DataViewSpec specs = 3;
- getSpecs(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction
-
repeated .org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction.DataViewSpec specs = 3;
- getSpecs(int) - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctionOrBuilder
-
repeated .org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction.DataViewSpec specs = 3;
- getSpecsBuilder(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.Builder
-
repeated .org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction.DataViewSpec specs = 3;
- getSpecsBuilderList() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.Builder
-
repeated .org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction.DataViewSpec specs = 3;
- getSpecsCount() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.Builder
-
repeated .org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction.DataViewSpec specs = 3;
- getSpecsCount() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction
-
repeated .org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction.DataViewSpec specs = 3;
- getSpecsCount() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctionOrBuilder
-
repeated .org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction.DataViewSpec specs = 3;
- getSpecsList() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.Builder
-
repeated .org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction.DataViewSpec specs = 3;
- getSpecsList() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction
-
repeated .org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction.DataViewSpec specs = 3;
- getSpecsList() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctionOrBuilder
-
repeated .org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction.DataViewSpec specs = 3;
- getSpecsOrBuilder(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.Builder
-
repeated .org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction.DataViewSpec specs = 3;
- getSpecsOrBuilder(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction
-
repeated .org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction.DataViewSpec specs = 3;
- getSpecsOrBuilder(int) - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctionOrBuilder
-
repeated .org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction.DataViewSpec specs = 3;
- getSpecsOrBuilderList() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.Builder
-
repeated .org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction.DataViewSpec specs = 3;
- getSpecsOrBuilderList() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction
-
repeated .org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction.DataViewSpec specs = 3;
- getSpecsOrBuilderList() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctionOrBuilder
-
repeated .org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction.DataViewSpec specs = 3;
- getStateCacheSize() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
-
The state cache size.
- getStateCacheSize() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions
-
The state cache size.
- getStateCacheSize() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctionsOrBuilder
-
The state cache size.
- getStateCacheSize() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.Builder
-
The state cache size.
- getStateCacheSize() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction
-
The state cache size.
- getStateCacheSize() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunctionOrBuilder
-
The state cache size.
- getStateCleaningEnabled() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
-
Cleanup the expired state if true.
- getStateCleaningEnabled() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions
-
Cleanup the expired state if true.
- getStateCleaningEnabled() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctionsOrBuilder
-
Cleanup the expired state if true.
- getStateKeyType() - Method in class org.apache.flink.streaming.api.transformations.python.PythonKeyedBroadcastStateTransformation
- getStateName() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.Builder
-
string state_name = 1;
- getStateName() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor
-
string state_name = 1;
- getStateName() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptorOrBuilder
-
string state_name = 1;
- getStateNameBytes() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.Builder
-
string state_name = 1;
- getStateNameBytes() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor
-
string state_name = 1;
- getStateNameBytes() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptorOrBuilder
-
string state_name = 1;
- getStateTtlConfig() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.Builder
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig state_ttl_config = 2;
- getStateTtlConfig() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig state_ttl_config = 2;
- getStateTtlConfig() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptorOrBuilder
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig state_ttl_config = 2;
- getStateTtlConfigBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.Builder
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig state_ttl_config = 2;
- getStateTtlConfigOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.Builder
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig state_ttl_config = 2;
- getStateTtlConfigOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig state_ttl_config = 2;
- getStateTtlConfigOrBuilder() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptorOrBuilder
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig state_ttl_config = 2;
- getStateVisibility() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.Builder
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.StateVisibility state_visibility = 2;
- getStateVisibility() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.StateVisibility state_visibility = 2;
- getStateVisibility() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfigOrBuilder
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.StateVisibility state_visibility = 2;
- getStateVisibilityValue() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.Builder
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.StateVisibility state_visibility = 2;
- getStateVisibilityValue() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.StateVisibility state_visibility = 2;
- getStateVisibilityValue() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfigOrBuilder
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.StateVisibility state_visibility = 2;
- getStrategies(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.Builder
-
repeated .org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry strategies = 2;
- getStrategies(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies
-
repeated .org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry strategies = 2;
- getStrategies(int) - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategiesOrBuilder
-
repeated .org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry strategies = 2;
- getStrategiesBuilder(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.Builder
-
repeated .org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry strategies = 2;
- getStrategiesBuilderList() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.Builder
-
repeated .org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry strategies = 2;
- getStrategiesCount() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.Builder
-
repeated .org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry strategies = 2;
- getStrategiesCount() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies
-
repeated .org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry strategies = 2;
- getStrategiesCount() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategiesOrBuilder
-
repeated .org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry strategies = 2;
- getStrategiesList() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.Builder
-
repeated .org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry strategies = 2;
- getStrategiesList() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies
-
repeated .org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry strategies = 2;
- getStrategiesList() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategiesOrBuilder
-
repeated .org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry strategies = 2;
- getStrategiesOrBuilder(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.Builder
-
repeated .org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry strategies = 2;
- getStrategiesOrBuilder(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies
-
repeated .org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry strategies = 2;
- getStrategiesOrBuilder(int) - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategiesOrBuilder
-
repeated .org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry strategies = 2;
- getStrategiesOrBuilderList() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.Builder
-
repeated .org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry strategies = 2;
- getStrategiesOrBuilderList() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies
-
repeated .org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry strategies = 2;
- getStrategiesOrBuilderList() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategiesOrBuilder
-
repeated .org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry strategies = 2;
- getStrategy() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry.Builder
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies.Strategies strategy = 1;
- getStrategy() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies.Strategies strategy = 1;
- getStrategy() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntryOrBuilder
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies.Strategies strategy = 1;
- getStrategyValue() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry.Builder
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies.Strategies strategy = 1;
- getStrategyValue() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies.Strategies strategy = 1;
- getStrategyValue() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntryOrBuilder
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies.Strategies strategy = 1;
- getTakesRowAsInput() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.Builder
-
Whether the UDF takes row as input instead of each columns of a row
- getTakesRowAsInput() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction
-
Whether the UDF takes row as input instead of each columns of a row
- getTakesRowAsInput() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctionOrBuilder
-
Whether the UDF takes row as input instead of each columns of a row
- getTakesRowAsInput() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction.Builder
-
Whether the UDF takes row as input instead of each columns of a row
- getTakesRowAsInput() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction
-
Whether the UDF takes row as input instead of each columns of a row
- getTakesRowAsInput() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctionOrBuilder
-
Whether the UDF takes row as input instead of each columns of a row
- getTaskName() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder
-
string task_name = 1;
- getTaskName() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext
-
string task_name = 1;
- getTaskName() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContextOrBuilder
-
string task_name = 1;
- getTaskNameBytes() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder
-
string task_name = 1;
- getTaskNameBytes() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext
-
string task_name = 1;
- getTaskNameBytes() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContextOrBuilder
-
string task_name = 1;
- getTaskNameWithSubtasks() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder
-
string task_name_with_subtasks = 2;
- getTaskNameWithSubtasks() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext
-
string task_name_with_subtasks = 2;
- getTaskNameWithSubtasks() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContextOrBuilder
-
string task_name_with_subtasks = 2;
- getTaskNameWithSubtasksBytes() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder
-
string task_name_with_subtasks = 2;
- getTaskNameWithSubtasksBytes() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext
-
string task_name_with_subtasks = 2;
- getTaskNameWithSubtasksBytes() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContextOrBuilder
-
string task_name_with_subtasks = 2;
- getTimeFieldIndex() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.Builder
-
int32 time_field_index = 7;
- getTimeFieldIndex() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow
-
int32 time_field_index = 7;
- getTimeFieldIndex() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindowOrBuilder
-
int32 time_field_index = 7;
- getTimeInfo() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.TimeInfo time_info = 7;
- getTimeInfo() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
-
.org.apache.flink.fn_execution.v1.Schema.TimeInfo time_info = 7;
- getTimeInfo() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldTypeOrBuilder
-
.org.apache.flink.fn_execution.v1.Schema.TimeInfo time_info = 7;
- getTimeInfoBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.TimeInfo time_info = 7;
- getTimeInfoOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.TimeInfo time_info = 7;
- getTimeInfoOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
-
.org.apache.flink.fn_execution.v1.Schema.TimeInfo time_info = 7;
- getTimeInfoOrBuilder() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldTypeOrBuilder
-
.org.apache.flink.fn_execution.v1.Schema.TimeInfo time_info = 7;
- getTimerContext() - Method in class org.apache.flink.streaming.api.operators.python.embedded.AbstractOneInputEmbeddedPythonFunctionOperator
-
Gets The Timer context.
- getTimerContext() - Method in class org.apache.flink.streaming.api.operators.python.embedded.AbstractTwoInputEmbeddedPythonFunctionOperator
-
Gets The Timer context.
- getTimerContext() - Method in class org.apache.flink.streaming.api.operators.python.embedded.EmbeddedPythonCoProcessOperator
- getTimerContext() - Method in class org.apache.flink.streaming.api.operators.python.embedded.EmbeddedPythonKeyedCoProcessOperator
- getTimerContext() - Method in class org.apache.flink.streaming.api.operators.python.embedded.EmbeddedPythonKeyedProcessOperator
- getTimerContext() - Method in class org.apache.flink.streaming.api.operators.python.embedded.EmbeddedPythonProcessOperator
- getTimerContext() - Method in class org.apache.flink.streaming.api.operators.python.embedded.EmbeddedPythonWindowOperator
- getTimers(RunnerApi.Components) - Method in class org.apache.flink.streaming.api.runners.python.beam.BeamDataStreamPythonFunctionRunner
- getTimers(RunnerApi.Components) - Method in class org.apache.flink.streaming.api.runners.python.beam.BeamPythonFunctionRunner
- getTimers(RunnerApi.Components) - Method in class org.apache.flink.table.runtime.runners.python.beam.BeamTablePythonFunctionRunner
- getTimestamp(int, int) - Method in class org.apache.flink.table.runtime.arrow.vectors.ArrowTimestampColumnVector
- getTimestampInfo() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.TimestampInfo timestamp_info = 8;
- getTimestampInfo() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
-
.org.apache.flink.fn_execution.v1.Schema.TimestampInfo timestamp_info = 8;
- getTimestampInfo() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldTypeOrBuilder
-
.org.apache.flink.fn_execution.v1.Schema.TimestampInfo timestamp_info = 8;
- getTimestampInfoBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.TimestampInfo timestamp_info = 8;
- getTimestampInfoOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.TimestampInfo timestamp_info = 8;
- getTimestampInfoOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
-
.org.apache.flink.fn_execution.v1.Schema.TimestampInfo timestamp_info = 8;
- getTimestampInfoOrBuilder() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldTypeOrBuilder
-
.org.apache.flink.fn_execution.v1.Schema.TimestampInfo timestamp_info = 8;
- getTotalFields() - Method in class org.apache.flink.streaming.api.typeinfo.python.PickledByteArrayTypeInfo
- getTtl() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.Builder
-
int64 ttl = 4;
- getTtl() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig
-
int64 ttl = 4;
- getTtl() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfigOrBuilder
-
int64 ttl = 4;
- getTtlTimeCharacteristic() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.Builder
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.TtlTimeCharacteristic ttl_time_characteristic = 3;
- getTtlTimeCharacteristic() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.TtlTimeCharacteristic ttl_time_characteristic = 3;
- getTtlTimeCharacteristic() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfigOrBuilder
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.TtlTimeCharacteristic ttl_time_characteristic = 3;
- getTtlTimeCharacteristicValue() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.Builder
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.TtlTimeCharacteristic ttl_time_characteristic = 3;
- getTtlTimeCharacteristicValue() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.TtlTimeCharacteristic ttl_time_characteristic = 3;
- getTtlTimeCharacteristicValue() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfigOrBuilder
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.TtlTimeCharacteristic ttl_time_characteristic = 3;
- getTupleTypeInfo() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.Builder
-
.org.apache.flink.fn_execution.v1.TypeInfo.TupleTypeInfo tuple_type_info = 4;
- getTupleTypeInfo() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo
-
.org.apache.flink.fn_execution.v1.TypeInfo.TupleTypeInfo tuple_type_info = 4;
- getTupleTypeInfo() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfoOrBuilder
-
.org.apache.flink.fn_execution.v1.TypeInfo.TupleTypeInfo tuple_type_info = 4;
- getTupleTypeInfoBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.Builder
-
.org.apache.flink.fn_execution.v1.TypeInfo.TupleTypeInfo tuple_type_info = 4;
- getTupleTypeInfoOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.Builder
-
.org.apache.flink.fn_execution.v1.TypeInfo.TupleTypeInfo tuple_type_info = 4;
- getTupleTypeInfoOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo
-
.org.apache.flink.fn_execution.v1.TypeInfo.TupleTypeInfo tuple_type_info = 4;
- getTupleTypeInfoOrBuilder() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfoOrBuilder
-
.org.apache.flink.fn_execution.v1.TypeInfo.TupleTypeInfo tuple_type_info = 4;
- getType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Field.Builder
-
.org.apache.flink.fn_execution.v1.Schema.FieldType type = 3;
- getType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Field
-
.org.apache.flink.fn_execution.v1.Schema.FieldType type = 3;
- getType() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldOrBuilder
-
.org.apache.flink.fn_execution.v1.Schema.FieldType type = 3;
- getTypeBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Field.Builder
-
.org.apache.flink.fn_execution.v1.Schema.FieldType type = 3;
- getTypeClass() - Method in class org.apache.flink.streaming.api.typeinfo.python.PickledByteArrayTypeInfo
- getTypeInfo() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RawType.Builder
-
.org.apache.flink.fn_execution.v1.TypeInfo type_info = 1;
- getTypeInfo() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RawType
-
.org.apache.flink.fn_execution.v1.TypeInfo type_info = 1;
- getTypeInfo() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RawTypeOrBuilder
-
.org.apache.flink.fn_execution.v1.TypeInfo type_info = 1;
- getTypeInfoBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RawType.Builder
-
.org.apache.flink.fn_execution.v1.TypeInfo type_info = 1;
- getTypeInfoCase() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
- getTypeInfoCase() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
- getTypeInfoCase() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldTypeOrBuilder
- getTypeInfoCase() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.Builder
- getTypeInfoCase() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo
- getTypeInfoCase() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfoOrBuilder
- getTypeInfoOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RawType.Builder
-
.org.apache.flink.fn_execution.v1.TypeInfo type_info = 1;
- getTypeInfoOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RawType
-
.org.apache.flink.fn_execution.v1.TypeInfo type_info = 1;
- getTypeInfoOrBuilder() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RawTypeOrBuilder
-
.org.apache.flink.fn_execution.v1.TypeInfo type_info = 1;
- getTypeName() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.TypeName type_name = 1;
- getTypeName() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
-
.org.apache.flink.fn_execution.v1.Schema.TypeName type_name = 1;
- getTypeName() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldTypeOrBuilder
-
.org.apache.flink.fn_execution.v1.Schema.TypeName type_name = 1;
- getTypeName() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.Builder
-
.org.apache.flink.fn_execution.v1.TypeInfo.TypeName type_name = 1;
- getTypeName() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo
-
.org.apache.flink.fn_execution.v1.TypeInfo.TypeName type_name = 1;
- getTypeName() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfoOrBuilder
-
.org.apache.flink.fn_execution.v1.TypeInfo.TypeName type_name = 1;
- getTypeNameValue() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.TypeName type_name = 1;
- getTypeNameValue() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
-
.org.apache.flink.fn_execution.v1.Schema.TypeName type_name = 1;
- getTypeNameValue() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldTypeOrBuilder
-
.org.apache.flink.fn_execution.v1.Schema.TypeName type_name = 1;
- getTypeNameValue() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.Builder
-
.org.apache.flink.fn_execution.v1.TypeInfo.TypeName type_name = 1;
- getTypeNameValue() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo
-
.org.apache.flink.fn_execution.v1.TypeInfo.TypeName type_name = 1;
- getTypeNameValue() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfoOrBuilder
-
.org.apache.flink.fn_execution.v1.TypeInfo.TypeName type_name = 1;
- getTypeOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Field.Builder
-
.org.apache.flink.fn_execution.v1.Schema.FieldType type = 3;
- getTypeOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Field
-
.org.apache.flink.fn_execution.v1.Schema.FieldType type = 3;
- getTypeOrBuilder() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldOrBuilder
-
.org.apache.flink.fn_execution.v1.Schema.FieldType type = 3;
- getUdf() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input.Builder
-
.org.apache.flink.fn_execution.v1.UserDefinedFunction udf = 1;
- getUdf() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input
-
.org.apache.flink.fn_execution.v1.UserDefinedFunction udf = 1;
- getUdf() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.InputOrBuilder
-
.org.apache.flink.fn_execution.v1.UserDefinedFunction udf = 1;
- getUdfBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input.Builder
-
.org.apache.flink.fn_execution.v1.UserDefinedFunction udf = 1;
- getUdfOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input.Builder
-
.org.apache.flink.fn_execution.v1.UserDefinedFunction udf = 1;
- getUdfOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input
-
.org.apache.flink.fn_execution.v1.UserDefinedFunction udf = 1;
- getUdfOrBuilder() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.InputOrBuilder
-
.org.apache.flink.fn_execution.v1.UserDefinedFunction udf = 1;
- getUdfs(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction udfs = 1;
- getUdfs(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions
-
repeated .org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction udfs = 1;
- getUdfs(int) - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctionsOrBuilder
-
repeated .org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction udfs = 1;
- getUdfs(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.UserDefinedFunction udfs = 1;
- getUdfs(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions
-
repeated .org.apache.flink.fn_execution.v1.UserDefinedFunction udfs = 1;
- getUdfs(int) - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctionsOrBuilder
-
repeated .org.apache.flink.fn_execution.v1.UserDefinedFunction udfs = 1;
- getUdfsBuilder(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction udfs = 1;
- getUdfsBuilder(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.UserDefinedFunction udfs = 1;
- getUdfsBuilderList() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction udfs = 1;
- getUdfsBuilderList() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.UserDefinedFunction udfs = 1;
- getUdfsCount() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction udfs = 1;
- getUdfsCount() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions
-
repeated .org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction udfs = 1;
- getUdfsCount() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctionsOrBuilder
-
repeated .org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction udfs = 1;
- getUdfsCount() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.UserDefinedFunction udfs = 1;
- getUdfsCount() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions
-
repeated .org.apache.flink.fn_execution.v1.UserDefinedFunction udfs = 1;
- getUdfsCount() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctionsOrBuilder
-
repeated .org.apache.flink.fn_execution.v1.UserDefinedFunction udfs = 1;
- getUdfsList() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction udfs = 1;
- getUdfsList() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions
-
repeated .org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction udfs = 1;
- getUdfsList() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctionsOrBuilder
-
repeated .org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction udfs = 1;
- getUdfsList() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.UserDefinedFunction udfs = 1;
- getUdfsList() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions
-
repeated .org.apache.flink.fn_execution.v1.UserDefinedFunction udfs = 1;
- getUdfsList() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctionsOrBuilder
-
repeated .org.apache.flink.fn_execution.v1.UserDefinedFunction udfs = 1;
- getUdfsOrBuilder(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction udfs = 1;
- getUdfsOrBuilder(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions
-
repeated .org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction udfs = 1;
- getUdfsOrBuilder(int) - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctionsOrBuilder
-
repeated .org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction udfs = 1;
- getUdfsOrBuilder(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.UserDefinedFunction udfs = 1;
- getUdfsOrBuilder(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions
-
repeated .org.apache.flink.fn_execution.v1.UserDefinedFunction udfs = 1;
- getUdfsOrBuilder(int) - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctionsOrBuilder
-
repeated .org.apache.flink.fn_execution.v1.UserDefinedFunction udfs = 1;
- getUdfsOrBuilderList() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction udfs = 1;
- getUdfsOrBuilderList() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions
-
repeated .org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction udfs = 1;
- getUdfsOrBuilderList() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctionsOrBuilder
-
repeated .org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction udfs = 1;
- getUdfsOrBuilderList() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.UserDefinedFunction udfs = 1;
- getUdfsOrBuilderList() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions
-
repeated .org.apache.flink.fn_execution.v1.UserDefinedFunction udfs = 1;
- getUdfsOrBuilderList() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctionsOrBuilder
-
repeated .org.apache.flink.fn_execution.v1.UserDefinedFunction udfs = 1;
- getUnknownFields() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.ArrowType
- getUnknownFields() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.FlattenRowType
- getUnknownFields() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor
- getUnknownFields() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.OverWindowArrowType
- getUnknownFields() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RawType
- getUnknownFields() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RowType
- getUnknownFields() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow
- getUnknownFields() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input
- getUnknownFields() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.JobParameter
- getUnknownFields() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow
- getUnknownFields() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.BinaryInfo
- getUnknownFields() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.CharInfo
- getUnknownFields() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.DecimalInfo
- getUnknownFields() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Field
- getUnknownFields() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
- getUnknownFields() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema
- getUnknownFields() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.LocalZonedTimestampInfo
- getUnknownFields() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.MapInfo
- getUnknownFields() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimeInfo
- getUnknownFields() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimestampInfo
- getUnknownFields() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarBinaryInfo
- getUnknownFields() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarCharInfo
- getUnknownFields() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.ZonedTimestampInfo
- getUnknownFields() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor
- getUnknownFields() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies
- getUnknownFields() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategy
- getUnknownFields() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry
- getUnknownFields() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.RocksdbCompactFilterCleanupStrategy
- getUnknownFields() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig
- getUnknownFields() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.AvroTypeInfo
- getUnknownFields() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo
- getUnknownFields() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.MapTypeInfo
- getUnknownFields() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Field
- getUnknownFields() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo
- getUnknownFields() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TupleTypeInfo
- getUnknownFields() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec
- getUnknownFields() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.ListView
- getUnknownFields() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapView
- getUnknownFields() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction
- getUnknownFields() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions
- getUnknownFields() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction
- getUnknownFields() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext
- getUnknownFields() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction
- getUnknownFields() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions
- getUpdateType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.Builder
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.UpdateType update_type = 1;
- getUpdateType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.UpdateType update_type = 1;
- getUpdateType() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfigOrBuilder
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.UpdateType update_type = 1;
- getUpdateTypeValue() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.Builder
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.UpdateType update_type = 1;
- getUpdateTypeValue() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.UpdateType update_type = 1;
- getUpdateTypeValue() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfigOrBuilder
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.UpdateType update_type = 1;
- getUpperBoundary() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow.Builder
-
int64 upper_boundary = 3;
- getUpperBoundary() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow
-
int64 upper_boundary = 3;
- getUpperBoundary() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindowOrBuilder
-
int64 upper_boundary = 3;
- getUserDefinedFunctionsProto() - Method in class org.apache.flink.table.runtime.operators.python.aggregate.AbstractPythonStreamAggregateOperator
-
Gets the proto representation of the Python user-defined aggregate functions to be executed.
- getUserDefinedFunctionsProto() - Method in class org.apache.flink.table.runtime.operators.python.aggregate.AbstractPythonStreamGroupAggregateOperator
- getUserDefinedFunctionsProto() - Method in class org.apache.flink.table.runtime.operators.python.aggregate.PythonStreamGroupAggregateOperator
-
Gets the proto representation of the Python user-defined aggregate functions to be executed.
- getUserDefinedFunctionsProto() - Method in class org.apache.flink.table.runtime.operators.python.aggregate.PythonStreamGroupTableAggregateOperator
-
Gets the proto representation of the Python user-defined table aggregate function to be executed.
- getUserDefinedFunctionsProto() - Method in class org.apache.flink.table.runtime.operators.python.aggregate.PythonStreamGroupWindowAggregateOperator
- getValue() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.JobParameter.Builder
-
string value = 2;
- getValue() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.JobParameter
-
string value = 2;
- getValue() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.JobParameterOrBuilder
-
string value = 2;
- getValue() - Method in class org.apache.flink.python.metric.embedded.MetricDistribution
- getValue() - Method in class org.apache.flink.python.metric.embedded.MetricGauge
- getValue() - Method in class org.apache.flink.python.metric.process.FlinkMetricContainer.FlinkDistributionGauge
- getValue() - Method in class org.apache.flink.python.metric.process.FlinkMetricContainer.FlinkGauge
- getValueBytes() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.JobParameter.Builder
-
string value = 2;
- getValueBytes() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.JobParameter
-
string value = 2;
- getValueBytes() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.JobParameterOrBuilder
-
string value = 2;
- getValueDescriptor() - Method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.Mode
- getValueDescriptor() - Method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.WindowProperty
- getValueDescriptor() - Method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.WindowType
- getValueDescriptor() - Method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow.WindowType
- getValueDescriptor() - Method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TypeName
- getValueDescriptor() - Method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.EmptyCleanupStrategy
- getValueDescriptor() - Method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.Strategies
- getValueDescriptor() - Method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.StateVisibility
- getValueDescriptor() - Method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.TtlTimeCharacteristic
- getValueDescriptor() - Method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.UpdateType
- getValueDescriptor() - Method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TypeName
- getValueDescriptor() - Method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.FunctionType
- getValueType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.MapInfo.Builder
-
.org.apache.flink.fn_execution.v1.Schema.FieldType value_type = 2;
- getValueType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.MapInfo
-
.org.apache.flink.fn_execution.v1.Schema.FieldType value_type = 2;
- getValueType() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.MapInfoOrBuilder
-
.org.apache.flink.fn_execution.v1.Schema.FieldType value_type = 2;
- getValueType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.MapTypeInfo.Builder
-
.org.apache.flink.fn_execution.v1.TypeInfo value_type = 2;
- getValueType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.MapTypeInfo
-
.org.apache.flink.fn_execution.v1.TypeInfo value_type = 2;
- getValueType() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.MapTypeInfoOrBuilder
-
.org.apache.flink.fn_execution.v1.TypeInfo value_type = 2;
- getValueType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapView.Builder
-
.org.apache.flink.fn_execution.v1.Schema.FieldType value_type = 2;
- getValueType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapView
-
.org.apache.flink.fn_execution.v1.Schema.FieldType value_type = 2;
- getValueType() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapViewOrBuilder
-
.org.apache.flink.fn_execution.v1.Schema.FieldType value_type = 2;
- getValueTypeBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.MapInfo.Builder
-
.org.apache.flink.fn_execution.v1.Schema.FieldType value_type = 2;
- getValueTypeBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.MapTypeInfo.Builder
-
.org.apache.flink.fn_execution.v1.TypeInfo value_type = 2;
- getValueTypeBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapView.Builder
-
.org.apache.flink.fn_execution.v1.Schema.FieldType value_type = 2;
- getValueTypeOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.MapInfo.Builder
-
.org.apache.flink.fn_execution.v1.Schema.FieldType value_type = 2;
- getValueTypeOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.MapInfo
-
.org.apache.flink.fn_execution.v1.Schema.FieldType value_type = 2;
- getValueTypeOrBuilder() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.MapInfoOrBuilder
-
.org.apache.flink.fn_execution.v1.Schema.FieldType value_type = 2;
- getValueTypeOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.MapTypeInfo.Builder
-
.org.apache.flink.fn_execution.v1.TypeInfo value_type = 2;
- getValueTypeOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.MapTypeInfo
-
.org.apache.flink.fn_execution.v1.TypeInfo value_type = 2;
- getValueTypeOrBuilder() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.MapTypeInfoOrBuilder
-
.org.apache.flink.fn_execution.v1.TypeInfo value_type = 2;
- getValueTypeOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapView.Builder
-
.org.apache.flink.fn_execution.v1.Schema.FieldType value_type = 2;
- getValueTypeOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapView
-
.org.apache.flink.fn_execution.v1.Schema.FieldType value_type = 2;
- getValueTypeOrBuilder() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapViewOrBuilder
-
.org.apache.flink.fn_execution.v1.Schema.FieldType value_type = 2;
- getValueVector() - Method in class org.apache.flink.table.runtime.arrow.writers.ArrowFieldWriter
-
Returns the underlying container which stores the sequence of values of a column.
- getVarBinaryInfo() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.VarBinaryInfo var_binary_info = 12;
- getVarBinaryInfo() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
-
.org.apache.flink.fn_execution.v1.Schema.VarBinaryInfo var_binary_info = 12;
- getVarBinaryInfo() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldTypeOrBuilder
-
.org.apache.flink.fn_execution.v1.Schema.VarBinaryInfo var_binary_info = 12;
- getVarBinaryInfoBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.VarBinaryInfo var_binary_info = 12;
- getVarBinaryInfoOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.VarBinaryInfo var_binary_info = 12;
- getVarBinaryInfoOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
-
.org.apache.flink.fn_execution.v1.Schema.VarBinaryInfo var_binary_info = 12;
- getVarBinaryInfoOrBuilder() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldTypeOrBuilder
-
.org.apache.flink.fn_execution.v1.Schema.VarBinaryInfo var_binary_info = 12;
- getVarCharInfo() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.VarCharInfo var_char_info = 14;
- getVarCharInfo() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
-
.org.apache.flink.fn_execution.v1.Schema.VarCharInfo var_char_info = 14;
- getVarCharInfo() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldTypeOrBuilder
-
.org.apache.flink.fn_execution.v1.Schema.VarCharInfo var_char_info = 14;
- getVarCharInfoBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.VarCharInfo var_char_info = 14;
- getVarCharInfoOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.VarCharInfo var_char_info = 14;
- getVarCharInfoOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
-
.org.apache.flink.fn_execution.v1.Schema.VarCharInfo var_char_info = 14;
- getVarCharInfoOrBuilder() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldTypeOrBuilder
-
.org.apache.flink.fn_execution.v1.Schema.VarCharInfo var_char_info = 14;
- getWindowGap() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.Builder
-
int64 window_gap = 5;
- getWindowGap() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow
-
int64 window_gap = 5;
- getWindowGap() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindowOrBuilder
-
int64 window_gap = 5;
- getWindowIndex() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction.Builder
-
The index of the over window used in pandas batch over window aggregation
- getWindowIndex() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction
-
The index of the over window used in pandas batch over window aggregation
- getWindowIndex() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctionOrBuilder
-
The index of the over window used in pandas batch over window aggregation
- getWindows(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.OverWindow windows = 3;
- getWindows(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions
-
repeated .org.apache.flink.fn_execution.v1.OverWindow windows = 3;
- getWindows(int) - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctionsOrBuilder
-
repeated .org.apache.flink.fn_execution.v1.OverWindow windows = 3;
- getWindowsBuilder(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.OverWindow windows = 3;
- getWindowsBuilderList() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.OverWindow windows = 3;
- getWindowsCount() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.OverWindow windows = 3;
- getWindowsCount() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions
-
repeated .org.apache.flink.fn_execution.v1.OverWindow windows = 3;
- getWindowsCount() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctionsOrBuilder
-
repeated .org.apache.flink.fn_execution.v1.OverWindow windows = 3;
- getWindowSerializer() - Method in class org.apache.flink.table.runtime.operators.python.aggregate.PythonStreamGroupWindowAggregateOperator
- getWindowSize() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.Builder
-
int64 window_size = 4;
- getWindowSize() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow
-
int64 window_size = 4;
- getWindowSize() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindowOrBuilder
-
int64 window_size = 4;
- getWindowSlide() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.Builder
-
int64 window_slide = 3;
- getWindowSlide() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow
-
int64 window_slide = 3;
- getWindowSlide() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindowOrBuilder
-
int64 window_slide = 3;
- getWindowsList() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.OverWindow windows = 3;
- getWindowsList() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions
-
repeated .org.apache.flink.fn_execution.v1.OverWindow windows = 3;
- getWindowsList() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctionsOrBuilder
-
repeated .org.apache.flink.fn_execution.v1.OverWindow windows = 3;
- getWindowsOrBuilder(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.OverWindow windows = 3;
- getWindowsOrBuilder(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions
-
repeated .org.apache.flink.fn_execution.v1.OverWindow windows = 3;
- getWindowsOrBuilder(int) - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctionsOrBuilder
-
repeated .org.apache.flink.fn_execution.v1.OverWindow windows = 3;
- getWindowsOrBuilderList() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.OverWindow windows = 3;
- getWindowsOrBuilderList() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions
-
repeated .org.apache.flink.fn_execution.v1.OverWindow windows = 3;
- getWindowsOrBuilderList() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctionsOrBuilder
-
repeated .org.apache.flink.fn_execution.v1.OverWindow windows = 3;
- getWindowType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.Builder
-
.org.apache.flink.fn_execution.v1.GroupWindow.WindowType window_type = 1;
- getWindowType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow
-
.org.apache.flink.fn_execution.v1.GroupWindow.WindowType window_type = 1;
- getWindowType() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindowOrBuilder
-
.org.apache.flink.fn_execution.v1.GroupWindow.WindowType window_type = 1;
- getWindowType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow.Builder
-
.org.apache.flink.fn_execution.v1.OverWindow.WindowType window_type = 1;
- getWindowType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow
-
.org.apache.flink.fn_execution.v1.OverWindow.WindowType window_type = 1;
- getWindowType() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindowOrBuilder
-
.org.apache.flink.fn_execution.v1.OverWindow.WindowType window_type = 1;
- getWindowTypeValue() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.Builder
-
.org.apache.flink.fn_execution.v1.GroupWindow.WindowType window_type = 1;
- getWindowTypeValue() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow
-
.org.apache.flink.fn_execution.v1.GroupWindow.WindowType window_type = 1;
- getWindowTypeValue() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindowOrBuilder
-
.org.apache.flink.fn_execution.v1.GroupWindow.WindowType window_type = 1;
- getWindowTypeValue() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow.Builder
-
.org.apache.flink.fn_execution.v1.OverWindow.WindowType window_type = 1;
- getWindowTypeValue() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow
-
.org.apache.flink.fn_execution.v1.OverWindow.WindowType window_type = 1;
- getWindowTypeValue() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindowOrBuilder
-
.org.apache.flink.fn_execution.v1.OverWindow.WindowType window_type = 1;
- getZonedTimestampInfo() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.ZonedTimestampInfo zoned_timestamp_info = 10;
- getZonedTimestampInfo() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
-
.org.apache.flink.fn_execution.v1.Schema.ZonedTimestampInfo zoned_timestamp_info = 10;
- getZonedTimestampInfo() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldTypeOrBuilder
-
.org.apache.flink.fn_execution.v1.Schema.ZonedTimestampInfo zoned_timestamp_info = 10;
- getZonedTimestampInfoBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.ZonedTimestampInfo zoned_timestamp_info = 10;
- getZonedTimestampInfoOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.ZonedTimestampInfo zoned_timestamp_info = 10;
- getZonedTimestampInfoOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
-
.org.apache.flink.fn_execution.v1.Schema.ZonedTimestampInfo zoned_timestamp_info = 10;
- getZonedTimestampInfoOrBuilder() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldTypeOrBuilder
-
.org.apache.flink.fn_execution.v1.Schema.ZonedTimestampInfo zoned_timestamp_info = 10;
- GROUP_WINDOW_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions
- GROUPING_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions
- GrpcStateService - Class in org.apache.beam.runners.fnexecution.state
-
An implementation of the Beam Fn State service.
H
- handle(BeamFnApi.StateRequest) - Method in class org.apache.flink.streaming.api.runners.python.beam.state.BeamStateRequestHandler
- handle(BeamFnApi.StateRequest, S) - Method in class org.apache.flink.streaming.api.runners.python.beam.state.AbstractBeamStateHandler
- handle(BeamFnApi.StateRequest, S) - Method in interface org.apache.flink.streaming.api.runners.python.beam.state.BeamStateHandler
-
Dispatches
BeamFnApi.StateRequest
to different handle functions base on request case. - handleAppend(BeamFnApi.StateRequest, ListState<byte[]>) - Method in class org.apache.flink.streaming.api.runners.python.beam.state.BeamBagStateHandler
- handleAppend(BeamFnApi.StateRequest, MapState<ByteArrayWrapper, byte[]>) - Method in class org.apache.flink.streaming.api.runners.python.beam.state.BeamMapStateHandler
- handleAppend(BeamFnApi.StateRequest, S) - Method in interface org.apache.flink.streaming.api.runners.python.beam.state.BeamStateHandler
-
Handles APPEND requests.
- handleClear(BeamFnApi.StateRequest, ListState<byte[]>) - Method in class org.apache.flink.streaming.api.runners.python.beam.state.BeamBagStateHandler
- handleClear(BeamFnApi.StateRequest, MapState<ByteArrayWrapper, byte[]>) - Method in class org.apache.flink.streaming.api.runners.python.beam.state.BeamMapStateHandler
- handleClear(BeamFnApi.StateRequest, S) - Method in interface org.apache.flink.streaming.api.runners.python.beam.state.BeamStateHandler
-
Handles CLEAR requests.
- handleGet(BeamFnApi.StateRequest, ListState<byte[]>) - Method in class org.apache.flink.streaming.api.runners.python.beam.state.BeamBagStateHandler
- handleGet(BeamFnApi.StateRequest, MapState<ByteArrayWrapper, byte[]>) - Method in class org.apache.flink.streaming.api.runners.python.beam.state.BeamMapStateHandler
- handleGet(BeamFnApi.StateRequest, S) - Method in interface org.apache.flink.streaming.api.runners.python.beam.state.BeamStateHandler
-
Handles GET requests.
- HAS_SIDE_OUTPUT_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction
- hasArrowType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.Builder
-
.org.apache.flink.fn_execution.v1.CoderInfoDescriptor.ArrowType arrow_type = 3;
- hasArrowType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor
-
.org.apache.flink.fn_execution.v1.CoderInfoDescriptor.ArrowType arrow_type = 3;
- hasArrowType() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptorOrBuilder
-
.org.apache.flink.fn_execution.v1.CoderInfoDescriptor.ArrowType arrow_type = 3;
- hasAvroTypeInfo() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.Builder
-
.org.apache.flink.fn_execution.v1.TypeInfo.AvroTypeInfo avro_type_info = 6;
- hasAvroTypeInfo() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo
-
.org.apache.flink.fn_execution.v1.TypeInfo.AvroTypeInfo avro_type_info = 6;
- hasAvroTypeInfo() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfoOrBuilder
-
.org.apache.flink.fn_execution.v1.TypeInfo.AvroTypeInfo avro_type_info = 6;
- hasBinaryInfo() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.BinaryInfo binary_info = 11;
- hasBinaryInfo() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
-
.org.apache.flink.fn_execution.v1.Schema.BinaryInfo binary_info = 11;
- hasBinaryInfo() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldTypeOrBuilder
-
.org.apache.flink.fn_execution.v1.Schema.BinaryInfo binary_info = 11;
- hasCharInfo() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.CharInfo char_info = 13;
- hasCharInfo() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
-
.org.apache.flink.fn_execution.v1.Schema.CharInfo char_info = 13;
- hasCharInfo() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldTypeOrBuilder
-
.org.apache.flink.fn_execution.v1.Schema.CharInfo char_info = 13;
- hasCleanupStrategies() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.Builder
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies cleanup_strategies = 5;
- hasCleanupStrategies() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies cleanup_strategies = 5;
- hasCleanupStrategies() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfigOrBuilder
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies cleanup_strategies = 5;
- hasCollectionElementType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.FieldType collection_element_type = 3;
- hasCollectionElementType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
-
.org.apache.flink.fn_execution.v1.Schema.FieldType collection_element_type = 3;
- hasCollectionElementType() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldTypeOrBuilder
-
.org.apache.flink.fn_execution.v1.Schema.FieldType collection_element_type = 3;
- hasCollectionElementType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.Builder
-
.org.apache.flink.fn_execution.v1.TypeInfo collection_element_type = 2;
- hasCollectionElementType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo
-
.org.apache.flink.fn_execution.v1.TypeInfo collection_element_type = 2;
- hasCollectionElementType() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfoOrBuilder
-
.org.apache.flink.fn_execution.v1.TypeInfo collection_element_type = 2;
- hasDecimalInfo() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.DecimalInfo decimal_info = 6;
- hasDecimalInfo() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
-
.org.apache.flink.fn_execution.v1.Schema.DecimalInfo decimal_info = 6;
- hasDecimalInfo() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldTypeOrBuilder
-
.org.apache.flink.fn_execution.v1.Schema.DecimalInfo decimal_info = 6;
- hasElementType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.ListView.Builder
-
.org.apache.flink.fn_execution.v1.Schema.FieldType element_type = 1;
- hasElementType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.ListView
-
.org.apache.flink.fn_execution.v1.Schema.FieldType element_type = 1;
- hasElementType() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.ListViewOrBuilder
-
.org.apache.flink.fn_execution.v1.Schema.FieldType element_type = 1;
- hasEmptyStrategy() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry.Builder
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies.EmptyCleanupStrategy empty_strategy = 2;
- hasEmptyStrategy() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies.EmptyCleanupStrategy empty_strategy = 2;
- hasEmptyStrategy() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntryOrBuilder
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies.EmptyCleanupStrategy empty_strategy = 2;
- hasFieldType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Field.Builder
-
.org.apache.flink.fn_execution.v1.TypeInfo field_type = 2;
- hasFieldType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Field
-
.org.apache.flink.fn_execution.v1.TypeInfo field_type = 2;
- hasFieldType() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.FieldOrBuilder
-
.org.apache.flink.fn_execution.v1.TypeInfo field_type = 2;
- hasFlattenRowType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.Builder
-
for Table & SQL
- hasFlattenRowType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor
-
for Table & SQL
- hasFlattenRowType() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptorOrBuilder
-
for Table & SQL
- hasGroupWindow() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
-
Group Window.
- hasGroupWindow() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions
-
Group Window.
- hasGroupWindow() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctionsOrBuilder
-
Group Window.
- hashCode() - Method in class org.apache.flink.client.python.PythonFunctionFactory.CacheKey
- hashCode() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.ArrowType
- hashCode() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.FlattenRowType
- hashCode() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor
- hashCode() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.OverWindowArrowType
- hashCode() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RawType
- hashCode() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RowType
- hashCode() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow
- hashCode() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input
- hashCode() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.JobParameter
- hashCode() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow
- hashCode() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.BinaryInfo
- hashCode() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.CharInfo
- hashCode() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.DecimalInfo
- hashCode() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Field
- hashCode() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
- hashCode() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema
- hashCode() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.LocalZonedTimestampInfo
- hashCode() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.MapInfo
- hashCode() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimeInfo
- hashCode() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimestampInfo
- hashCode() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarBinaryInfo
- hashCode() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarCharInfo
- hashCode() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.ZonedTimestampInfo
- hashCode() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor
- hashCode() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies
- hashCode() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategy
- hashCode() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry
- hashCode() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.RocksdbCompactFilterCleanupStrategy
- hashCode() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig
- hashCode() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.AvroTypeInfo
- hashCode() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo
- hashCode() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.MapTypeInfo
- hashCode() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Field
- hashCode() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo
- hashCode() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TupleTypeInfo
- hashCode() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec
- hashCode() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.ListView
- hashCode() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapView
- hashCode() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction
- hashCode() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions
- hashCode() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction
- hashCode() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext
- hashCode() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction
- hashCode() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions
- hashCode() - Method in class org.apache.flink.formats.avro.AvroRowDeserializationSchema
- hashCode() - Method in class org.apache.flink.formats.avro.AvroRowSerializationSchema
- hashCode() - Method in class org.apache.flink.formats.csv.CsvRowDeserializationSchema
- hashCode() - Method in class org.apache.flink.formats.csv.CsvRowSerializationSchema
- hashCode() - Method in class org.apache.flink.formats.json.JsonRowDeserializationSchema
- hashCode() - Method in class org.apache.flink.formats.json.JsonRowSerializationSchema
- hashCode() - Method in class org.apache.flink.streaming.api.typeinfo.python.PickledByteArrayTypeInfo
- hashCode() - Method in class org.apache.flink.streaming.api.utils.ByteArrayWrapper
- hashCode() - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.DecimalDataSerializer
- HashMapWrapper - Class in org.apache.flink.python.util
-
Helper class to create a
HashMap
taking Numeric data as key or value from Python side. - HashMapWrapper(Class<?>, Class<?>) - Constructor for class org.apache.flink.python.util.HashMapWrapper
- hasIncrementalCleanupStrategy() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry.Builder
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategy incremental_cleanup_strategy = 3;
- hasIncrementalCleanupStrategy() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategy incremental_cleanup_strategy = 3;
- hasIncrementalCleanupStrategy() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntryOrBuilder
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategy incremental_cleanup_strategy = 3;
- hasInputConstant() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input.Builder
-
bytes inputConstant = 3;
- hasInputConstant() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input
-
bytes inputConstant = 3;
- hasInputConstant() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.InputOrBuilder
-
bytes inputConstant = 3;
- hasInputOffset() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input.Builder
-
int32 inputOffset = 2;
- hasInputOffset() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input
-
int32 inputOffset = 2;
- hasInputOffset() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.InputOrBuilder
-
int32 inputOffset = 2;
- hasKeyType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.MapInfo.Builder
-
.org.apache.flink.fn_execution.v1.Schema.FieldType key_type = 1;
- hasKeyType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.MapInfo
-
.org.apache.flink.fn_execution.v1.Schema.FieldType key_type = 1;
- hasKeyType() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.MapInfoOrBuilder
-
.org.apache.flink.fn_execution.v1.Schema.FieldType key_type = 1;
- hasKeyType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.MapTypeInfo.Builder
-
.org.apache.flink.fn_execution.v1.TypeInfo key_type = 1;
- hasKeyType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.MapTypeInfo
-
.org.apache.flink.fn_execution.v1.TypeInfo key_type = 1;
- hasKeyType() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.MapTypeInfoOrBuilder
-
.org.apache.flink.fn_execution.v1.TypeInfo key_type = 1;
- hasKeyType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapView.Builder
-
.org.apache.flink.fn_execution.v1.Schema.FieldType key_type = 1;
- hasKeyType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapView
-
.org.apache.flink.fn_execution.v1.Schema.FieldType key_type = 1;
- hasKeyType() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapViewOrBuilder
-
.org.apache.flink.fn_execution.v1.Schema.FieldType key_type = 1;
- hasKeyType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
-
The schema of the grouping keys.
- hasKeyType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions
-
The schema of the grouping keys.
- hasKeyType() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctionsOrBuilder
-
The schema of the grouping keys.
- hasKeyTypeInfo() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.Builder
-
.org.apache.flink.fn_execution.v1.TypeInfo key_type_info = 5;
- hasKeyTypeInfo() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction
-
.org.apache.flink.fn_execution.v1.TypeInfo key_type_info = 5;
- hasKeyTypeInfo() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunctionOrBuilder
-
.org.apache.flink.fn_execution.v1.TypeInfo key_type_info = 5;
- hasListView() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.Builder
-
.org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction.DataViewSpec.ListView list_view = 3;
- hasListView() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec
-
.org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction.DataViewSpec.ListView list_view = 3;
- hasListView() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpecOrBuilder
-
.org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction.DataViewSpec.ListView list_view = 3;
- hasLocalZonedTimestampInfo() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.LocalZonedTimestampInfo local_zoned_timestamp_info = 9;
- hasLocalZonedTimestampInfo() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
-
.org.apache.flink.fn_execution.v1.Schema.LocalZonedTimestampInfo local_zoned_timestamp_info = 9;
- hasLocalZonedTimestampInfo() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldTypeOrBuilder
-
.org.apache.flink.fn_execution.v1.Schema.LocalZonedTimestampInfo local_zoned_timestamp_info = 9;
- hasMapInfo() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.MapInfo map_info = 4;
- hasMapInfo() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
-
.org.apache.flink.fn_execution.v1.Schema.MapInfo map_info = 4;
- hasMapInfo() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldTypeOrBuilder
-
.org.apache.flink.fn_execution.v1.Schema.MapInfo map_info = 4;
- hasMapTypeInfo() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.Builder
-
.org.apache.flink.fn_execution.v1.TypeInfo.MapTypeInfo map_type_info = 5;
- hasMapTypeInfo() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo
-
.org.apache.flink.fn_execution.v1.TypeInfo.MapTypeInfo map_type_info = 5;
- hasMapTypeInfo() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfoOrBuilder
-
.org.apache.flink.fn_execution.v1.TypeInfo.MapTypeInfo map_type_info = 5;
- hasMapView() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.Builder
-
.org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction.DataViewSpec.MapView map_view = 4;
- hasMapView() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec
-
.org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction.DataViewSpec.MapView map_view = 4;
- hasMapView() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpecOrBuilder
-
.org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction.DataViewSpec.MapView map_view = 4;
- hasOverWindowArrowType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.Builder
-
.org.apache.flink.fn_execution.v1.CoderInfoDescriptor.OverWindowArrowType over_window_arrow_type = 4;
- hasOverWindowArrowType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor
-
.org.apache.flink.fn_execution.v1.CoderInfoDescriptor.OverWindowArrowType over_window_arrow_type = 4;
- hasOverWindowArrowType() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptorOrBuilder
-
.org.apache.flink.fn_execution.v1.CoderInfoDescriptor.OverWindowArrowType over_window_arrow_type = 4;
- hasRawType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.Builder
-
for DataStream
- hasRawType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor
-
for DataStream
- hasRawType() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptorOrBuilder
-
for DataStream
- hasRocksdbCompactFilterCleanupStrategy() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry.Builder
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies.RocksdbCompactFilterCleanupStrategy rocksdb_compact_filter_cleanup_strategy = 4;
- hasRocksdbCompactFilterCleanupStrategy() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies.RocksdbCompactFilterCleanupStrategy rocksdb_compact_filter_cleanup_strategy = 4;
- hasRocksdbCompactFilterCleanupStrategy() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntryOrBuilder
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies.RocksdbCompactFilterCleanupStrategy rocksdb_compact_filter_cleanup_strategy = 4;
- hasRowSchema() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema row_schema = 5;
- hasRowSchema() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
-
.org.apache.flink.fn_execution.v1.Schema row_schema = 5;
- hasRowSchema() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldTypeOrBuilder
-
.org.apache.flink.fn_execution.v1.Schema row_schema = 5;
- hasRowType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.Builder
-
.org.apache.flink.fn_execution.v1.CoderInfoDescriptor.RowType row_type = 2;
- hasRowType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor
-
.org.apache.flink.fn_execution.v1.CoderInfoDescriptor.RowType row_type = 2;
- hasRowType() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptorOrBuilder
-
.org.apache.flink.fn_execution.v1.CoderInfoDescriptor.RowType row_type = 2;
- hasRowTypeInfo() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.Builder
-
.org.apache.flink.fn_execution.v1.TypeInfo.RowTypeInfo row_type_info = 3;
- hasRowTypeInfo() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo
-
.org.apache.flink.fn_execution.v1.TypeInfo.RowTypeInfo row_type_info = 3;
- hasRowTypeInfo() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfoOrBuilder
-
.org.apache.flink.fn_execution.v1.TypeInfo.RowTypeInfo row_type_info = 3;
- hasRuntimeContext() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.Builder
-
.org.apache.flink.fn_execution.v1.UserDefinedDataStreamFunction.RuntimeContext runtime_context = 2;
- hasRuntimeContext() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction
-
.org.apache.flink.fn_execution.v1.UserDefinedDataStreamFunction.RuntimeContext runtime_context = 2;
- hasRuntimeContext() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunctionOrBuilder
-
.org.apache.flink.fn_execution.v1.UserDefinedDataStreamFunction.RuntimeContext runtime_context = 2;
- hasSchema() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.ArrowType.Builder
-
.org.apache.flink.fn_execution.v1.Schema schema = 1;
- hasSchema() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.ArrowType
-
.org.apache.flink.fn_execution.v1.Schema schema = 1;
- hasSchema() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.ArrowTypeOrBuilder
-
.org.apache.flink.fn_execution.v1.Schema schema = 1;
- hasSchema() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.FlattenRowType.Builder
-
.org.apache.flink.fn_execution.v1.Schema schema = 1;
- hasSchema() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.FlattenRowType
-
.org.apache.flink.fn_execution.v1.Schema schema = 1;
- hasSchema() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.FlattenRowTypeOrBuilder
-
.org.apache.flink.fn_execution.v1.Schema schema = 1;
- hasSchema() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.OverWindowArrowType.Builder
-
.org.apache.flink.fn_execution.v1.Schema schema = 1;
- hasSchema() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.OverWindowArrowType
-
.org.apache.flink.fn_execution.v1.Schema schema = 1;
- hasSchema() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.OverWindowArrowTypeOrBuilder
-
.org.apache.flink.fn_execution.v1.Schema schema = 1;
- hasSchema() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RowType.Builder
-
.org.apache.flink.fn_execution.v1.Schema schema = 1;
- hasSchema() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RowType
-
.org.apache.flink.fn_execution.v1.Schema schema = 1;
- hasSchema() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RowTypeOrBuilder
-
.org.apache.flink.fn_execution.v1.Schema schema = 1;
- hasSideOutput - Variable in class org.apache.flink.streaming.api.operators.python.embedded.AbstractEmbeddedDataStreamPythonFunctionOperator
- hasStateTtlConfig() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.Builder
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig state_ttl_config = 2;
- hasStateTtlConfig() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig state_ttl_config = 2;
- hasStateTtlConfig() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptorOrBuilder
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig state_ttl_config = 2;
- hasTimeInfo() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.TimeInfo time_info = 7;
- hasTimeInfo() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
-
.org.apache.flink.fn_execution.v1.Schema.TimeInfo time_info = 7;
- hasTimeInfo() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldTypeOrBuilder
-
.org.apache.flink.fn_execution.v1.Schema.TimeInfo time_info = 7;
- hasTimestampInfo() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.TimestampInfo timestamp_info = 8;
- hasTimestampInfo() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
-
.org.apache.flink.fn_execution.v1.Schema.TimestampInfo timestamp_info = 8;
- hasTimestampInfo() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldTypeOrBuilder
-
.org.apache.flink.fn_execution.v1.Schema.TimestampInfo timestamp_info = 8;
- hasTupleTypeInfo() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.Builder
-
.org.apache.flink.fn_execution.v1.TypeInfo.TupleTypeInfo tuple_type_info = 4;
- hasTupleTypeInfo() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo
-
.org.apache.flink.fn_execution.v1.TypeInfo.TupleTypeInfo tuple_type_info = 4;
- hasTupleTypeInfo() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfoOrBuilder
-
.org.apache.flink.fn_execution.v1.TypeInfo.TupleTypeInfo tuple_type_info = 4;
- hasType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Field.Builder
-
.org.apache.flink.fn_execution.v1.Schema.FieldType type = 3;
- hasType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Field
-
.org.apache.flink.fn_execution.v1.Schema.FieldType type = 3;
- hasType() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldOrBuilder
-
.org.apache.flink.fn_execution.v1.Schema.FieldType type = 3;
- hasTypeInfo() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RawType.Builder
-
.org.apache.flink.fn_execution.v1.TypeInfo type_info = 1;
- hasTypeInfo() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RawType
-
.org.apache.flink.fn_execution.v1.TypeInfo type_info = 1;
- hasTypeInfo() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RawTypeOrBuilder
-
.org.apache.flink.fn_execution.v1.TypeInfo type_info = 1;
- hasUdf() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input.Builder
-
.org.apache.flink.fn_execution.v1.UserDefinedFunction udf = 1;
- hasUdf() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input
-
.org.apache.flink.fn_execution.v1.UserDefinedFunction udf = 1;
- hasUdf() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.InputOrBuilder
-
.org.apache.flink.fn_execution.v1.UserDefinedFunction udf = 1;
- hasValueType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.MapInfo.Builder
-
.org.apache.flink.fn_execution.v1.Schema.FieldType value_type = 2;
- hasValueType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.MapInfo
-
.org.apache.flink.fn_execution.v1.Schema.FieldType value_type = 2;
- hasValueType() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.MapInfoOrBuilder
-
.org.apache.flink.fn_execution.v1.Schema.FieldType value_type = 2;
- hasValueType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.MapTypeInfo.Builder
-
.org.apache.flink.fn_execution.v1.TypeInfo value_type = 2;
- hasValueType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.MapTypeInfo
-
.org.apache.flink.fn_execution.v1.TypeInfo value_type = 2;
- hasValueType() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.MapTypeInfoOrBuilder
-
.org.apache.flink.fn_execution.v1.TypeInfo value_type = 2;
- hasValueType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapView.Builder
-
.org.apache.flink.fn_execution.v1.Schema.FieldType value_type = 2;
- hasValueType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapView
-
.org.apache.flink.fn_execution.v1.Schema.FieldType value_type = 2;
- hasValueType() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapViewOrBuilder
-
.org.apache.flink.fn_execution.v1.Schema.FieldType value_type = 2;
- hasVarBinaryInfo() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.VarBinaryInfo var_binary_info = 12;
- hasVarBinaryInfo() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
-
.org.apache.flink.fn_execution.v1.Schema.VarBinaryInfo var_binary_info = 12;
- hasVarBinaryInfo() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldTypeOrBuilder
-
.org.apache.flink.fn_execution.v1.Schema.VarBinaryInfo var_binary_info = 12;
- hasVarCharInfo() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.VarCharInfo var_char_info = 14;
- hasVarCharInfo() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
-
.org.apache.flink.fn_execution.v1.Schema.VarCharInfo var_char_info = 14;
- hasVarCharInfo() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldTypeOrBuilder
-
.org.apache.flink.fn_execution.v1.Schema.VarCharInfo var_char_info = 14;
- hasZonedTimestampInfo() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.ZonedTimestampInfo zoned_timestamp_info = 10;
- hasZonedTimestampInfo() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
-
.org.apache.flink.fn_execution.v1.Schema.ZonedTimestampInfo zoned_timestamp_info = 10;
- hasZonedTimestampInfo() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldTypeOrBuilder
-
.org.apache.flink.fn_execution.v1.Schema.ZonedTimestampInfo zoned_timestamp_info = 10;
I
- IDENTIFIER - Static variable in class org.apache.flink.table.runtime.arrow.sources.ArrowTableSourceFactory
- IDENTIFIER - Static variable in class org.apache.flink.table.utils.python.PythonDynamicTableFactory
- IdentityDataConverter() - Constructor for class org.apache.flink.streaming.api.utils.PythonTypeUtils.IdentityDataConverter
- IdPartitioner - Class in org.apache.flink.python.legacy
-
Partitioner that partitions by id.
- IdPartitioner() - Constructor for class org.apache.flink.python.legacy.IdPartitioner
- ignoreParseErrors() - Method in class org.apache.flink.formats.json.JsonRowDeserializationSchema.Builder
-
Configures schema to fail when parsing json failed.
- IN_BATCH_EXECUTION_MODE_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext
- inBatchExecutionMode(KeyedStateBackend<K>) - Static method in class org.apache.flink.streaming.api.utils.PythonOperatorUtils
- INCREMENTAL_CLEANUP - org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.Strategies
-
INCREMENTAL_CLEANUP = 1;
- INCREMENTAL_CLEANUP_STRATEGY - org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry.CleanupStrategyCase
- INCREMENTAL_CLEANUP_STRATEGY_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry
- INCREMENTAL_CLEANUP_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.Strategies
-
INCREMENTAL_CLEANUP = 1;
- INDEX_OF_COUNT_STAR_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions
- INDEX_OF_THIS_SUBTASK_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext
- initializeState(FunctionInitializationContext) - Method in class org.apache.flink.table.runtime.arrow.sources.ArrowSourceFunction
-
Deprecated.
- INPUT_COLLECTION_ID - Static variable in class org.apache.flink.python.Constants
- INPUT_FILE_PATH - Static variable in class org.apache.flink.table.utils.python.PythonDynamicTableOptions
- INPUT_NOT_SET - org.apache.flink.fnexecution.v1.FlinkFnApi.Input.InputCase
- inputCoderDescriptor - Variable in class org.apache.flink.streaming.api.runners.python.beam.BeamPythonFunctionRunner
- INPUTCONSTANT - org.apache.flink.fnexecution.v1.FlinkFnApi.Input.InputCase
- INPUTCONSTANT_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input
- INPUTOFFSET - org.apache.flink.fnexecution.v1.FlinkFnApi.Input.InputCase
- INPUTOFFSET_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input
- INPUTS_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction
- INPUTS_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction
- inputTimeFieldIndex - Variable in class org.apache.flink.table.runtime.operators.python.aggregate.arrow.stream.AbstractStreamArrowPythonOverWindowAggregateFunctionOperator
-
The row time index of the input data.
- inputType - Variable in class org.apache.flink.table.runtime.arrow.serializers.ArrowSerializer
-
The input RowType.
- inputType - Variable in class org.apache.flink.table.runtime.operators.python.AbstractEmbeddedStatelessFunctionOperator
-
The input logical type.
- inputType - Variable in class org.apache.flink.table.runtime.operators.python.AbstractStatelessFunctionOperator
-
The input logical type.
- inputType - Variable in class org.apache.flink.table.runtime.operators.python.aggregate.AbstractPythonStreamAggregateOperator
-
The input logical type.
- INSTANCE - Static variable in class org.apache.flink.streaming.api.utils.ByteArrayWrapperSerializer
- INSTANCE - Static variable in class org.apache.flink.streaming.api.utils.PythonTypeUtils.ByteDataConverter
- INSTANCE - Static variable in class org.apache.flink.streaming.api.utils.PythonTypeUtils.FloatDataConverter
- INSTANCE - Static variable in class org.apache.flink.streaming.api.utils.PythonTypeUtils.IdentityDataConverter
- INSTANCE - Static variable in class org.apache.flink.streaming.api.utils.PythonTypeUtils.IntDataConverter
- INSTANCE - Static variable in class org.apache.flink.streaming.api.utils.PythonTypeUtils.ShortDataConverter
- INSTANCE - Static variable in class org.apache.flink.table.runtime.arrow.vectors.ArrowNullColumnVector
- INSTANCE - Static variable in class org.apache.flink.table.runtime.typeutils.PythonTypeUtils.ByteDataConverter
- INSTANCE - Static variable in class org.apache.flink.table.runtime.typeutils.PythonTypeUtils.FloatDataConverter
- INSTANCE - Static variable in class org.apache.flink.table.runtime.typeutils.PythonTypeUtils.IntDataConverter
- INSTANCE - Static variable in class org.apache.flink.table.runtime.typeutils.PythonTypeUtils.ShortDataConverter
- INSTANCE - Static variable in class org.apache.flink.table.runtime.typeutils.PythonTypeUtils.TimeDataConverter
- INSTANCE - Static variable in class org.apache.flink.table.runtime.typeutils.serializers.python.BigDecSerializer
- INSTANCE - Static variable in class org.apache.flink.table.runtime.typeutils.serializers.python.DateSerializer
- INSTANCE - Static variable in class org.apache.flink.table.runtime.typeutils.serializers.python.StringSerializer
- INSTANCE - Static variable in class org.apache.flink.table.runtime.typeutils.serializers.python.TimeSerializer
- INSTANT - org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TypeName
-
INSTANT = 22;
- INSTANT_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TypeName
-
INSTANT = 22;
- INT - org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TypeName
-
INT = 3;
- INT - org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TypeName
-
INT = 5;
- INT_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TypeName
-
INT = 3;
- INT_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TypeName
-
INT = 5;
- IntDataConverter() - Constructor for class org.apache.flink.streaming.api.utils.PythonTypeUtils.IntDataConverter
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.ArrowType.Builder
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.ArrowType
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.Builder
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.FlattenRowType.Builder
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.FlattenRowType
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.OverWindowArrowType.Builder
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.OverWindowArrowType
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RawType.Builder
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RawType
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RowType.Builder
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RowType
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.Builder
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input.Builder
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.JobParameter.Builder
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.JobParameter
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow.Builder
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.BinaryInfo.Builder
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.BinaryInfo
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Builder
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.CharInfo.Builder
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.CharInfo
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.DecimalInfo.Builder
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.DecimalInfo
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Field.Builder
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Field
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.LocalZonedTimestampInfo.Builder
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.LocalZonedTimestampInfo
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.MapInfo.Builder
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.MapInfo
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimeInfo.Builder
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimeInfo
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimestampInfo.Builder
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimestampInfo
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarBinaryInfo.Builder
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarBinaryInfo
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarCharInfo.Builder
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarCharInfo
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.ZonedTimestampInfo.Builder
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.ZonedTimestampInfo
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.Builder
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.Builder
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.Builder
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategy.Builder
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategy
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry.Builder
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.RocksdbCompactFilterCleanupStrategy.Builder
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.RocksdbCompactFilterCleanupStrategy
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.AvroTypeInfo.Builder
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.AvroTypeInfo
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.Builder
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.MapTypeInfo.Builder
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.MapTypeInfo
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Builder
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Field.Builder
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Field
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TupleTypeInfo.Builder
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TupleTypeInfo
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.Builder
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.Builder
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.ListView.Builder
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.ListView
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapView.Builder
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapView
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.Builder
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction.Builder
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions.Builder
- internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions
- internalGetValueMap() - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.Mode
- internalGetValueMap() - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.WindowProperty
- internalGetValueMap() - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.WindowType
- internalGetValueMap() - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow.WindowType
- internalGetValueMap() - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TypeName
- internalGetValueMap() - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.EmptyCleanupStrategy
- internalGetValueMap() - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.Strategies
- internalGetValueMap() - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.StateVisibility
- internalGetValueMap() - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.TtlTimeCharacteristic
- internalGetValueMap() - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.UpdateType
- internalGetValueMap() - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TypeName
- internalGetValueMap() - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.FunctionType
- interpreter - Variable in class org.apache.flink.streaming.api.operators.python.embedded.AbstractEmbeddedPythonFunctionOperator
-
Every operator will hold the only python interpreter.
- IntWriter<T> - Class in org.apache.flink.table.runtime.arrow.writers
-
ArrowFieldWriter
for Int. - IntWriter.IntWriterForArray - Class in org.apache.flink.table.runtime.arrow.writers
-
IntWriter
forArrayData
input. - IntWriter.IntWriterForRow - Class in org.apache.flink.table.runtime.arrow.writers
-
IntWriter
forRowData
input. - invoke(Object, Method, Object[]) - Method in class org.apache.flink.python.util.PythonConnectorUtils.FirstColumnTopicSelectorInvocationHandler
- invokeCurrentBatch() - Method in class org.apache.flink.table.runtime.operators.python.aggregate.arrow.batch.BatchArrowPythonGroupAggregateFunctionOperator
- invokeCurrentBatch() - Method in class org.apache.flink.table.runtime.operators.python.aggregate.arrow.batch.BatchArrowPythonGroupWindowAggregateFunctionOperator
- invokeCurrentBatch() - Method in class org.apache.flink.table.runtime.operators.python.aggregate.arrow.batch.BatchArrowPythonOverWindowAggregateFunctionOperator
- invokeFinishBundle() - Method in class org.apache.flink.streaming.api.operators.python.AbstractPythonFunctionOperator
- invokeFinishBundle() - Method in class org.apache.flink.streaming.api.operators.python.embedded.AbstractEmbeddedPythonFunctionOperator
- invokeFinishBundle() - Method in class org.apache.flink.streaming.api.operators.python.process.AbstractExternalPythonFunctionOperator
- invokeFinishBundle() - Method in class org.apache.flink.streaming.api.transformations.python.DelegateOperatorTransformation.DelegateOperator
- invokeFinishBundle() - Method in class org.apache.flink.table.runtime.operators.python.scalar.arrow.ArrowPythonScalarFunctionOperator
- IS_CLEANUP_IN_BACKGROUND_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies
- IS_PANDAS_UDF_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction
- IS_ROW_TIME_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow
- IS_TIME_WINDOW_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow
- isBasicType() - Method in class org.apache.flink.streaming.api.typeinfo.python.PickledByteArrayTypeInfo
- isBundleFinished() - Method in class org.apache.flink.streaming.api.operators.python.AbstractPythonFunctionOperator
-
Returns whether the bundle is finished.
- isBundleFinished() - Method in class org.apache.flink.table.runtime.operators.python.aggregate.arrow.AbstractArrowPythonAggregateFunctionOperator
- isCheckpointingEnabled() - Method in class org.apache.flink.table.executor.python.ChainingOptimizingExecutor
- isEndOfStream(Row) - Method in class org.apache.flink.formats.csv.CsvRowDeserializationSchema
- isEndOfStream(Row) - Method in class org.apache.flink.formats.json.JsonRowDeserializationSchema
- isImmutableType() - Method in class org.apache.flink.streaming.api.utils.ByteArrayWrapperSerializer
- isImmutableType() - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.BigDecSerializer
- isImmutableType() - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.DateSerializer
- isImmutableType() - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.DecimalDataSerializer
- isImmutableType() - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.StringSerializer
- isImmutableType() - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.TimeSerializer
- isImmutableType() - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.TimestampSerializer
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.ArrowType.Builder
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.ArrowType
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.Builder
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.FlattenRowType.Builder
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.FlattenRowType
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.OverWindowArrowType.Builder
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.OverWindowArrowType
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RawType.Builder
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RawType
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RowType.Builder
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RowType
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.Builder
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input.Builder
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.JobParameter.Builder
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.JobParameter
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow.Builder
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.BinaryInfo.Builder
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.BinaryInfo
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Builder
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.CharInfo.Builder
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.CharInfo
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.DecimalInfo.Builder
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.DecimalInfo
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Field.Builder
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Field
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.LocalZonedTimestampInfo.Builder
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.LocalZonedTimestampInfo
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.MapInfo.Builder
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.MapInfo
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimeInfo.Builder
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimeInfo
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimestampInfo.Builder
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimestampInfo
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarBinaryInfo.Builder
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarBinaryInfo
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarCharInfo.Builder
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarCharInfo
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.ZonedTimestampInfo.Builder
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.ZonedTimestampInfo
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.Builder
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.Builder
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.Builder
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategy.Builder
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategy
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry.Builder
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.RocksdbCompactFilterCleanupStrategy.Builder
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.RocksdbCompactFilterCleanupStrategy
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.AvroTypeInfo.Builder
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.AvroTypeInfo
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.Builder
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.MapTypeInfo.Builder
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.MapTypeInfo
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Builder
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Field.Builder
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Field
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TupleTypeInfo.Builder
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TupleTypeInfo
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.Builder
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.Builder
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.ListView.Builder
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.ListView
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapView.Builder
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapView
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.Builder
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction.Builder
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions.Builder
- isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions
- isKeyType() - Method in class org.apache.flink.streaming.api.typeinfo.python.PickledByteArrayTypeInfo
- isNullAt(int) - Method in class org.apache.flink.table.runtime.arrow.vectors.ArrowArrayColumnVector
- isNullAt(int) - Method in class org.apache.flink.table.runtime.arrow.vectors.ArrowBigIntColumnVector
- isNullAt(int) - Method in class org.apache.flink.table.runtime.arrow.vectors.ArrowBinaryColumnVector
- isNullAt(int) - Method in class org.apache.flink.table.runtime.arrow.vectors.ArrowBooleanColumnVector
- isNullAt(int) - Method in class org.apache.flink.table.runtime.arrow.vectors.ArrowDateColumnVector
- isNullAt(int) - Method in class org.apache.flink.table.runtime.arrow.vectors.ArrowDecimalColumnVector
- isNullAt(int) - Method in class org.apache.flink.table.runtime.arrow.vectors.ArrowDoubleColumnVector
- isNullAt(int) - Method in class org.apache.flink.table.runtime.arrow.vectors.ArrowFloatColumnVector
- isNullAt(int) - Method in class org.apache.flink.table.runtime.arrow.vectors.ArrowIntColumnVector
- isNullAt(int) - Method in class org.apache.flink.table.runtime.arrow.vectors.ArrowMapColumnVector
- isNullAt(int) - Method in class org.apache.flink.table.runtime.arrow.vectors.ArrowNullColumnVector
- isNullAt(int) - Method in class org.apache.flink.table.runtime.arrow.vectors.ArrowRowColumnVector
- isNullAt(int) - Method in class org.apache.flink.table.runtime.arrow.vectors.ArrowSmallIntColumnVector
- isNullAt(int) - Method in class org.apache.flink.table.runtime.arrow.vectors.ArrowTimeColumnVector
- isNullAt(int) - Method in class org.apache.flink.table.runtime.arrow.vectors.ArrowTimestampColumnVector
- isNullAt(int) - Method in class org.apache.flink.table.runtime.arrow.vectors.ArrowTinyIntColumnVector
- isNullAt(int) - Method in class org.apache.flink.table.runtime.arrow.vectors.ArrowVarBinaryColumnVector
- isNullAt(int) - Method in class org.apache.flink.table.runtime.arrow.vectors.ArrowVarCharColumnVector
- isPythonDataStreamOperator(Transformation<?>) - Static method in class org.apache.flink.python.util.PythonConfigUtil
- isTupleType() - Method in class org.apache.flink.streaming.api.typeinfo.python.PickledByteArrayTypeInfo
- ITEMS - org.apache.flink.streaming.api.runners.python.beam.state.IterateType
-
Equivalent to iterate
Map.entrySet()
. - IterateType - Enum in org.apache.flink.streaming.api.runners.python.beam.state
-
The type of the Python map state iterate request.
J
- JOB_PARAMETERS_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions
- JOB_PARAMETERS_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext
- JOB_PARAMETERS_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions
- JsonRowDeserializationSchema - Class in org.apache.flink.formats.json
-
Deserialization schema from JSON to Flink types.
- JsonRowDeserializationSchema(String) - Constructor for class org.apache.flink.formats.json.JsonRowDeserializationSchema
- JsonRowDeserializationSchema(TypeInformation<Row>) - Constructor for class org.apache.flink.formats.json.JsonRowDeserializationSchema
- JsonRowDeserializationSchema.Builder - Class in org.apache.flink.formats.json
-
Builder for
JsonRowDeserializationSchema
. - JsonRowSerializationSchema - Class in org.apache.flink.formats.json
-
Serialization schema that serializes an object of Flink types into a JSON bytes.
- JsonRowSerializationSchema.Builder - Class in org.apache.flink.formats.json
-
Builder for
JsonRowSerializationSchema
.
K
- KEY_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.JobParameter
- KEY_TYPE_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.MapInfo
- KEY_TYPE_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.MapTypeInfo
- KEY_TYPE_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapView
- KEY_TYPE_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions
- KEY_TYPE_INFO_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction
- KeyByKeySelector - Class in org.apache.flink.streaming.api.functions.python
-
KeyByKeySelector
is responsible for extracting the first field of the input row as key. - KeyByKeySelector() - Constructor for class org.apache.flink.streaming.api.functions.python.KeyByKeySelector
- KEYED_CO_BROADCAST_PROCESS - org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.FunctionType
-
KEYED_CO_BROADCAST_PROCESS = 6;
- KEYED_CO_BROADCAST_PROCESS_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.FunctionType
-
KEYED_CO_BROADCAST_PROCESS = 6;
- KEYED_CO_PROCESS - org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.FunctionType
-
KEYED_CO_PROCESS = 3;
- KEYED_CO_PROCESS_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.FunctionType
-
KEYED_CO_PROCESS = 3;
- KEYED_PROCESS - org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.FunctionType
-
KEYED_PROCESS = 2;
- KEYED_PROCESS_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.FunctionType
-
KEYED_PROCESS = 2;
- KEYED_STREAM_VALUE_OPERATOR_NAME - Static variable in class org.apache.flink.python.util.PythonConfigUtil
- KEYS - org.apache.flink.streaming.api.runners.python.beam.state.IterateType
-
Equivalent to iterate
Map.keySet()
.
L
- lastFinishBundleTime - Variable in class org.apache.flink.streaming.api.operators.python.AbstractPythonFunctionOperator
-
Time that the last bundle was finished.
- LENGTH_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.BinaryInfo
- LENGTH_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.CharInfo
- LENGTH_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarBinaryInfo
- LENGTH_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarCharInfo
- LIST - org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TypeName
-
LIST = 18;
- LIST_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TypeName
-
LIST = 18;
- LIST_VIEW - org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.DataViewCase
- LIST_VIEW_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec
- load() - Method in class org.apache.flink.table.runtime.arrow.serializers.ArrowSerializer
- LOCAL_DATE - org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TypeName
-
LOCAL_DATE = 24;
- LOCAL_DATE_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TypeName
-
LOCAL_DATE = 24;
- LOCAL_DATETIME - org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TypeName
-
LOCAL_DATETIME = 26;
- LOCAL_DATETIME_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TypeName
-
LOCAL_DATETIME = 26;
- LOCAL_TIME - org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TypeName
-
LOCAL_TIME = 25;
- LOCAL_TIME_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TypeName
-
LOCAL_TIME = 25;
- LOCAL_ZONED_TIMESTAMP - org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TypeName
-
LOCAL_ZONED_TIMESTAMP = 19;
- LOCAL_ZONED_TIMESTAMP - org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TypeName
-
LOCAL_ZONED_TIMESTAMP = 27;
- LOCAL_ZONED_TIMESTAMP_INFO - org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.TypeInfoCase
- LOCAL_ZONED_TIMESTAMP_INFO_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
- LOCAL_ZONED_TIMESTAMP_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TypeName
-
LOCAL_ZONED_TIMESTAMP = 19;
- LOCAL_ZONED_TIMESTAMP_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TypeName
-
LOCAL_ZONED_TIMESTAMP = 27;
- LOG - Static variable in class org.apache.flink.streaming.api.runners.python.beam.BeamPythonFunctionRunner
- LogicalTypeToProtoTypeConverter() - Constructor for class org.apache.flink.table.runtime.typeutils.PythonTypeUtils.LogicalTypeToProtoTypeConverter
- LONG - org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TypeName
-
LONG = 6;
- LONG_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TypeName
-
LONG = 6;
- LOWER_BOUNDARY_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow
- lowerBoundary - Variable in class org.apache.flink.table.runtime.operators.python.aggregate.arrow.stream.AbstractStreamArrowPythonOverWindowAggregateFunctionOperator
-
Window lower boundary.
M
- main(String[]) - Static method in class org.apache.flink.client.python.PythonDriver
- main(String[]) - Static method in class org.apache.flink.client.python.PythonGatewayServer
-
Main method to start a local GatewayServer on a ephemeral port.
- main(String[]) - Static method in class org.apache.flink.client.python.PythonShellParser
- MAIN_INPUT_NAME - Static variable in class org.apache.flink.python.Constants
- MAIN_OUTPUT_NAME - Static variable in class org.apache.flink.python.Constants
- mainInputReceiver - Variable in class org.apache.flink.streaming.api.runners.python.beam.BeamPythonFunctionRunner
-
The receiver which forwards the input elements to a remote environment for processing.
- map(Tuple2<T, Long>) - Method in class org.apache.flink.streaming.api.functions.python.eventtime.RemoveTimestampMapFunction
- MAP - org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TypeName
-
MAP = 17;
- MAP - org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TypeName
-
MAP = 19;
- MAP_INFO - org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.TypeInfoCase
- MAP_INFO_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
- MAP_STATE_ITERATE_RESPONSE_BATCH_SIZE - Static variable in class org.apache.flink.python.PythonOptions
-
The maximum number of entries sent to Python UDF worker per request when iterating a Python MapState.
- MAP_STATE_READ_CACHE_SIZE - Static variable in class org.apache.flink.python.PythonOptions
-
The maximum number of cached items which read from Java side in a Python MapState.
- MAP_STATE_READ_CACHE_SIZE_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions
- MAP_STATE_READ_CACHE_SIZE_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction
- MAP_STATE_WRITE_CACHE_SIZE - Static variable in class org.apache.flink.python.PythonOptions
-
The maximum number of write requests cached in a Python MapState.
- MAP_STATE_WRITE_CACHE_SIZE_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions
- MAP_STATE_WRITE_CACHE_SIZE_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction
- MAP_TYPE_INFO - org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TypeInfoCase
- MAP_TYPE_INFO_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo
- MAP_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TypeName
-
MAP = 17;
- MAP_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TypeName
-
MAP = 19;
- MAP_VIEW - org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.DataViewCase
- MAP_VIEW_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec
- MapDataSerializer - Class in org.apache.flink.table.runtime.typeutils.serializers.python
-
A
TypeSerializer
forMapData
. - MapDataSerializer(LogicalType, LogicalType, TypeSerializer, TypeSerializer) - Constructor for class org.apache.flink.table.runtime.typeutils.serializers.python.MapDataSerializer
- MapDataSerializer.BaseMapSerializerSnapshot - Class in org.apache.flink.table.runtime.typeutils.serializers.python
-
TypeSerializerSnapshot
forMapDataSerializer
. - MapWriter<T> - Class in org.apache.flink.table.runtime.arrow.writers
-
ArrowFieldWriter
for Map. - MapWriter.MapWriterForArray - Class in org.apache.flink.table.runtime.arrow.writers
-
MapWriter
forArrayData
input. - MapWriter.MapWriterForRow - Class in org.apache.flink.table.runtime.arrow.writers
-
MapWriter
forRowData
input. - MAX_ARROW_BATCH_SIZE - Static variable in class org.apache.flink.python.PythonOptions
-
The maximum number of elements to include in an arrow batch.
- MAX_BUNDLE_SIZE - Static variable in class org.apache.flink.python.PythonOptions
-
The maximum number of elements to include in a bundle.
- MAX_BUNDLE_TIME_MILLS - Static variable in class org.apache.flink.python.PythonOptions
-
The maximum time to wait before finalising a bundle (in milliseconds).
- MAX_NUMBER_OF_PARALLEL_SUBTASKS_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext
- maxBundleSize - Variable in class org.apache.flink.streaming.api.operators.python.AbstractPythonFunctionOperator
-
Max number of elements to include in a bundle.
- merge(Configuration, Configuration) - Static method in class org.apache.flink.python.util.PythonDependencyUtils
- mergeArrowType(FlinkFnApi.CoderInfoDescriptor.ArrowType) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.Builder
-
.org.apache.flink.fn_execution.v1.CoderInfoDescriptor.ArrowType arrow_type = 3;
- mergeAvroTypeInfo(FlinkFnApi.TypeInfo.AvroTypeInfo) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.Builder
-
.org.apache.flink.fn_execution.v1.TypeInfo.AvroTypeInfo avro_type_info = 6;
- mergeBinaryInfo(FlinkFnApi.Schema.BinaryInfo) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.BinaryInfo binary_info = 11;
- mergeCharInfo(FlinkFnApi.Schema.CharInfo) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.CharInfo char_info = 13;
- mergeCleanupStrategies(FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.Builder
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies cleanup_strategies = 5;
- mergeCollectionElementType(FlinkFnApi.Schema.FieldType) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.FieldType collection_element_type = 3;
- mergeCollectionElementType(FlinkFnApi.TypeInfo) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.Builder
-
.org.apache.flink.fn_execution.v1.TypeInfo collection_element_type = 2;
- mergeDecimalInfo(FlinkFnApi.Schema.DecimalInfo) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.DecimalInfo decimal_info = 6;
- mergeElementType(FlinkFnApi.Schema.FieldType) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.ListView.Builder
-
.org.apache.flink.fn_execution.v1.Schema.FieldType element_type = 1;
- mergeFieldType(FlinkFnApi.TypeInfo) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Field.Builder
-
.org.apache.flink.fn_execution.v1.TypeInfo field_type = 2;
- mergeFlattenRowType(FlinkFnApi.CoderInfoDescriptor.FlattenRowType) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.Builder
-
for Table & SQL
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.ArrowType.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.FlattenRowType.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.OverWindowArrowType.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RawType.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RowType.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.JobParameter.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.BinaryInfo.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.CharInfo.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.DecimalInfo.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Field.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.LocalZonedTimestampInfo.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.MapInfo.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimeInfo.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimestampInfo.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarBinaryInfo.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarCharInfo.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.ZonedTimestampInfo.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategy.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.RocksdbCompactFilterCleanupStrategy.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.AvroTypeInfo.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.MapTypeInfo.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Field.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TupleTypeInfo.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.ListView.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapView.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions.Builder
- mergeFrom(Message) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.ArrowType.Builder
- mergeFrom(Message) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.Builder
- mergeFrom(Message) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.FlattenRowType.Builder
- mergeFrom(Message) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.OverWindowArrowType.Builder
- mergeFrom(Message) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RawType.Builder
- mergeFrom(Message) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RowType.Builder
- mergeFrom(Message) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.Builder
- mergeFrom(Message) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input.Builder
- mergeFrom(Message) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.JobParameter.Builder
- mergeFrom(Message) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow.Builder
- mergeFrom(Message) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.BinaryInfo.Builder
- mergeFrom(Message) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Builder
- mergeFrom(Message) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.CharInfo.Builder
- mergeFrom(Message) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.DecimalInfo.Builder
- mergeFrom(Message) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Field.Builder
- mergeFrom(Message) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
- mergeFrom(Message) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.LocalZonedTimestampInfo.Builder
- mergeFrom(Message) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.MapInfo.Builder
- mergeFrom(Message) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimeInfo.Builder
- mergeFrom(Message) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimestampInfo.Builder
- mergeFrom(Message) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarBinaryInfo.Builder
- mergeFrom(Message) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarCharInfo.Builder
- mergeFrom(Message) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.ZonedTimestampInfo.Builder
- mergeFrom(Message) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.Builder
- mergeFrom(Message) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.Builder
- mergeFrom(Message) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.Builder
- mergeFrom(Message) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategy.Builder
- mergeFrom(Message) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry.Builder
- mergeFrom(Message) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.RocksdbCompactFilterCleanupStrategy.Builder
- mergeFrom(Message) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.AvroTypeInfo.Builder
- mergeFrom(Message) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.Builder
- mergeFrom(Message) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.MapTypeInfo.Builder
- mergeFrom(Message) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Builder
- mergeFrom(Message) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Field.Builder
- mergeFrom(Message) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TupleTypeInfo.Builder
- mergeFrom(Message) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.Builder
- mergeFrom(Message) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.Builder
- mergeFrom(Message) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.ListView.Builder
- mergeFrom(Message) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapView.Builder
- mergeFrom(Message) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
- mergeFrom(Message) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.Builder
- mergeFrom(Message) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder
- mergeFrom(Message) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction.Builder
- mergeFrom(Message) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions.Builder
- mergeFrom(FlinkFnApi.CoderInfoDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.Builder
- mergeFrom(FlinkFnApi.CoderInfoDescriptor.ArrowType) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.ArrowType.Builder
- mergeFrom(FlinkFnApi.CoderInfoDescriptor.FlattenRowType) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.FlattenRowType.Builder
- mergeFrom(FlinkFnApi.CoderInfoDescriptor.OverWindowArrowType) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.OverWindowArrowType.Builder
- mergeFrom(FlinkFnApi.CoderInfoDescriptor.RawType) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RawType.Builder
- mergeFrom(FlinkFnApi.CoderInfoDescriptor.RowType) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RowType.Builder
- mergeFrom(FlinkFnApi.GroupWindow) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.Builder
- mergeFrom(FlinkFnApi.Input) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input.Builder
- mergeFrom(FlinkFnApi.JobParameter) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.JobParameter.Builder
- mergeFrom(FlinkFnApi.OverWindow) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow.Builder
- mergeFrom(FlinkFnApi.Schema) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Builder
- mergeFrom(FlinkFnApi.Schema.BinaryInfo) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.BinaryInfo.Builder
- mergeFrom(FlinkFnApi.Schema.CharInfo) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.CharInfo.Builder
- mergeFrom(FlinkFnApi.Schema.DecimalInfo) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.DecimalInfo.Builder
- mergeFrom(FlinkFnApi.Schema.Field) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Field.Builder
- mergeFrom(FlinkFnApi.Schema.FieldType) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
- mergeFrom(FlinkFnApi.Schema.LocalZonedTimestampInfo) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.LocalZonedTimestampInfo.Builder
- mergeFrom(FlinkFnApi.Schema.MapInfo) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.MapInfo.Builder
- mergeFrom(FlinkFnApi.Schema.TimeInfo) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimeInfo.Builder
- mergeFrom(FlinkFnApi.Schema.TimestampInfo) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimestampInfo.Builder
- mergeFrom(FlinkFnApi.Schema.VarBinaryInfo) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarBinaryInfo.Builder
- mergeFrom(FlinkFnApi.Schema.VarCharInfo) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarCharInfo.Builder
- mergeFrom(FlinkFnApi.Schema.ZonedTimestampInfo) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.ZonedTimestampInfo.Builder
- mergeFrom(FlinkFnApi.StateDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.Builder
- mergeFrom(FlinkFnApi.StateDescriptor.StateTTLConfig) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.Builder
- mergeFrom(FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.Builder
- mergeFrom(FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategy) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategy.Builder
- mergeFrom(FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry.Builder
- mergeFrom(FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.RocksdbCompactFilterCleanupStrategy) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.RocksdbCompactFilterCleanupStrategy.Builder
- mergeFrom(FlinkFnApi.TypeInfo) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.Builder
- mergeFrom(FlinkFnApi.TypeInfo.AvroTypeInfo) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.AvroTypeInfo.Builder
- mergeFrom(FlinkFnApi.TypeInfo.MapTypeInfo) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.MapTypeInfo.Builder
- mergeFrom(FlinkFnApi.TypeInfo.RowTypeInfo) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Builder
- mergeFrom(FlinkFnApi.TypeInfo.RowTypeInfo.Field) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Field.Builder
- mergeFrom(FlinkFnApi.TypeInfo.TupleTypeInfo) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TupleTypeInfo.Builder
- mergeFrom(FlinkFnApi.UserDefinedAggregateFunction) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.Builder
- mergeFrom(FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.Builder
- mergeFrom(FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.ListView) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.ListView.Builder
- mergeFrom(FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapView) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapView.Builder
- mergeFrom(FlinkFnApi.UserDefinedAggregateFunctions) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
- mergeFrom(FlinkFnApi.UserDefinedDataStreamFunction) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.Builder
- mergeFrom(FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder
- mergeFrom(FlinkFnApi.UserDefinedFunction) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction.Builder
- mergeFrom(FlinkFnApi.UserDefinedFunctions) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions.Builder
- mergeGroupWindow(FlinkFnApi.GroupWindow) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
-
Group Window.
- mergeIncrementalCleanupStrategy(FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategy) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry.Builder
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategy incremental_cleanup_strategy = 3;
- mergeKeyType(FlinkFnApi.Schema.FieldType) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.MapInfo.Builder
-
.org.apache.flink.fn_execution.v1.Schema.FieldType key_type = 1;
- mergeKeyType(FlinkFnApi.Schema.FieldType) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapView.Builder
-
.org.apache.flink.fn_execution.v1.Schema.FieldType key_type = 1;
- mergeKeyType(FlinkFnApi.Schema.FieldType) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
-
The schema of the grouping keys.
- mergeKeyType(FlinkFnApi.TypeInfo) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.MapTypeInfo.Builder
-
.org.apache.flink.fn_execution.v1.TypeInfo key_type = 1;
- mergeKeyTypeInfo(FlinkFnApi.TypeInfo) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.Builder
-
.org.apache.flink.fn_execution.v1.TypeInfo key_type_info = 5;
- mergeListView(FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.ListView) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.Builder
-
.org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction.DataViewSpec.ListView list_view = 3;
- mergeLocalZonedTimestampInfo(FlinkFnApi.Schema.LocalZonedTimestampInfo) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.LocalZonedTimestampInfo local_zoned_timestamp_info = 9;
- mergeMapInfo(FlinkFnApi.Schema.MapInfo) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.MapInfo map_info = 4;
- mergeMapTypeInfo(FlinkFnApi.TypeInfo.MapTypeInfo) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.Builder
-
.org.apache.flink.fn_execution.v1.TypeInfo.MapTypeInfo map_type_info = 5;
- mergeMapView(FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapView) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.Builder
-
.org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction.DataViewSpec.MapView map_view = 4;
- mergeOverWindowArrowType(FlinkFnApi.CoderInfoDescriptor.OverWindowArrowType) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.Builder
-
.org.apache.flink.fn_execution.v1.CoderInfoDescriptor.OverWindowArrowType over_window_arrow_type = 4;
- mergeRawType(FlinkFnApi.CoderInfoDescriptor.RawType) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.Builder
-
for DataStream
- mergeRocksdbCompactFilterCleanupStrategy(FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.RocksdbCompactFilterCleanupStrategy) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry.Builder
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies.RocksdbCompactFilterCleanupStrategy rocksdb_compact_filter_cleanup_strategy = 4;
- mergeRowSchema(FlinkFnApi.Schema) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema row_schema = 5;
- mergeRowType(FlinkFnApi.CoderInfoDescriptor.RowType) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.Builder
-
.org.apache.flink.fn_execution.v1.CoderInfoDescriptor.RowType row_type = 2;
- mergeRowTypeInfo(FlinkFnApi.TypeInfo.RowTypeInfo) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.Builder
-
.org.apache.flink.fn_execution.v1.TypeInfo.RowTypeInfo row_type_info = 3;
- mergeRuntimeContext(FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.Builder
-
.org.apache.flink.fn_execution.v1.UserDefinedDataStreamFunction.RuntimeContext runtime_context = 2;
- mergeSchema(FlinkFnApi.Schema) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.ArrowType.Builder
-
.org.apache.flink.fn_execution.v1.Schema schema = 1;
- mergeSchema(FlinkFnApi.Schema) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.FlattenRowType.Builder
-
.org.apache.flink.fn_execution.v1.Schema schema = 1;
- mergeSchema(FlinkFnApi.Schema) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.OverWindowArrowType.Builder
-
.org.apache.flink.fn_execution.v1.Schema schema = 1;
- mergeSchema(FlinkFnApi.Schema) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RowType.Builder
-
.org.apache.flink.fn_execution.v1.Schema schema = 1;
- mergeStateTtlConfig(FlinkFnApi.StateDescriptor.StateTTLConfig) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.Builder
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig state_ttl_config = 2;
- mergeTimeInfo(FlinkFnApi.Schema.TimeInfo) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.TimeInfo time_info = 7;
- mergeTimestampInfo(FlinkFnApi.Schema.TimestampInfo) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.TimestampInfo timestamp_info = 8;
- mergeTupleTypeInfo(FlinkFnApi.TypeInfo.TupleTypeInfo) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.Builder
-
.org.apache.flink.fn_execution.v1.TypeInfo.TupleTypeInfo tuple_type_info = 4;
- mergeType(FlinkFnApi.Schema.FieldType) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Field.Builder
-
.org.apache.flink.fn_execution.v1.Schema.FieldType type = 3;
- mergeTypeInfo(FlinkFnApi.TypeInfo) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RawType.Builder
-
.org.apache.flink.fn_execution.v1.TypeInfo type_info = 1;
- mergeUdf(FlinkFnApi.UserDefinedFunction) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input.Builder
-
.org.apache.flink.fn_execution.v1.UserDefinedFunction udf = 1;
- mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.ArrowType.Builder
- mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.Builder
- mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.FlattenRowType.Builder
- mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.OverWindowArrowType.Builder
- mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RawType.Builder
- mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RowType.Builder
- mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.Builder
- mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input.Builder
- mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.JobParameter.Builder
- mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow.Builder
- mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.BinaryInfo.Builder
- mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Builder
- mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.CharInfo.Builder
- mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.DecimalInfo.Builder
- mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Field.Builder
- mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
- mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.LocalZonedTimestampInfo.Builder
- mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.MapInfo.Builder
- mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimeInfo.Builder
- mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimestampInfo.Builder
- mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarBinaryInfo.Builder
- mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarCharInfo.Builder
- mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.ZonedTimestampInfo.Builder
- mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.Builder
- mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.Builder
- mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.Builder
- mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategy.Builder
- mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry.Builder
- mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.RocksdbCompactFilterCleanupStrategy.Builder
- mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.AvroTypeInfo.Builder
- mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.Builder
- mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.MapTypeInfo.Builder
- mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Builder
- mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Field.Builder
- mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TupleTypeInfo.Builder
- mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.Builder
- mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.Builder
- mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.ListView.Builder
- mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapView.Builder
- mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
- mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.Builder
- mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder
- mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction.Builder
- mergeUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions.Builder
- mergeValueType(FlinkFnApi.Schema.FieldType) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.MapInfo.Builder
-
.org.apache.flink.fn_execution.v1.Schema.FieldType value_type = 2;
- mergeValueType(FlinkFnApi.Schema.FieldType) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapView.Builder
-
.org.apache.flink.fn_execution.v1.Schema.FieldType value_type = 2;
- mergeValueType(FlinkFnApi.TypeInfo) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.MapTypeInfo.Builder
-
.org.apache.flink.fn_execution.v1.TypeInfo value_type = 2;
- mergeVarBinaryInfo(FlinkFnApi.Schema.VarBinaryInfo) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.VarBinaryInfo var_binary_info = 12;
- mergeVarCharInfo(FlinkFnApi.Schema.VarCharInfo) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.VarCharInfo var_char_info = 14;
- mergeZonedTimestampInfo(FlinkFnApi.Schema.ZonedTimestampInfo) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.ZonedTimestampInfo zoned_timestamp_info = 10;
- METRIC_ENABLED_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions
- METRIC_ENABLED_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction
- METRIC_ENABLED_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions
- MetricDistribution - Class in org.apache.flink.python.metric.embedded
-
Flink
Gauge
for Python Distribution. - MetricDistribution() - Constructor for class org.apache.flink.python.metric.embedded.MetricDistribution
- MetricGauge - Class in org.apache.flink.python.metric.embedded
-
Flink
Gauge
for Python Gauge. - MetricGauge(PyObject) - Constructor for class org.apache.flink.python.metric.embedded.MetricGauge
- MODE_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor
- MULTIPLE - org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.Mode
-
process multiple records at a time
- MULTIPLE_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.Mode
-
process multiple records at a time
- MULTISET - org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TypeName
-
MULTISET = 18;
- MULTISET_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TypeName
-
MULTISET = 18;
N
- NAME_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Field
- NAME_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec
- NAMEDPROPERTIES_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow
- NeverReturnExpired - org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.StateVisibility
-
Never return expired user value.
- NeverReturnExpired_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.StateVisibility
-
Never return expired user value.
- newBuilder() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.ArrowType
- newBuilder() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.FlattenRowType
- newBuilder() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor
- newBuilder() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.OverWindowArrowType
- newBuilder() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RawType
- newBuilder() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RowType
- newBuilder() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow
- newBuilder() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input
- newBuilder() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.JobParameter
- newBuilder() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow
- newBuilder() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.BinaryInfo
- newBuilder() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.CharInfo
- newBuilder() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.DecimalInfo
- newBuilder() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Field
- newBuilder() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
- newBuilder() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.LocalZonedTimestampInfo
- newBuilder() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.MapInfo
- newBuilder() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema
- newBuilder() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimeInfo
- newBuilder() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimestampInfo
- newBuilder() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarBinaryInfo
- newBuilder() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarCharInfo
- newBuilder() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.ZonedTimestampInfo
- newBuilder() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor
- newBuilder() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategy
- newBuilder() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry
- newBuilder() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies
- newBuilder() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.RocksdbCompactFilterCleanupStrategy
- newBuilder() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig
- newBuilder() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.AvroTypeInfo
- newBuilder() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.MapTypeInfo
- newBuilder() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo
- newBuilder() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Field
- newBuilder() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo
- newBuilder() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TupleTypeInfo
- newBuilder() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.ListView
- newBuilder() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapView
- newBuilder() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec
- newBuilder() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction
- newBuilder() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions
- newBuilder() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction
- newBuilder() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext
- newBuilder() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction
- newBuilder() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions
- newBuilder(FlinkFnApi.CoderInfoDescriptor) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor
- newBuilder(FlinkFnApi.CoderInfoDescriptor.ArrowType) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.ArrowType
- newBuilder(FlinkFnApi.CoderInfoDescriptor.FlattenRowType) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.FlattenRowType
- newBuilder(FlinkFnApi.CoderInfoDescriptor.OverWindowArrowType) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.OverWindowArrowType
- newBuilder(FlinkFnApi.CoderInfoDescriptor.RawType) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RawType
- newBuilder(FlinkFnApi.CoderInfoDescriptor.RowType) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RowType
- newBuilder(FlinkFnApi.GroupWindow) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow
- newBuilder(FlinkFnApi.Input) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input
- newBuilder(FlinkFnApi.JobParameter) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.JobParameter
- newBuilder(FlinkFnApi.OverWindow) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow
- newBuilder(FlinkFnApi.Schema) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema
- newBuilder(FlinkFnApi.Schema.BinaryInfo) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.BinaryInfo
- newBuilder(FlinkFnApi.Schema.CharInfo) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.CharInfo
- newBuilder(FlinkFnApi.Schema.DecimalInfo) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.DecimalInfo
- newBuilder(FlinkFnApi.Schema.Field) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Field
- newBuilder(FlinkFnApi.Schema.FieldType) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
- newBuilder(FlinkFnApi.Schema.LocalZonedTimestampInfo) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.LocalZonedTimestampInfo
- newBuilder(FlinkFnApi.Schema.MapInfo) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.MapInfo
- newBuilder(FlinkFnApi.Schema.TimeInfo) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimeInfo
- newBuilder(FlinkFnApi.Schema.TimestampInfo) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimestampInfo
- newBuilder(FlinkFnApi.Schema.VarBinaryInfo) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarBinaryInfo
- newBuilder(FlinkFnApi.Schema.VarCharInfo) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarCharInfo
- newBuilder(FlinkFnApi.Schema.ZonedTimestampInfo) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.ZonedTimestampInfo
- newBuilder(FlinkFnApi.StateDescriptor) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor
- newBuilder(FlinkFnApi.StateDescriptor.StateTTLConfig) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig
- newBuilder(FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies
- newBuilder(FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategy) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategy
- newBuilder(FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry
- newBuilder(FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.RocksdbCompactFilterCleanupStrategy) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.RocksdbCompactFilterCleanupStrategy
- newBuilder(FlinkFnApi.TypeInfo) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo
- newBuilder(FlinkFnApi.TypeInfo.AvroTypeInfo) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.AvroTypeInfo
- newBuilder(FlinkFnApi.TypeInfo.MapTypeInfo) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.MapTypeInfo
- newBuilder(FlinkFnApi.TypeInfo.RowTypeInfo) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo
- newBuilder(FlinkFnApi.TypeInfo.RowTypeInfo.Field) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Field
- newBuilder(FlinkFnApi.TypeInfo.TupleTypeInfo) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TupleTypeInfo
- newBuilder(FlinkFnApi.UserDefinedAggregateFunction) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction
- newBuilder(FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec
- newBuilder(FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.ListView) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.ListView
- newBuilder(FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapView) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapView
- newBuilder(FlinkFnApi.UserDefinedAggregateFunctions) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions
- newBuilder(FlinkFnApi.UserDefinedDataStreamFunction) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction
- newBuilder(FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext
- newBuilder(FlinkFnApi.UserDefinedFunction) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction
- newBuilder(FlinkFnApi.UserDefinedFunctions) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions
- newBuilderForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.ArrowType
- newBuilderForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.FlattenRowType
- newBuilderForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor
- newBuilderForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.OverWindowArrowType
- newBuilderForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RawType
- newBuilderForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RowType
- newBuilderForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow
- newBuilderForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input
- newBuilderForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.JobParameter
- newBuilderForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow
- newBuilderForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.BinaryInfo
- newBuilderForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.CharInfo
- newBuilderForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.DecimalInfo
- newBuilderForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Field
- newBuilderForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
- newBuilderForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.LocalZonedTimestampInfo
- newBuilderForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.MapInfo
- newBuilderForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema
- newBuilderForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimeInfo
- newBuilderForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimestampInfo
- newBuilderForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarBinaryInfo
- newBuilderForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarCharInfo
- newBuilderForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.ZonedTimestampInfo
- newBuilderForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor
- newBuilderForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategy
- newBuilderForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry
- newBuilderForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies
- newBuilderForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.RocksdbCompactFilterCleanupStrategy
- newBuilderForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig
- newBuilderForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.AvroTypeInfo
- newBuilderForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.MapTypeInfo
- newBuilderForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo
- newBuilderForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Field
- newBuilderForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo
- newBuilderForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TupleTypeInfo
- newBuilderForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.ListView
- newBuilderForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapView
- newBuilderForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec
- newBuilderForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction
- newBuilderForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions
- newBuilderForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction
- newBuilderForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext
- newBuilderForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction
- newBuilderForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.ArrowType
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.FlattenRowType
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.OverWindowArrowType
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RawType
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RowType
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.JobParameter
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.BinaryInfo
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.CharInfo
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.DecimalInfo
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Field
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.LocalZonedTimestampInfo
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.MapInfo
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimeInfo
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimestampInfo
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarBinaryInfo
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarCharInfo
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.ZonedTimestampInfo
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategy
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.RocksdbCompactFilterCleanupStrategy
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.AvroTypeInfo
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.MapTypeInfo
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Field
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TupleTypeInfo
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.ListView
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapView
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction
- newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions
- newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.ArrowType
- newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.FlattenRowType
- newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor
- newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.OverWindowArrowType
- newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RawType
- newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RowType
- newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow
- newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input
- newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.JobParameter
- newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow
- newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.BinaryInfo
- newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.CharInfo
- newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.DecimalInfo
- newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Field
- newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
- newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.LocalZonedTimestampInfo
- newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.MapInfo
- newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema
- newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimeInfo
- newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimestampInfo
- newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarBinaryInfo
- newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarCharInfo
- newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.ZonedTimestampInfo
- newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor
- newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategy
- newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry
- newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies
- newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.RocksdbCompactFilterCleanupStrategy
- newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig
- newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.AvroTypeInfo
- newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.MapTypeInfo
- newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo
- newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Field
- newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo
- newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TupleTypeInfo
- newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.ListView
- newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapView
- newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec
- newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction
- newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions
- newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction
- newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext
- newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction
- newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions
- nextSelection() - Method in class org.apache.flink.streaming.api.operators.python.embedded.EmbeddedPythonBatchCoBroadcastProcessOperator
- nextSelection() - Method in class org.apache.flink.streaming.api.operators.python.process.ExternalPythonBatchCoBroadcastProcessOperator
- notifyNoMoreResults() - Method in class org.apache.flink.streaming.api.runners.python.beam.BeamPythonFunctionRunner
-
Interrupts the progress of takeResult.
- NULL - org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TypeName
-
NULL = 21;
- NULL_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TypeName
-
NULL = 21;
- NULLABLE_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
- NullWriter<T> - Class in org.apache.flink.table.runtime.arrow.writers
-
ArrowFieldWriter
for Null. - NullWriter(NullVector) - Constructor for class org.apache.flink.table.runtime.arrow.writers.NullWriter
- NUMBER_OF_PARALLEL_SUBTASKS_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext
O
- OBJECT_ARRAY - org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TypeName
-
OBJECT_ARRAY = 21;
- OBJECT_ARRAY_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TypeName
-
OBJECT_ARRAY = 21;
- of(ReadableConfig, ClassLoader) - Static method in class org.apache.flink.client.python.PythonFunctionFactory.CacheKey
- of(KeyedStateBackend<?>, OperatorStateBackend, TypeSerializer<?>, TypeSerializer<?>, ReadableConfig) - Static method in class org.apache.flink.streaming.api.runners.python.beam.state.BeamStateRequestHandler
-
Create a
BeamStateRequestHandler
. - OnCreateAndWrite - org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.UpdateType
-
Last access timestamp is initialised when state is created and updated on every write operation.
- OnCreateAndWrite_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.UpdateType
-
Last access timestamp is initialised when state is created and updated on every write operation.
- onEventTime(InternalTimer<K, VoidNamespace>) - Method in class org.apache.flink.streaming.api.operators.python.embedded.EmbeddedPythonKeyedCoProcessOperator
- onEventTime(InternalTimer<K, VoidNamespace>) - Method in class org.apache.flink.streaming.api.operators.python.embedded.EmbeddedPythonKeyedProcessOperator
- onEventTime(InternalTimer<K, VoidNamespace>) - Method in class org.apache.flink.table.runtime.operators.python.aggregate.arrow.stream.AbstractStreamArrowPythonBoundedRangeOperator
- onEventTime(InternalTimer<K, VoidNamespace>) - Method in class org.apache.flink.table.runtime.operators.python.aggregate.arrow.stream.AbstractStreamArrowPythonBoundedRowsOperator
- onEventTime(InternalTimer<K, W>) - Method in class org.apache.flink.streaming.api.operators.python.embedded.EmbeddedPythonWindowOperator
- onEventTime(InternalTimer<K, W>) - Method in class org.apache.flink.table.runtime.operators.python.aggregate.arrow.stream.StreamArrowPythonGroupWindowAggregateFunctionOperator
- onEventTime(InternalTimer<K, W>) - Method in class org.apache.flink.table.runtime.operators.python.aggregate.PythonStreamGroupWindowAggregateOperator
- onEventTime(InternalTimer<RowData, VoidNamespace>) - Method in class org.apache.flink.table.runtime.operators.python.aggregate.AbstractPythonStreamGroupAggregateOperator
-
Invoked when an event-time timer fires.
- onEventTime(InternalTimer<Row, Object>) - Method in class org.apache.flink.streaming.api.operators.python.process.ExternalPythonKeyedProcessOperator
- onEventTime(InternalTimer<Row, VoidNamespace>) - Method in class org.apache.flink.streaming.api.operators.python.process.ExternalPythonKeyedCoProcessOperator
- onProcessingTime(InternalTimer<K, VoidNamespace>) - Method in class org.apache.flink.streaming.api.operators.python.embedded.EmbeddedPythonKeyedCoProcessOperator
- onProcessingTime(InternalTimer<K, VoidNamespace>) - Method in class org.apache.flink.streaming.api.operators.python.embedded.EmbeddedPythonKeyedProcessOperator
- onProcessingTime(InternalTimer<K, VoidNamespace>) - Method in class org.apache.flink.table.runtime.operators.python.aggregate.arrow.stream.AbstractStreamArrowPythonBoundedRangeOperator
- onProcessingTime(InternalTimer<K, VoidNamespace>) - Method in class org.apache.flink.table.runtime.operators.python.aggregate.arrow.stream.AbstractStreamArrowPythonBoundedRowsOperator
- onProcessingTime(InternalTimer<K, W>) - Method in class org.apache.flink.streaming.api.operators.python.embedded.EmbeddedPythonWindowOperator
- onProcessingTime(InternalTimer<K, W>) - Method in class org.apache.flink.table.runtime.operators.python.aggregate.arrow.stream.StreamArrowPythonGroupWindowAggregateFunctionOperator
- onProcessingTime(InternalTimer<K, W>) - Method in class org.apache.flink.table.runtime.operators.python.aggregate.PythonStreamGroupWindowAggregateOperator
- onProcessingTime(InternalTimer<RowData, VoidNamespace>) - Method in class org.apache.flink.table.runtime.operators.python.aggregate.AbstractPythonStreamGroupAggregateOperator
-
Invoked when a processing-time timer fires.
- onProcessingTime(InternalTimer<Row, Object>) - Method in class org.apache.flink.streaming.api.operators.python.process.ExternalPythonKeyedProcessOperator
- onProcessingTime(InternalTimer<Row, VoidNamespace>) - Method in class org.apache.flink.streaming.api.operators.python.process.ExternalPythonKeyedCoProcessOperator
- OnReadAndWrite - org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.UpdateType
-
The same as OnCreateAndWrite but also updated on read.
- OnReadAndWrite_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.UpdateType
-
The same as OnCreateAndWrite but also updated on read.
- open() - Method in class org.apache.flink.python.env.AbstractPythonEnvironmentManager
- open() - Method in interface org.apache.flink.python.env.PythonEnvironmentManager
-
Initialize the environment manager.
- open() - Method in class org.apache.flink.streaming.api.operators.python.AbstractPythonFunctionOperator
- open() - Method in class org.apache.flink.streaming.api.operators.python.embedded.AbstractEmbeddedDataStreamPythonFunctionOperator
- open() - Method in class org.apache.flink.streaming.api.operators.python.embedded.AbstractEmbeddedPythonFunctionOperator
- open() - Method in class org.apache.flink.streaming.api.operators.python.embedded.AbstractOneInputEmbeddedPythonFunctionOperator
- open() - Method in class org.apache.flink.streaming.api.operators.python.embedded.AbstractTwoInputEmbeddedPythonFunctionOperator
- open() - Method in class org.apache.flink.streaming.api.operators.python.embedded.EmbeddedPythonCoProcessOperator
- open() - Method in class org.apache.flink.streaming.api.operators.python.embedded.EmbeddedPythonKeyedCoProcessOperator
- open() - Method in class org.apache.flink.streaming.api.operators.python.embedded.EmbeddedPythonKeyedProcessOperator
- open() - Method in class org.apache.flink.streaming.api.operators.python.embedded.EmbeddedPythonProcessOperator
- open() - Method in class org.apache.flink.streaming.api.operators.python.embedded.EmbeddedPythonWindowOperator
- open() - Method in class org.apache.flink.streaming.api.operators.python.process.AbstractExternalDataStreamPythonFunctionOperator
- open() - Method in class org.apache.flink.streaming.api.operators.python.process.AbstractExternalOneInputPythonFunctionOperator
- open() - Method in class org.apache.flink.streaming.api.operators.python.process.AbstractExternalPythonFunctionOperator
- open() - Method in class org.apache.flink.streaming.api.operators.python.process.AbstractExternalTwoInputPythonFunctionOperator
- open() - Method in class org.apache.flink.streaming.api.operators.python.process.ExternalPythonCoProcessOperator
- open() - Method in class org.apache.flink.streaming.api.operators.python.process.ExternalPythonKeyedCoProcessOperator
- open() - Method in class org.apache.flink.streaming.api.operators.python.process.ExternalPythonKeyedProcessOperator
- open() - Method in class org.apache.flink.streaming.api.operators.python.process.ExternalPythonProcessOperator
- open() - Method in class org.apache.flink.table.runtime.operators.python.AbstractEmbeddedStatelessFunctionOperator
- open() - Method in class org.apache.flink.table.runtime.operators.python.AbstractStatelessFunctionOperator
- open() - Method in class org.apache.flink.table.runtime.operators.python.aggregate.AbstractPythonStreamAggregateOperator
- open() - Method in class org.apache.flink.table.runtime.operators.python.aggregate.AbstractPythonStreamGroupAggregateOperator
- open() - Method in class org.apache.flink.table.runtime.operators.python.aggregate.arrow.AbstractArrowPythonAggregateFunctionOperator
- open() - Method in class org.apache.flink.table.runtime.operators.python.aggregate.arrow.batch.BatchArrowPythonGroupWindowAggregateFunctionOperator
- open() - Method in class org.apache.flink.table.runtime.operators.python.aggregate.arrow.batch.BatchArrowPythonOverWindowAggregateFunctionOperator
- open() - Method in class org.apache.flink.table.runtime.operators.python.aggregate.arrow.stream.AbstractStreamArrowPythonBoundedRangeOperator
- open() - Method in class org.apache.flink.table.runtime.operators.python.aggregate.arrow.stream.AbstractStreamArrowPythonBoundedRowsOperator
- open() - Method in class org.apache.flink.table.runtime.operators.python.aggregate.arrow.stream.AbstractStreamArrowPythonOverWindowAggregateFunctionOperator
- open() - Method in class org.apache.flink.table.runtime.operators.python.aggregate.arrow.stream.StreamArrowPythonGroupWindowAggregateFunctionOperator
- open() - Method in class org.apache.flink.table.runtime.operators.python.aggregate.PythonStreamGroupWindowAggregateOperator
- open() - Method in class org.apache.flink.table.runtime.operators.python.scalar.AbstractPythonScalarFunctionOperator
- open() - Method in class org.apache.flink.table.runtime.operators.python.scalar.arrow.ArrowPythonScalarFunctionOperator
- open() - Method in class org.apache.flink.table.runtime.operators.python.scalar.EmbeddedPythonScalarFunctionOperator
- open() - Method in class org.apache.flink.table.runtime.operators.python.scalar.PythonScalarFunctionOperator
- open() - Method in class org.apache.flink.table.runtime.operators.python.table.EmbeddedPythonTableFunctionOperator
- open() - Method in class org.apache.flink.table.runtime.operators.python.table.PythonTableFunctionOperator
- open(InputStream, OutputStream) - Method in class org.apache.flink.table.runtime.arrow.serializers.ArrowSerializer
- open(OpenContext) - Method in class org.apache.flink.python.util.PythonConnectorUtils.RowRowMapper
- open(OpenContext) - Method in class org.apache.flink.table.runtime.arrow.sources.ArrowSourceFunction
-
Deprecated.
- open(DeserializationSchema.InitializationContext) - Method in class org.apache.flink.formats.csv.CsvRowDeserializationSchema
- open(DeserializationSchema.InitializationContext) - Method in class org.apache.flink.formats.json.JsonRowDeserializationSchema
- open(SerializationSchema.InitializationContext) - Method in class org.apache.flink.formats.csv.CsvRowSerializationSchema
- open(SerializationSchema.InitializationContext) - Method in class org.apache.flink.formats.json.JsonRowSerializationSchema
- open(SerializationSchema.InitializationContext) - Method in class org.apache.flink.python.util.PythonConnectorUtils.SecondColumnSerializationSchema
- open(ReadableConfig) - Method in interface org.apache.flink.python.PythonFunctionRunner
-
Prepares the Python function runner, such as preparing the Python execution environment, etc.
- open(ReadableConfig) - Method in class org.apache.flink.streaming.api.runners.python.beam.BeamPythonFunctionRunner
- openPythonInterpreter() - Method in class org.apache.flink.streaming.api.operators.python.embedded.AbstractEmbeddedPythonFunctionOperator
-
Setup method for Python Interpreter.
- openPythonInterpreter() - Method in class org.apache.flink.streaming.api.operators.python.embedded.AbstractOneInputEmbeddedPythonFunctionOperator
- openPythonInterpreter() - Method in class org.apache.flink.streaming.api.operators.python.embedded.AbstractTwoInputEmbeddedPythonFunctionOperator
- openPythonInterpreter() - Method in class org.apache.flink.table.runtime.operators.python.scalar.EmbeddedPythonScalarFunctionOperator
- openPythonInterpreter() - Method in class org.apache.flink.table.runtime.operators.python.table.EmbeddedPythonTableFunctionOperator
- optimize(List<Transformation<?>>) - Static method in class org.apache.flink.python.chain.PythonOperatorChainingOptimizer
-
Perform chaining optimization.
- optimize(List<Transformation<?>>, Transformation<?>) - Static method in class org.apache.flink.python.chain.PythonOperatorChainingOptimizer
-
Perform chaining optimization.
- optionalOptions() - Method in class org.apache.flink.table.runtime.arrow.sources.ArrowTableSourceFactory
- optionalOptions() - Method in class org.apache.flink.table.utils.python.PythonDynamicTableFactory
- org.apache.beam.runners.fnexecution.control - package org.apache.beam.runners.fnexecution.control
- org.apache.beam.runners.fnexecution.state - package org.apache.beam.runners.fnexecution.state
- org.apache.beam.sdk.fn.server - package org.apache.beam.sdk.fn.server
- org.apache.beam.vendor.grpc.v1p60p1.io.grpc.internal - package org.apache.beam.vendor.grpc.v1p60p1.io.grpc.internal
- org.apache.flink.api.common.python - package org.apache.flink.api.common.python
- org.apache.flink.api.common.python.pickle - package org.apache.flink.api.common.python.pickle
- org.apache.flink.client.cli - package org.apache.flink.client.cli
- org.apache.flink.client.python - package org.apache.flink.client.python
- org.apache.flink.fnexecution.v1 - package org.apache.flink.fnexecution.v1
- org.apache.flink.formats.avro - package org.apache.flink.formats.avro
- org.apache.flink.formats.csv - package org.apache.flink.formats.csv
- org.apache.flink.formats.json - package org.apache.flink.formats.json
- org.apache.flink.python - package org.apache.flink.python
- org.apache.flink.python.chain - package org.apache.flink.python.chain
- org.apache.flink.python.env - package org.apache.flink.python.env
- org.apache.flink.python.env.embedded - package org.apache.flink.python.env.embedded
- org.apache.flink.python.env.process - package org.apache.flink.python.env.process
- org.apache.flink.python.legacy - package org.apache.flink.python.legacy
- org.apache.flink.python.metric.embedded - package org.apache.flink.python.metric.embedded
- org.apache.flink.python.metric.process - package org.apache.flink.python.metric.process
- org.apache.flink.python.util - package org.apache.flink.python.util
- org.apache.flink.streaming.api.functions.python - package org.apache.flink.streaming.api.functions.python
- org.apache.flink.streaming.api.functions.python.eventtime - package org.apache.flink.streaming.api.functions.python.eventtime
- org.apache.flink.streaming.api.operators.python - package org.apache.flink.streaming.api.operators.python
- org.apache.flink.streaming.api.operators.python.embedded - package org.apache.flink.streaming.api.operators.python.embedded
- org.apache.flink.streaming.api.operators.python.process - package org.apache.flink.streaming.api.operators.python.process
- org.apache.flink.streaming.api.operators.python.process.collector - package org.apache.flink.streaming.api.operators.python.process.collector
- org.apache.flink.streaming.api.operators.python.process.timer - package org.apache.flink.streaming.api.operators.python.process.timer
- org.apache.flink.streaming.api.runners.python.beam - package org.apache.flink.streaming.api.runners.python.beam
- org.apache.flink.streaming.api.runners.python.beam.state - package org.apache.flink.streaming.api.runners.python.beam.state
- org.apache.flink.streaming.api.transformations.python - package org.apache.flink.streaming.api.transformations.python
- org.apache.flink.streaming.api.typeinfo.python - package org.apache.flink.streaming.api.typeinfo.python
- org.apache.flink.streaming.api.utils - package org.apache.flink.streaming.api.utils
- org.apache.flink.streaming.runtime.translators.python - package org.apache.flink.streaming.runtime.translators.python
- org.apache.flink.table.executor.python - package org.apache.flink.table.executor.python
- org.apache.flink.table.runtime.arrow - package org.apache.flink.table.runtime.arrow
- org.apache.flink.table.runtime.arrow.serializers - package org.apache.flink.table.runtime.arrow.serializers
- org.apache.flink.table.runtime.arrow.sources - package org.apache.flink.table.runtime.arrow.sources
- org.apache.flink.table.runtime.arrow.vectors - package org.apache.flink.table.runtime.arrow.vectors
- org.apache.flink.table.runtime.arrow.writers - package org.apache.flink.table.runtime.arrow.writers
- org.apache.flink.table.runtime.operators.python - package org.apache.flink.table.runtime.operators.python
- org.apache.flink.table.runtime.operators.python.aggregate - package org.apache.flink.table.runtime.operators.python.aggregate
- org.apache.flink.table.runtime.operators.python.aggregate.arrow - package org.apache.flink.table.runtime.operators.python.aggregate.arrow
- org.apache.flink.table.runtime.operators.python.aggregate.arrow.batch - package org.apache.flink.table.runtime.operators.python.aggregate.arrow.batch
- org.apache.flink.table.runtime.operators.python.aggregate.arrow.stream - package org.apache.flink.table.runtime.operators.python.aggregate.arrow.stream
- org.apache.flink.table.runtime.operators.python.scalar - package org.apache.flink.table.runtime.operators.python.scalar
- org.apache.flink.table.runtime.operators.python.scalar.arrow - package org.apache.flink.table.runtime.operators.python.scalar.arrow
- org.apache.flink.table.runtime.operators.python.table - package org.apache.flink.table.runtime.operators.python.table
- org.apache.flink.table.runtime.operators.python.utils - package org.apache.flink.table.runtime.operators.python.utils
- org.apache.flink.table.runtime.runners.python.beam - package org.apache.flink.table.runtime.runners.python.beam
- org.apache.flink.table.runtime.typeutils - package org.apache.flink.table.runtime.typeutils
- org.apache.flink.table.runtime.typeutils.serializers.python - package org.apache.flink.table.runtime.typeutils.serializers.python
- org.apache.flink.table.utils.python - package org.apache.flink.table.utils.python
- OUTPUT_COLLECTION_ID - Static variable in class org.apache.flink.python.Constants
- outputCoderDescriptor - Variable in class org.apache.flink.streaming.api.runners.python.beam.BeamPythonFunctionRunner
- outputType - Variable in class org.apache.flink.table.runtime.arrow.serializers.ArrowSerializer
-
The output RowType.
- outputType - Variable in class org.apache.flink.table.runtime.operators.python.aggregate.AbstractPythonStreamAggregateOperator
-
The output logical type.
- outputTypeInfo - Variable in class org.apache.flink.streaming.api.operators.python.embedded.AbstractEmbeddedDataStreamPythonFunctionOperator
-
The TypeInformation of output data.
- OVER_WINDOW_ARROW_TYPE - org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.DataTypeCase
- OVER_WINDOW_ARROW_TYPE_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor
P
- pandasAggFunctions - Variable in class org.apache.flink.table.runtime.operators.python.aggregate.arrow.AbstractArrowPythonAggregateFunctionOperator
-
The Pandas
AggregateFunction
s to be executed. - PARAM_DELIMITER - Static variable in class org.apache.flink.python.util.PythonDependencyUtils
- parseDelimitedFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.ArrowType
- parseDelimitedFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.FlattenRowType
- parseDelimitedFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.OverWindowArrowType
- parseDelimitedFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor
- parseDelimitedFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RawType
- parseDelimitedFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RowType
- parseDelimitedFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow
- parseDelimitedFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input
- parseDelimitedFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.JobParameter
- parseDelimitedFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow
- parseDelimitedFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.BinaryInfo
- parseDelimitedFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.CharInfo
- parseDelimitedFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.DecimalInfo
- parseDelimitedFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Field
- parseDelimitedFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
- parseDelimitedFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.LocalZonedTimestampInfo
- parseDelimitedFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.MapInfo
- parseDelimitedFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema
- parseDelimitedFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimeInfo
- parseDelimitedFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimestampInfo
- parseDelimitedFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarBinaryInfo
- parseDelimitedFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarCharInfo
- parseDelimitedFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.ZonedTimestampInfo
- parseDelimitedFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor
- parseDelimitedFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategy
- parseDelimitedFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry
- parseDelimitedFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies
- parseDelimitedFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.RocksdbCompactFilterCleanupStrategy
- parseDelimitedFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig
- parseDelimitedFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.AvroTypeInfo
- parseDelimitedFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.MapTypeInfo
- parseDelimitedFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo
- parseDelimitedFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Field
- parseDelimitedFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo
- parseDelimitedFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TupleTypeInfo
- parseDelimitedFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.ListView
- parseDelimitedFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapView
- parseDelimitedFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec
- parseDelimitedFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction
- parseDelimitedFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions
- parseDelimitedFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction
- parseDelimitedFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext
- parseDelimitedFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction
- parseDelimitedFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.ArrowType
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.FlattenRowType
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.OverWindowArrowType
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RawType
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RowType
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.JobParameter
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.BinaryInfo
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.CharInfo
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.DecimalInfo
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Field
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.LocalZonedTimestampInfo
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.MapInfo
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimeInfo
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimestampInfo
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarBinaryInfo
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarCharInfo
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.ZonedTimestampInfo
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategy
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.RocksdbCompactFilterCleanupStrategy
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.AvroTypeInfo
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.MapTypeInfo
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Field
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TupleTypeInfo
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.ListView
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapView
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions
- parseFrom(byte[]) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.ArrowType
- parseFrom(byte[]) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.FlattenRowType
- parseFrom(byte[]) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.OverWindowArrowType
- parseFrom(byte[]) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor
- parseFrom(byte[]) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RawType
- parseFrom(byte[]) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RowType
- parseFrom(byte[]) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow
- parseFrom(byte[]) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input
- parseFrom(byte[]) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.JobParameter
- parseFrom(byte[]) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow
- parseFrom(byte[]) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.BinaryInfo
- parseFrom(byte[]) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.CharInfo
- parseFrom(byte[]) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.DecimalInfo
- parseFrom(byte[]) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Field
- parseFrom(byte[]) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
- parseFrom(byte[]) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.LocalZonedTimestampInfo
- parseFrom(byte[]) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.MapInfo
- parseFrom(byte[]) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema
- parseFrom(byte[]) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimeInfo
- parseFrom(byte[]) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimestampInfo
- parseFrom(byte[]) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarBinaryInfo
- parseFrom(byte[]) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarCharInfo
- parseFrom(byte[]) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.ZonedTimestampInfo
- parseFrom(byte[]) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor
- parseFrom(byte[]) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategy
- parseFrom(byte[]) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry
- parseFrom(byte[]) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies
- parseFrom(byte[]) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.RocksdbCompactFilterCleanupStrategy
- parseFrom(byte[]) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig
- parseFrom(byte[]) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.AvroTypeInfo
- parseFrom(byte[]) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.MapTypeInfo
- parseFrom(byte[]) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo
- parseFrom(byte[]) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Field
- parseFrom(byte[]) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo
- parseFrom(byte[]) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TupleTypeInfo
- parseFrom(byte[]) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.ListView
- parseFrom(byte[]) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapView
- parseFrom(byte[]) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec
- parseFrom(byte[]) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction
- parseFrom(byte[]) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions
- parseFrom(byte[]) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction
- parseFrom(byte[]) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext
- parseFrom(byte[]) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction
- parseFrom(byte[]) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.ArrowType
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.FlattenRowType
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.OverWindowArrowType
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RawType
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RowType
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.JobParameter
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.BinaryInfo
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.CharInfo
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.DecimalInfo
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Field
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.LocalZonedTimestampInfo
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.MapInfo
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimeInfo
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimestampInfo
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarBinaryInfo
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarCharInfo
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.ZonedTimestampInfo
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategy
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.RocksdbCompactFilterCleanupStrategy
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.AvroTypeInfo
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.MapTypeInfo
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Field
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TupleTypeInfo
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.ListView
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapView
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions
- parseFrom(ByteString) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.ArrowType
- parseFrom(ByteString) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.FlattenRowType
- parseFrom(ByteString) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.OverWindowArrowType
- parseFrom(ByteString) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor
- parseFrom(ByteString) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RawType
- parseFrom(ByteString) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RowType
- parseFrom(ByteString) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow
- parseFrom(ByteString) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input
- parseFrom(ByteString) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.JobParameter
- parseFrom(ByteString) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow
- parseFrom(ByteString) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.BinaryInfo
- parseFrom(ByteString) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.CharInfo
- parseFrom(ByteString) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.DecimalInfo
- parseFrom(ByteString) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Field
- parseFrom(ByteString) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
- parseFrom(ByteString) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.LocalZonedTimestampInfo
- parseFrom(ByteString) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.MapInfo
- parseFrom(ByteString) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema
- parseFrom(ByteString) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimeInfo
- parseFrom(ByteString) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimestampInfo
- parseFrom(ByteString) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarBinaryInfo
- parseFrom(ByteString) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarCharInfo
- parseFrom(ByteString) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.ZonedTimestampInfo
- parseFrom(ByteString) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor
- parseFrom(ByteString) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategy
- parseFrom(ByteString) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry
- parseFrom(ByteString) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies
- parseFrom(ByteString) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.RocksdbCompactFilterCleanupStrategy
- parseFrom(ByteString) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig
- parseFrom(ByteString) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.AvroTypeInfo
- parseFrom(ByteString) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.MapTypeInfo
- parseFrom(ByteString) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo
- parseFrom(ByteString) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Field
- parseFrom(ByteString) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo
- parseFrom(ByteString) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TupleTypeInfo
- parseFrom(ByteString) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.ListView
- parseFrom(ByteString) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapView
- parseFrom(ByteString) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec
- parseFrom(ByteString) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction
- parseFrom(ByteString) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions
- parseFrom(ByteString) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction
- parseFrom(ByteString) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext
- parseFrom(ByteString) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction
- parseFrom(ByteString) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.ArrowType
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.FlattenRowType
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.OverWindowArrowType
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RawType
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RowType
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.JobParameter
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.BinaryInfo
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.CharInfo
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.DecimalInfo
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Field
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.LocalZonedTimestampInfo
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.MapInfo
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimeInfo
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimestampInfo
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarBinaryInfo
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarCharInfo
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.ZonedTimestampInfo
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategy
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.RocksdbCompactFilterCleanupStrategy
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.AvroTypeInfo
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.MapTypeInfo
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Field
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TupleTypeInfo
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.ListView
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapView
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions
- parseFrom(CodedInputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.ArrowType
- parseFrom(CodedInputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.FlattenRowType
- parseFrom(CodedInputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.OverWindowArrowType
- parseFrom(CodedInputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor
- parseFrom(CodedInputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RawType
- parseFrom(CodedInputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RowType
- parseFrom(CodedInputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow
- parseFrom(CodedInputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input
- parseFrom(CodedInputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.JobParameter
- parseFrom(CodedInputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow
- parseFrom(CodedInputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.BinaryInfo
- parseFrom(CodedInputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.CharInfo
- parseFrom(CodedInputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.DecimalInfo
- parseFrom(CodedInputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Field
- parseFrom(CodedInputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
- parseFrom(CodedInputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.LocalZonedTimestampInfo
- parseFrom(CodedInputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.MapInfo
- parseFrom(CodedInputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema
- parseFrom(CodedInputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimeInfo
- parseFrom(CodedInputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimestampInfo
- parseFrom(CodedInputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarBinaryInfo
- parseFrom(CodedInputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarCharInfo
- parseFrom(CodedInputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.ZonedTimestampInfo
- parseFrom(CodedInputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor
- parseFrom(CodedInputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategy
- parseFrom(CodedInputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry
- parseFrom(CodedInputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies
- parseFrom(CodedInputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.RocksdbCompactFilterCleanupStrategy
- parseFrom(CodedInputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig
- parseFrom(CodedInputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.AvroTypeInfo
- parseFrom(CodedInputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.MapTypeInfo
- parseFrom(CodedInputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo
- parseFrom(CodedInputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Field
- parseFrom(CodedInputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo
- parseFrom(CodedInputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TupleTypeInfo
- parseFrom(CodedInputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.ListView
- parseFrom(CodedInputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapView
- parseFrom(CodedInputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec
- parseFrom(CodedInputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction
- parseFrom(CodedInputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions
- parseFrom(CodedInputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction
- parseFrom(CodedInputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext
- parseFrom(CodedInputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction
- parseFrom(CodedInputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.ArrowType
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.FlattenRowType
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.OverWindowArrowType
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RawType
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RowType
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.JobParameter
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.BinaryInfo
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.CharInfo
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.DecimalInfo
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Field
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.LocalZonedTimestampInfo
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.MapInfo
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimeInfo
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimestampInfo
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarBinaryInfo
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarCharInfo
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.ZonedTimestampInfo
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategy
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.RocksdbCompactFilterCleanupStrategy
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.AvroTypeInfo
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.MapTypeInfo
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Field
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TupleTypeInfo
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.ListView
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapView
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions
- parseFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.ArrowType
- parseFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.FlattenRowType
- parseFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.OverWindowArrowType
- parseFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor
- parseFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RawType
- parseFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RowType
- parseFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow
- parseFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input
- parseFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.JobParameter
- parseFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow
- parseFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.BinaryInfo
- parseFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.CharInfo
- parseFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.DecimalInfo
- parseFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Field
- parseFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
- parseFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.LocalZonedTimestampInfo
- parseFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.MapInfo
- parseFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema
- parseFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimeInfo
- parseFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimestampInfo
- parseFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarBinaryInfo
- parseFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarCharInfo
- parseFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.ZonedTimestampInfo
- parseFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor
- parseFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategy
- parseFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry
- parseFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies
- parseFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.RocksdbCompactFilterCleanupStrategy
- parseFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig
- parseFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.AvroTypeInfo
- parseFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.MapTypeInfo
- parseFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo
- parseFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Field
- parseFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo
- parseFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TupleTypeInfo
- parseFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.ListView
- parseFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapView
- parseFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec
- parseFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction
- parseFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions
- parseFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction
- parseFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext
- parseFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction
- parseFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.ArrowType
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.FlattenRowType
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.OverWindowArrowType
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RawType
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RowType
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.JobParameter
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.BinaryInfo
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.CharInfo
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.DecimalInfo
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Field
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.LocalZonedTimestampInfo
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.MapInfo
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimeInfo
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimestampInfo
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarBinaryInfo
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarCharInfo
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.ZonedTimestampInfo
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategy
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.RocksdbCompactFilterCleanupStrategy
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.AvroTypeInfo
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.MapTypeInfo
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Field
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TupleTypeInfo
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.ListView
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapView
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions
- parseFrom(ByteBuffer) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.ArrowType
- parseFrom(ByteBuffer) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.FlattenRowType
- parseFrom(ByteBuffer) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.OverWindowArrowType
- parseFrom(ByteBuffer) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor
- parseFrom(ByteBuffer) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RawType
- parseFrom(ByteBuffer) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RowType
- parseFrom(ByteBuffer) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow
- parseFrom(ByteBuffer) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input
- parseFrom(ByteBuffer) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.JobParameter
- parseFrom(ByteBuffer) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow
- parseFrom(ByteBuffer) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.BinaryInfo
- parseFrom(ByteBuffer) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.CharInfo
- parseFrom(ByteBuffer) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.DecimalInfo
- parseFrom(ByteBuffer) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Field
- parseFrom(ByteBuffer) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
- parseFrom(ByteBuffer) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.LocalZonedTimestampInfo
- parseFrom(ByteBuffer) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.MapInfo
- parseFrom(ByteBuffer) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema
- parseFrom(ByteBuffer) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimeInfo
- parseFrom(ByteBuffer) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimestampInfo
- parseFrom(ByteBuffer) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarBinaryInfo
- parseFrom(ByteBuffer) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarCharInfo
- parseFrom(ByteBuffer) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.ZonedTimestampInfo
- parseFrom(ByteBuffer) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor
- parseFrom(ByteBuffer) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategy
- parseFrom(ByteBuffer) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry
- parseFrom(ByteBuffer) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies
- parseFrom(ByteBuffer) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.RocksdbCompactFilterCleanupStrategy
- parseFrom(ByteBuffer) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig
- parseFrom(ByteBuffer) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.AvroTypeInfo
- parseFrom(ByteBuffer) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.MapTypeInfo
- parseFrom(ByteBuffer) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo
- parseFrom(ByteBuffer) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Field
- parseFrom(ByteBuffer) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo
- parseFrom(ByteBuffer) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TupleTypeInfo
- parseFrom(ByteBuffer) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.ListView
- parseFrom(ByteBuffer) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapView
- parseFrom(ByteBuffer) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec
- parseFrom(ByteBuffer) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction
- parseFrom(ByteBuffer) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions
- parseFrom(ByteBuffer) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction
- parseFrom(ByteBuffer) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext
- parseFrom(ByteBuffer) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction
- parseFrom(ByteBuffer) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.ArrowType
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.FlattenRowType
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.OverWindowArrowType
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RawType
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RowType
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.JobParameter
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.BinaryInfo
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.CharInfo
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.DecimalInfo
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Field
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.LocalZonedTimestampInfo
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.MapInfo
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimeInfo
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimestampInfo
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarBinaryInfo
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarCharInfo
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.ZonedTimestampInfo
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategy
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.RocksdbCompactFilterCleanupStrategy
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.AvroTypeInfo
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.MapTypeInfo
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Field
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TupleTypeInfo
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.ListView
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapView
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions
- parsePythonDependencyConfiguration(CommandLine) - Static method in class org.apache.flink.python.util.PythonDependencyUtils
- parser() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.ArrowType
- parser() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.FlattenRowType
- parser() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.OverWindowArrowType
- parser() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor
- parser() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RawType
- parser() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RowType
- parser() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow
- parser() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input
- parser() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.JobParameter
- parser() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow
- parser() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.BinaryInfo
- parser() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.CharInfo
- parser() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.DecimalInfo
- parser() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Field
- parser() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
- parser() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.LocalZonedTimestampInfo
- parser() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.MapInfo
- parser() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema
- parser() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimeInfo
- parser() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimestampInfo
- parser() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarBinaryInfo
- parser() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarCharInfo
- parser() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.ZonedTimestampInfo
- parser() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor
- parser() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategy
- parser() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry
- parser() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies
- parser() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.RocksdbCompactFilterCleanupStrategy
- parser() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig
- parser() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.AvroTypeInfo
- parser() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.MapTypeInfo
- parser() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo
- parser() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Field
- parser() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo
- parser() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TupleTypeInfo
- parser() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.ListView
- parser() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapView
- parser() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec
- parser() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction
- parser() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions
- parser() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction
- parser() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext
- parser() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction
- parser() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions
- parseStateTtlConfigFromProto(FlinkFnApi.StateDescriptor.StateTTLConfig) - Static method in enum org.apache.flink.python.util.ProtoUtils
- partition(Integer, int) - Method in class org.apache.flink.python.legacy.IdPartitioner
- PartitionCustomKeySelector - Class in org.apache.flink.streaming.api.functions.python
-
The
PartitionCustomKeySelector
will return the first field of the input row value. - PartitionCustomKeySelector() - Constructor for class org.apache.flink.streaming.api.functions.python.PartitionCustomKeySelector
- PAYLOAD_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction
- PAYLOAD_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction
- PAYLOAD_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction
- PICKLED_BYTE_ARRAY_TYPE_INFO - Static variable in class org.apache.flink.streaming.api.typeinfo.python.PickledByteArrayTypeInfo
- PICKLED_BYTES - org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TypeName
-
PICKLED_BYTES = 20;
- PICKLED_BYTES_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TypeName
-
PICKLED_BYTES = 20;
- PickledByteArrayTypeInfo - Class in org.apache.flink.streaming.api.typeinfo.python
-
A PickledByteArrayTypeInfo indicates that the data of this type is a generated primitive byte array by pickle.
- PickledByteArrayTypeInfo() - Constructor for class org.apache.flink.streaming.api.typeinfo.python.PickledByteArrayTypeInfo
- pickleValue(Object, byte) - Static method in class org.apache.flink.api.common.python.PythonBridgeUtils
- ping() - Method in interface org.apache.flink.client.python.PythonGatewayServer.Watchdog
- pipInstallRequirements(String, String, String, String, Map<String, String>) - Static method in class org.apache.flink.python.util.PythonEnvironmentManagerUtils
-
Installs the 3rd party libraries listed in the user-provided requirements file.
- pollResult() - Method in interface org.apache.flink.python.PythonFunctionRunner
-
Retrieves the Python function result.
- pollResult() - Method in class org.apache.flink.streaming.api.runners.python.beam.BeamPythonFunctionRunner
- precision - Variable in class org.apache.flink.table.runtime.arrow.writers.DecimalWriter
- precision - Variable in class org.apache.flink.table.runtime.arrow.writers.TimestampWriter
- PRECISION_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.DecimalInfo
- PRECISION_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.LocalZonedTimestampInfo
- PRECISION_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimeInfo
- PRECISION_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimestampInfo
- PRECISION_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.ZonedTimestampInfo
- prepareSnapshotPreBarrier(long) - Method in class org.apache.flink.streaming.api.operators.python.AbstractPythonFunctionOperator
- PRIMITIVE_ARRAY - org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TypeName
-
PRIMITIVE_ARRAY = 16;
- PRIMITIVE_ARRAY_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TypeName
-
PRIMITIVE_ARRAY = 16;
- PROC_TIME_ATTRIBUTE - org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.WindowProperty
-
PROC_TIME_ATTRIBUTE = 3;
- PROC_TIME_ATTRIBUTE_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.WindowProperty
-
PROC_TIME_ATTRIBUTE = 3;
- process(byte[]) - Method in interface org.apache.flink.python.PythonFunctionRunner
-
Executes the Python function with the input byte array.
- process(byte[]) - Method in class org.apache.flink.streaming.api.runners.python.beam.BeamPythonFunctionRunner
- PROCESS - org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.FunctionType
-
PROCESS = 0;
- PROCESS_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.FunctionType
-
PROCESS = 0;
- processElement(boolean, long, long, Object) - Method in class org.apache.flink.streaming.api.operators.python.process.AbstractExternalTwoInputPythonFunctionOperator
- processElement(long, long, Object) - Method in class org.apache.flink.streaming.api.operators.python.process.AbstractExternalOneInputPythonFunctionOperator
- processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.api.operators.python.embedded.AbstractOneInputEmbeddedPythonFunctionOperator
- processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.api.operators.python.process.ExternalPythonProcessOperator
- processElement(StreamRecord<IN>) - Method in class org.apache.flink.table.runtime.operators.python.AbstractStatelessFunctionOperator
- processElement(StreamRecord<RowData>) - Method in class org.apache.flink.table.runtime.operators.python.aggregate.AbstractPythonStreamAggregateOperator
- processElement(StreamRecord<RowData>) - Method in class org.apache.flink.table.runtime.operators.python.aggregate.arrow.AbstractArrowPythonAggregateFunctionOperator
- processElement(StreamRecord<RowData>) - Method in class org.apache.flink.table.runtime.operators.python.scalar.EmbeddedPythonScalarFunctionOperator
- processElement(StreamRecord<RowData>) - Method in class org.apache.flink.table.runtime.operators.python.table.EmbeddedPythonTableFunctionOperator
- processElement(StreamRecord<Row>) - Method in class org.apache.flink.streaming.api.operators.python.process.ExternalPythonKeyedProcessOperator
- processElement(Row, ProcessFunction.Context, Collector<RowData>) - Method in class org.apache.flink.python.util.PythonConnectorUtils.RowRowMapper
- processElement1(StreamRecord<IN1>) - Method in class org.apache.flink.streaming.api.operators.python.embedded.AbstractTwoInputEmbeddedPythonFunctionOperator
- processElement1(StreamRecord<IN1>) - Method in class org.apache.flink.streaming.api.operators.python.embedded.EmbeddedPythonBatchCoBroadcastProcessOperator
- processElement1(StreamRecord<IN1>) - Method in class org.apache.flink.streaming.api.operators.python.embedded.EmbeddedPythonBatchKeyedCoBroadcastProcessOperator
- processElement1(StreamRecord<IN1>) - Method in class org.apache.flink.streaming.api.operators.python.process.ExternalPythonBatchCoBroadcastProcessOperator
- processElement1(StreamRecord<IN1>) - Method in class org.apache.flink.streaming.api.operators.python.process.ExternalPythonCoProcessOperator
- processElement1(StreamRecord<Row>) - Method in class org.apache.flink.streaming.api.operators.python.process.ExternalPythonBatchKeyedCoBroadcastProcessOperator
- processElement1(StreamRecord<Row>) - Method in class org.apache.flink.streaming.api.operators.python.process.ExternalPythonKeyedCoProcessOperator
- processElement2(StreamRecord<IN2>) - Method in class org.apache.flink.streaming.api.operators.python.embedded.AbstractTwoInputEmbeddedPythonFunctionOperator
- processElement2(StreamRecord<IN2>) - Method in class org.apache.flink.streaming.api.operators.python.process.ExternalPythonCoProcessOperator
- processElement2(StreamRecord<Row>) - Method in class org.apache.flink.streaming.api.operators.python.process.ExternalPythonKeyedCoProcessOperator
- processElementInternal(IN) - Method in class org.apache.flink.table.runtime.operators.python.AbstractStatelessFunctionOperator
- processElementInternal(RowData) - Method in class org.apache.flink.table.runtime.operators.python.aggregate.AbstractPythonStreamAggregateOperator
- processElementInternal(RowData) - Method in class org.apache.flink.table.runtime.operators.python.aggregate.AbstractPythonStreamGroupAggregateOperator
- processElementInternal(RowData) - Method in class org.apache.flink.table.runtime.operators.python.aggregate.arrow.batch.BatchArrowPythonGroupAggregateFunctionOperator
- processElementInternal(RowData) - Method in class org.apache.flink.table.runtime.operators.python.aggregate.arrow.batch.BatchArrowPythonGroupWindowAggregateFunctionOperator
- processElementInternal(RowData) - Method in class org.apache.flink.table.runtime.operators.python.aggregate.arrow.batch.BatchArrowPythonOverWindowAggregateFunctionOperator
- processElementInternal(RowData) - Method in class org.apache.flink.table.runtime.operators.python.aggregate.arrow.stream.AbstractStreamArrowPythonOverWindowAggregateFunctionOperator
- processElementInternal(RowData) - Method in class org.apache.flink.table.runtime.operators.python.aggregate.arrow.stream.StreamArrowPythonGroupWindowAggregateFunctionOperator
- processElementInternal(RowData) - Method in class org.apache.flink.table.runtime.operators.python.aggregate.arrow.stream.StreamArrowPythonProcTimeBoundedRowsOperator
- processElementInternal(RowData) - Method in class org.apache.flink.table.runtime.operators.python.aggregate.PythonStreamGroupWindowAggregateOperator
- processElementInternal(RowData) - Method in class org.apache.flink.table.runtime.operators.python.scalar.arrow.ArrowPythonScalarFunctionOperator
- processElementInternal(RowData) - Method in class org.apache.flink.table.runtime.operators.python.scalar.PythonScalarFunctionOperator
- processElementInternal(RowData) - Method in class org.apache.flink.table.runtime.operators.python.table.PythonTableFunctionOperator
- ProcessingTime - org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.TtlTimeCharacteristic
-
Processing time
- ProcessingTime_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.TtlTimeCharacteristic
-
Processing time
- ProcessPythonEnvironment - Class in org.apache.flink.python.env.process
-
A
PythonEnvironment
for executing UDFs in Process. - ProcessPythonEnvironment(String, Map<String, String>) - Constructor for class org.apache.flink.python.env.process.ProcessPythonEnvironment
- ProcessPythonEnvironmentManager - Class in org.apache.flink.python.env.process
-
The ProcessPythonEnvironmentManager is used to prepare the working dir of python UDF worker and create ProcessPythonEnvironment object of Beam Fn API.
- ProcessPythonEnvironmentManager(PythonDependencyInfo, String[], Map<String, String>, JobID) - Constructor for class org.apache.flink.python.env.process.ProcessPythonEnvironmentManager
- processTimer(byte[]) - Method in interface org.apache.flink.python.PythonFunctionRunner
-
Send the triggered timer to the Python function.
- processTimer(byte[]) - Method in class org.apache.flink.streaming.api.runners.python.beam.BeamPythonFunctionRunner
- processTimer(byte[]) - Method in class org.apache.flink.table.runtime.runners.python.beam.BeamTablePythonFunctionRunner
- processWatermark(Watermark) - Method in class org.apache.flink.streaming.api.operators.python.AbstractPythonFunctionOperator
- processWatermark(Watermark) - Method in class org.apache.flink.streaming.api.operators.python.embedded.EmbeddedPythonCoProcessOperator
- processWatermark(Watermark) - Method in class org.apache.flink.streaming.api.operators.python.embedded.EmbeddedPythonProcessOperator
- processWatermark(Watermark) - Method in class org.apache.flink.streaming.api.operators.python.process.ExternalPythonCoProcessOperator
- processWatermark(Watermark) - Method in class org.apache.flink.streaming.api.operators.python.process.ExternalPythonProcessOperator
- PROFILE_ENABLED_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions
- PROFILE_ENABLED_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction
- PROFILE_ENABLED_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions
- ProtoUtils - Enum in org.apache.flink.python.util
-
Utilities used to construct protobuf objects or construct objects from protobuf objects.
- put(Object, Object) - Method in class org.apache.flink.python.util.HashMapWrapper
- PYFLINK_GATEWAY_DISABLED - Static variable in class org.apache.flink.python.env.AbstractPythonEnvironmentManager
- PYFLINK_UDF_RUNNER_DIR - Static variable in class org.apache.flink.python.util.PythonEnvironmentManagerUtils
- PYTHON_ARCHIVES - Static variable in class org.apache.flink.python.PythonOptions
- PYTHON_ARCHIVES_DIR - Static variable in class org.apache.flink.python.env.AbstractPythonEnvironmentManager
- PYTHON_ARCHIVES_DISTRIBUTED_CACHE_INFO - Static variable in class org.apache.flink.python.PythonOptions
- PYTHON_CLIENT_EXECUTABLE - Static variable in class org.apache.flink.python.PythonOptions
- PYTHON_EXECUTABLE - Static variable in class org.apache.flink.python.PythonOptions
- PYTHON_EXECUTION_MODE - Static variable in class org.apache.flink.python.PythonOptions
-
Specify the python runtime execution mode.
- PYTHON_FILES - Static variable in class org.apache.flink.python.PythonOptions
- PYTHON_FILES_DIR - Static variable in class org.apache.flink.python.env.AbstractPythonEnvironmentManager
- PYTHON_FILES_DISTRIBUTED_CACHE_INFO - Static variable in class org.apache.flink.python.PythonOptions
- PYTHON_FUNCTION_FACTORY_CACHE - Static variable in interface org.apache.flink.client.python.PythonFunctionFactory
- PYTHON_JOB_OPTIONS - Static variable in class org.apache.flink.python.PythonOptions
- PYTHON_LOOPBACK_SERVER_ADDRESS - Static variable in class org.apache.flink.python.PythonOptions
- PYTHON_METRIC_ENABLED - Static variable in class org.apache.flink.python.PythonOptions
-
The configuration to enable or disable metric for Python execution.
- PYTHON_OPERATOR_CHAINING_ENABLED - Static variable in class org.apache.flink.python.PythonOptions
-
The configuration to enable or disable python operator chaining.
- PYTHON_PATH - Static variable in class org.apache.flink.python.PythonOptions
-
The configuration allows user to define python path for client and workers.
- PYTHON_PROFILE_ENABLED - Static variable in class org.apache.flink.python.PythonOptions
-
The configuration to enable or disable profile for Python execution.
- PYTHON_REQUIREMENTS - Static variable in class org.apache.flink.python.PythonOptions
- PYTHON_REQUIREMENTS_CACHE - Static variable in class org.apache.flink.python.env.AbstractPythonEnvironmentManager
- PYTHON_REQUIREMENTS_DIR - Static variable in class org.apache.flink.python.env.AbstractPythonEnvironmentManager
- PYTHON_REQUIREMENTS_FILE - Static variable in class org.apache.flink.python.env.AbstractPythonEnvironmentManager
- PYTHON_REQUIREMENTS_FILE_DISTRIBUTED_CACHE_INFO - Static variable in class org.apache.flink.python.PythonOptions
- PYTHON_REQUIREMENTS_INSTALL_DIR - Static variable in class org.apache.flink.python.env.AbstractPythonEnvironmentManager
- PYTHON_STATE_PREFIX - Static variable in interface org.apache.flink.streaming.api.runners.python.beam.state.BeamStateStore
- PYTHON_SYSTEMENV_ENABLED - Static variable in class org.apache.flink.python.PythonOptions
-
The configuration to enable or disable system env for Python execution.
- PYTHON_WORKING_DIR - Static variable in class org.apache.flink.python.env.AbstractPythonEnvironmentManager
- PythonBridgeUtils - Class in org.apache.flink.api.common.python
-
Utility class that contains helper methods to create a TableSource from a file which contains Python objects.
- PythonBridgeUtils() - Constructor for class org.apache.flink.api.common.python.PythonBridgeUtils
- PythonBroadcastStateTransformation<IN1,IN2,OUT> - Class in org.apache.flink.streaming.api.transformations.python
-
A
Transformation
representing a Python Co-Broadcast-Process operation, which will be translated into different operations byPythonBroadcastStateTransformationTranslator
. - PythonBroadcastStateTransformation(String, Configuration, DataStreamPythonFunctionInfo, Transformation<IN1>, Transformation<IN2>, List<MapStateDescriptor<?, ?>>, TypeInformation<OUT>, int) - Constructor for class org.apache.flink.streaming.api.transformations.python.PythonBroadcastStateTransformation
- PythonBroadcastStateTransformationTranslator<IN1,IN2,OUT> - Class in org.apache.flink.streaming.runtime.translators.python
-
A
TransformationTranslator
that translatesPythonBroadcastStateTransformation
intoExternalPythonCoProcessOperator
/EmbeddedPythonCoProcessOperator
in streaming mode orExternalPythonBatchCoBroadcastProcessOperator
/EmbeddedPythonBatchCoBroadcastProcessOperator
in batch mode. - PythonBroadcastStateTransformationTranslator() - Constructor for class org.apache.flink.streaming.runtime.translators.python.PythonBroadcastStateTransformationTranslator
- PythonConfig - Class in org.apache.flink.python
-
Configurations for the Python job which are used at run time.
- PythonConfig(ReadableConfig, ReadableConfig) - Constructor for class org.apache.flink.python.PythonConfig
- PythonConfigUtil - Class in org.apache.flink.python.util
-
A Util class to handle the configurations of Python jobs.
- PythonConfigUtil() - Constructor for class org.apache.flink.python.util.PythonConfigUtil
- PythonConnectorUtils - Class in org.apache.flink.python.util
-
Utility class for using DataStream connectors in Python.
- PythonConnectorUtils() - Constructor for class org.apache.flink.python.util.PythonConnectorUtils
- PythonConnectorUtils.FirstColumnTopicSelectorInvocationHandler - Class in org.apache.flink.python.util
-
The serializable
InvocationHandler
as the proxy for first column selector. - PythonConnectorUtils.RowRowMapper - Class in org.apache.flink.python.util
-
A
ProcessFunction
that convertRow
toRowData
. - PythonConnectorUtils.SecondColumnSerializationSchema<T> - Class in org.apache.flink.python.util
-
A
SerializationSchema
forRow
that only serialize the second column using a wrappedSerializationSchema
forPythonConnectorUtils.SecondColumnSerializationSchema
. - PythonCsvUtils - Class in org.apache.flink.formats.csv
-
Utilities for using CSV format in PyFlink.
- PythonCsvUtils() - Constructor for class org.apache.flink.formats.csv.PythonCsvUtils
- PythonDependencyInfo - Class in org.apache.flink.python.env
-
PythonDependencyInfo contains the information of third-party dependencies.
- PythonDependencyInfo(Map<String, String>, String, String, Map<String, String>, String) - Constructor for class org.apache.flink.python.env.PythonDependencyInfo
- PythonDependencyInfo(Map<String, String>, String, String, Map<String, String>, String, String, String) - Constructor for class org.apache.flink.python.env.PythonDependencyInfo
- PythonDependencyUtils - Class in org.apache.flink.python.util
-
Utility class for Python dependency management.
- PythonDependencyUtils() - Constructor for class org.apache.flink.python.util.PythonDependencyUtils
- PythonDriver - Class in org.apache.flink.client.python
-
A main class used to launch Python applications.
- PythonDriver() - Constructor for class org.apache.flink.client.python.PythonDriver
- PythonDynamicTableFactory - Class in org.apache.flink.table.utils.python
-
Table source factory for PythonDynamicTableSource.
- PythonDynamicTableFactory() - Constructor for class org.apache.flink.table.utils.python.PythonDynamicTableFactory
- PythonDynamicTableOptions - Class in org.apache.flink.table.utils.python
-
Options for PythonDynamicTableSource.
- PythonDynamicTableOptions() - Constructor for class org.apache.flink.table.utils.python.PythonDynamicTableOptions
- PythonDynamicTableSource - Class in org.apache.flink.table.utils.python
-
Implementation of
ScanTableSource
for python elements table. - PythonDynamicTableSource(String, boolean, DataType) - Constructor for class org.apache.flink.table.utils.python.PythonDynamicTableSource
- PythonEnvironment - Interface in org.apache.flink.python.env
-
The base interface of python environment for executing UDFs.
- PythonEnvironmentManager - Interface in org.apache.flink.python.env
-
The base interface of python environment manager which is used to create the PythonEnvironment object used to execute Python functions.
- PythonEnvironmentManagerUtils - Class in org.apache.flink.python.util
-
Utils used to prepare the python environment.
- PythonEnvironmentManagerUtils() - Constructor for class org.apache.flink.python.util.PythonEnvironmentManagerUtils
- PythonFunctionFactory - Interface in org.apache.flink.client.python
-
The factory which creates the PythonFunction objects from given module name and object name.
- PythonFunctionFactory.CacheKey - Class in org.apache.flink.client.python
-
The cache key.
- PythonFunctionFactoryImpl - Class in org.apache.flink.client.python
-
Default implementation of PythonFunctionFactory.
- PythonFunctionFactoryImpl(PythonFunctionFactory, PythonEnvUtils.PythonProcessShutdownHook) - Constructor for class org.apache.flink.client.python.PythonFunctionFactoryImpl
- pythonFunctionRunner - Variable in class org.apache.flink.streaming.api.operators.python.process.AbstractExternalPythonFunctionOperator
-
The
PythonFunctionRunner
which is responsible for Python user-defined function execution. - PythonFunctionRunner - Interface in org.apache.flink.python
-
The base interface of runner which is responsible for the execution of Python functions.
- PythonGatewayServer - Class in org.apache.flink.client.python
-
The Py4j Gateway Server provides RPC service for user's python process.
- PythonGatewayServer() - Constructor for class org.apache.flink.client.python.PythonGatewayServer
- PythonGatewayServer.Watchdog - Interface in org.apache.flink.client.python
-
A simple watch dog interface.
- PythonKeyedBroadcastStateTransformation<OUT> - Class in org.apache.flink.streaming.api.transformations.python
-
A
Transformation
representing a Python Keyed-Co-Broadcast-Process operation, which will be translated into different operations byPythonKeyedBroadcastStateTransformationTranslator
. - PythonKeyedBroadcastStateTransformation(String, Configuration, DataStreamPythonFunctionInfo, Transformation<Row>, Transformation<Row>, List<MapStateDescriptor<?, ?>>, TypeInformation<Row>, KeySelector<Row, Row>, TypeInformation<OUT>, int) - Constructor for class org.apache.flink.streaming.api.transformations.python.PythonKeyedBroadcastStateTransformation
- PythonKeyedBroadcastStateTransformationTranslator<OUT> - Class in org.apache.flink.streaming.runtime.translators.python
-
A
TransformationTranslator
that translatesPythonKeyedBroadcastStateTransformation
intoExternalPythonKeyedCoProcessOperator
/EmbeddedPythonKeyedCoProcessOperator
in streaming mode orExternalPythonBatchKeyedCoBroadcastProcessOperator
/EmbeddedPythonBatchKeyedCoBroadcastProcessOperator
in batch mode. - PythonKeyedBroadcastStateTransformationTranslator() - Constructor for class org.apache.flink.streaming.runtime.translators.python.PythonKeyedBroadcastStateTransformationTranslator
- PythonOperatorChainingOptimizer - Class in org.apache.flink.python.chain
-
A util class which attempts to chain all available Python functions.
- PythonOperatorChainingOptimizer() - Constructor for class org.apache.flink.python.chain.PythonOperatorChainingOptimizer
- PythonOperatorUtils - Class in org.apache.flink.streaming.api.utils
-
Utilities used by Python operators.
- PythonOperatorUtils() - Constructor for class org.apache.flink.streaming.api.utils.PythonOperatorUtils
- PythonOptions - Class in org.apache.flink.python
-
Configuration options for the Python API.
- PythonOptions() - Constructor for class org.apache.flink.python.PythonOptions
- PythonProgramOptions - Class in org.apache.flink.client.cli
-
The class for command line options that refer to a Python program or JAR program with Python command line options.
- PythonProgramOptions(CommandLine) - Constructor for class org.apache.flink.client.cli.PythonProgramOptions
- PythonScalarFunctionOperator - Class in org.apache.flink.table.runtime.operators.python.scalar
-
The Python
ScalarFunction
operator. - PythonScalarFunctionOperator(Configuration, PythonFunctionInfo[], RowType, RowType, RowType, GeneratedProjection, GeneratedProjection) - Constructor for class org.apache.flink.table.runtime.operators.python.scalar.PythonScalarFunctionOperator
- PythonSharedResources - Class in org.apache.flink.streaming.api.runners.python.beam
-
The set of resources that can be shared by all the Python operators in a slot.
- PythonShellParser - Class in org.apache.flink.client.python
-
Command line parser for Python shell.
- PythonShellParser() - Constructor for class org.apache.flink.client.python.PythonShellParser
- PythonStreamGroupAggregateOperator - Class in org.apache.flink.table.runtime.operators.python.aggregate
-
The Python AggregateFunction operator.
- PythonStreamGroupAggregateOperator(Configuration, RowType, RowType, PythonAggregateFunctionInfo[], DataViewSpec[][], int[], int, boolean, boolean, long, long) - Constructor for class org.apache.flink.table.runtime.operators.python.aggregate.PythonStreamGroupAggregateOperator
- PythonStreamGroupTableAggregateOperator - Class in org.apache.flink.table.runtime.operators.python.aggregate
-
The Python TableAggregateFunction operator.
- PythonStreamGroupTableAggregateOperator(Configuration, RowType, RowType, PythonAggregateFunctionInfo[], DataViewSpec[][], int[], int, boolean, long, long) - Constructor for class org.apache.flink.table.runtime.operators.python.aggregate.PythonStreamGroupTableAggregateOperator
- PythonStreamGroupWindowAggregateOperator<K,W extends org.apache.flink.table.runtime.operators.window.Window> - Class in org.apache.flink.table.runtime.operators.python.aggregate
-
The Python Group Window AggregateFunction operator.
- PythonStreamGroupWindowAggregateOperator(Configuration, RowType, RowType, PythonAggregateFunctionInfo[], DataViewSpec[][], int[], int, boolean, boolean, int, GroupWindowAssigner<W>, FlinkFnApi.GroupWindow.WindowType, boolean, boolean, long, long, long, long, NamedWindowProperty[], ZoneId) - Constructor for class org.apache.flink.table.runtime.operators.python.aggregate.PythonStreamGroupWindowAggregateOperator
- PythonTableFunctionOperator - Class in org.apache.flink.table.runtime.operators.python.table
-
The Python
TableFunction
operator. - PythonTableFunctionOperator(Configuration, PythonFunctionInfo, RowType, RowType, RowType, FlinkJoinType, GeneratedProjection) - Constructor for class org.apache.flink.table.runtime.operators.python.table.PythonTableFunctionOperator
- PythonTableUtils - Class in org.apache.flink.table.utils.python
-
Python utilities.
- PythonTypeUtils - Class in org.apache.flink.streaming.api.utils
-
A util class for converting the given TypeInformation to other objects.
- PythonTypeUtils - Class in org.apache.flink.table.runtime.typeutils
-
Utilities for converting Flink logical types, such as convert it to the related TypeSerializer or ProtoType.
- PythonTypeUtils() - Constructor for class org.apache.flink.streaming.api.utils.PythonTypeUtils
- PythonTypeUtils() - Constructor for class org.apache.flink.table.runtime.typeutils.PythonTypeUtils
- PythonTypeUtils.ArrayDataConverter<T> - Class in org.apache.flink.streaming.api.utils
-
The element in the Object Array will be converted to the corresponding Data through element DataConverter.
- PythonTypeUtils.ArrayDataConverter<T> - Class in org.apache.flink.table.runtime.typeutils
-
The element in the Object Array will be converted to the corresponding Data through element DataConverter.
- PythonTypeUtils.ByteDataConverter - Class in org.apache.flink.streaming.api.utils
-
Python Long will be converted to Long in PemJa, so we need ByteDataConverter to convert Java Long to internal Byte.
- PythonTypeUtils.ByteDataConverter - Class in org.apache.flink.table.runtime.typeutils
-
Python Long will be converted to Long in PemJa, so we need ByteDataConverter to convert Java Long to internal Byte.
- PythonTypeUtils.DataConverter<IN,OUT> - Class in org.apache.flink.streaming.api.utils
-
Data Converter that converts the data to the format data which can be used in PemJa.
- PythonTypeUtils.DataConverter<IN,INTER,OUT> - Class in org.apache.flink.table.runtime.typeutils
-
Data Converter that converts the data to the java format data which can be used in PemJa.
- PythonTypeUtils.FloatDataConverter - Class in org.apache.flink.streaming.api.utils
-
Python Float will be converted to Double in PemJa, so we need FloatDataConverter to convert Java Double to internal Float.
- PythonTypeUtils.FloatDataConverter - Class in org.apache.flink.table.runtime.typeutils
-
Python Float will be converted to Double in PemJa, so we need FloatDataConverter to convert Java Double to internal Float.
- PythonTypeUtils.IdentityDataConverter<T> - Class in org.apache.flink.streaming.api.utils
-
Identity data converter.
- PythonTypeUtils.IdentityDataConverter<IN,OUT> - Class in org.apache.flink.table.runtime.typeutils
-
Identity data converter.
- PythonTypeUtils.IntDataConverter - Class in org.apache.flink.streaming.api.utils
-
Python Long will be converted to Long in PemJa, so we need IntDataConverter to convert Java Long to internal Integer.
- PythonTypeUtils.IntDataConverter - Class in org.apache.flink.table.runtime.typeutils
-
Python Long will be converted to Long in PemJa, so we need IntDataConverter to convert Java Long to internal Integer.
- PythonTypeUtils.ListDataConverter - Class in org.apache.flink.streaming.api.utils
-
The element in the List will be converted to the corresponding Data through element DataConverter.
- PythonTypeUtils.LogicalTypeToProtoTypeConverter - Class in org.apache.flink.table.runtime.typeutils
-
Converter That convert the logicalType to the related Prototype.
- PythonTypeUtils.MapDataConverter - Class in org.apache.flink.streaming.api.utils
-
The key/value in the Map will be converted to the corresponding Data through key/value DataConverter.
- PythonTypeUtils.MapDataConverter - Class in org.apache.flink.table.runtime.typeutils
-
The key/value in the Map will be converted to the corresponding Data through key/value DataConverter.
- PythonTypeUtils.RowDataConverter - Class in org.apache.flink.streaming.api.utils
-
Row Data will be converted to the Object Array [RowKind(as Long Object), Field Values(as Object Array)].
- PythonTypeUtils.RowDataConverter - Class in org.apache.flink.table.runtime.typeutils
-
RowData will be converted to the Object Array [RowKind(as Long Object), Field Values(as Object Array)].
- PythonTypeUtils.RowDataDataConverter - Class in org.apache.flink.streaming.api.utils
-
RowData Data will be converted to the Object Array [RowKind(as Long Object), Field Values(as Object Array)].
- PythonTypeUtils.ShortDataConverter - Class in org.apache.flink.streaming.api.utils
-
Python Long will be converted to Long in PemJa, so we need ShortDataConverter to convert Java Long to internal Short.
- PythonTypeUtils.ShortDataConverter - Class in org.apache.flink.table.runtime.typeutils
-
Python Long will be converted to Long in PemJa, so we need ShortDataConverter to convert Java Long to internal Short.
- PythonTypeUtils.TimeDataConverter - Class in org.apache.flink.table.runtime.typeutils
-
Python datetime.time will be converted to Time in PemJa, so we need TimeDataConverter to convert Java Double to internal Integer.
- PythonTypeUtils.TupleDataConverter - Class in org.apache.flink.streaming.api.utils
-
Tuple Data will be converted to the Object Array.
- PythonTypeUtils.TypeInfoToDataConverter - Class in org.apache.flink.streaming.api.utils
-
Get DataConverter according to the given typeInformation.
- PythonTypeUtils.TypeInfoToProtoConverter - Class in org.apache.flink.streaming.api.utils
-
Get coder proto according to the given type information.
- PythonTypeUtils.TypeInfoToSerializerConverter - Class in org.apache.flink.streaming.api.utils
-
Get serializers according to the given typeInformation.
Q
- QUERY_TIME_AFTER_NUM_ENTRIES_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.RocksdbCompactFilterCleanupStrategy
R
- RANGE_SLIDING - org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow.WindowType
-
RANGE_SLIDING = 3;
- RANGE_SLIDING_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow.WindowType
-
RANGE_SLIDING = 3;
- RANGE_UNBOUNDED - org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow.WindowType
-
RANGE_UNBOUNDED = 0;
- RANGE_UNBOUNDED_FOLLOWING - org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow.WindowType
-
RANGE_UNBOUNDED_FOLLOWING = 2;
- RANGE_UNBOUNDED_FOLLOWING_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow.WindowType
-
RANGE_UNBOUNDED_FOLLOWING = 2;
- RANGE_UNBOUNDED_PRECEDING - org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow.WindowType
-
RANGE_UNBOUNDED_PRECEDING = 1;
- RANGE_UNBOUNDED_PRECEDING_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow.WindowType
-
RANGE_UNBOUNDED_PRECEDING = 1;
- RANGE_UNBOUNDED_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow.WindowType
-
RANGE_UNBOUNDED = 0;
- RAW_TYPE - org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.DataTypeCase
- RAW_TYPE_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor
- read(int) - Method in class org.apache.flink.table.runtime.arrow.ArrowReader
-
Read the specified row from underlying Arrow format data.
- read(int) - Method in class org.apache.flink.table.runtime.arrow.serializers.ArrowSerializer
- readArrowBatches(String) - Static method in class org.apache.flink.table.runtime.arrow.ArrowUtils
- readArrowBatches(ReadableByteChannel) - Static method in class org.apache.flink.table.runtime.arrow.ArrowUtils
- readPickledBytes(String) - Static method in class org.apache.flink.api.common.python.PythonBridgeUtils
- readPythonObjects(String) - Static method in class org.apache.flink.api.common.python.PythonBridgeUtils
- readPythonObjects(String, boolean) - Static method in class org.apache.flink.api.common.python.PythonBridgeUtils
- readSnapshot(int, DataInputView, ClassLoader) - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.ArrayDataSerializer.ArrayDataSerializerSnapshot
- readSnapshot(int, DataInputView, ClassLoader) - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.DecimalDataSerializer.DecimalSerializerSnapshot
- readSnapshot(int, DataInputView, ClassLoader) - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.MapDataSerializer.BaseMapSerializerSnapshot
- readSnapshot(int, DataInputView, ClassLoader) - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.RowDataSerializer.RowDataSerializerSnapshot
- readSnapshot(int, DataInputView, ClassLoader) - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.TimestampSerializer.TimestampSerializerSnapshot
- registerAllExtensions(ExtensionRegistry) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi
- registerAllExtensions(ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi
- registerForProcessBundleInstructionId(String, StateRequestHandler) - Method in class org.apache.beam.runners.fnexecution.state.GrpcStateService
- registerPythonBroadcastTransformationTranslator() - Static method in class org.apache.flink.python.util.PythonConfigUtil
- registerTimer() - Method in class org.apache.flink.streaming.api.operators.python.process.timer.TimerRegistrationAction
- release(SharedResourceHolder.Resource<T>, T) - Static method in class org.apache.beam.vendor.grpc.v1p60p1.io.grpc.internal.SharedResourceHolder
-
Releases an instance of the given resource.
- removeFields(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Builder
-
repeated .org.apache.flink.fn_execution.v1.Schema.Field fields = 1;
- removeFields(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Builder
-
repeated .org.apache.flink.fn_execution.v1.TypeInfo.RowTypeInfo.Field fields = 1;
- removeFieldTypes(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TupleTypeInfo.Builder
-
repeated .org.apache.flink.fn_execution.v1.TypeInfo field_types = 1;
- removeInputs(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.Builder
-
The input arguments of the user-defined function, it could be one of the following: 1.
- removeInputs(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction.Builder
-
The input arguments of the user-defined function, it could be one of the following: 1.
- removeJobParameters(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 14;
- removeJobParameters(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder
-
repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 7;
- removeJobParameters(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 5;
- removeSpecs(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.Builder
-
repeated .org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction.DataViewSpec specs = 3;
- removeStrategies(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.Builder
-
repeated .org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry strategies = 2;
- RemoveTimestampMapFunction<T> - Class in org.apache.flink.streaming.api.functions.python.eventtime
-
MapFunction which removes the timestamp field from the input element.
- RemoveTimestampMapFunction() - Constructor for class org.apache.flink.streaming.api.functions.python.eventtime.RemoveTimestampMapFunction
- removeUdfs(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction udfs = 1;
- removeUdfs(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.UserDefinedFunction udfs = 1;
- removeWindows(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.OverWindow windows = 3;
- requiredOptions() - Method in class org.apache.flink.table.runtime.arrow.sources.ArrowTableSourceFactory
- requiredOptions() - Method in class org.apache.flink.table.utils.python.PythonDynamicTableFactory
- reset() - Method in class org.apache.flink.table.runtime.arrow.ArrowWriter
-
Resets the state of the writer to write the next batch of rows.
- reset() - Method in class org.apache.flink.table.runtime.arrow.writers.ArrayWriter
- reset() - Method in class org.apache.flink.table.runtime.arrow.writers.ArrowFieldWriter
-
Resets the state of the writer to write the next batch of fields.
- reset() - Method in class org.apache.flink.table.runtime.arrow.writers.RowWriter
- resetReader() - Method in class org.apache.flink.table.runtime.arrow.serializers.ArrowSerializer
- resetWriter() - Method in class org.apache.flink.table.runtime.arrow.serializers.ArrowSerializer
- resolveSchemaCompatibility(TypeSerializerSnapshot<Timestamp>) - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.TimestampSerializer.TimestampSerializerSnapshot
- resolveSchemaCompatibility(TypeSerializerSnapshot<ArrayData>) - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.ArrayDataSerializer.ArrayDataSerializerSnapshot
- resolveSchemaCompatibility(TypeSerializerSnapshot<DecimalData>) - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.DecimalDataSerializer.DecimalSerializerSnapshot
- resolveSchemaCompatibility(TypeSerializerSnapshot<MapData>) - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.MapDataSerializer.BaseMapSerializerSnapshot
- resolveSchemaCompatibility(TypeSerializerSnapshot<RowData>) - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.RowDataSerializer.RowDataSerializerSnapshot
- resource - Variable in class org.apache.flink.python.env.AbstractPythonEnvironmentManager
- restoreSerializer() - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.ArrayDataSerializer.ArrayDataSerializerSnapshot
- restoreSerializer() - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.DecimalDataSerializer.DecimalSerializerSnapshot
- restoreSerializer() - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.MapDataSerializer.BaseMapSerializerSnapshot
- restoreSerializer() - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.RowDataSerializer.RowDataSerializerSnapshot
- restoreSerializer() - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.TimestampSerializer.TimestampSerializerSnapshot
- resultBuffer - Variable in class org.apache.flink.streaming.api.runners.python.beam.BeamPythonFunctionRunner
-
Buffers the Python function execution result which has still not been processed.
- ReturnExpiredIfNotCleanedUp - org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.StateVisibility
-
Return expired user value if it is not cleaned up yet.
- ReturnExpiredIfNotCleanedUp_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.StateVisibility
-
Return expired user value if it is not cleaned up yet.
- reuseJoinedRow - Variable in class org.apache.flink.table.runtime.operators.python.aggregate.arrow.AbstractArrowPythonAggregateFunctionOperator
-
The JoinedRowData reused holding the execution result.
- reuseJoinedRow - Variable in class org.apache.flink.table.runtime.operators.python.scalar.AbstractPythonScalarFunctionOperator
-
The JoinedRowData reused holding the execution result.
- reuseResultRowData - Variable in class org.apache.flink.table.runtime.operators.python.AbstractEmbeddedStatelessFunctionOperator
-
The GenericRowData reused holding the execution result of python udf.
- REVISE_OUTPUT - org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.FunctionType
-
REVISE_OUTPUT = 100;
- REVISE_OUTPUT_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.FunctionType
-
REVISE_OUTPUT = 100;
- ROCKSDB_COMPACT_FILTER_CLEANUP_STRATEGY - org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry.CleanupStrategyCase
- ROCKSDB_COMPACT_FILTER_CLEANUP_STRATEGY_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry
- ROCKSDB_COMPACTION_FILTER - org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.Strategies
-
ROCKSDB_COMPACTION_FILTER = 2;
- ROCKSDB_COMPACTION_FILTER_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.Strategies
-
ROCKSDB_COMPACTION_FILTER = 2;
- ROW - org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TypeName
-
ROW = 0;
- ROW - org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TypeName
-
ROW = 0;
- ROW_SCHEMA - org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.TypeInfoCase
- ROW_SCHEMA_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
- ROW_SLIDING - org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow.WindowType
-
ROW_SLIDING = 7;
- ROW_SLIDING_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow.WindowType
-
ROW_SLIDING = 7;
- ROW_TIME_ATTRIBUTE - org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.WindowProperty
-
ROW_TIME_ATTRIBUTE = 2;
- ROW_TIME_ATTRIBUTE_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.WindowProperty
-
ROW_TIME_ATTRIBUTE = 2;
- ROW_TYPE - org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.DataTypeCase
- ROW_TYPE_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor
- ROW_TYPE_INFO - org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TypeInfoCase
- ROW_TYPE_INFO_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo
- ROW_UNBOUNDED - org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow.WindowType
-
ROW_UNBOUNDED = 4;
- ROW_UNBOUNDED_FOLLOWING - org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow.WindowType
-
ROW_UNBOUNDED_FOLLOWING = 6;
- ROW_UNBOUNDED_FOLLOWING_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow.WindowType
-
ROW_UNBOUNDED_FOLLOWING = 6;
- ROW_UNBOUNDED_PRECEDING - org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow.WindowType
-
ROW_UNBOUNDED_PRECEDING = 5;
- ROW_UNBOUNDED_PRECEDING_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow.WindowType
-
ROW_UNBOUNDED_PRECEDING = 5;
- ROW_UNBOUNDED_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow.WindowType
-
ROW_UNBOUNDED = 4;
- ROW_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TypeName
-
ROW = 0;
- ROW_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TypeName
-
ROW = 0;
- RowDataSerializer - Class in org.apache.flink.table.runtime.typeutils.serializers.python
-
A
TypeSerializer
forRowData
. - RowDataSerializer(LogicalType[], TypeSerializer[]) - Constructor for class org.apache.flink.table.runtime.typeutils.serializers.python.RowDataSerializer
- RowDataSerializer.RowDataSerializerSnapshot - Class in org.apache.flink.table.runtime.typeutils.serializers.python
-
TypeSerializerSnapshot
forRowDataSerializer
. - RowDataSerializerSnapshot() - Constructor for class org.apache.flink.table.runtime.typeutils.serializers.python.RowDataSerializer.RowDataSerializerSnapshot
- rowDataWrapper - Variable in class org.apache.flink.table.runtime.operators.python.AbstractEmbeddedStatelessFunctionOperator
-
The collector used to collect records.
- rowDataWrapper - Variable in class org.apache.flink.table.runtime.operators.python.aggregate.AbstractPythonStreamAggregateOperator
-
The collector used to collect records.
- rowDataWrapper - Variable in class org.apache.flink.table.runtime.operators.python.aggregate.arrow.AbstractArrowPythonAggregateFunctionOperator
-
The collector used to collect records.
- rowDataWrapper - Variable in class org.apache.flink.table.runtime.operators.python.scalar.AbstractPythonScalarFunctionOperator
-
The collector used to collect records.
- RowRowMapper(DataType) - Constructor for class org.apache.flink.python.util.PythonConnectorUtils.RowRowMapper
- RowWriter<T> - Class in org.apache.flink.table.runtime.arrow.writers
-
ArrowFieldWriter
for Row. - RowWriter.RowWriterForArray - Class in org.apache.flink.table.runtime.arrow.writers
-
RowWriter
forArrayData
input. - RowWriter.RowWriterForRow - Class in org.apache.flink.table.runtime.arrow.writers
-
RowWriter
forRowData
input. - run() - Method in class org.apache.flink.streaming.api.operators.python.process.timer.TimerRegistrationAction
- run(SourceFunction.SourceContext<RowData>) - Method in class org.apache.flink.table.runtime.arrow.sources.ArrowSourceFunction
-
Deprecated.
- RUN_CLEANUP_FOR_EVERY_RECORD_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategy
- RunnerOutputCollector<OUT> - Class in org.apache.flink.streaming.api.operators.python.process.collector
-
Output collector for Python UDF runner.
- RunnerOutputCollector(TimestampedCollector<OUT>) - Constructor for class org.apache.flink.streaming.api.operators.python.process.collector.RunnerOutputCollector
- RUNTIME_CONTEXT_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction
S
- scalarFunctions - Variable in class org.apache.flink.table.runtime.operators.python.scalar.AbstractPythonScalarFunctionOperator
-
The Python
ScalarFunction
s to be executed. - scale - Variable in class org.apache.flink.table.runtime.arrow.writers.DecimalWriter
- SCALE_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.DecimalInfo
- SCHEMA_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.ArrowType
- SCHEMA_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.FlattenRowType
- SCHEMA_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.OverWindowArrowType
- SCHEMA_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RowType
- SCHEMA_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.AvroTypeInfo
- SecondColumnSerializationSchema(SerializationSchema<T>) - Constructor for class org.apache.flink.python.util.PythonConnectorUtils.SecondColumnSerializationSchema
-
The constructor.
- SEPARATED_WITH_END_MESSAGE_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor
- serialize(String, DataOutputView) - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.StringSerializer
- serialize(BigDecimal, DataOutputView) - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.BigDecSerializer
- serialize(Date, DataOutputView) - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.DateSerializer
- serialize(Time, DataOutputView) - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.TimeSerializer
- serialize(Timestamp, DataOutputView) - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.TimestampSerializer
- serialize(ByteArrayWrapper, DataOutputView) - Method in class org.apache.flink.streaming.api.utils.ByteArrayWrapperSerializer
- serialize(ArrayData, DataOutputView) - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.ArrayDataSerializer
- serialize(DecimalData, DataOutputView) - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.DecimalDataSerializer
- serialize(MapData, DataOutputView) - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.MapDataSerializer
- serialize(RowData, DataOutputView) - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.RowDataSerializer
- serialize(Row) - Method in class org.apache.flink.formats.avro.AvroRowSerializationSchema
- serialize(Row) - Method in class org.apache.flink.formats.csv.CsvRowSerializationSchema
- serialize(Row) - Method in class org.apache.flink.formats.json.JsonRowSerializationSchema
- serialize(Row) - Method in class org.apache.flink.python.util.PythonConnectorUtils.SecondColumnSerializationSchema
- ServerFactory - Class in org.apache.beam.sdk.fn.server
-
A
gRPC server
factory. - ServerFactory() - Constructor for class org.apache.beam.sdk.fn.server.ServerFactory
- ServerFactory.InetSocketAddressServerFactory - Class in org.apache.beam.sdk.fn.server
-
Creates a
gRPC Server
using the default server factory. - ServerFactory.UrlFactory - Interface in org.apache.beam.sdk.fn.server
-
Factory that constructs client-accessible URLs from a local server address and port.
- ServerInfo() - Constructor for class org.apache.beam.runners.fnexecution.control.DefaultJobBundleFactory.ServerInfo
- SESSION_GROUP_WINDOW - org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.WindowType
-
SESSION_GROUP_WINDOW = 2;
- SESSION_GROUP_WINDOW_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.WindowType
-
SESSION_GROUP_WINDOW = 2;
- setAllowComments(boolean) - Method in class org.apache.flink.formats.csv.CsvRowDeserializationSchema.Builder
- setAllowedLateness(long) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.Builder
-
int64 allowedLateness = 8;
- setArrayElementDelimiter(String) - Method in class org.apache.flink.formats.csv.CsvRowDeserializationSchema.Builder
- setArrayElementDelimiter(String) - Method in class org.apache.flink.formats.csv.CsvRowSerializationSchema.Builder
- setArrowType(FlinkFnApi.CoderInfoDescriptor.ArrowType) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.Builder
-
.org.apache.flink.fn_execution.v1.CoderInfoDescriptor.ArrowType arrow_type = 3;
- setArrowType(FlinkFnApi.CoderInfoDescriptor.ArrowType.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.Builder
-
.org.apache.flink.fn_execution.v1.CoderInfoDescriptor.ArrowType arrow_type = 3;
- setAttemptNumber(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder
-
int32 attempt_number = 6;
- setAvroTypeInfo(FlinkFnApi.TypeInfo.AvroTypeInfo) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.Builder
-
.org.apache.flink.fn_execution.v1.TypeInfo.AvroTypeInfo avro_type_info = 6;
- setAvroTypeInfo(FlinkFnApi.TypeInfo.AvroTypeInfo.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.Builder
-
.org.apache.flink.fn_execution.v1.TypeInfo.AvroTypeInfo avro_type_info = 6;
- setBinaryInfo(FlinkFnApi.Schema.BinaryInfo) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.BinaryInfo binary_info = 11;
- setBinaryInfo(FlinkFnApi.Schema.BinaryInfo.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.BinaryInfo binary_info = 11;
- setCharInfo(FlinkFnApi.Schema.CharInfo) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.CharInfo char_info = 13;
- setCharInfo(FlinkFnApi.Schema.CharInfo.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.CharInfo char_info = 13;
- setCleanupSize(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategy.Builder
-
Max number of keys pulled from queue for clean up upon state touch for any key.
- setCleanupStrategies(FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.Builder
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies cleanup_strategies = 5;
- setCleanupStrategies(FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.Builder
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies cleanup_strategies = 5;
- setCollectionElementType(FlinkFnApi.Schema.FieldType) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.FieldType collection_element_type = 3;
- setCollectionElementType(FlinkFnApi.Schema.FieldType.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.FieldType collection_element_type = 3;
- setCollectionElementType(FlinkFnApi.TypeInfo) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.Builder
-
.org.apache.flink.fn_execution.v1.TypeInfo collection_element_type = 2;
- setCollectionElementType(FlinkFnApi.TypeInfo.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.Builder
-
.org.apache.flink.fn_execution.v1.TypeInfo collection_element_type = 2;
- setCountStarInserted(boolean) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
-
True if the count(*) agg is inserted by the planner.
- setCurrentKey(Object) - Method in class org.apache.flink.streaming.api.operators.python.AbstractPythonFunctionOperator
- setCurrentKey(Object) - Method in class org.apache.flink.streaming.api.operators.python.process.ExternalPythonKeyedCoProcessOperator
-
As the beam state gRPC service will access the KeyedStateBackend in parallel with this operator, we must override this method to prevent changing the current key of the KeyedStateBackend while the beam service is handling requests.
- setCurrentKey(Object) - Method in class org.apache.flink.streaming.api.operators.python.process.ExternalPythonKeyedProcessOperator
-
As the beam state gRPC service will access the KeyedStateBackend in parallel with this operator, we must override this method to prevent changing the current key of the KeyedStateBackend while the beam service is handling requests.
- setCurrentKey(Object) - Method in class org.apache.flink.table.runtime.operators.python.aggregate.AbstractPythonStreamAggregateOperator
-
As the beam state gRPC service will access the KeyedStateBackend in parallel with this operator, we must override this method to prevent changing the current key of the KeyedStateBackend while the beam service is handling requests.
- setCurrentKeyForStreaming(KeyedStateBackend<K>, K) - Static method in class org.apache.flink.streaming.api.utils.PythonOperatorUtils
-
Set the current key for streaming operator.
- setCurrentKeyForTimerService(InternalTimerService<N>, K) - Static method in class org.apache.flink.streaming.api.utils.PythonOperatorUtils
-
Set the current key for the timer service.
- setData(byte[]) - Method in class org.apache.flink.streaming.api.utils.ByteArrayWrapper
- setDecimalInfo(FlinkFnApi.Schema.DecimalInfo) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.DecimalInfo decimal_info = 6;
- setDecimalInfo(FlinkFnApi.Schema.DecimalInfo.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.DecimalInfo decimal_info = 6;
- setDescription(String) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Field.Builder
-
string description = 2;
- setDescriptionBytes(ByteString) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Field.Builder
-
string description = 2;
- setDistinct(boolean) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.Builder
-
bool distinct = 5;
- setElementType(FlinkFnApi.Schema.FieldType) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.ListView.Builder
-
.org.apache.flink.fn_execution.v1.Schema.FieldType element_type = 1;
- setElementType(FlinkFnApi.Schema.FieldType.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.ListView.Builder
-
.org.apache.flink.fn_execution.v1.Schema.FieldType element_type = 1;
- setEmptyStrategy(FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.EmptyCleanupStrategy) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry.Builder
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies.EmptyCleanupStrategy empty_strategy = 2;
- setEmptyStrategyValue(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry.Builder
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies.EmptyCleanupStrategy empty_strategy = 2;
- setEscapeCharacter(char) - Method in class org.apache.flink.formats.csv.CsvRowDeserializationSchema.Builder
- setEscapeCharacter(char) - Method in class org.apache.flink.formats.csv.CsvRowSerializationSchema.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.ArrowType.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.FlattenRowType.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.OverWindowArrowType.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RawType.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RowType.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.JobParameter.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.BinaryInfo.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.CharInfo.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.DecimalInfo.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Field.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.LocalZonedTimestampInfo.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.MapInfo.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimeInfo.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimestampInfo.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarBinaryInfo.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarCharInfo.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.ZonedTimestampInfo.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategy.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.RocksdbCompactFilterCleanupStrategy.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.AvroTypeInfo.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.MapTypeInfo.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Field.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TupleTypeInfo.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.ListView.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapView.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction.Builder
- setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions.Builder
- setFieldDelimiter(char) - Method in class org.apache.flink.formats.csv.CsvRowDeserializationSchema.Builder
- setFieldDelimiter(char) - Method in class org.apache.flink.formats.csv.CsvRowSerializationSchema.Builder
- setFieldIndex(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.Builder
-
int32 field_index = 2;
- setFieldName(String) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Field.Builder
-
string field_name = 1;
- setFieldNameBytes(ByteString) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Field.Builder
-
string field_name = 1;
- setFields(int, FlinkFnApi.Schema.Field) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Builder
-
repeated .org.apache.flink.fn_execution.v1.Schema.Field fields = 1;
- setFields(int, FlinkFnApi.Schema.Field.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Builder
-
repeated .org.apache.flink.fn_execution.v1.Schema.Field fields = 1;
- setFields(int, FlinkFnApi.TypeInfo.RowTypeInfo.Field) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Builder
-
repeated .org.apache.flink.fn_execution.v1.TypeInfo.RowTypeInfo.Field fields = 1;
- setFields(int, FlinkFnApi.TypeInfo.RowTypeInfo.Field.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Builder
-
repeated .org.apache.flink.fn_execution.v1.TypeInfo.RowTypeInfo.Field fields = 1;
- setFieldType(FlinkFnApi.TypeInfo) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Field.Builder
-
.org.apache.flink.fn_execution.v1.TypeInfo field_type = 2;
- setFieldType(FlinkFnApi.TypeInfo.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Field.Builder
-
.org.apache.flink.fn_execution.v1.TypeInfo field_type = 2;
- setFieldTypes(int, FlinkFnApi.TypeInfo) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TupleTypeInfo.Builder
-
repeated .org.apache.flink.fn_execution.v1.TypeInfo field_types = 1;
- setFieldTypes(int, FlinkFnApi.TypeInfo.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TupleTypeInfo.Builder
-
repeated .org.apache.flink.fn_execution.v1.TypeInfo field_types = 1;
- setFilterArg(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.Builder
-
int32 filter_arg = 4;
- setFlattenRowType(FlinkFnApi.CoderInfoDescriptor.FlattenRowType) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.Builder
-
for Table & SQL
- setFlattenRowType(FlinkFnApi.CoderInfoDescriptor.FlattenRowType.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.Builder
-
for Table & SQL
- setFunctionType(FlinkFnApi.UserDefinedDataStreamFunction.FunctionType) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.Builder
-
.org.apache.flink.fn_execution.v1.UserDefinedDataStreamFunction.FunctionType function_type = 1;
- setFunctionTypeValue(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.Builder
-
.org.apache.flink.fn_execution.v1.UserDefinedDataStreamFunction.FunctionType function_type = 1;
- setGenerateUpdateBefore(boolean) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
-
Generate retract messages if true.
- setGrouping(int, int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
-
The array of the key indexes.
- setGroupWindow(FlinkFnApi.GroupWindow) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
-
Group Window.
- setGroupWindow(FlinkFnApi.GroupWindow.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
-
Group Window.
- setHasSideOutput(boolean) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.Builder
-
bool has_side_output = 7;
- setIgnoreParseErrors(boolean) - Method in class org.apache.flink.formats.csv.CsvRowDeserializationSchema.Builder
- setInBatchExecutionMode(boolean) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder
-
bool in_batch_execution_mode = 8;
- setIncrementalCleanupStrategy(FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategy) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry.Builder
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategy incremental_cleanup_strategy = 3;
- setIncrementalCleanupStrategy(FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategy.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry.Builder
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategy incremental_cleanup_strategy = 3;
- setIndexOfCountStar(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
-
The index of a count aggregate used to calculate the number of accumulated rows.
- setIndexOfThisSubtask(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder
-
int32 index_of_this_subtask = 5;
- setInputConstant(ByteString) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input.Builder
-
bytes inputConstant = 3;
- setInputOffset(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input.Builder
-
int32 inputOffset = 2;
- setInputs(int, FlinkFnApi.Input) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.Builder
-
The input arguments of the user-defined function, it could be one of the following: 1.
- setInputs(int, FlinkFnApi.Input) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction.Builder
-
The input arguments of the user-defined function, it could be one of the following: 1.
- setInputs(int, FlinkFnApi.Input.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.Builder
-
The input arguments of the user-defined function, it could be one of the following: 1.
- setInputs(int, FlinkFnApi.Input.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction.Builder
-
The input arguments of the user-defined function, it could be one of the following: 1.
- setIsCleanupInBackground(boolean) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.Builder
-
bool is_cleanup_in_background = 1;
- setIsPandasUdf(boolean) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction.Builder
-
Whether it's pandas UDF
- setIsRowTime(boolean) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.Builder
-
bool is_row_time = 6;
- setIsTimeWindow(boolean) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.Builder
-
bool is_time_window = 2;
- setJobParameters(int, FlinkFnApi.JobParameter) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 14;
- setJobParameters(int, FlinkFnApi.JobParameter) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder
-
repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 7;
- setJobParameters(int, FlinkFnApi.JobParameter) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 5;
- setJobParameters(int, FlinkFnApi.JobParameter.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 14;
- setJobParameters(int, FlinkFnApi.JobParameter.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder
-
repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 7;
- setJobParameters(int, FlinkFnApi.JobParameter.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 5;
- setKey(String) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.JobParameter.Builder
-
string key = 1;
- setKeyBytes(ByteString) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.JobParameter.Builder
-
string key = 1;
- setKeyType(FlinkFnApi.Schema.FieldType) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.MapInfo.Builder
-
.org.apache.flink.fn_execution.v1.Schema.FieldType key_type = 1;
- setKeyType(FlinkFnApi.Schema.FieldType) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapView.Builder
-
.org.apache.flink.fn_execution.v1.Schema.FieldType key_type = 1;
- setKeyType(FlinkFnApi.Schema.FieldType) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
-
The schema of the grouping keys.
- setKeyType(FlinkFnApi.Schema.FieldType.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.MapInfo.Builder
-
.org.apache.flink.fn_execution.v1.Schema.FieldType key_type = 1;
- setKeyType(FlinkFnApi.Schema.FieldType.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapView.Builder
-
.org.apache.flink.fn_execution.v1.Schema.FieldType key_type = 1;
- setKeyType(FlinkFnApi.Schema.FieldType.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
-
The schema of the grouping keys.
- setKeyType(FlinkFnApi.TypeInfo) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.MapTypeInfo.Builder
-
.org.apache.flink.fn_execution.v1.TypeInfo key_type = 1;
- setKeyType(FlinkFnApi.TypeInfo.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.MapTypeInfo.Builder
-
.org.apache.flink.fn_execution.v1.TypeInfo key_type = 1;
- setKeyTypeInfo(FlinkFnApi.TypeInfo) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.Builder
-
.org.apache.flink.fn_execution.v1.TypeInfo key_type_info = 5;
- setKeyTypeInfo(FlinkFnApi.TypeInfo.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.Builder
-
.org.apache.flink.fn_execution.v1.TypeInfo key_type_info = 5;
- setLength(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.BinaryInfo.Builder
-
int32 length = 1;
- setLength(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.CharInfo.Builder
-
int32 length = 1;
- setLength(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarBinaryInfo.Builder
-
int32 length = 1;
- setLength(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarCharInfo.Builder
-
int32 length = 1;
- setLimit(int) - Method in class org.apache.flink.streaming.api.utils.ByteArrayWrapper
- setLineDelimiter(String) - Method in class org.apache.flink.formats.csv.CsvRowSerializationSchema.Builder
- setListView(FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.ListView) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.Builder
-
.org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction.DataViewSpec.ListView list_view = 3;
- setListView(FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.ListView.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.Builder
-
.org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction.DataViewSpec.ListView list_view = 3;
- setLocalZonedTimestampInfo(FlinkFnApi.Schema.LocalZonedTimestampInfo) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.LocalZonedTimestampInfo local_zoned_timestamp_info = 9;
- setLocalZonedTimestampInfo(FlinkFnApi.Schema.LocalZonedTimestampInfo.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.LocalZonedTimestampInfo local_zoned_timestamp_info = 9;
- setLowerBoundary(long) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow.Builder
-
int64 lower_boundary = 2;
- setMapInfo(FlinkFnApi.Schema.MapInfo) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.MapInfo map_info = 4;
- setMapInfo(FlinkFnApi.Schema.MapInfo.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.MapInfo map_info = 4;
- setMapStateReadCacheSize(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
-
The map state read cache size.
- setMapStateReadCacheSize(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.Builder
-
The map state read cache size.
- setMapStateWriteCacheSize(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
-
The map_state_write_cache_size.
- setMapStateWriteCacheSize(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.Builder
-
The map_state_write_cache_size.
- setMapTypeInfo(FlinkFnApi.TypeInfo.MapTypeInfo) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.Builder
-
.org.apache.flink.fn_execution.v1.TypeInfo.MapTypeInfo map_type_info = 5;
- setMapTypeInfo(FlinkFnApi.TypeInfo.MapTypeInfo.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.Builder
-
.org.apache.flink.fn_execution.v1.TypeInfo.MapTypeInfo map_type_info = 5;
- setMapView(FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapView) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.Builder
-
.org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction.DataViewSpec.MapView map_view = 4;
- setMapView(FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapView.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.Builder
-
.org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction.DataViewSpec.MapView map_view = 4;
- setMaxNumberOfParallelSubtasks(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder
-
int32 max_number_of_parallel_subtasks = 4;
- setMetricEnabled(boolean) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
-
bool metric_enabled = 2;
- setMetricEnabled(boolean) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.Builder
-
bool metric_enabled = 4;
- setMetricEnabled(boolean) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions.Builder
-
bool metric_enabled = 2;
- setMode(FlinkFnApi.CoderInfoDescriptor.Mode) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.Builder
-
.org.apache.flink.fn_execution.v1.CoderInfoDescriptor.Mode mode = 6;
- setModeValue(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.Builder
-
.org.apache.flink.fn_execution.v1.CoderInfoDescriptor.Mode mode = 6;
- setName(String) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Field.Builder
-
string name = 1;
- setName(String) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.Builder
-
string name = 1;
- setNameBytes(ByteString) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Field.Builder
-
string name = 1;
- setNameBytes(ByteString) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.Builder
-
string name = 1;
- setNamedProperties(int, FlinkFnApi.GroupWindow.WindowProperty) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.Builder
-
repeated .org.apache.flink.fn_execution.v1.GroupWindow.WindowProperty namedProperties = 9;
- setNamedPropertiesValue(int, int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.Builder
-
repeated .org.apache.flink.fn_execution.v1.GroupWindow.WindowProperty namedProperties = 9;
- setNullable(boolean) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
bool nullable = 2;
- setNullLiteral(String) - Method in class org.apache.flink.formats.csv.CsvRowDeserializationSchema.Builder
- setNullLiteral(String) - Method in class org.apache.flink.formats.csv.CsvRowSerializationSchema.Builder
- setNumberOfParallelSubtasks(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder
-
int32 number_of_parallel_subtasks = 3;
- setNumPartitions(int) - Method in interface org.apache.flink.streaming.api.operators.python.DataStreamPythonFunctionOperator
-
Sets the number of partitions.
- setNumPartitions(int) - Method in class org.apache.flink.streaming.api.operators.python.embedded.AbstractEmbeddedDataStreamPythonFunctionOperator
- setNumPartitions(int) - Method in class org.apache.flink.streaming.api.operators.python.process.AbstractExternalDataStreamPythonFunctionOperator
- setNumPartitions(int) - Method in class org.apache.flink.streaming.api.transformations.python.DelegateOperatorTransformation.DelegateOperator
- setOffset(int) - Method in class org.apache.flink.streaming.api.utils.ByteArrayWrapper
- setOverWindowArrowType(FlinkFnApi.CoderInfoDescriptor.OverWindowArrowType) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.Builder
-
.org.apache.flink.fn_execution.v1.CoderInfoDescriptor.OverWindowArrowType over_window_arrow_type = 4;
- setOverWindowArrowType(FlinkFnApi.CoderInfoDescriptor.OverWindowArrowType.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.Builder
-
.org.apache.flink.fn_execution.v1.CoderInfoDescriptor.OverWindowArrowType over_window_arrow_type = 4;
- setPartitionCustomOperatorNumPartitions(List<Transformation<?>>) - Static method in class org.apache.flink.python.util.PythonConfigUtil
- setPayload(ByteString) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.Builder
-
The serialized representation of the user-defined function
- setPayload(ByteString) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.Builder
-
bytes payload = 3;
- setPayload(ByteString) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction.Builder
-
The serialized representation of the user-defined function
- setPrecision(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.DecimalInfo.Builder
-
int32 precision = 1;
- setPrecision(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.LocalZonedTimestampInfo.Builder
-
int32 precision = 1;
- setPrecision(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimeInfo.Builder
-
int32 precision = 1;
- setPrecision(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimestampInfo.Builder
-
int32 precision = 1;
- setPrecision(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.ZonedTimestampInfo.Builder
-
int32 precision = 1;
- setProfileEnabled(boolean) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
-
bool profile_enabled = 13;
- setProfileEnabled(boolean) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.Builder
-
bool profile_enabled = 6;
- setProfileEnabled(boolean) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions.Builder
-
bool profile_enabled = 4;
- setQueryTimeAfterNumEntries(long) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.RocksdbCompactFilterCleanupStrategy.Builder
-
Number of state entries to process by compaction filter before updating current timestamp.
- setQuoteCharacter(char) - Method in class org.apache.flink.formats.csv.CsvRowDeserializationSchema.Builder
- setQuoteCharacter(char) - Method in class org.apache.flink.formats.csv.CsvRowSerializationSchema.Builder
- setRawType(FlinkFnApi.CoderInfoDescriptor.RawType) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.Builder
-
for DataStream
- setRawType(FlinkFnApi.CoderInfoDescriptor.RawType.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.Builder
-
for DataStream
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.ArrowType.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.FlattenRowType.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.OverWindowArrowType.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RawType.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RowType.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.JobParameter.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.BinaryInfo.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.CharInfo.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.DecimalInfo.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Field.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.LocalZonedTimestampInfo.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.MapInfo.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimeInfo.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimestampInfo.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarBinaryInfo.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarCharInfo.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.ZonedTimestampInfo.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategy.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.RocksdbCompactFilterCleanupStrategy.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.AvroTypeInfo.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.MapTypeInfo.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Field.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TupleTypeInfo.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.ListView.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapView.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction.Builder
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions.Builder
- setRocksdbCompactFilterCleanupStrategy(FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.RocksdbCompactFilterCleanupStrategy) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry.Builder
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies.RocksdbCompactFilterCleanupStrategy rocksdb_compact_filter_cleanup_strategy = 4;
- setRocksdbCompactFilterCleanupStrategy(FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.RocksdbCompactFilterCleanupStrategy.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry.Builder
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies.RocksdbCompactFilterCleanupStrategy rocksdb_compact_filter_cleanup_strategy = 4;
- setRowSchema(FlinkFnApi.Schema) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema row_schema = 5;
- setRowSchema(FlinkFnApi.Schema.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema row_schema = 5;
- setRowType(FlinkFnApi.CoderInfoDescriptor.RowType) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.Builder
-
.org.apache.flink.fn_execution.v1.CoderInfoDescriptor.RowType row_type = 2;
- setRowType(FlinkFnApi.CoderInfoDescriptor.RowType.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.Builder
-
.org.apache.flink.fn_execution.v1.CoderInfoDescriptor.RowType row_type = 2;
- setRowTypeInfo(FlinkFnApi.TypeInfo.RowTypeInfo) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.Builder
-
.org.apache.flink.fn_execution.v1.TypeInfo.RowTypeInfo row_type_info = 3;
- setRowTypeInfo(FlinkFnApi.TypeInfo.RowTypeInfo.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.Builder
-
.org.apache.flink.fn_execution.v1.TypeInfo.RowTypeInfo row_type_info = 3;
- setRunCleanupForEveryRecord(boolean) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategy.Builder
-
Whether to run incremental cleanup per each processed record.
- setRuntimeContext(FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.Builder
-
.org.apache.flink.fn_execution.v1.UserDefinedDataStreamFunction.RuntimeContext runtime_context = 2;
- setRuntimeContext(FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.Builder
-
.org.apache.flink.fn_execution.v1.UserDefinedDataStreamFunction.RuntimeContext runtime_context = 2;
- setScale(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.DecimalInfo.Builder
-
int32 scale = 2;
- setSchema(String) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.AvroTypeInfo.Builder
-
string schema = 1;
- setSchema(FlinkFnApi.Schema) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.ArrowType.Builder
-
.org.apache.flink.fn_execution.v1.Schema schema = 1;
- setSchema(FlinkFnApi.Schema) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.FlattenRowType.Builder
-
.org.apache.flink.fn_execution.v1.Schema schema = 1;
- setSchema(FlinkFnApi.Schema) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.OverWindowArrowType.Builder
-
.org.apache.flink.fn_execution.v1.Schema schema = 1;
- setSchema(FlinkFnApi.Schema) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RowType.Builder
-
.org.apache.flink.fn_execution.v1.Schema schema = 1;
- setSchema(FlinkFnApi.Schema.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.ArrowType.Builder
-
.org.apache.flink.fn_execution.v1.Schema schema = 1;
- setSchema(FlinkFnApi.Schema.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.FlattenRowType.Builder
-
.org.apache.flink.fn_execution.v1.Schema schema = 1;
- setSchema(FlinkFnApi.Schema.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.OverWindowArrowType.Builder
-
.org.apache.flink.fn_execution.v1.Schema schema = 1;
- setSchema(FlinkFnApi.Schema.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RowType.Builder
-
.org.apache.flink.fn_execution.v1.Schema schema = 1;
- setSchemaBytes(ByteString) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.AvroTypeInfo.Builder
-
string schema = 1;
- setSeparatedWithEndMessage(boolean) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.Builder
-
append an end message (0x00) after serializing the records belonging to the same batch.
- setShiftTimezone(String) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.Builder
-
string shift_timezone = 10;
- setShiftTimezoneBytes(ByteString) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.Builder
-
string shift_timezone = 10;
- setSpecs(int, FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.Builder
-
repeated .org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction.DataViewSpec specs = 3;
- setSpecs(int, FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.Builder
-
repeated .org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction.DataViewSpec specs = 3;
- setStateCacheSize(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
-
The state cache size.
- setStateCacheSize(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.Builder
-
The state cache size.
- setStateCleaningEnabled(boolean) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
-
Cleanup the expired state if true.
- setStateName(String) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.Builder
-
string state_name = 1;
- setStateNameBytes(ByteString) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.Builder
-
string state_name = 1;
- setStateTtlConfig(FlinkFnApi.StateDescriptor.StateTTLConfig) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.Builder
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig state_ttl_config = 2;
- setStateTtlConfig(FlinkFnApi.StateDescriptor.StateTTLConfig.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.Builder
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig state_ttl_config = 2;
- setStateVisibility(FlinkFnApi.StateDescriptor.StateTTLConfig.StateVisibility) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.Builder
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.StateVisibility state_visibility = 2;
- setStateVisibilityValue(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.Builder
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.StateVisibility state_visibility = 2;
- setStrategies(int, FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.Builder
-
repeated .org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry strategies = 2;
- setStrategies(int, FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.Builder
-
repeated .org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry strategies = 2;
- setStrategy(FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.Strategies) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry.Builder
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies.Strategies strategy = 1;
- setStrategyValue(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry.Builder
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.CleanupStrategies.Strategies strategy = 1;
- setTakesRowAsInput(boolean) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.Builder
-
Whether the UDF takes row as input instead of each columns of a row
- setTakesRowAsInput(boolean) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction.Builder
-
Whether the UDF takes row as input instead of each columns of a row
- setTaskName(String) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder
-
string task_name = 1;
- setTaskNameBytes(ByteString) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder
-
string task_name = 1;
- setTaskNameWithSubtasks(String) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder
-
string task_name_with_subtasks = 2;
- setTaskNameWithSubtasksBytes(ByteString) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder
-
string task_name_with_subtasks = 2;
- setTimeFieldIndex(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.Builder
-
int32 time_field_index = 7;
- setTimeInfo(FlinkFnApi.Schema.TimeInfo) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.TimeInfo time_info = 7;
- setTimeInfo(FlinkFnApi.Schema.TimeInfo.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.TimeInfo time_info = 7;
- setTimer(byte[]) - Method in class org.apache.flink.streaming.api.operators.python.process.timer.TimerRegistration
- setTimestampInfo(FlinkFnApi.Schema.TimestampInfo) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.TimestampInfo timestamp_info = 8;
- setTimestampInfo(FlinkFnApi.Schema.TimestampInfo.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.TimestampInfo timestamp_info = 8;
- setTtl(long) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.Builder
-
int64 ttl = 4;
- setTtlTimeCharacteristic(FlinkFnApi.StateDescriptor.StateTTLConfig.TtlTimeCharacteristic) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.Builder
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.TtlTimeCharacteristic ttl_time_characteristic = 3;
- setTtlTimeCharacteristicValue(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.Builder
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.TtlTimeCharacteristic ttl_time_characteristic = 3;
- setTupleTypeInfo(FlinkFnApi.TypeInfo.TupleTypeInfo) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.Builder
-
.org.apache.flink.fn_execution.v1.TypeInfo.TupleTypeInfo tuple_type_info = 4;
- setTupleTypeInfo(FlinkFnApi.TypeInfo.TupleTypeInfo.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.Builder
-
.org.apache.flink.fn_execution.v1.TypeInfo.TupleTypeInfo tuple_type_info = 4;
- setType(FlinkFnApi.Schema.FieldType) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Field.Builder
-
.org.apache.flink.fn_execution.v1.Schema.FieldType type = 3;
- setType(FlinkFnApi.Schema.FieldType.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Field.Builder
-
.org.apache.flink.fn_execution.v1.Schema.FieldType type = 3;
- setTypeInfo(FlinkFnApi.TypeInfo) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RawType.Builder
-
.org.apache.flink.fn_execution.v1.TypeInfo type_info = 1;
- setTypeInfo(FlinkFnApi.TypeInfo.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RawType.Builder
-
.org.apache.flink.fn_execution.v1.TypeInfo type_info = 1;
- setTypeName(FlinkFnApi.Schema.TypeName) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.TypeName type_name = 1;
- setTypeName(FlinkFnApi.TypeInfo.TypeName) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.Builder
-
.org.apache.flink.fn_execution.v1.TypeInfo.TypeName type_name = 1;
- setTypeNameValue(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.TypeName type_name = 1;
- setTypeNameValue(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.Builder
-
.org.apache.flink.fn_execution.v1.TypeInfo.TypeName type_name = 1;
- setUdf(FlinkFnApi.UserDefinedFunction) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input.Builder
-
.org.apache.flink.fn_execution.v1.UserDefinedFunction udf = 1;
- setUdf(FlinkFnApi.UserDefinedFunction.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input.Builder
-
.org.apache.flink.fn_execution.v1.UserDefinedFunction udf = 1;
- setUdfs(int, FlinkFnApi.UserDefinedAggregateFunction) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction udfs = 1;
- setUdfs(int, FlinkFnApi.UserDefinedAggregateFunction.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction udfs = 1;
- setUdfs(int, FlinkFnApi.UserDefinedFunction) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.UserDefinedFunction udfs = 1;
- setUdfs(int, FlinkFnApi.UserDefinedFunction.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.UserDefinedFunction udfs = 1;
- setUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.ArrowType.Builder
- setUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.Builder
- setUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.FlattenRowType.Builder
- setUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.OverWindowArrowType.Builder
- setUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RawType.Builder
- setUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RowType.Builder
- setUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.Builder
- setUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input.Builder
- setUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.JobParameter.Builder
- setUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow.Builder
- setUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.BinaryInfo.Builder
- setUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Builder
- setUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.CharInfo.Builder
- setUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.DecimalInfo.Builder
- setUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Field.Builder
- setUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
- setUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.LocalZonedTimestampInfo.Builder
- setUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.MapInfo.Builder
- setUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimeInfo.Builder
- setUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimestampInfo.Builder
- setUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarBinaryInfo.Builder
- setUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarCharInfo.Builder
- setUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.ZonedTimestampInfo.Builder
- setUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.Builder
- setUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.Builder
- setUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.Builder
- setUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategy.Builder
- setUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry.Builder
- setUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.RocksdbCompactFilterCleanupStrategy.Builder
- setUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.AvroTypeInfo.Builder
- setUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.Builder
- setUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.MapTypeInfo.Builder
- setUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Builder
- setUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Field.Builder
- setUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TupleTypeInfo.Builder
- setUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.Builder
- setUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.Builder
- setUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.ListView.Builder
- setUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapView.Builder
- setUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
- setUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.Builder
- setUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder
- setUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction.Builder
- setUnknownFields(UnknownFieldSet) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions.Builder
- setUpdateType(FlinkFnApi.StateDescriptor.StateTTLConfig.UpdateType) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.Builder
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.UpdateType update_type = 1;
- setUpdateTypeValue(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.Builder
-
.org.apache.flink.fn_execution.v1.StateDescriptor.StateTTLConfig.UpdateType update_type = 1;
- setUpperBoundary(long) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow.Builder
-
int64 upper_boundary = 3;
- setValue(String) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.JobParameter.Builder
-
string value = 2;
- setValueBytes(ByteString) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.JobParameter.Builder
-
string value = 2;
- setValueType(FlinkFnApi.Schema.FieldType) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.MapInfo.Builder
-
.org.apache.flink.fn_execution.v1.Schema.FieldType value_type = 2;
- setValueType(FlinkFnApi.Schema.FieldType) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapView.Builder
-
.org.apache.flink.fn_execution.v1.Schema.FieldType value_type = 2;
- setValueType(FlinkFnApi.Schema.FieldType.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.MapInfo.Builder
-
.org.apache.flink.fn_execution.v1.Schema.FieldType value_type = 2;
- setValueType(FlinkFnApi.Schema.FieldType.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapView.Builder
-
.org.apache.flink.fn_execution.v1.Schema.FieldType value_type = 2;
- setValueType(FlinkFnApi.TypeInfo) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.MapTypeInfo.Builder
-
.org.apache.flink.fn_execution.v1.TypeInfo value_type = 2;
- setValueType(FlinkFnApi.TypeInfo.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.MapTypeInfo.Builder
-
.org.apache.flink.fn_execution.v1.TypeInfo value_type = 2;
- setVarBinaryInfo(FlinkFnApi.Schema.VarBinaryInfo) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.VarBinaryInfo var_binary_info = 12;
- setVarBinaryInfo(FlinkFnApi.Schema.VarBinaryInfo.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.VarBinaryInfo var_binary_info = 12;
- setVarCharInfo(FlinkFnApi.Schema.VarCharInfo) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.VarCharInfo var_char_info = 14;
- setVarCharInfo(FlinkFnApi.Schema.VarCharInfo.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.VarCharInfo var_char_info = 14;
- setWindowGap(long) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.Builder
-
int64 window_gap = 5;
- setWindowIndex(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction.Builder
-
The index of the over window used in pandas batch over window aggregation
- setWindows(int, FlinkFnApi.OverWindow) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.OverWindow windows = 3;
- setWindows(int, FlinkFnApi.OverWindow.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions.Builder
-
repeated .org.apache.flink.fn_execution.v1.OverWindow windows = 3;
- setWindowSize(long) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.Builder
-
int64 window_size = 4;
- setWindowSlide(long) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.Builder
-
int64 window_slide = 3;
- setWindowType(FlinkFnApi.GroupWindow.WindowType) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.Builder
-
.org.apache.flink.fn_execution.v1.GroupWindow.WindowType window_type = 1;
- setWindowType(FlinkFnApi.OverWindow.WindowType) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow.Builder
-
.org.apache.flink.fn_execution.v1.OverWindow.WindowType window_type = 1;
- setWindowTypeValue(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.Builder
-
.org.apache.flink.fn_execution.v1.GroupWindow.WindowType window_type = 1;
- setWindowTypeValue(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow.Builder
-
.org.apache.flink.fn_execution.v1.OverWindow.WindowType window_type = 1;
- setZonedTimestampInfo(FlinkFnApi.Schema.ZonedTimestampInfo) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.ZonedTimestampInfo zoned_timestamp_info = 10;
- setZonedTimestampInfo(FlinkFnApi.Schema.ZonedTimestampInfo.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
-
.org.apache.flink.fn_execution.v1.Schema.ZonedTimestampInfo zoned_timestamp_info = 10;
- SharedResourceHolder - Class in org.apache.beam.vendor.grpc.v1p60p1.io.grpc.internal
-
A holder for shared resource singletons.
- SharedResourceHolder.Resource<T> - Interface in org.apache.beam.vendor.grpc.v1p60p1.io.grpc.internal
-
Defines a resource, and the way to create and destroy instances of it.
- SHIFT_TIMEZONE_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow
- SHORT - org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TypeName
-
SHORT = 4;
- SHORT_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TypeName
-
SHORT = 4;
- ShortDataConverter() - Constructor for class org.apache.flink.streaming.api.utils.PythonTypeUtils.ShortDataConverter
- SIDE_OUTPUT_CODER_PREFIX - Static variable in class org.apache.flink.python.Constants
- sideOutputCoderDescriptors - Variable in class org.apache.flink.streaming.api.runners.python.beam.BeamPythonFunctionRunner
- sideOutputContext - Variable in class org.apache.flink.streaming.api.operators.python.embedded.AbstractEmbeddedDataStreamPythonFunctionOperator
- SINGLE - org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.Mode
-
process one record at a time
- SINGLE_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.Mode
-
process one record at a time
- SLIDING_GROUP_WINDOW - org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.WindowType
-
SLIDING_GROUP_WINDOW = 1;
- SLIDING_GROUP_WINDOW_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.WindowType
-
SLIDING_GROUP_WINDOW = 1;
- SMALLINT - org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TypeName
-
SMALLINT = 2;
- SMALLINT_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TypeName
-
SMALLINT = 2;
- SmallIntWriter<T> - Class in org.apache.flink.table.runtime.arrow.writers
-
ArrowFieldWriter
for SmallInt. - SmallIntWriter.SmallIntWriterForArray - Class in org.apache.flink.table.runtime.arrow.writers
-
SmallIntWriter
forArrayData
input. - SmallIntWriter.SmallIntWriterForRow - Class in org.apache.flink.table.runtime.arrow.writers
-
SmallIntWriter
forRowData
input. - snapshotConfiguration() - Method in class org.apache.flink.streaming.api.utils.ByteArrayWrapperSerializer
- snapshotConfiguration() - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.ArrayDataSerializer
- snapshotConfiguration() - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.BigDecSerializer
- snapshotConfiguration() - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.DateSerializer
- snapshotConfiguration() - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.DecimalDataSerializer
- snapshotConfiguration() - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.MapDataSerializer
- snapshotConfiguration() - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.RowDataSerializer
- snapshotConfiguration() - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.StringSerializer
- snapshotConfiguration() - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.TimeSerializer
- snapshotConfiguration() - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.TimestampSerializer
- snapshotState(FunctionSnapshotContext) - Method in class org.apache.flink.table.runtime.arrow.sources.ArrowSourceFunction
-
Deprecated.
- SPECS_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction
- SQL_DATE - org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TypeName
-
SQL_DATE = 12;
- SQL_DATE_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TypeName
-
SQL_DATE = 12;
- SQL_TIME - org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TypeName
-
SQL_TIME = 13;
- SQL_TIME_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TypeName
-
SQL_TIME = 13;
- SQL_TIMESTAMP - org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TypeName
-
SQL_TIMESTAMP = 14;
- SQL_TIMESTAMP_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TypeName
-
SQL_TIMESTAMP = 14;
- startBundle() - Method in class org.apache.flink.streaming.api.runners.python.beam.BeamPythonFunctionRunner
- state(StreamObserver<BeamFnApi.StateResponse>) - Method in class org.apache.beam.runners.fnexecution.state.GrpcStateService
- STATE_CACHE_SIZE - Static variable in class org.apache.flink.python.PythonOptions
-
The maximum number of states cached in a Python UDF worker.
- STATE_CACHE_SIZE_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions
- STATE_CACHE_SIZE_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction
- STATE_CLEANING_ENABLED_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions
- STATE_NAME_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor
- STATE_TTL_CONFIG_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor
- STATE_VISIBILITY_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig
- stateful(Environment, String, ProcessPythonEnvironmentManager, String, GeneratedMessageV3, FlinkMetricContainer, KeyedStateBackend<?>, TypeSerializer<?>, TypeSerializer<?>, MemoryManager, double, FlinkFnApi.CoderInfoDescriptor, FlinkFnApi.CoderInfoDescriptor) - Static method in class org.apache.flink.table.runtime.runners.python.beam.BeamTablePythonFunctionRunner
- STATEFUL_FUNCTION_URN - Static variable in class org.apache.flink.python.Constants
- stateless(Environment, String, ProcessPythonEnvironmentManager, String, GeneratedMessageV3, FlinkMetricContainer, MemoryManager, double, FlinkFnApi.CoderInfoDescriptor, FlinkFnApi.CoderInfoDescriptor) - Static method in class org.apache.flink.table.runtime.runners.python.beam.BeamTablePythonFunctionRunner
- STATELESS_FUNCTION_URN - Static variable in class org.apache.flink.python.Constants
- STRATEGIES_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies
- STRATEGY_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry
- STREAM_GROUP_AGGREGATE_URN - Static variable in class org.apache.flink.table.runtime.operators.python.aggregate.PythonStreamGroupAggregateOperator
- STREAM_GROUP_TABLE_AGGREGATE_URN - Static variable in class org.apache.flink.table.runtime.operators.python.aggregate.PythonStreamGroupTableAggregateOperator
- STREAM_KEY_BY_MAP_OPERATOR_NAME - Static variable in class org.apache.flink.python.util.PythonConfigUtil
- STREAM_PARTITION_CUSTOM_MAP_OPERATOR_NAME - Static variable in class org.apache.flink.python.util.PythonConfigUtil
- StreamArrowPythonGroupWindowAggregateFunctionOperator<K,W extends org.apache.flink.table.runtime.operators.window.Window> - Class in org.apache.flink.table.runtime.operators.python.aggregate.arrow.stream
-
The Stream Arrow Python
AggregateFunction
Operator for Group Window Aggregation. - StreamArrowPythonGroupWindowAggregateFunctionOperator(Configuration, PythonFunctionInfo[], RowType, RowType, RowType, int, GroupWindowAssigner<W>, Trigger<W>, long, NamedWindowProperty[], ZoneId, GeneratedProjection) - Constructor for class org.apache.flink.table.runtime.operators.python.aggregate.arrow.stream.StreamArrowPythonGroupWindowAggregateFunctionOperator
- StreamArrowPythonProcTimeBoundedRangeOperator<K> - Class in org.apache.flink.table.runtime.operators.python.aggregate.arrow.stream
-
The Stream Arrow Python
AggregateFunction
Operator for ROWS clause proc-time bounded OVER window. - StreamArrowPythonProcTimeBoundedRangeOperator(Configuration, PythonFunctionInfo[], RowType, RowType, RowType, int, long, GeneratedProjection) - Constructor for class org.apache.flink.table.runtime.operators.python.aggregate.arrow.stream.StreamArrowPythonProcTimeBoundedRangeOperator
- StreamArrowPythonProcTimeBoundedRowsOperator<K> - Class in org.apache.flink.table.runtime.operators.python.aggregate.arrow.stream
-
The Stream Arrow Python
AggregateFunction
Operator for ROWS clause proc-time bounded OVER window. - StreamArrowPythonProcTimeBoundedRowsOperator(Configuration, long, long, PythonFunctionInfo[], RowType, RowType, RowType, int, long, GeneratedProjection) - Constructor for class org.apache.flink.table.runtime.operators.python.aggregate.arrow.stream.StreamArrowPythonProcTimeBoundedRowsOperator
- StreamArrowPythonRowTimeBoundedRangeOperator<K> - Class in org.apache.flink.table.runtime.operators.python.aggregate.arrow.stream
-
The Stream Arrow Python
AggregateFunction
Operator for RANGE clause event-time bounded OVER window. - StreamArrowPythonRowTimeBoundedRangeOperator(Configuration, PythonFunctionInfo[], RowType, RowType, RowType, int, long, GeneratedProjection) - Constructor for class org.apache.flink.table.runtime.operators.python.aggregate.arrow.stream.StreamArrowPythonRowTimeBoundedRangeOperator
- StreamArrowPythonRowTimeBoundedRowsOperator<K> - Class in org.apache.flink.table.runtime.operators.python.aggregate.arrow.stream
-
The Stream Arrow Python
AggregateFunction
Operator for RANGE clause event-time bounded OVER window. - StreamArrowPythonRowTimeBoundedRowsOperator(Configuration, long, long, PythonFunctionInfo[], RowType, RowType, RowType, int, long, GeneratedProjection) - Constructor for class org.apache.flink.table.runtime.operators.python.aggregate.arrow.stream.StreamArrowPythonRowTimeBoundedRowsOperator
- StreamRecordRowDataWrappingCollector - Class in org.apache.flink.table.runtime.operators.python.utils
-
The collector is used to convert a
RowData
to aStreamRecord
. - StreamRecordRowDataWrappingCollector(Collector<StreamRecord<RowData>>) - Constructor for class org.apache.flink.table.runtime.operators.python.utils.StreamRecordRowDataWrappingCollector
- STRING - org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TypeName
-
STRING = 1;
- STRING_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TypeName
-
STRING = 1;
- StringSerializer - Class in org.apache.flink.table.runtime.typeutils.serializers.python
-
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() - Constructor for class org.apache.flink.table.runtime.typeutils.serializers.python.StringSerializer
- StringSerializer.StringSerializerSnapshot - Class in org.apache.flink.table.runtime.typeutils.serializers.python
-
Serializer configuration snapshot for compatibility and format evolution.
- StringSerializerSnapshot() - Constructor for class org.apache.flink.table.runtime.typeutils.serializers.python.StringSerializer.StringSerializerSnapshot
- stringToTwoDimByteArray(String) - Static method in class org.apache.flink.table.runtime.arrow.ByteArrayUtils
-
Convert String to byte[][].
- systemEnvEnabled - Variable in class org.apache.flink.streaming.api.operators.python.AbstractPythonFunctionOperator
T
- takeResult() - Method in interface org.apache.flink.python.PythonFunctionRunner
-
Retrieves the Python function result, waiting if necessary until an element becomes available.
- takeResult() - Method in class org.apache.flink.streaming.api.runners.python.beam.BeamPythonFunctionRunner
- TAKES_ROW_AS_INPUT_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction
- TAKES_ROW_AS_INPUT_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction
- TASK_NAME_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext
- TASK_NAME_WITH_SUBTASKS_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext
- TIME - org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TypeName
-
TIME = 9;
- TIME_FIELD_INDEX_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow
- TIME_INFO - org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.TypeInfoCase
- TIME_INFO_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
- TIME_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TypeName
-
TIME = 9;
- TIMER_CODER_ID - Static variable in class org.apache.flink.python.Constants
- TIMER_ID - Static variable in class org.apache.flink.python.Constants
- TimerHandler - Class in org.apache.flink.streaming.api.operators.python.process.timer
-
Utilities to handle triggered timer.
- TimerHandler() - Constructor for class org.apache.flink.streaming.api.operators.python.process.timer.TimerHandler
- TimerRegistration - Class in org.apache.flink.streaming.api.operators.python.process.timer
-
Handles the interaction with the Python worker for registering and deleting timers.
- TimerRegistration(KeyedStateBackend<Row>, InternalTimerService, KeyContext, TypeSerializer, TypeSerializer<Row>) - Constructor for class org.apache.flink.streaming.api.operators.python.process.timer.TimerRegistration
- TimerRegistrationAction - Class in org.apache.flink.streaming.api.operators.python.process.timer
-
TimerRegistrationAction
used to register Timer. - TimerRegistrationAction(TimerRegistration, byte[], List<TimerRegistrationAction>) - Constructor for class org.apache.flink.streaming.api.operators.python.process.timer.TimerRegistrationAction
- TimerUtils - Class in org.apache.flink.streaming.api.operators.python.process.timer
-
Utilities for timer.
- TimerUtils() - Constructor for class org.apache.flink.streaming.api.operators.python.process.timer.TimerUtils
- TimeSerializer - Class in org.apache.flink.table.runtime.typeutils.serializers.python
-
Uses int instead of long as the serialized value.
- TimeSerializer() - Constructor for class org.apache.flink.table.runtime.typeutils.serializers.python.TimeSerializer
- TimeSerializer.TimeSerializerSnapshot - Class in org.apache.flink.table.runtime.typeutils.serializers.python
-
Serializer configuration snapshot for compatibility and format evolution.
- TimeSerializerSnapshot() - Constructor for class org.apache.flink.table.runtime.typeutils.serializers.python.TimeSerializer.TimeSerializerSnapshot
- timestamp - Variable in class org.apache.flink.streaming.api.operators.python.embedded.AbstractOneInputEmbeddedPythonFunctionOperator
- timestamp - Variable in class org.apache.flink.streaming.api.operators.python.embedded.AbstractTwoInputEmbeddedPythonFunctionOperator
- TIMESTAMP - org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TypeName
-
TIMESTAMP = 10;
- TIMESTAMP_INFO - org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.TypeInfoCase
- TIMESTAMP_INFO_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
- TIMESTAMP_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TypeName
-
TIMESTAMP = 10;
- TimestampSerializer - Class in org.apache.flink.table.runtime.typeutils.serializers.python
-
Uses similar serialization/deserialization of SqlTimestampSerializer to serialize Timestamp.
- TimestampSerializer(int) - Constructor for class org.apache.flink.table.runtime.typeutils.serializers.python.TimestampSerializer
- TimestampSerializer.TimestampSerializerSnapshot - Class in org.apache.flink.table.runtime.typeutils.serializers.python
-
TypeSerializerSnapshot
forTimestampSerializer
. - TimestampSerializerSnapshot() - Constructor for class org.apache.flink.table.runtime.typeutils.serializers.python.TimestampSerializer.TimestampSerializerSnapshot
- TimestampWriter<T> - Class in org.apache.flink.table.runtime.arrow.writers
-
ArrowFieldWriter
for Timestamp. - TimestampWriter.TimestampWriterForArray - Class in org.apache.flink.table.runtime.arrow.writers
-
TimestampWriter
forArrayData
input. - TimestampWriter.TimestampWriterForRow - Class in org.apache.flink.table.runtime.arrow.writers
-
TimestampWriter
forRowData
input. - TimeWriter<T> - Class in org.apache.flink.table.runtime.arrow.writers
-
ArrowFieldWriter
for Time. - TimeWriter.TimeWriterForArray - Class in org.apache.flink.table.runtime.arrow.writers
-
TimeWriter
forArrayData
input. - TimeWriter.TimeWriterForRow - Class in org.apache.flink.table.runtime.arrow.writers
-
TimeWriter
forRowData
input. - TINYINT - org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TypeName
-
TINYINT = 1;
- TINYINT_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TypeName
-
TINYINT = 1;
- TinyIntWriter<T> - Class in org.apache.flink.table.runtime.arrow.writers
-
ArrowFieldWriter
for TinyInt. - TinyIntWriter.TinyIntWriterForArray - Class in org.apache.flink.table.runtime.arrow.writers
-
TinyIntWriter
forArrayData
input. - TinyIntWriter.TinyIntWriterForRow - Class in org.apache.flink.table.runtime.arrow.writers
-
TinyIntWriter
forRowData
input. - toArrowSchema(RowType) - Static method in class org.apache.flink.table.runtime.arrow.ArrowUtils
-
Returns the Arrow schema of the specified type.
- toBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.ArrowType
- toBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.FlattenRowType
- toBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.OverWindowArrowType
- toBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RawType
- toBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RowType
- toBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor
- toBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow
- toBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input
- toBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.JobParameter
- toBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow
- toBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.BinaryInfo
- toBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.CharInfo
- toBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.DecimalInfo
- toBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Field
- toBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
- toBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.LocalZonedTimestampInfo
- toBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.MapInfo
- toBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimeInfo
- toBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimestampInfo
- toBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema
- toBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarBinaryInfo
- toBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarCharInfo
- toBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.ZonedTimestampInfo
- toBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategy
- toBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry
- toBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.RocksdbCompactFilterCleanupStrategy
- toBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies
- toBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig
- toBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor
- toBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.AvroTypeInfo
- toBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.MapTypeInfo
- toBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Field
- toBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo
- toBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo
- toBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TupleTypeInfo
- toBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.ListView
- toBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapView
- toBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec
- toBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction
- toBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions
- toBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext
- toBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction
- toBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction
- toBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions
- toConfiguration() - Method in class org.apache.flink.python.PythonConfig
- toDataConverter(LogicalType) - Static method in class org.apache.flink.table.runtime.typeutils.PythonTypeUtils
- toExternal(IN) - Method in class org.apache.flink.streaming.api.utils.PythonTypeUtils.DataConverter
- toExternal(Byte) - Method in class org.apache.flink.streaming.api.utils.PythonTypeUtils.ByteDataConverter
- toExternal(Float) - Method in class org.apache.flink.streaming.api.utils.PythonTypeUtils.FloatDataConverter
- toExternal(Integer) - Method in class org.apache.flink.streaming.api.utils.PythonTypeUtils.IntDataConverter
- toExternal(Short) - Method in class org.apache.flink.streaming.api.utils.PythonTypeUtils.ShortDataConverter
- toExternal(List) - Method in class org.apache.flink.streaming.api.utils.PythonTypeUtils.ListDataConverter
- toExternal(Map<?, ?>) - Method in class org.apache.flink.streaming.api.utils.PythonTypeUtils.MapDataConverter
- toExternal(Tuple) - Method in class org.apache.flink.streaming.api.utils.PythonTypeUtils.TupleDataConverter
- toExternal(RowData) - Method in class org.apache.flink.streaming.api.utils.PythonTypeUtils.RowDataDataConverter
- toExternal(RowData, int) - Method in class org.apache.flink.table.runtime.typeutils.PythonTypeUtils.DataConverter
- toExternal(Row) - Method in class org.apache.flink.streaming.api.utils.PythonTypeUtils.RowDataConverter
- toExternal(T) - Method in class org.apache.flink.streaming.api.utils.PythonTypeUtils.IdentityDataConverter
- toExternal(T[]) - Method in class org.apache.flink.streaming.api.utils.PythonTypeUtils.ArrayDataConverter
- toInternal(Double) - Method in class org.apache.flink.streaming.api.utils.PythonTypeUtils.FloatDataConverter
- toInternal(Long) - Method in class org.apache.flink.streaming.api.utils.PythonTypeUtils.ByteDataConverter
- toInternal(Long) - Method in class org.apache.flink.streaming.api.utils.PythonTypeUtils.IntDataConverter
- toInternal(Long) - Method in class org.apache.flink.streaming.api.utils.PythonTypeUtils.ShortDataConverter
- toInternal(Object[]) - Method in class org.apache.flink.streaming.api.utils.PythonTypeUtils.ArrayDataConverter
- toInternal(Object[]) - Method in class org.apache.flink.streaming.api.utils.PythonTypeUtils.RowDataConverter
- toInternal(Object[]) - Method in class org.apache.flink.streaming.api.utils.PythonTypeUtils.RowDataDataConverter
- toInternal(Object[]) - Method in class org.apache.flink.streaming.api.utils.PythonTypeUtils.TupleDataConverter
- toInternal(List) - Method in class org.apache.flink.streaming.api.utils.PythonTypeUtils.ListDataConverter
- toInternal(Map<?, ?>) - Method in class org.apache.flink.streaming.api.utils.PythonTypeUtils.MapDataConverter
- toInternal(OUT) - Method in class org.apache.flink.streaming.api.utils.PythonTypeUtils.DataConverter
- toInternal(OUT) - Method in class org.apache.flink.table.runtime.typeutils.PythonTypeUtils.DataConverter
- toInternal(T) - Method in class org.apache.flink.streaming.api.utils.PythonTypeUtils.IdentityDataConverter
- toInternalSerializer(LogicalType) - Static method in class org.apache.flink.table.runtime.typeutils.PythonTypeUtils
- toMap() - Method in class org.apache.flink.python.PythonConfig
- toProtoType(LogicalType) - Static method in class org.apache.flink.table.runtime.typeutils.PythonTypeUtils
- toString() - Method in class org.apache.flink.streaming.api.typeinfo.python.PickledByteArrayTypeInfo
- toTypeInfoProto(TypeInformation<?>, ClassLoader) - Static method in class org.apache.flink.streaming.api.utils.PythonTypeUtils.TypeInfoToProtoConverter
-
userClassLoader could be null if no external class loading is needed, e.g. load Avro classes.
- TRANSFORM_ID - Static variable in class org.apache.flink.python.Constants
- translateForBatchInternal(PythonBroadcastStateTransformation<IN1, IN2, OUT>, TransformationTranslator.Context) - Method in class org.apache.flink.streaming.runtime.translators.python.PythonBroadcastStateTransformationTranslator
- translateForBatchInternal(PythonKeyedBroadcastStateTransformation<OUT>, TransformationTranslator.Context) - Method in class org.apache.flink.streaming.runtime.translators.python.PythonKeyedBroadcastStateTransformationTranslator
- translateForStreamingInternal(PythonBroadcastStateTransformation<IN1, IN2, OUT>, TransformationTranslator.Context) - Method in class org.apache.flink.streaming.runtime.translators.python.PythonBroadcastStateTransformationTranslator
- translateForStreamingInternal(PythonKeyedBroadcastStateTransformation<OUT>, TransformationTranslator.Context) - Method in class org.apache.flink.streaming.runtime.translators.python.PythonKeyedBroadcastStateTransformationTranslator
- TTL_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig
- TTL_TIME_CHARACTERISTIC_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig
- TUMBLING_GROUP_WINDOW - org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.WindowType
-
TUMBLING_GROUP_WINDOW = 0;
- TUMBLING_GROUP_WINDOW_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.WindowType
-
TUMBLING_GROUP_WINDOW = 0;
- TUPLE - org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TypeName
-
TUPLE = 17;
- TUPLE_TYPE_INFO - org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TypeInfoCase
- TUPLE_TYPE_INFO_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo
- TUPLE_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TypeName
-
TUPLE = 17;
- twoDimByteArrayToString(byte[][]) - Static method in class org.apache.flink.table.runtime.arrow.ByteArrayUtils
-
Convert byte[][] to String.
- TYPE_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Field
- TYPE_INFO_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RawType
- TYPE_NAME_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
- TYPE_NAME_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo
- TYPEINFO_NOT_SET - org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.TypeInfoCase
- TYPEINFO_NOT_SET - org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TypeInfoCase
- typeInfoDataConverter(TypeInformation<IN>) - Static method in class org.apache.flink.streaming.api.utils.PythonTypeUtils.TypeInfoToDataConverter
- typeInfoSerializerConverter(TypeInformation<T>) - Static method in class org.apache.flink.streaming.api.utils.PythonTypeUtils.TypeInfoToSerializerConverter
- TypeInfoToDataConverter() - Constructor for class org.apache.flink.streaming.api.utils.PythonTypeUtils.TypeInfoToDataConverter
- TypeInfoToProtoConverter() - Constructor for class org.apache.flink.streaming.api.utils.PythonTypeUtils.TypeInfoToProtoConverter
- TypeInfoToSerializerConverter() - Constructor for class org.apache.flink.streaming.api.utils.PythonTypeUtils.TypeInfoToSerializerConverter
U
- UDF - org.apache.flink.fnexecution.v1.FlinkFnApi.Input.InputCase
- UDF_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input
- udfInputOffsets - Variable in class org.apache.flink.table.runtime.operators.python.AbstractEmbeddedStatelessFunctionOperator
-
The offsets of user-defined function inputs.
- udfInputType - Variable in class org.apache.flink.table.runtime.operators.python.AbstractEmbeddedStatelessFunctionOperator
-
The user-defined function input logical type.
- udfInputType - Variable in class org.apache.flink.table.runtime.operators.python.AbstractStatelessFunctionOperator
-
The user-defined function input logical type.
- udfOutputType - Variable in class org.apache.flink.table.runtime.operators.python.AbstractEmbeddedStatelessFunctionOperator
-
The user-defined function output logical type.
- udfOutputType - Variable in class org.apache.flink.table.runtime.operators.python.AbstractStatelessFunctionOperator
-
The user-defined function output logical type.
- UDFS_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions
- UDFS_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions
- UNRECOGNIZED - org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.Mode
- UNRECOGNIZED - org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.WindowProperty
- UNRECOGNIZED - org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.WindowType
- UNRECOGNIZED - org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow.WindowType
- UNRECOGNIZED - org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TypeName
- UNRECOGNIZED - org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.EmptyCleanupStrategy
- UNRECOGNIZED - org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.Strategies
- UNRECOGNIZED - org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.StateVisibility
- UNRECOGNIZED - org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.TtlTimeCharacteristic
- UNRECOGNIZED - org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.UpdateType
- UNRECOGNIZED - org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TypeName
- UNRECOGNIZED - org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.FunctionType
- unsupported() - Static method in interface org.apache.flink.streaming.api.runners.python.beam.state.BeamStateStore
- update(long) - Method in class org.apache.flink.python.metric.embedded.MetricDistribution
- UPDATE_TYPE_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig
- updateMetrics(String, List<MetricsApi.MonitoringInfo>) - Method in class org.apache.flink.python.metric.process.FlinkMetricContainer
-
Update this container with metrics from the passed
MetricsApi.MonitoringInfo
s, and send updates along to Flink's internal metrics framework. - UPPER_BOUNDARY_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow
- USE_MANAGED_MEMORY - Static variable in class org.apache.flink.python.PythonOptions
-
Whether the memory used by the Python framework is managed memory.
- userDefinedFunctionInputArgs - Variable in class org.apache.flink.table.runtime.operators.python.AbstractEmbeddedStatelessFunctionOperator
- userDefinedFunctionInputConverters - Variable in class org.apache.flink.table.runtime.operators.python.AbstractEmbeddedStatelessFunctionOperator
- userDefinedFunctionInputType - Variable in class org.apache.flink.table.runtime.operators.python.aggregate.AbstractPythonStreamAggregateOperator
-
The user-defined function input logical type.
- userDefinedFunctionOutputConverters - Variable in class org.apache.flink.table.runtime.operators.python.AbstractEmbeddedStatelessFunctionOperator
- userDefinedFunctionOutputType - Variable in class org.apache.flink.table.runtime.operators.python.aggregate.AbstractPythonStreamAggregateOperator
-
The user-defined function output logical type.
V
- validate() - Method in class org.apache.flink.client.cli.PythonProgramOptions
- VALUE_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.JobParameter
- VALUE_TYPE_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.MapInfo
- VALUE_TYPE_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.MapTypeInfo
- VALUE_TYPE_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapView
- valueOf(int) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.DataTypeCase
-
Deprecated.
- valueOf(int) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.Mode
-
Deprecated.
- valueOf(int) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.WindowProperty
-
Deprecated.
- valueOf(int) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.WindowType
-
Deprecated.
- valueOf(int) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.Input.InputCase
-
Deprecated.
- valueOf(int) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow.WindowType
-
Deprecated.
- valueOf(int) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.TypeInfoCase
-
Deprecated.
- valueOf(int) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TypeName
-
Deprecated.
- valueOf(int) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.EmptyCleanupStrategy
-
Deprecated.
- valueOf(int) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry.CleanupStrategyCase
-
Deprecated.
- valueOf(int) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.Strategies
-
Deprecated.
- valueOf(int) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.StateVisibility
-
Deprecated.
- valueOf(int) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.TtlTimeCharacteristic
-
Deprecated.
- valueOf(int) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.UpdateType
-
Deprecated.
- valueOf(int) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TypeInfoCase
-
Deprecated.
- valueOf(int) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TypeName
-
Deprecated.
- valueOf(int) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.DataViewCase
-
Deprecated.
- valueOf(int) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.FunctionType
-
Deprecated.
- valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.Mode
-
Returns the enum constant of this type with the specified name.
- valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.WindowProperty
-
Returns the enum constant of this type with the specified name.
- valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.WindowType
-
Returns the enum constant of this type with the specified name.
- valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow.WindowType
-
Returns the enum constant of this type with the specified name.
- valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TypeName
-
Returns the enum constant of this type with the specified name.
- valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.EmptyCleanupStrategy
-
Returns the enum constant of this type with the specified name.
- valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.Strategies
-
Returns the enum constant of this type with the specified name.
- valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.StateVisibility
-
Returns the enum constant of this type with the specified name.
- valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.TtlTimeCharacteristic
-
Returns the enum constant of this type with the specified name.
- valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.UpdateType
-
Returns the enum constant of this type with the specified name.
- valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TypeName
-
Returns the enum constant of this type with the specified name.
- valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.FunctionType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.DataTypeCase
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.Mode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.WindowProperty
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.WindowType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.Input.InputCase
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow.WindowType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.TypeInfoCase
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TypeName
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.EmptyCleanupStrategy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry.CleanupStrategyCase
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.Strategies
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.StateVisibility
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.TtlTimeCharacteristic
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.UpdateType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TypeInfoCase
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TypeName
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.DataViewCase
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.FunctionType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.python.util.ProtoUtils
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.streaming.api.runners.python.beam.state.IterateType
-
Returns the enum constant of this type with the specified name.
- values() - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.DataTypeCase
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.Mode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.WindowProperty
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.WindowType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.Input.InputCase
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow.WindowType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.TypeInfoCase
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TypeName
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.EmptyCleanupStrategy
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry.CleanupStrategyCase
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.Strategies
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.StateVisibility
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.TtlTimeCharacteristic
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.UpdateType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TypeInfoCase
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TypeName
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.DataViewCase
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.FunctionType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.python.util.ProtoUtils
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.streaming.api.runners.python.beam.state.IterateType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- VALUES - org.apache.flink.streaming.api.runners.python.beam.state.IterateType
-
Equivalent to iterate
Map.values()
. - VAR_BINARY_INFO - org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.TypeInfoCase
- VAR_BINARY_INFO_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
- VAR_CHAR_INFO - org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.TypeInfoCase
- VAR_CHAR_INFO_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
- VARBINARY - org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TypeName
-
VARBINARY = 13;
- VARBINARY_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TypeName
-
VARBINARY = 13;
- VarBinaryWriter<T> - Class in org.apache.flink.table.runtime.arrow.writers
-
ArrowFieldWriter
for VarBinary. - VarBinaryWriter.VarBinaryWriterForArray - Class in org.apache.flink.table.runtime.arrow.writers
-
VarBinaryWriter
forArrayData
input. - VarBinaryWriter.VarBinaryWriterForRow - Class in org.apache.flink.table.runtime.arrow.writers
-
VarBinaryWriter
forRowData
input. - VARCHAR - org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TypeName
-
VARCHAR = 15;
- VARCHAR_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TypeName
-
VARCHAR = 15;
- VarCharWriter<T> - Class in org.apache.flink.table.runtime.arrow.writers
-
ArrowFieldWriter
for VarChar. - VarCharWriter.VarCharWriterForArray - Class in org.apache.flink.table.runtime.arrow.writers
-
VarCharWriter
forArrayData
input. - VarCharWriter.VarCharWriterForRow - Class in org.apache.flink.table.runtime.arrow.writers
-
VarCharWriter
forRowData
input. - visit(ArrayType) - Method in class org.apache.flink.table.runtime.typeutils.PythonTypeUtils.LogicalTypeToProtoTypeConverter
- visit(BigIntType) - Method in class org.apache.flink.table.runtime.typeutils.PythonTypeUtils.LogicalTypeToProtoTypeConverter
- visit(BinaryType) - Method in class org.apache.flink.table.runtime.typeutils.PythonTypeUtils.LogicalTypeToProtoTypeConverter
- visit(BooleanType) - Method in class org.apache.flink.table.runtime.typeutils.PythonTypeUtils.LogicalTypeToProtoTypeConverter
- visit(CharType) - Method in class org.apache.flink.table.runtime.typeutils.PythonTypeUtils.LogicalTypeToProtoTypeConverter
- visit(DateType) - Method in class org.apache.flink.table.runtime.typeutils.PythonTypeUtils.LogicalTypeToProtoTypeConverter
- visit(DecimalType) - Method in class org.apache.flink.table.runtime.typeutils.PythonTypeUtils.LogicalTypeToProtoTypeConverter
- visit(DoubleType) - Method in class org.apache.flink.table.runtime.typeutils.PythonTypeUtils.LogicalTypeToProtoTypeConverter
- visit(FloatType) - Method in class org.apache.flink.table.runtime.typeutils.PythonTypeUtils.LogicalTypeToProtoTypeConverter
- visit(IntType) - Method in class org.apache.flink.table.runtime.typeutils.PythonTypeUtils.LogicalTypeToProtoTypeConverter
- visit(LocalZonedTimestampType) - Method in class org.apache.flink.table.runtime.typeutils.PythonTypeUtils.LogicalTypeToProtoTypeConverter
- visit(MapType) - Method in class org.apache.flink.table.runtime.typeutils.PythonTypeUtils.LogicalTypeToProtoTypeConverter
- visit(RowType) - Method in class org.apache.flink.table.runtime.typeutils.PythonTypeUtils.LogicalTypeToProtoTypeConverter
- visit(SmallIntType) - Method in class org.apache.flink.table.runtime.typeutils.PythonTypeUtils.LogicalTypeToProtoTypeConverter
- visit(TimestampType) - Method in class org.apache.flink.table.runtime.typeutils.PythonTypeUtils.LogicalTypeToProtoTypeConverter
- visit(TimeType) - Method in class org.apache.flink.table.runtime.typeutils.PythonTypeUtils.LogicalTypeToProtoTypeConverter
- visit(TinyIntType) - Method in class org.apache.flink.table.runtime.typeutils.PythonTypeUtils.LogicalTypeToProtoTypeConverter
- visit(VarBinaryType) - Method in class org.apache.flink.table.runtime.typeutils.PythonTypeUtils.LogicalTypeToProtoTypeConverter
- visit(VarCharType) - Method in class org.apache.flink.table.runtime.typeutils.PythonTypeUtils.LogicalTypeToProtoTypeConverter
W
- watchdog - Static variable in class org.apache.flink.client.python.PythonGatewayServer
-
This watchdog object is provided to Python side to check whether its parent process is alive.
- WINDOW - org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.FunctionType
-
WINDOW = 4;
- WINDOW_CODER_ID - Static variable in class org.apache.flink.python.Constants
- WINDOW_END - org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.WindowProperty
-
WINDOW_END = 1;
- WINDOW_END_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.WindowProperty
-
WINDOW_END = 1;
- WINDOW_GAP_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow
- WINDOW_INDEX_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction
- WINDOW_SIZE_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow
- WINDOW_SLIDE_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow
- WINDOW_START - org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.WindowProperty
-
WINDOW_START = 0;
- WINDOW_START_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.WindowProperty
-
WINDOW_START = 0;
- WINDOW_STRATEGY - Static variable in class org.apache.flink.python.Constants
- WINDOW_TYPE_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow
- WINDOW_TYPE_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow
- WINDOW_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.FunctionType
-
WINDOW = 4;
- WINDOWS_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions
- withTypeInfo(TypeInformation<Row>) - Method in class org.apache.flink.formats.json.JsonRowSerializationSchema.Builder
-
Sets type information for JSON serialization schema.
- WRAPPER_TIMER_CODER_ID - Static variable in class org.apache.flink.python.Constants
- write(IN) - Method in class org.apache.flink.table.runtime.arrow.ArrowWriter
-
Writes the specified row which is serialized into Arrow format.
- write(IN, int) - Method in class org.apache.flink.table.runtime.arrow.writers.ArrowFieldWriter
-
Writes the specified ordinal of the specified row.
- write(RowData) - Method in class org.apache.flink.table.runtime.arrow.serializers.ArrowSerializer
- writeSnapshot(DataOutputView) - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.ArrayDataSerializer.ArrayDataSerializerSnapshot
- writeSnapshot(DataOutputView) - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.DecimalDataSerializer.DecimalSerializerSnapshot
- writeSnapshot(DataOutputView) - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.MapDataSerializer.BaseMapSerializerSnapshot
- writeSnapshot(DataOutputView) - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.RowDataSerializer.RowDataSerializerSnapshot
- writeSnapshot(DataOutputView) - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.TimestampSerializer.TimestampSerializerSnapshot
- writeTo(CodedOutputStream) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.ArrowType
- writeTo(CodedOutputStream) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.FlattenRowType
- writeTo(CodedOutputStream) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.OverWindowArrowType
- writeTo(CodedOutputStream) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RawType
- writeTo(CodedOutputStream) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor.RowType
- writeTo(CodedOutputStream) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderInfoDescriptor
- writeTo(CodedOutputStream) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow
- writeTo(CodedOutputStream) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input
- writeTo(CodedOutputStream) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.JobParameter
- writeTo(CodedOutputStream) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow
- writeTo(CodedOutputStream) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.BinaryInfo
- writeTo(CodedOutputStream) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.CharInfo
- writeTo(CodedOutputStream) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.DecimalInfo
- writeTo(CodedOutputStream) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Field
- writeTo(CodedOutputStream) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
- writeTo(CodedOutputStream) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.LocalZonedTimestampInfo
- writeTo(CodedOutputStream) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.MapInfo
- writeTo(CodedOutputStream) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimeInfo
- writeTo(CodedOutputStream) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimestampInfo
- writeTo(CodedOutputStream) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarBinaryInfo
- writeTo(CodedOutputStream) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarCharInfo
- writeTo(CodedOutputStream) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema
- writeTo(CodedOutputStream) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.ZonedTimestampInfo
- writeTo(CodedOutputStream) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.IncrementalCleanupStrategy
- writeTo(CodedOutputStream) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.MapStrategiesEntry
- writeTo(CodedOutputStream) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies.RocksdbCompactFilterCleanupStrategy
- writeTo(CodedOutputStream) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig.CleanupStrategies
- writeTo(CodedOutputStream) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor.StateTTLConfig
- writeTo(CodedOutputStream) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.StateDescriptor
- writeTo(CodedOutputStream) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.AvroTypeInfo
- writeTo(CodedOutputStream) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.MapTypeInfo
- writeTo(CodedOutputStream) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Field
- writeTo(CodedOutputStream) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo
- writeTo(CodedOutputStream) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TupleTypeInfo
- writeTo(CodedOutputStream) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo
- writeTo(CodedOutputStream) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.ListView
- writeTo(CodedOutputStream) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapView
- writeTo(CodedOutputStream) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec
- writeTo(CodedOutputStream) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction
- writeTo(CodedOutputStream) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions
- writeTo(CodedOutputStream) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext
- writeTo(CodedOutputStream) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction
- writeTo(CodedOutputStream) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction
- writeTo(CodedOutputStream) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions
Z
- ZONED_TIMESTAMP - org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TypeName
-
ZONED_TIMESTAMP = 20;
- ZONED_TIMESTAMP_INFO - org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.TypeInfoCase
- ZONED_TIMESTAMP_INFO_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
- ZONED_TIMESTAMP_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TypeName
-
ZONED_TIMESTAMP = 20;
All Classes All Packages