Interface and Description |
---|
org.apache.flink.table.sinks.AppendStreamTableSink
This interface has been replaced by
DynamicTableSink . The new interface
consumes internal data structures and only works with the Blink planner. See FLIP-95 for more
information. |
org.apache.flink.streaming.api.functions.AssignerWithPeriodicWatermarks |
org.apache.flink.streaming.api.functions.AssignerWithPunctuatedWatermarks |
org.apache.flink.table.api.bridge.java.BatchTableEnvironment
BatchTableEnvironment will be dropped in Flink 1.14 because it only supports
the old planner. Use the unified TableEnvironment instead, which supports both batch
and streaming. More advanced operations previously covered by the DataSet API can now use the
DataStream API in BATCH execution mode. |
org.apache.flink.table.sinks.BatchTableSink
use
OutputFormatTableSink instead. |
org.apache.flink.table.factories.BatchTableSinkFactory
This interface has been replaced by
DynamicTableSinkFactory . The new
interface creates instances of DynamicTableSink and only works with the Blink
planner. See FLIP-95 for more information. |
org.apache.flink.table.sources.BatchTableSource
use
InputFormatTableSource instead. |
org.apache.flink.table.factories.BatchTableSourceFactory
This interface has been replaced by
DynamicTableSourceFactory . The new
interface creates instances of DynamicTableSource and only works with the Blink
planner. See FLIP-95 for more information. |
org.apache.flink.runtime.state.CheckpointListener
This interface has been moved to
CheckpointListener . This class is kept to maintain
backwards compatibility and will be removed in future releases. |
org.apache.flink.table.api.constraints.Constraint
See
ResolvedSchema and Constraint . |
org.apache.flink.table.sources.DefinedFieldMapping
This interface will not be supported in the new source design around
DynamicTableSource which only works with the Blink planner. See FLIP-95 for more
information. |
org.apache.flink.table.sources.DefinedProctimeAttribute
This interface will not be supported in the new source design around
DynamicTableSource which only works with the Blink planner. Use the concept of computed
columns instead. See FLIP-95 for more information. |
org.apache.flink.table.sources.DefinedRowtimeAttributes
This interface will not be supported in the new source design around
DynamicTableSource which only works with the Blink planner. Use the concept of computed
columns instead. See FLIP-95 for more information. |
org.apache.flink.streaming.util.serialization.DeserializationSchema
Use
DeserializationSchema instead. |
org.apache.flink.table.sources.FieldComputer
This interface will not be supported in the new source design around
DynamicTableSource which only works with the Blink planner. Use the concept of computed
columns instead. See FLIP-95 for more information. |
org.apache.flink.table.factories.FileSystemFormatFactory
This interface has been replaced by
BulkReaderFormatFactory and BulkWriterFormatFactory . |
org.apache.flink.table.sources.FilterableTableSource
This interface will not be supported in the new source design around
DynamicTableSource which only works with the Blink planner. Use SupportsFilterPushDown instead. See FLIP-95 for more information. |
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.
|
org.apache.flink.streaming.util.serialization.KeyedDeserializationSchema |
org.apache.flink.streaming.util.serialization.KeyedSerializationSchema |
org.apache.flink.table.sources.LimitableTableSource
This interface will not be supported in the new source design around
DynamicTableSource which only works with the Blink planner. Use SupportsLimitPushDown instead. See FLIP-95 for more information. |
org.apache.flink.streaming.api.checkpoint.ListCheckpointed
If you need to do non-keyed state snapshots of your operator, use
CheckpointedFunction . This should only be needed in rare cases, though. |
org.apache.flink.table.sources.LookupableTableSource
This interface will not be supported in the new source design around
DynamicTableSource which only works with the Blink planner. Use LookupTableSource
instead. See FLIP-95 for more information. |
org.apache.flink.mesos.util.MesosArtifactResolver
Apache Mesos support was deprecated in Flink 1.13 and is subject to removal in the
future (see FLINK-22352 for further details).
|
org.apache.flink.mesos.util.MesosArtifactServer
Apache Mesos support was deprecated in Flink 1.13 and is subject to removal in the
future (see FLINK-22352 for further details).
|
org.apache.flink.mesos.runtime.clusterframework.MesosResourceManagerActions
Apache Mesos support was deprecated in Flink 1.13 and is subject to removal in the
future (see FLINK-22352 for further details).
|
org.apache.flink.mesos.runtime.clusterframework.MesosResourceManagerActorFactory
Apache Mesos support was deprecated in Flink 1.13 and is subject to removal in the
future (see FLINK-22352 for further details).
|
org.apache.flink.mesos.runtime.clusterframework.services.MesosServices
Apache Mesos support was deprecated in Flink 1.13 and is subject to removal in the
future (see FLINK-22352 for further details).
|
org.apache.flink.mesos.runtime.clusterframework.store.MesosWorkerStore
Apache Mesos support was deprecated in Flink 1.13 and is subject to removal in the
future (see FLINK-22352 for further details).
|
org.apache.flink.table.sources.NestedFieldsProjectableTableSource
This interface will not be supported in the new source design around
DynamicTableSource which only works with the Blink planner. Use SupportsProjectionPushDown instead. See FLIP-95 for more information. |
org.apache.flink.table.sinks.OverwritableTableSink
This interface will not be supported in the new sink design around
DynamicTableSink which only works with the Blink planner. Use SupportsOverwrite
instead. See FLIP-95 for more information. |
org.apache.flink.table.sinks.PartitionableTableSink
This interface will not be supported in the new sink design around
DynamicTableSink which only works with the Blink planner. Use SupportsPartitioning
instead. See FLIP-95 for more information. |
org.apache.flink.table.sources.PartitionableTableSource
This interface will not be supported in the new source design around
DynamicTableSource which only works with the Blink planner. Use SupportsPartitionPushDown instead. See FLIP-95 for more information. |
org.apache.flink.table.sources.ProjectableTableSource
This interface will not be supported in the new source design around
DynamicTableSource which only works with the Blink planner. Use SupportsProjectionPushDown instead. See FLIP-95 for more information. |
org.apache.flink.table.sinks.RetractStreamTableSink
This interface has been replaced by
DynamicTableSink . The new interface
consumes internal data structures and only works with the Blink planner. See FLIP-95 for more
information. |
org.apache.flink.streaming.util.serialization.SerializationSchema
Use
SerializationSchema instead. |
org.apache.flink.streaming.api.operators.SetupableStreamOperator
This class is deprecated in favour of using
StreamOperatorFactory and it's
StreamOperatorFactory.createStreamOperator(org.apache.flink.streaming.api.operators.StreamOperatorParameters<OUT>) and passing the required parameters to the
Operator's constructor in create method. |
org.apache.flink.table.sinks.StreamTableSink
This interface has been replaced by
DynamicTableSink . The new interface
consumes internal data structures and only works with the Blink planner. See FLIP-95 for more
information. |
org.apache.flink.table.factories.StreamTableSinkFactory
This interface has been replaced by
DynamicTableSinkFactory . The new
interface creates instances of DynamicTableSink and only works with the Blink
planner. See FLIP-95 for more information. |
org.apache.flink.table.sources.StreamTableSource
This interface has been replaced by
DynamicTableSource . The new interface
produces internal data structures and only works with the Blink planner. See FLIP-95 for more
information. |
org.apache.flink.table.factories.StreamTableSourceFactory
This interface has been replaced by
DynamicTableSourceFactory . The new
interface creates instances of DynamicTableSource and only works with the Blink
planner. See FLIP-95 for more information. |
org.apache.flink.table.sinks.TableSink
This interface has been replaced by
DynamicTableSink . The new interface
consumes internal data structures and only works with the Blink planner. See FLIP-95 for more
information. |
org.apache.flink.table.sources.TableSource
This interface has been replaced by
DynamicTableSource . The new interface
produces internal data structures and only works with the Blink planner. See FLIP-95 for more
information. |
org.apache.flink.streaming.api.functions.TimestampAssigner |
org.apache.flink.table.sinks.UpsertStreamTableSink
This interface has been replaced by
DynamicTableSink . The new interface
consumes internal data structures and only works with the Blink planner. See FLIP-95 for more
information. |
Class and Description |
---|
org.apache.flink.streaming.util.serialization.AbstractDeserializationSchema
Use
AbstractDeserializationSchema
instead. |
org.apache.flink.runtime.state.filesystem.AbstractFileStateBackend
State backends should no longer implement
CheckpointStorage functionality.
Please inherit AbstractStateBackend instead. Custom checkpoint storage can be
additionally implemented as a separate class. |
org.apache.flink.mesos.runtime.clusterframework.services.AbstractMesosServices
Apache Mesos support was deprecated in Flink 1.13 and is subject to removal in the
future (see FLINK-22352 for further details).
|
org.apache.flink.cep.pattern.conditions.AndCondition
Please use
RichAndCondition instead. This class exists just for backwards
compatibility and will be removed in FLINK-10113. |
org.apache.flink.streaming.api.functions.AscendingTimestampExtractor
Extend
AscendingTimestampExtractor instead. |
org.apache.flink.streaming.api.functions.timestamps.AscendingTimestampExtractor |
org.apache.flink.formats.avro.typeutils.AvroSerializer.AvroSchemaSerializerConfigSnapshot |
org.apache.flink.streaming.api.windowing.assigners.BaseAlignedWindowAssigner
will be removed in a future version. please use other
WindowAssigner s listed
under org.apache.flink.streaming.api.windowing.assigners . |
org.apache.flink.batch.connectors.cassandra.CassandraOutputFormat
Please use CassandraTupleOutputFormat instead.
|
org.apache.flink.table.client.config.entries.CatalogEntry
This will be removed in Flink 1.14 with dropping support of
sql-client.yaml
configuration file. |
org.apache.flink.table.catalog.CatalogTableImpl
Use
CatalogTable.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
Use
CatalogView.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.streaming.api.datastream.CoGroupedStreams.UnionSerializerConfigSnapshot
this snapshot class is no longer in use, and is maintained only for backwards
compatibility. It is fully replaced by
CoGroupedStreams.UnionSerializerSnapshot . |
org.apache.flink.api.common.typeutils.base.CollectionSerializerConfigSnapshot
this snapshot class should no longer be used by any serializers as their snapshot.
|
org.apache.flink.api.common.typeutils.CompositeSerializer.ConfigSnapshot
this snapshot class is no longer in use by any serializers, and is only kept
around for backwards compatibility. All subclass serializers should have their own
serializer snapshot classes.
|
org.apache.flink.table.client.config.entries.ConfigurationEntry
This will be removed in Flink 1.14 with dropping support of
sql-client.yaml
configuration file. |
org.apache.flink.table.client.config.ConfigUtil
This will be removed in Flink 1.14 with dropping support of
sql-client.yaml
configuration file. |
org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer.CopyableValueSerializerConfigSnapshot |
org.apache.flink.table.client.config.entries.DeploymentEntry
This will be removed in Flink 1.14 with dropping support of
sql-client.yaml
configuration file. |
org.apache.flink.table.descriptors.DescriptorProperties
This utility will be dropped soon.
DynamicTableFactory is based on ConfigOption and catalogs use CatalogPropertiesUtil . |
org.apache.flink.api.java.typeutils.runtime.EitherSerializerConfigSnapshot |
org.apache.flink.api.java.typeutils.runtime.EitherSerializerSnapshot
this snapshot class is no longer used by any serializers. Instead,
JavaEitherSerializerSnapshot is used. |
org.apache.flink.api.common.typeutils.base.EnumSerializer.EnumSerializerConfigSnapshot |
org.apache.flink.table.client.config.Environment
This will be removed in Flink 1.14 with dropping support of
sql-client.yaml
configuration file. |
org.apache.flink.table.client.config.entries.ExecutionEntry
This will be removed in Flink 1.14 with dropping support of
sql-client.yaml
configuration file. |
org.apache.flink.streaming.api.functions.source.FileMonitoringFunction
Internal class deprecated in favour of
ContinuousFileMonitoringFunction . |
org.apache.flink.streaming.api.functions.source.FileReadFunction
Internal class deprecated in favour of
ContinuousFileMonitoringFunction . |
org.apache.flink.runtime.state.filesystem.FsStateBackend |
org.apache.flink.table.client.config.entries.FunctionEntry
This will be removed in Flink 1.14 with dropping support of
sql-client.yaml
configuration file. |
org.apache.flink.api.common.typeutils.base.GenericArraySerializerConfigSnapshot
this is deprecated and no longer used by the
GenericArraySerializer . It has
been replaced by GenericArraySerializerSnapshot . |
org.apache.flink.table.planner.functions.utils.HiveAggSqlFunction
TODO hack code, its logical should be integrated to AggSqlFunction
|
org.apache.flink.table.planner.functions.utils.HiveTableSqlFunction
TODO hack code, its logical should be integrated to TableSqlFunction
|
org.apache.flink.table.planner.functions.utils.HiveTableSqlFunction.HiveOperandTypeChecker
TODO hack code, should modify calcite getRowType to pass operand types
|
org.apache.flink.streaming.api.functions.IngestionTimeExtractor |
org.apache.flink.table.sources.InputFormatTableSource
This interface has been replaced by
DynamicTableSource . The new interface
produces internal data structures and only works with the Blink planner. See FLIP-95 for more
information. |
org.apache.flink.connector.jdbc.internal.executor.InsertOrUpdateJdbcExecutor
This has been replaced with
TableInsertOrUpdateStatementExecutor , will remove
this once JdbcUpsertTableSink is removed. |
org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferSerializerConfigSnapshot
this snapshot class is no longer in use, and is maintained only for backwards
compatibility. It is fully replaced by
IntervalJoinOperator.BufferEntrySerializerSnapshot . |
org.apache.flink.runtime.rest.messages.JobExceptionsInfo.ExecutionExceptionInfo
ExecutionExceptionInfo will be replaced by JobExceptionsInfoWithHistory.ExceptionInfo as part of the effort of deprecating JobExceptionsInfo.allExceptions . |
org.apache.flink.runtime.rest.handler.job.metrics.JobVertexMetricsHandler
This class is subsumed by
SubtaskMetricsHandler and is only kept for
backwards-compatibility. |
org.apache.flink.streaming.connectors.kafka.KafkaTableSink
Use
KafkaDynamicSink via KafkaDynamicTableFactory . |
org.apache.flink.streaming.connectors.kafka.KafkaTableSinkBase
Use
KafkaDynamicSink via KafkaDynamicTableFactory . |
org.apache.flink.streaming.connectors.kafka.KafkaTableSource |
org.apache.flink.streaming.connectors.kafka.KafkaTableSourceBase |
org.apache.flink.streaming.connectors.kafka.KafkaTableSourceSinkFactory |
org.apache.flink.streaming.connectors.kafka.KafkaTableSourceSinkFactoryBase |
org.apache.flink.streaming.connectors.kinesis.model.KinesisStreamShard
Will be remove in a future version in favor of
StreamShardHandle . |
org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer.KryoSerializerConfigSnapshot |
org.apache.flink.mesos.runtime.clusterframework.LaunchableMesosWorker
Apache Mesos support was deprecated in Flink 1.13 and is subject to removal in the
future (see FLINK-22352 for further details).
|
org.apache.flink.streaming.api.operators.co.LegacyKeyedCoProcessOperator
Replaced by
KeyedCoProcessOperator which takes KeyedCoProcessFunction |
org.apache.flink.streaming.api.operators.LegacyKeyedProcessOperator
Replaced by
KeyedProcessOperator which takes KeyedProcessFunction |
org.apache.flink.table.client.gateway.context.LegacyTableEnvironmentInitializer
This will be dropped in Flink 1.14 with dropping support of
sql-client.yaml
configuration file. |
org.apache.flink.table.types.utils.LegacyTypeInfoDataTypeConverter
Use
DataTypeFactory.createDataType(TypeInformation) instead. Note that this
method will not create legacy types anymore. It fully uses the new type system available only
in the Blink planner. |
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.runtime.types.LogicalTypeDataTypeConverter |
org.apache.flink.api.common.typeutils.base.MapSerializerConfigSnapshot
this snapshot class should not be used by any serializer anymore.
|
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.runtime.state.memory.MemoryStateBackend |
org.apache.flink.mesos.util.MesosArtifactServerImpl
Apache Mesos support was deprecated in Flink 1.13 and is subject to removal in the
future (see FLINK-22352 for further details).
|
org.apache.flink.mesos.runtime.clusterframework.MesosConfigKeys
Apache Mesos support was deprecated in Flink 1.13 and is subject to removal in the
future (see FLINK-22352 for further details).
|
org.apache.flink.mesos.util.MesosConfiguration
Apache Mesos support was deprecated in Flink 1.13 and is subject to removal in the
future (see FLINK-22352 for further details).
|
org.apache.flink.mesos.entrypoint.MesosJobClusterEntrypoint
Apache Mesos support was deprecated in Flink 1.13 and is subject to removal in the
future (see FLINK-22352 for further details).
|
org.apache.flink.mesos.configuration.MesosOptions
Apache Mesos support was deprecated in Flink 1.13 and is subject to removal in the
future (see FLINK-22352 for further details).
|
org.apache.flink.mesos.util.MesosResourceAllocation
Apache Mesos support was deprecated in Flink 1.13 and is subject to removal in the
future (see FLINK-22352 for further details).
|
org.apache.flink.mesos.runtime.clusterframework.MesosResourceManagerActorFactoryImpl
Apache Mesos support was deprecated in Flink 1.13 and is subject to removal in the
future (see FLINK-22352 for further details).
|
org.apache.flink.mesos.runtime.clusterframework.MesosResourceManagerDriver
Apache Mesos support was deprecated in Flink 1.13 and is subject to removal in the
future (see FLINK-22352 for further details).
|
org.apache.flink.mesos.runtime.clusterframework.MesosResourceManagerFactory
Apache Mesos support was deprecated in Flink 1.13 and is subject to removal in the
future (see FLINK-22352 for further details).
|
org.apache.flink.mesos.runtime.clusterframework.services.MesosServicesUtils
Apache Mesos support was deprecated in Flink 1.13 and is subject to removal in the
future (see FLINK-22352 for further details).
|
org.apache.flink.mesos.entrypoint.MesosSessionClusterEntrypoint
Apache Mesos support was deprecated in Flink 1.13 and is subject to removal in the
future (see FLINK-22352 for further details).
|
org.apache.flink.mesos.entrypoint.MesosTaskExecutorRunner
Apache Mesos support was deprecated in Flink 1.13 and is subject to removal in the
future (see FLINK-22352 for further details).
|
org.apache.flink.mesos.runtime.clusterframework.MesosTaskManagerParameters
Apache Mesos support was deprecated in Flink 1.13 and is subject to removal in the
future (see FLINK-22352 for further details).
|
org.apache.flink.mesos.util.MesosUtils
Apache Mesos support was deprecated in Flink 1.13 and is subject to removal in the
future (see FLINK-22352 for further details).
|
org.apache.flink.mesos.runtime.clusterframework.MesosWorkerResourceSpecFactory
Apache Mesos support was deprecated in Flink 1.13 and is subject to removal in the
future (see FLINK-22352 for further details).
|
org.apache.flink.test.util.MiniClusterResource
This class should be replaced with
MiniClusterWithClientResource . |
org.apache.flink.test.util.MiniClusterResourceConfiguration
This class should be replaced with
MiniClusterResourceConfiguration . |
org.apache.flink.table.client.config.entries.ModuleEntry
This will be removed in Flink 1.14 with dropping support of
sql-client.yaml
configuration file. |
org.apache.flink.cep.nfa.NFA.NFASerializer |
org.apache.flink.cep.nfa.NFA.NFASerializerConfigSnapshot
This snapshot class is no longer in use, and only maintained for backwards
compatibility purposes. It is fully replaced by
NFA.MigratedNFASerializerSnapshot . |
org.apache.flink.cep.pattern.conditions.NotCondition
Please use
RichNotCondition instead. This class exists just for backwards
compatibility and will be removed in FLINK-10113. |
org.apache.flink.api.java.typeutils.runtime.NullableSerializer.NullableSerializerConfigSnapshot
this snapshot class is no longer in use, and is maintained only for backwards
compatibility purposes. It is fully replaced by
NullableSerializer.NullableSerializerSnapshot . |
org.apache.flink.table.dataview.NullAwareMapSerializer |
org.apache.flink.table.dataview.NullAwareMapSerializerSnapshot |
org.apache.flink.table.descriptors.OldCsv
Use the RFC-compliant
Csv format in the dedicated flink-formats/flink-csv
module instead when writing to Kafka. |
org.apache.flink.table.descriptors.OldCsvValidator
Use the RFC-compliant
Csv format in the dedicated flink-formats/flink-csv
module instead. |
org.apache.flink.api.java.utils.Option
These classes will be dropped in the next version. Use
ParameterTool or a
third-party command line parsing library instead. |
org.apache.flink.cep.pattern.conditions.OrCondition
Please use
RichOrCondition instead. This class exists just for backwards
compatibility and will be removed in FLINK-10113. |
org.apache.flink.streaming.api.functions.sink.OutputFormatSinkFunction
Please use the
StreamingFileSink
for writing to files from a streaming program. |
org.apache.flink.table.sinks.OutputFormatTableSink
This interface has been replaced by
DynamicTableSink . The new interface
consumes internal data structures and only works with the Blink planner. See FLIP-95 for more
information. |
org.apache.flink.api.common.typeutils.ParameterlessTypeSerializerConfig
this snapshot class is no longer used by any serializers, and is maintained only for
backward compatibility reasons. It is fully replaced by
SimpleTypeSerializerSnapshot . |
org.apache.flink.api.java.typeutils.runtime.PojoSerializer.PojoSerializerConfigSnapshot
This snapshot class is no longer being used. It has been fully replaced by
PojoSerializerSnapshot . |
org.apache.flink.streaming.connectors.kinesis.config.ProducerConfigConstants
This class is deprecated in favor of the official AWS Kinesis producer configuration
keys. See
here for the full list of available configs. For configuring the region and credentials,
please use the keys in
AWSConfigConstants . |
org.apache.flink.runtime.webmonitor.handlers.ProgramArgsQueryParameter
please, use
JarRequestBody.FIELD_NAME_PROGRAM_ARGUMENTS_LIST |
org.apache.flink.mesos.runtime.clusterframework.RegisteredMesosWorkerNode
Apache Mesos support was deprecated in Flink 1.13 and is subject to removal in the
future (see FLINK-22352 for further details).
|
org.apache.flink.api.java.utils.RequiredParameters
These classes will be dropped in the next version. Use
ParameterTool or a
third-party command line parsing library instead. |
org.apache.flink.streaming.api.functions.windowing.RichProcessAllWindowFunction
use
ProcessAllWindowFunction instead |
org.apache.flink.streaming.api.functions.windowing.RichProcessWindowFunction
use
ProcessWindowFunction instead |
org.apache.flink.contrib.streaming.state.RocksDBStateBackend |
org.apache.flink.api.java.typeutils.runtime.RowSerializer.RowSerializerConfigSnapshot
this snapshot class is no longer in use, and is maintained only for backwards
compatibility. It is fully replaced by
RowSerializer.RowSerializerSnapshot . |
org.apache.flink.table.sources.RowtimeAttributeDescriptor
This interface will not be supported in the new source design around
DynamicTableSource which only works with the Blink planner. Use the concept of computed
columns instead. See FLIP-95 for more information. |
org.apache.flink.api.scala.typeutils.ScalaOptionSerializerConfigSnapshot
this snapshot class is no longer in use, and is maintained only for backwards
compatibility. It is fully replaced by
ScalaOptionSerializerSnapshot . |
org.apache.flink.api.scala.typeutils.ScalaTrySerializerConfigSnapshot |
org.apache.flink.cep.nfa.SharedBuffer
everything in this class is deprecated. Those are only migration procedures from
older versions.
|
org.apache.flink.cep.nfa.SharedBuffer.SharedBufferSerializerConfigSnapshot
This snapshot class is no longer in use, and only maintained for backwards
compatibility purposes. It is fully replaced by
SharedBuffer.SharedBufferSerializerSnapshot . |
org.apache.flink.cep.nfa.sharedbuffer.SharedBufferNode.SharedBufferNodeSerializer
was used in <= 1.12, use
SharedBufferNodeSerializer instead. |
org.apache.flink.streaming.util.serialization.SimpleStringSchema
Use
SimpleStringSchema instead. |
org.apache.flink.table.client.config.entries.SinkTableEntry
This will be removed in Flink 1.14 with dropping support of
sql-client.yaml
configuration file. |
org.apache.flink.streaming.api.windowing.assigners.SlidingTimeWindows
Please use
SlidingEventTimeWindows . |
org.apache.flink.table.client.config.entries.SourceSinkTableEntry
This will be removed in Flink 1.14 with dropping support of
sql-client.yaml
configuration file. |
org.apache.flink.table.client.config.entries.SourceTableEntry
This will be removed in Flink 1.14 with dropping support of
sql-client.yaml
configuration file. |
org.apache.flink.mesos.runtime.clusterframework.services.StandaloneMesosServices
Apache Mesos support was deprecated in Flink 1.13 and is subject to removal in the
future (see FLINK-22352 for further details).
|
org.apache.flink.mesos.runtime.clusterframework.store.StandaloneMesosWorkerStore
Apache Mesos support was deprecated in Flink 1.13 and is subject to removal in the
future (see FLINK-22352 for further details).
|
org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer.StreamElementSerializerConfigSnapshot |
org.apache.flink.streaming.runtime.tasks.StreamTaskActionExecutor.SynchronizedStreamTaskActionExecutor
this class should only be used in
SourceStreamTask which exposes the
checkpoint lock as part of Public API. |
org.apache.flink.table.api.TableColumn
See
ResolvedSchema and Column . |
org.apache.flink.table.util.TableConnectorUtil
Use
TableConnectorUtils instead. |
org.apache.flink.table.client.config.entries.TableEntry
This will be removed in Flink 1.14 with dropping support of
sql-client.yaml
configuration file. |
org.apache.flink.addons.hbase1.TableInputFormat
please use
HBaseInputFormat . |
org.apache.flink.table.api.TableSchema
This class has been deprecated as part of FLIP-164. It has been replaced by two more
dedicated classes
Schema and ResolvedSchema . Use Schema for
declaration in APIs. ResolvedSchema is offered by the framework after resolution and
validation. |
org.apache.flink.runtime.checkpoint.TaskState
Internal class for savepoint backwards compatibility. Don't use for other purposes.
|
org.apache.flink.table.client.config.entries.TemporalTableEntry
This will be removed in Flink 1.14 with dropping support of
sql-client.yaml
configuration file. |
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 use
DataTypes 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 use
DataTypes 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.streaming.api.operators.TimerSerializer.TimerSerializerConfigSnapshot
this snapshot class is no longer in use, and is maintained only for backwards
compatibility purposes. It is fully replaced by
TimerSerializerSnapshot . |
org.apache.flink.table.sources.tsextractors.TimestampExtractor
This interface will not be supported in the new source design around
DynamicTableSource which only works with the Blink planner. Use the concept of computed
columns instead. See FLIP-95 for more information. |
org.apache.flink.api.scala.typeutils.TraversableSerializerConfigSnapshot
This is being replaced with
TraversableSerializerSnapshot . |
org.apache.flink.streaming.api.windowing.assigners.TumblingTimeWindows
Please use
TumblingEventTimeWindows . |
org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.StateSerializerConfigSnapshot
this snapshot class is no longer in use, and is maintained only for backwards
compatibility purposes. It is fully replaced by
TwoPhaseCommitSinkFunction.StateSerializerSnapshot . |
org.apache.flink.table.runtime.types.TypeInfoDataTypeConverter
Use
InternalTypeInfo.of(LogicalType) instead if TypeInformation is
really required. In many cases, InternalSerializers.create(LogicalType) should be
sufficient. |
org.apache.flink.table.runtime.types.TypeInfoLogicalTypeConverter |
org.apache.flink.table.types.logical.TypeInformationRawType
Use
RawType instead. |
org.apache.flink.streaming.util.serialization.TypeInformationSerializationSchema
Use
TypeInformationSerializationSchema instead. |
org.apache.flink.table.api.Types
This class will be removed in future versions as it uses the old type system. It is
recommended to use
DataTypes instead which uses the new type system based on
instances of DataType . 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.api.common.typeutils.TypeSerializerConfigSnapshot |
org.apache.flink.api.common.typeutils.TypeSerializerSerializationUtil
This utility class was used to write serializers into checkpoints. Starting from
Flink 1.6.x, this should no longer happen, and therefore this class is deprecated. It remains
here for backwards compatibility paths.
|
org.apache.flink.table.utils.TypeStringUtils
This utility is based on
TypeInformation . However, the Table & SQL API is
currently updated to use DataType s based on LogicalType s. Use LogicalTypeParser instead. |
org.apache.flink.table.api.constraints.UniqueConstraint
See
ResolvedSchema and UniqueConstraint . |
org.apache.flink.api.java.typeutils.runtime.ValueSerializer.ValueSerializerConfigSnapshot |
org.apache.flink.table.client.config.entries.ViewEntry
This will be removed in Flink 1.14 with dropping support of
sql-client.yaml
configuration file. |
org.apache.flink.table.api.WatermarkSpec
See
ResolvedSchema and WatermarkSpec . |
org.apache.flink.api.java.typeutils.runtime.WritableSerializer.WritableSerializerConfigSnapshot
This class is no longer used as a snapshot for any serializer. It is fully
replaced by
WritableSerializer.WritableSerializerSnapshot . |
org.apache.flink.streaming.api.functions.sink.WriteFormat
Please use the
StreamingFileSink
for writing to files from a streaming program. |
org.apache.flink.streaming.api.functions.sink.WriteFormatAsCsv
Please use the
StreamingFileSink
for writing to files from a streaming program. |
org.apache.flink.streaming.api.functions.sink.WriteFormatAsText
Please use the
StreamingFileSink
for writing to files from a streaming program. |
org.apache.flink.streaming.api.functions.sink.WriteSinkFunction
Please use the
StreamingFileSink
for writing to files from a streaming program. |
org.apache.flink.streaming.api.functions.sink.WriteSinkFunctionByMillis
Please use the
StreamingFileSink
for writing to files from a streaming program. |
org.apache.flink.table.client.config.YamlConfigUtils
This will be removed in Flink 1.14 with dropping support of
sql-client.yaml
configuration file. |
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.mesos.runtime.clusterframework.services.ZooKeeperMesosServices
Apache Mesos support was deprecated in Flink 1.13 and is subject to removal in the
future (see FLINK-22352 for further details).
|
org.apache.flink.mesos.runtime.clusterframework.store.ZooKeeperMesosWorkerStore
Apache Mesos support was deprecated in Flink 1.13 and is subject to removal in the
future (see FLINK-22352 for further details).
|
Enum and Description |
---|
org.apache.flink.api.common.CodeAnalysisMode
The code analysis code has been removed and this enum has no effect. NOTE It
can not be removed from the codebase for now, because it had been serialized as part of the
ExecutionConfig which in turn had been serialized as part of the PojoSerializer .
This class can be removed when we drop support for pre 1.8 serializer snapshots that
contained java serialized serializers ( |
org.apache.flink.api.common.InputDependencyConstraint
InputDependencyConstraint is not used anymore and will be deleted in one of
the future versions. It was previously used in the scheduler implementations that were
removed as part of FLINK-20589. |
org.apache.flink.api.java.utils.OptionType
These classes will be dropped in the next version. Use
ParameterTool or a
third-party command line parsing library instead. |
org.apache.flink.contrib.streaming.state.RocksDBStateBackend.PriorityQueueStateType |
org.apache.flink.streaming.api.TimeCharacteristic
In Flink 1.12 the default stream time characteristic has been changed to
TimeCharacteristic.EventTime , thus you don't need to call this method for enabling
event-time support anymore. Explicitly using processing-time windows and timers works in
event-time mode. If you need to disable watermarks, please use ExecutionConfig.setAutoWatermarkInterval(long) . If you are using TimeCharacteristic.IngestionTime , please manually set an appropriate WatermarkStrategy . If you are using generic "time window" operations (for example KeyedStream.timeWindow(org.apache.flink.streaming.api.windowing.time.Time)
that change behaviour based on the time characteristic, please use equivalent operations that
explicitly specify processing time or event time. |
Exceptions and Description |
---|
org.apache.flink.api.java.utils.RequiredParametersException
These classes will be dropped in the next version. Use
ParameterTool or a
third-party command line parsing library instead. |
Enum Constant and Description |
---|
org.apache.flink.runtime.rest.messages.TerminationModeQueryParameter.TerminationMode.STOP
Please use the "stop" command instead.
|
org.apache.flink.api.common.state.StateDescriptor.Type.UNKNOWN
Enum for migrating from old checkpoints/savepoint versions.
|
Copyright © 2014–2022 The Apache Software Foundation. All rights reserved.