Modifier and Type | Field and Description |
---|---|
protected StreamTransformation<T> |
DataStream.transformation |
Modifier and Type | Method and Description |
---|---|
StreamTransformation<T> |
DataStream.getTransformation()
Returns the
StreamTransformation that represents the operation that logically creates
this DataStream . |
StreamTransformation<T> |
BroadcastStream.getTransformation() |
Constructor and Description |
---|
DataStream(StreamExecutionEnvironment environment,
StreamTransformation<T> transformation)
Create a new
DataStream in the given execution environment with
partitioning set to forward by default. |
SingleOutputStreamOperator(StreamExecutionEnvironment environment,
StreamTransformation<T> transformation) |
Modifier and Type | Field and Description |
---|---|
protected List<StreamTransformation<?>> |
StreamExecutionEnvironment.transformations |
Modifier and Type | Method and Description |
---|---|
void |
StreamExecutionEnvironment.addOperator(StreamTransformation<?> transformation)
Adds an operator to the list of operators that should be executed when calling
StreamExecutionEnvironment.execute() . |
Modifier and Type | Method and Description |
---|---|
static StreamGraph |
StreamGraphGenerator.generate(StreamExecutionEnvironment env,
List<StreamTransformation<?>> transformations)
Generates a
StreamGraph by traversing the graph of StreamTransformations
starting from the given transformations. |
Modifier and Type | Class and Description |
---|---|
class |
CoFeedbackTransformation<F>
This represents a feedback point in a topology.
|
class |
FeedbackTransformation<T>
This represents a feedback point in a topology.
|
class |
OneInputTransformation<IN,OUT>
This Transformation represents the application of a
OneInputStreamOperator to one input
StreamTransformation . |
class |
PartitionTransformation<T>
This transformation represents a change of partitioning of the input elements.
|
class |
SelectTransformation<T>
This transformation represents a selection of only certain upstream elements.
|
class |
SideOutputTransformation<T>
This transformation represents a selection of a side output of an upstream operation with a
given
OutputTag . |
class |
SinkTransformation<T>
This Transformation represents a Sink.
|
class |
SourceTransformation<T>
This represents a Source.
|
class |
SplitTransformation<T>
This transformation represents a split of one
DataStream into several DataStreams
using an OutputSelector . |
class |
TwoInputTransformation<IN1,IN2,OUT>
This Transformation represents the application of a
TwoInputStreamOperator to two input StreamTransformations . |
class |
UnionTransformation<T>
This transformation represents a union of several input
StreamTransformations . |
Modifier and Type | Method and Description |
---|---|
StreamTransformation<T> |
SelectTransformation.getInput()
Returns the input
StreamTransformation . |
StreamTransformation<T> |
FeedbackTransformation.getInput()
Returns the input
StreamTransformation of this FeedbackTransformation . |
StreamTransformation<T> |
PartitionTransformation.getInput()
Returns the input
StreamTransformation of this SinkTransformation . |
StreamTransformation<IN> |
OneInputTransformation.getInput()
Returns the input
StreamTransformation of this OneInputTransformation . |
StreamTransformation<T> |
SplitTransformation.getInput()
Returns the input
StreamTransformation . |
StreamTransformation<?> |
SideOutputTransformation.getInput()
Returns the input
StreamTransformation . |
StreamTransformation<T> |
SinkTransformation.getInput()
Returns the input
StreamTransformation of this SinkTransformation . |
StreamTransformation<IN1> |
TwoInputTransformation.getInput1()
Returns the first input
StreamTransformation of this TwoInputTransformation . |
StreamTransformation<IN2> |
TwoInputTransformation.getInput2()
Returns the first input
StreamTransformation of this TwoInputTransformation . |
Modifier and Type | Method and Description |
---|---|
void |
CoFeedbackTransformation.addFeedbackEdge(StreamTransformation<F> transform)
Adds a feedback edge.
|
void |
FeedbackTransformation.addFeedbackEdge(StreamTransformation<T> transform)
Adds a feedback edge.
|
Constructor and Description |
---|
FeedbackTransformation(StreamTransformation<T> input,
Long waitTime)
Creates a new
FeedbackTransformation from the given input. |
OneInputTransformation(StreamTransformation<IN> input,
String name,
OneInputStreamOperator<IN,OUT> operator,
TypeInformation<OUT> outputType,
int parallelism)
Creates a new
OneInputTransformation from the given input and operator. |
PartitionTransformation(StreamTransformation<T> input,
StreamPartitioner<T> partitioner)
Creates a new
PartitionTransformation from the given input and
StreamPartitioner . |
SelectTransformation(StreamTransformation<T> input,
List<String> selectedNames)
Creates a new
SelectionTransformation from the given input that only selects
the streams with the selected names. |
SideOutputTransformation(StreamTransformation<?> input,
OutputTag<T> tag) |
SinkTransformation(StreamTransformation<T> input,
String name,
StreamSink<T> operator,
int parallelism)
Creates a new
SinkTransformation from the given input StreamTransformation . |
SplitTransformation(StreamTransformation<T> input,
OutputSelector<T> outputSelector)
Creates a new
SplitTransformation from the given input and OutputSelector . |
TwoInputTransformation(StreamTransformation<IN1> input1,
StreamTransformation<IN2> input2,
String name,
TwoInputStreamOperator<IN1,IN2,OUT> operator,
TypeInformation<OUT> outputType,
int parallelism)
Creates a new
TwoInputTransformation from the given inputs and operator. |
TwoInputTransformation(StreamTransformation<IN1> input1,
StreamTransformation<IN2> input2,
String name,
TwoInputStreamOperator<IN1,IN2,OUT> operator,
TypeInformation<OUT> outputType,
int parallelism)
Creates a new
TwoInputTransformation from the given inputs and operator. |
Constructor and Description |
---|
UnionTransformation(List<StreamTransformation<T>> inputs)
Creates a new
UnionTransformation from the given input StreamTransformations . |
Copyright © 2014–2020 The Apache Software Foundation. All rights reserved.