Class CacheTransformation<T>
- java.lang.Object
-
- org.apache.flink.api.dag.Transformation<T>
-
- org.apache.flink.streaming.api.transformations.CacheTransformation<T>
-
- Type Parameters:
T
- The type of the elements in the cache intermediate result.
@Internal public class CacheTransformation<T> extends Transformation<T>
When in batch mode, theCacheTransformation
represents the intermediate result of the upper stream should be cached when it is computed at the first time. And it consumes the cached intermediate result in later jobs. In stream mode, it has no affect.
-
-
Field Summary
-
Fields inherited from class org.apache.flink.api.dag.Transformation
bufferTimeout, description, id, name, outputType, typeUsed, UPPER_BOUND_MAX_PARALLELISM
-
-
Constructor Summary
Constructors Constructor Description CacheTransformation(Transformation<T> transformationToCache, String name)
Creates a newTransformation
with the given name, output type and parallelism.
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description AbstractID
getDatasetId()
List<Transformation<?>>
getInputs()
Returns thetransformations
that are the immediate predecessors of the current transformation in the transformation graph.Transformation<T>
getTransformationToCache()
protected List<Transformation<?>>
getTransitivePredecessorsInternal()
Returns all transitive predecessorTransformation
s of thisTransformation
.boolean
isCached()
void
setCached(boolean cached)
-
Methods inherited from class org.apache.flink.api.dag.Transformation
declareManagedMemoryUseCaseAtOperatorScope, declareManagedMemoryUseCaseAtSlotScope, equals, getAttribute, getBufferTimeout, getCoLocationGroupKey, getDescription, getId, getManagedMemoryOperatorScopeUseCaseWeights, getManagedMemorySlotScopeUseCases, getMaxParallelism, getMinResources, getName, getNewNodeId, getOutputType, getParallelism, getPreferredResources, getSlotSharingGroup, getTransitivePredecessors, getUid, getUserProvidedNodeHash, hashCode, isParallelismConfigured, setAttribute, setBufferTimeout, setCoLocationGroupKey, setDescription, setMaxParallelism, setName, setOutputType, setParallelism, setParallelism, setResources, setSlotSharingGroup, setSlotSharingGroup, setUid, setUidHash, toString, updateManagedMemoryStateBackendUseCase
-
-
-
-
Constructor Detail
-
CacheTransformation
public CacheTransformation(Transformation<T> transformationToCache, String name)
Creates a newTransformation
with the given name, output type and parallelism.- Parameters:
name
- The name of theTransformation
, this will be shown in Visualizations and the Log
-
-
Method Detail
-
getTransitivePredecessorsInternal
protected List<Transformation<?>> getTransitivePredecessorsInternal()
Description copied from class:Transformation
Returns all transitive predecessorTransformation
s of thisTransformation
. This is, for example, used when determining whether a feedback edge of an iteration actually has the iteration head as a predecessor.- Specified by:
getTransitivePredecessorsInternal
in classTransformation<T>
- Returns:
- The list of transitive predecessors.
-
getInputs
public List<Transformation<?>> getInputs()
Description copied from class:Transformation
Returns thetransformations
that are the immediate predecessors of the current transformation in the transformation graph.- Specified by:
getInputs
in classTransformation<T>
-
getDatasetId
public AbstractID getDatasetId()
-
getTransformationToCache
public Transformation<T> getTransformationToCache()
-
setCached
public void setCached(boolean cached)
-
isCached
public boolean isCached()
-
-