Package | Description |
---|---|
org.apache.flink.streaming.api.datastream | |
org.apache.flink.streaming.api.operators | |
org.apache.flink.streaming.api.transformations | |
org.apache.flink.streaming.runtime.tasks |
This package contains classes that realize streaming tasks.
|
Constructor and Description |
---|
DataStreamSource(StreamExecutionEnvironment environment,
TypeInformation<T> outTypeInfo,
StreamSource<T,?> operator,
boolean isParallel,
String sourceName) |
Modifier and Type | Class and Description |
---|---|
class |
StoppableStreamSource<OUT,SRC extends SourceFunction<OUT> & StoppableFunction>
|
Modifier and Type | Method and Description |
---|---|
StreamSource<T,?> |
SourceTransformation.getOperator()
Returns the
StreamSource , the operator of this SourceTransformation . |
Constructor and Description |
---|
SourceTransformation(String name,
StreamSource<T,?> operator,
TypeInformation<T> outputType,
int parallelism)
Creates a new
SourceTransformation from the given operator. |
Modifier and Type | Class and Description |
---|---|
class |
SourceStreamTask<OUT,SRC extends SourceFunction<OUT>,OP extends StreamSource<OUT,SRC>>
StreamTask for executing a StreamSource . |
Copyright © 2014–2019 The Apache Software Foundation. All rights reserved.