Skip navigation links
A B C D E F G H I J K L M N O P R S T U V W Z 

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, int[], int[]) - Constructor for class org.apache.flink.table.runtime.operators.python.aggregate.arrow.AbstractArrowPythonAggregateFunctionOperator
 
AbstractArrowSourceFunction<OUT> - Class in org.apache.flink.table.runtime.arrow.sources
An Arrow SourceFunction which takes the serialized arrow record batch data as input.
AbstractArrowTableSource<T> - Class in org.apache.flink.table.runtime.arrow.sources
A StreamTableSource for serialized arrow record batch data.
AbstractOneInputPythonFunctionOperator<IN,OUT> - Class in org.apache.flink.streaming.api.operators.python
Base class for all one input stream operators to execute Python functions.
AbstractOneInputPythonFunctionOperator(Configuration) - Constructor for class org.apache.flink.streaming.api.operators.python.AbstractOneInputPythonFunctionOperator
 
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
 
AbstractPythonScalarFunctionFlatMap - Class in org.apache.flink.table.runtime.functions.python
The abstract base RichFlatMapFunction used to invoke Python ScalarFunction functions for the old planner.
AbstractPythonScalarFunctionFlatMap(Configuration, PythonFunctionInfo[], RowType, RowType, int[], int[]) - Constructor for class org.apache.flink.table.runtime.functions.python.AbstractPythonScalarFunctionFlatMap
 
AbstractPythonScalarFunctionOperator<IN,OUT,UDFIN> - Class in org.apache.flink.table.runtime.operators.python.scalar
Base class for all stream operators to execute Python ScalarFunctions.
AbstractPythonStatelessFunctionFlatMap - Class in org.apache.flink.table.runtime.functions.python
Base Python stateless RichFlatMapFunction used to invoke Python stateless functions for the old planner.
AbstractPythonStatelessFunctionFlatMap(Configuration, RowType, RowType, int[]) - Constructor for class org.apache.flink.table.runtime.functions.python.AbstractPythonStatelessFunctionFlatMap
 
AbstractPythonStreamAggregateOperator - Class in org.apache.flink.table.runtime.operators.python.aggregate
AbstractPythonStreamAggregateOperator(Configuration, RowType, RowType, PythonAggregateFunctionInfo[], DataViewUtils.DataViewSpec[][], int[], int, boolean, String, FlinkFnApi.CoderParam.OutputMode) - Constructor for class org.apache.flink.table.runtime.operators.python.aggregate.AbstractPythonStreamAggregateOperator
 
AbstractPythonStreamGroupAggregateOperator - Class in org.apache.flink.table.runtime.operators.python.aggregate
AbstractPythonStreamGroupAggregateOperator(Configuration, RowType, RowType, PythonAggregateFunctionInfo[], DataViewUtils.DataViewSpec[][], int[], int, boolean, long, long, FlinkFnApi.CoderParam.OutputMode) - Constructor for class org.apache.flink.table.runtime.operators.python.aggregate.AbstractPythonStreamGroupAggregateOperator
 
AbstractPythonTableFunctionOperator<IN,OUT,UDTFIN> - Class in org.apache.flink.table.runtime.operators.python.table
 
AbstractPythonTableFunctionOperator(Configuration, PythonFunctionInfo, RowType, RowType, int[], FlinkJoinType) - Constructor for class org.apache.flink.table.runtime.operators.python.table.AbstractPythonTableFunctionOperator
 
AbstractRowDataPythonScalarFunctionOperator - Class in org.apache.flink.table.runtime.operators.python.scalar
The Python ScalarFunction operator for the blink planner.
AbstractRowDataPythonScalarFunctionOperator(Configuration, PythonFunctionInfo[], RowType, RowType, int[], int[]) - Constructor for class org.apache.flink.table.runtime.operators.python.scalar.AbstractRowDataPythonScalarFunctionOperator
 
AbstractRowPythonScalarFunctionOperator - Class in org.apache.flink.table.runtime.operators.python.scalar
Base Python ScalarFunction operator for the legacy planner.
AbstractRowPythonScalarFunctionOperator(Configuration, PythonFunctionInfo[], RowType, RowType, int[], int[]) - Constructor for class org.apache.flink.table.runtime.operators.python.scalar.AbstractRowPythonScalarFunctionOperator
 
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, int[]) - 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, int, long, int[], int[]) - 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, int, long, int[], int[]) - 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, int, long, int[], int[]) - Constructor for class org.apache.flink.table.runtime.operators.python.aggregate.arrow.stream.AbstractStreamArrowPythonOverWindowAggregateFunctionOperator
 
AbstractTwoInputPythonFunctionOperator<IN1,IN2,OUT> - Class in org.apache.flink.streaming.api.operators.python
Base class for all two input stream operators to execute Python functions.
AbstractTwoInputPythonFunctionOperator(Configuration) - Constructor for class org.apache.flink.streaming.api.operators.python.AbstractTwoInputPythonFunctionOperator
 
accept(Row, long) - Method in class org.apache.flink.streaming.api.utils.output.OutputWithTimerRowHandler
 
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.UserDefinedDataStreamFunction.JobParameter>) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder
repeated .org.apache.flink.fn_execution.v1.UserDefinedDataStreamFunction.JobParameter job_parameters = 7;
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;
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(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) - 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(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(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) - 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;
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;
addFieldsBuilder() - 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.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.TypeInfo.RowTypeInfo.Builder
repeated .org.apache.flink.fn_execution.v1.TypeInfo.RowTypeInfo.Field fields = 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(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(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(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;
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(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.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.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.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(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(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(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.
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(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() - 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.UserDefinedFunction.Builder
The input arguments of the user-defined function, it could be one of the following: 1.
addJobParameters(FlinkFnApi.UserDefinedDataStreamFunction.JobParameter) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder
repeated .org.apache.flink.fn_execution.v1.UserDefinedDataStreamFunction.JobParameter job_parameters = 7;
addJobParameters(int, FlinkFnApi.UserDefinedDataStreamFunction.JobParameter) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder
repeated .org.apache.flink.fn_execution.v1.UserDefinedDataStreamFunction.JobParameter job_parameters = 7;
addJobParameters(FlinkFnApi.UserDefinedDataStreamFunction.JobParameter.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder
repeated .org.apache.flink.fn_execution.v1.UserDefinedDataStreamFunction.JobParameter job_parameters = 7;
addJobParameters(int, FlinkFnApi.UserDefinedDataStreamFunction.JobParameter.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder
repeated .org.apache.flink.fn_execution.v1.UserDefinedDataStreamFunction.JobParameter job_parameters = 7;
addJobParametersBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder
repeated .org.apache.flink.fn_execution.v1.UserDefinedDataStreamFunction.JobParameter job_parameters = 7;
addJobParametersBuilder(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder
repeated .org.apache.flink.fn_execution.v1.UserDefinedDataStreamFunction.JobParameter job_parameters = 7;
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.CoderParam.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.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.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.JobParameter.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
 
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(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(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(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;
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;
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(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(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.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(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(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(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;
addUdfsBuilder() - 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.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.UserDefinedFunctions.Builder
repeated .org.apache.flink.fn_execution.v1.UserDefinedFunction udfs = 1;
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(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(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(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;
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;
ALLOWEDLATENESS_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow
 
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 for ArrayData.
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 for ArrayDataSerializer.
ArrayDataSerializerSnapshot() - Constructor for class org.apache.flink.table.runtime.typeutils.serializers.python.ArrayDataSerializer.ArrayDataSerializerSnapshot
 
ArrayFieldReader - Class in org.apache.flink.table.runtime.arrow.readers
ArrowFieldReader for Array.
ArrayFieldReader(ListVector, ArrowFieldReader, LogicalType) - Constructor for class org.apache.flink.table.runtime.arrow.readers.ArrayFieldReader
 
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 for ArrayData input.
ArrayWriter.ArrayWriterForRow - Class in org.apache.flink.table.runtime.arrow.writers
ArrayWriter for RowData input.
ARROW_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam.DataType
ARROW = 3;
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
 
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
 
ArrowFieldReader<OUT> - Class in org.apache.flink.table.runtime.arrow.readers
Base class for arrow field reader.
ArrowFieldReader(ValueVector) - Constructor for class org.apache.flink.table.runtime.arrow.readers.ArrowFieldReader
 
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
 
ArrowPythonScalarFunctionFlatMap - Class in org.apache.flink.table.runtime.functions.python.arrow
The RichFlatMapFunction used to invoke Arrow Python ScalarFunction functions for the old planner.
ArrowPythonScalarFunctionFlatMap(Configuration, PythonFunctionInfo[], RowType, RowType, int[], int[]) - Constructor for class org.apache.flink.table.runtime.functions.python.arrow.ArrowPythonScalarFunctionFlatMap
 
ArrowPythonScalarFunctionOperator - Class in org.apache.flink.table.runtime.operators.python.scalar.arrow
Arrow Python ScalarFunction operator for the old planner.
ArrowPythonScalarFunctionOperator(Configuration, PythonFunctionInfo[], RowType, RowType, int[], int[]) - Constructor for class org.apache.flink.table.runtime.operators.python.scalar.arrow.ArrowPythonScalarFunctionOperator
 
ArrowReader<OUT> - Interface in org.apache.flink.table.runtime.arrow
Reader which deserialize the Arrow format data to the Flink rows.
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<T> - 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
 
arrowSerializer - Variable in class org.apache.flink.table.runtime.operators.python.aggregate.arrow.AbstractArrowPythonAggregateFunctionOperator
 
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
An Arrow SourceFunction which takes RowData as the type of the produced records.
ArrowTableSource - Class in org.apache.flink.table.runtime.arrow.sources
An Arrow TableSource which takes RowData as the type of the produced records.
ArrowTableSource(DataType, byte[][]) - Constructor for class org.apache.flink.table.runtime.arrow.sources.ArrowTableSource
 
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
 
ATTEMPT_NUMBER_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext
 

B

bais - Variable in class org.apache.flink.streaming.api.operators.python.OneInputPythonFunctionOperator
Reusable InputStream used to holding the execution results to be deserialized.
bais - Variable in class org.apache.flink.streaming.api.operators.python.TwoInputPythonFunctionOperator
 
bais - Variable in class org.apache.flink.table.runtime.functions.python.AbstractPythonStatelessFunctionFlatMap
Reusable InputStream used to holding the execution results to be deserialized.
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.streaming.api.operators.python.OneInputPythonFunctionOperator
InputStream Wrapper.
baisWrapper - Variable in class org.apache.flink.streaming.api.operators.python.TwoInputPythonFunctionOperator
 
baisWrapper - Variable in class org.apache.flink.table.runtime.functions.python.AbstractPythonStatelessFunctionFlatMap
InputStream Wrapper.
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.OneInputPythonFunctionOperator
Reusable OutputStream used to holding the serialized input elements.
baos - Variable in class org.apache.flink.streaming.api.operators.python.TwoInputPythonFunctionOperator
 
baos - Variable in class org.apache.flink.table.runtime.functions.python.AbstractPythonStatelessFunctionFlatMap
Reusable OutputStream used to holding the serialized input elements.
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.OneInputPythonFunctionOperator
OutputStream Wrapper.
baosWrapper - Variable in class org.apache.flink.streaming.api.operators.python.TwoInputPythonFunctionOperator
 
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.
BaseMapSerializerSnapshot() - Constructor for class org.apache.flink.table.runtime.typeutils.serializers.python.MapDataSerializer.BaseMapSerializerSnapshot
 
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;
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, int[], int[], int[]) - 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, int, int, long, long, int[], int[], int[], int[]) - 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, long[], long[], boolean[], int[], int[], int[], int[], int, boolean) - Constructor for class org.apache.flink.table.runtime.operators.python.aggregate.arrow.batch.BatchArrowPythonOverWindowAggregateFunctionOperator
 
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(String, PythonEnvironmentManager, TypeInformation, TypeInformation, String, FlinkFnApi.UserDefinedDataStreamFunction, String, Map<String, String>, FlinkMetricContainer, KeyedStateBackend, TypeSerializer, TypeSerializer, MemoryManager, double) - Constructor for class org.apache.flink.streaming.api.runners.python.beam.BeamDataStreamPythonFunctionRunner
 
BeamPythonFunctionRunner - Class in org.apache.flink.streaming.api.runners.python.beam
A BeamPythonFunctionRunner used to execute Python functions.
BeamPythonFunctionRunner(String, PythonEnvironmentManager, String, Map<String, String>, FlinkMetricContainer, KeyedStateBackend, TypeSerializer, TypeSerializer, MemoryManager, double, FlinkFnApi.CoderParam.OutputMode) - Constructor for class org.apache.flink.streaming.api.runners.python.beam.BeamPythonFunctionRunner
 
BeamTableStatefulPythonFunctionRunner - Class in org.apache.flink.table.runtime.runners.python.beam
A BeamTableStatefulPythonFunctionRunner used to execute Python stateful functions.
BeamTableStatefulPythonFunctionRunner(String, PythonEnvironmentManager, RowType, RowType, String, FlinkFnApi.UserDefinedAggregateFunctions, String, Map<String, String>, FlinkMetricContainer, KeyedStateBackend, TypeSerializer, TypeSerializer, MemoryManager, double, FlinkFnApi.CoderParam.OutputMode) - Constructor for class org.apache.flink.table.runtime.runners.python.beam.BeamTableStatefulPythonFunctionRunner
 
BeamTableStatelessPythonFunctionRunner - Class in org.apache.flink.table.runtime.runners.python.beam
A BeamTableStatelessPythonFunctionRunner used to execute Python stateless functions.
BeamTableStatelessPythonFunctionRunner(String, PythonEnvironmentManager, RowType, RowType, String, FlinkFnApi.UserDefinedFunctions, String, Map<String, String>, FlinkMetricContainer, MemoryManager, double, FlinkFnApi.CoderParam.OutputMode) - Constructor for class org.apache.flink.table.runtime.runners.python.beam.BeamTableStatelessPythonFunctionRunner
 
BIG_DEC_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TypeName
BIG_DEC = 11;
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_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TypeName
BIGINT = 4;
BigIntFieldReader - Class in org.apache.flink.table.runtime.arrow.readers
ArrowFieldReader for BigInt.
BigIntFieldReader(BigIntVector) - Constructor for class org.apache.flink.table.runtime.arrow.readers.BigIntFieldReader
 
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 for ArrayData input.
BigIntWriter.BigIntWriterForRow - Class in org.apache.flink.table.runtime.arrow.writers
BigIntWriter for RowData input.
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;
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;
BooleanFieldReader - Class in org.apache.flink.table.runtime.arrow.readers
ArrowFieldReader for Boolean.
BooleanFieldReader(BitVector) - Constructor for class org.apache.flink.table.runtime.arrow.readers.BooleanFieldReader
 
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 for ArrayData input.
BooleanWriter.BooleanWriterForRow - Class in org.apache.flink.table.runtime.arrow.writers
BooleanWriter for RowData input.
bufferInput(Row) - Method in class org.apache.flink.table.runtime.functions.python.AbstractPythonScalarFunctionFlatMap
 
bufferInput(Row) - Method in class org.apache.flink.table.runtime.functions.python.AbstractPythonStatelessFunctionFlatMap
 
bufferInput(Row) - Method in class org.apache.flink.table.runtime.functions.python.PythonTableFunctionFlatMap
 
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.AbstractRowDataPythonScalarFunctionOperator
 
bufferInput(CRow) - Method in class org.apache.flink.table.runtime.operators.python.scalar.AbstractRowPythonScalarFunctionOperator
 
bufferInput(CRow) - Method in class org.apache.flink.table.runtime.operators.python.table.PythonTableFunctionOperator
 
bufferInput(RowData) - Method in class org.apache.flink.table.runtime.operators.python.table.RowDataPythonTableFunctionOperator
 
build() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam.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.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.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.JobParameter.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
 
buildPartial() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam.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.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.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.JobParameter.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
 
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
 
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
 

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.AbstractArrowSourceFunction
 
canEqual(Object) - Method in class org.apache.flink.streaming.api.typeinfo.python.PickledByteArrayTypeInfo
 
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.
checkInvokeFinishBundleByCount() - Method in class org.apache.flink.table.runtime.functions.python.AbstractPythonStatelessFunctionFlatMap
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
 
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.
clear() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam.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.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.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.JobParameter.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;
clearAttemptNumber() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder
int32 attempt_number = 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;
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.
clearDataInfo() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam.Builder
 
clearDataType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam.Builder
.org.apache.flink.fn_execution.v1.CoderParam.DataType data_type = 3;
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;
clearField(Descriptors.FieldDescriptor) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam.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.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.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.JobParameter.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;
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.
clearInBatchExecutionMode() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder
bool in_batch_execution_mode = 8;
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.
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.UserDefinedDataStreamFunction.RuntimeContext.Builder
repeated .org.apache.flink.fn_execution.v1.UserDefinedDataStreamFunction.JobParameter job_parameters = 7;
clearKey() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.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.
clearMapStateWriteCacheSize() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.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;
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.CoderParam.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.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.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.JobParameter.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
 
clearOutputMode() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam.Builder
.org.apache.flink.fn_execution.v1.CoderParam.OutputMode output_mode = 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;
clearRowSchema() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
.org.apache.flink.fn_execution.v1.Schema row_schema = 5;
clearRowTypeInfo() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.Builder
.org.apache.flink.fn_execution.v1.TypeInfo.RowTypeInfo row_type_info = 3;
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.CoderParam.Builder
.org.apache.flink.fn_execution.v1.Schema schema = 1;
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.
clearStateCleaningEnabled() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
Cleanup the expired state if true.
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;
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.CoderParam.Builder
.org.apache.flink.fn_execution.v1.TypeInfo type_info = 2;
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;
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.UserDefinedDataStreamFunction.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.CoderParam.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.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.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.JobParameter.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.state.GrpcStateService
 
close(T) - Method in interface org.apache.beam.vendor.grpc.v1p26p0.io.grpc.internal.SharedResourceHolder.Resource
Destroy the given instance.
close() - Method in class org.apache.flink.client.python.PythonFunctionFactoryImpl
 
close() - Method in class org.apache.flink.python.env.beam.ProcessPythonEnvironmentManager
 
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.PythonTimestampsAndWatermarksOperator
 
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.AbstractArrowSourceFunction
 
close() - Method in class org.apache.flink.table.runtime.functions.python.AbstractPythonStatelessFunctionFlatMap
 
close() - Method in class org.apache.flink.table.runtime.functions.python.arrow.ArrowPythonScalarFunctionFlatMap
 
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.scalar.arrow.RowDataArrowPythonScalarFunctionOperator
 
close() - Method in class org.apache.flink.table.runtime.operators.python.utils.StreamRecordCRowWrappingCollector
 
close() - Method in class org.apache.flink.table.runtime.operators.python.utils.StreamRecordRowDataWrappingCollector
 
CO_FLAT_MAP_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.FunctionType
CO_FLAT_MAP = 3;
CO_MAP_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.FunctionType
CO_MAP = 2;
collect(Row) - Method in class org.apache.flink.table.runtime.operators.python.utils.StreamRecordCRowWrappingCollector
 
collect(RowData) - Method in class org.apache.flink.table.runtime.operators.python.utils.StreamRecordRowDataWrappingCollector
 
collectAsPandasDataFrame(Table, int) - Static method in class org.apache.flink.table.runtime.arrow.ArrowUtils
Convert Flink table to Pandas DataFrame.
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.OneInputPythonFunctionOperator
 
collector - Variable in class org.apache.flink.streaming.api.operators.python.TwoInputPythonFunctionOperator
 
configPythonOperator(StreamExecutionEnvironment) - Static method in class org.apache.flink.python.util.PythonConfigUtil
 
configureEmitProgressiveWatermarks(boolean) - Method in class org.apache.flink.streaming.api.operators.python.PythonTimestampsAndWatermarksOperator
 
configurePythonDependencies(List<Tuple2<String, DistributedCache.DistributedCacheEntry>>, Configuration) - 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.
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
 
convertLiteralToPython(RexLiteral, SqlTypeName) - Static method in class org.apache.flink.api.common.python.PythonBridgeUtils
 
copy() - Method in class org.apache.flink.streaming.api.utils.ByteArrayWrapper
 
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(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(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(DataInputView, DataOutputView) - 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(DataInputView, DataOutputView) - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.DateSerializer
 
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
 
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(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(DataInputView, DataOutputView) - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.StringSerializer
 
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(DataInputView, DataOutputView) - 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.table.runtime.typeutils.serializers.python.TimestampSerializer
 
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.v1p26p0.io.grpc.internal.SharedResourceHolder.Resource
Create a new instance of the resource.
create(PythonConfig, 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) - Method in class org.apache.flink.table.runtime.arrow.serializers.RowArrowSerializer
 
createArrowReader(VectorSchemaRoot) - Method in class org.apache.flink.table.runtime.arrow.serializers.RowDataArrowSerializer
 
createArrowTableSource(DataType, String) - Static method in class org.apache.flink.table.runtime.arrow.ArrowUtils
 
createArrowWriter() - Method in class org.apache.flink.table.runtime.arrow.serializers.ArrowSerializer
Creates an ArrowWriter.
createArrowWriter() - Method in class org.apache.flink.table.runtime.arrow.serializers.RowArrowSerializer
 
createArrowWriter() - Method in class org.apache.flink.table.runtime.arrow.serializers.RowDataArrowSerializer
 
createColumnVector(ValueVector, LogicalType) - Static method in class org.apache.flink.table.runtime.arrow.ArrowUtils
 
createEnvironment() - Method in class org.apache.flink.python.env.beam.ProcessPythonEnvironmentManager
 
createEnvironment() - Method in interface org.apache.flink.python.env.PythonEnvironmentManager
Creates the PythonEnvironment object used in PythonFunctionRunner.
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
 
createPythonEnvironmentManager() - Method in class org.apache.flink.streaming.api.operators.python.AbstractPythonFunctionOperator
 
createPythonEnvironmentManager() - Method in class org.apache.flink.table.runtime.functions.python.AbstractPythonStatelessFunctionFlatMap
 
createPythonFunctionFactory(ReadableConfig) - Static method in interface org.apache.flink.client.python.PythonFunctionFactory
 
createPythonFunctionRunner() - Method in class org.apache.flink.streaming.api.operators.python.AbstractPythonFunctionOperator
Creates the PythonFunctionRunner which is responsible for Python user-defined function execution.
createPythonFunctionRunner() - Method in class org.apache.flink.streaming.api.operators.python.OneInputPythonFunctionOperator
 
createPythonFunctionRunner() - Method in class org.apache.flink.streaming.api.operators.python.PythonKeyedCoProcessOperator
 
createPythonFunctionRunner() - Method in class org.apache.flink.streaming.api.operators.python.PythonKeyedProcessOperator
 
createPythonFunctionRunner() - Method in class org.apache.flink.streaming.api.operators.python.TwoInputPythonFunctionOperator
 
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
 
createRetrievalToken() - Method in class org.apache.flink.python.env.beam.ProcessPythonEnvironmentManager
Returns an empty RetrievalToken because no files will be transmit via ArtifactService in process mode.
createRetrievalToken() - Method in interface org.apache.flink.python.env.PythonEnvironmentManager
Creates the RetrievalToken used in PythonFunctionRunner.
createRowArrowFieldReader(ValueVector, LogicalType) - Static method in class org.apache.flink.table.runtime.arrow.ArrowUtils
 
createRowArrowReader(VectorSchemaRoot, RowType) - Static method in class org.apache.flink.table.runtime.arrow.ArrowUtils
Creates an ArrowReader for the specified VectorSchemaRoot.
createRowArrowWriter(VectorSchemaRoot, RowType) - Static method in class org.apache.flink.table.runtime.arrow.ArrowUtils
Creates an ArrowWriter for the specified VectorSchemaRoot.
createRowDataArrowReader(VectorSchemaRoot, RowType) - Static method in class org.apache.flink.table.runtime.arrow.ArrowUtils
Creates an ArrowReader for blink planner for the specified VectorSchemaRoot.
createRowDataArrowWriter(VectorSchemaRoot, RowType) - Static method in class org.apache.flink.table.runtime.arrow.ArrowUtils
Creates an ArrowWriter for blink planner for the specified VectorSchemaRoot.
createSerializer(ExecutionConfig) - Method in class org.apache.flink.streaming.api.typeinfo.python.PickledByteArrayTypeInfo
 
cRowWrapper - Variable in class org.apache.flink.table.runtime.operators.python.scalar.AbstractRowPythonScalarFunctionOperator
The collector used to collect records.
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.
CustomFormatDescriptor - Class in org.apache.flink.table.descriptors.python
Describes the custom format of data.
CustomFormatDescriptor(String, int) - Constructor for class org.apache.flink.table.descriptors.python.CustomFormatDescriptor

D

DATA_STREAM_STATELESS_FUNCTION_URN - Static variable in class org.apache.flink.streaming.api.operators.python.OneInputPythonFunctionOperator
 
DATA_TYPE_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam
 
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
 
DATE_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TypeName
DATE = 8;
DateFieldReader - Class in org.apache.flink.table.runtime.arrow.readers
DateFieldReader(DateDayVector) - Constructor for class org.apache.flink.table.runtime.arrow.readers.DateFieldReader
 
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
 
dateToInternal(Date) - Static method in class org.apache.flink.table.runtime.typeutils.PythonTypeUtils
Converts the Java type used for UDF parameters of SQL DATE type (Date) to internal representation (int).
DateWriter<T> - Class in org.apache.flink.table.runtime.arrow.writers
DateWriter.DateWriterForArray - Class in org.apache.flink.table.runtime.arrow.writers
DateWriter for ArrayData input.
DateWriter.DateWriterForRow - Class in org.apache.flink.table.runtime.arrow.writers
DateWriter for RowData input.
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-blink 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 for DecimalDataSerializer.
DecimalFieldReader - Class in org.apache.flink.table.runtime.arrow.readers
ArrowFieldReader for Decimal.
DecimalFieldReader(DecimalVector) - Constructor for class org.apache.flink.table.runtime.arrow.readers.DecimalFieldReader
 
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 for ArrayData input.
DecimalWriter.DecimalWriterForRow - Class in org.apache.flink.table.runtime.arrow.writers
DecimalWriter for RowData input.
declareManagedMemory(Transformation<?>, StreamExecutionEnvironment, TableConfig) - Static method in class org.apache.flink.python.util.PythonConfigUtil
Set Python Operator Use Managed Memory.
defaultMethod(LogicalType) - Method in class org.apache.flink.table.runtime.typeutils.PythonTypeUtils.LogicalTypeToConversionClassConverter
 
defaultMethod(LogicalType) - Method in class org.apache.flink.table.runtime.typeutils.PythonTypeUtils.LogicalTypeToProtoTypeConverter
 
DESCRIPTION_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Field
 
deserialize(DataInputView) - Method in class org.apache.flink.streaming.api.utils.ByteArrayWrapperSerializer
 
deserialize(ByteArrayWrapper, 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(ArrayData, 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(BigDecimal, 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(Date, 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(DecimalData, 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(MapData, 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(RowData, 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(String, 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(Time, 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(Timestamp, DataInputView) - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.TimestampSerializer
 
dispose() - Method in class org.apache.flink.streaming.api.operators.python.AbstractPythonFunctionOperator
 
dispose() - Method in class org.apache.flink.table.runtime.operators.python.aggregate.arrow.AbstractArrowPythonAggregateFunctionOperator
 
dispose() - Method in class org.apache.flink.table.runtime.operators.python.scalar.arrow.ArrowPythonScalarFunctionOperator
 
dispose() - Method in class org.apache.flink.table.runtime.operators.python.scalar.arrow.RowDataArrowPythonScalarFunctionOperator
 
DISTINCT_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction
 
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;
DoubleFieldReader - Class in org.apache.flink.table.runtime.arrow.readers
ArrowFieldReader for Double.
DoubleFieldReader(Float8Vector) - Constructor for class org.apache.flink.table.runtime.arrow.readers.DoubleFieldReader
 
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 for ArrayData input.
DoubleWriter.DoubleWriterForRow - Class in org.apache.flink.table.runtime.arrow.writers
DoubleWriter for RowData input.
doWrite(T, int) - Method in class org.apache.flink.table.runtime.arrow.writers.ArrayWriter
 
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.BigIntWriter
 
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(Row, int) - Method in class org.apache.flink.table.runtime.arrow.writers.RowArrayWriter
 
doWrite(Row, int) - Method in class org.apache.flink.table.runtime.arrow.writers.RowBigIntWriter
 
doWrite(Row, int) - Method in class org.apache.flink.table.runtime.arrow.writers.RowBooleanWriter
 
doWrite(Row, int) - Method in class org.apache.flink.table.runtime.arrow.writers.RowDateWriter
 
doWrite(Row, int) - Method in class org.apache.flink.table.runtime.arrow.writers.RowDecimalWriter
 
doWrite(Row, int) - Method in class org.apache.flink.table.runtime.arrow.writers.RowDoubleWriter
 
doWrite(Row, int) - Method in class org.apache.flink.table.runtime.arrow.writers.RowFloatWriter
 
doWrite(Row, int) - Method in class org.apache.flink.table.runtime.arrow.writers.RowIntWriter
 
doWrite(Row, int) - Method in class org.apache.flink.table.runtime.arrow.writers.RowRowWriter
 
doWrite(Row, int) - Method in class org.apache.flink.table.runtime.arrow.writers.RowSmallIntWriter
 
doWrite(Row, int) - Method in class org.apache.flink.table.runtime.arrow.writers.RowTimestampWriter
 
doWrite(Row, int) - Method in class org.apache.flink.table.runtime.arrow.writers.RowTimeWriter
 
doWrite(Row, int) - Method in class org.apache.flink.table.runtime.arrow.writers.RowTinyIntWriter
 
doWrite(Row, int) - Method in class org.apache.flink.table.runtime.arrow.writers.RowVarBinaryWriter
 
doWrite(Row, int) - Method in class org.apache.flink.table.runtime.arrow.writers.RowVarCharWriter
 
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
 
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.
emitResult(Tuple2<byte[], Integer>) - Method in class org.apache.flink.streaming.api.operators.python.AbstractPythonFunctionOperator
Sends the execution result to the downstream operator.
emitResult(Tuple2<byte[], Integer>) - Method in class org.apache.flink.streaming.api.operators.python.PythonCoFlatMapOperator
 
emitResult(Tuple2<byte[], Integer>) - Method in class org.apache.flink.streaming.api.operators.python.PythonCoMapOperator
 
emitResult(Tuple2<byte[], Integer>) - Method in class org.apache.flink.streaming.api.operators.python.PythonFlatMapOperator
 
emitResult(Tuple2<byte[], Integer>) - Method in class org.apache.flink.streaming.api.operators.python.PythonKeyedCoProcessOperator
 
emitResult(Tuple2<byte[], Integer>) - Method in class org.apache.flink.streaming.api.operators.python.PythonKeyedProcessOperator
 
emitResult(Tuple2<byte[], Integer>) - Method in class org.apache.flink.streaming.api.operators.python.PythonMapOperator
 
emitResult(Tuple2<byte[], Integer>) - Method in class org.apache.flink.streaming.api.operators.python.PythonPartitionCustomOperator
 
emitResult(Tuple2<byte[], Integer>) - Method in class org.apache.flink.streaming.api.operators.python.PythonProcessOperator
 
emitResult(Tuple2<byte[], Integer>) - Method in class org.apache.flink.streaming.api.operators.python.PythonTimestampsAndWatermarksOperator
 
emitResult(Tuple2<byte[], Integer>) - Method in class org.apache.flink.table.runtime.functions.python.AbstractPythonStatelessFunctionFlatMap
 
emitResult(Tuple2<byte[], Integer>) - Method in class org.apache.flink.table.runtime.functions.python.arrow.ArrowPythonScalarFunctionFlatMap
 
emitResult(Tuple2<byte[], Integer>) - Method in class org.apache.flink.table.runtime.functions.python.PythonScalarFunctionFlatMap
 
emitResult(Tuple2<byte[], Integer>) - Method in class org.apache.flink.table.runtime.functions.python.PythonTableFunctionFlatMap
 
emitResult(Tuple2<byte[], Integer>) - Method in class org.apache.flink.table.runtime.operators.python.aggregate.AbstractPythonStreamGroupAggregateOperator
 
emitResult(Tuple2<byte[], Integer>) - Method in class org.apache.flink.table.runtime.operators.python.aggregate.arrow.batch.BatchArrowPythonGroupAggregateFunctionOperator
 
emitResult(Tuple2<byte[], Integer>) - Method in class org.apache.flink.table.runtime.operators.python.aggregate.arrow.batch.BatchArrowPythonGroupWindowAggregateFunctionOperator
 
emitResult(Tuple2<byte[], Integer>) - Method in class org.apache.flink.table.runtime.operators.python.aggregate.arrow.batch.BatchArrowPythonOverWindowAggregateFunctionOperator
 
emitResult(Tuple2<byte[], Integer>) - Method in class org.apache.flink.table.runtime.operators.python.aggregate.arrow.stream.AbstractStreamArrowPythonBoundedRangeOperator
 
emitResult(Tuple2<byte[], Integer>) - Method in class org.apache.flink.table.runtime.operators.python.aggregate.arrow.stream.AbstractStreamArrowPythonBoundedRowsOperator
 
emitResult(Tuple2<byte[], Integer>) - Method in class org.apache.flink.table.runtime.operators.python.aggregate.arrow.stream.StreamArrowPythonGroupWindowAggregateFunctionOperator
 
emitResult(Tuple2<byte[], Integer>) - Method in class org.apache.flink.table.runtime.operators.python.aggregate.PythonStreamGroupWindowAggregateOperator
 
emitResult(Tuple2<byte[], Integer>) - Method in class org.apache.flink.table.runtime.operators.python.scalar.arrow.ArrowPythonScalarFunctionOperator
 
emitResult(Tuple2<byte[], Integer>) - Method in class org.apache.flink.table.runtime.operators.python.scalar.arrow.RowDataArrowPythonScalarFunctionOperator
 
emitResult(Tuple2<byte[], Integer>) - Method in class org.apache.flink.table.runtime.operators.python.scalar.PythonScalarFunctionOperator
 
emitResult(Tuple2<byte[], Integer>) - Method in class org.apache.flink.table.runtime.operators.python.scalar.RowDataPythonScalarFunctionOperator
 
emitResult(Tuple2<byte[], Integer>) - Method in class org.apache.flink.table.runtime.operators.python.table.PythonTableFunctionOperator
 
emitResult(Tuple2<byte[], Integer>) - Method in class org.apache.flink.table.runtime.operators.python.table.RowDataPythonTableFunctionOperator
 
emitResults() - Method in class org.apache.flink.streaming.api.operators.python.AbstractPythonFunctionOperator
 
endInput() - Method in class org.apache.flink.streaming.api.operators.python.AbstractOneInputPythonFunctionOperator
 
endInput(int) - Method in class org.apache.flink.streaming.api.operators.python.AbstractTwoInputPythonFunctionOperator
 
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.arrow.RowDataArrowPythonScalarFunctionOperator
 
endOfLastFlatMap(int, byte[]) - Static method in enum org.apache.flink.streaming.api.utils.PythonOperatorUtils
 
ensureCacheCleanupExecutorServiceStarted() - Static method in interface org.apache.flink.client.python.PythonFunctionFactory
 
equals(Object) - Method in class org.apache.flink.client.python.PythonFunctionFactory.CacheKey
 
equals(Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam
 
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.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.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.JobParameter
 
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.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.table.runtime.typeutils.serializers.python.DecimalDataSerializer
 
extractProgramArgs(CommandLine) - Method in class org.apache.flink.client.cli.PythonProgramOptions
 
extractZipFileWithPermissions(String, String) - Static method in class org.apache.flink.python.util.ZipUtils
 

F

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.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.RowArrayWriter
 
finish() - Method in class org.apache.flink.table.runtime.arrow.writers.RowRowWriter
 
finish() - Method in class org.apache.flink.table.runtime.arrow.writers.RowWriter
 
finishCurrentBatch() - Method in class org.apache.flink.table.runtime.arrow.serializers.ArrowSerializer
Forces to finish the processing of the current batch of elements.
FLAT_MAP_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.FunctionType
FLAT_MAP = 1;
flatMap(Row, Collector<Row>) - Method in class org.apache.flink.table.runtime.functions.python.AbstractPythonStatelessFunctionFlatMap
 
FLATTEN_ROW_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam.DataType
FLATTEN_ROW = 0;
FLINK_AGGREGATE_FUNCTION_SCHEMA_CODER_URN - Static variable in class org.apache.flink.table.runtime.operators.python.aggregate.AbstractPythonStreamAggregateOperator
 
FlinkFnApi - Class in org.apache.flink.fnexecution.v1
 
FlinkFnApi.CoderParam - Class in org.apache.flink.fnexecution.v1
A representation of the coder
FlinkFnApi.CoderParam.Builder - Class in org.apache.flink.fnexecution.v1
A representation of the coder
FlinkFnApi.CoderParam.DataInfoCase - Enum in org.apache.flink.fnexecution.v1
 
FlinkFnApi.CoderParam.DataType - Enum in org.apache.flink.fnexecution.v1
Protobuf enum org.apache.flink.fn_execution.v1.CoderParam.DataType
FlinkFnApi.CoderParam.OutputMode - Enum in org.apache.flink.fnexecution.v1
Protobuf enum org.apache.flink.fn_execution.v1.CoderParam.OutputMode
FlinkFnApi.CoderParamOrBuilder - 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.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.TypeInfo - Class in org.apache.flink.fnexecution.v1
A representation of the data type information in DataStream.
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.JobParameter - Class in org.apache.flink.fnexecution.v1
Protobuf type org.apache.flink.fn_execution.v1.UserDefinedDataStreamFunction.JobParameter
FlinkFnApi.UserDefinedDataStreamFunction.JobParameter.Builder - Class in org.apache.flink.fnexecution.v1
Protobuf type org.apache.flink.fn_execution.v1.UserDefinedDataStreamFunction.JobParameter
FlinkFnApi.UserDefinedDataStreamFunction.JobParameterOrBuilder - Interface in org.apache.flink.fnexecution.v1
 
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
Helper class for forwarding Python metrics to Java accumulators and metrics.
FlinkMetricContainer(MetricGroup) - Constructor for class org.apache.flink.python.metric.FlinkMetricContainer
 
FlinkMetricContainer.FlinkDistributionGauge - Class in org.apache.flink.python.metric
Flink Gauge for DistributionResult.
FlinkMetricContainer.FlinkGauge - Class in org.apache.flink.python.metric
Flink Gauge for GaugeResult.
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;
FloatFieldReader - Class in org.apache.flink.table.runtime.arrow.readers
ArrowFieldReader for Float.
FloatFieldReader(Float4Vector) - Constructor for class org.apache.flink.table.runtime.arrow.readers.FloatFieldReader
 
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 for ArrayData input.
FloatWriter.FloatWriterForRow - Class in org.apache.flink.table.runtime.arrow.writers
FloatWriter for RowData 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(ListVector, ArrowFieldWriter<ArrayData>) - Static method in class org.apache.flink.table.runtime.arrow.writers.ArrayWriter
 
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(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(Float8Vector) - Static method in class org.apache.flink.table.runtime.arrow.writers.DoubleWriter
 
forArray(Float4Vector) - Static method in class org.apache.flink.table.runtime.arrow.writers.FloatWriter
 
forArray(IntVector) - Static method in class org.apache.flink.table.runtime.arrow.writers.IntWriter
 
forArray(StructVector, ArrowFieldWriter<RowData>[]) - Static method in class org.apache.flink.table.runtime.arrow.writers.RowWriter
 
forArray(SmallIntVector) - Static method in class org.apache.flink.table.runtime.arrow.writers.SmallIntWriter
 
forArray(ValueVector, int) - Static method in class org.apache.flink.table.runtime.arrow.writers.TimestampWriter
 
forArray(ValueVector) - Static method in class org.apache.flink.table.runtime.arrow.writers.TimeWriter
 
forArray(TinyIntVector) - Static method in class org.apache.flink.table.runtime.arrow.writers.TinyIntWriter
 
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.CoderParam.DataInfoCase
 
forNumber(int) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam.DataType
 
forNumber(int) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam.OutputMode
 
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.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(ListVector, ArrowFieldWriter<ArrayData>) - Static method in class org.apache.flink.table.runtime.arrow.writers.ArrayWriter
 
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(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(Float8Vector) - Static method in class org.apache.flink.table.runtime.arrow.writers.DoubleWriter
 
forRow(Float4Vector) - Static method in class org.apache.flink.table.runtime.arrow.writers.FloatWriter
 
forRow(IntVector) - Static method in class org.apache.flink.table.runtime.arrow.writers.IntWriter
 
forRow(StructVector, ArrowFieldWriter<RowData>[]) - Static method in class org.apache.flink.table.runtime.arrow.writers.RowWriter
 
forRow(SmallIntVector) - Static method in class org.apache.flink.table.runtime.arrow.writers.SmallIntWriter
 
forRow(ValueVector, int) - Static method in class org.apache.flink.table.runtime.arrow.writers.TimestampWriter
 
forRow(ValueVector) - Static method in class org.apache.flink.table.runtime.arrow.writers.TimeWriter
 
forRow(TinyIntVector) - Static method in class org.apache.flink.table.runtime.arrow.writers.TinyIntWriter
 
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
 
forwardedFields - Variable in class org.apache.flink.table.runtime.operators.python.scalar.AbstractPythonScalarFunctionOperator
The offset of the fields which should be forwarded.
forwardedInputQueue - Variable in class org.apache.flink.table.runtime.functions.python.AbstractPythonStatelessFunctionFlatMap
The queue holding the input elements for which the execution results have not been received.
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.
forwardedInputSerializer - Variable in class org.apache.flink.table.runtime.functions.python.AbstractPythonStatelessFunctionFlatMap
The type serializer for the forwarded fields.
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.
fromNormalData(long, long, Row) - Method in class org.apache.flink.streaming.api.utils.input.KeyedInputWithTimerRowFactory
 
fromNormalData(boolean, long, long, Row) - Method in class org.apache.flink.streaming.api.utils.input.KeyedTwoInputWithTimerRowFactory
 
fromTimer(TimeDomain, long, long, Row, byte[]) - Method in class org.apache.flink.streaming.api.utils.input.KeyedInputWithTimerRowFactory
 
fromTimer(TimeDomain, long, long, Row, byte[]) - Method in class org.apache.flink.streaming.api.utils.input.KeyedTwoInputWithTimerRowFactory
 
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
 
generateStreamGraphWithDependencies(StreamExecutionEnvironment, boolean) - Static method in class org.apache.flink.python.util.PythonConfigUtil
Generate a StreamGraph for transformations maintained by current StreamExecutionEnvironment, and reset the merged env configurations with dependencies to every OneInputPythonFunctionOperator.
get(SharedResourceHolder.Resource<T>) - Static method in class org.apache.beam.vendor.grpc.v1p26p0.io.grpc.internal.SharedResourceHolder
Try to get an existing instance of the given resource.
get(int) - Method in class org.apache.flink.streaming.api.utils.ByteArrayWrapper
 
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
 
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;
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.beam.ProcessPythonEnvironmentManager
 
getBootLog() - Method in interface org.apache.flink.python.env.PythonEnvironmentManager
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.ArrowVarBinaryColumnVector
 
getBytes(int) - Method in class org.apache.flink.table.runtime.arrow.vectors.ArrowVarCharColumnVector
 
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;
getCoderUrn() - Method in class org.apache.flink.streaming.api.operators.python.OneInputPythonFunctionOperator
 
getCoderUrn() - Method in class org.apache.flink.streaming.api.operators.python.PythonFlatMapOperator
 
getCoderUrn() - Method in class org.apache.flink.streaming.api.operators.python.PythonMapOperator
 
getCoderUrn() - Method in class org.apache.flink.streaming.api.operators.python.PythonPartitionCustomOperator
 
getCoderUrn() - Method in class org.apache.flink.streaming.api.operators.python.PythonProcessOperator
 
getCoderUrn() - Method in class org.apache.flink.streaming.api.operators.python.PythonTimestampsAndWatermarksOperator
 
getCoderUrn() - Method in class org.apache.flink.streaming.api.operators.python.TwoInputPythonFunctionOperator
 
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;
getColumnVectors() - Method in class org.apache.flink.table.runtime.arrow.vectors.RowDataArrowReader
Gets the column vectors.
getCommand() - Method in class org.apache.flink.python.env.ProcessPythonEnvironment
 
getConfig() - Method in class org.apache.flink.python.PythonConfig
 
getConfig() - Method in class org.apache.flink.streaming.api.operators.python.AbstractPythonFunctionOperator
Returns the PythonConfig.
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.PythonKeyedCoProcessOperator
 
getCurrentKey() - Method in class org.apache.flink.streaming.api.operators.python.PythonKeyedProcessOperator
 
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
 
getDataInfoCase() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam.Builder
 
getDataInfoCase() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam
 
getDataInfoCase() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParamOrBuilder
 
getDataStream(StreamExecutionEnvironment) - Method in class org.apache.flink.table.runtime.arrow.sources.ArrowTableSource
 
getDataStream(StreamExecutionEnvironment) - Method in class org.apache.flink.table.runtime.arrow.sources.RowArrowTableSource
 
getDataType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam.Builder
.org.apache.flink.fn_execution.v1.CoderParam.DataType data_type = 3;
getDataType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam
.org.apache.flink.fn_execution.v1.CoderParam.DataType data_type = 3;
getDataType() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParamOrBuilder
.org.apache.flink.fn_execution.v1.CoderParam.DataType data_type = 3;
getDataTypeValue() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam.Builder
.org.apache.flink.fn_execution.v1.CoderParam.DataType data_type = 3;
getDataTypeValue() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam
.org.apache.flink.fn_execution.v1.CoderParam.DataType data_type = 3;
getDataTypeValue() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParamOrBuilder
.org.apache.flink.fn_execution.v1.CoderParam.DataType data_type = 3;
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.CoderParam
 
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.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.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.JobParameter
 
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.CoderParam.Builder
 
getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam
 
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.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.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.JobParameter.Builder
 
getDefaultInstanceForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.JobParameter
 
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.CoderParam.Builder
 
getDescriptor() - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam.DataType
 
getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam
 
getDescriptor() - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam.OutputMode
 
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.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.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.JobParameter.Builder
 
getDescriptor() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.JobParameter
 
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.CoderParam.Builder
 
getDescriptorForType() - Method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam.DataType
 
getDescriptorForType() - Method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam.OutputMode
 
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.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.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.JobParameter.Builder
 
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;
getEnv() - Method in class org.apache.flink.python.env.ProcessPythonEnvironment
 
getEnvConfigWithDependencies(StreamExecutionEnvironment) - Static method in class org.apache.flink.python.util.PythonConfigUtil
A static method to get the StreamExecutionEnvironment configuration merged with python dependency management configurations.
getEnvironmentConfig(StreamExecutionEnvironment) - Static method in class org.apache.flink.python.util.PythonConfigUtil
Get the private method StreamExecutionEnvironment.getConfiguration() by reflection recursively.
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;
getFieldReaders() - Method in class org.apache.flink.table.runtime.arrow.readers.RowArrowReader
Gets the field readers.
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;
getFlinkMetricContainer() - Method in class org.apache.flink.streaming.api.operators.python.AbstractPythonFunctionOperator
 
getFlinkMetricContainer() - Method in class org.apache.flink.table.runtime.functions.python.AbstractPythonStatelessFunctionFlatMap
 
getFloat(int) - Method in class org.apache.flink.table.runtime.arrow.vectors.ArrowFloatColumnVector
 
getForwardedFieldsCount() - Method in class org.apache.flink.table.runtime.functions.python.AbstractPythonScalarFunctionFlatMap
 
getForwardedFieldsCount() - Method in class org.apache.flink.table.runtime.functions.python.AbstractPythonStatelessFunctionFlatMap
 
getForwardedFieldsCount() - Method in class org.apache.flink.table.runtime.functions.python.PythonTableFunctionFlatMap
 
getFunctionInput(Row) - Method in class org.apache.flink.table.runtime.functions.python.AbstractPythonStatelessFunctionFlatMap
 
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.AbstractRowDataPythonScalarFunctionOperator
 
getFunctionInput(CRow) - Method in class org.apache.flink.table.runtime.operators.python.scalar.AbstractRowPythonScalarFunctionOperator
 
getFunctionInput(CRow) - Method in class org.apache.flink.table.runtime.operators.python.table.PythonTableFunctionOperator
 
getFunctionInput(RowData) - Method in class org.apache.flink.table.runtime.operators.python.table.RowDataPythonTableFunctionOperator
 
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.streaming.api.operators.python.OneInputPythonFunctionOperator
 
getFunctionUrn() - Method in class org.apache.flink.streaming.api.operators.python.PythonProcessOperator
 
getFunctionUrn() - Method in class org.apache.flink.table.runtime.functions.python.AbstractPythonScalarFunctionFlatMap
 
getFunctionUrn() - Method in class org.apache.flink.table.runtime.functions.python.AbstractPythonStatelessFunctionFlatMap
 
getFunctionUrn() - Method in class org.apache.flink.table.runtime.functions.python.PythonTableFunctionFlatMap
 
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.AbstractPythonTableFunctionOperator
 
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.
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;
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
 
getInputCoderProto() - Method in class org.apache.flink.streaming.api.runners.python.beam.BeamDataStreamPythonFunctionRunner
 
getInputCoderProto() - Method in class org.apache.flink.streaming.api.runners.python.beam.BeamPythonFunctionRunner
 
getInputCoderProto() - Method in class org.apache.flink.table.runtime.runners.python.beam.BeamTableStatefulPythonFunctionRunner
 
getInputCoderProto() - Method in class org.apache.flink.table.runtime.runners.python.beam.BeamTableStatelessPythonFunctionRunner
 
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;
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;
getInputOutputCoderUrn() - Method in class org.apache.flink.table.runtime.functions.python.AbstractPythonStatelessFunctionFlatMap
 
getInputOutputCoderUrn() - Method in class org.apache.flink.table.runtime.functions.python.arrow.ArrowPythonScalarFunctionFlatMap
 
getInputOutputCoderUrn() - Method in class org.apache.flink.table.runtime.functions.python.PythonScalarFunctionFlatMap
 
getInputOutputCoderUrn() - Method in class org.apache.flink.table.runtime.functions.python.PythonTableFunctionFlatMap
 
getInputOutputCoderUrn() - Method in class org.apache.flink.table.runtime.operators.python.AbstractStatelessFunctionOperator
 
getInputOutputCoderUrn() - Method in class org.apache.flink.table.runtime.operators.python.aggregate.arrow.AbstractArrowPythonAggregateFunctionOperator
 
getInputOutputCoderUrn() - Method in class org.apache.flink.table.runtime.operators.python.aggregate.arrow.batch.BatchArrowPythonOverWindowAggregateFunctionOperator
 
getInputOutputCoderUrn() - Method in class org.apache.flink.table.runtime.operators.python.scalar.AbstractPythonScalarFunctionOperator
 
getInputOutputCoderUrn() - Method in class org.apache.flink.table.runtime.operators.python.scalar.arrow.ArrowPythonScalarFunctionOperator
 
getInputOutputCoderUrn() - Method in class org.apache.flink.table.runtime.operators.python.scalar.arrow.RowDataArrowPythonScalarFunctionOperator
 
getInputOutputCoderUrn() - Method in class org.apache.flink.table.runtime.operators.python.table.AbstractPythonTableFunctionOperator
 
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.
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.OneInputPythonFunctionOperator
 
getInternalParameters() - Method in class org.apache.flink.streaming.api.operators.python.PythonPartitionCustomOperator
 
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;
getJobOptions() - Method in class org.apache.flink.streaming.api.operators.python.TwoInputPythonFunctionOperator
 
getJobParameters(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder
repeated .org.apache.flink.fn_execution.v1.UserDefinedDataStreamFunction.JobParameter job_parameters = 7;
getJobParameters(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext
repeated .org.apache.flink.fn_execution.v1.UserDefinedDataStreamFunction.JobParameter job_parameters = 7;
getJobParameters(int) - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContextOrBuilder
repeated .org.apache.flink.fn_execution.v1.UserDefinedDataStreamFunction.JobParameter job_parameters = 7;
getJobParametersBuilder(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder
repeated .org.apache.flink.fn_execution.v1.UserDefinedDataStreamFunction.JobParameter job_parameters = 7;
getJobParametersBuilderList() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder
repeated .org.apache.flink.fn_execution.v1.UserDefinedDataStreamFunction.JobParameter job_parameters = 7;
getJobParametersCount() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder
repeated .org.apache.flink.fn_execution.v1.UserDefinedDataStreamFunction.JobParameter job_parameters = 7;
getJobParametersCount() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext
repeated .org.apache.flink.fn_execution.v1.UserDefinedDataStreamFunction.JobParameter job_parameters = 7;
getJobParametersCount() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContextOrBuilder
repeated .org.apache.flink.fn_execution.v1.UserDefinedDataStreamFunction.JobParameter job_parameters = 7;
getJobParametersList() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder
repeated .org.apache.flink.fn_execution.v1.UserDefinedDataStreamFunction.JobParameter job_parameters = 7;
getJobParametersList() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext
repeated .org.apache.flink.fn_execution.v1.UserDefinedDataStreamFunction.JobParameter job_parameters = 7;
getJobParametersList() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContextOrBuilder
repeated .org.apache.flink.fn_execution.v1.UserDefinedDataStreamFunction.JobParameter job_parameters = 7;
getJobParametersOrBuilder(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder
repeated .org.apache.flink.fn_execution.v1.UserDefinedDataStreamFunction.JobParameter job_parameters = 7;
getJobParametersOrBuilder(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext
repeated .org.apache.flink.fn_execution.v1.UserDefinedDataStreamFunction.JobParameter job_parameters = 7;
getJobParametersOrBuilder(int) - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContextOrBuilder
repeated .org.apache.flink.fn_execution.v1.UserDefinedDataStreamFunction.JobParameter job_parameters = 7;
getJobParametersOrBuilderList() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder
repeated .org.apache.flink.fn_execution.v1.UserDefinedDataStreamFunction.JobParameter job_parameters = 7;
getJobParametersOrBuilderList() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext
repeated .org.apache.flink.fn_execution.v1.UserDefinedDataStreamFunction.JobParameter job_parameters = 7;
getJobParametersOrBuilderList() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContextOrBuilder
repeated .org.apache.flink.fn_execution.v1.UserDefinedDataStreamFunction.JobParameter job_parameters = 7;
getKey() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.JobParameter.Builder
string key = 1;
getKey() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.JobParameter
string key = 1;
getKey() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.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.UserDefinedDataStreamFunction.JobParameter.Builder
string key = 1;
getKeyBytes() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.JobParameter
string key = 1;
getKeyBytes() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.JobParameterOrBuilder
string key = 1;
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.
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
 
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;
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;
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.
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.
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;
getMaxArrowBatchSize() - Method in class org.apache.flink.python.PythonConfig
 
getMaxBundleSize() - Method in class org.apache.flink.python.PythonConfig
 
getMaxBundleTimeMills() - Method in class org.apache.flink.python.PythonConfig
 
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;
getMergedConfig(StreamExecutionEnvironment, TableConfig) - Static method in class org.apache.flink.python.util.PythonConfigUtil
 
getMergedConfig(ExecutionEnvironment, TableConfig) - Static method in class org.apache.flink.python.util.PythonConfigUtil
 
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;
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.CoderParam.DataInfoCase
 
getNumber() - Method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam.DataType
 
getNumber() - Method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam.OutputMode
 
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.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;
getOffset() - Method in class org.apache.flink.streaming.api.utils.ByteArrayWrapper
 
getOutputCoderProto() - Method in class org.apache.flink.streaming.api.runners.python.beam.BeamDataStreamPythonFunctionRunner
 
getOutputCoderProto() - Method in class org.apache.flink.streaming.api.runners.python.beam.BeamPythonFunctionRunner
 
getOutputCoderProto() - Method in class org.apache.flink.table.runtime.runners.python.beam.BeamTableStatefulPythonFunctionRunner
 
getOutputCoderProto() - Method in class org.apache.flink.table.runtime.runners.python.beam.BeamTableStatelessPythonFunctionRunner
 
getOutputMode() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam.Builder
.org.apache.flink.fn_execution.v1.CoderParam.OutputMode output_mode = 4;
getOutputMode() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam
.org.apache.flink.fn_execution.v1.CoderParam.OutputMode output_mode = 4;
getOutputMode() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParamOrBuilder
.org.apache.flink.fn_execution.v1.CoderParam.OutputMode output_mode = 4;
getOutputModeValue() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam.Builder
.org.apache.flink.fn_execution.v1.CoderParam.OutputMode output_mode = 4;
getOutputModeValue() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam
.org.apache.flink.fn_execution.v1.CoderParam.OutputMode output_mode = 4;
getOutputModeValue() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParamOrBuilder
.org.apache.flink.fn_execution.v1.CoderParam.OutputMode output_mode = 4;
getParserForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam
 
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.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.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.JobParameter
 
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;
getProducedDataType() - Method in class org.apache.flink.table.runtime.arrow.sources.AbstractArrowTableSource
 
getProducedType() - Method in class org.apache.flink.streaming.api.operators.python.PythonKeyedCoProcessOperator
 
getProducedType() - Method in class org.apache.flink.streaming.api.operators.python.PythonKeyedProcessOperator
 
getProducedType() - Method in class org.apache.flink.table.runtime.arrow.sources.ArrowSourceFunction
 
getProducedType() - Method in class org.apache.flink.table.runtime.arrow.sources.RowArrowSourceFunction
 
getProducedType() - Method in class org.apache.flink.table.runtime.functions.python.AbstractPythonStatelessFunctionFlatMap
 
getPythonArchivesInfo() - Method in class org.apache.flink.python.PythonConfig
 
getPythonConfig() - Method in class org.apache.flink.streaming.api.operators.python.AbstractPythonFunctionOperator
 
getPythonConfig() - Method in class org.apache.flink.table.runtime.functions.python.AbstractPythonStatelessFunctionFlatMap
 
getPythonEnv() - Method in class org.apache.flink.streaming.api.functions.python.DataStreamPythonFunction
 
getPythonEnv() - Method in class org.apache.flink.streaming.api.operators.python.AbstractPythonFunctionOperator
Returns the PythonEnv used to create PythonEnvironmentManager..
getPythonEnv() - Method in class org.apache.flink.streaming.api.operators.python.OneInputPythonFunctionOperator
 
getPythonEnv() - Method in class org.apache.flink.streaming.api.operators.python.PythonKeyedProcessOperator
 
getPythonEnv() - Method in class org.apache.flink.streaming.api.operators.python.TwoInputPythonFunctionOperator
 
getPythonEnv() - Method in class org.apache.flink.table.runtime.functions.python.AbstractPythonScalarFunctionFlatMap
 
getPythonEnv() - Method in class org.apache.flink.table.runtime.functions.python.AbstractPythonStatelessFunctionFlatMap
Returns the PythonEnv used to create PythonEnvironmentManager..
getPythonEnv() - Method in class org.apache.flink.table.runtime.functions.python.PythonTableFunctionFlatMap
 
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.AbstractPythonTableFunctionOperator
 
getPythonExec() - Method in class org.apache.flink.python.env.PythonDependencyInfo
 
getPythonExec() - Method in class org.apache.flink.python.PythonConfig
 
getPythonFiles() - Method in class org.apache.flink.python.env.PythonDependencyInfo
 
getPythonFilesInfo() - Method in class org.apache.flink.python.PythonConfig
 
getPythonFunction(String, String) - Method in interface org.apache.flink.client.python.PythonFunctionFactory
Returns PythonFunction according to moduleName and objectName.
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}.${functionName} or ${moduleName}.${className}.
getPythonFunction(String, String) - Method in class org.apache.flink.client.python.PythonFunctionFactoryImpl
 
getPythonFunction() - Method in class org.apache.flink.streaming.api.functions.python.DataStreamPythonFunctionInfo
 
getPythonFunctionInfo() - Method in class org.apache.flink.streaming.api.operators.python.TwoInputPythonFunctionOperator
 
getPythonRequirementsCacheDirInfo() - Method in class org.apache.flink.python.PythonConfig
 
getPythonRequirementsFileInfo() - Method in class org.apache.flink.python.PythonConfig
 
getPythonUdfRunnerScript(String, Map<String, String>) - Static method in class org.apache.flink.python.util.PythonEnvironmentManagerUtils
 
getRequirementsCacheDir() - Method in class org.apache.flink.python.env.PythonDependencyInfo
 
getRequirementsFilePath() - Method in class org.apache.flink.python.env.PythonDependencyInfo
 
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
 
getRowCoderProto(RowType, String, FlinkFnApi.CoderParam.OutputMode) - Static method in class org.apache.flink.table.runtime.typeutils.PythonTypeUtils
 
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;
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;
getRunnerInputTypeInfo() - Method in class org.apache.flink.streaming.api.operators.python.TwoInputPythonFunctionOperator
 
getRunnerInputTypeInfo(TypeInformation<Row>, TypeInformation<Row>) - Static method in class org.apache.flink.streaming.api.utils.input.KeyedInputWithTimerRowFactory
 
getRunnerInputTypeInfo(TypeInformation<Row>, TypeInformation<Row>, TypeInformation<Row>) - Static method in class org.apache.flink.streaming.api.utils.input.KeyedTwoInputWithTimerRowFactory
 
getRunnerInputTypeSerializer() - Method in class org.apache.flink.streaming.api.operators.python.TwoInputPythonFunctionOperator
 
getRunnerOutputTypeInfo() - Method in class org.apache.flink.streaming.api.operators.python.TwoInputPythonFunctionOperator
 
getRunnerOutputTypeInfo(TypeInformation<?>, TypeInformation<Row>) - Static method in class org.apache.flink.streaming.api.utils.output.OutputWithTimerRowHandler
 
getRunnerOutputTypeSerializer() - Method in class org.apache.flink.streaming.api.operators.python.TwoInputPythonFunctionOperator
 
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;
getSchema() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam.Builder
.org.apache.flink.fn_execution.v1.Schema schema = 1;
getSchema() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam
.org.apache.flink.fn_execution.v1.Schema schema = 1;
getSchema() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParamOrBuilder
.org.apache.flink.fn_execution.v1.Schema schema = 1;
getSchemaBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam.Builder
.org.apache.flink.fn_execution.v1.Schema schema = 1;
getSchemaOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam.Builder
.org.apache.flink.fn_execution.v1.Schema schema = 1;
getSchemaOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam
.org.apache.flink.fn_execution.v1.Schema schema = 1;
getSchemaOrBuilder() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParamOrBuilder
.org.apache.flink.fn_execution.v1.Schema schema = 1;
getSerializedPythonFunction() - Method in class org.apache.flink.streaming.api.functions.python.DataStreamPythonFunction
 
getSerializedSize() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam
 
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.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.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.JobParameter
 
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
 
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.
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.
getTableSchema() - Method in class org.apache.flink.table.runtime.arrow.sources.AbstractArrowTableSource
 
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;
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
 
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.CoderParam.Builder
.org.apache.flink.fn_execution.v1.TypeInfo type_info = 2;
getTypeInfo() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam
.org.apache.flink.fn_execution.v1.TypeInfo type_info = 2;
getTypeInfo() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParamOrBuilder
.org.apache.flink.fn_execution.v1.TypeInfo type_info = 2;
getTypeInfoBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam.Builder
.org.apache.flink.fn_execution.v1.TypeInfo type_info = 2;
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.CoderParam.Builder
.org.apache.flink.fn_execution.v1.TypeInfo type_info = 2;
getTypeInfoOrBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam
.org.apache.flink.fn_execution.v1.TypeInfo type_info = 2;
getTypeInfoOrBuilder() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParamOrBuilder
.org.apache.flink.fn_execution.v1.TypeInfo type_info = 2;
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.CoderParam
 
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.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.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.JobParameter
 
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
 
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;
getUserDefinedAggregateFunctionProto(PythonAggregateFunctionInfo, DataViewUtils.DataViewSpec[]) - Static method in enum org.apache.flink.streaming.api.utils.PythonOperatorUtils
 
getUserDefinedDataStreamFunctionProto(DataStreamPythonFunctionInfo, RuntimeContext, Map<String, String>, boolean) - Static method in enum org.apache.flink.streaming.api.utils.PythonOperatorUtils
 
getUserDefinedDataStreamStatefulFunctionProto(DataStreamPythonFunctionInfo, RuntimeContext, Map<String, String>, TypeInformation, boolean) - Static method in enum org.apache.flink.streaming.api.utils.PythonOperatorUtils
 
getUserDefinedFunctionInputType() - Method in class org.apache.flink.table.runtime.operators.python.aggregate.AbstractPythonStreamAggregateOperator
 
getUserDefinedFunctionInputType() - Method in class org.apache.flink.table.runtime.operators.python.aggregate.AbstractPythonStreamGroupAggregateOperator
 
getUserDefinedFunctionInputType() - Method in class org.apache.flink.table.runtime.operators.python.aggregate.PythonStreamGroupWindowAggregateOperator
 
getUserDefinedFunctionOutputType() - Method in class org.apache.flink.table.runtime.operators.python.aggregate.AbstractPythonStreamAggregateOperator
 
getUserDefinedFunctionOutputType() - Method in class org.apache.flink.table.runtime.operators.python.aggregate.AbstractPythonStreamGroupAggregateOperator
 
getUserDefinedFunctionOutputType() - Method in class org.apache.flink.table.runtime.operators.python.aggregate.PythonStreamGroupWindowAggregateOperator
 
getUserDefinedFunctionProto(PythonFunctionInfo) - Static method in enum org.apache.flink.streaming.api.utils.PythonOperatorUtils
 
getUserDefinedFunctionsProto() - Method in class org.apache.flink.table.runtime.functions.python.AbstractPythonScalarFunctionFlatMap
 
getUserDefinedFunctionsProto() - Method in class org.apache.flink.table.runtime.functions.python.AbstractPythonStatelessFunctionFlatMap
Gets the proto representation of the Python user-defined functions to be executed.
getUserDefinedFunctionsProto() - Method in class org.apache.flink.table.runtime.functions.python.PythonTableFunctionFlatMap
 
getUserDefinedFunctionsProto() - Method in class org.apache.flink.table.runtime.operators.python.AbstractStatelessFunctionOperator
Gets the proto representation of the Python user-defined functions to be executed.
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.arrow.AbstractArrowPythonAggregateFunctionOperator
 
getUserDefinedFunctionsProto() - Method in class org.apache.flink.table.runtime.operators.python.aggregate.arrow.batch.BatchArrowPythonOverWindowAggregateFunctionOperator
 
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
 
getUserDefinedFunctionsProto() - 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.
getUserDefinedFunctionsProto() - Method in class org.apache.flink.table.runtime.operators.python.table.AbstractPythonTableFunctionOperator
 
getUserDefinedFunctionsProtoBytes() - Method in class org.apache.flink.streaming.api.runners.python.beam.BeamDataStreamPythonFunctionRunner
 
getUserDefinedFunctionsProtoBytes() - Method in class org.apache.flink.streaming.api.runners.python.beam.BeamPythonFunctionRunner
 
getUserDefinedFunctionsProtoBytes() - Method in class org.apache.flink.table.runtime.runners.python.beam.BeamTableStatefulPythonFunctionRunner
 
getUserDefinedFunctionsProtoBytes() - Method in class org.apache.flink.table.runtime.runners.python.beam.BeamTableStatelessPythonFunctionRunner
 
getValue() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.JobParameter.Builder
string value = 2;
getValue() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.JobParameter
string value = 2;
getValue() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.JobParameterOrBuilder
string value = 2;
getValue() - Method in class org.apache.flink.python.metric.FlinkMetricContainer.FlinkDistributionGauge
 
getValue() - Method in class org.apache.flink.python.metric.FlinkMetricContainer.FlinkGauge
 
getValueBytes() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.JobParameter.Builder
string value = 2;
getValueBytes() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.JobParameter
string value = 2;
getValueBytes() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.JobParameterOrBuilder
string value = 2;
getValueDescriptor() - Method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam.DataType
 
getValueDescriptor() - Method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam.OutputMode
 
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.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.readers.ArrowFieldReader
Returns the underlying container which stores the sequence of values of a column to read.
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
 
groupingSet - Variable in class org.apache.flink.table.runtime.operators.python.aggregate.arrow.AbstractArrowPythonAggregateFunctionOperator
 
GrpcStateService - Class in org.apache.beam.runners.fnexecution.state
An implementation of the Beam Fn State service.

H

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;
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;
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;
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.CoderParam
 
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.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.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.JobParameter
 
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.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
 
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;
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;
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.CoderParam.Builder
.org.apache.flink.fn_execution.v1.Schema schema = 1;
hasSchema() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam
.org.apache.flink.fn_execution.v1.Schema schema = 1;
hasSchema() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParamOrBuilder
.org.apache.flink.fn_execution.v1.Schema schema = 1;
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.CoderParam.Builder
.org.apache.flink.fn_execution.v1.TypeInfo type_info = 2;
hasTypeInfo() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam
.org.apache.flink.fn_execution.v1.TypeInfo type_info = 2;
hasTypeInfo() - Method in interface org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParamOrBuilder
.org.apache.flink.fn_execution.v1.TypeInfo type_info = 2;
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

IN_BATCH_EXECUTION_MODE_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext
 
inBatchExecutionMode(KeyedStateBackend<K>) - Static method in enum org.apache.flink.streaming.api.utils.PythonOperatorUtils
 
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.AbstractArrowSourceFunction
 
INPUTCONSTANT_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input
 
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.functions.python.AbstractPythonStatelessFunctionFlatMap
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.table.runtime.typeutils.PythonTypeUtils.LogicalTypeToConversionClassConverter
 
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
 
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;
internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam
 
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.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.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.JobParameter.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.JobParameter
 
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.CoderParam.DataType
 
internalGetValueMap() - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam.OutputMode
 
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.TypeInfo.TypeName
 
internalGetValueMap() - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.FunctionType
 
internalToDate(int) - Static method in class org.apache.flink.table.runtime.typeutils.PythonTypeUtils
Converts the internal representation of a SQL DATE (int) to the Java type used for UDF parameters (Date).
internalToTimestamp(long) - Static method in class org.apache.flink.table.runtime.typeutils.PythonTypeUtils
Converts the internal representation of a SQL TIMESTAMP (long) to the Java type used for UDF parameters (Timestamp).
IntFieldReader - Class in org.apache.flink.table.runtime.arrow.readers
IntFieldReader(IntVector) - Constructor for class org.apache.flink.table.runtime.arrow.readers.IntFieldReader
 
IntWriter<T> - Class in org.apache.flink.table.runtime.arrow.writers
IntWriter.IntWriterForArray - Class in org.apache.flink.table.runtime.arrow.writers
IntWriter for ArrayData input.
IntWriter.IntWriterForRow - Class in org.apache.flink.table.runtime.arrow.writers
IntWriter for RowData input.
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.table.runtime.functions.python.AbstractPythonStatelessFunctionFlatMap
 
invokeFinishBundle() - Method in class org.apache.flink.table.runtime.functions.python.arrow.ArrowPythonScalarFunctionFlatMap
 
invokeFinishBundle() - Method in class org.apache.flink.table.runtime.operators.python.scalar.arrow.ArrowPythonScalarFunctionOperator
 
invokeFinishBundle() - Method in class org.apache.flink.table.runtime.operators.python.scalar.arrow.RowDataArrowPythonScalarFunctionOperator
 
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
 
isBounded() - Method in class org.apache.flink.table.runtime.arrow.sources.AbstractArrowTableSource
 
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
 
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.CoderParam.Builder
 
isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam
 
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.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.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.JobParameter.Builder
 
isInitialized() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.JobParameter
 
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
 
isMetricEnabled() - Method in class org.apache.flink.python.PythonConfig
 
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.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.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
 
isTupleType() - Method in class org.apache.flink.streaming.api.typeinfo.python.PickledByteArrayTypeInfo
 
isUsingManagedMemory() - Method in class org.apache.flink.python.PythonConfig
 

J

JOB_PARAMETERS_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext
 
jobOptions - Variable in class org.apache.flink.streaming.api.operators.python.OneInputPythonFunctionOperator
The options used to configure the Python worker process.
jobOptions - Variable in class org.apache.flink.table.runtime.functions.python.AbstractPythonStatelessFunctionFlatMap
The options used to configure the Python worker process.
joinType - Variable in class org.apache.flink.table.runtime.operators.python.table.AbstractPythonTableFunctionOperator
The correlate join type.

K

KEY_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.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_PROCESS_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.FunctionType
KEYED_CO_PROCESS = 6;
KEYED_PROCESS_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.FunctionType
KEYED_PROCESS = 5;
KEYED_STREAM_VALUE_OPERATOR_NAME - Static variable in class org.apache.flink.python.util.PythonConfigUtil
 
KeyedInputWithTimerRowFactory - Class in org.apache.flink.streaming.api.utils.input
This factory produces runner input row for one input operators which need to send the timer trigger event to python side.
KeyedInputWithTimerRowFactory() - Constructor for class org.apache.flink.streaming.api.utils.input.KeyedInputWithTimerRowFactory
 
KeyedTwoInputWithTimerRowFactory - Class in org.apache.flink.streaming.api.utils.input
This factory produces runner input row for two input operators which need to send the timer trigger event to python side.
KeyedTwoInputWithTimerRowFactory() - Constructor for class org.apache.flink.streaming.api.utils.input.KeyedTwoInputWithTimerRowFactory
 

L

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_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TypeName
LIST = 18;
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_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;
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_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
 
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_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_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_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_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.FunctionType
MAP = 0;
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 for MapData.
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 for MapDataSerializer.
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
 
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;
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;
mergeFrom(Message) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam.Builder
 
mergeFrom(FlinkFnApi.CoderParam) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam.Builder
 
mergeFrom(Message) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.Builder
 
mergeFrom(FlinkFnApi.GroupWindow) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - 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(FlinkFnApi.Input) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input.Builder
 
mergeFrom(Message) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow.Builder
 
mergeFrom(FlinkFnApi.OverWindow) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - 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(FlinkFnApi.Schema.BinaryInfo) - 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.BinaryInfo.Builder
 
mergeFrom(Message) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Builder
 
mergeFrom(FlinkFnApi.Schema) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - 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(FlinkFnApi.Schema.CharInfo) - 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.CharInfo.Builder
 
mergeFrom(Message) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.DecimalInfo.Builder
 
mergeFrom(FlinkFnApi.Schema.DecimalInfo) - 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.DecimalInfo.Builder
 
mergeFrom(Message) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Field.Builder
 
mergeFrom(FlinkFnApi.Schema.Field) - 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.Field.Builder
 
mergeFrom(Message) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.Builder
 
mergeFrom(FlinkFnApi.Schema.FieldType) - 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.FieldType.Builder
 
mergeFrom(Message) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.LocalZonedTimestampInfo.Builder
 
mergeFrom(FlinkFnApi.Schema.LocalZonedTimestampInfo) - 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.LocalZonedTimestampInfo.Builder
 
mergeFrom(Message) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.MapInfo.Builder
 
mergeFrom(FlinkFnApi.Schema.MapInfo) - 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.MapInfo.Builder
 
mergeFrom(Message) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimeInfo.Builder
 
mergeFrom(FlinkFnApi.Schema.TimeInfo) - 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.TimeInfo.Builder
 
mergeFrom(Message) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimestampInfo.Builder
 
mergeFrom(FlinkFnApi.Schema.TimestampInfo) - 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.TimestampInfo.Builder
 
mergeFrom(Message) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarBinaryInfo.Builder
 
mergeFrom(FlinkFnApi.Schema.VarBinaryInfo) - 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.VarBinaryInfo.Builder
 
mergeFrom(Message) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarCharInfo.Builder
 
mergeFrom(FlinkFnApi.Schema.VarCharInfo) - 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.VarCharInfo.Builder
 
mergeFrom(Message) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.ZonedTimestampInfo.Builder
 
mergeFrom(FlinkFnApi.Schema.ZonedTimestampInfo) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.ZonedTimestampInfo.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.ZonedTimestampInfo.Builder
 
mergeFrom(Message) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.Builder
 
mergeFrom(FlinkFnApi.TypeInfo) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - 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(FlinkFnApi.TypeInfo.MapTypeInfo) - 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.MapTypeInfo.Builder
 
mergeFrom(Message) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Builder
 
mergeFrom(FlinkFnApi.TypeInfo.RowTypeInfo) - 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.Builder
 
mergeFrom(Message) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo.Field.Builder
 
mergeFrom(FlinkFnApi.TypeInfo.RowTypeInfo.Field) - 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.RowTypeInfo.Field.Builder
 
mergeFrom(Message) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TupleTypeInfo.Builder
 
mergeFrom(FlinkFnApi.TypeInfo.TupleTypeInfo) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TupleTypeInfo.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - 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(FlinkFnApi.UserDefinedAggregateFunction) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - 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(FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec) - 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.Builder
 
mergeFrom(Message) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.ListView.Builder
 
mergeFrom(FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.ListView) - 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.ListView.Builder
 
mergeFrom(Message) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapView.Builder
 
mergeFrom(FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapView) - 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.UserDefinedAggregateFunction.DataViewSpec.MapView.Builder
 
mergeFrom(Message) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
 
mergeFrom(FlinkFnApi.UserDefinedAggregateFunctions) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - 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(FlinkFnApi.UserDefinedDataStreamFunction) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.Builder
 
mergeFrom(Message) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.JobParameter.Builder
 
mergeFrom(FlinkFnApi.UserDefinedDataStreamFunction.JobParameter) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.JobParameter.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.JobParameter.Builder
 
mergeFrom(Message) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder
 
mergeFrom(FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - 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(FlinkFnApi.UserDefinedFunction) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - 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.UserDefinedFunctions) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - 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.
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.TypeInfo) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.MapTypeInfo.Builder
.org.apache.flink.fn_execution.v1.TypeInfo 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.
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;
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;
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.CoderParam.Builder
.org.apache.flink.fn_execution.v1.Schema schema = 1;
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.CoderParam.Builder
.org.apache.flink.fn_execution.v1.TypeInfo type_info = 2;
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.CoderParam.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.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.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.JobParameter.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.TypeInfo) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.MapTypeInfo.Builder
.org.apache.flink.fn_execution.v1.TypeInfo 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;
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
 
MULTIPLE_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam.OutputMode
MULTIPLE = 1;
MULTIPLE_WITH_END_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam.OutputMode
MULTIPLE_WITH_END = 2;
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
 
newBuilder() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam
 
newBuilder(FlinkFnApi.CoderParam) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam
 
newBuilder() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow
 
newBuilder(FlinkFnApi.GroupWindow) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow
 
newBuilder() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input
 
newBuilder(FlinkFnApi.Input) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input
 
newBuilder() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow
 
newBuilder(FlinkFnApi.OverWindow) - 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(FlinkFnApi.Schema.BinaryInfo) - 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(FlinkFnApi.Schema.CharInfo) - 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(FlinkFnApi.Schema.DecimalInfo) - 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(FlinkFnApi.Schema.Field) - 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(FlinkFnApi.Schema.FieldType) - 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(FlinkFnApi.Schema.LocalZonedTimestampInfo) - 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(FlinkFnApi.Schema.MapInfo) - 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(FlinkFnApi.Schema) - 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(FlinkFnApi.Schema.TimeInfo) - 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(FlinkFnApi.Schema.TimestampInfo) - 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(FlinkFnApi.Schema.VarBinaryInfo) - 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(FlinkFnApi.Schema.VarCharInfo) - 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(FlinkFnApi.Schema.ZonedTimestampInfo) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.ZonedTimestampInfo
 
newBuilder() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.MapTypeInfo
 
newBuilder(FlinkFnApi.TypeInfo.MapTypeInfo) - 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(FlinkFnApi.TypeInfo) - 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(FlinkFnApi.TypeInfo.RowTypeInfo.Field) - 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(FlinkFnApi.TypeInfo.RowTypeInfo) - 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(FlinkFnApi.TypeInfo.TupleTypeInfo) - 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(FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.ListView) - 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(FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.MapView) - 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(FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec) - 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(FlinkFnApi.UserDefinedAggregateFunction) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction
 
newBuilder() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions
 
newBuilder(FlinkFnApi.UserDefinedAggregateFunctions) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions
 
newBuilder() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.JobParameter
 
newBuilder(FlinkFnApi.UserDefinedDataStreamFunction.JobParameter) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.JobParameter
 
newBuilder() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction
 
newBuilder(FlinkFnApi.UserDefinedDataStreamFunction) - 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(FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext) - 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(FlinkFnApi.UserDefinedFunction) - 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.UserDefinedFunctions) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions
 
newBuilderForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam
 
newBuilderForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow
 
newBuilderForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input
 
newBuilderForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow
 
newBuilderForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.BinaryInfo
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.BinaryInfo
 
newBuilderForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.CharInfo
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.CharInfo
 
newBuilderForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.DecimalInfo
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.DecimalInfo
 
newBuilderForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Field
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.Field
 
newBuilderForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
 
newBuilderForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.LocalZonedTimestampInfo
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.LocalZonedTimestampInfo
 
newBuilderForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.MapInfo
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.MapInfo
 
newBuilderForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema
 
newBuilderForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimeInfo
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimeInfo
 
newBuilderForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimestampInfo
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TimestampInfo
 
newBuilderForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarBinaryInfo
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarBinaryInfo
 
newBuilderForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarCharInfo
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.VarCharInfo
 
newBuilderForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.ZonedTimestampInfo
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.ZonedTimestampInfo
 
newBuilderForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.MapTypeInfo
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.MapTypeInfo
 
newBuilderForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo
 
newBuilderForType() - 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.Field
 
newBuilderForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.RowTypeInfo
 
newBuilderForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TupleTypeInfo
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - 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(GeneratedMessageV3.BuilderParent) - 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(GeneratedMessageV3.BuilderParent) - 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(GeneratedMessageV3.BuilderParent) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec
 
newBuilderForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction
 
newBuilderForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions
 
newBuilderForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.JobParameter
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.JobParameter
 
newBuilderForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction
 
newBuilderForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext
 
newBuilderForType() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - 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.UserDefinedFunctions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam
 
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.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.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.JobParameter
 
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
 
NULLABLE_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
 
NUMBER_OF_PARALLEL_SUBTASKS_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext
 

O

of(ReadableConfig, ClassLoader) - Static method in class org.apache.flink.client.python.PythonFunctionFactory.CacheKey
 
OneInputPythonFunctionOperator<IN,OUT,UDFIN,UDFOUT> - Class in org.apache.flink.streaming.api.operators.python
OneInputPythonFunctionOperator is responsible for launching beam runner which will start a python harness to execute user defined python function.
OneInputPythonFunctionOperator(Configuration, TypeInformation<UDFIN>, TypeInformation<UDFOUT>, DataStreamPythonFunctionInfo) - Constructor for class org.apache.flink.streaming.api.operators.python.OneInputPythonFunctionOperator
 
onEventTime(InternalTimer<Row, VoidNamespace>) - Method in class org.apache.flink.streaming.api.operators.python.PythonKeyedCoProcessOperator
 
onEventTime(InternalTimer<Row, Object>) - Method in class org.apache.flink.streaming.api.operators.python.PythonKeyedProcessOperator
 
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<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.table.runtime.operators.python.aggregate.arrow.stream.StreamArrowPythonGroupWindowAggregateFunctionOperator
 
onEventTime(InternalTimer<K, W>) - Method in class org.apache.flink.table.runtime.operators.python.aggregate.PythonStreamGroupWindowAggregateOperator
 
onProcessingTime(InternalTimer<Row, VoidNamespace>) - Method in class org.apache.flink.streaming.api.operators.python.PythonKeyedCoProcessOperator
 
onProcessingTime(InternalTimer<Row, Object>) - Method in class org.apache.flink.streaming.api.operators.python.PythonKeyedProcessOperator
 
onProcessingTime(long) - Method in class org.apache.flink.streaming.api.operators.python.PythonTimestampsAndWatermarksOperator
 
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<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.table.runtime.operators.python.aggregate.arrow.stream.StreamArrowPythonGroupWindowAggregateFunctionOperator
 
onProcessingTime(InternalTimer<K, W>) - Method in class org.apache.flink.table.runtime.operators.python.aggregate.PythonStreamGroupWindowAggregateOperator
 
open() - Method in class org.apache.flink.python.env.beam.ProcessPythonEnvironmentManager
 
open() - Method in interface org.apache.flink.python.env.PythonEnvironmentManager
Initialize the environment manager.
open(PythonConfig) - Method in interface org.apache.flink.python.PythonFunctionRunner
Prepares the Python function runner, such as preparing the Python execution environment, etc.
open() - Method in class org.apache.flink.streaming.api.operators.python.AbstractPythonFunctionOperator
 
open() - Method in class org.apache.flink.streaming.api.operators.python.OneInputPythonFunctionOperator
 
open() - Method in class org.apache.flink.streaming.api.operators.python.PythonKeyedCoProcessOperator
 
open() - Method in class org.apache.flink.streaming.api.operators.python.PythonKeyedProcessOperator
 
open() - Method in class org.apache.flink.streaming.api.operators.python.PythonProcessOperator
 
open() - Method in class org.apache.flink.streaming.api.operators.python.PythonTimestampsAndWatermarksOperator
 
open() - Method in class org.apache.flink.streaming.api.operators.python.TwoInputPythonFunctionOperator
 
open(PythonConfig) - Method in class org.apache.flink.streaming.api.runners.python.beam.BeamPythonFunctionRunner
 
open(InputStream, OutputStream) - Method in class org.apache.flink.table.runtime.arrow.serializers.ArrowSerializer
 
open(Configuration) - Method in class org.apache.flink.table.runtime.arrow.sources.AbstractArrowSourceFunction
 
open(Configuration) - Method in class org.apache.flink.table.runtime.functions.python.AbstractPythonScalarFunctionFlatMap
 
open(Configuration) - Method in class org.apache.flink.table.runtime.functions.python.AbstractPythonStatelessFunctionFlatMap
 
open(Configuration) - Method in class org.apache.flink.table.runtime.functions.python.arrow.ArrowPythonScalarFunctionFlatMap
 
open(Configuration) - Method in class org.apache.flink.table.runtime.functions.python.PythonScalarFunctionFlatMap
 
open(Configuration) - Method in class org.apache.flink.table.runtime.functions.python.PythonTableFunctionFlatMap
 
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.BatchArrowPythonGroupAggregateFunctionOperator
 
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.AbstractRowDataPythonScalarFunctionOperator
 
open() - Method in class org.apache.flink.table.runtime.operators.python.scalar.AbstractRowPythonScalarFunctionOperator
 
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.arrow.RowDataArrowPythonScalarFunctionOperator
 
open() - Method in class org.apache.flink.table.runtime.operators.python.scalar.PythonScalarFunctionOperator
 
open() - Method in class org.apache.flink.table.runtime.operators.python.scalar.RowDataPythonScalarFunctionOperator
 
open() - Method in class org.apache.flink.table.runtime.operators.python.table.AbstractPythonTableFunctionOperator
 
open() - Method in class org.apache.flink.table.runtime.operators.python.table.PythonTableFunctionOperator
 
open() - Method in class org.apache.flink.table.runtime.operators.python.table.RowDataPythonTableFunctionOperator
 
org.apache.beam.runners.fnexecution.state - package org.apache.beam.runners.fnexecution.state
 
org.apache.beam.vendor.grpc.v1p26p0.io.grpc.internal - package org.apache.beam.vendor.grpc.v1p26p0.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.python - package org.apache.flink.python
 
org.apache.flink.python.env - package org.apache.flink.python.env
 
org.apache.flink.python.env.beam - package org.apache.flink.python.env.beam
 
org.apache.flink.python.metric - package org.apache.flink.python.metric
 
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.operators.python - package org.apache.flink.streaming.api.operators.python
 
org.apache.flink.streaming.api.runners.python.beam - package org.apache.flink.streaming.api.runners.python.beam
 
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.api.utils.input - package org.apache.flink.streaming.api.utils.input
 
org.apache.flink.streaming.api.utils.output - package org.apache.flink.streaming.api.utils.output
 
org.apache.flink.table.descriptors.python - package org.apache.flink.table.descriptors.python
 
org.apache.flink.table.runtime.arrow - package org.apache.flink.table.runtime.arrow
 
org.apache.flink.table.runtime.arrow.readers - package org.apache.flink.table.runtime.arrow.readers
 
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.functions.python - package org.apache.flink.table.runtime.functions.python
 
org.apache.flink.table.runtime.functions.python.arrow - package org.apache.flink.table.runtime.functions.python.arrow
 
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
 
OUTPUT_MODE_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam
 
outputMode - 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.functions.python.AbstractPythonStatelessFunctionFlatMap
The output logical type.
outputType - Variable in class org.apache.flink.table.runtime.operators.python.AbstractStatelessFunctionOperator
The output logical type.
outputType - Variable in class org.apache.flink.table.runtime.operators.python.aggregate.AbstractPythonStreamAggregateOperator
The output logical type.
OutputWithTimerRowHandler - Class in org.apache.flink.streaming.api.utils.output
This handler can accepts the runner output which contains timer registration event.
OutputWithTimerRowHandler(KeyedStateBackend<Row>, InternalTimerService, TimestampedCollector, KeyContext, TypeSerializer) - Constructor for class org.apache.flink.streaming.api.utils.output.OutputWithTimerRowHandler
 

P

pandasAggFunctions - Variable in class org.apache.flink.table.runtime.operators.python.aggregate.arrow.AbstractArrowPythonAggregateFunctionOperator
The Pandas AggregateFunctions 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.CoderParam
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - 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, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - 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, ExtensionRegistryLite) - 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, ExtensionRegistryLite) - 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, ExtensionRegistryLite) - 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, ExtensionRegistryLite) - 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, ExtensionRegistryLite) - 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, ExtensionRegistryLite) - 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, ExtensionRegistryLite) - 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, ExtensionRegistryLite) - 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, ExtensionRegistryLite) - 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, ExtensionRegistryLite) - 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, ExtensionRegistryLite) - 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, ExtensionRegistryLite) - 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, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.ZonedTimestampInfo
 
parseDelimitedFrom(InputStream) - 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.MapTypeInfo
 
parseDelimitedFrom(InputStream) - 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
 
parseDelimitedFrom(InputStream) - 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.Field
 
parseDelimitedFrom(InputStream) - 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.RowTypeInfo
 
parseDelimitedFrom(InputStream) - 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.TypeInfo.TupleTypeInfo
 
parseDelimitedFrom(InputStream) - 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.ListView
 
parseDelimitedFrom(InputStream) - 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.MapView
 
parseDelimitedFrom(InputStream) - 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.DataViewSpec
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - 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, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.JobParameter
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.JobParameter
 
parseDelimitedFrom(InputStream) - 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
 
parseDelimitedFrom(InputStream) - 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.UserDefinedDataStreamFunction.RuntimeContext
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - 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.UserDefinedFunctions
 
parseFrom(ByteBuffer) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam
 
parseFrom(ByteString) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam
 
parseFrom(byte[]) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam
 
parseFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam
 
parseFrom(CodedInputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam
 
parseFrom(ByteBuffer) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow
 
parseFrom(ByteString) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow
 
parseFrom(byte[]) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow
 
parseFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow
 
parseFrom(CodedInputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - 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, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input
 
parseFrom(ByteString) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input
 
parseFrom(byte[]) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input
 
parseFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input
 
parseFrom(CodedInputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input
 
parseFrom(ByteBuffer) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow
 
parseFrom(ByteString) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow
 
parseFrom(byte[]) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow
 
parseFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow
 
parseFrom(CodedInputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - 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, ExtensionRegistryLite) - 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.BinaryInfo
 
parseFrom(ByteString, ExtensionRegistryLite) - 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.BinaryInfo
 
parseFrom(byte[], ExtensionRegistryLite) - 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.BinaryInfo
 
parseFrom(InputStream, ExtensionRegistryLite) - 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.BinaryInfo
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - 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, ExtensionRegistryLite) - 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.CharInfo
 
parseFrom(ByteString, ExtensionRegistryLite) - 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.CharInfo
 
parseFrom(byte[], ExtensionRegistryLite) - 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.CharInfo
 
parseFrom(InputStream, ExtensionRegistryLite) - 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.CharInfo
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - 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, ExtensionRegistryLite) - 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.DecimalInfo
 
parseFrom(ByteString, ExtensionRegistryLite) - 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.DecimalInfo
 
parseFrom(byte[], ExtensionRegistryLite) - 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.DecimalInfo
 
parseFrom(InputStream, ExtensionRegistryLite) - 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.DecimalInfo
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - 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, ExtensionRegistryLite) - 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.Field
 
parseFrom(ByteString, ExtensionRegistryLite) - 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.Field
 
parseFrom(byte[], ExtensionRegistryLite) - 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.Field
 
parseFrom(InputStream, ExtensionRegistryLite) - 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.Field
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - 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, ExtensionRegistryLite) - 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.FieldType
 
parseFrom(ByteString, ExtensionRegistryLite) - 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.FieldType
 
parseFrom(byte[], ExtensionRegistryLite) - 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.FieldType
 
parseFrom(InputStream, ExtensionRegistryLite) - 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.FieldType
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - 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, ExtensionRegistryLite) - 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.LocalZonedTimestampInfo
 
parseFrom(ByteString, ExtensionRegistryLite) - 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.LocalZonedTimestampInfo
 
parseFrom(byte[], ExtensionRegistryLite) - 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.LocalZonedTimestampInfo
 
parseFrom(InputStream, ExtensionRegistryLite) - 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.LocalZonedTimestampInfo
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - 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, ExtensionRegistryLite) - 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.MapInfo
 
parseFrom(ByteString, ExtensionRegistryLite) - 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.MapInfo
 
parseFrom(byte[], ExtensionRegistryLite) - 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.MapInfo
 
parseFrom(InputStream, ExtensionRegistryLite) - 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.MapInfo
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - 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, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema
 
parseFrom(ByteString) - 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
 
parseFrom(byte[]) - 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
 
parseFrom(InputStream) - 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
 
parseFrom(CodedInputStream) - 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
 
parseFrom(ByteBuffer) - 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.TimeInfo
 
parseFrom(ByteString) - 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.TimeInfo
 
parseFrom(byte[]) - 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.TimeInfo
 
parseFrom(InputStream) - 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.TimeInfo
 
parseFrom(CodedInputStream) - 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.TimeInfo
 
parseFrom(ByteBuffer) - 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.TimestampInfo
 
parseFrom(ByteString) - 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.TimestampInfo
 
parseFrom(byte[]) - 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.TimestampInfo
 
parseFrom(InputStream) - 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.TimestampInfo
 
parseFrom(CodedInputStream) - 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.TimestampInfo
 
parseFrom(ByteBuffer) - 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.VarBinaryInfo
 
parseFrom(ByteString) - 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.VarBinaryInfo
 
parseFrom(byte[]) - 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.VarBinaryInfo
 
parseFrom(InputStream) - 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.VarBinaryInfo
 
parseFrom(CodedInputStream) - 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.VarBinaryInfo
 
parseFrom(ByteBuffer) - 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.VarCharInfo
 
parseFrom(ByteString) - 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.VarCharInfo
 
parseFrom(byte[]) - 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.VarCharInfo
 
parseFrom(InputStream) - 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.VarCharInfo
 
parseFrom(CodedInputStream) - 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.VarCharInfo
 
parseFrom(ByteBuffer) - 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.Schema.ZonedTimestampInfo
 
parseFrom(ByteString) - 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.Schema.ZonedTimestampInfo
 
parseFrom(byte[]) - 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.Schema.ZonedTimestampInfo
 
parseFrom(InputStream) - 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.Schema.ZonedTimestampInfo
 
parseFrom(CodedInputStream) - 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.Schema.ZonedTimestampInfo
 
parseFrom(ByteBuffer) - 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.MapTypeInfo
 
parseFrom(ByteString) - 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.MapTypeInfo
 
parseFrom(byte[]) - 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.MapTypeInfo
 
parseFrom(InputStream) - 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.MapTypeInfo
 
parseFrom(CodedInputStream) - 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.MapTypeInfo
 
parseFrom(ByteBuffer) - 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
 
parseFrom(ByteString) - 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
 
parseFrom(byte[]) - 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
 
parseFrom(InputStream) - 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
 
parseFrom(CodedInputStream) - 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
 
parseFrom(ByteBuffer) - 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.Field
 
parseFrom(ByteString) - 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.Field
 
parseFrom(byte[]) - 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.Field
 
parseFrom(InputStream) - 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.Field
 
parseFrom(CodedInputStream) - 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.Field
 
parseFrom(ByteBuffer) - 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.RowTypeInfo
 
parseFrom(ByteString) - 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.RowTypeInfo
 
parseFrom(byte[]) - 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.RowTypeInfo
 
parseFrom(InputStream) - 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.RowTypeInfo
 
parseFrom(CodedInputStream) - 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.RowTypeInfo
 
parseFrom(ByteBuffer) - 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.TypeInfo.TupleTypeInfo
 
parseFrom(ByteString) - 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.TypeInfo.TupleTypeInfo
 
parseFrom(byte[]) - 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.TypeInfo.TupleTypeInfo
 
parseFrom(InputStream) - 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.TypeInfo.TupleTypeInfo
 
parseFrom(CodedInputStream) - 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.TypeInfo.TupleTypeInfo
 
parseFrom(ByteBuffer) - 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.ListView
 
parseFrom(ByteString) - 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.ListView
 
parseFrom(byte[]) - 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.ListView
 
parseFrom(InputStream) - 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.ListView
 
parseFrom(CodedInputStream) - 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.ListView
 
parseFrom(ByteBuffer) - 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.MapView
 
parseFrom(ByteString) - 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.MapView
 
parseFrom(byte[]) - 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.MapView
 
parseFrom(InputStream) - 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.MapView
 
parseFrom(CodedInputStream) - 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.MapView
 
parseFrom(ByteBuffer) - 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.DataViewSpec
 
parseFrom(ByteString) - 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.DataViewSpec
 
parseFrom(byte[]) - 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.DataViewSpec
 
parseFrom(InputStream) - 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.DataViewSpec
 
parseFrom(CodedInputStream) - 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.DataViewSpec
 
parseFrom(ByteBuffer) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction
 
parseFrom(ByteString) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction
 
parseFrom(byte[]) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction
 
parseFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction
 
parseFrom(CodedInputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - 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, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions
 
parseFrom(ByteString) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions
 
parseFrom(byte[]) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions
 
parseFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions
 
parseFrom(CodedInputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions
 
parseFrom(ByteBuffer) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.JobParameter
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.JobParameter
 
parseFrom(ByteString) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.JobParameter
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.JobParameter
 
parseFrom(byte[]) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.JobParameter
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.JobParameter
 
parseFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.JobParameter
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.JobParameter
 
parseFrom(CodedInputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.JobParameter
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.JobParameter
 
parseFrom(ByteBuffer) - 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
 
parseFrom(ByteString) - 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
 
parseFrom(byte[]) - 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
 
parseFrom(InputStream) - 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
 
parseFrom(CodedInputStream) - 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
 
parseFrom(ByteBuffer) - 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.UserDefinedDataStreamFunction.RuntimeContext
 
parseFrom(ByteString) - 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.UserDefinedDataStreamFunction.RuntimeContext
 
parseFrom(byte[]) - 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.UserDefinedDataStreamFunction.RuntimeContext
 
parseFrom(InputStream) - 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.UserDefinedDataStreamFunction.RuntimeContext
 
parseFrom(CodedInputStream) - 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.UserDefinedDataStreamFunction.RuntimeContext
 
parseFrom(ByteBuffer) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction
 
parseFrom(ByteString) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction
 
parseFrom(byte[]) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction
 
parseFrom(InputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction
 
parseFrom(CodedInputStream) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunction
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - 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.UserDefinedFunctions
 
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.UserDefinedFunctions
 
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.UserDefinedFunctions
 
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.UserDefinedFunctions
 
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.UserDefinedFunctions
 
parsePythonDependencyConfiguration(CommandLine) - Static method in class org.apache.flink.python.util.PythonDependencyUtils
 
parser() - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam
 
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.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.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.JobParameter
 
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
 
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_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
 
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_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TypeName
PRIMITIVE_ARRAY = 16;
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_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.FunctionType
PROCESS = 4;
processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.api.operators.python.OneInputPythonFunctionOperator
 
processElement(StreamRecord<Row>) - Method in class org.apache.flink.streaming.api.operators.python.PythonKeyedProcessOperator
 
processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.api.operators.python.PythonProcessOperator
 
processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.api.operators.python.PythonTimestampsAndWatermarksOperator
 
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
 
processElement1(StreamRecord<Row>) - Method in class org.apache.flink.streaming.api.operators.python.PythonKeyedCoProcessOperator
 
processElement1(StreamRecord<IN1>) - Method in class org.apache.flink.streaming.api.operators.python.TwoInputPythonFunctionOperator
 
processElement2(StreamRecord<Row>) - Method in class org.apache.flink.streaming.api.operators.python.PythonKeyedCoProcessOperator
 
processElement2(StreamRecord<IN2>) - Method in class org.apache.flink.streaming.api.operators.python.TwoInputPythonFunctionOperator
 
processElementInternal(Row) - Method in class org.apache.flink.table.runtime.functions.python.AbstractPythonStatelessFunctionFlatMap
 
processElementInternal(Row) - Method in class org.apache.flink.table.runtime.functions.python.arrow.ArrowPythonScalarFunctionFlatMap
 
processElementInternal(Row) - Method in class org.apache.flink.table.runtime.functions.python.PythonScalarFunctionFlatMap
 
processElementInternal(Row) - Method in class org.apache.flink.table.runtime.functions.python.PythonTableFunctionFlatMap
 
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(CRow) - 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.arrow.RowDataArrowPythonScalarFunctionOperator
 
processElementInternal(CRow) - Method in class org.apache.flink.table.runtime.operators.python.scalar.PythonScalarFunctionOperator
 
processElementInternal(RowData) - Method in class org.apache.flink.table.runtime.operators.python.scalar.RowDataPythonScalarFunctionOperator
 
processElementInternal(CRow) - Method in class org.apache.flink.table.runtime.operators.python.table.PythonTableFunctionOperator
 
processElementInternal(RowData) - Method in class org.apache.flink.table.runtime.operators.python.table.RowDataPythonTableFunctionOperator
 
ProcessPythonEnvironment - Class in org.apache.flink.python.env
A PythonEnvironment for executing UDFs in Process.
ProcessPythonEnvironment(String, Map<String, String>) - Constructor for class org.apache.flink.python.env.ProcessPythonEnvironment
 
ProcessPythonEnvironmentManager - Class in org.apache.flink.python.env.beam
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>) - Constructor for class org.apache.flink.python.env.beam.ProcessPythonEnvironmentManager
 
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.PythonProcessOperator
 
processWatermark(Watermark) - Method in class org.apache.flink.streaming.api.operators.python.PythonTimestampsAndWatermarksOperator
 
properties(Map<String, String>) - Method in class org.apache.flink.table.descriptors.python.CustomFormatDescriptor
Adds a set of properties for the format.
property(String, String) - Method in class org.apache.flink.table.descriptors.python.CustomFormatDescriptor
Adds a configuration property for the format.
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 - Static variable in class org.apache.flink.python.util.PythonDependencyUtils
 
PYTHON_CLIENT_EXECUTABLE - Static variable in class org.apache.flink.python.PythonOptions
 
PYTHON_EXECUTABLE - Static variable in class org.apache.flink.python.PythonOptions
 
PYTHON_FILES - Static variable in class org.apache.flink.python.PythonOptions
 
PYTHON_FILES - Static variable in class org.apache.flink.python.util.PythonDependencyUtils
 
PYTHON_FUNCTION_FACTORY_CACHE - Static variable in interface org.apache.flink.client.python.PythonFunctionFactory
 
PYTHON_METRIC_ENABLED - Static variable in class org.apache.flink.python.PythonOptions
The configuration to enable or disable metric 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.beam.ProcessPythonEnvironmentManager
 
PYTHON_REQUIREMENTS_FILE - Static variable in class org.apache.flink.python.env.beam.ProcessPythonEnvironmentManager
 
PYTHON_REQUIREMENTS_FILE - Static variable in class org.apache.flink.python.util.PythonDependencyUtils
 
PYTHON_REQUIREMENTS_INSTALL_DIR - Static variable in class org.apache.flink.python.env.beam.ProcessPythonEnvironmentManager
 
PYTHON_WORKING_DIR - Static variable in class org.apache.flink.python.env.beam.ProcessPythonEnvironmentManager
 
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
 
PythonCoFlatMapOperator<IN1,IN2,OUT> - Class in org.apache.flink.streaming.api.operators.python
The PythonCoFlatMapOperator is responsible for executing the Python CoMap Function.
PythonCoFlatMapOperator(Configuration, TypeInformation<IN1>, TypeInformation<IN2>, TypeInformation<OUT>, DataStreamPythonFunctionInfo) - Constructor for class org.apache.flink.streaming.api.operators.python.PythonCoFlatMapOperator
 
PythonCoMapOperator<IN1,IN2,OUT> - Class in org.apache.flink.streaming.api.operators.python
The PythonCoFlatMapOperator is responsible for executing the Python CoMap Function.
PythonCoMapOperator(Configuration, TypeInformation<IN1>, TypeInformation<IN2>, TypeInformation<OUT>, DataStreamPythonFunctionInfo) - Constructor for class org.apache.flink.streaming.api.operators.python.PythonCoMapOperator
 
PythonConfig - Class in org.apache.flink.python
Configurations for the Python job which are used at run time.
PythonConfig(Configuration) - Constructor for class org.apache.flink.python.PythonConfig
 
PythonConfigUtil - Class in org.apache.flink.python.util
A Util class to get the StreamExecutionEnvironment configuration and merged configuration with environment settings.
PythonConfigUtil() - Constructor for class org.apache.flink.python.util.PythonConfigUtil
 
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
 
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
 
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 and the RetrievalToken.
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
 
PythonFlatMapOperator<IN,OUT> - Class in org.apache.flink.streaming.api.operators.python
The PythonFlatMapOperator is responsible for executing Python functions that gets one input and produces zero/one or more outputs.
PythonFlatMapOperator(Configuration, TypeInformation<IN>, TypeInformation<OUT>, DataStreamPythonFunctionInfo) - Constructor for class org.apache.flink.streaming.api.operators.python.PythonFlatMapOperator
 
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 - Interface in org.apache.flink.python
The base interface of runner which is responsible for the execution of Python functions.
pythonFunctionRunner - Variable in class org.apache.flink.streaming.api.operators.python.AbstractPythonFunctionOperator
The PythonFunctionRunner which is responsible for Python user-defined function execution.
pythonFunctionRunner - Variable in class org.apache.flink.table.runtime.functions.python.AbstractPythonStatelessFunctionFlatMap
The PythonFunctionRunner which is responsible for Python user-defined function execution.
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.
PythonKeyedCoProcessOperator<OUT> - Class in org.apache.flink.streaming.api.operators.python
KeyedCoProcessOperator.
PythonKeyedCoProcessOperator(Configuration, TypeInformation<Row>, TypeInformation<Row>, TypeInformation<OUT>, DataStreamPythonFunctionInfo) - Constructor for class org.apache.flink.streaming.api.operators.python.PythonKeyedCoProcessOperator
 
PythonKeyedProcessOperator<OUT> - Class in org.apache.flink.streaming.api.operators.python
PythonKeyedProcessOperator is responsible for launching beam runner which will start a python harness to execute user defined python function.
PythonKeyedProcessOperator(Configuration, RowTypeInfo, TypeInformation<OUT>, DataStreamPythonFunctionInfo) - Constructor for class org.apache.flink.streaming.api.operators.python.PythonKeyedProcessOperator
 
PythonKeyedProcessOperator(Configuration, RowTypeInfo, TypeInformation<OUT>, DataStreamPythonFunctionInfo, TypeSerializer) - Constructor for class org.apache.flink.streaming.api.operators.python.PythonKeyedProcessOperator
 
PythonMapOperator<IN,OUT> - Class in org.apache.flink.streaming.api.operators.python
The PythonMapOperator is responsible for executing Python functions that gets one input and produces zero/one or more outputs.
PythonMapOperator(Configuration, TypeInformation<IN>, TypeInformation<OUT>, DataStreamPythonFunctionInfo) - Constructor for class org.apache.flink.streaming.api.operators.python.PythonMapOperator
 
PythonOperatorUtils - Enum in org.apache.flink.streaming.api.utils
The collectors used to collect Row values.
PythonOptions - Class in org.apache.flink.python
Configuration options for the Python API.
PythonOptions() - Constructor for class org.apache.flink.python.PythonOptions
 
PythonPartitionCustomOperator<IN,OUT> - Class in org.apache.flink.streaming.api.operators.python
The PythonPartitionCustomOperator enables us to set the number of partitions for current operator dynamically when generating the StreamGraph before executing the job.
PythonPartitionCustomOperator(Configuration, TypeInformation<IN>, TypeInformation<OUT>, DataStreamPythonFunctionInfo) - Constructor for class org.apache.flink.streaming.api.operators.python.PythonPartitionCustomOperator
 
PythonProcessOperator<IN,OUT> - Class in org.apache.flink.streaming.api.operators.python
PythonProcessOperator is responsible for launching beam runner which will start a python harness to execute user defined python ProcessFunction.
PythonProcessOperator(Configuration, TypeInformation<IN>, TypeInformation<OUT>, DataStreamPythonFunctionInfo) - Constructor for class org.apache.flink.streaming.api.operators.python.PythonProcessOperator
 
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
 
PythonScalarFunctionFlatMap - Class in org.apache.flink.table.runtime.functions.python
The RichFlatMapFunction used to invoke Python ScalarFunction functions for the old planner.
PythonScalarFunctionFlatMap(Configuration, PythonFunctionInfo[], RowType, RowType, int[], int[]) - Constructor for class org.apache.flink.table.runtime.functions.python.PythonScalarFunctionFlatMap
 
PythonScalarFunctionOperator - Class in org.apache.flink.table.runtime.operators.python.scalar
The Python ScalarFunction operator for the legacy planner.
PythonScalarFunctionOperator(Configuration, PythonFunctionInfo[], RowType, RowType, int[], int[]) - 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 for the blink planner.
PythonStreamGroupAggregateOperator(Configuration, RowType, RowType, PythonAggregateFunctionInfo[], DataViewUtils.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 for the blink planner.
PythonStreamGroupTableAggregateOperator(Configuration, RowType, RowType, PythonAggregateFunctionInfo[], DataViewUtils.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 for the blink planner.
PythonStreamGroupWindowAggregateOperator(Configuration, RowType, RowType, PythonAggregateFunctionInfo[], DataViewUtils.DataViewSpec[][], int[], int, boolean, boolean, int, WindowAssigner<W>, LogicalWindow, long, PlannerNamedWindowProperty[], ZoneId) - Constructor for class org.apache.flink.table.runtime.operators.python.aggregate.PythonStreamGroupWindowAggregateOperator
 
PythonTableFunctionFlatMap - Class in org.apache.flink.table.runtime.functions.python
The RichFlatMapFunction used to invoke Python TableFunction functions for the old planner.
PythonTableFunctionFlatMap(Configuration, PythonFunctionInfo, RowType, RowType, int[], JoinRelType) - Constructor for class org.apache.flink.table.runtime.functions.python.PythonTableFunctionFlatMap
 
PythonTableFunctionOperator - Class in org.apache.flink.table.runtime.operators.python.table
The Python TableFunction operator for the legacy planner.
PythonTableFunctionOperator(Configuration, PythonFunctionInfo, RowType, RowType, int[], JoinRelType) - Constructor for class org.apache.flink.table.runtime.operators.python.table.PythonTableFunctionOperator
 
PythonTimestampsAndWatermarksOperator<IN> - Class in org.apache.flink.streaming.api.operators.python
A stream operator that may do one or both of the following: extract timestamps from events and generate watermarks by user specify TimestampAssigner and WatermarkStrategy.
PythonTimestampsAndWatermarksOperator(Configuration, TypeInformation<IN>, DataStreamPythonFunctionInfo, WatermarkStrategy<IN>) - Constructor for class org.apache.flink.streaming.api.operators.python.PythonTimestampsAndWatermarksOperator
 
PythonTypeUtils - Class in org.apache.flink.streaming.api.utils
A util class for converting the given TypeInformation to other objects.
PythonTypeUtils() - Constructor for class org.apache.flink.streaming.api.utils.PythonTypeUtils
 
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.table.runtime.typeutils.PythonTypeUtils
 
PythonTypeUtils.LogicalTypeToConversionClassConverter - Class in org.apache.flink.table.runtime.typeutils
Convert LogicalType to conversion class for flink planner.
PythonTypeUtils.LogicalTypeToProtoTypeConverter - Class in org.apache.flink.table.runtime.typeutils
Converter That convert the logicalType to the related Prototype.
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.

R

RANGE_SLIDING_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow.WindowType
RANGE_SLIDING = 3;
RANGE_UNBOUNDED_FOLLOWING_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow.WindowType
RANGE_UNBOUNDED_FOLLOWING = 2;
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_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam.DataType
RAW = 2;
read(int) - Method in interface 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.readers.ArrayFieldReader
 
read(int) - Method in class org.apache.flink.table.runtime.arrow.readers.ArrowFieldReader
Sets the field value as the specified value.
read(int) - Method in class org.apache.flink.table.runtime.arrow.readers.BigIntFieldReader
 
read(int) - Method in class org.apache.flink.table.runtime.arrow.readers.BooleanFieldReader
 
read(int) - Method in class org.apache.flink.table.runtime.arrow.readers.DateFieldReader
 
read(int) - Method in class org.apache.flink.table.runtime.arrow.readers.DecimalFieldReader
 
read(int) - Method in class org.apache.flink.table.runtime.arrow.readers.DoubleFieldReader
 
read(int) - Method in class org.apache.flink.table.runtime.arrow.readers.FloatFieldReader
 
read(int) - Method in class org.apache.flink.table.runtime.arrow.readers.IntFieldReader
 
read(int) - Method in class org.apache.flink.table.runtime.arrow.readers.RowArrowReader
 
read(int) - Method in class org.apache.flink.table.runtime.arrow.readers.RowFieldReader
 
read(int) - Method in class org.apache.flink.table.runtime.arrow.readers.SmallIntFieldReader
 
read(int) - Method in class org.apache.flink.table.runtime.arrow.readers.TimeFieldReader
 
read(int) - Method in class org.apache.flink.table.runtime.arrow.readers.TimestampFieldReader
 
read(int) - Method in class org.apache.flink.table.runtime.arrow.readers.TinyIntFieldReader
 
read(int) - Method in class org.apache.flink.table.runtime.arrow.readers.VarBinaryFieldReader
 
read(int) - Method in class org.apache.flink.table.runtime.arrow.readers.VarCharFieldReader
 
read(int) - Method in class org.apache.flink.table.runtime.arrow.serializers.ArrowSerializer
 
read(int) - Method in class org.apache.flink.table.runtime.arrow.vectors.RowDataArrowReader
 
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, boolean) - Static method in class org.apache.flink.api.common.python.PythonBridgeUtils
 
readPythonObjects(String) - 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(ExtensionRegistryLite) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.apache.flink.fnexecution.v1.FlinkFnApi
 
registerForProcessBundleInstructionId(String, StateRequestHandler) - Method in class org.apache.beam.runners.fnexecution.state.GrpcStateService
 
release(SharedResourceHolder.Resource<T>, T) - Static method in class org.apache.beam.vendor.grpc.v1p26p0.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.UserDefinedDataStreamFunction.RuntimeContext.Builder
repeated .org.apache.flink.fn_execution.v1.UserDefinedDataStreamFunction.JobParameter job_parameters = 7;
removeSpecs(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.Builder
repeated .org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction.DataViewSpec specs = 3;
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;
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.RowArrayWriter
 
reset() - Method in class org.apache.flink.table.runtime.arrow.writers.RowRowWriter
 
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(TypeSerializer<ArrayData>) - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.ArrayDataSerializer.ArrayDataSerializerSnapshot
 
resolveSchemaCompatibility(TypeSerializer<DecimalData>) - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.DecimalDataSerializer.DecimalSerializerSnapshot
 
resolveSchemaCompatibility(TypeSerializer<MapData>) - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.MapDataSerializer.BaseMapSerializerSnapshot
 
resolveSchemaCompatibility(TypeSerializer<RowData>) - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.RowDataSerializer.RowDataSerializerSnapshot
 
resolveSchemaCompatibility(TypeSerializer<Timestamp>) - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.TimestampSerializer.TimestampSerializerSnapshot
 
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
The Python function execution result receiver.
resultCollector - Variable in class org.apache.flink.table.runtime.functions.python.AbstractPythonStatelessFunctionFlatMap
The collector used to collect records.
resultTuple - Variable in class org.apache.flink.streaming.api.runners.python.beam.BeamPythonFunctionRunner
The Python function execution result tuple.
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.AbstractRowDataPythonScalarFunctionOperator
The JoinedRowData reused holding the execution result.
reuseRow - Variable in class org.apache.flink.streaming.api.operators.python.TwoInputPythonFunctionOperator
 
reuseRunnerInput - Variable in class org.apache.flink.streaming.api.utils.input.KeyedInputWithTimerRowFactory
 
reuseTimerData - Variable in class org.apache.flink.streaming.api.utils.input.KeyedInputWithTimerRowFactory
Reusable row for timer data runner inputs.
ROW_SCHEMA_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
 
ROW_SLIDING_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow.WindowType
ROW_SLIDING = 7;
ROW_TIME_ATTRIBUTE_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.WindowProperty
ROW_TIME_ATTRIBUTE = 2;
ROW_TYPE_INFO_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo
 
ROW_UNBOUNDED_FOLLOWING_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow.WindowType
ROW_UNBOUNDED_FOLLOWING = 6;
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.CoderParam.DataType
ROW = 1;
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;
RowArrayWriter - Class in org.apache.flink.table.runtime.arrow.writers
ArrowFieldWriter for Array.
RowArrayWriter(ListVector, ArrowFieldWriter<Row>) - Constructor for class org.apache.flink.table.runtime.arrow.writers.RowArrayWriter
 
RowArrowReader - Class in org.apache.flink.table.runtime.arrow.readers
ArrowReader which read the underlying Arrow format data as Row.
RowArrowReader(ArrowFieldReader[]) - Constructor for class org.apache.flink.table.runtime.arrow.readers.RowArrowReader
 
RowArrowSerializer - Class in org.apache.flink.table.runtime.arrow.serializers
It takes Row as the input type.
RowArrowSerializer(RowType, RowType) - Constructor for class org.apache.flink.table.runtime.arrow.serializers.RowArrowSerializer
 
RowArrowSourceFunction - Class in org.apache.flink.table.runtime.arrow.sources
An Arrow SourceFunction which takes Row as the type of the produced records.
RowArrowTableSource - Class in org.apache.flink.table.runtime.arrow.sources
An Arrow TableSource which takes Row as the type of the produced records.
RowArrowTableSource(DataType, byte[][]) - Constructor for class org.apache.flink.table.runtime.arrow.sources.RowArrowTableSource
 
RowBigIntWriter - Class in org.apache.flink.table.runtime.arrow.writers
ArrowFieldWriter for BigInt.
RowBigIntWriter(BigIntVector) - Constructor for class org.apache.flink.table.runtime.arrow.writers.RowBigIntWriter
 
RowBooleanWriter - Class in org.apache.flink.table.runtime.arrow.writers
ArrowFieldWriter for Boolean.
RowBooleanWriter(BitVector) - Constructor for class org.apache.flink.table.runtime.arrow.writers.RowBooleanWriter
 
RowDataArrowPythonScalarFunctionOperator - Class in org.apache.flink.table.runtime.operators.python.scalar.arrow
Arrow Python ScalarFunction operator for the blink planner.
RowDataArrowPythonScalarFunctionOperator(Configuration, PythonFunctionInfo[], RowType, RowType, int[], int[]) - Constructor for class org.apache.flink.table.runtime.operators.python.scalar.arrow.RowDataArrowPythonScalarFunctionOperator
 
RowDataArrowReader - Class in org.apache.flink.table.runtime.arrow.vectors
ArrowReader which read the underlying Arrow format data as RowData.
RowDataArrowReader(ColumnVector[]) - Constructor for class org.apache.flink.table.runtime.arrow.vectors.RowDataArrowReader
 
RowDataArrowSerializer - Class in org.apache.flink.table.runtime.arrow.serializers
It takes RowData as the input type.
RowDataArrowSerializer(RowType, RowType) - Constructor for class org.apache.flink.table.runtime.arrow.serializers.RowDataArrowSerializer
 
RowDataPythonScalarFunctionOperator - Class in org.apache.flink.table.runtime.operators.python.scalar
The Python ScalarFunction operator for the blink planner.
RowDataPythonScalarFunctionOperator(Configuration, PythonFunctionInfo[], RowType, RowType, int[], int[]) - Constructor for class org.apache.flink.table.runtime.operators.python.scalar.RowDataPythonScalarFunctionOperator
 
RowDataPythonTableFunctionOperator - Class in org.apache.flink.table.runtime.operators.python.table
The Python TableFunction operator for the blink planner.
RowDataPythonTableFunctionOperator(Configuration, PythonFunctionInfo, RowType, RowType, int[], FlinkJoinType) - Constructor for class org.apache.flink.table.runtime.operators.python.table.RowDataPythonTableFunctionOperator
 
RowDataSerializer - Class in org.apache.flink.table.runtime.typeutils.serializers.python
A TypeSerializer for RowData.
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 for RowDataSerializer.
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.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.AbstractRowDataPythonScalarFunctionOperator
The collector used to collect records.
RowDateWriter - Class in org.apache.flink.table.runtime.arrow.writers
RowDateWriter(DateDayVector) - Constructor for class org.apache.flink.table.runtime.arrow.writers.RowDateWriter
 
RowDecimalWriter - Class in org.apache.flink.table.runtime.arrow.writers
ArrowFieldWriter for Decimal.
RowDecimalWriter(DecimalVector, int, int) - Constructor for class org.apache.flink.table.runtime.arrow.writers.RowDecimalWriter
 
RowDoubleWriter - Class in org.apache.flink.table.runtime.arrow.writers
ArrowFieldWriter for Double.
RowDoubleWriter(Float8Vector) - Constructor for class org.apache.flink.table.runtime.arrow.writers.RowDoubleWriter
 
RowFieldReader - Class in org.apache.flink.table.runtime.arrow.readers
RowFieldReader(StructVector, ArrowFieldReader[]) - Constructor for class org.apache.flink.table.runtime.arrow.readers.RowFieldReader
 
RowFloatWriter - Class in org.apache.flink.table.runtime.arrow.writers
ArrowFieldWriter for Float.
RowFloatWriter(Float4Vector) - Constructor for class org.apache.flink.table.runtime.arrow.writers.RowFloatWriter
 
RowIntWriter - Class in org.apache.flink.table.runtime.arrow.writers
RowIntWriter(IntVector) - Constructor for class org.apache.flink.table.runtime.arrow.writers.RowIntWriter
 
RowRowWriter - Class in org.apache.flink.table.runtime.arrow.writers
RowRowWriter(StructVector, ArrowFieldWriter<Row>[]) - Constructor for class org.apache.flink.table.runtime.arrow.writers.RowRowWriter
 
RowSmallIntWriter - Class in org.apache.flink.table.runtime.arrow.writers
ArrowFieldWriter for SmallInt.
RowSmallIntWriter(SmallIntVector) - Constructor for class org.apache.flink.table.runtime.arrow.writers.RowSmallIntWriter
 
RowTimestampWriter - Class in org.apache.flink.table.runtime.arrow.writers
ArrowFieldWriter for Timestamp.
RowTimestampWriter(ValueVector) - Constructor for class org.apache.flink.table.runtime.arrow.writers.RowTimestampWriter
 
RowTimeWriter - Class in org.apache.flink.table.runtime.arrow.writers
RowTimeWriter(ValueVector) - Constructor for class org.apache.flink.table.runtime.arrow.writers.RowTimeWriter
 
RowTinyIntWriter - Class in org.apache.flink.table.runtime.arrow.writers
ArrowFieldWriter for TinyInt.
RowTinyIntWriter(TinyIntVector) - Constructor for class org.apache.flink.table.runtime.arrow.writers.RowTinyIntWriter
 
RowVarBinaryWriter - Class in org.apache.flink.table.runtime.arrow.writers
ArrowFieldWriter for VarBinary.
RowVarBinaryWriter(VarBinaryVector) - Constructor for class org.apache.flink.table.runtime.arrow.writers.RowVarBinaryWriter
 
RowVarCharWriter - Class in org.apache.flink.table.runtime.arrow.writers
ArrowFieldWriter for VarChar.
RowVarCharWriter(VarCharVector) - Constructor for class org.apache.flink.table.runtime.arrow.writers.RowVarCharWriter
 
RowWriter<T> - Class in org.apache.flink.table.runtime.arrow.writers
RowWriter.RowWriterForArray - Class in org.apache.flink.table.runtime.arrow.writers
RowWriter for ArrayData input.
RowWriter.RowWriterForRow - Class in org.apache.flink.table.runtime.arrow.writers
RowWriter for RowData input.
run(SourceFunction.SourceContext<OUT>) - Method in class org.apache.flink.table.runtime.arrow.sources.AbstractArrowSourceFunction
 
RunnerInputType - Enum in org.apache.flink.streaming.api.utils.input
The type of the runner input.
RunnerOutputType - Enum in org.apache.flink.streaming.api.utils.output
The type of the runner output.
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.functions.python.AbstractPythonScalarFunctionFlatMap
The Python ScalarFunctions to be executed.
scalarFunctions - Variable in class org.apache.flink.table.runtime.operators.python.scalar.AbstractPythonScalarFunctionOperator
The Python ScalarFunctions 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.CoderParam
 
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(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(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(String, DataOutputView) - Method in class org.apache.flink.table.runtime.typeutils.serializers.python.StringSerializer
 
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
 
SESSION_GROUP_WINDOW_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.WindowType
SESSION_GROUP_WINDOW = 2;
setAllowedLateness(long) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.Builder
int64 allowedLateness = 8;
setAttemptNumber(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder
int32 attempt_number = 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;
setChange(boolean) - Method in class org.apache.flink.table.runtime.operators.python.utils.StreamRecordCRowWrappingCollector
 
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;
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.PythonKeyedCoProcessOperator
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.PythonKeyedProcessOperator
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 enum org.apache.flink.streaming.api.utils.PythonOperatorUtils
Set the current key for streaming operator.
setData(byte[]) - Method in class org.apache.flink.streaming.api.utils.ByteArrayWrapper
 
setDataType(FlinkFnApi.CoderParam.DataType) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam.Builder
.org.apache.flink.fn_execution.v1.CoderParam.DataType data_type = 3;
setDataTypeValue(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam.Builder
.org.apache.flink.fn_execution.v1.CoderParam.DataType data_type = 3;
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;
setEnvironmentVariable(String, String) - Method in class org.apache.flink.python.env.beam.ProcessPythonEnvironmentManager
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam.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.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.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.JobParameter.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
 
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;
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.
setInBatchExecutionMode(boolean) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder
bool in_batch_execution_mode = 8;
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.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) - 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.UserDefinedFunction.Builder
The input arguments of the user-defined function, it could be one of the following: 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.UserDefinedDataStreamFunction.JobParameter) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder
repeated .org.apache.flink.fn_execution.v1.UserDefinedDataStreamFunction.JobParameter job_parameters = 7;
setJobParameters(int, FlinkFnApi.UserDefinedDataStreamFunction.JobParameter.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder
repeated .org.apache.flink.fn_execution.v1.UserDefinedDataStreamFunction.JobParameter job_parameters = 7;
setKey(String) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.JobParameter.Builder
string key = 1;
setKeyBytes(ByteString) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.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.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.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;
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.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) - 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.UserDefinedAggregateFunctions.Builder
The schema of the grouping keys.
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
 
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.
setMapStateWriteCacheSize(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.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;
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;
setNumberOfParallelSubtasks(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.RuntimeContext.Builder
int32 number_of_parallel_subtasks = 3;
setNumPartitions(int) - Method in class org.apache.flink.streaming.api.operators.python.PythonPartitionCustomOperator
 
setOffset(int) - Method in class org.apache.flink.streaming.api.utils.ByteArrayWrapper
 
setOutputMode(FlinkFnApi.CoderParam.OutputMode) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam.Builder
.org.apache.flink.fn_execution.v1.CoderParam.OutputMode output_mode = 4;
setOutputModeValue(int) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam.Builder
.org.apache.flink.fn_execution.v1.CoderParam.OutputMode output_mode = 4;
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;
setPythonConfig(PythonConfig) - Method in class org.apache.flink.streaming.api.operators.python.AbstractPythonFunctionOperator
Reset the PythonConfig if needed.
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam.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.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.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.JobParameter.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
 
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;
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;
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(FlinkFnApi.Schema) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam.Builder
.org.apache.flink.fn_execution.v1.Schema schema = 1;
setSchema(FlinkFnApi.Schema.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam.Builder
.org.apache.flink.fn_execution.v1.Schema schema = 1;
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.
setStateCleaningEnabled(boolean) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions.Builder
Cleanup the expired state if true.
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;
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;
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.CoderParam.Builder
.org.apache.flink.fn_execution.v1.TypeInfo type_info = 2;
setTypeInfo(FlinkFnApi.TypeInfo.Builder) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam.Builder
.org.apache.flink.fn_execution.v1.TypeInfo type_info = 2;
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.CoderParam.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.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.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.JobParameter.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
 
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.UserDefinedDataStreamFunction.JobParameter.Builder
string value = 2;
setValueBytes(ByteString) - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.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.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.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;
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.UserDefinedAggregateFunction.DataViewSpec.MapView.Builder
.org.apache.flink.fn_execution.v1.Schema.FieldType 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.v1p26p0.io.grpc.internal
A holder for shared resource singletons.
SharedResourceHolder.Resource<T> - Interface in org.apache.beam.vendor.grpc.v1p26p0.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_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TypeName
SHORT = 4;
SINGLE_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam.OutputMode
SINGLE = 0;
SLIDING_GROUP_WINDOW_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.WindowType
SLIDING_GROUP_WINDOW = 1;
SMALLINT_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TypeName
SMALLINT = 2;
SmallIntFieldReader - Class in org.apache.flink.table.runtime.arrow.readers
ArrowFieldReader for SmallInt.
SmallIntFieldReader(SmallIntVector) - Constructor for class org.apache.flink.table.runtime.arrow.readers.SmallIntFieldReader
 
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 for ArrayData input.
SmallIntWriter.SmallIntWriterForRow - Class in org.apache.flink.table.runtime.arrow.writers
SmallIntWriter for RowData 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.AbstractArrowSourceFunction
 
SPECS_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction
 
SQL_DATE_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TypeName
SQL_DATE = 12;
SQL_TIME_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TypeName
SQL_TIME = 13;
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_CLEANING_ENABLED_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunctions
 
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
 
STREAM_TIMESTAMP_AND_WATERMARK_OPERATOR_NAME - Static variable in class org.apache.flink.streaming.api.operators.python.PythonTimestampsAndWatermarksOperator
 
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, int, WindowAssigner<W>, Trigger<W>, long, PlannerNamedWindowProperty[], int[], int[], ZoneId) - 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, int, long, int[], int[]) - 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, int, long, int[], int[]) - 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, int, long, int[], int[]) - 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, int, long, int[], int[]) - Constructor for class org.apache.flink.table.runtime.operators.python.aggregate.arrow.stream.StreamArrowPythonRowTimeBoundedRowsOperator
 
StreamRecordCRowWrappingCollector - Class in org.apache.flink.table.runtime.operators.python.utils
The collector is used to convert a Row to a CRow.
StreamRecordCRowWrappingCollector(Collector<StreamRecord<CRow>>) - Constructor for class org.apache.flink.table.runtime.operators.python.utils.StreamRecordCRowWrappingCollector
 
StreamRecordRowDataWrappingCollector - Class in org.apache.flink.table.runtime.operators.python.utils
The collector is used to convert a RowData to a StreamRecord.
StreamRecordRowDataWrappingCollector(Collector<StreamRecord<RowData>>) - Constructor for class org.apache.flink.table.runtime.operators.python.utils.StreamRecordRowDataWrappingCollector
 
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
 

T

tableFunction - Variable in class org.apache.flink.table.runtime.operators.python.table.AbstractPythonTableFunctionOperator
The Python TableFunction to be executed.
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_FIELD_INDEX_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow
 
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;
TimeFieldReader - Class in org.apache.flink.table.runtime.arrow.readers
TimeFieldReader(ValueVector) - Constructor for class org.apache.flink.table.runtime.arrow.readers.TimeFieldReader
 
TimerOperandType - Enum in org.apache.flink.streaming.api.utils.output
The Flag for indicating the timer operation type.
TimerType - Enum in org.apache.flink.streaming.api.utils.input
The type of the triggered timer.
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_ASSIGNER_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.FunctionType
TIMESTAMP_ASSIGNER = 7;
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;
TimestampFieldReader - Class in org.apache.flink.table.runtime.arrow.readers
ArrowFieldReader for Timestamp.
TimestampFieldReader(ValueVector) - Constructor for class org.apache.flink.table.runtime.arrow.readers.TimestampFieldReader
 
TimestampSerializer - Class in org.apache.flink.table.runtime.typeutils.serializers.python
Uses similar serialization/deserialization of SqlTimestampSerializer in blink 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 for TimestampSerializer.
TimestampSerializerSnapshot() - Constructor for class org.apache.flink.table.runtime.typeutils.serializers.python.TimestampSerializer.TimestampSerializerSnapshot
 
timestampToInternal(Timestamp) - Static method in class org.apache.flink.table.runtime.typeutils.PythonTypeUtils
Converts the Java type used for UDF parameters of SQL TIMESTAMP type (Timestamp) to internal representation (long).
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 for ArrayData input.
TimestampWriter.TimestampWriterForRow - Class in org.apache.flink.table.runtime.arrow.writers
TimestampWriter for RowData input.
TimeWriter<T> - Class in org.apache.flink.table.runtime.arrow.writers
TimeWriter.TimeWriterForArray - Class in org.apache.flink.table.runtime.arrow.writers
TimeWriter for ArrayData input.
TimeWriter.TimeWriterForRow - Class in org.apache.flink.table.runtime.arrow.writers
TimeWriter for RowData input.
TINYINT_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TypeName
TINYINT = 1;
TinyIntFieldReader - Class in org.apache.flink.table.runtime.arrow.readers
ArrowFieldReader for TinyInt.
TinyIntFieldReader(TinyIntVector) - Constructor for class org.apache.flink.table.runtime.arrow.readers.TinyIntFieldReader
 
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 for ArrayData input.
TinyIntWriter.TinyIntWriterForRow - Class in org.apache.flink.table.runtime.arrow.writers
TinyIntWriter for RowData input.
toArrowSchema(RowType) - Static method in class org.apache.flink.table.runtime.arrow.ArrowUtils
Returns the Arrow schema of the specified type.
toBlinkTypeSerializer(LogicalType) - Static method in class org.apache.flink.table.runtime.typeutils.PythonTypeUtils
 
toBuilder() - Method in class org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam
 
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.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.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.JobParameter
 
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
 
toFlinkTypeSerializer(LogicalType) - Static method in class org.apache.flink.table.runtime.typeutils.PythonTypeUtils
 
toFormatProperties() - Method in class org.apache.flink.table.descriptors.python.CustomFormatDescriptor
 
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) - Static method in class org.apache.flink.streaming.api.utils.PythonTypeUtils.TypeInfoToProtoConverter
 
TUMBLING_GROUP_WINDOW_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.WindowType
TUMBLING_GROUP_WINDOW = 0;
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;
TwoInputPythonFunctionOperator<IN1,IN2,RUNNER_OUT,OUT> - Class in org.apache.flink.streaming.api.operators.python
TwoInputPythonFunctionOperator is responsible for launching beam runner which will start a python harness to execute two-input user defined python function.
TwoInputPythonFunctionOperator(Configuration, DataStreamPythonFunctionInfo, String, TypeInformation<Row>, TypeInformation<RUNNER_OUT>) - Constructor for class org.apache.flink.streaming.api.operators.python.TwoInputPythonFunctionOperator
 
TwoInputPythonFunctionOperator(Configuration, TypeInformation<IN1>, TypeInformation<IN2>, TypeInformation<OUT>, DataStreamPythonFunctionInfo, String) - Constructor for class org.apache.flink.streaming.api.operators.python.TwoInputPythonFunctionOperator
 
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.CoderParam
 
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
 
typeInfoSerializerConverter(TypeInformation) - Static method in class org.apache.flink.streaming.api.utils.PythonTypeUtils.TypeInfoToSerializerConverter
 
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_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.Input
 
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
 
updateMetrics(String, List<MetricsApi.MonitoringInfo>) - Method in class org.apache.flink.python.metric.FlinkMetricContainer
Update this container with metrics from the passed MetricsApi.MonitoringInfos, 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.
userDefinedFunctionInputOffsets - Variable in class org.apache.flink.table.runtime.operators.python.AbstractStatelessFunctionOperator
The offsets of user-defined function inputs.
userDefinedFunctionInputType - Variable in class org.apache.flink.table.runtime.functions.python.AbstractPythonStatelessFunctionFlatMap
The user-defined function input logical type.
userDefinedFunctionInputType - Variable in class org.apache.flink.table.runtime.operators.python.AbstractStatelessFunctionOperator
The user-defined function input logical type.
userDefinedFunctionInputType - Variable in class org.apache.flink.table.runtime.operators.python.aggregate.AbstractPythonStreamAggregateOperator
The user-defined function input logical type.
userDefinedFunctionOutputType - Variable in class org.apache.flink.table.runtime.functions.python.AbstractPythonStatelessFunctionFlatMap
The user-defined function output logical type.
userDefinedFunctionOutputType - Variable in class org.apache.flink.table.runtime.operators.python.AbstractStatelessFunctionOperator
The user-defined function output logical type.
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 - Variable in enum org.apache.flink.streaming.api.utils.input.RunnerInputType
 
value - Variable in enum org.apache.flink.streaming.api.utils.input.TimerType
 
VALUE_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.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(String) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam.DataInfoCase
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam.DataInfoCase
valueOf(String) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam.DataType
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam.DataType
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam.DataType
 
valueOf(String) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam.OutputMode
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam.OutputMode
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam.OutputMode
 
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(int) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.WindowProperty
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.WindowProperty
 
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(int) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.WindowType
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.WindowType
 
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(int) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.Input.InputCase
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(int) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow.WindowType
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.OverWindow.WindowType
 
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(int) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType.TypeInfoCase
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(int) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TypeName
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TypeName
 
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(int) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TypeInfoCase
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(int) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TypeName
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.TypeInfo.TypeName
 
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(int) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedAggregateFunction.DataViewSpec.DataViewCase
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(int) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.FunctionType
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedDataStreamFunction.FunctionType
 
valueOf(String) - Static method in enum org.apache.flink.streaming.api.utils.input.RunnerInputType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.streaming.api.utils.input.TimerType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.streaming.api.utils.output.RunnerOutputType
Returns the enum constant of this type with the specified name.
valueOf(byte) - Static method in enum org.apache.flink.streaming.api.utils.output.RunnerOutputType
 
valueOf(String) - Static method in enum org.apache.flink.streaming.api.utils.output.TimerOperandType
Returns the enum constant of this type with the specified name.
valueOf(byte) - Static method in enum org.apache.flink.streaming.api.utils.output.TimerOperandType
 
valueOf(String) - Static method in enum org.apache.flink.streaming.api.utils.PythonOperatorUtils
Returns the enum constant of this type with the specified name.
values() - Static method in enum org.apache.flink.fnexecution.v1.FlinkFnApi.CoderParam.DataInfoCase
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.CoderParam.DataType
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.CoderParam.OutputMode
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.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.streaming.api.utils.input.RunnerInputType
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.utils.input.TimerType
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.utils.output.RunnerOutputType
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.utils.output.TimerOperandType
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.utils.PythonOperatorUtils
Returns an array containing the constants of this enum type, in the order they are declared.
VAR_BINARY_INFO_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
 
VAR_CHAR_INFO_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.FieldType
 
VARBINARY_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TypeName
VARBINARY = 13;
VarBinaryFieldReader - Class in org.apache.flink.table.runtime.arrow.readers
ArrowFieldReader for VarBinary.
VarBinaryFieldReader(VarBinaryVector) - Constructor for class org.apache.flink.table.runtime.arrow.readers.VarBinaryFieldReader
 
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 for ArrayData input.
VarBinaryWriter.VarBinaryWriterForRow - Class in org.apache.flink.table.runtime.arrow.writers
VarBinaryWriter for RowData input.
VARCHAR_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.Schema.TypeName
VARCHAR = 15;
VarCharFieldReader - Class in org.apache.flink.table.runtime.arrow.readers
ArrowFieldReader for VarChar.
VarCharFieldReader(VarCharVector) - Constructor for class org.apache.flink.table.runtime.arrow.readers.VarCharFieldReader
 
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 for ArrayData input.
VarCharWriter.VarCharWriterForRow - Class in org.apache.flink.table.runtime.arrow.writers
VarCharWriter for RowData input.
visit(DateType) - Method in class org.apache.flink.table.runtime.typeutils.PythonTypeUtils.LogicalTypeToConversionClassConverter
 
visit(TimeType) - Method in class org.apache.flink.table.runtime.typeutils.PythonTypeUtils.LogicalTypeToConversionClassConverter
 
visit(TimestampType) - Method in class org.apache.flink.table.runtime.typeutils.PythonTypeUtils.LogicalTypeToConversionClassConverter
 
visit(ArrayType) - Method in class org.apache.flink.table.runtime.typeutils.PythonTypeUtils.LogicalTypeToConversionClassConverter
 
visit(BooleanType) - 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(SmallIntType) - 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(BigIntType) - 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(DoubleType) - 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(VarBinaryType) - 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(VarCharType) - 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(TimeType) - 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(LocalZonedTimestampType) - 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(ArrayType) - 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
 

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_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_VALUE - Static variable in enum org.apache.flink.fnexecution.v1.FlinkFnApi.GroupWindow.WindowProperty
WINDOW_START = 0;
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 = 8;
WINDOWS_FIELD_NUMBER - Static variable in class org.apache.flink.fnexecution.v1.FlinkFnApi.UserDefinedFunctions
 
write(IN) - Method in class org.apache.flink.table.runtime.arrow.ArrowWriter
Writes the specified row which is serialized into Arrow format.
write(T) - Method in class org.apache.flink.table.runtime.arrow.serializers.ArrowSerializer
 
write(IN, int) - Method in class org.apache.flink.table.runtime.arrow.writers.ArrowFieldWriter
Writes the specified ordinal of the specified row.
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.CoderParam
 
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.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.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.JobParameter
 
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

ZipUtils - Class in org.apache.flink.python.util
Utils used to extract zip files and try to restore the origin permissions of files.
ZipUtils() - Constructor for class org.apache.flink.python.util.ZipUtils
 
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;
A B C D E F G H I J K L M N O P R S T U V W Z 
Skip navigation links

Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.