所有类 接口概要 类概要 枚举概要
| 类 |
说明 |
| AbstractAllRoundWrapperOperator<T,S extends org.apache.flink.streaming.api.operators.StreamOperator<T>> |
The base class for the all-round wrapper operators.
|
| AbstractPerRoundWrapperOperator<T,S extends org.apache.flink.streaming.api.operators.StreamOperator<T>> |
The base class for all the per-round wrapper operators.
|
| AbstractWrapperOperator<T> |
The base class of all the wrapper operators.
|
| AllRoundOperatorWrapper<T> |
The operator wrapper implementation for all-round wrappers.
|
| BroadcastOutput<OUT> |
Wrapper output that broadcasts the records to all the downstream operators.
|
| BroadcastOutputFactory |
|
| BroadcastStateTransformationTranslator |
Draft translator for the BroadcastStateTransformation.
|
| ChainingBroadcastOutput<OUT> |
The broadcast output corresponding to a chained output.
|
| Checkpoints<T> |
Maintains the pending checkpoints.
|
| CheckpointsBroker |
Hand offs the Checkpoints from the head operator to the tail operator so that the tail
operator could decrease the reference count of the raw state when checkpoints are aborted.
|
| CoordinatorCheckpointEvent |
Coordinator received the request of checkpoints.
|
| CountingBroadcastOutput<OUT> |
The intermediate broadcast output that wrappers a list of internal outputs.
|
| DataCacheReader<T> |
Reads the cached data from a list of segments.
|
| DataCacheSnapshot |
The snapshot of a data cache.
|
| DataCacheWriter<T> |
Records the data received and replayed them when required.
|
| DataStreamList |
A utility class to maintain a list of DataStream, which might have different types.
|
| DraftExecutionEnvironment |
A specialized stream execution environment that allows users to first construct a subgraph and
later copy the transformations into the actual environment.
|
| DraftExecutionEnvironment.EmptySource<T> |
A special source that emits no data.
|
| DraftTransformationTranslator<TF extends org.apache.flink.api.dag.Transformation<?>> |
Creates the actual transformation according to the draft transformation.
|
| DraftTransformationTranslator.Context |
|
| EpochAware |
Operators or UDF implements this method would be provided with an supplier that provides the
current rounds of the current element.
|
| EpochAwareAllRoundProcessFunction<I,O> |
A specialized ProcessFunction that also provide the attach epoch with each record.
|
| EpochAwareCoProcessFunction<I1,I2,O> |
A specialized CoProcessFunction that also provide the attach epoch with each record.
|
| GloballyAlignedEvent |
|
| HeadOperator |
The head operator unions the initialized variable stream and the feedback stream, synchronize the
epoch watermark (round) and taking care of the checkpoints.
|
| HeadOperatorCoordinator |
The OperatorCoordinator of the HeadOperator, it notifies the SharedProgressAligner when received aligned event from the operator, and emit the globally
aligned event back after one round is globally aligned.
|
| HeadOperatorCoordinator.HeadOperatorCoordinatorProvider |
|
| HeadOperatorFactory |
|
| HeadOperatorRecordProcessor |
The component to actually deal with the event received in the HeadOperator.
|
| HeadOperatorRecordProcessor.Context |
|
| HeadOperatorState |
The state entry for the head operator.
|
| InputOperator<T> |
|
| IterationBody |
The builder of the subgraph that will be executed inside the iteration.
|
| IterationBody.PerRoundSubBody |
The sub-graph inside the iteration body that should be executed as per-round.
|
| IterationBodyResult |
The result of an iteration, specifying the feedbacks and the outputs.
|
| IterationConfig |
The config for an iteration.
|
| IterationConfig.IterationConfigBuilder |
|
| IterationConfig.OperatorLifeCycle |
LifeCycles of the operator inside the iteration.
|
| IterationID |
The id of a single iteration instance in the job graph.
|
| IterationListener<T> |
The callbacks which will be invoked if the operator or UDF inside iteration implement this
interface.
|
| IterationListener.Context |
Information available in an invocation of the callbacks defined in the
IterationProgressListener.
|
| IterationOptions |
The options for the iteration.
|
| IterationRecord<T> |
The wrapper for the records in iterative stream.
|
| IterationRecord.Type |
The type of iteration records.
|
| IterationRecordSerializer<T> |
|
| IterationRecordTypeInfo<T> |
|
| Iterations |
A helper class to create iterations.
|
| KeyedBroadcastStateTransformationTranslator |
Draft translator for the KeyedBroadcastStateTransformation.
|
| KeyedMultipleInputTransformationTranslator |
Draft translator for the KeyedMultipleInputTransformation.
|
| ListStateWithCache<T> |
A ListState child class that records data and replays them when required.
|
| MultipleInputAllRoundWrapperOperator<OUT> |
All-round wrapper for the multiple-inputs operator.
|
| MultipleInputPerRoundWrapperOperator<OUT> |
Per-round wrapper for the multiple-inputs operator.
|
| MultipleInputTransformationTranslator |
Draft translator for the MultipleInputTransformation.
|
| OneInputAllRoundWrapperOperator<IN,OUT> |
All-round wrapper for the one-input operator.
|
| OneInputPerRoundWrapperOperator<IN,OUT> |
Per-round wrapper operator for the one-input operator.
|
| OneInputTransformationTranslator |
Draft translator for the OneInputTransformation.
|
| OperatorEpochWatermarkTracker |
Tracks the epoch watermark from each input.
|
| OperatorEpochWatermarkTrackerFactory |
|
| OperatorEpochWatermarkTrackerListener |
The listener of alignment.
|
| OperatorStateUtils |
Utility to deal with the states inside the operator.
|
| OperatorUtils |
Utility class for operators.
|
| OperatorWrapper<T,R> |
Wrappers for the given operator factory.
|
| OutputOperator<T> |
Output operator that unwraps IterationRecord into user record, and desert all the event
records.
|
| OutputReflectionContext |
The reflection utilities to parse the output and create the broadcast output.
|
| PartitionTransformationTranslator |
Draft translator for the PartitionTransformation.
|
| PerRoundOperatorWrapper<T> |
The operator wrapper implementation for per-round wrappers.
|
| ProxyInternalTimeServiceManager<K> |
Proxy InternalTimeServiceManager for the wrapped operators.
|
| ProxyKeyedStateBackend<K> |
Proxy KeyedStateBackend for the wrapped operators.
|
| ProxyKeySelector<T,KEY> |
Proxy key selector for the wrapped one.
|
| ProxyOperatorStateBackend |
Proxy OperatorStateBackend for the wrapped Operator.
|
| ProxyOutput<T> |
Proxy output to provide to the wrapped operator.
|
| ProxyStateSnapshotContext |
Proxy StateSnapshotContext for the wrapped operators.
|
| ProxyStreamOperatorStateContext |
Proxy StreamOperatorStateContext for the wrapped operator.
|
| ProxyStreamPartitioner<T> |
Proxy stream partitioner for the wrapped one.
|
| RecordWriterBroadcastOutput<OUT> |
The broadcast output corresponding to a record writer output.
|
| ReduceTransformationTranslator |
Draft translator for the ReduceTransformation.
|
| ReflectionUtils |
Utility class to provide some reflection tools.
|
| RegularHeadOperatorRecordProcessor |
Processes the event before we received the terminated global aligned event from the coordinator.
|
| ReplayableDataStreamList |
A list of data streams and whether they need replayed.
|
| ReplayableDataStreamList.NonReplayedDataStreamList |
|
| ReplayableDataStreamList.ReplayedDataStreamList |
|
| ReplayOperator<T> |
Replays the data received in the round 0 in the following round.
|
| Segment |
A segment contains the information about a cache unit.
|
| SharedProgressAligner |
|
| SharedProgressAlignerListener |
|
| SideOutputTransformationTranslator |
Draft translator for the SideOutputTransformation.
|
| StateNamePrefix |
The prefix for the state name.
|
| SubtaskAlignedEvent |
|
| TailOperator |
The tail operators is attached after each feedback operator to increment the round of each
record.
|
| TerminatingHeadOperatorRecordProcessor |
Processor used after we received terminated globally aligned event from the coordinator, but
before we received the (Integer.MAX_VALUE + 1) from the feedback channel again.
|
| TerminatingOnInitializeEvent |
|
| TwoInputAllRoundWrapperOperator<IN1,IN2,OUT> |
All-round wrapper for the two-inputs operator.
|
| TwoInputPerRoundWrapperOperator<IN1,IN2,OUT> |
Per-round wrapper for the two-inputs operator.
|
| TwoInputTransformationTranslator |
Draft translator for the TwoInputTransformation.
|
| UnionTransformationTranslator |
Draft translator for the UnionTransformation.
|
| WrapperOperatorFactory<OUT> |
|