T
- The type of the elements in this operator.OneInputStateTransformation
instead.@PublicEvolving @Deprecated public class OneInputOperatorTransformation<T> extends Object
OneInputOperatorTransformation
represents a user defined transformation applied on an
OperatorTransformation
with one input.Modifier and Type | Method and Description |
---|---|
OneInputOperatorTransformation<T> |
assignTimestamps(TimestampAssigner<T> assigner)
Deprecated.
Assigns an event time timestamp to each record.
|
OneInputOperatorTransformation<T> |
assignTimestamps(Timestamper<T> timestamper)
Deprecated.
Assigns an event time timestamp to each record.
|
KeyedOperatorTransformation<Tuple,T> |
keyBy(int... fields)
Deprecated.
Partitions the operator state of a
OperatorTransformation by the given key positions. |
<K> KeyedOperatorTransformation<K,T> |
keyBy(KeySelector<T,K> keySelector)
Deprecated.
It creates a new
KeyedOperatorTransformation that uses the provided key for
partitioning its operator states. |
<K> KeyedOperatorTransformation<K,T> |
keyBy(KeySelector<T,K> keySelector,
TypeInformation<K> keyType)
Deprecated.
It creates a new
KeyedOperatorTransformation that uses the provided key with explicit
type information for partitioning its operator states. |
KeyedOperatorTransformation<Tuple,T> |
keyBy(String... fields)
Deprecated.
Partitions the operator state of a
OperatorTransformation using field expressions. |
OneInputOperatorTransformation<T> |
setMaxParallelism(int maxParallelism)
Deprecated.
Sets the maximum parallelism of this operator.
|
BootstrapTransformation<T> |
transform(BroadcastStateBootstrapFunction<T> processFunction)
Deprecated.
Applies the given
BroadcastStateBootstrapFunction on the non-keyed input. |
BootstrapTransformation<T> |
transform(SavepointWriterOperatorFactory factory)
Deprecated.
Method for passing user defined operators along with the type information that will transform
the OperatorTransformation.
|
BootstrapTransformation<T> |
transform(StateBootstrapFunction<T> processFunction)
Deprecated.
Applies the given
StateBootstrapFunction on the non-keyed input. |
@PublicEvolving public OneInputOperatorTransformation<T> setMaxParallelism(int maxParallelism)
The maximum parallelism specifies the upper bound for dynamic scaling. It also defines the number of key groups used for partitioned state.
maxParallelism
- Maximum parallelismpublic OneInputOperatorTransformation<T> assignTimestamps(Timestamper<T> timestamper)
public OneInputOperatorTransformation<T> assignTimestamps(TimestampAssigner<T> assigner)
public BootstrapTransformation<T> transform(StateBootstrapFunction<T> processFunction)
StateBootstrapFunction
on the non-keyed input.
The function will be called for every element in the input and can be used for writing
operator state into a Savepoint
.
processFunction
- The StateBootstrapFunction
that is called for each element.OperatorTransformation
that can be added to a Savepoint
.public BootstrapTransformation<T> transform(BroadcastStateBootstrapFunction<T> processFunction)
BroadcastStateBootstrapFunction
on the non-keyed input.
The function will be called for every element in the input and can be used for writing
broadcast state into a Savepoint
.
processFunction
- The BroadcastStateBootstrapFunction
that is called for each
element.BootstrapTransformation
that can be added to a Savepoint
.public BootstrapTransformation<T> transform(SavepointWriterOperatorFactory factory)
IMPORTANT: Any output from this operator will be discarded.
factory
- A factory returning transformation logic type of the return streamBootstrapTransformation
that can be added to a Savepoint
.public <K> KeyedOperatorTransformation<K,T> keyBy(KeySelector<T,K> keySelector)
KeyedOperatorTransformation
that uses the provided key for
partitioning its operator states.keySelector
- The KeySelector to be used for extracting the key for partitioning.BootstrapTransformation
with partitioned state.public <K> KeyedOperatorTransformation<K,T> keyBy(KeySelector<T,K> keySelector, TypeInformation<K> keyType)
KeyedOperatorTransformation
that uses the provided key with explicit
type information for partitioning its operator states.keySelector
- The KeySelector to be used for extracting the key for partitioning.keyType
- The type information describing the key type.BootstrapTransformation
with partitioned state.public KeyedOperatorTransformation<Tuple,T> keyBy(int... fields)
OperatorTransformation
by the given key positions.fields
- The position of the fields on which the OperatorTransformation
will be
grouped.OperatorTransformation
with partitioned state.public KeyedOperatorTransformation<Tuple,T> keyBy(String... fields)
OperatorTransformation
using field expressions. A
field expression is either the name of a public field or a getter method with parentheses of
the OperatorTransformation
's underlying type. A dot can be used to drill down into
objects, as in "field1.getInnerField2()"
.fields
- One or more field expressions on which the state of the OperatorTransformation
operators will be partitioned.OperatorTransformation
with partitioned state (i.e. KeyedStream)Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.