| Package | Description | 
|---|---|
| org.apache.flink.api.java | |
| org.apache.flink.api.java.io | |
| org.apache.flink.api.java.operators | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | CollectionEnvironmentDeprecated. 
 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. | 
| class  | LocalEnvironmentDeprecated. 
 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. | 
| class  | RemoteEnvironmentDeprecated. 
 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. | 
| Modifier and Type | Field and Description | 
|---|---|
| protected ExecutionEnvironment | DataSet. contextDeprecated.  | 
| Modifier and Type | Method and Description | 
|---|---|
| ExecutionEnvironment | ExecutionEnvironmentFactory. createExecutionEnvironment()Deprecated.  Creates an ExecutionEnvironment from this factory. | 
| static ExecutionEnvironment | ExecutionEnvironment. createLocalEnvironmentWithWebUI(org.apache.flink.configuration.Configuration conf)Deprecated.  Creates a  LocalEnvironmentfor local program execution that also starts the web
 monitoring UI. | 
| static ExecutionEnvironment | ExecutionEnvironment. createRemoteEnvironment(String host,
                       int port,
                       org.apache.flink.configuration.Configuration clientConfiguration,
                       String... jarFiles)Deprecated.  Creates a  RemoteEnvironment. | 
| static ExecutionEnvironment | ExecutionEnvironment. createRemoteEnvironment(String host,
                       int port,
                       int parallelism,
                       String... jarFiles)Deprecated.  Creates a  RemoteEnvironment. | 
| static ExecutionEnvironment | ExecutionEnvironment. createRemoteEnvironment(String host,
                       int port,
                       String... jarFiles)Deprecated.  Creates a  RemoteEnvironment. | 
| static ExecutionEnvironment | ExecutionEnvironment. getExecutionEnvironment()Deprecated.  Creates an execution environment that represents the context in which the program is
 currently executed. | 
| ExecutionEnvironment | DataSet. getExecutionEnvironment()Deprecated.  Returns the  ExecutionEnvironmentin which this DataSet is registered. | 
| Constructor and Description | 
|---|
| DataSet(ExecutionEnvironment context,
       org.apache.flink.api.common.typeinfo.TypeInformation<T> typeInfo)Deprecated.  | 
| Constructor and Description | 
|---|
| CsvReader(org.apache.flink.core.fs.Path filePath,
         ExecutionEnvironment executionContext)Deprecated.  | 
| CsvReader(String filePath,
         ExecutionEnvironment executionContext)Deprecated.  | 
| Constructor and Description | 
|---|
| DataSource(ExecutionEnvironment context,
          org.apache.flink.api.common.io.InputFormat<OUT,?> inputFormat,
          org.apache.flink.api.common.typeinfo.TypeInformation<OUT> type,
          String dataSourceLocationName)Deprecated.  Creates a new data source. | 
| DeltaIteration(ExecutionEnvironment context,
              org.apache.flink.api.common.typeinfo.TypeInformation<ST> type,
              DataSet<ST> solutionSet,
              DataSet<WT> workset,
              org.apache.flink.api.common.operators.Keys<ST> keys,
              int maxIterations)Deprecated.  | 
| IterativeDataSet(ExecutionEnvironment context,
                org.apache.flink.api.common.typeinfo.TypeInformation<T> type,
                DataSet<T> input,
                int maxIterations)Deprecated.  | 
| Operator(ExecutionEnvironment context,
        org.apache.flink.api.common.typeinfo.TypeInformation<OUT> resultType)Deprecated.  | 
Copyright © 2014–2025 The Apache Software Foundation. All rights reserved.