OUT
- The type of the elements produced by this data source.@Public public class DataSource<OUT> extends Operator<OUT,DataSource<OUT>>
minResources, name, parallelism, preferredResources
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)
Creates a new data source.
|
Modifier and Type | Method and Description |
---|---|
org.apache.flink.api.common.io.InputFormat<OUT,?> |
getInputFormat()
Gets the input format that is executed by this data source.
|
org.apache.flink.configuration.Configuration |
getParameters() |
SplitDataProperties<OUT> |
getSplitDataProperties()
Returns the
SplitDataProperties for the
InputSplit s of this DataSource
for configurations. |
protected org.apache.flink.api.common.operators.GenericDataSourceBase<OUT,?> |
translateToDataFlow() |
DataSource<OUT> |
withParameters(org.apache.flink.configuration.Configuration parameters)
Pass a configuration to the InputFormat
|
getMinResources, getName, getParallelism, getPreferredResources, getResultType, name, setParallelism
aggregate, checkSameExecutionContext, clean, coGroup, collect, combineGroup, count, cross, crossWithHuge, crossWithTiny, distinct, distinct, distinct, distinct, fillInType, filter, first, flatMap, fullOuterJoin, fullOuterJoin, getExecutionEnvironment, getType, groupBy, groupBy, groupBy, iterate, iterateDelta, join, join, joinWithHuge, joinWithTiny, leftOuterJoin, leftOuterJoin, map, mapPartition, max, maxBy, min, minBy, output, partitionByHash, partitionByHash, partitionByHash, partitionByRange, partitionByRange, partitionByRange, partitionCustom, partitionCustom, partitionCustom, print, print, printOnTaskManager, printToErr, printToErr, project, rebalance, reduce, reduceGroup, rightOuterJoin, rightOuterJoin, runOperation, sortPartition, sortPartition, sortPartition, sum, union, write, write, writeAsCsv, writeAsCsv, writeAsCsv, writeAsCsv, writeAsFormattedText, writeAsFormattedText, writeAsText, writeAsText
public DataSource(ExecutionEnvironment context, org.apache.flink.api.common.io.InputFormat<OUT,?> inputFormat, org.apache.flink.api.common.typeinfo.TypeInformation<OUT> type, String dataSourceLocationName)
context
- The environment in which the data source gets executed.inputFormat
- The input format that the data source executes.type
- The type of the elements produced by this input format.@Internal public org.apache.flink.api.common.io.InputFormat<OUT,?> getInputFormat()
public DataSource<OUT> withParameters(org.apache.flink.configuration.Configuration parameters)
parameters
- Configuration parameterspublic org.apache.flink.configuration.Configuration getParameters()
@PublicEvolving public SplitDataProperties<OUT> getSplitDataProperties()
SplitDataProperties
for the
InputSplit
s of this DataSource
for configurations.
SplitDataProperties can help to generate more efficient execution plans.
protected org.apache.flink.api.common.operators.GenericDataSourceBase<OUT,?> translateToDataFlow()
Copyright © 2014–2017 The Apache Software Foundation. All rights reserved.