Uses of Interface
org.apache.flink.configuration.ReadableConfig
-
-
Uses of ReadableConfig in org.apache.flink.api.common
Methods in org.apache.flink.api.common with parameters of type ReadableConfig Modifier and Type Method Description void
ExecutionConfig. configure(ReadableConfig configuration, ClassLoader classLoader)
Sets all relevant options contained in theReadableConfig
such as e.g. -
Uses of ReadableConfig in org.apache.flink.api.common.serialization
Methods in org.apache.flink.api.common.serialization with parameters of type ReadableConfig Modifier and Type Method Description void
SerializerConfig. configure(ReadableConfig configuration, ClassLoader classLoader)
Sets all relevant options contained in theReadableConfig
such as e.g.void
SerializerConfigImpl. configure(ReadableConfig configuration, ClassLoader classLoader)
Sets all relevant options contained in theReadableConfig
such as e.g. -
Uses of ReadableConfig in org.apache.flink.cep.configuration
Methods in org.apache.flink.cep.configuration with parameters of type ReadableConfig Modifier and Type Method Description static SharedBufferCacheConfig
SharedBufferCacheConfig. of(ReadableConfig readableConfig)
-
Uses of ReadableConfig in org.apache.flink.changelog.fs
Methods in org.apache.flink.changelog.fs with parameters of type ReadableConfig Modifier and Type Method Description static RetryPolicy
RetryPolicy. fromConfig(ReadableConfig config)
static StateChangeUploadScheduler
StateChangeUploadScheduler. fromConfig(JobID jobID, ReadableConfig config, ChangelogStorageMetricGroup metricGroup, TaskChangelogRegistry changelogRegistry, LocalRecoveryConfig localRecoveryConfig)
-
Uses of ReadableConfig in org.apache.flink.client.python
Methods in org.apache.flink.client.python with parameters of type ReadableConfig Modifier and Type Method Description static PythonFunctionFactory
PythonFunctionFactory. createPythonFunctionFactory(ReadableConfig config)
static PythonFunction
PythonFunctionFactory. getPythonFunction(String fullyQualifiedName, ReadableConfig config, ClassLoader classLoader)
Returns PythonFunction according to the fully qualified name of the Python UDF i.e ${moduleName}.static PythonFunctionFactory.CacheKey
PythonFunctionFactory.CacheKey. of(ReadableConfig config, ClassLoader classLoader)
-
Uses of ReadableConfig in org.apache.flink.configuration
Classes in org.apache.flink.configuration that implement ReadableConfig Modifier and Type Class Description class
Configuration
Lightweight configuration object which stores key/value pairs.class
DelegatingConfiguration
A configuration that manages a subset of keys with a common prefix from a given configuration.class
UnmodifiableConfiguration
Unmodifiable version of the Configuration class.Methods in org.apache.flink.configuration with parameters of type ReadableConfig Modifier and Type Method Description static <IN,OUT,E extends Throwable>
List<OUT>ConfigUtils. decodeListFromConfig(ReadableConfig configuration, ConfigOption<List<IN>> key, FunctionWithException<IN,OUT,E> mapper)
Gets aList
of values of typeIN
from aReadableConfig
and transforms it to aList
of typeOUT
based on the providedmapper
function.static String[]
CoreOptions. getParentFirstLoaderPatterns(ReadableConfig config)
-
Uses of ReadableConfig in org.apache.flink.connector.base.table
Methods in org.apache.flink.connector.base.table that return ReadableConfig Modifier and Type Method Description ReadableConfig
AsyncDynamicTableSinkFactory.AsyncDynamicSinkContext. getTableOptions()
-
Uses of ReadableConfig in org.apache.flink.connector.base.table.sink.options
Fields in org.apache.flink.connector.base.table.sink.options declared as ReadableConfig Modifier and Type Field Description protected ReadableConfig
AsyncSinkConfigurationValidator. tableOptions
Constructors in org.apache.flink.connector.base.table.sink.options with parameters of type ReadableConfig Constructor Description AsyncSinkConfigurationValidator(ReadableConfig tableOptions)
-
Uses of ReadableConfig in org.apache.flink.connector.datagen.table
Fields in org.apache.flink.connector.datagen.table declared as ReadableConfig Modifier and Type Field Description protected ReadableConfig
DataGenVisitorBase. config
Constructors in org.apache.flink.connector.datagen.table with parameters of type ReadableConfig Constructor Description DataGenVisitorBase(String name, ReadableConfig config)
RandomGeneratorVisitor(String name, ReadableConfig config)
SequenceGeneratorVisitor(String name, ReadableConfig config)
-
Uses of ReadableConfig in org.apache.flink.connector.file.table
Constructors in org.apache.flink.connector.file.table with parameters of type ReadableConfig Constructor Description FileSystemTableSource(ObjectIdentifier tableIdentifier, DataType physicalRowDataType, List<String> partitionKeys, ReadableConfig tableOptions, DecodingFormat<BulkFormat<RowData,FileSourceSplit>> bulkReaderFormat, DecodingFormat<DeserializationSchema<RowData>> deserializationFormat)
-
Uses of ReadableConfig in org.apache.flink.connector.file.table.factories
Methods in org.apache.flink.connector.file.table.factories with parameters of type ReadableConfig Modifier and Type Method Description BulkDecodingFormat<RowData>
BulkReaderFormatFactory. createDecodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
Creates aBulkDecodingFormat
from the given context and format options. -
Uses of ReadableConfig in org.apache.flink.contrib.streaming.state
Methods in org.apache.flink.contrib.streaming.state with parameters of type ReadableConfig Modifier and Type Method Description EmbeddedRocksDBStateBackend
EmbeddedRocksDBStateBackend. configure(ReadableConfig config, ClassLoader classLoader)
Deprecated.Creates a copy of this state backend that uses the values defined in the configuration for fields where that were not yet specified in this state backend.EmbeddedRocksDBStateBackend
EmbeddedRocksDBStateBackendFactory. createFromConfig(ReadableConfig config, ClassLoader classLoader)
Deprecated. -
Uses of ReadableConfig in org.apache.flink.formats.avro
Methods in org.apache.flink.formats.avro with parameters of type ReadableConfig Modifier and Type Method Description BulkDecodingFormat<RowData>
AvroFileFormatFactory. createDecodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
DecodingFormat<DeserializationSchema<RowData>>
AvroFormatFactory. createDecodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
EncodingFormat<BulkWriter.Factory<RowData>>
AvroFileFormatFactory. createEncodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
EncodingFormat<SerializationSchema<RowData>>
AvroFormatFactory. createEncodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
-
Uses of ReadableConfig in org.apache.flink.formats.avro.registry.confluent
Methods in org.apache.flink.formats.avro.registry.confluent with parameters of type ReadableConfig Modifier and Type Method Description static Map<String,String>
RegistryAvroFormatFactory. buildOptionalPropertiesMap(ReadableConfig formatOptions)
DecodingFormat<DeserializationSchema<RowData>>
RegistryAvroFormatFactory. createDecodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
EncodingFormat<SerializationSchema<RowData>>
RegistryAvroFormatFactory. createEncodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
-
Uses of ReadableConfig in org.apache.flink.formats.avro.registry.confluent.debezium
Methods in org.apache.flink.formats.avro.registry.confluent.debezium with parameters of type ReadableConfig Modifier and Type Method Description DecodingFormat<DeserializationSchema<RowData>>
DebeziumAvroFormatFactory. createDecodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
EncodingFormat<SerializationSchema<RowData>>
DebeziumAvroFormatFactory. createEncodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
-
Uses of ReadableConfig in org.apache.flink.formats.csv
Methods in org.apache.flink.formats.csv with parameters of type ReadableConfig Modifier and Type Method Description BulkDecodingFormat<RowData>
CsvFileFormatFactory. createDecodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
DecodingFormat<DeserializationSchema<RowData>>
CsvFormatFactory. createDecodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
EncodingFormat<BulkWriter.Factory<RowData>>
CsvFileFormatFactory. createEncodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
EncodingFormat<SerializationSchema<RowData>>
CsvFormatFactory. createEncodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
Constructors in org.apache.flink.formats.csv with parameters of type ReadableConfig Constructor Description CsvBulkDecodingFormat(ReadableConfig formatOptions)
-
Uses of ReadableConfig in org.apache.flink.formats.json
Methods in org.apache.flink.formats.json with parameters of type ReadableConfig Modifier and Type Method Description DecodingFormat<DeserializationSchema<RowData>>
JsonFormatFactory. createDecodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
EncodingFormat<SerializationSchema<RowData>>
JsonFormatFactory. createEncodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
static JsonFormatOptions.MapNullKeyMode
JsonFormatOptionsUtil. getMapNullKeyMode(ReadableConfig config)
Creates handling mode for null key map data.static TimestampFormat
JsonFormatOptionsUtil. getTimestampFormat(ReadableConfig config)
static void
JsonFormatOptionsUtil. validateDecodingFormatOptions(ReadableConfig tableOptions)
Validator for json decoding format.static void
JsonFormatOptionsUtil. validateEncodingFormatOptions(ReadableConfig tableOptions)
Validator for json encoding format. -
Uses of ReadableConfig in org.apache.flink.formats.json.canal
Methods in org.apache.flink.formats.json.canal with parameters of type ReadableConfig Modifier and Type Method Description DecodingFormat<DeserializationSchema<RowData>>
CanalJsonFormatFactory. createDecodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
EncodingFormat<SerializationSchema<RowData>>
CanalJsonFormatFactory. createEncodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
-
Uses of ReadableConfig in org.apache.flink.formats.json.debezium
Methods in org.apache.flink.formats.json.debezium with parameters of type ReadableConfig Modifier and Type Method Description DecodingFormat<DeserializationSchema<RowData>>
DebeziumJsonFormatFactory. createDecodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
EncodingFormat<SerializationSchema<RowData>>
DebeziumJsonFormatFactory. createEncodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
-
Uses of ReadableConfig in org.apache.flink.formats.json.maxwell
Methods in org.apache.flink.formats.json.maxwell with parameters of type ReadableConfig Modifier and Type Method Description DecodingFormat<DeserializationSchema<RowData>>
MaxwellJsonFormatFactory. createDecodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
EncodingFormat<SerializationSchema<RowData>>
MaxwellJsonFormatFactory. createEncodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
-
Uses of ReadableConfig in org.apache.flink.formats.json.ogg
Methods in org.apache.flink.formats.json.ogg with parameters of type ReadableConfig Modifier and Type Method Description DecodingFormat<DeserializationSchema<RowData>>
OggJsonFormatFactory. createDecodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
EncodingFormat<SerializationSchema<RowData>>
OggJsonFormatFactory. createEncodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
-
Uses of ReadableConfig in org.apache.flink.formats.parquet
Methods in org.apache.flink.formats.parquet with parameters of type ReadableConfig Modifier and Type Method Description BulkDecodingFormat<RowData>
ParquetFileFormatFactory. createDecodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
EncodingFormat<BulkWriter.Factory<RowData>>
ParquetFileFormatFactory. createEncodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
Constructors in org.apache.flink.formats.parquet with parameters of type ReadableConfig Constructor Description ParquetBulkDecodingFormat(ReadableConfig formatOptions)
-
Uses of ReadableConfig in org.apache.flink.formats.protobuf
Methods in org.apache.flink.formats.protobuf with parameters of type ReadableConfig Modifier and Type Method Description BulkDecodingFormat<RowData>
PbFileFormatFactory. createDecodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
DecodingFormat<DeserializationSchema<RowData>>
PbFormatFactory. createDecodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
EncodingFormat<BulkWriter.Factory<RowData>>
PbFileFormatFactory. createEncodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
EncodingFormat<SerializationSchema<RowData>>
PbFormatFactory. createEncodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
-
Uses of ReadableConfig in org.apache.flink.formats.raw
Methods in org.apache.flink.formats.raw with parameters of type ReadableConfig Modifier and Type Method Description DecodingFormat<DeserializationSchema<RowData>>
RawFormatFactory. createDecodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
EncodingFormat<SerializationSchema<RowData>>
RawFormatFactory. createEncodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
-
Uses of ReadableConfig in org.apache.flink.orc
Methods in org.apache.flink.orc with parameters of type ReadableConfig Modifier and Type Method Description BulkDecodingFormat<RowData>
OrcFileFormatFactory. createDecodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
EncodingFormat<BulkWriter.Factory<RowData>>
OrcFileFormatFactory. createEncodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
Constructors in org.apache.flink.orc with parameters of type ReadableConfig Constructor Description OrcBulkDecodingFormat(ReadableConfig formatOptions)
-
Uses of ReadableConfig in org.apache.flink.python
Classes in org.apache.flink.python that implement ReadableConfig Modifier and Type Class Description class
PythonConfig
Configurations for the Python job which are used at run time.Methods in org.apache.flink.python with parameters of type ReadableConfig Modifier and Type Method Description void
PythonFunctionRunner. open(ReadableConfig config)
Prepares the Python function runner, such as preparing the Python execution environment, etc.Constructors in org.apache.flink.python with parameters of type ReadableConfig Constructor Description PythonConfig(ReadableConfig configuration, ReadableConfig pythonDependencyConfiguration)
-
Uses of ReadableConfig in org.apache.flink.python.env
Methods in org.apache.flink.python.env with parameters of type ReadableConfig Modifier and Type Method Description static PythonDependencyInfo
PythonDependencyInfo. create(ReadableConfig config, DistributedCache distributedCache)
Creates PythonDependencyInfo from GlobalJobParameters and DistributedCache. -
Uses of ReadableConfig in org.apache.flink.python.util
Methods in org.apache.flink.python.util with parameters of type ReadableConfig Modifier and Type Method Description static Configuration
PythonDependencyUtils. configurePythonDependencies(ReadableConfig config)
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.static Configuration
PythonConfigUtil. extractPythonConfiguration(ReadableConfig config)
Extract the configurations which is used in the Python operators. -
Uses of ReadableConfig in org.apache.flink.runtime.jobgraph
Methods in org.apache.flink.runtime.jobgraph with parameters of type ReadableConfig Modifier and Type Method Description static SavepointRestoreSettings
SavepointRestoreSettings. fromConfiguration(ReadableConfig configuration)
-
Uses of ReadableConfig in org.apache.flink.runtime.state
Methods in org.apache.flink.runtime.state with parameters of type ReadableConfig Modifier and Type Method Description CheckpointStorage
ConfigurableCheckpointStorage. configure(ReadableConfig config, ClassLoader classLoader)
Creates a variant of the checkpoint storage that applies additional configuration parameters.StateBackend
ConfigurableStateBackend. configure(ReadableConfig config, ClassLoader classLoader)
Creates a variant of the state backend that applies additional configuration parameters.T
CheckpointStorageFactory. createFromConfig(ReadableConfig config, ClassLoader classLoader)
Creates the checkpoint storage, optionally using the given configuration.T
StateBackendFactory. createFromConfig(ReadableConfig config, ClassLoader classLoader)
Creates the state backend, optionally using the given configuration.static Optional<CheckpointStorage>
CheckpointStorageLoader. fromConfig(ReadableConfig config, ClassLoader classLoader, org.slf4j.Logger logger)
Loads the checkpoint storage from the configuration, from the parameter 'execution.checkpointing.storage', as defined inCheckpointingOptions.CHECKPOINT_STORAGE
.static StateBackend
StateBackendLoader. loadStateBackendFromConfig(ReadableConfig config, ClassLoader classLoader, org.slf4j.Logger logger)
Loads the unwrapped state backend from the configuration, from the parameter 'state.backend', as defined inStateBackendOptions.STATE_BACKEND
. -
Uses of ReadableConfig in org.apache.flink.runtime.state.filesystem
Constructors in org.apache.flink.runtime.state.filesystem with parameters of type ReadableConfig Constructor Description AbstractFileStateBackend(Path baseCheckpointPath, Path baseSavepointPath, ReadableConfig configuration)
Deprecated.Creates a new backend using the given checkpoint-/savepoint directories, or the values defined in the given configuration. -
Uses of ReadableConfig in org.apache.flink.runtime.state.hashmap
Methods in org.apache.flink.runtime.state.hashmap with parameters of type ReadableConfig Modifier and Type Method Description HashMapStateBackend
HashMapStateBackend. configure(ReadableConfig config, ClassLoader classLoader)
HashMapStateBackend
HashMapStateBackendFactory. createFromConfig(ReadableConfig config, ClassLoader classLoader)
-
Uses of ReadableConfig in org.apache.flink.runtime.state.metrics
Methods in org.apache.flink.runtime.state.metrics with parameters of type ReadableConfig Modifier and Type Method Description LatencyTrackingStateConfig.Builder
LatencyTrackingStateConfig.Builder. configure(ReadableConfig config)
-
Uses of ReadableConfig in org.apache.flink.runtime.state.storage
Methods in org.apache.flink.runtime.state.storage with parameters of type ReadableConfig Modifier and Type Method Description FileSystemCheckpointStorage
FileSystemCheckpointStorage. configure(ReadableConfig config, ClassLoader classLoader)
JobManagerCheckpointStorage
JobManagerCheckpointStorage. configure(ReadableConfig config, ClassLoader classLoader)
Creates a copy of this checkpoint storage that uses the values defined in the configuration for fields where that were not specified in this checkpoint storage.static FileSystemCheckpointStorage
FileSystemCheckpointStorage. createFromConfig(ReadableConfig config, ClassLoader classLoader)
Creates a newFileSystemCheckpointStorage
using the given configuration.static JobManagerCheckpointStorage
JobManagerCheckpointStorage. createFromConfig(ReadableConfig config, ClassLoader classLoader)
Creates a newJobManagerCheckpointStorage
using the given configuration. -
Uses of ReadableConfig in org.apache.flink.runtime.throughput
Methods in org.apache.flink.runtime.throughput with parameters of type ReadableConfig Modifier and Type Method Description static BufferDebloatConfiguration
BufferDebloatConfiguration. fromConfiguration(ReadableConfig config)
-
Uses of ReadableConfig in org.apache.flink.state.api.runtime
Methods in org.apache.flink.state.api.runtime with parameters of type ReadableConfig Modifier and Type Method Description static Configuration
MutableConfig. of(ReadableConfig config)
Creates a newConfiguration
. -
Uses of ReadableConfig in org.apache.flink.state.changelog
Methods in org.apache.flink.state.changelog with parameters of type ReadableConfig Modifier and Type Method Description StateBackend
ChangelogStateBackend. configure(ReadableConfig config, ClassLoader classLoader)
-
Uses of ReadableConfig in org.apache.flink.state.forst
Methods in org.apache.flink.state.forst with parameters of type ReadableConfig Modifier and Type Method Description ForStOptionsFactory
ConfigurableForStOptionsFactory. configure(ReadableConfig configuration)
Creates a variant of the options factory that applies additional configuration parameters.ForStStateBackend
ForStStateBackend. configure(ReadableConfig config, ClassLoader classLoader)
Creates a copy of this state backend that uses the values defined in the configuration for fields where that were not yet specified in this state backend.ForStStateBackend
ForStStateBackendFactory. createFromConfig(ReadableConfig config, ClassLoader classLoader)
static ForStNativeMetricOptions
ForStNativeMetricOptions. fromConfig(ReadableConfig config)
Creates aForStNativeMetricOptions
based on an external configuration.static ForStMemoryConfiguration
ForStMemoryConfiguration. fromOtherAndConfiguration(ForStMemoryConfiguration other, ReadableConfig config)
Derives a ForStMemoryConfiguration from another object and a configuration.Constructors in org.apache.flink.state.forst with parameters of type ReadableConfig Constructor Description ForStResourceContainer(ReadableConfig configuration, ForStOptionsFactory optionsFactory, OpaqueMemoryResource<org.apache.flink.state.forst.ForStSharedResources> sharedResources, Path localBasePath, Path remoteBasePath, boolean enableStatistics)
-
Uses of ReadableConfig in org.apache.flink.state.forst.sync
Methods in org.apache.flink.state.forst.sync with parameters of type ReadableConfig Modifier and Type Method Description static ForStPriorityQueueConfig
ForStPriorityQueueConfig. fromOtherAndConfiguration(ForStPriorityQueueConfig other, ReadableConfig config)
-
Uses of ReadableConfig in org.apache.flink.state.rocksdb
Methods in org.apache.flink.state.rocksdb with parameters of type ReadableConfig Modifier and Type Method Description RocksDBOptionsFactory
ConfigurableRocksDBOptionsFactory. configure(ReadableConfig configuration)
Creates a variant of the options factory that applies additional configuration parameters.EmbeddedRocksDBStateBackend
EmbeddedRocksDBStateBackend. configure(ReadableConfig config, ClassLoader classLoader)
Creates a copy of this state backend that uses the values defined in the configuration for fields where that were not yet specified in this state backend.EmbeddedRocksDBStateBackend
EmbeddedRocksDBStateBackendFactory. createFromConfig(ReadableConfig config, ClassLoader classLoader)
static RocksDBNativeMetricOptions
RocksDBNativeMetricOptions. fromConfig(ReadableConfig config)
Creates aRocksDBNativeMetricOptions
based on an external configuration.static RocksDBMemoryConfiguration
RocksDBMemoryConfiguration. fromOtherAndConfiguration(RocksDBMemoryConfiguration other, ReadableConfig config)
Derives a RocksDBMemoryConfiguration from another object and a configuration.static RocksDBPriorityQueueConfig
RocksDBPriorityQueueConfig. fromOtherAndConfiguration(RocksDBPriorityQueueConfig other, ReadableConfig config)
Constructors in org.apache.flink.state.rocksdb with parameters of type ReadableConfig Constructor Description EmbeddedRocksDBStateBackend(EmbeddedRocksDBStateBackend original, ReadableConfig config, ClassLoader classLoader)
Private constructor that creates a re-configured copy of the state backend.RocksDBResourceContainer(ReadableConfig configuration, PredefinedOptions predefinedOptions, RocksDBOptionsFactory optionsFactory, OpaqueMemoryResource<org.apache.flink.state.rocksdb.RocksDBSharedResources> sharedResources, File instanceBasePath, boolean enableStatistics)
-
Uses of ReadableConfig in org.apache.flink.state.rocksdb.sstmerge
Methods in org.apache.flink.state.rocksdb.sstmerge with parameters of type ReadableConfig Modifier and Type Method Description static RocksDBManualCompactionConfig
RocksDBManualCompactionConfig. from(ReadableConfig config)
-
Uses of ReadableConfig in org.apache.flink.streaming.api.environment
Methods in org.apache.flink.streaming.api.environment that return ReadableConfig Modifier and Type Method Description ReadableConfig
StreamExecutionEnvironment. getConfiguration()
Gives read-only access to the underlying configuration of this environment.Methods in org.apache.flink.streaming.api.environment with parameters of type ReadableConfig Modifier and Type Method Description void
CheckpointConfig. configure(ReadableConfig configuration)
Sets all relevant options contained in theReadableConfig
such as e.g.void
StreamExecutionEnvironment. configure(ReadableConfig configuration)
Sets all relevant options contained in theReadableConfig
.void
StreamExecutionEnvironment. configure(ReadableConfig configuration, ClassLoader classLoader)
Sets all relevant options contained in theReadableConfig
. -
Uses of ReadableConfig in org.apache.flink.streaming.api.graph
Methods in org.apache.flink.streaming.api.graph that return ReadableConfig Modifier and Type Method Description ReadableConfig
TransformationTranslator.Context. getGraphGeneratorConfig()
Retrieves additional configuration for the graph generation process. -
Uses of ReadableConfig in org.apache.flink.streaming.api.runners.python.beam
Methods in org.apache.flink.streaming.api.runners.python.beam with parameters of type ReadableConfig Modifier and Type Method Description void
BeamPythonFunctionRunner. open(ReadableConfig config)
-
Uses of ReadableConfig in org.apache.flink.streaming.api.runners.python.beam.state
Methods in org.apache.flink.streaming.api.runners.python.beam.state with parameters of type ReadableConfig Modifier and Type Method Description static BeamStateRequestHandler
BeamStateRequestHandler. of(KeyedStateBackend<?> keyedStateBackend, OperatorStateBackend operatorStateBackend, TypeSerializer<?> keySerializer, TypeSerializer<?> namespaceSerializer, ReadableConfig config)
Create aBeamStateRequestHandler
.Constructors in org.apache.flink.streaming.api.runners.python.beam.state with parameters of type ReadableConfig Constructor Description BeamMapStateHandler(ReadableConfig config)
-
Uses of ReadableConfig in org.apache.flink.table.api
Classes in org.apache.flink.table.api that implement ReadableConfig Modifier and Type Class Description class
TableConfig
Configuration for the currentTableEnvironment
session to adjust Table & SQL API programs.Methods in org.apache.flink.table.api that return ReadableConfig Modifier and Type Method Description ReadableConfig
TableConfig. getRootConfiguration()
Gives direct access to the underlying environment-specific key-value map for advanced configuration.Methods in org.apache.flink.table.api with parameters of type ReadableConfig Modifier and Type Method Description static EnvironmentSettings
EnvironmentSettings. fromConfiguration(ReadableConfig configuration)
Deprecated.void
TableConfig. setRootConfiguration(ReadableConfig rootConfiguration)
Sets the given configuration asTableConfig.rootConfiguration
, which contains any configuration set in the execution context. -
Uses of ReadableConfig in org.apache.flink.table.catalog
Methods in org.apache.flink.table.catalog that return ReadableConfig Modifier and Type Method Description ReadableConfig
CatalogStoreHolder. config()
Methods in org.apache.flink.table.catalog with parameters of type ReadableConfig Modifier and Type Method Description CatalogManager.Builder
CatalogManager.Builder. config(ReadableConfig config)
CatalogStoreHolder.Builder
CatalogStoreHolder.Builder. config(ReadableConfig config)
Constructors in org.apache.flink.table.catalog with parameters of type ReadableConfig Constructor Description FunctionCatalog(ReadableConfig config, ResourceManager resourceManager, CatalogManager catalogManager, ModuleManager moduleManager)
ManagedTableListener(ClassLoader classLoader, ReadableConfig config)
Deprecated. -
Uses of ReadableConfig in org.apache.flink.table.catalog.listener
Methods in org.apache.flink.table.catalog.listener that return ReadableConfig Modifier and Type Method Description ReadableConfig
CatalogModificationListenerFactory.Context. getConfiguration()
Returns the read-only job configuration with which the listener is created. -
Uses of ReadableConfig in org.apache.flink.table.client.cli
Methods in org.apache.flink.table.client.cli with parameters of type ReadableConfig Modifier and Type Method Description static Printer.StatementResultPrinter
Printer. createStatementCommandPrinter(StatementResult result, ReadableConfig sessionConfig, long startTime)
static ZoneId
CliUtils. getSessionTimeZone(ReadableConfig sessionConfig)
Get time zone from the given session config.Constructors in org.apache.flink.table.client.cli with parameters of type ReadableConfig Constructor Description StatementResultPrinter(StatementResult result, ReadableConfig sessionConfig, long queryBeginTime)
-
Uses of ReadableConfig in org.apache.flink.table.client.gateway
Methods in org.apache.flink.table.client.gateway that return ReadableConfig Modifier and Type Method Description ReadableConfig
Executor. getSessionConfig()
Get the configuration of the session.ReadableConfig
ExecutorImpl. getSessionConfig()
Constructors in org.apache.flink.table.client.gateway with parameters of type ReadableConfig Constructor Description ResultDescriptor(StatementResult tableResult, ReadableConfig config)
-
Uses of ReadableConfig in org.apache.flink.table.connector.source.lookup.cache
Methods in org.apache.flink.table.connector.source.lookup.cache with parameters of type ReadableConfig Modifier and Type Method Description static DefaultLookupCache
DefaultLookupCache. fromConfig(ReadableConfig config)
-
Uses of ReadableConfig in org.apache.flink.table.connector.source.lookup.cache.trigger
Methods in org.apache.flink.table.connector.source.lookup.cache.trigger with parameters of type ReadableConfig Modifier and Type Method Description static PeriodicCacheReloadTrigger
PeriodicCacheReloadTrigger. fromConfig(ReadableConfig config)
static TimedCacheReloadTrigger
TimedCacheReloadTrigger. fromConfig(ReadableConfig config)
-
Uses of ReadableConfig in org.apache.flink.table.delegation
Methods in org.apache.flink.table.delegation that return ReadableConfig Modifier and Type Method Description ReadableConfig
Executor. getConfiguration()
Gives read-only access to the configuration of the executor.Methods in org.apache.flink.table.delegation with parameters of type ReadableConfig Modifier and Type Method Description Pipeline
Executor. createPipeline(List<Transformation<?>> transformations, ReadableConfig tableConfiguration, String defaultJobName)
Translates the given transformations to aPipeline
.Pipeline
Executor. createPipeline(List<Transformation<?>> transformations, ReadableConfig tableConfiguration, String defaultJobName, List<JobStatusHook> jobStatusHookList)
Translates the given transformations with a list ofJobStatusHook
s to aPipeline
. -
Uses of ReadableConfig in org.apache.flink.table.examples.java.connectors
Methods in org.apache.flink.table.examples.java.connectors with parameters of type ReadableConfig Modifier and Type Method Description DecodingFormat<DeserializationSchema<RowData>>
ChangelogCsvFormatFactory. createDecodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
-
Uses of ReadableConfig in org.apache.flink.table.executor.python
Methods in org.apache.flink.table.executor.python that return ReadableConfig Modifier and Type Method Description ReadableConfig
ChainingOptimizingExecutor. getConfiguration()
Methods in org.apache.flink.table.executor.python with parameters of type ReadableConfig Modifier and Type Method Description Pipeline
ChainingOptimizingExecutor. createPipeline(List<Transformation<?>> transformations, ReadableConfig configuration, String defaultJobName)
Pipeline
ChainingOptimizingExecutor. createPipeline(List<Transformation<?>> transformations, ReadableConfig configuration, String defaultJobName, List<JobStatusHook> jobStatusHookList)
-
Uses of ReadableConfig in org.apache.flink.table.expressions.resolver.rules
Methods in org.apache.flink.table.expressions.resolver.rules that return ReadableConfig Modifier and Type Method Description ReadableConfig
ResolverRule.ResolutionContext. configuration()
Access to configuration. -
Uses of ReadableConfig in org.apache.flink.table.factories
Methods in org.apache.flink.table.factories that return ReadableConfig Modifier and Type Method Description ReadableConfig
CatalogFactory.Context. getConfiguration()
Gives read-only access to the configuration of the current session.ReadableConfig
CatalogStoreFactory.Context. getConfiguration()
Gives read-only access to the configuration of the current session.ReadableConfig
DynamicTableFactory.Context. getConfiguration()
Gives read-only access to the configuration of the current session.ReadableConfig
FactoryUtil.DefaultCatalogContext. getConfiguration()
ReadableConfig
FactoryUtil.DefaultCatalogStoreContext. getConfiguration()
ReadableConfig
FactoryUtil.DefaultDynamicTableContext. getConfiguration()
ReadableConfig
FactoryUtil.DefaultModuleContext. getConfiguration()
ReadableConfig
ModuleFactory.Context. getConfiguration()
Gives read-only access to the configuration of the current session.ReadableConfig
TableSinkFactoryContextImpl. getConfiguration()
Deprecated.ReadableConfig
TableSourceFactoryContextImpl. getConfiguration()
Deprecated.ReadableConfig
WorkflowSchedulerFactory.Context. getConfiguration()
Gives the config option to createWorkflowScheduler
.ReadableConfig
WorkflowSchedulerFactoryUtil.DefaultWorkflowSchedulerContext. getConfiguration()
ReadableConfig
FactoryUtil.FactoryHelper. getOptions()
Returns all options currently being consumed by the factory.ReadableConfig
FactoryUtil.TableFactoryHelper. getOptions()
Returns all options currently being consumed by the factory.Methods in org.apache.flink.table.factories with parameters of type ReadableConfig Modifier and Type Method Description static Optional<String>
FactoryUtil. checkWatermarkOptions(ReadableConfig conf)
Check watermark-related options and return error messages.static Catalog
FactoryUtil. createCatalog(String catalogName, Map<String,String> options, ReadableConfig configuration, ClassLoader classLoader)
Attempts to discover an appropriate catalog factory and creates an instance of the catalog.DecodingFormat<I>
DecodingFormatFactory. createDecodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
Creates a format from the given context and format options.static DynamicTableSink
FactoryUtil. createDynamicTableSink(DynamicTableSinkFactory preferredFactory, ObjectIdentifier objectIdentifier, ResolvedCatalogTable catalogTable, Map<String,String> enrichmentOptions, ReadableConfig configuration, ClassLoader classLoader, boolean isTemporary)
Creates aDynamicTableSink
from aCatalogTable
.static DynamicTableSource
FactoryUtil. createDynamicTableSource(DynamicTableSourceFactory preferredFactory, ObjectIdentifier objectIdentifier, ResolvedCatalogTable catalogTable, Map<String,String> enrichmentOptions, ReadableConfig configuration, ClassLoader classLoader, boolean isTemporary)
Creates aDynamicTableSource
from aCatalogTable
.EncodingFormat<I>
EncodingFormatFactory. createEncodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
Creates a format from the given context and format options.static Module
FactoryUtil. createModule(String moduleName, Map<String,String> options, ReadableConfig configuration, ClassLoader classLoader)
Discovers a matching module factory and creates an instance of it.static <T> TableSink<T>
TableFactoryUtil. findAndCreateTableSink(Catalog catalog, ObjectIdentifier objectIdentifier, CatalogTable catalogTable, ReadableConfig configuration, boolean isStreamingMode, boolean isTemporary)
Creates aTableSink
from aCatalogTable
.static <T> TableSource<T>
TableFactoryUtil. findAndCreateTableSource(Catalog catalog, ObjectIdentifier objectIdentifier, CatalogTable catalogTable, ReadableConfig configuration, boolean isTemporary)
Creates aTableSource
from aCatalogTable
.static List<CatalogModificationListener>
TableFactoryUtil. findCatalogModificationListenerList(ReadableConfig configuration, ClassLoader classLoader)
Find and create modification listener list from configuration.static boolean
TableFactoryUtil. isLegacyConnectorOptions(Catalog catalog, ReadableConfig configuration, boolean isStreamingMode, ObjectIdentifier objectIdentifier, CatalogTable catalogTable, boolean isTemporary)
Checks whether theCatalogTable
uses legacy connector sink options.static void
FactoryUtil. validateFactoryOptions(Set<ConfigOption<?>> requiredOptions, Set<ConfigOption<?>> optionalOptions, ReadableConfig options)
Validates the required options and optional options.static void
FactoryUtil. validateFactoryOptions(Factory factory, ReadableConfig options)
Validates the required and optionalConfigOption
s of a factory.static void
FactoryUtil. validateWatermarkOptions(String factoryIdentifier, ReadableConfig conf)
Validate watermark options from table options. -
Uses of ReadableConfig in org.apache.flink.table.functions
Methods in org.apache.flink.table.functions that return ReadableConfig Modifier and Type Method Description ReadableConfig
SpecializedFunction.SpecializedContext. getConfiguration()
Gives read-only access to the configuration of the current session.Methods in org.apache.flink.table.functions with parameters of type ReadableConfig Modifier and Type Method Description static UserDefinedFunction
UserDefinedFunctionHelper. createSpecializedFunction(String functionName, FunctionDefinition definition, CallContext callContext, ClassLoader builtInClassLoader, ReadableConfig configuration, SpecializedFunction.ExpressionEvaluatorFactory evaluatorFactory)
Creates the runtime implementation of aFunctionDefinition
as an instance ofUserDefinedFunction
.static UserDefinedFunction
UserDefinedFunctionHelper. instantiateFunction(ClassLoader classLoader, ReadableConfig config, String name, CatalogFunction catalogFunction)
Instantiates aUserDefinedFunction
from aCatalogFunction
.static void
UserDefinedFunctionHelper. prepareInstance(ReadableConfig config, UserDefinedFunction function)
Prepares aUserDefinedFunction
instance for usage in the API. -
Uses of ReadableConfig in org.apache.flink.table.functions.python.utils
Methods in org.apache.flink.table.functions.python.utils with parameters of type ReadableConfig Modifier and Type Method Description static PythonFunction
PythonFunctionUtils. getPythonFunction(String fullyQualifiedName, ReadableConfig config, ClassLoader classLoader)
-
Uses of ReadableConfig in org.apache.flink.table.gateway.api.endpoint
Methods in org.apache.flink.table.gateway.api.endpoint that return ReadableConfig Modifier and Type Method Description ReadableConfig
SqlGatewayEndpointFactory.Context. getFlinkConfiguration()
Gives read-only access to the configuration of the current session.ReadableConfig
SqlGatewayEndpointFactoryUtils.DefaultEndpointFactoryContext. getFlinkConfiguration()
-
Uses of ReadableConfig in org.apache.flink.table.gateway.api.session
Methods in org.apache.flink.table.gateway.api.session with parameters of type ReadableConfig Modifier and Type Method Description Catalog
SessionEnvironment.CatalogCreator. create(ReadableConfig configuration, ClassLoader classLoader)
Module
SessionEnvironment.ModuleCreator. create(ReadableConfig configuration, ClassLoader classLoader)
-
Uses of ReadableConfig in org.apache.flink.table.gateway.rest.util
Constructors in org.apache.flink.table.gateway.rest.util with parameters of type ReadableConfig Constructor Description RowDataLocalTimeZoneConverter(List<LogicalType> logicalTypeList, ReadableConfig config)
-
Uses of ReadableConfig in org.apache.flink.table.legacy.factories
Methods in org.apache.flink.table.legacy.factories that return ReadableConfig Modifier and Type Method Description ReadableConfig
TableSinkFactory.Context. getConfiguration()
ReadableConfig
TableSourceFactory.Context. getConfiguration()
-
Uses of ReadableConfig in org.apache.flink.table.operations.utils
Methods in org.apache.flink.table.operations.utils with parameters of type ReadableConfig Modifier and Type Method Description static DynamicTableSink
ExecutableOperationUtils. createDynamicTableSink(Catalog catalog, Supplier<Optional<DynamicTableSinkFactory>> sinkFactorySupplier, ObjectIdentifier objectIdentifier, ResolvedCatalogTable catalogTable, Map<String,String> enrichmentOptions, ReadableConfig configuration, ClassLoader classLoader, boolean isTemporary)
Creates aDynamicTableSink
from aCatalogTable
. -
Uses of ReadableConfig in org.apache.flink.table.planner.codegen
Methods in org.apache.flink.table.planner.codegen with parameters of type ReadableConfig Modifier and Type Method Description static GeneratedFunction<AsyncFunction<RowData,RowData>>
AsyncCodeGenerator. generateFunction(String name, RowType inputType, RowType returnType, List<org.apache.calcite.rex.RexNode> calcProjection, boolean retainHeader, ReadableConfig tableConfig, ClassLoader classLoader)
Creates a generated function which produces anAsyncFunction
which executes the calc projections. -
Uses of ReadableConfig in org.apache.flink.table.planner.connectors
Methods in org.apache.flink.table.planner.connectors with parameters of type ReadableConfig Modifier and Type Method Description static org.apache.calcite.rel.RelNode
DynamicSinkUtils. convertCollectToRel(FlinkRelBuilder relBuilder, org.apache.calcite.rel.RelNode input, CollectModifyOperation collectModifyOperation, ReadableConfig configuration, ClassLoader classLoader)
Converts anTableResult.collect()
sink to aRelNode
.static org.apache.calcite.rel.RelNode
DynamicSourceUtils. convertDataStreamToRel(boolean isBatchMode, ReadableConfig config, FlinkRelBuilder relBuilder, ContextResolvedTable contextResolvedTable, DataStream<?> dataStream, DataType physicalDataType, boolean isTopLevelRecord, ChangelogMode changelogMode)
Converts a givenDataStream
to aRelNode
.static org.apache.calcite.rel.RelNode
DynamicSourceUtils. convertSourceToRel(boolean isBatchMode, ReadableConfig config, FlinkRelBuilder relBuilder, ContextResolvedTable contextResolvedTable, org.apache.flink.table.planner.plan.stats.FlinkStatistic statistic, List<org.apache.calcite.rel.hint.RelHint> hints, DynamicTableSource tableSource)
Converts a givenDynamicTableSource
to aRelNode
.static void
DynamicSourceUtils. prepareDynamicSource(String tableDebugName, ResolvedCatalogTable table, DynamicTableSource source, boolean isBatchMode, ReadableConfig config, List<SourceAbilitySpec> sourceAbilities)
Prepares the givenDynamicTableSource
. -
Uses of ReadableConfig in org.apache.flink.table.planner.delegation
Methods in org.apache.flink.table.planner.delegation that return ReadableConfig Modifier and Type Method Description ReadableConfig
DefaultExecutor. getConfiguration()
Methods in org.apache.flink.table.planner.delegation with parameters of type ReadableConfig Modifier and Type Method Description Pipeline
DefaultExecutor. createPipeline(List<Transformation<?>> transformations, ReadableConfig tableConfiguration, String defaultJobName)
Pipeline
DefaultExecutor. createPipeline(List<Transformation<?>> transformations, ReadableConfig tableConfiguration, String defaultJobName, List<JobStatusHook> jobStatusHookList)
-
Uses of ReadableConfig in org.apache.flink.table.planner.plan.nodes.exec
Classes in org.apache.flink.table.planner.plan.nodes.exec that implement ReadableConfig Modifier and Type Class Description class
ExecNodeConfig
Configuration view which is used combine thePlannerBase.getTableConfig()
with theExecNodeBase.getPersistedConfig()
configuration.Methods in org.apache.flink.table.planner.plan.nodes.exec that return ReadableConfig Modifier and Type Method Description ReadableConfig
ExecNodeBase. getPersistedConfig()
static <T extends ExecNode<?>>
ReadableConfigExecNodeContext. newPersistedConfig(Class<T> execNodeClass, ReadableConfig tableConfig)
Create a configuration for theExecNode
, ready to be persisted to a JSON plan.Methods in org.apache.flink.table.planner.plan.nodes.exec with parameters of type ReadableConfig Modifier and Type Method Description protected String
ExecNodeBase. createFormattedTransformationDescription(String description, ReadableConfig config)
protected String
ExecNodeBase. createFormattedTransformationName(String detailName, String simplifiedName, ReadableConfig config)
protected String
ExecNodeBase. createTransformationDescription(ReadableConfig config)
protected String
ExecNodeBase. createTransformationName(ReadableConfig config)
static List<StateMetadata>
StateMetadata. getMultiInputOperatorDefaultMeta(Map<Integer,Long> stateTtlFromHint, ReadableConfig tableConfig, String... stateNameList)
static List<StateMetadata>
StateMetadata. getOneInputOperatorDefaultMeta(Long stateTtlFromHint, ReadableConfig tableConfig, String stateName)
static List<StateMetadata>
StateMetadata. getOneInputOperatorDefaultMeta(ReadableConfig tableConfig, String stateName)
static <T extends ExecNode<?>>
ReadableConfigExecNodeContext. newPersistedConfig(Class<T> execNodeClass, ReadableConfig tableConfig)
Create a configuration for theExecNode
, ready to be persisted to a JSON plan.static ExecNodeConfig
ExecNodeConfig. ofNodeConfig(ReadableConfig nodeConfig, boolean isCompiled)
Constructors in org.apache.flink.table.planner.plan.nodes.exec with parameters of type ReadableConfig Constructor Description ExecNodeBase(int id, ExecNodeContext context, ReadableConfig persistedConfig, List<InputProperty> inputProperties, LogicalType outputType, String description)
-
Uses of ReadableConfig in org.apache.flink.table.planner.plan.nodes.exec.batch
Constructors in org.apache.flink.table.planner.plan.nodes.exec.batch with parameters of type ReadableConfig Constructor Description BatchExecBoundedStreamScan(ReadableConfig tableConfig, DataStream<?> dataStream, DataType sourceType, int[] fieldIndexes, List<String> qualifiedName, RowType outputType, String description)
BatchExecCalc(int id, ExecNodeContext context, ReadableConfig persistedConfig, List<org.apache.calcite.rex.RexNode> projection, org.apache.calcite.rex.RexNode condition, List<InputProperty> inputProperties, RowType outputType, String description)
BatchExecCalc(ReadableConfig tableConfig, List<org.apache.calcite.rex.RexNode> projection, org.apache.calcite.rex.RexNode condition, InputProperty inputProperty, RowType outputType, String description)
BatchExecCorrelate(int id, ExecNodeContext context, ReadableConfig persistedConfig, FlinkJoinType joinType, org.apache.calcite.rex.RexNode invocation, org.apache.calcite.rex.RexNode condition, List<InputProperty> inputProperties, RowType outputType, String description)
BatchExecCorrelate(ReadableConfig tableConfig, FlinkJoinType joinType, org.apache.calcite.rex.RexCall invocation, org.apache.calcite.rex.RexNode condition, InputProperty inputProperty, RowType outputType, String description)
BatchExecDynamicFilteringDataCollector(List<Integer> dynamicFilteringFieldIndices, ReadableConfig tableConfig, InputProperty inputProperty, RowType outputType, String description)
BatchExecExchange(int id, ExecNodeContext context, ReadableConfig persistedConfig, List<InputProperty> inputProperties, RowType outputType, String description, StreamExchangeMode requiredExchangeMode)
BatchExecExchange(ReadableConfig tableConfig, InputProperty inputProperty, RowType outputType, String description)
BatchExecExecutionOrderEnforcer(ReadableConfig tableConfig, List<InputProperty> inputProperties, LogicalType outputType, String description)
BatchExecExpand(int id, ExecNodeContext context, ReadableConfig persistedConfig, List<List<org.apache.calcite.rex.RexNode>> projects, List<InputProperty> inputProperties, RowType outputType, String description)
BatchExecExpand(ReadableConfig tableConfig, List<List<org.apache.calcite.rex.RexNode>> projects, InputProperty inputProperty, RowType outputType, String description)
BatchExecHashAggregate(int id, ExecNodeContext context, ReadableConfig persistedConfig, int[] grouping, int[] auxGrouping, org.apache.calcite.rel.core.AggregateCall[] aggCalls, RowType aggInputRowType, boolean isMerge, boolean isFinal, boolean supportAdaptiveLocalHashAgg, List<InputProperty> inputProperties, RowType outputType, String description)
BatchExecHashAggregate(ReadableConfig tableConfig, int[] grouping, int[] auxGrouping, org.apache.calcite.rel.core.AggregateCall[] aggCalls, RowType aggInputRowType, boolean isMerge, boolean isFinal, boolean supportAdaptiveLocalHashAgg, InputProperty inputProperty, RowType outputType, String description)
BatchExecHashJoin(int id, ExecNodeContext context, ReadableConfig persistedConfig, JoinSpec joinSpec, int estimatedLeftAvgRowSize, int estimatedRightAvgRowSize, long estimatedLeftRowCount, long estimatedRightRowCount, boolean isBroadcast, boolean leftIsBuild, boolean tryDistinctBuildRow, List<InputProperty> inputProperties, RowType outputType, String description)
BatchExecHashJoin(ReadableConfig tableConfig, JoinSpec joinSpec, int estimatedLeftAvgRowSize, int estimatedRightAvgRowSize, long estimatedLeftRowCount, long estimatedRightRowCount, boolean isBroadcast, boolean leftIsBuild, boolean tryDistinctBuildRow, InputProperty leftInputProperty, InputProperty rightInputProperty, RowType outputType, String description)
BatchExecHashWindowAggregate(ReadableConfig tableConfig, int[] grouping, int[] auxGrouping, org.apache.calcite.rel.core.AggregateCall[] aggCalls, org.apache.flink.table.planner.plan.logical.LogicalWindow window, int inputTimeFieldIndex, boolean inputTimeIsDate, NamedWindowProperty[] namedWindowProperties, RowType aggInputRowType, boolean enableAssignPane, boolean isMerge, boolean isFinal, InputProperty inputProperty, RowType outputType, String description)
BatchExecInputAdapter(int multipleInputId, ReadableConfig tableConfig, InputProperty inputProperty, LogicalType outputType, String description)
BatchExecLegacySink(ReadableConfig tableConfig, TableSink<T> tableSink, String[] upsertKeys, InputProperty inputProperty, LogicalType outputType, String description)
BatchExecLegacyTableSourceScan(ReadableConfig tableConfig, TableSource<?> tableSource, List<String> qualifiedName, RowType outputType, String description)
BatchExecLimit(int id, ExecNodeContext context, ReadableConfig persistedConfig, long limitStart, long limitEnd, boolean isGlobal, List<InputProperty> inputProperties, LogicalType outputType, String description)
BatchExecLimit(ReadableConfig tableConfig, long limitStart, long limitEnd, boolean isGlobal, InputProperty inputProperty, LogicalType outputType, String description)
BatchExecLookupJoin(int id, ExecNodeContext context, ReadableConfig persistedConfig, FlinkJoinType joinType, org.apache.calcite.rex.RexNode preFilterCondition, org.apache.calcite.rex.RexNode remainingJoinCondition, TemporalTableSourceSpec temporalTableSourceSpec, Map<Integer,LookupJoinUtil.LookupKey> lookupKeys, List<org.apache.calcite.rex.RexNode> projectionOnTemporalTable, org.apache.calcite.rex.RexNode filterOnTemporalTable, LookupJoinUtil.AsyncLookupOptions asyncLookupOptions, List<InputProperty> inputProperties, RowType outputType, String description)
BatchExecLookupJoin(ReadableConfig tableConfig, FlinkJoinType joinType, org.apache.calcite.rex.RexNode preFilterCondition, org.apache.calcite.rex.RexNode remainingJoinCondition, TemporalTableSourceSpec temporalTableSourceSpec, Map<Integer,LookupJoinUtil.LookupKey> lookupKeys, List<org.apache.calcite.rex.RexNode> projectionOnTemporalTable, org.apache.calcite.rex.RexNode filterOnTemporalTable, LookupJoinUtil.AsyncLookupOptions asyncLookupOptions, InputProperty inputProperty, RowType outputType, String description)
BatchExecMatch(int id, ExecNodeContext context, ReadableConfig persistedConfig, MatchSpec matchSpec, List<InputProperty> inputProperties, RowType outputType, String description)
BatchExecMatch(ReadableConfig tableConfig, MatchSpec matchSpec, InputProperty inputProperty, RowType outputType, String description)
BatchExecMultipleInput(ReadableConfig tableConfig, List<InputProperty> inputProperties, ExecNode<?> rootNode, List<ExecNode<?>> memberExecNodes, List<ExecEdge> originalEdges, String description)
BatchExecNestedLoopJoin(int id, ExecNodeContext context, ReadableConfig persistedConfig, FlinkJoinType joinType, org.apache.calcite.rex.RexNode condition, boolean leftIsBuild, boolean singleRowJoin, List<InputProperty> inputProperties, RowType outputType, String description)
BatchExecNestedLoopJoin(ReadableConfig tableConfig, FlinkJoinType joinType, org.apache.calcite.rex.RexNode condition, boolean leftIsBuild, boolean singleRowJoin, InputProperty leftInputProperty, InputProperty rightInputProperty, RowType outputType, String description)
BatchExecOverAggregate(int id, ExecNodeContext context, ReadableConfig persistedConfig, OverSpec overSpec, List<InputProperty> inputProperties, RowType outputType, String description)
BatchExecOverAggregate(ReadableConfig tableConfig, OverSpec overSpec, InputProperty inputProperty, RowType outputType, String description)
BatchExecOverAggregateBase(int id, ExecNodeContext context, ReadableConfig persistedConfig, OverSpec overSpec, List<InputProperty> inputProperties, RowType outputType, String description)
BatchExecOverAggregateBase(int id, ExecNodeContext context, ReadableConfig persistedConfig, OverSpec overSpec, InputProperty inputProperty, RowType outputType, String description)
BatchExecPythonCalc(ReadableConfig tableConfig, List<org.apache.calcite.rex.RexNode> projection, InputProperty inputProperty, RowType outputType, String description)
BatchExecPythonCorrelate(ReadableConfig tableConfig, FlinkJoinType joinType, org.apache.calcite.rex.RexCall invocation, InputProperty inputProperty, RowType outputType, String description)
BatchExecPythonGroupAggregate(ReadableConfig tableConfig, int[] grouping, int[] auxGrouping, org.apache.calcite.rel.core.AggregateCall[] aggCalls, InputProperty inputProperty, RowType outputType, String description)
BatchExecPythonGroupWindowAggregate(ReadableConfig tableConfig, int[] grouping, int[] auxGrouping, org.apache.calcite.rel.core.AggregateCall[] aggCalls, org.apache.flink.table.planner.plan.logical.LogicalWindow window, int inputTimeFieldIndex, NamedWindowProperty[] namedWindowProperties, InputProperty inputProperty, RowType outputType, String description)
BatchExecPythonOverAggregate(ReadableConfig tableConfig, OverSpec overSpec, InputProperty inputProperty, RowType outputType, String description)
BatchExecRank(int id, ExecNodeContext context, ReadableConfig persistedConfig, int[] partitionFields, int[] sortFields, long rankStart, long rankEnd, boolean outputRankNumber, List<InputProperty> inputProperties, RowType outputType, String description)
BatchExecRank(ReadableConfig tableConfig, int[] partitionFields, int[] sortFields, long rankStart, long rankEnd, boolean outputRankNumber, InputProperty inputProperty, RowType outputType, String description)
BatchExecScriptTransform(ReadableConfig tableConfig, InputProperty inputProperty, LogicalType inputType, LogicalType outputType, String description, int[] inputIndexes, String script, ScriptTransformIOInfo scriptTransformIOInfo)
BatchExecSink(int id, ExecNodeContext context, ReadableConfig persistedConfig, DynamicTableSinkSpec tableSinkSpec, List<InputProperty> inputProperties, LogicalType outputType, String description)
BatchExecSink(ReadableConfig tableConfig, DynamicTableSinkSpec tableSinkSpec, InputProperty inputProperty, LogicalType outputType, String description)
BatchExecSort(int id, ExecNodeContext context, ReadableConfig persistedConfig, SortSpec sortSpec, List<InputProperty> inputProperties, RowType outputType, String description)
BatchExecSort(ReadableConfig tableConfig, SortSpec sortSpec, InputProperty inputProperty, RowType outputType, String description)
BatchExecSortAggregate(int id, ExecNodeContext context, ReadableConfig persistedConfig, int[] grouping, int[] auxGrouping, org.apache.calcite.rel.core.AggregateCall[] aggCalls, RowType aggInputRowType, boolean isMerge, boolean isFinal, List<InputProperty> inputProperties, RowType outputType, String description)
BatchExecSortAggregate(ReadableConfig tableConfig, int[] grouping, int[] auxGrouping, org.apache.calcite.rel.core.AggregateCall[] aggCalls, RowType aggInputRowType, boolean isMerge, boolean isFinal, InputProperty inputProperty, RowType outputType, String description)
BatchExecSortLimit(int id, ExecNodeContext context, ReadableConfig persistedConfig, SortSpec sortSpec, long limitStart, long limitEnd, boolean isGlobal, List<InputProperty> inputProperties, RowType outputType, String description)
BatchExecSortLimit(ReadableConfig tableConfig, SortSpec sortSpec, long limitStart, long limitEnd, boolean isGlobal, InputProperty inputProperty, RowType outputType, String description)
BatchExecSortMergeJoin(ReadableConfig tableConfig, FlinkJoinType joinType, int[] leftKeys, int[] rightKeys, boolean[] filterNulls, org.apache.calcite.rex.RexNode nonEquiCondition, boolean leftIsSmaller, InputProperty leftInputProperty, InputProperty rightInputProperty, RowType outputType, String description)
BatchExecSortWindowAggregate(ReadableConfig tableConfig, int[] grouping, int[] auxGrouping, org.apache.calcite.rel.core.AggregateCall[] aggCalls, org.apache.flink.table.planner.plan.logical.LogicalWindow window, int inputTimeFieldIndex, boolean inputTimeIsDate, NamedWindowProperty[] namedWindowProperties, RowType aggInputRowType, boolean enableAssignPane, boolean isMerge, boolean isFinal, InputProperty inputProperty, RowType outputType, String description)
BatchExecTableSourceScan(int id, ExecNodeContext context, ReadableConfig tableConfig, DynamicTableSourceSpec tableSourceSpec, RowType outputType, String description)
BatchExecTableSourceScan(ReadableConfig tableConfig, DynamicTableSourceSpec tableSourceSpec, InputProperty inputProperty, RowType outputType, String description)
BatchExecTableSourceScan(ReadableConfig tableConfig, DynamicTableSourceSpec tableSourceSpec, RowType outputType, String description)
BatchExecUnion(int id, ExecNodeContext context, ReadableConfig persistedConfig, List<InputProperty> inputProperties, RowType outputType, String description)
BatchExecUnion(ReadableConfig tableConfig, List<InputProperty> inputProperties, RowType outputType, String description)
BatchExecValues(int id, ExecNodeContext context, ReadableConfig persistedConfig, List<List<org.apache.calcite.rex.RexLiteral>> tuples, RowType outputType, String description)
BatchExecValues(ReadableConfig tableConfig, List<List<org.apache.calcite.rex.RexLiteral>> tuples, RowType outputType, String description)
BatchExecWindowTableFunction(int id, ExecNodeContext context, ReadableConfig persistedConfig, TimeAttributeWindowingStrategy windowingStrategy, List<InputProperty> inputProperties, RowType outputType, String description)
BatchExecWindowTableFunction(ReadableConfig tableConfig, TimeAttributeWindowingStrategy windowingStrategy, InputProperty inputProperty, RowType outputType, String description)
-
Uses of ReadableConfig in org.apache.flink.table.planner.plan.nodes.exec.batch.runtimefilter
Constructors in org.apache.flink.table.planner.plan.nodes.exec.batch.runtimefilter with parameters of type ReadableConfig Constructor Description BatchExecGlobalRuntimeFilterBuilder(ReadableConfig tableConfig, List<InputProperty> inputProperties, LogicalType outputType, String description, int maxRowCount)
BatchExecLocalRuntimeFilterBuilder(ReadableConfig tableConfig, List<InputProperty> inputProperties, LogicalType outputType, String description, int[] buildIndices, int estimatedRowCount, int maxRowCount)
BatchExecRuntimeFilter(ReadableConfig tableConfig, List<InputProperty> inputProperties, LogicalType outputType, String description, int[] probeIndices)
-
Uses of ReadableConfig in org.apache.flink.table.planner.plan.nodes.exec.common
Methods in org.apache.flink.table.planner.plan.nodes.exec.common with parameters of type ReadableConfig Modifier and Type Method Description static Tuple2<Pattern<RowData,RowData>,List<String>>
CommonExecMatch. translatePattern(MatchSpec matchSpec, ReadableConfig config, ClassLoader classLoader, RelBuilder relBuilder, RowType inputRowType)
Constructors in org.apache.flink.table.planner.plan.nodes.exec.common with parameters of type ReadableConfig Constructor Description CommonExecAsyncCalc(int id, ExecNodeContext context, ReadableConfig persistedConfig, List<org.apache.calcite.rex.RexNode> projection, List<InputProperty> inputProperties, RowType outputType, String description)
CommonExecCalc(int id, ExecNodeContext context, ReadableConfig persistedConfig, List<org.apache.calcite.rex.RexNode> projection, org.apache.calcite.rex.RexNode condition, Class<?> operatorBaseClass, boolean retainHeader, List<InputProperty> inputProperties, RowType outputType, String description)
CommonExecCorrelate(int id, ExecNodeContext context, ReadableConfig persistedConfig, FlinkJoinType joinType, org.apache.calcite.rex.RexCall invocation, org.apache.calcite.rex.RexNode condition, Class<?> operatorBaseClass, boolean retainHeader, List<InputProperty> inputProperties, RowType outputType, String description)
CommonExecExchange(int id, ExecNodeContext context, ReadableConfig persistedConfig, List<InputProperty> inputProperties, RowType outputType, String description)
CommonExecExpand(int id, ExecNodeContext context, ReadableConfig persistedConfig, List<List<org.apache.calcite.rex.RexNode>> projects, boolean retainHeader, List<InputProperty> inputProperties, RowType outputType, String description)
CommonExecLegacySink(int id, ExecNodeContext context, ReadableConfig persistedConfig, TableSink<T> tableSink, String[] upsertKeys, boolean needRetraction, boolean isStreaming, InputProperty inputProperty, LogicalType outputType, String description)
CommonExecLegacyTableSourceScan(int id, ExecNodeContext context, ReadableConfig persistedConfig, TableSource<?> tableSource, List<String> qualifiedName, RowType outputType, String description)
CommonExecLookupJoin(int id, ExecNodeContext context, ReadableConfig persistedConfig, FlinkJoinType joinType, org.apache.calcite.rex.RexNode preFilterCondition, org.apache.calcite.rex.RexNode remainingJoinCondition, TemporalTableSourceSpec temporalTableSourceSpec, Map<Integer,LookupJoinUtil.LookupKey> lookupKeys, List<org.apache.calcite.rex.RexNode> projectionOnTemporalTable, org.apache.calcite.rex.RexNode filterOnTemporalTable, LookupJoinUtil.AsyncLookupOptions asyncLookupOptions, LookupJoinUtil.RetryLookupOptions retryOptions, ChangelogMode inputChangelogMode, List<InputProperty> inputProperties, RowType outputType, String description)
CommonExecMatch(int id, ExecNodeContext context, ReadableConfig persistedConfig, MatchSpec matchSpec, List<InputProperty> inputProperties, LogicalType outputType, String description)
CommonExecPythonCalc(int id, ExecNodeContext context, ReadableConfig persistedConfig, List<org.apache.calcite.rex.RexNode> projection, List<InputProperty> inputProperties, RowType outputType, String description)
CommonExecPythonCorrelate(int id, ExecNodeContext context, ReadableConfig persistedConfig, FlinkJoinType joinType, org.apache.calcite.rex.RexCall invocation, List<InputProperty> inputProperties, RowType outputType, String description)
CommonExecSink(int id, ExecNodeContext context, ReadableConfig persistedConfig, DynamicTableSinkSpec tableSinkSpec, ChangelogMode inputChangelogMode, boolean isBounded, List<InputProperty> inputProperties, LogicalType outputType, String description)
CommonExecTableSourceScan(int id, ExecNodeContext context, ReadableConfig persistedConfig, DynamicTableSourceSpec tableSourceSpec, List<InputProperty> inputProperties, LogicalType outputType, String description)
CommonExecUnion(int id, ExecNodeContext context, ReadableConfig persistedConfig, List<InputProperty> inputProperties, RowType outputType, String description)
CommonExecValues(int id, ExecNodeContext context, ReadableConfig persistedConfig, List<List<org.apache.calcite.rex.RexLiteral>> tuples, RowType outputType, String description)
CommonExecWindowTableFunction(int id, ExecNodeContext context, ReadableConfig persistedConfig, TimeAttributeWindowingStrategy windowingStrategy, List<InputProperty> inputProperties, RowType outputType, String description)
-
Uses of ReadableConfig in org.apache.flink.table.planner.plan.nodes.exec.processor.utils
Constructors in org.apache.flink.table.planner.plan.nodes.exec.processor.utils with parameters of type ReadableConfig Constructor Description InputPriorityConflictResolver(List<ExecNode<?>> roots, InputProperty.DamBehavior safeDamBehavior, StreamExchangeMode exchangeMode, ReadableConfig tableConfig)
Create aInputPriorityConflictResolver
for the givenExecNode
graph. -
Uses of ReadableConfig in org.apache.flink.table.planner.plan.nodes.exec.serde
Methods in org.apache.flink.table.planner.plan.nodes.exec.serde that return ReadableConfig Modifier and Type Method Description ReadableConfig
SerdeContext. getConfiguration()
-
Uses of ReadableConfig in org.apache.flink.table.planner.plan.nodes.exec.stream
Constructors in org.apache.flink.table.planner.plan.nodes.exec.stream with parameters of type ReadableConfig Constructor Description StreamExecAggregateBase(int id, ExecNodeContext context, ReadableConfig persistedConfig, List<InputProperty> inputProperties, LogicalType outputType, String description)
StreamExecAsyncCalc(int id, ExecNodeContext context, ReadableConfig persistedConfig, List<org.apache.calcite.rex.RexNode> projection, List<InputProperty> inputProperties, RowType outputType, String description)
StreamExecAsyncCalc(ReadableConfig tableConfig, List<org.apache.calcite.rex.RexNode> projection, InputProperty inputProperty, RowType outputType, String description)
StreamExecCalc(int id, ExecNodeContext context, ReadableConfig persistedConfig, List<org.apache.calcite.rex.RexNode> projection, org.apache.calcite.rex.RexNode condition, List<InputProperty> inputProperties, RowType outputType, String description)
StreamExecCalc(ReadableConfig tableConfig, List<org.apache.calcite.rex.RexNode> projection, org.apache.calcite.rex.RexNode condition, InputProperty inputProperty, RowType outputType, String description)
StreamExecChangelogNormalize(Integer id, ExecNodeContext context, ReadableConfig persistedConfig, int[] uniqueKeys, boolean generateUpdateBefore, List<StateMetadata> stateMetadataList, List<InputProperty> inputProperties, RowType outputType, String description)
StreamExecChangelogNormalize(ReadableConfig tableConfig, int[] uniqueKeys, boolean generateUpdateBefore, InputProperty inputProperty, RowType outputType, String description)
StreamExecCorrelate(int id, ExecNodeContext context, ReadableConfig persistedConfig, FlinkJoinType joinType, org.apache.calcite.rex.RexNode invocation, org.apache.calcite.rex.RexNode condition, List<InputProperty> inputProperties, RowType outputType, String description)
StreamExecCorrelate(ReadableConfig tableConfig, FlinkJoinType joinType, org.apache.calcite.rex.RexCall invocation, org.apache.calcite.rex.RexNode condition, InputProperty inputProperty, RowType outputType, String description)
StreamExecDataStreamScan(ReadableConfig tableConfig, DataStream<?> dataStream, DataType sourceType, int[] fieldIndexes, String[] fieldNames, List<String> qualifiedName, RowType outputType, String description)
StreamExecDeduplicate(int id, ExecNodeContext context, ReadableConfig persistedConfig, int[] uniqueKeys, boolean isRowtime, boolean keepLastRow, boolean generateUpdateBefore, List<StateMetadata> stateMetadataList, List<InputProperty> inputProperties, RowType outputType, String description)
StreamExecDeduplicate(ReadableConfig tableConfig, int[] uniqueKeys, boolean isRowtime, boolean keepLastRow, boolean generateUpdateBefore, InputProperty inputProperty, RowType outputType, String description)
StreamExecDropUpdateBefore(int id, ExecNodeContext context, ReadableConfig persistedConfig, List<InputProperty> inputProperties, RowType outputType, String description)
StreamExecDropUpdateBefore(ReadableConfig tableConfig, InputProperty inputProperty, RowType outputType, String description)
StreamExecExchange(int id, ExecNodeContext context, ReadableConfig persistedConfig, List<InputProperty> inputProperties, RowType outputType, String description)
StreamExecExchange(ReadableConfig tableConfig, InputProperty inputProperty, RowType outputType, String description)
StreamExecExpand(int id, ExecNodeContext context, ReadableConfig persistedConfig, List<List<org.apache.calcite.rex.RexNode>> projects, List<InputProperty> inputProperties, RowType outputType, String description)
StreamExecExpand(ReadableConfig tableConfig, List<List<org.apache.calcite.rex.RexNode>> projects, InputProperty inputProperty, RowType outputType, String description)
StreamExecGlobalGroupAggregate(int id, ExecNodeContext context, ReadableConfig persistedConfig, int[] grouping, org.apache.calcite.rel.core.AggregateCall[] aggCalls, boolean[] aggCallNeedRetractions, RowType localAggInputRowType, boolean generateUpdateBefore, boolean needRetraction, Integer indexOfCountStar, List<StateMetadata> stateMetadataList, List<InputProperty> inputProperties, RowType outputType, String description)
StreamExecGlobalGroupAggregate(ReadableConfig tableConfig, int[] grouping, org.apache.calcite.rel.core.AggregateCall[] aggCalls, boolean[] aggCallNeedRetractions, RowType localAggInputRowType, boolean generateUpdateBefore, boolean needRetraction, Integer indexOfCountStar, Long stateTtlFromHint, InputProperty inputProperty, RowType outputType, String description)
StreamExecGlobalWindowAggregate(int id, ExecNodeContext context, ReadableConfig persistedConfig, int[] grouping, org.apache.calcite.rel.core.AggregateCall[] aggCalls, WindowingStrategy windowing, NamedWindowProperty[] namedWindowProperties, Boolean needRetraction, List<InputProperty> inputProperties, RowType localAggInputRowType, RowType outputType, String description)
StreamExecGlobalWindowAggregate(ReadableConfig tableConfig, int[] grouping, org.apache.calcite.rel.core.AggregateCall[] aggCalls, WindowingStrategy windowing, NamedWindowProperty[] namedWindowProperties, Boolean needRetraction, InputProperty inputProperty, RowType localAggInputRowType, RowType outputType, String description)
StreamExecGroupAggregate(int id, ExecNodeContext context, ReadableConfig persistedConfig, int[] grouping, org.apache.calcite.rel.core.AggregateCall[] aggCalls, boolean[] aggCallNeedRetractions, boolean generateUpdateBefore, boolean needRetraction, List<StateMetadata> stateMetadataList, List<InputProperty> inputProperties, RowType outputType, String description)
StreamExecGroupAggregate(ReadableConfig tableConfig, int[] grouping, org.apache.calcite.rel.core.AggregateCall[] aggCalls, boolean[] aggCallNeedRetractions, boolean generateUpdateBefore, boolean needRetraction, Long stateTtlFromHint, InputProperty inputProperty, RowType outputType, String description)
StreamExecGroupTableAggregate(ReadableConfig tableConfig, int[] grouping, org.apache.calcite.rel.core.AggregateCall[] aggCalls, boolean[] aggCallNeedRetractions, boolean generateUpdateBefore, boolean needRetraction, InputProperty inputProperty, RowType outputType, String description)
StreamExecGroupWindowAggregate(int id, ExecNodeContext context, ReadableConfig persistedConfig, int[] grouping, org.apache.calcite.rel.core.AggregateCall[] aggCalls, org.apache.flink.table.planner.plan.logical.LogicalWindow window, NamedWindowProperty[] namedWindowProperties, boolean needRetraction, List<InputProperty> inputProperties, RowType outputType, String description)
StreamExecGroupWindowAggregate(ReadableConfig tableConfig, int[] grouping, org.apache.calcite.rel.core.AggregateCall[] aggCalls, org.apache.flink.table.planner.plan.logical.LogicalWindow window, NamedWindowProperty[] namedWindowProperties, boolean needRetraction, InputProperty inputProperty, RowType outputType, String description)
StreamExecIncrementalGroupAggregate(int id, ExecNodeContext context, ReadableConfig persistedConfig, int[] partialAggGrouping, int[] finalAggGrouping, org.apache.calcite.rel.core.AggregateCall[] partialOriginalAggCalls, boolean[] partialAggCallNeedRetractions, RowType partialLocalAggInputType, boolean partialAggNeedRetraction, List<StateMetadata> stateMetadataList, List<InputProperty> inputProperties, RowType outputType, String description)
StreamExecIncrementalGroupAggregate(ReadableConfig tableConfig, int[] partialAggGrouping, int[] finalAggGrouping, org.apache.calcite.rel.core.AggregateCall[] partialOriginalAggCalls, boolean[] partialAggCallNeedRetractions, RowType partialLocalAggInputType, boolean partialAggNeedRetraction, Long stateTtlFromHint, InputProperty inputProperty, RowType outputType, String description)
StreamExecIntervalJoin(int id, ExecNodeContext context, ReadableConfig persistedConfig, IntervalJoinSpec intervalJoinSpec, List<InputProperty> inputProperties, RowType outputType, String description)
StreamExecIntervalJoin(ReadableConfig tableConfig, IntervalJoinSpec intervalJoinSpec, InputProperty leftInputProperty, InputProperty rightInputProperty, RowType outputType, String description)
StreamExecJoin(int id, ExecNodeContext context, ReadableConfig persistedConfig, JoinSpec joinSpec, List<int[]> leftUpsertKeys, List<int[]> rightUpsertKeys, List<StateMetadata> stateMetadataList, List<InputProperty> inputProperties, RowType outputType, String description)
StreamExecJoin(ReadableConfig tableConfig, JoinSpec joinSpec, List<int[]> leftUpsertKeys, List<int[]> rightUpsertKeys, InputProperty leftInputProperty, InputProperty rightInputProperty, Map<Integer,Long> stateTtlFromHint, RowType outputType, String description)
StreamExecLegacySink(ReadableConfig tableConfig, TableSink<T> tableSink, String[] upsertKeys, boolean needRetraction, InputProperty inputProperty, LogicalType outputType, String description)
StreamExecLegacyTableSourceScan(ReadableConfig tableConfig, TableSource<?> tableSource, List<String> qualifiedName, RowType outputType, String description)
StreamExecLimit(int id, ExecNodeContext context, ReadableConfig persistedConfig, ConstantRankRange rankRange, RankProcessStrategy rankStrategy, boolean generateUpdateBefore, List<StateMetadata> stateMetadataList, List<InputProperty> inputProperties, RowType outputType, String description)
StreamExecLimit(ReadableConfig tableConfig, long limitStart, long limitEnd, boolean generateUpdateBefore, boolean needRetraction, InputProperty inputProperty, RowType outputType, String description)
StreamExecLocalGroupAggregate(int id, ExecNodeContext context, ReadableConfig persistedConfig, int[] grouping, org.apache.calcite.rel.core.AggregateCall[] aggCalls, boolean[] aggCallNeedRetractions, boolean needRetraction, List<InputProperty> inputProperties, RowType outputType, String description)
StreamExecLocalGroupAggregate(ReadableConfig tableConfig, int[] grouping, org.apache.calcite.rel.core.AggregateCall[] aggCalls, boolean[] aggCallNeedRetractions, boolean needRetraction, InputProperty inputProperty, RowType outputType, String description)
StreamExecLocalWindowAggregate(int id, ExecNodeContext context, ReadableConfig persistedConfig, int[] grouping, org.apache.calcite.rel.core.AggregateCall[] aggCalls, WindowingStrategy windowing, Boolean needRetraction, List<InputProperty> inputProperties, RowType outputType, String description)
StreamExecLocalWindowAggregate(ReadableConfig tableConfig, int[] grouping, org.apache.calcite.rel.core.AggregateCall[] aggCalls, WindowingStrategy windowing, Boolean needRetraction, InputProperty inputProperty, RowType outputType, String description)
StreamExecLookupJoin(int id, ExecNodeContext context, ReadableConfig persistedConfig, FlinkJoinType joinType, org.apache.calcite.rex.RexNode preFilterCondition, org.apache.calcite.rex.RexNode remainingJoinCondition, TemporalTableSourceSpec temporalTableSourceSpec, Map<Integer,LookupJoinUtil.LookupKey> lookupKeys, List<org.apache.calcite.rex.RexNode> projectionOnTemporalTable, org.apache.calcite.rex.RexNode filterOnTemporalTable, boolean lookupKeyContainsPrimaryKey, boolean upsertMaterialize, LookupJoinUtil.AsyncLookupOptions asyncLookupOptions, LookupJoinUtil.RetryLookupOptions retryOptions, ChangelogMode inputChangelogMode, int[] inputUpsertKey, List<StateMetadata> stateMetadataList, List<InputProperty> inputProperties, RowType outputType, String description)
StreamExecLookupJoin(ReadableConfig tableConfig, FlinkJoinType joinType, org.apache.calcite.rex.RexNode preFilterCondition, org.apache.calcite.rex.RexNode remainingJoinCondition, TemporalTableSourceSpec temporalTableSourceSpec, Map<Integer,LookupJoinUtil.LookupKey> lookupKeys, List<org.apache.calcite.rex.RexNode> projectionOnTemporalTable, org.apache.calcite.rex.RexNode filterOnTemporalTable, boolean lookupKeyContainsPrimaryKey, boolean upsertMaterialize, LookupJoinUtil.AsyncLookupOptions asyncLookupOptions, LookupJoinUtil.RetryLookupOptions retryOptions, ChangelogMode inputChangelogMode, int[] inputUpsertKey, InputProperty inputProperty, RowType outputType, String description)
StreamExecMatch(int id, ExecNodeContext context, ReadableConfig persistedConfig, MatchSpec matchSpec, List<InputProperty> inputProperties, RowType outputType, String description)
StreamExecMatch(ReadableConfig tableConfig, MatchSpec matchSpec, InputProperty inputProperty, RowType outputType, String description)
StreamExecMiniBatchAssigner(int id, ExecNodeContext context, ReadableConfig persistedConfig, MiniBatchInterval miniBatchInterval, List<InputProperty> inputProperties, RowType outputType, String description)
StreamExecMiniBatchAssigner(ReadableConfig tableConfig, MiniBatchInterval miniBatchInterval, InputProperty inputProperty, RowType outputType, String description)
StreamExecMultipleInput(ReadableConfig tableConfig, List<InputProperty> inputProperties, ExecNode<?> rootNode, String description)
StreamExecOverAggregate(int id, ExecNodeContext context, ReadableConfig persistedConfig, OverSpec overSpec, List<InputProperty> inputProperties, RowType outputType, String description)
StreamExecOverAggregate(ReadableConfig tableConfig, OverSpec overSpec, InputProperty inputProperty, RowType outputType, String description)
StreamExecPythonCalc(int id, ExecNodeContext context, ReadableConfig persistedConfig, List<org.apache.calcite.rex.RexNode> projection, List<InputProperty> inputProperties, RowType outputType, String description)
StreamExecPythonCalc(ReadableConfig tableConfig, List<org.apache.calcite.rex.RexNode> projection, InputProperty inputProperty, RowType outputType, String description)
StreamExecPythonCorrelate(int id, ExecNodeContext context, ReadableConfig persistedConfig, FlinkJoinType joinType, org.apache.calcite.rex.RexNode invocation, List<InputProperty> inputProperties, RowType outputType, String description)
StreamExecPythonCorrelate(ReadableConfig tableConfig, FlinkJoinType joinType, org.apache.calcite.rex.RexCall invocation, InputProperty inputProperty, RowType outputType, String description)
StreamExecPythonGroupAggregate(int id, ExecNodeContext context, ReadableConfig persistedConfig, int[] grouping, org.apache.calcite.rel.core.AggregateCall[] aggCalls, boolean[] aggCallNeedRetractions, boolean generateUpdateBefore, boolean needRetraction, List<InputProperty> inputProperties, RowType outputType, String description)
StreamExecPythonGroupAggregate(ReadableConfig tableConfig, int[] grouping, org.apache.calcite.rel.core.AggregateCall[] aggCalls, boolean[] aggCallNeedRetractions, boolean generateUpdateBefore, boolean needRetraction, InputProperty inputProperty, RowType outputType, String description)
StreamExecPythonGroupTableAggregate(ReadableConfig tableConfig, int[] grouping, org.apache.calcite.rel.core.AggregateCall[] aggCalls, boolean[] aggCallNeedRetractions, boolean generateUpdateBefore, boolean needRetraction, InputProperty inputProperty, RowType outputType, String description)
StreamExecPythonGroupWindowAggregate(int id, ExecNodeContext context, ReadableConfig persistedConfig, int[] grouping, org.apache.calcite.rel.core.AggregateCall[] aggCalls, org.apache.flink.table.planner.plan.logical.LogicalWindow window, NamedWindowProperty[] namedWindowProperties, boolean generateUpdateBefore, boolean needRetraction, List<InputProperty> inputProperties, RowType outputType, String description)
StreamExecPythonGroupWindowAggregate(ReadableConfig tableConfig, int[] grouping, org.apache.calcite.rel.core.AggregateCall[] aggCalls, org.apache.flink.table.planner.plan.logical.LogicalWindow window, NamedWindowProperty[] namedWindowProperties, boolean generateUpdateBefore, boolean needRetraction, InputProperty inputProperty, RowType outputType, String description)
StreamExecPythonOverAggregate(int id, ExecNodeContext context, ReadableConfig persistedConfig, OverSpec overSpec, List<InputProperty> inputProperties, RowType outputType, String description)
StreamExecPythonOverAggregate(ReadableConfig tableConfig, OverSpec overSpec, InputProperty inputProperty, RowType outputType, String description)
StreamExecRank(int id, ExecNodeContext context, ReadableConfig persistedConfig, RankType rankType, PartitionSpec partitionSpec, SortSpec sortSpec, RankRange rankRange, RankProcessStrategy rankStrategy, boolean outputRankNumber, boolean generateUpdateBefore, List<StateMetadata> stateMetadataList, List<InputProperty> inputProperties, RowType outputType, String description)
StreamExecRank(ReadableConfig tableConfig, RankType rankType, PartitionSpec partitionSpec, SortSpec sortSpec, RankRange rankRange, RankProcessStrategy rankStrategy, boolean outputRankNumber, boolean generateUpdateBefore, InputProperty inputProperty, RowType outputType, String description)
StreamExecSink(int id, ExecNodeContext context, ReadableConfig persistedConfig, DynamicTableSinkSpec tableSinkSpec, ChangelogMode inputChangelogMode, boolean upsertMaterialize, List<StateMetadata> stateMetadataList, int[] inputUpsertKey, List<InputProperty> inputProperties, LogicalType outputType, String description)
StreamExecSink(ReadableConfig tableConfig, DynamicTableSinkSpec tableSinkSpec, ChangelogMode inputChangelogMode, InputProperty inputProperty, LogicalType outputType, boolean upsertMaterialize, int[] inputUpsertKey, String description)
StreamExecSort(int id, ExecNodeContext context, ReadableConfig persistedConfig, SortSpec sortSpec, List<InputProperty> inputProperties, RowType outputType, String description)
StreamExecSort(ReadableConfig tableConfig, SortSpec sortSpec, InputProperty inputProperty, RowType outputType, String description)
StreamExecSortLimit(int id, ExecNodeContext context, ReadableConfig persistedConfig, SortSpec sortSpec, ConstantRankRange rankRange, RankProcessStrategy rankStrategy, boolean generateUpdateBefore, List<StateMetadata> stateMetadataList, List<InputProperty> inputProperties, RowType outputType, String description)
StreamExecSortLimit(ReadableConfig tableConfig, SortSpec sortSpec, long limitStart, long limitEnd, RankProcessStrategy rankStrategy, boolean generateUpdateBefore, InputProperty inputProperty, RowType outputType, String description)
StreamExecTableSourceScan(int id, ExecNodeContext context, ReadableConfig persistedConfig, DynamicTableSourceSpec tableSourceSpec, RowType outputType, String description)
StreamExecTableSourceScan(ReadableConfig tableConfig, DynamicTableSourceSpec tableSourceSpec, RowType outputType, String description)
StreamExecTemporalJoin(int id, ExecNodeContext context, ReadableConfig persistedConfig, JoinSpec joinSpec, boolean isTemporalTableFunctionJoin, int leftTimeAttributeIndex, int rightTimeAttributeIndex, List<InputProperty> inputProperties, RowType outputType, String description)
StreamExecTemporalJoin(ReadableConfig tableConfig, JoinSpec joinSpec, boolean isTemporalTableFunctionJoin, int leftTimeAttributeIndex, int rightTimeAttributeIndex, InputProperty leftInputProperty, InputProperty rightInputProperty, RowType outputType, String description)
StreamExecTemporalSort(int id, ExecNodeContext context, ReadableConfig persistedConfig, SortSpec sortSpec, List<InputProperty> inputProperties, RowType outputType, String description)
StreamExecTemporalSort(ReadableConfig tableConfig, SortSpec sortSpec, InputProperty inputProperty, RowType outputType, String description)
StreamExecUnion(int id, ExecNodeContext context, ReadableConfig persistedConfig, List<InputProperty> inputProperties, RowType outputType, String description)
StreamExecUnion(ReadableConfig tableConfig, List<InputProperty> inputProperties, RowType outputType, String description)
StreamExecValues(int id, ExecNodeContext context, ReadableConfig persistedConfig, List<List<org.apache.calcite.rex.RexLiteral>> tuples, RowType outputType, String description)
StreamExecValues(ReadableConfig tableConfig, List<List<org.apache.calcite.rex.RexLiteral>> tuples, RowType outputType, String description)
StreamExecWatermarkAssigner(int id, ExecNodeContext context, ReadableConfig persistedConfig, org.apache.calcite.rex.RexNode watermarkExpr, int rowtimeFieldIndex, List<InputProperty> inputProperties, RowType outputType, String description)
StreamExecWatermarkAssigner(ReadableConfig tableConfig, org.apache.calcite.rex.RexNode watermarkExpr, int rowtimeFieldIndex, InputProperty inputProperty, RowType outputType, String description)
StreamExecWindowAggregate(int id, ExecNodeContext context, ReadableConfig persistedConfig, int[] grouping, org.apache.calcite.rel.core.AggregateCall[] aggCalls, WindowingStrategy windowing, NamedWindowProperty[] namedWindowProperties, Boolean needRetraction, List<InputProperty> inputProperties, RowType outputType, String description)
StreamExecWindowAggregate(ReadableConfig tableConfig, int[] grouping, org.apache.calcite.rel.core.AggregateCall[] aggCalls, WindowingStrategy windowing, NamedWindowProperty[] namedWindowProperties, Boolean needRetraction, InputProperty inputProperty, RowType outputType, String description)
StreamExecWindowAggregateBase(int id, ExecNodeContext context, ReadableConfig persistedConfig, List<InputProperty> inputProperties, LogicalType outputType, String description)
StreamExecWindowDeduplicate(int id, ExecNodeContext context, ReadableConfig persistedConfig, int[] partitionKeys, int orderKey, boolean keepLastRow, WindowingStrategy windowing, List<InputProperty> inputProperties, RowType outputType, String description)
StreamExecWindowDeduplicate(ReadableConfig tableConfig, int[] partitionKeys, int orderKey, boolean keepLastRow, WindowingStrategy windowing, InputProperty inputProperty, RowType outputType, String description)
StreamExecWindowJoin(int id, ExecNodeContext context, ReadableConfig persistedConfig, JoinSpec joinSpec, WindowingStrategy leftWindowing, WindowingStrategy rightWindowing, List<InputProperty> inputProperties, RowType outputType, String description)
StreamExecWindowJoin(ReadableConfig tableConfig, JoinSpec joinSpec, WindowingStrategy leftWindowing, WindowingStrategy rightWindowing, InputProperty leftInputProperty, InputProperty rightInputProperty, RowType outputType, String description)
StreamExecWindowRank(int id, ExecNodeContext context, ReadableConfig persistedConfig, RankType rankType, PartitionSpec partitionSpec, SortSpec sortSpec, RankRange rankRange, boolean outputRankNumber, WindowingStrategy windowing, List<InputProperty> inputProperties, RowType outputType, String description)
StreamExecWindowRank(ReadableConfig tableConfig, RankType rankType, PartitionSpec partitionSpec, SortSpec sortSpec, RankRange rankRange, boolean outputRankNumber, WindowingStrategy windowing, InputProperty inputProperty, RowType outputType, String description)
StreamExecWindowTableFunction(int id, ExecNodeContext context, ReadableConfig persistedConfig, TimeAttributeWindowingStrategy windowingStrategy, List<InputProperty> inputProperties, RowType outputType, String description)
StreamExecWindowTableFunction(ReadableConfig tableConfig, TimeAttributeWindowingStrategy windowingStrategy, InputProperty inputProperty, RowType outputType, String description)
-
Uses of ReadableConfig in org.apache.flink.table.planner.plan.nodes.exec.utils
Methods in org.apache.flink.table.planner.plan.nodes.exec.utils with parameters of type ReadableConfig Modifier and Type Method Description static Configuration
CommonPythonUtil. extractPythonConfiguration(ReadableConfig tableConfig, ClassLoader classLoader)
-
Uses of ReadableConfig in org.apache.flink.table.planner.plan.utils
Methods in org.apache.flink.table.planner.plan.utils that return ReadableConfig Modifier and Type Method Description static <T extends ExecNode<?>>
ReadableConfigExecNodeMetadataUtil. newPersistedConfig(Class<T> execNodeClass, ReadableConfig tableConfig, Stream<ConfigOption<?>> configOptions)
Methods in org.apache.flink.table.planner.plan.utils with parameters of type ReadableConfig Modifier and Type Method Description static CoBundleTrigger<RowData,RowData>
MinibatchUtil. createMiniBatchCoTrigger(ReadableConfig config)
Creates a MiniBatch trigger depends on the config for two input.static CountBundleTrigger<RowData>
MinibatchUtil. createMiniBatchTrigger(ReadableConfig config)
Creates a MiniBatch trigger depends on the config for one input.static boolean
MinibatchUtil. isMiniBatchEnabled(ReadableConfig config)
Check if MiniBatch is enabled.static long
MinibatchUtil. miniBatchSize(ReadableConfig config)
Returns the mini batch size for given config and mixed mode flag, considering fallback logic.static <T extends ExecNode<?>>
ReadableConfigExecNodeMetadataUtil. newPersistedConfig(Class<T> execNodeClass, ReadableConfig tableConfig, Stream<ConfigOption<?>> configOptions)
-
Uses of ReadableConfig in org.apache.flink.table.planner.utils
Methods in org.apache.flink.table.planner.utils that return ReadableConfig Modifier and Type Method Description ReadableConfig
DummyStreamExecutionEnvironment. getConfiguration()
Methods in org.apache.flink.table.planner.utils with parameters of type ReadableConfig Modifier and Type Method Description static AggregatePhaseStrategy
TableConfigUtils. getAggPhaseStrategy(ReadableConfig tableConfig)
Returns the aggregate phase strategy configuration.static StreamExchangeMode
StreamExchangeModeUtils. getBatchStreamExchangeMode(ReadableConfig config, StreamExchangeMode requiredExchangeMode)
static ZoneId
TableConfigUtils. getLocalTimeZone(ReadableConfig tableConfig)
Similar toTableConfig.getLocalTimeZone()
but extracting it from a genericReadableConfig
.static long
TableConfigUtils. getMaxIdleStateRetentionTime(ReadableConfig tableConfig)
Deprecated. -
Uses of ReadableConfig in org.apache.flink.table.resource
Methods in org.apache.flink.table.resource with parameters of type ReadableConfig Modifier and Type Method Description static ResourceManager
ResourceManager. createResourceManager(URL[] urls, ClassLoader parent, ReadableConfig config)
Constructors in org.apache.flink.table.resource with parameters of type ReadableConfig Constructor Description ResourceManager(ReadableConfig config, MutableURLClassLoader userClassLoader)
-
Uses of ReadableConfig in org.apache.flink.table.runtime.generated
Constructors in org.apache.flink.table.runtime.generated with parameters of type ReadableConfig Constructor Description GeneratedAggsHandleFunction(String className, String code, Object[] references, ReadableConfig conf)
GeneratedClass(String className, String code, Object[] references, ReadableConfig config)
GeneratedCollector(String className, String code, Object[] references, ReadableConfig conf)
Creates a GeneratedCollector.GeneratedFilterCondition(String className, String code, Object[] references, ReadableConfig conf)
Creates a GeneratedFilterCondition.GeneratedFunction(String className, String code, Object[] references, ReadableConfig conf)
Creates a GeneratedFunction.GeneratedHashFunction(String className, String code, Object[] references, ReadableConfig conf)
Creates a GeneratedHashFunction.GeneratedInput(String className, String code, Object[] references, ReadableConfig conf)
Creates a GeneratedInput.GeneratedJoinCondition(String className, String code, Object[] references, ReadableConfig conf)
Creates a GeneratedJoinCondition.GeneratedNamespaceAggsHandleFunction(String className, String code, Object[] references, ReadableConfig conf)
GeneratedNamespaceTableAggsHandleFunction(String className, String code, Object[] references, ReadableConfig conf)
GeneratedNormalizedKeyComputer(String className, String code, ReadableConfig config)
Creates a GeneratedNormalizedKeyComputer.GeneratedOperator(String className, String code, Object[] references, ReadableConfig conf)
Creates a GeneratedOperator.GeneratedProjection(String className, String code, Object[] references, ReadableConfig conf)
Creates a GeneratedProjection.GeneratedRecordComparator(String className, String code, Object[] references, ReadableConfig conf)
Creates a GeneratedRecordComparator.GeneratedRecordEqualiser(String className, String code, Object[] references, ReadableConfig conf)
Creates a GeneratedRecordEqualiser.GeneratedResultFuture(String className, String code, Object[] references, ReadableConfig conf)
Creates a GeneratedResultFuture.GeneratedTableAggsHandleFunction(String className, String code, Object[] references, ReadableConfig conf)
GeneratedWatermarkGenerator(String className, String code, Object[] references, ReadableConfig conf)
-
Uses of ReadableConfig in org.apache.flink.util
Methods in org.apache.flink.util with parameters of type ReadableConfig Modifier and Type Method Description static MutableURLClassLoader
FlinkUserCodeClassLoaders. create(URL[] urls, ClassLoader parent, ReadableConfig config)
static TernaryBoolean
TernaryBoolean. mergeTernaryBooleanWithConfig(TernaryBoolean original, ConfigOption<Boolean> configOption, ReadableConfig config)
Merges an existing value with a config, accepting the config's value only if the existing value is undefined.
-