public class PythonConfigUtil extends Object
StreamExecutionEnvironment
configuration and merged configuration
with environment settings.Modifier and Type | Field and Description |
---|---|
static String |
KEYED_STREAM_VALUE_OPERATOR_NAME |
static String |
STREAM_KEY_BY_MAP_OPERATOR_NAME |
static String |
STREAM_PARTITION_CUSTOM_MAP_OPERATOR_NAME |
Constructor and Description |
---|
PythonConfigUtil() |
Modifier and Type | Method and Description |
---|---|
static void |
configPythonOperator(org.apache.flink.streaming.api.environment.StreamExecutionEnvironment env) |
static void |
declareManagedMemory(org.apache.flink.api.dag.Transformation<?> transformation,
org.apache.flink.streaming.api.environment.StreamExecutionEnvironment env,
org.apache.flink.table.api.TableConfig tableConfig)
Set Python Operator Use Managed Memory.
|
static org.apache.flink.streaming.api.graph.StreamGraph |
generateStreamGraphWithDependencies(org.apache.flink.streaming.api.environment.StreamExecutionEnvironment env,
boolean clearTransformations)
Generate a
StreamGraph for transformations maintained by current StreamExecutionEnvironment , and reset the merged env configurations with dependencies to
every OneInputPythonFunctionOperator . |
static org.apache.flink.configuration.Configuration |
getEnvConfigWithDependencies(org.apache.flink.streaming.api.environment.StreamExecutionEnvironment env)
A static method to get the
StreamExecutionEnvironment configuration merged with
python dependency management configurations. |
static org.apache.flink.configuration.Configuration |
getEnvironmentConfig(org.apache.flink.streaming.api.environment.StreamExecutionEnvironment env)
Get the private method
StreamExecutionEnvironment.getConfiguration() by reflection
recursively. |
static org.apache.flink.configuration.Configuration |
getMergedConfig(org.apache.flink.api.java.ExecutionEnvironment env,
org.apache.flink.table.api.TableConfig tableConfig) |
static org.apache.flink.configuration.Configuration |
getMergedConfig(org.apache.flink.streaming.api.environment.StreamExecutionEnvironment env,
org.apache.flink.table.api.TableConfig tableConfig) |
public static final String KEYED_STREAM_VALUE_OPERATOR_NAME
public static final String STREAM_KEY_BY_MAP_OPERATOR_NAME
public static final String STREAM_PARTITION_CUSTOM_MAP_OPERATOR_NAME
public static org.apache.flink.configuration.Configuration getEnvConfigWithDependencies(org.apache.flink.streaming.api.environment.StreamExecutionEnvironment env) throws InvocationTargetException, IllegalAccessException, NoSuchMethodException
StreamExecutionEnvironment
configuration merged with
python dependency management configurations.public static org.apache.flink.configuration.Configuration getEnvironmentConfig(org.apache.flink.streaming.api.environment.StreamExecutionEnvironment env) throws InvocationTargetException, IllegalAccessException, NoSuchMethodException
StreamExecutionEnvironment.getConfiguration()
by reflection
recursively. Then access the method to get the configuration of the given
StreamExecutionEnvironment.public static void declareManagedMemory(org.apache.flink.api.dag.Transformation<?> transformation, org.apache.flink.streaming.api.environment.StreamExecutionEnvironment env, org.apache.flink.table.api.TableConfig tableConfig)
public static org.apache.flink.streaming.api.graph.StreamGraph generateStreamGraphWithDependencies(org.apache.flink.streaming.api.environment.StreamExecutionEnvironment env, boolean clearTransformations) throws IllegalAccessException, NoSuchMethodException, InvocationTargetException, NoSuchFieldException
StreamGraph
for transformations maintained by current StreamExecutionEnvironment
, and reset the merged env configurations with dependencies to
every OneInputPythonFunctionOperator
. It is an idempotent operation that can be call
multiple times. Remember that only when need to execute the StreamGraph can we set the
clearTransformations to be True.public static void configPythonOperator(org.apache.flink.streaming.api.environment.StreamExecutionEnvironment env) throws IllegalAccessException, NoSuchMethodException, InvocationTargetException, NoSuchFieldException
public static org.apache.flink.configuration.Configuration getMergedConfig(org.apache.flink.streaming.api.environment.StreamExecutionEnvironment env, org.apache.flink.table.api.TableConfig tableConfig)
public static org.apache.flink.configuration.Configuration getMergedConfig(org.apache.flink.api.java.ExecutionEnvironment env, org.apache.flink.table.api.TableConfig tableConfig)
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.