Package | Description |
---|---|
org.apache.flink.state.api | |
org.apache.flink.state.api.runtime | |
org.apache.flink.state.api.runtime.metadata |
Modifier and Type | Method and Description |
---|---|
<ACC,R> BootstrapTransformation<T> |
WindowedOperatorTransformation.aggregate(AggregateFunction<T,ACC,R> function)
Applies the given aggregation function to each window.
|
<ACC,R> BootstrapTransformation<T> |
WindowedOperatorTransformation.aggregate(AggregateFunction<T,ACC,R> function,
TypeInformation<ACC> accumulatorType)
Applies the given aggregation function to each window.
|
<ACC,V,R> BootstrapTransformation<T> |
WindowedOperatorTransformation.aggregate(AggregateFunction<T,ACC,V> aggFunction,
ProcessWindowFunction<V,R,K,W> windowFunction)
Applies the given window function to each window.
|
<ACC,V,R> BootstrapTransformation<T> |
WindowedOperatorTransformation.aggregate(AggregateFunction<T,ACC,V> aggregateFunction,
ProcessWindowFunction<V,R,K,W> windowFunction,
TypeInformation<ACC> accumulatorType)
Applies the given window function to each window.
|
<ACC,V,R> BootstrapTransformation<T> |
WindowedOperatorTransformation.aggregate(AggregateFunction<T,ACC,V> aggFunction,
WindowFunction<V,R,K,W> windowFunction)
Applies the given window function to each window.
|
<ACC,V,R> BootstrapTransformation<T> |
WindowedOperatorTransformation.aggregate(AggregateFunction<T,ACC,V> aggregateFunction,
WindowFunction<V,R,K,W> windowFunction,
TypeInformation<ACC> accumulatorType)
Applies the given window function to each window.
|
<R> BootstrapTransformation<T> |
WindowedOperatorTransformation.apply(WindowFunction<T,R,K,W> function)
Applies the given window function to each window.
|
<R> BootstrapTransformation<T> |
WindowedOperatorTransformation.apply(WindowFunction<T,R,K,W> function,
TypeInformation<R> resultType)
Applies the given window function to each window.
|
<R> BootstrapTransformation<T> |
WindowedOperatorTransformation.process(ProcessWindowFunction<T,R,K,W> function)
Applies the given window function to each window.
|
BootstrapTransformation<T> |
WindowedOperatorTransformation.reduce(ReduceFunction<T> function)
Applies a reduce function to the window.
|
<R> BootstrapTransformation<T> |
WindowedOperatorTransformation.reduce(ReduceFunction<T> reduceFunction,
ProcessWindowFunction<T,R,K,W> function)
Applies the given window function to each window.
|
<R> BootstrapTransformation<T> |
WindowedOperatorTransformation.reduce(ReduceFunction<T> reduceFunction,
WindowFunction<T,R,K,W> function)
Applies the given window function to each window.
|
BootstrapTransformation<T> |
OneInputOperatorTransformation.transform(BroadcastStateBootstrapFunction<T> processFunction)
Deprecated.
Applies the given
BroadcastStateBootstrapFunction on the non-keyed input. |
BootstrapTransformation<T> |
KeyedOperatorTransformation.transform(KeyedStateBootstrapFunction<K,T> processFunction)
Deprecated.
Applies the given
KeyedStateBootstrapFunction on the keyed input. |
BootstrapTransformation<T> |
OneInputOperatorTransformation.transform(SavepointWriterOperatorFactory factory)
Deprecated.
Method for passing user defined operators along with the type information that will transform
the OperatorTransformation.
|
BootstrapTransformation<T> |
KeyedOperatorTransformation.transform(SavepointWriterOperatorFactory factory)
Deprecated.
Method for passing user defined operators along with the type information that will transform
the OperatorTransformation.
|
BootstrapTransformation<T> |
OneInputOperatorTransformation.transform(StateBootstrapFunction<T> processFunction)
Deprecated.
Applies the given
StateBootstrapFunction on the non-keyed input. |
Modifier and Type | Method and Description |
---|---|
<T> F |
WritableSavepoint.withOperator(String uid,
BootstrapTransformation<T> transformation)
Deprecated.
Adds a new operator to the savepoint.
|
Modifier and Type | Method and Description |
---|---|
BootstrapTransformation<T> |
BootstrapTransformationWithID.getBootstrapTransformation()
Deprecated.
|
Constructor and Description |
---|
BootstrapTransformationWithID(OperatorID operatorID,
BootstrapTransformation<T> bootstrapTransformation)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
void |
SavepointMetadata.addOperator(String uid,
BootstrapTransformation<?> transformation)
Deprecated.
|
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.