Package | Description |
---|---|
org.apache.flink.streaming.api.environment | |
org.apache.flink.streaming.api.graph | |
org.apache.flink.streaming.api.operators | |
org.apache.flink.streaming.api.operators.async | |
org.apache.flink.streaming.runtime.io | |
org.apache.flink.streaming.runtime.io.checkpointing | |
org.apache.flink.streaming.runtime.tasks |
This package contains classes that realize streaming tasks.
|
org.apache.flink.streaming.runtime.translators | |
org.apache.flink.streaming.util.graph |
Class and Description |
---|
StreamGraph
Class representing the streaming topology.
|
Class and Description |
---|
GlobalStreamExchangeMode
This mode decides the default
ResultPartitionType of job edges. |
NonChainedOutput
Used by operator chain and represents a non-chained output of the corresponding stream operator.
|
StreamConfig
Internal configuration for a
StreamOperator . |
StreamConfig.InputConfig
Interface representing chained inputs.
|
StreamConfig.InputRequirement
Requirements of the different inputs of an operator.
|
StreamEdge
An edge in the streaming topology.
|
StreamGraph
Class representing the streaming topology.
|
StreamGraphGenerator
A generator that generates a
StreamGraph from a graph of Transformation s. |
StreamGraphHasher
Interface for different implementations of generating hashes over a stream graph.
|
StreamNode
Class representing the operators in the streaming programs, with all their properties.
|
TransformationTranslator
A
TransformationTranslator is responsible for translating a given Transformation
to its runtime implementation depending on the execution mode. |
TransformationTranslator.Context
A context giving the necessary information for the translation of a given transformation.
|
Class and Description |
---|
StreamConfig
Internal configuration for a
StreamOperator . |
Class and Description |
---|
StreamConfig
Internal configuration for a
StreamOperator . |
Class and Description |
---|
StreamConfig
Internal configuration for a
StreamOperator . |
StreamConfig.InputConfig
Interface representing chained inputs.
|
Class and Description |
---|
StreamConfig
Internal configuration for a
StreamOperator . |
Class and Description |
---|
StreamConfig
Internal configuration for a
StreamOperator . |
StreamConfig.InputConfig
Interface representing chained inputs.
|
StreamConfig.SourceInputConfig
A serialized representation of an input.
|
Class and Description |
---|
SimpleTransformationTranslator
A base class for all
TransformationTranslators who translate
Transformations that have a single operator in their runtime
implementation. |
StreamConfig.InputRequirement
Requirements of the different inputs of an operator.
|
TransformationTranslator
A
TransformationTranslator is responsible for translating a given Transformation
to its runtime implementation depending on the execution mode. |
TransformationTranslator.Context
A context giving the necessary information for the translation of a given transformation.
|
Class and Description |
---|
StreamGraph
Class representing the streaming topology.
|
Copyright © 2014–2023 The Apache Software Foundation. All rights reserved.