IN1
- The type of the elements in the first input Transformation
IN2
- The type of the elements in the second input Transformation
OUT
- The type of the elements that result from this TwoInputTransformation
@Internal public class TwoInputTransformation<IN1,IN2,OUT> extends PhysicalTransformation<OUT>
TwoInputStreamOperator
to two input
Transformations
. The result is again only one stream.bufferTimeout, description, id, name, outputType, typeUsed, UPPER_BOUND_MAX_PARALLELISM
Constructor and Description |
---|
TwoInputTransformation(Transformation<IN1> input1,
Transformation<IN2> input2,
String name,
StreamOperatorFactory<OUT> operatorFactory,
TypeInformation<OUT> outputType,
int parallelism) |
TwoInputTransformation(Transformation<IN1> input1,
Transformation<IN2> input2,
String name,
StreamOperatorFactory<OUT> operatorFactory,
TypeInformation<OUT> outputType,
int parallelism,
boolean parallelismConfigured)
Creates a new
TwoInputTransformation from the given inputs and operator. |
TwoInputTransformation(Transformation<IN1> input1,
Transformation<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(Transformation<IN1> input1,
Transformation<IN2> input2,
String name,
TwoInputStreamOperator<IN1,IN2,OUT> operator,
TypeInformation<OUT> outputType,
int parallelism,
boolean parallelismConfigured) |
Modifier and Type | Method and Description |
---|---|
Transformation<IN1> |
getInput1()
Returns the first input
Transformation of this TwoInputTransformation . |
Transformation<IN2> |
getInput2()
Returns the second input
Transformation of this TwoInputTransformation . |
List<Transformation<?>> |
getInputs()
Returns the
transformations that are the immediate predecessors of the
current transformation in the transformation graph. |
TypeInformation<IN1> |
getInputType1()
Returns the
TypeInformation for the elements from the first input. |
TypeInformation<IN2> |
getInputType2()
Returns the
TypeInformation for the elements from the second input. |
TwoInputStreamOperator<IN1,IN2,OUT> |
getOperator() |
StreamOperatorFactory<OUT> |
getOperatorFactory()
Returns the
StreamOperatorFactory of this Transformation. |
KeySelector<IN1,?> |
getStateKeySelector1()
Returns the
KeySelector that must be used for partitioning keyed state in this
Operation for the first input. |
KeySelector<IN2,?> |
getStateKeySelector2()
Returns the
KeySelector that must be used for partitioning keyed state in this
Operation for the second input. |
TypeInformation<?> |
getStateKeyType() |
protected List<Transformation<?>> |
getTransitivePredecessorsInternal()
Returns all transitive predecessor
Transformation s of this Transformation . |
boolean |
isInternalSorterSupported() |
boolean |
isOutputOnlyAfterEndOfStream() |
void |
setChainingStrategy(ChainingStrategy strategy)
Sets the chaining strategy of this
Transformation . |
void |
setStateKeySelectors(KeySelector<IN1,?> stateKeySelector1,
KeySelector<IN2,?> stateKeySelector2)
Sets the
KeySelectors that must be used for partitioning keyed state of
this transformation. |
void |
setStateKeyType(TypeInformation<?> stateKeyType) |
isSupportsConcurrentExecutionAttempts, setSupportsConcurrentExecutionAttempts
declareManagedMemoryUseCaseAtOperatorScope, declareManagedMemoryUseCaseAtSlotScope, equals, getBufferTimeout, getCoLocationGroupKey, getDescription, getId, getManagedMemoryOperatorScopeUseCaseWeights, getManagedMemorySlotScopeUseCases, getMaxParallelism, getMinResources, getName, getNewNodeId, getOutputType, getParallelism, getPreferredResources, getSlotSharingGroup, getTransitivePredecessors, getUid, getUserProvidedNodeHash, hashCode, isParallelismConfigured, setBufferTimeout, setCoLocationGroupKey, setDescription, setMaxParallelism, setName, setOutputType, setParallelism, setParallelism, setResources, setSlotSharingGroup, setSlotSharingGroup, setUid, setUidHash, toString, updateManagedMemoryStateBackendUseCase
public TwoInputTransformation(Transformation<IN1> input1, Transformation<IN2> input2, String name, TwoInputStreamOperator<IN1,IN2,OUT> operator, TypeInformation<OUT> outputType, int parallelism)
TwoInputTransformation
from the given inputs and operator.input1
- The first input Transformation
input2
- The second input Transformation
name
- The name of the Transformation
, this will be shown in Visualizations and
the Logoperator
- The TwoInputStreamOperator
outputType
- The type of the elements produced by this Transformationparallelism
- The parallelism of this Transformationpublic TwoInputTransformation(Transformation<IN1> input1, Transformation<IN2> input2, String name, TwoInputStreamOperator<IN1,IN2,OUT> operator, TypeInformation<OUT> outputType, int parallelism, boolean parallelismConfigured)
public TwoInputTransformation(Transformation<IN1> input1, Transformation<IN2> input2, String name, StreamOperatorFactory<OUT> operatorFactory, TypeInformation<OUT> outputType, int parallelism)
public TwoInputTransformation(Transformation<IN1> input1, Transformation<IN2> input2, String name, StreamOperatorFactory<OUT> operatorFactory, TypeInformation<OUT> outputType, int parallelism, boolean parallelismConfigured)
TwoInputTransformation
from the given inputs and operator.input1
- The first input Transformation
input2
- The second input Transformation
name
- The name of the Transformation
, this will be shown in Visualizations and
the LogoperatorFactory
- The TwoInputStreamOperator
factoryoutputType
- The type of the elements produced by this Transformationparallelism
- The parallelism of this TransformationparallelismConfigured
- If true, the parallelism of the transformation is explicitly set
and should be respected. Otherwise the parallelism can be changed at runtime.public Transformation<IN1> getInput1()
Transformation
of this TwoInputTransformation
.public Transformation<IN2> getInput2()
Transformation
of this TwoInputTransformation
.public List<Transformation<?>> getInputs()
Transformation
transformations
that are the immediate predecessors of the
current transformation in the transformation graph.getInputs
in class Transformation<OUT>
public TypeInformation<IN1> getInputType1()
TypeInformation
for the elements from the first input.public TypeInformation<IN2> getInputType2()
TypeInformation
for the elements from the second input.@VisibleForTesting public TwoInputStreamOperator<IN1,IN2,OUT> getOperator()
public StreamOperatorFactory<OUT> getOperatorFactory()
StreamOperatorFactory
of this Transformation.public void setStateKeySelectors(KeySelector<IN1,?> stateKeySelector1, KeySelector<IN2,?> stateKeySelector2)
KeySelectors
that must be used for partitioning keyed state of
this transformation.stateKeySelector1
- The KeySelector
to set for the first inputstateKeySelector2
- The KeySelector
to set for the first inputpublic KeySelector<IN1,?> getStateKeySelector1()
KeySelector
that must be used for partitioning keyed state in this
Operation for the first input.public KeySelector<IN2,?> getStateKeySelector2()
KeySelector
that must be used for partitioning keyed state in this
Operation for the second input.public void setStateKeyType(TypeInformation<?> stateKeyType)
public TypeInformation<?> getStateKeyType()
protected List<Transformation<?>> getTransitivePredecessorsInternal()
Transformation
Transformation
s of this Transformation
.
This is, for example, used when determining whether a feedback edge of an iteration actually
has the iteration head as a predecessor.getTransitivePredecessorsInternal
in class Transformation<OUT>
public final void setChainingStrategy(ChainingStrategy strategy)
PhysicalTransformation
Transformation
.setChainingStrategy
in class PhysicalTransformation<OUT>
public boolean isOutputOnlyAfterEndOfStream()
public boolean isInternalSorterSupported()
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.