Interface FlinkFnApi.UserDefinedAggregateFunctionsOrBuilder

    • Method Detail

      • getUdfsCount

        int getUdfsCount()
        repeated .org.apache.flink.fn_execution.v1.UserDefinedAggregateFunction udfs = 1;
      • getMetricEnabled

        boolean getMetricEnabled()
        bool metric_enabled = 2;
        Returns:
        The metricEnabled.
      • getGroupingList

        List<Integer> getGroupingList()
         The array of the key indexes.
         
        repeated int32 grouping = 3;
        Returns:
        A list containing the grouping.
      • getGroupingCount

        int getGroupingCount()
         The array of the key indexes.
         
        repeated int32 grouping = 3;
        Returns:
        The count of grouping.
      • getGrouping

        int getGrouping​(int index)
         The array of the key indexes.
         
        repeated int32 grouping = 3;
        Parameters:
        index - The index of the element to return.
        Returns:
        The grouping at the given index.
      • getGenerateUpdateBefore

        boolean getGenerateUpdateBefore()
         Generate retract messages if true.
         
        bool generate_update_before = 4;
        Returns:
        The generateUpdateBefore.
      • hasKeyType

        boolean hasKeyType()
         The schema of the grouping keys.
         
        .org.apache.flink.fn_execution.v1.Schema.FieldType key_type = 5;
        Returns:
        Whether the keyType field is set.
      • getKeyType

        FlinkFnApi.Schema.FieldType getKeyType()
         The schema of the grouping keys.
         
        .org.apache.flink.fn_execution.v1.Schema.FieldType key_type = 5;
        Returns:
        The keyType.
      • getIndexOfCountStar

        int getIndexOfCountStar()
         The index of a count aggregate used to calculate the number of accumulated rows.
         
        int32 index_of_count_star = 6;
        Returns:
        The indexOfCountStar.
      • getStateCleaningEnabled

        boolean getStateCleaningEnabled()
         Cleanup the expired state if true.
         
        bool state_cleaning_enabled = 7;
        Returns:
        The stateCleaningEnabled.
      • getStateCacheSize

        int getStateCacheSize()
         The state cache size.
         
        int32 state_cache_size = 8;
        Returns:
        The stateCacheSize.
      • getMapStateReadCacheSize

        int getMapStateReadCacheSize()
         The map state read cache size.
         
        int32 map_state_read_cache_size = 9;
        Returns:
        The mapStateReadCacheSize.
      • getMapStateWriteCacheSize

        int getMapStateWriteCacheSize()
         The map_state_write_cache_size.
         
        int32 map_state_write_cache_size = 10;
        Returns:
        The mapStateWriteCacheSize.
      • getCountStarInserted

        boolean getCountStarInserted()
         True if the count(*) agg is inserted by the planner.
         
        bool count_star_inserted = 11;
        Returns:
        The countStarInserted.
      • hasGroupWindow

        boolean hasGroupWindow()
         Group Window.
         
        .org.apache.flink.fn_execution.v1.GroupWindow group_window = 12;
        Returns:
        Whether the groupWindow field is set.
      • getGroupWindow

        FlinkFnApi.GroupWindow getGroupWindow()
         Group Window.
         
        .org.apache.flink.fn_execution.v1.GroupWindow group_window = 12;
        Returns:
        The groupWindow.
      • getGroupWindowOrBuilder

        FlinkFnApi.GroupWindowOrBuilder getGroupWindowOrBuilder()
         Group Window.
         
        .org.apache.flink.fn_execution.v1.GroupWindow group_window = 12;
      • getProfileEnabled

        boolean getProfileEnabled()
        bool profile_enabled = 13;
        Returns:
        The profileEnabled.
      • getJobParametersList

        List<FlinkFnApi.JobParameter> getJobParametersList()
        repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 14;
      • getJobParameters

        FlinkFnApi.JobParameter getJobParameters​(int index)
        repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 14;
      • getJobParametersCount

        int getJobParametersCount()
        repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 14;
      • getJobParametersOrBuilderList

        List<? extends FlinkFnApi.JobParameterOrBuilder> getJobParametersOrBuilderList()
        repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 14;
      • getJobParametersOrBuilder

        FlinkFnApi.JobParameterOrBuilder getJobParametersOrBuilder​(int index)
        repeated .org.apache.flink.fn_execution.v1.JobParameter job_parameters = 14;