Deprecated API
Contents
-
Interfaces Interface Description org.apache.flink.contrib.streaming.state.ConfigurableRocksDBOptionsFactory This class has been moved toConfigurableRocksDBOptionsFactory
. Please use the one under the new package instead.org.apache.flink.contrib.streaming.state.RocksDBOptionsFactory This class has been moved toRocksDBOptionsFactory
. Please use the one under the new package instead.org.apache.flink.legacy.table.connector.source.SourceFunctionProvider This interface is based on theSourceFunction
API, which is due to be removed. UseSourceProvider
instead.org.apache.flink.legacy.table.factories.StreamTableSinkFactory This interface has been replaced byDynamicTableSinkFactory
. The new interface creates instances ofDynamicTableSink
. See FLIP-95 for more information.org.apache.flink.legacy.table.factories.StreamTableSourceFactory This interface has been replaced byDynamicTableSourceFactory
. The new interface creates instances ofDynamicTableSource
. See FLIP-95 for more information.org.apache.flink.legacy.table.sinks.AppendStreamTableSink This interface has been replaced byDynamicTableSink
. The new interface consumes internal data structures. See FLIP-95 for more information.org.apache.flink.legacy.table.sinks.RetractStreamTableSink This interface has been replaced byDynamicTableSink
. The new interface consumes internal data structures. See FLIP-95 for more information.org.apache.flink.legacy.table.sinks.StreamTableSink This interface has been replaced byDynamicTableSink
. The new interface consumes internal data structures. See FLIP-95 for more information.org.apache.flink.legacy.table.sinks.UpsertStreamTableSink This interface has been replaced byDynamicTableSink
. The new interface consumes internal data structures. See FLIP-95 for more information.org.apache.flink.legacy.table.sources.StreamTableSource This interface has been replaced byDynamicTableSource
. The new interface produces internal data structures. See FLIP-95 for more information.org.apache.flink.streaming.api.checkpoint.ExternallyInducedSource This interface is based on theSourceFunction
API, which is due to be removed. Use the newSource
API instead.org.apache.flink.streaming.api.checkpoint.ListCheckpointed If you need to do non-keyed state snapshots of your operator, useCheckpointedFunction
. This should only be needed in rare cases, though.org.apache.flink.streaming.api.functions.sink.legacy.SinkFunction This interface will be removed in future versions. Use the newSink
interface instead.org.apache.flink.streaming.api.functions.source.legacy.ParallelSourceFunction This interface is based on theSourceFunction
API, which is due to be removed. Use the newSource
API instead.org.apache.flink.streaming.api.functions.source.legacy.SourceFunction This interface will be removed in future versions. Use the newSource
interface instead. NOTE: All sub-tasks from FLINK-28045 must be closed before this API can be completely removed.org.apache.flink.streaming.api.operators.legacy.YieldingOperatorFactory org.apache.flink.table.catalog.CatalogLock This interface will be removed soon. Please see FLIP-346 for more details.org.apache.flink.table.catalog.CatalogLock.Factory This interface will be removed soon. Please see FLIP-346 for more details.org.apache.flink.table.connector.RequireCatalogLock This interface will be removed soon. Please see FLIP-346 for more details.org.apache.flink.table.connector.sink.legacy.SinkFunctionProvider This interface is based on theSinkFunction
API, which is due to be removed. UseSinkV2Provider
instead.org.apache.flink.table.descriptors.DescriptorValidator SeeDescriptor
for details.org.apache.flink.table.factories.ManagedTableFactory This interface will be removed soon. Please see FLIP-346 for more details.org.apache.flink.table.legacy.api.constraints.Constraint SeeResolvedSchema
andConstraint
.org.apache.flink.table.legacy.connector.source.AsyncTableFunctionProvider Please useAsyncLookupFunctionProvider
to implement asynchronous lookup table.org.apache.flink.table.legacy.connector.source.TableFunctionProvider Please useLookupFunctionProvider
to implement synchronous lookup table.org.apache.flink.table.legacy.descriptors.Descriptor Descriptor
was primarily used for the legacy connector stack and have been deprecated. UseTableDescriptor
for creating sources and sinks from the Table API.org.apache.flink.table.legacy.factories.TableFactory This interface has been replaced byFactory
.org.apache.flink.table.legacy.factories.TableSinkFactory This interface has been replaced byDynamicTableSinkFactory
. The new interface consumes internal data structures. See FLIP-95 for more information.org.apache.flink.table.legacy.factories.TableSourceFactory This interface has been replaced byDynamicTableSourceFactory
. The new interface produces internal data structures. See FLIP-95 for more information.org.apache.flink.table.legacy.sinks.OverwritableTableSink This interface will not be supported in the new sink design aroundDynamicTableSink
. UseSupportsOverwrite
instead. See FLIP-95 for more information.org.apache.flink.table.legacy.sinks.PartitionableTableSink This interface will not be supported in the new sink design aroundDynamicTableSink
. UseSupportsPartitioning
instead. See FLIP-95 for more information.org.apache.flink.table.legacy.sinks.TableSink This interface has been replaced byDynamicTableSink
. The new interface consumes internal data structures. See FLIP-95 for more information.org.apache.flink.table.legacy.sources.DefinedFieldMapping This interface will not be supported in the new source design aroundDynamicTableSource
. See FLIP-95 for more information.org.apache.flink.table.legacy.sources.DefinedProctimeAttribute This interface will not be supported in the new source design aroundDynamicTableSource
. Use the concept of computed columns instead. See FLIP-95 for more information.org.apache.flink.table.legacy.sources.DefinedRowtimeAttributes This interface will not be supported in the new source design aroundDynamicTableSource
. Use the concept of computed columns instead. See FLIP-95 for more information.org.apache.flink.table.legacy.sources.FieldComputer This interface will not be supported in the new source design aroundDynamicTableSource
. Use the concept of computed columns instead. See FLIP-95 for more information.org.apache.flink.table.legacy.sources.FilterableTableSource This interface will not be supported in the new source design aroundDynamicTableSource
. UseSupportsFilterPushDown
instead. See FLIP-95 for more information.org.apache.flink.table.legacy.sources.LimitableTableSource This interface will not be supported in the new source design aroundDynamicTableSource
. UseSupportsLimitPushDown
instead. See FLIP-95 for more information.org.apache.flink.table.legacy.sources.LookupableTableSource This interface will not be supported in the new source design aroundDynamicTableSource
. UseLookupTableSource
instead. See FLIP-95 for more information.org.apache.flink.table.legacy.sources.NestedFieldsProjectableTableSource This interface will not be supported in the new source design aroundDynamicTableSource
. UseSupportsProjectionPushDown
instead. See FLIP-95 for more information.org.apache.flink.table.legacy.sources.PartitionableTableSource This interface will not be supported in the new source design aroundDynamicTableSource
. UseSupportsPartitionPushDown
instead. See FLIP-95 for more information.org.apache.flink.table.legacy.sources.ProjectableTableSource This interface will not be supported in the new source design aroundDynamicTableSource
. UseSupportsProjectionPushDown
instead. See FLIP-95 for more information.org.apache.flink.table.legacy.sources.TableSource This interface has been replaced byDynamicTableSource
. The new interface produces internal data structures. See FLIP-95 for more information.org.apache.flink.table.runtime.groupwindow.WindowProperty The POJOs in this package are used to represent the deprecated Group Window feature. Currently, they also used to configure Python operators.org.apache.flink.types.Key The Key type is a relict of a deprecated and removed API and will be removed in future (2.0) versions as well.
-
Classes Class Description org.apache.calcite.rex.RexUtil.ExprSimplifier org.apache.flink.client.deployment.executors.AbstractJobClusterExecutor org.apache.flink.configuration.QueryableStateOptions The Queryable State feature is deprecated since Flink 1.18, and will be removed in a future Flink major version.org.apache.flink.contrib.streaming.state.EmbeddedRocksDBStateBackend This class has been moved toEmbeddedRocksDBStateBackend
. Please use the one under the new package instead.org.apache.flink.contrib.streaming.state.EmbeddedRocksDBStateBackendFactory This class has been moved toEmbeddedRocksDBStateBackendFactory
. Please use the one under the new package instead.org.apache.flink.contrib.streaming.state.RocksDBConfigurableOptions This class has been moved toRocksDBConfigurableOptions
. Please use the one under the new package instead.org.apache.flink.contrib.streaming.state.RocksDBNativeMetricOptions This class has been moved toRocksDBNativeMetricOptions
. Please use the one under the new package instead.org.apache.flink.contrib.streaming.state.RocksDBOptions This class has been moved toRocksDBNativeMetricOptions
. Please use the one under the new package instead.org.apache.flink.core.testutils.FlinkMatchers You should assertj assertions, which have built-in assertions forCompletableFuture
. To check chains ofThrowable
causes, useFlinkAssertions.anyCauseMatches(String)
orFlinkAssertions.anyCauseMatches(Class, String)
org.apache.flink.legacy.table.descriptors.RowtimeValidator SeeRowtime
for details.org.apache.flink.legacy.table.descriptors.SchemaValidator SeeSchema
for details.org.apache.flink.legacy.table.sinks.OutputFormatTableSink This interface has been replaced byDynamicTableSink
. The new interface consumes internal data structures. See FLIP-95 for more information.org.apache.flink.legacy.table.sources.InputFormatTableSource This interface has been replaced byDynamicTableSource
. The new interface produces internal data structures. See FLIP-95 for more information.org.apache.flink.queryablestate.client.QueryableStateClient The Queryable State feature is deprecated since Flink 1.18, and will be removed in a future Flink major version.org.apache.flink.runtime.checkpoint.SubtaskState Internal class for savepoint backwards compatibility. Don't use for other purposes.org.apache.flink.runtime.checkpoint.TaskState Internal class for savepoint backwards compatibility. Don't use for other purposes.org.apache.flink.runtime.entrypoint.JobClusterEntrypoint Per-job mode has been deprecated in Flink 1.15 and will be removed in the future. Please use application mode instead.org.apache.flink.runtime.rest.handler.job.metrics.JobVertexMetricsHandler This class is subsumed bySubtaskMetricsHandler
and is only kept for backwards-compatibility.org.apache.flink.runtime.rest.messages.YarnCancelJobTerminationHeaders This should be removed once we can send arbitrary REST calls via the Yarn proxy.org.apache.flink.runtime.rest.messages.YarnStopJobTerminationHeaders This should be removed once we can send arbitrary REST calls via the Yarn proxy.org.apache.flink.runtime.state.filesystem.AbstractFileStateBackend State backends should no longer implementCheckpointStorage
functionality. Please inheritAbstractStateBackend
instead. Custom checkpoint storage can be additionally implemented as a separate class.org.apache.flink.streaming.api.datastream.QueryableStateStream The Queryable State feature is deprecated since Flink 1.18, and will be removed in a future Flink major version.org.apache.flink.streaming.api.functions.sink.filesystem.legacy.StreamingFileSink UseFileSink
instead.org.apache.flink.streaming.api.functions.sink.legacy.DiscardingSink This interface will be removed in future versions. Use the newDiscardingSink
interface instead.org.apache.flink.streaming.api.functions.sink.legacy.OutputFormatSinkFunction Please use theStreamingFileSink
for writing to files from a streaming program.org.apache.flink.streaming.api.functions.sink.legacy.PrintSinkFunction This interface will be removed in future versions. Use the newPrintSink
interface instead.org.apache.flink.streaming.api.functions.sink.legacy.RichSinkFunction This interface will be removed in future versions. Use the newSink
interface instead.org.apache.flink.streaming.api.functions.sink.legacy.SocketClientSink This interface will be removed in future versions. Use the newSink
interface instead.org.apache.flink.streaming.api.functions.sink.legacy.TwoPhaseCommitSinkFunction This interface will be removed in future versions. Use the newSink
interface instead.org.apache.flink.streaming.api.functions.source.datagen.DataGeneratorSource Useorg.apache.flink.connector.datagen.source.DataGeneratorSource
instead.org.apache.flink.streaming.api.functions.source.legacy.ContinuousFileMonitoringFunction This class is based on theSourceFunction
API, which is due to be removed. Use the newSource
API instead.org.apache.flink.streaming.api.functions.source.legacy.FileMonitoringFunction Internal class deprecated in favour ofContinuousFileMonitoringFunction
.org.apache.flink.streaming.api.functions.source.legacy.FileReadFunction Internal class deprecated in favour ofContinuousFileMonitoringFunction
.org.apache.flink.streaming.api.functions.source.legacy.FromElementsFunction This class is based on theSourceFunction
API, which is due to be removed. Use the newSource
API instead.org.apache.flink.streaming.api.functions.source.legacy.FromIteratorFunction This class is based on theSourceFunction
API, which is due to be removed. Use the newSource
API instead.org.apache.flink.streaming.api.functions.source.legacy.FromSplittableIteratorFunction This class is based on theSourceFunction
API, which is due to be removed. Use the newSource
API instead.org.apache.flink.streaming.api.functions.source.legacy.InputFormatSourceFunction This class is based on theSourceFunction
API, which is due to be removed. Use the newSource
API instead.org.apache.flink.streaming.api.functions.source.legacy.RichParallelSourceFunction This class is based on theSourceFunction
API, which is due to be removed. Use the newSource
API instead.org.apache.flink.streaming.api.functions.source.legacy.RichSourceFunction This class is based on theSourceFunction
API, which is due to be removed. Use the newSource
API instead.org.apache.flink.streaming.api.functions.source.legacy.SocketTextStreamFunction This class is based on theSourceFunction
API, which is due to be removed. Use the newSource
API instead.org.apache.flink.streaming.api.functions.source.legacy.StatefulSequenceSource This class is based on theSourceFunction
API, which is due to be removed. Use the newSource
API instead.org.apache.flink.streaming.api.functions.timestamps.AscendingTimestampExtractor org.apache.flink.streaming.api.legacy.io.TextInputFormat If you want to read/write data from/to text file, please use FLIP-27 FileSource and Sink-V2 FlinkSink. This class should be removed if we drop the supports for read/write via input/output format in DataStream api.org.apache.flink.streaming.api.legacy.io.TextOutputFormat If you want to read/write data from/to text file, please use FLIP-27 FileSource and Sink-V2 FlinkSink. This class should be removed if we drop all supports forInputFormat
andOutputFormat
org.apache.flink.streaming.api.operators.co.LegacyKeyedCoProcessOperator Replaced byKeyedCoProcessOperator
which takesKeyedCoProcessFunction
org.apache.flink.streaming.api.operators.LegacyKeyedProcessOperator Replaced byKeyedProcessOperator
which takesKeyedProcessFunction
org.apache.flink.streaming.api.operators.StreamSource This class is based on theSourceFunction
API, which is due to be removed. Use the newSource
API instead.org.apache.flink.streaming.api.operators.StreamSourceContexts This class is based on theSourceFunction
API, which is due to be removed. Use the newSource
API instead.org.apache.flink.streaming.runtime.tasks.SourceStreamTask This class is based on theSourceFunction
API, which is due to be removed. Use the newSource
API instead.org.apache.flink.streaming.runtime.tasks.StreamTaskActionExecutor.SynchronizedStreamTaskActionExecutor this class should only be used inSourceStreamTask
which exposes the checkpoint lock as part of Public API.org.apache.flink.streaming.tests.SequenceGeneratorSource This class is based on theSourceFunction
API, which is due to be removed. Use the newSource
API instead.org.apache.flink.table.catalog.CatalogTableImpl UseCatalogTable.of(Schema, String, List, Map)
or a custom implementation instead. Don't implement against this internal class. It can lead to unintended side effects if code checks against this class instead of the common interface.org.apache.flink.table.catalog.CatalogViewImpl UseCatalogView.of(Schema, String, String, String, Map)
or a custom implementation instead. Don't implement against this internal class. It can lead to unintended side effects if code checks against this class instead of the common interface.org.apache.flink.table.catalog.ManagedTableListener This interface will be removed soon. Please see FLIP-346 for more details.org.apache.flink.table.dataview.ListViewSerializer org.apache.flink.table.dataview.ListViewSerializerSnapshot org.apache.flink.table.dataview.ListViewTypeInfo org.apache.flink.table.dataview.ListViewTypeInfoFactory org.apache.flink.table.dataview.MapViewSerializer org.apache.flink.table.dataview.MapViewSerializerSnapshot org.apache.flink.table.dataview.MapViewTypeInfo org.apache.flink.table.dataview.MapViewTypeInfoFactory org.apache.flink.table.dataview.NullAwareMapSerializer org.apache.flink.table.dataview.NullAwareMapSerializerSnapshot org.apache.flink.table.descriptors.ConnectorDescriptorValidator org.apache.flink.table.descriptors.DescriptorProperties This utility will be dropped soon.DynamicTableFactory
is based onConfigOption
and catalogs useCatalogPropertiesUtil
.org.apache.flink.table.descriptors.FileSystemValidator The legacy CSV connector has been replaced byFileSource
/FileSink
. It is kept only to support tests for the legacy connector stack.org.apache.flink.table.descriptors.OldCsvValidator Use the RFC-compliantCsv
format in the dedicated flink-formats/flink-csv module instead.org.apache.flink.table.factories.TableFactoryService org.apache.flink.table.factories.TableSinkFactoryContextImpl org.apache.flink.table.factories.TableSourceFactoryContextImpl org.apache.flink.table.functions.AggregateFunctionDefinition Non-legacy functions can simply omit this wrapper for declarations.org.apache.flink.table.functions.LegacyUserDefinedFunctionInference org.apache.flink.table.functions.ScalarFunctionDefinition Non-legacy functions can simply omit this wrapper for declarations.org.apache.flink.table.functions.TableAggregateFunctionDefinition Non-legacy functions can simply omit this wrapper for declarations.org.apache.flink.table.functions.TableFunctionDefinition Non-legacy functions can simply omit this wrapper for declarations.org.apache.flink.table.legacy.api.constraints.UniqueConstraint SeeResolvedSchema
andUniqueConstraint
.org.apache.flink.table.legacy.api.TableColumn SeeResolvedSchema
andColumn
.org.apache.flink.table.legacy.api.TableSchema This class has been deprecated as part of FLIP-164. It has been replaced by two more dedicated classesSchema
andResolvedSchema
. UseSchema
for declaration in APIs.ResolvedSchema
is offered by the framework after resolution and validation.org.apache.flink.table.legacy.api.Types This class will be removed in future versions as it uses the old type system. It is recommended to useDataTypes
instead which uses the new type system based on instances ofDataType
. Please make sure to use either the old or the new type system consistently to avoid unintended behavior. See the website documentation for more information.org.apache.flink.table.legacy.api.WatermarkSpec SeeResolvedSchema
andWatermarkSpec
.org.apache.flink.table.legacy.descriptors.Rowtime This class was used for legacy connectors usingDescriptor
.org.apache.flink.table.legacy.descriptors.Schema This class was used for legacy connectors usingDescriptor
.org.apache.flink.table.legacy.operations.ddl.AlterTableOptionsOperation Please useAlterTableChangeOperation
instead.org.apache.flink.table.legacy.sources.RowtimeAttributeDescriptor This interface will not be supported in the new source design aroundDynamicTableSource
. Use the concept of computed columns instead. See FLIP-95 for more information.org.apache.flink.table.legacy.sources.tsextractors.ExistingField This class will not be supported in the new source design aroundDynamicTableSource
. See FLIP-95 for more information.org.apache.flink.table.legacy.sources.tsextractors.StreamRecordTimestamp This class will not be supported in the new source design aroundDynamicTableSource
. See FLIP-95 for more information.org.apache.flink.table.legacy.sources.tsextractors.TimestampExtractor This interface will not be supported in the new source design aroundDynamicTableSource
. Use the concept of computed columns instead. See FLIP-95 for more information.org.apache.flink.table.legacy.types.logical.TypeInformationRawType UseRawType
instead.org.apache.flink.table.legacy.utils.TypeStringUtils This utility is based onTypeInformation
. However, the Table & SQL API is currently updated to useDataType
s based onLogicalType
s. UseLogicalTypeParser
instead.org.apache.flink.table.operations.DataStreamQueryOperation org.apache.flink.table.planner.operations.InternalDataStreamQueryOperation org.apache.flink.table.runtime.arrow.sources.ArrowSourceFunction This class is based on theSourceFunction
API, which is due to be removed. Use the newSource
API instead.org.apache.flink.table.runtime.groupwindow.AbstractWindowProperty The POJOs in this package are used to represent the deprecated Group Window feature. Currently, they also used to configure Python operators.org.apache.flink.table.runtime.groupwindow.NamedWindowProperty The POJOs in this package are used to represent the deprecated Group Window feature. Currently, they also used to configure Python operators.org.apache.flink.table.runtime.groupwindow.ProctimeAttribute The POJOs in this package are used to represent the deprecated Group Window feature. Currently, they also used to configure Python operators.org.apache.flink.table.runtime.groupwindow.RowtimeAttribute The POJOs in this package are used to represent the deprecated Group Window feature. Currently, they also used to configure Python operators.org.apache.flink.table.runtime.groupwindow.SliceEnd The POJOs in this package are used to represent the deprecated Group Window feature. Currently, they also used to configure Python operators.org.apache.flink.table.runtime.groupwindow.WindowEnd The POJOs in this package are used to represent the deprecated Group Window feature. Currently, they also used to configure Python operators.org.apache.flink.table.runtime.groupwindow.WindowReference The POJOs in this package are used to represent the deprecated Group Window feature. Currently, they are also used to configure Python operators.org.apache.flink.table.runtime.groupwindow.WindowStart The POJOs in this package are used to represent the deprecated Group Window feature. Currently, they also used to configure Python operators.org.apache.flink.table.runtime.types.LogicalTypeDataTypeConverter org.apache.flink.table.runtime.types.TypeInfoDataTypeConverter UseInternalTypeInfo.of(LogicalType)
instead ifTypeInformation
is really required. In many cases,InternalSerializers.create(LogicalType)
should be sufficient.org.apache.flink.table.runtime.types.TypeInfoLogicalTypeConverter org.apache.flink.table.sinks.CsvAppendTableSinkFactory The legacy CSV connector has been replaced byFileSink
. It is kept only to support tests for the legacy connector stack.org.apache.flink.table.sinks.CsvBatchTableSinkFactory The legacy CSV connector has been replaced byFileSink
. It is kept only to support tests for the legacy connector stack.org.apache.flink.table.sinks.CsvTableSink The legacy CSV connector has been replaced byFileSink
. It is kept only to support tests for the legacy connector stack.org.apache.flink.table.sinks.CsvTableSinkFactoryBase The legacy CSV connector has been replaced byFileSink
. It is kept only to support tests for the legacy connector stack.org.apache.flink.table.sinks.TableSinkBase This class is implementing the deprecatedTableSink
interface. ImplementDynamicTableSink
directly instead.org.apache.flink.table.sources.CsvAppendTableSourceFactory The legacy CSV connector has been replaced byFileSource
. It is kept only to support tests for the legacy connector stack.org.apache.flink.table.sources.CsvBatchTableSourceFactory The legacy CSV connector has been replaced byFileSource
. It is kept only to support tests for the legacy connector stack.org.apache.flink.table.sources.CsvTableSource The legacy CSV connector has been replaced byFileSource
. It is kept only to support tests for the legacy connector stack.org.apache.flink.table.sources.CsvTableSourceFactoryBase The legacy CSV connector has been replaced byFileSource
. It is kept only to support tests for the legacy connector stack.org.apache.flink.table.sources.format.CsvInputFormat org.apache.flink.table.sources.format.RowCsvInputFormat All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a future Flink major version. You can still build your application in DataSet, but you should move to either the DataStream and/or Table API.org.apache.flink.table.types.utils.LegacyTypeInfoDataTypeConverter UseDataTypeFactory.createDataType(TypeInformation)
instead. Note that this method will not create legacy types anymore. It fully uses the new type system available only in the planner.org.apache.flink.table.typeutils.TimeIndicatorTypeInfo This class will be removed in future versions as it is used for the old type system. It is recommended to useDataTypes
instead. Please make sure to use either the old or the new type system consistently to avoid unintended behavior. See the website documentation for more information.org.apache.flink.table.typeutils.TimeIntervalTypeInfo This class will be removed in future versions as it is used for the old type system. It is recommended to useDataTypes
instead. Please make sure to use either the old or the new type system consistently to avoid unintended behavior. See the website documentation for more information.org.apache.flink.test.util.AbstractTestBaseJUnit4 UseAbstractTestBase
instead.org.apache.flink.test.util.JavaProgramTestBaseJUnit4 UseJavaProgramTestBase
instead.org.apache.flink.test.util.MultipleProgramsTestBaseJUnit4 UseMultipleProgramsTestBase
instead.org.apache.flink.walkthrough.common.sink.AlertSink org.apache.flink.walkthrough.common.source.TransactionSource This class is based on theSourceFunction
API, which is due to be removed. Use the newSource
API instead.org.apache.flink.yarn.entrypoint.YarnJobClusterEntrypoint Per-mode has been deprecated in Flink 1.15 and will be removed in the future. Please use application mode instead.org.apache.flink.yarn.executors.YarnJobClusterExecutor org.apache.flink.yarn.executors.YarnJobClusterExecutorFactory
-
Enums Enum Description org.apache.flink.streaming.api.CheckpointingMode This class has been moved toCheckpointingMode
.org.apache.flink.table.api.config.ExecutionConfigOptions.LegacyCastBehaviour
-
Exceptions Exceptions Description org.apache.flink.table.api.AmbiguousTableFactoryException This exception is considered internal and has been erroneously placed in the *.api package. It is replaced byAmbiguousTableFactoryException
and should not be used directly anymore.org.apache.flink.table.api.ExpressionParserException This exception is considered internal and has been erroneously placed in the *.api package. It is replaced byExpressionParserException
and should not be used directly anymore.org.apache.flink.table.api.NoMatchingTableFactoryException This exception is considered internal and has been erroneously placed in the *.api package. It is replaced byNoMatchingTableFactoryException
and should not be used directly anymore.
-
Enum Constants Enum Constant Description org.apache.flink.api.common.state.StateDescriptor.Type.UNKNOWN Enum for migrating from old checkpoints/savepoint versions.org.apache.flink.core.execution.RecoveryClaimMode.LEGACY org.apache.flink.runtime.rest.messages.TerminationModeQueryParameter.TerminationMode.STOP Please use the "stop" command instead.org.apache.flink.yarn.configuration.YarnDeploymentTarget.PER_JOB