跳过导航链接
A B C D E F G H I K L M N O P R S T U V W 

A

abort(long) - 类 中的方法org.apache.flink.iteration.checkpoint.Checkpoints
 
AbstractAllRoundWrapperOperator<T,S extends org.apache.flink.streaming.api.operators.StreamOperator<T>> - org.apache.flink.iteration.operator.allround中的类
The base class for the all-round wrapper operators.
AbstractAllRoundWrapperOperator(StreamOperatorParameters<IterationRecord<T>>, StreamOperatorFactory<T>) - 类 的构造器org.apache.flink.iteration.operator.allround.AbstractAllRoundWrapperOperator
 
AbstractPerRoundWrapperOperator<T,S extends org.apache.flink.streaming.api.operators.StreamOperator<T>> - org.apache.flink.iteration.operator.perround中的类
The base class for all the per-round wrapper operators.
AbstractPerRoundWrapperOperator(StreamOperatorParameters<IterationRecord<T>>, StreamOperatorFactory<T>) - 类 的构造器org.apache.flink.iteration.operator.perround.AbstractPerRoundWrapperOperator
 
AbstractWrapperOperator<T> - org.apache.flink.iteration.operator中的类
The base class of all the wrapper operators.
AbstractWrapperOperator(StreamOperatorParameters<IterationRecord<T>>, StreamOperatorFactory<T>) - 类 的构造器org.apache.flink.iteration.operator.AbstractWrapperOperator
 
add(T) - 类 中的方法org.apache.flink.iteration.datacache.nonkeyed.ListStateWithCache
 
addAll(List<T>) - 类 中的方法org.apache.flink.iteration.datacache.nonkeyed.ListStateWithCache
 
addDraftSource(DataStream<?>, TypeInformation<T>) - 类 中的方法org.apache.flink.iteration.compile.DraftExecutionEnvironment
 
addOperator(Transformation<?>) - 类 中的方法org.apache.flink.iteration.compile.DraftExecutionEnvironment
 
addOperatorIfNotExists(Transformation<?>) - 类 中的方法org.apache.flink.iteration.compile.DraftExecutionEnvironment
 
addRecord(T) - 类 中的方法org.apache.flink.iteration.datacache.nonkeyed.DataCacheWriter
 
advanceWatermark(Watermark) - 类 中的方法org.apache.flink.iteration.proxy.state.ProxyInternalTimeServiceManager
 
ALIGN_NOTIFY_OUTPUT_TAG - 类 中的静态变量org.apache.flink.iteration.operator.HeadOperator
 
AllRoundOperatorWrapper<T> - org.apache.flink.iteration.operator.allround中的类
The operator wrapper implementation for all-round wrappers.
AllRoundOperatorWrapper() - 类 的构造器org.apache.flink.iteration.operator.allround.AllRoundOperatorWrapper
 
andNotReplay(DataStream<?>...) - 类 中的方法org.apache.flink.iteration.ReplayableDataStreamList.ReplayedDataStreamList
 
append(T) - 类 中的方法org.apache.flink.iteration.checkpoint.Checkpoints
 
applyToAllKeys(N, TypeSerializer<N>, StateDescriptor<S, T>, KeyedStateFunction<K, S>) - 类 中的方法org.apache.flink.iteration.proxy.state.ProxyKeyedStateBackend
 

B

broadcastEmit(StreamRecord<OUT>) - 接口 中的方法org.apache.flink.iteration.broadcast.BroadcastOutput
Broadcasts the record to all the downstream operators.
broadcastEmit(StreamRecord<OUT>) - 类 中的方法org.apache.flink.iteration.broadcast.ChainingBroadcastOutput
 
broadcastEmit(StreamRecord<OUT>) - 类 中的方法org.apache.flink.iteration.broadcast.CountingBroadcastOutput
 
broadcastEmit(StreamRecord<OUT>) - 类 中的方法org.apache.flink.iteration.broadcast.RecordWriterBroadcastOutput
 
BroadcastOutput<OUT> - org.apache.flink.iteration.broadcast中的接口
Wrapper output that broadcasts the records to all the downstream operators.
broadcastOutput(StreamRecord<IterationRecord<?>>) - 接口 中的方法org.apache.flink.iteration.operator.headprocessor.HeadOperatorRecordProcessor.Context
 
BroadcastOutputFactory - org.apache.flink.iteration.broadcast中的类
Factory that creates the corresponding BroadcastOutput from the Output.
BroadcastOutputFactory() - 类 的构造器org.apache.flink.iteration.broadcast.BroadcastOutputFactory
 
BroadcastStateTransformationTranslator - org.apache.flink.iteration.compile.translator中的类
Draft translator for the BroadcastStateTransformation.
BroadcastStateTransformationTranslator() - 类 的构造器org.apache.flink.iteration.compile.translator.BroadcastStateTransformationTranslator
 
build() - 类 中的方法org.apache.flink.iteration.IterationConfig.IterationConfigBuilder
 

C

callMethod(Object, Class<?>, String) - 类 中的静态方法org.apache.flink.iteration.utils.ReflectionUtils
 
callMethod(Object, Class<?>, String, List<Class<?>>, List<Object>) - 类 中的静态方法org.apache.flink.iteration.utils.ReflectionUtils
 
cancel() - 类 中的方法org.apache.flink.iteration.compile.DraftExecutionEnvironment.EmptySource
 
canEqual(Object) - 类 中的方法org.apache.flink.iteration.typeinfo.IterationRecordTypeInfo
 
ChainingBroadcastOutput<OUT> - org.apache.flink.iteration.broadcast中的类
The broadcast output corresponding to a chained output.
checkpointCoordinator(long, CompletableFuture<byte[]>) - 类 中的方法org.apache.flink.iteration.operator.coordinator.HeadOperatorCoordinator
 
Checkpoints<T> - org.apache.flink.iteration.checkpoint中的类
Maintains the pending checkpoints.
Checkpoints(TypeSerializer<T>, FileSystem, SupplierWithException<Path, IOException>) - 类 的构造器org.apache.flink.iteration.checkpoint.Checkpoints
 
CheckpointsBroker - org.apache.flink.iteration.checkpoint中的类
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.
CheckpointsBroker() - 类 的构造器org.apache.flink.iteration.checkpoint.CheckpointsBroker
 
clear() - 类 中的方法org.apache.flink.iteration.datacache.nonkeyed.DataCacheWriter
Removes all previously added records.
clear() - 类 中的方法org.apache.flink.iteration.datacache.nonkeyed.ListStateWithCache
 
clearIterationContextRound() - 类 中的方法org.apache.flink.iteration.operator.AbstractWrapperOperator
 
clone() - 类 中的方法org.apache.flink.iteration.IterationRecord
 
close() - 类 中的方法org.apache.flink.iteration.checkpoint.Checkpoints
 
close() - 类 中的方法org.apache.flink.iteration.operator.allround.AbstractAllRoundWrapperOperator
 
close() - 类 中的方法org.apache.flink.iteration.operator.coordinator.HeadOperatorCoordinator
 
close() - 类 中的方法org.apache.flink.iteration.operator.HeadOperator
 
close() - 类 中的方法org.apache.flink.iteration.operator.perround.AbstractPerRoundWrapperOperator
 
close() - 类 中的方法org.apache.flink.iteration.operator.TailOperator
 
close() - 类 中的方法org.apache.flink.iteration.proxy.ProxyOutput
 
close() - 类 中的方法org.apache.flink.iteration.proxy.state.ProxyKeyedStateBackend
 
close() - 类 中的方法org.apache.flink.iteration.proxy.state.ProxyOperatorStateBackend
 
closeStreamOperator(S, int, int) - 类 中的方法org.apache.flink.iteration.operator.perround.AbstractPerRoundWrapperOperator
 
closeStreamOperator(MultipleInputStreamOperator<OUT>, int, int) - 类 中的方法org.apache.flink.iteration.operator.perround.MultipleInputPerRoundWrapperOperator
 
collect(OutputTag<X>, StreamRecord<X>) - 类 中的方法org.apache.flink.iteration.proxy.ProxyOutput
 
collect(StreamRecord<T>) - 类 中的方法org.apache.flink.iteration.proxy.ProxyOutput
 
commitCheckpointsUntil(long) - 类 中的方法org.apache.flink.iteration.checkpoint.Checkpoints
 
containingTask - 类 中的变量org.apache.flink.iteration.operator.AbstractWrapperOperator
 
CoordinatorCheckpointEvent - org.apache.flink.iteration.operator.event中的类
Coordinator received the request of checkpoints.
CoordinatorCheckpointEvent(long) - 类 的构造器org.apache.flink.iteration.operator.event.CoordinatorCheckpointEvent
 
copy() - 类 中的方法org.apache.flink.iteration.proxy.ProxyStreamPartitioner
 
copy(IterationRecord<T>) - 类 中的方法org.apache.flink.iteration.typeinfo.IterationRecordSerializer
 
copy(IterationRecord<T>, IterationRecord<T>) - 类 中的方法org.apache.flink.iteration.typeinfo.IterationRecordSerializer
 
copy(DataInputView, DataOutputView) - 类 中的方法org.apache.flink.iteration.typeinfo.IterationRecordSerializer
 
copyProperties(Transformation<?>, Transformation<?>) - 接口 中的方法org.apache.flink.iteration.compile.DraftTransformationTranslator.Context
 
copyToActualEnvironment() - 类 中的方法org.apache.flink.iteration.compile.DraftExecutionEnvironment
 
CountingBroadcastOutput<OUT> - org.apache.flink.iteration.broadcast中的类
The intermediate broadcast output that wrappers a list of internal outputs.
CountingBroadcastOutput(Counter, List<BroadcastOutput<OUT>>) - 类 的构造器org.apache.flink.iteration.broadcast.CountingBroadcastOutput
 
create(OperatorCoordinator.Context) - 类 中的方法org.apache.flink.iteration.operator.coordinator.HeadOperatorCoordinator.HeadOperatorCoordinatorProvider
 
create(StreamConfig, StreamTask<?, ?>, OperatorEpochWatermarkTrackerListener) - 类 中的静态方法org.apache.flink.iteration.progresstrack.OperatorEpochWatermarkTrackerFactory
 
create(String, TypeSerializer<T>) - 类 中的方法org.apache.flink.iteration.proxy.state.ProxyKeyedStateBackend
 
createBroadcastOutput(Output<StreamRecord<OUT>>, Counter) - 类 中的静态方法org.apache.flink.iteration.broadcast.BroadcastOutputFactory
Creates the wrapper broadcast output from output.
createDataCacheFileGenerator(Path, String, OperatorID) - 类 中的静态方法org.apache.flink.iteration.operator.OperatorUtils
 
createFeedbackKey(IterationID, int) - 类 中的静态方法org.apache.flink.iteration.operator.OperatorUtils
Creates FeedbackKey from the iterationId and feedbackIndex.
createInstance() - 类 中的方法org.apache.flink.iteration.typeinfo.IterationRecordSerializer
 
createInternalState(TypeSerializer<N>, StateDescriptor<S, SV>, StateSnapshotTransformer.StateSnapshotTransformFactory<SEV>) - 类 中的方法org.apache.flink.iteration.proxy.state.ProxyKeyedStateBackend
 
createNewDescriptor(StateDescriptor<S, T>) - 类 中的方法org.apache.flink.iteration.proxy.state.ProxyKeyedStateBackend
 
createSerializer(ExecutionConfig) - 类 中的方法org.apache.flink.iteration.typeinfo.IterationRecordTypeInfo
 
createStreamOperator(StreamOperatorParameters<IterationRecord<?>>) - 类 中的方法org.apache.flink.iteration.operator.HeadOperatorFactory
 
createStreamOperator(StreamOperatorParameters<IterationRecord<OUT>>) - 类 中的方法org.apache.flink.iteration.operator.WrapperOperatorFactory
 
createWrappedOperatorConfig(StreamConfig) - 类 中的静态方法org.apache.flink.iteration.operator.OperatorUtils
 

D

DATA_CACHE_PATH - 类 中的静态变量org.apache.flink.iteration.config.IterationOptions
 
DataCacheReader<T> - org.apache.flink.iteration.datacache.nonkeyed中的类
Reads the cached data from a list of segments.
DataCacheReader(TypeSerializer<T>, List<Segment>) - 类 的构造器org.apache.flink.iteration.datacache.nonkeyed.DataCacheReader
 
DataCacheReader(TypeSerializer<T>, List<Segment>, Tuple2<Integer, Integer>) - 类 的构造器org.apache.flink.iteration.datacache.nonkeyed.DataCacheReader
 
DataCacheSnapshot - org.apache.flink.iteration.datacache.nonkeyed中的类
The snapshot of a data cache.
DataCacheSnapshot(FileSystem, Tuple2<Integer, Integer>, List<Segment>) - 类 的构造器org.apache.flink.iteration.datacache.nonkeyed.DataCacheSnapshot
 
DataCacheWriter<T> - org.apache.flink.iteration.datacache.nonkeyed中的类
Records the data received and replayed them when required.
DataCacheWriter(TypeSerializer<T>, FileSystem, SupplierWithException<Path, IOException>) - 类 的构造器org.apache.flink.iteration.datacache.nonkeyed.DataCacheWriter
 
DataCacheWriter(TypeSerializer<T>, FileSystem, SupplierWithException<Path, IOException>, MemorySegmentPool) - 类 的构造器org.apache.flink.iteration.datacache.nonkeyed.DataCacheWriter
 
DataCacheWriter(TypeSerializer<T>, FileSystem, SupplierWithException<Path, IOException>, List<Segment>) - 类 的构造器org.apache.flink.iteration.datacache.nonkeyed.DataCacheWriter
 
DataCacheWriter(TypeSerializer<T>, FileSystem, SupplierWithException<Path, IOException>, MemorySegmentPool, List<Segment>) - 类 的构造器org.apache.flink.iteration.datacache.nonkeyed.DataCacheWriter
 
DataStreamList - org.apache.flink.iteration中的类
A utility class to maintain a list of DataStream, which might have different types.
DataStreamList(List<DataStream<?>>) - 类 的构造器org.apache.flink.iteration.DataStreamList
 
deregisterKeySelectionListener(KeyedStateBackend.KeySelectionListener<K>) - 类 中的方法org.apache.flink.iteration.proxy.state.ProxyKeyedStateBackend
 
deserialize(DataInputView) - 类 中的方法org.apache.flink.iteration.typeinfo.IterationRecordSerializer
 
deserialize(IterationRecord<T>, DataInputView) - 类 中的方法org.apache.flink.iteration.typeinfo.IterationRecordSerializer
 
deserializeNumber(DataInputView) - 类 中的方法org.apache.flink.iteration.typeinfo.IterationRecordSerializer
 
dispose() - 类 中的方法org.apache.flink.iteration.proxy.state.ProxyKeyedStateBackend
 
dispose() - 类 中的方法org.apache.flink.iteration.proxy.state.ProxyOperatorStateBackend
 
DraftExecutionEnvironment - org.apache.flink.iteration.compile中的类
A specialized stream execution environment that allows users to first construct a subgraph and later copy the transformations into the actual environment.
DraftExecutionEnvironment(StreamExecutionEnvironment, OperatorWrapper<?, ?>) - 类 的构造器org.apache.flink.iteration.compile.DraftExecutionEnvironment
 
DraftExecutionEnvironment.EmptySource<T> - org.apache.flink.iteration.compile中的类
A special source that emits no data.
DraftTransformationTranslator<TF extends org.apache.flink.api.dag.Transformation<?>> - org.apache.flink.iteration.compile中的接口
Creates the actual transformation according to the draft transformation.
DraftTransformationTranslator.Context - org.apache.flink.iteration.compile中的接口
duplicate() - 类 中的方法org.apache.flink.iteration.typeinfo.IterationRecordSerializer
 

E

emitLatencyMarker(LatencyMarker) - 类 中的方法org.apache.flink.iteration.proxy.ProxyOutput
 
emitWatermark(Watermark) - 类 中的方法org.apache.flink.iteration.proxy.ProxyOutput
 
emitWatermarkStatus(WatermarkStatus) - 类 中的方法org.apache.flink.iteration.proxy.ProxyOutput
 
EmptySource() - 类 的构造器org.apache.flink.iteration.compile.DraftExecutionEnvironment.EmptySource
 
endInput(int) - 类 中的方法org.apache.flink.iteration.operator.AbstractWrapperOperator
 
endInput(int) - 类 中的方法org.apache.flink.iteration.operator.allround.MultipleInputAllRoundWrapperOperator
 
endInput() - 类 中的方法org.apache.flink.iteration.operator.allround.OneInputAllRoundWrapperOperator
 
endInput(int) - 类 中的方法org.apache.flink.iteration.operator.allround.TwoInputAllRoundWrapperOperator
 
endInput() - 类 中的方法org.apache.flink.iteration.operator.HeadOperator
 
endInput(int) - 类 中的方法org.apache.flink.iteration.operator.ReplayOperator
 
endInputAndEmitMaxWatermark(S, int, int) - 类 中的方法org.apache.flink.iteration.operator.perround.AbstractPerRoundWrapperOperator
 
endInputAndEmitMaxWatermark(MultipleInputStreamOperator<OUT>, int, int) - 类 中的方法org.apache.flink.iteration.operator.perround.MultipleInputPerRoundWrapperOperator
 
endInputAndEmitMaxWatermark(OneInputStreamOperator<IN, OUT>, int, int) - 类 中的方法org.apache.flink.iteration.operator.perround.OneInputPerRoundWrapperOperator
 
endInputAndEmitMaxWatermark(TwoInputStreamOperator<IN1, IN2, OUT>, int, int) - 类 中的方法org.apache.flink.iteration.operator.perround.TwoInputPerRoundWrapperOperator
 
EpochAware - org.apache.flink.iteration.operator.allround中的接口
Operators or UDF implements this method would be provided with an supplier that provides the current rounds of the current element.
EpochAwareAllRoundProcessFunction<I,O> - org.apache.flink.iteration.functions中的类
A specialized ProcessFunction that also provide the attach epoch with each record.
EpochAwareAllRoundProcessFunction() - 类 的构造器org.apache.flink.iteration.functions.EpochAwareAllRoundProcessFunction
 
EpochAwareCoProcessFunction<I1,I2,O> - org.apache.flink.iteration.functions中的类
A specialized CoProcessFunction that also provide the attach epoch with each record.
EpochAwareCoProcessFunction() - 类 的构造器org.apache.flink.iteration.functions.EpochAwareCoProcessFunction
 
epochWatermarkSupplier - 类 中的变量org.apache.flink.iteration.operator.AbstractWrapperOperator
 
epochWatermarkTracker - 类 中的变量org.apache.flink.iteration.operator.AbstractWrapperOperator
 
equals(Object) - 类 中的方法org.apache.flink.iteration.datacache.nonkeyed.Segment
 
equals(Object) - 类 中的方法org.apache.flink.iteration.IterationRecord
 
equals(Object) - 类 中的方法org.apache.flink.iteration.operator.event.CoordinatorCheckpointEvent
 
equals(Object) - 类 中的方法org.apache.flink.iteration.operator.event.GloballyAlignedEvent
 
equals(Object) - 类 中的方法org.apache.flink.iteration.operator.event.SubtaskAlignedEvent
 
equals(Object) - 类 中的方法org.apache.flink.iteration.typeinfo.IterationRecordSerializer
 
equals(Object) - 类 中的方法org.apache.flink.iteration.typeinfo.IterationRecordTypeInfo
 
eventBroadcastOutput - 类 中的变量org.apache.flink.iteration.operator.AbstractWrapperOperator
 
execute(StreamGraph) - 类 中的方法org.apache.flink.iteration.compile.DraftExecutionEnvironment
 

F

finish() - 类 中的方法org.apache.flink.iteration.datacache.nonkeyed.DataCacheWriter
Finishes adding records and closes resources occupied for adding records.
finish() - 类 中的方法org.apache.flink.iteration.operator.allround.AbstractAllRoundWrapperOperator
 
finish() - 类 中的方法org.apache.flink.iteration.operator.perround.AbstractPerRoundWrapperOperator
 
finish(int) - 类 中的方法org.apache.flink.iteration.progresstrack.OperatorEpochWatermarkTracker
 
FINISHED_STATE - 类 中的静态变量org.apache.flink.iteration.operator.headprocessor.HeadOperatorState
 
forEachRound(DataStreamList, IterationBody.PerRoundSubBody) - 接口 中的静态方法org.apache.flink.iteration.IterationBody
 

G

get() - 类 中的静态方法org.apache.flink.iteration.checkpoint.CheckpointsBroker
 
get() - 类 中的方法org.apache.flink.iteration.datacache.nonkeyed.ListStateWithCache
 
get(int) - 类 中的方法org.apache.flink.iteration.DataStreamList
Returns the data stream at the given index in this list.
getActualStream(int) - 类 中的方法org.apache.flink.iteration.compile.DraftExecutionEnvironment
 
getActualTransformation(int) - 接口 中的方法org.apache.flink.iteration.compile.DraftTransformationTranslator.Context
 
getArity() - 类 中的方法org.apache.flink.iteration.typeinfo.IterationRecordTypeInfo
 
getBroadcastingInternalOutputs(Object) - 类 中的方法org.apache.flink.iteration.broadcast.OutputReflectionContext
 
getBroadcastState(MapStateDescriptor<K, V>) - 类 中的方法org.apache.flink.iteration.proxy.state.ProxyOperatorStateBackend
 
getChainingOutputTag(Object) - 类 中的方法org.apache.flink.iteration.broadcast.OutputReflectionContext
 
getChainingStrategy() - 类 中的方法org.apache.flink.iteration.operator.HeadOperatorFactory
 
getCheckpointId() - 类 中的方法org.apache.flink.iteration.IterationRecord
 
getCheckpointId() - 类 中的方法org.apache.flink.iteration.operator.event.CoordinatorCheckpointEvent
 
getCheckpointId() - 类 中的方法org.apache.flink.iteration.proxy.state.ProxyStateSnapshotContext
 
getCheckpoints(SubtaskFeedbackKey<V>) - 类 中的方法org.apache.flink.iteration.checkpoint.CheckpointsBroker
 
getCheckpointTimestamp() - 类 中的方法org.apache.flink.iteration.proxy.state.ProxyStateSnapshotContext
 
getClassField(Class<?>, String) - 类 中的静态方法org.apache.flink.iteration.utils.ReflectionUtils
 
getCoordinatorProvider(String, OperatorID) - 类 中的方法org.apache.flink.iteration.operator.HeadOperatorFactory
 
getCurrentKey() - 类 中的方法org.apache.flink.iteration.operator.allround.AbstractAllRoundWrapperOperator
 
getCurrentKey() - 类 中的方法org.apache.flink.iteration.operator.perround.AbstractPerRoundWrapperOperator
 
getCurrentKey() - 类 中的方法org.apache.flink.iteration.proxy.state.ProxyKeyedStateBackend
 
getDataCachePath(Configuration, String[]) - 类 中的静态方法org.apache.flink.iteration.operator.OperatorUtils
 
getDataStreams() - 类 中的方法org.apache.flink.iteration.DataStreamList
Returns all the data streams as a native list.
getDownstreamSubtaskStateMapper() - 类 中的方法org.apache.flink.iteration.proxy.ProxyStreamPartitioner
 
getEpoch() - 类 中的方法org.apache.flink.iteration.IterationRecord
 
getEpoch() - 类 中的方法org.apache.flink.iteration.operator.event.GloballyAlignedEvent
 
getEpoch() - 类 中的方法org.apache.flink.iteration.operator.event.SubtaskAlignedEvent
 
getExecutionConfig() - 接口 中的方法org.apache.flink.iteration.compile.DraftTransformationTranslator.Context
 
getFeedbackVariableStreams() - 类 中的方法org.apache.flink.iteration.IterationBodyResult
 
getFieldValue(Object, Field) - 类 中的静态方法org.apache.flink.iteration.utils.ReflectionUtils
 
getFieldValue(Object, Class<?>, String) - 类 中的静态方法org.apache.flink.iteration.utils.ReflectionUtils
 
getFileSystem() - 类 中的方法org.apache.flink.iteration.checkpoint.Checkpoints
 
getFileSystem() - 类 中的方法org.apache.flink.iteration.datacache.nonkeyed.DataCacheSnapshot
 
getInnerSerializer() - 类 中的方法org.apache.flink.iteration.typeinfo.IterationRecordSerializer
 
getInnerTypeInfo() - 类 中的方法org.apache.flink.iteration.typeinfo.IterationRecordTypeInfo
 
getInputs() - 类 中的方法org.apache.flink.iteration.operator.allround.MultipleInputAllRoundWrapperOperator
 
getInputs() - 类 中的方法org.apache.flink.iteration.operator.perround.MultipleInputPerRoundWrapperOperator
 
getInternalTimerService(String, TypeSerializer<K>, TypeSerializer<N>, Triggerable<K, N>) - 类 中的方法org.apache.flink.iteration.proxy.state.ProxyInternalTimeServiceManager
 
getKey(IterationRecord<T>) - 类 中的方法org.apache.flink.iteration.proxy.ProxyKeySelector
 
getKeyGroupRange() - 类 中的方法org.apache.flink.iteration.proxy.state.ProxyKeyedStateBackend
 
getKeys(String, N) - 类 中的方法org.apache.flink.iteration.proxy.state.ProxyKeyedStateBackend
 
getKeysAndNamespaces(String) - 类 中的方法org.apache.flink.iteration.proxy.state.ProxyKeyedStateBackend
 
getKeySerializer() - 类 中的方法org.apache.flink.iteration.proxy.state.ProxyKeyedStateBackend
 
getLatestRoundAligned() - 类 中的方法org.apache.flink.iteration.operator.headprocessor.HeadOperatorState
 
getLatestRoundAligned() - 类 中的方法org.apache.flink.iteration.operator.headprocessor.RegularHeadOperatorRecordProcessor
 
getLatestRoundGloballyAligned() - 类 中的方法org.apache.flink.iteration.operator.headprocessor.HeadOperatorState
 
getLatestRoundGloballyAligned() - 类 中的方法org.apache.flink.iteration.operator.headprocessor.RegularHeadOperatorRecordProcessor
 
getLength() - 类 中的方法org.apache.flink.iteration.typeinfo.IterationRecordSerializer
 
getListState(ListStateDescriptor<S>) - 类 中的方法org.apache.flink.iteration.proxy.state.ProxyOperatorStateBackend
 
getMetricGroup() - 类 中的方法org.apache.flink.iteration.operator.allround.AbstractAllRoundWrapperOperator
 
getMetricGroup() - 类 中的方法org.apache.flink.iteration.operator.perround.AbstractPerRoundWrapperOperator
 
getNamePrefix() - 类 中的方法org.apache.flink.iteration.proxy.state.StateNamePrefix
 
getNumFeedbackRecordsEachRound() - 类 中的方法org.apache.flink.iteration.operator.headprocessor.HeadOperatorState
 
getNumFeedbackRecordsPerEpoch() - 类 中的方法org.apache.flink.iteration.operator.headprocessor.RegularHeadOperatorRecordProcessor
 
getNumRecordsThisRound() - 类 中的方法org.apache.flink.iteration.operator.event.SubtaskAlignedEvent
 
getOperatorEventGateway() - 类 中的方法org.apache.flink.iteration.operator.HeadOperator
 
getOperatorFactory() - 类 中的方法org.apache.flink.iteration.operator.WrapperOperatorFactory
 
getOperatorID() - 类 中的方法org.apache.flink.iteration.operator.allround.AbstractAllRoundWrapperOperator
 
getOperatorId() - 类 中的方法org.apache.flink.iteration.operator.coordinator.HeadOperatorCoordinator.HeadOperatorCoordinatorProvider
 
getOperatorID() - 类 中的方法org.apache.flink.iteration.operator.perround.AbstractPerRoundWrapperOperator
 
getOperatorLifeCycle() - 类 中的方法org.apache.flink.iteration.IterationConfig
 
getOrCreate(IterationID, int, OperatorCoordinator.Context, Supplier<Executor>) - 类 中的静态方法org.apache.flink.iteration.operator.coordinator.SharedProgressAligner
 
getOrCreateKeyedState(TypeSerializer<N>, StateDescriptor<S, T>) - 类 中的方法org.apache.flink.iteration.proxy.state.ProxyKeyedStateBackend
 
getOutputStreams() - 类 中的方法org.apache.flink.iteration.IterationBodyResult
 
getPartitionedState(N, TypeSerializer<N>, StateDescriptor<S, ?>) - 类 中的方法org.apache.flink.iteration.proxy.state.ProxyKeyedStateBackend
 
getPathSupplier() - 类 中的方法org.apache.flink.iteration.checkpoint.Checkpoints
 
getPosition() - 类 中的方法org.apache.flink.iteration.datacache.nonkeyed.DataCacheReader
 
getRawKeyedOperatorStateOutput() - 类 中的方法org.apache.flink.iteration.proxy.state.ProxyStateSnapshotContext
 
getRawOperatorStateOutput() - 类 中的方法org.apache.flink.iteration.proxy.state.ProxyStateSnapshotContext
 
getReaderPosition() - 类 中的方法org.apache.flink.iteration.datacache.nonkeyed.DataCacheSnapshot
 
getRecordWriter(Object) - 类 中的方法org.apache.flink.iteration.broadcast.OutputReflectionContext
 
getRecordWriterTypeSerializer(Object) - 类 中的方法org.apache.flink.iteration.broadcast.OutputReflectionContext
 
getRegisteredBroadcastStateNames() - 类 中的方法org.apache.flink.iteration.proxy.state.ProxyOperatorStateBackend
 
getRegisteredStateNames() - 类 中的方法org.apache.flink.iteration.proxy.state.ProxyOperatorStateBackend
 
getRestoredCheckpointId() - 类 中的方法org.apache.flink.iteration.proxy.state.ProxyStreamOperatorStateContext
 
getSegments() - 类 中的方法org.apache.flink.iteration.datacache.nonkeyed.DataCacheSnapshot
 
getSegments() - 类 中的方法org.apache.flink.iteration.datacache.nonkeyed.DataCacheWriter
Flushes all added records to segments and returns a list of segments containing all cached records.
getSender() - 类 中的方法org.apache.flink.iteration.IterationRecord
 
getStatus() - 类 中的方法org.apache.flink.iteration.operator.HeadOperator
 
getStreamConfig() - 接口 中的方法org.apache.flink.iteration.operator.headprocessor.HeadOperatorRecordProcessor.Context
 
getStreamOperatorClass(ClassLoader, StreamOperatorFactory<T>) - 类 中的方法org.apache.flink.iteration.operator.allround.AllRoundOperatorWrapper
 
getStreamOperatorClass(ClassLoader) - 类 中的方法org.apache.flink.iteration.operator.HeadOperatorFactory
 
getStreamOperatorClass(ClassLoader, StreamOperatorFactory<T>) - 接口 中的方法org.apache.flink.iteration.operator.OperatorWrapper
 
getStreamOperatorClass(ClassLoader, StreamOperatorFactory<T>) - 类 中的方法org.apache.flink.iteration.operator.perround.PerRoundOperatorWrapper
 
getStreamOperatorClass(ClassLoader) - 类 中的方法org.apache.flink.iteration.operator.WrapperOperatorFactory
 
getTaskInfo() - 接口 中的方法org.apache.flink.iteration.operator.headprocessor.HeadOperatorRecordProcessor.Context
 
getTerminationCriteria() - 类 中的方法org.apache.flink.iteration.IterationBodyResult
 
getTotalFields() - 类 中的方法org.apache.flink.iteration.typeinfo.IterationRecordTypeInfo
 
getType() - 类 中的方法org.apache.flink.iteration.IterationRecord
 
getTypeClass() - 类 中的方法org.apache.flink.iteration.typeinfo.IterationRecordTypeInfo
 
getTypeSerializer() - 类 中的方法org.apache.flink.iteration.checkpoint.Checkpoints
 
getUnionListState(ListStateDescriptor<S>) - 类 中的方法org.apache.flink.iteration.proxy.state.ProxyOperatorStateBackend
 
getUniqueElement(ListState<T>, String) - 类 中的静态方法org.apache.flink.iteration.operator.OperatorStateUtils
 
getUniqueSenderId(OperatorID, int) - 类 中的静态方法org.apache.flink.iteration.operator.OperatorUtils
Returns the unique id for the specified operator.
getValue() - 类 中的方法org.apache.flink.iteration.IterationRecord
 
getWrappedKeySelector() - 类 中的方法org.apache.flink.iteration.proxy.ProxyKeySelector
 
getWrappedOperator(int) - 类 中的方法org.apache.flink.iteration.operator.perround.AbstractPerRoundWrapperOperator
 
getWrappedOperator(int) - 类 中的方法org.apache.flink.iteration.operator.perround.MultipleInputPerRoundWrapperOperator
 
getWrappedOperators() - 类 中的方法org.apache.flink.iteration.operator.perround.AbstractPerRoundWrapperOperator
 
getWrappedTypeInfo(TypeInformation<T>) - 类 中的方法org.apache.flink.iteration.operator.allround.AllRoundOperatorWrapper
 
getWrappedTypeInfo(TypeInformation<T>) - 接口 中的方法org.apache.flink.iteration.operator.OperatorWrapper
 
getWrappedTypeInfo(TypeInformation<T>) - 类 中的方法org.apache.flink.iteration.operator.perround.PerRoundOperatorWrapper
 
getWrapper() - 类 中的方法org.apache.flink.iteration.operator.WrapperOperatorFactory
 
GloballyAlignedEvent - org.apache.flink.iteration.operator.event中的类
The event sent from HeadOperatorCoordinator to HeadOperator to notify a round is globally aligned and whether the iteration should terminate.
GloballyAlignedEvent(int, boolean) - 类 的构造器org.apache.flink.iteration.operator.event.GloballyAlignedEvent
 

H

handleEventFromOperator(int, OperatorEvent) - 类 中的方法org.apache.flink.iteration.operator.coordinator.HeadOperatorCoordinator
 
handleOperatorEvent(OperatorEvent) - 类 中的方法org.apache.flink.iteration.operator.HeadOperator
 
hashCode() - 类 中的方法org.apache.flink.iteration.datacache.nonkeyed.Segment
 
hashCode() - 类 中的方法org.apache.flink.iteration.IterationRecord
 
hashCode() - 类 中的方法org.apache.flink.iteration.operator.event.CoordinatorCheckpointEvent
 
hashCode() - 类 中的方法org.apache.flink.iteration.operator.event.GloballyAlignedEvent
 
hashCode() - 类 中的方法org.apache.flink.iteration.operator.event.SubtaskAlignedEvent
 
hashCode() - 类 中的方法org.apache.flink.iteration.typeinfo.IterationRecordSerializer
 
hashCode() - 类 中的方法org.apache.flink.iteration.typeinfo.IterationRecordTypeInfo
 
hasNext() - 类 中的方法org.apache.flink.iteration.datacache.nonkeyed.DataCacheReader
 
HeadOperator - org.apache.flink.iteration.operator中的类
The head operator unions the initialized variable stream and the feedback stream, synchronize the epoch watermark (round) and taking care of the checkpoints.
HeadOperator(IterationID, int, boolean, MailboxExecutor, OperatorEventGateway, ProcessingTimeService) - 类 的构造器org.apache.flink.iteration.operator.HeadOperator
 
HeadOperatorCoordinator - org.apache.flink.iteration.operator.coordinator中的类
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(OperatorCoordinator.Context, SharedProgressAligner) - 类 的构造器org.apache.flink.iteration.operator.coordinator.HeadOperatorCoordinator
 
HeadOperatorCoordinator.HeadOperatorCoordinatorProvider - org.apache.flink.iteration.operator.coordinator中的类
The factory of HeadOperatorCoordinator.
HeadOperatorCoordinatorProvider(OperatorID, IterationID, int) - 类 的构造器org.apache.flink.iteration.operator.coordinator.HeadOperatorCoordinator.HeadOperatorCoordinatorProvider
 
HeadOperatorFactory - org.apache.flink.iteration.operator中的类
The Factory for the HeadOperator.
HeadOperatorFactory(IterationID, int, boolean, int) - 类 的构造器org.apache.flink.iteration.operator.HeadOperatorFactory
 
HeadOperatorRecordProcessor - org.apache.flink.iteration.operator.headprocessor中的接口
The component to actually deal with the event received in the HeadOperator.
HeadOperatorRecordProcessor.Context - org.apache.flink.iteration.operator.headprocessor中的接口
HeadOperatorState - org.apache.flink.iteration.operator.headprocessor中的类
The state entry for the head operator.
HeadOperatorState(Map<Integer, Long>, int, int) - 类 的构造器org.apache.flink.iteration.operator.headprocessor.HeadOperatorState
 

I

incrementEpoch() - 类 中的方法org.apache.flink.iteration.IterationRecord
 
initializeState(StreamTaskStateInitializer) - 类 中的方法org.apache.flink.iteration.operator.allround.AbstractAllRoundWrapperOperator
 
initializeState(StateInitializationContext) - 类 中的方法org.apache.flink.iteration.operator.HeadOperator
 
initializeState(HeadOperatorState, Iterable<StatePartitionStreamProvider>) - 接口 中的方法org.apache.flink.iteration.operator.headprocessor.HeadOperatorRecordProcessor
 
initializeState(HeadOperatorState, Iterable<StatePartitionStreamProvider>) - 类 中的方法org.apache.flink.iteration.operator.headprocessor.RegularHeadOperatorRecordProcessor
 
initializeState(HeadOperatorState, Iterable<StatePartitionStreamProvider>) - 类 中的方法org.apache.flink.iteration.operator.headprocessor.TerminatingHeadOperatorRecordProcessor
 
initializeState(StreamTaskStateInitializer) - 类 中的方法org.apache.flink.iteration.operator.perround.AbstractPerRoundWrapperOperator
 
initializeState(StateInitializationContext) - 类 中的方法org.apache.flink.iteration.operator.perround.AbstractPerRoundWrapperOperator
 
initializeState(StateInitializationContext) - 类 中的方法org.apache.flink.iteration.operator.ReplayOperator
 
InputOperator<T> - org.apache.flink.iteration.operator中的类
Input operator that wraps the user record into IterationRecord.
InputOperator() - 类 的构造器org.apache.flink.iteration.operator.InputOperator
 
INSTANCE - 类 中的静态变量org.apache.flink.iteration.operator.event.TerminatingOnInitializeEvent
 
instances - 类 中的静态变量org.apache.flink.iteration.operator.coordinator.SharedProgressAligner
 
internalTimerServiceManager() - 类 中的方法org.apache.flink.iteration.proxy.state.ProxyStreamOperatorStateContext
 
isBasicType() - 类 中的方法org.apache.flink.iteration.typeinfo.IterationRecordTypeInfo
 
isBroadcastingOutput(Output<?>) - 类 中的方法org.apache.flink.iteration.broadcast.OutputReflectionContext
 
isChainingOutput(Output<?>) - 类 中的方法org.apache.flink.iteration.broadcast.OutputReflectionContext
 
isCriteriaStream() - 类 中的方法org.apache.flink.iteration.operator.event.SubtaskAlignedEvent
 
isImmutableType() - 类 中的方法org.apache.flink.iteration.typeinfo.IterationRecordSerializer
 
isKeyType() - 类 中的方法org.apache.flink.iteration.typeinfo.IterationRecordTypeInfo
 
isPointwise() - 类 中的方法org.apache.flink.iteration.proxy.ProxyStreamPartitioner
 
isRecordWriterOutput(Output<?>) - 类 中的方法org.apache.flink.iteration.broadcast.OutputReflectionContext
 
isRestored() - 类 中的方法org.apache.flink.iteration.proxy.state.ProxyStreamOperatorStateContext
 
isTerminated() - 类 中的方法org.apache.flink.iteration.operator.event.GloballyAlignedEvent
 
isTupleType() - 类 中的方法org.apache.flink.iteration.typeinfo.IterationRecordTypeInfo
 
isUsingCustomRawKeyedState() - 类 中的方法org.apache.flink.iteration.operator.perround.AbstractPerRoundWrapperOperator
 
iterateBoundedStreamsUntilTermination(DataStreamList, ReplayableDataStreamList, IterationConfig, IterationBody) - 类 中的静态方法org.apache.flink.iteration.Iterations
This method uses an iteration body to process records in some bounded data streams iteratively until no more records are iterating or the given terminating criteria stream is empty in one round.
iterateUnboundedStreams(DataStreamList, DataStreamList, IterationBody) - 类 中的静态方法org.apache.flink.iteration.Iterations
This method uses an iteration body to process records in possibly unbounded data streams.
IterationBody - org.apache.flink.iteration中的接口
The builder of the subgraph that will be executed inside the iteration.
IterationBody.PerRoundSubBody - org.apache.flink.iteration中的接口
The sub-graph inside the iteration body that should be executed as per-round.
IterationBodyResult - org.apache.flink.iteration中的类
The result of an iteration, specifying the feedbacks and the outputs.
IterationBodyResult(DataStreamList, DataStreamList) - 类 的构造器org.apache.flink.iteration.IterationBodyResult
 
IterationBodyResult(DataStreamList, DataStreamList, DataStream<?>) - 类 的构造器org.apache.flink.iteration.IterationBodyResult
 
IterationConfig - org.apache.flink.iteration中的类
The config for an iteration.
IterationConfig(IterationConfig.OperatorLifeCycle) - 类 的构造器org.apache.flink.iteration.IterationConfig
 
IterationConfig.IterationConfigBuilder - org.apache.flink.iteration中的类
The builder of the IterationConfig.
IterationConfig.OperatorLifeCycle - org.apache.flink.iteration中的枚举
LifeCycles of the operator inside the iteration.
iterationContext - 类 中的变量org.apache.flink.iteration.operator.AbstractWrapperOperator
 
IterationID - org.apache.flink.iteration中的类
The id of a single iteration instance in the job graph.
IterationID(byte[]) - 类 的构造器org.apache.flink.iteration.IterationID
 
IterationID() - 类 的构造器org.apache.flink.iteration.IterationID
 
IterationListener<T> - org.apache.flink.iteration中的接口
The callbacks which will be invoked if the operator or UDF inside iteration implement this interface.
IterationListener.Context - org.apache.flink.iteration中的接口
Information available in an invocation of the callbacks defined in the IterationProgressListener.
IterationOptions - org.apache.flink.iteration.config中的类
The options for the iteration.
IterationOptions() - 类 的构造器org.apache.flink.iteration.config.IterationOptions
 
IterationRecord<T> - org.apache.flink.iteration中的类
The wrapper for the records in iterative stream.
IterationRecord.Type - org.apache.flink.iteration中的枚举
The type of iteration records.
IterationRecordSerializer<T> - org.apache.flink.iteration.typeinfo中的类
The type serializer for IterationRecord.
IterationRecordSerializer(TypeSerializer<T>) - 类 的构造器org.apache.flink.iteration.typeinfo.IterationRecordSerializer
 
IterationRecordTypeInfo<T> - org.apache.flink.iteration.typeinfo中的类
The type information for IterationRecord.
IterationRecordTypeInfo(TypeInformation<T>) - 类 的构造器org.apache.flink.iteration.typeinfo.IterationRecordTypeInfo
 
Iterations - org.apache.flink.iteration中的类
A helper class to create iterations.
Iterations() - 类 的构造器org.apache.flink.iteration.Iterations
 

K

KeyedBroadcastStateTransformationTranslator - org.apache.flink.iteration.compile.translator中的类
Draft translator for the KeyedBroadcastStateTransformation.
KeyedBroadcastStateTransformationTranslator() - 类 的构造器org.apache.flink.iteration.compile.translator.KeyedBroadcastStateTransformationTranslator
 
KeyedMultipleInputTransformationTranslator - org.apache.flink.iteration.compile.translator中的类
Draft translator for the KeyedMultipleInputTransformation.
KeyedMultipleInputTransformationTranslator() - 类 的构造器org.apache.flink.iteration.compile.translator.KeyedMultipleInputTransformationTranslator
 
keyedStateBackend() - 类 中的方法org.apache.flink.iteration.proxy.state.ProxyStreamOperatorStateContext
 

L

latencyStats - 类 中的变量org.apache.flink.iteration.operator.perround.AbstractPerRoundWrapperOperator
 
ListStateWithCache<T> - org.apache.flink.iteration.datacache.nonkeyed中的类
A ListState child class that records data and replays them when required.
ListStateWithCache(TypeSerializer<T>, StreamTask<?, ?>, StreamingRuntimeContext, StateInitializationContext, OperatorID) - 类 的构造器org.apache.flink.iteration.datacache.nonkeyed.ListStateWithCache
 
LOG - 类 中的静态变量org.apache.flink.iteration.operator.headprocessor.RegularHeadOperatorRecordProcessor
 

M

metrics - 类 中的变量org.apache.flink.iteration.operator.AbstractWrapperOperator
Metric group for the operator.
MultipleInputAllRoundWrapperOperator<OUT> - org.apache.flink.iteration.operator.allround中的类
All-round wrapper for the multiple-inputs operator.
MultipleInputAllRoundWrapperOperator(StreamOperatorParameters<IterationRecord<OUT>>, StreamOperatorFactory<OUT>) - 类 的构造器org.apache.flink.iteration.operator.allround.MultipleInputAllRoundWrapperOperator
 
MultipleInputPerRoundWrapperOperator<OUT> - org.apache.flink.iteration.operator.perround中的类
Per-round wrapper for the multiple-inputs operator.
MultipleInputPerRoundWrapperOperator(StreamOperatorParameters<IterationRecord<OUT>>, StreamOperatorFactory<OUT>) - 类 的构造器org.apache.flink.iteration.operator.perround.MultipleInputPerRoundWrapperOperator
 
MultipleInputTransformationTranslator - org.apache.flink.iteration.compile.translator中的类
Draft translator for the MultipleInputTransformation.
MultipleInputTransformationTranslator() - 类 的构造器org.apache.flink.iteration.compile.translator.MultipleInputTransformationTranslator
 

N

newBarrier(long) - 类 中的静态方法org.apache.flink.iteration.IterationRecord
 
newBuilder() - 类 中的静态方法org.apache.flink.iteration.IterationConfig
 
newEpochWatermark(int, String) - 类 中的静态方法org.apache.flink.iteration.IterationRecord
 
newRecord(T, int) - 类 中的静态方法org.apache.flink.iteration.IterationRecord
 
next() - 类 中的方法org.apache.flink.iteration.datacache.nonkeyed.DataCacheReader
 
NonReplayedDataStreamList(List<DataStream<?>>) - 类 的构造器org.apache.flink.iteration.ReplayableDataStreamList.NonReplayedDataStreamList
 
notifyCheckpointAborted(long) - 类 中的方法org.apache.flink.iteration.operator.allround.AbstractAllRoundWrapperOperator
 
notifyCheckpointAborted(long) - 类 中的方法org.apache.flink.iteration.operator.HeadOperator
 
notifyCheckpointAborted(long) - 类 中的方法org.apache.flink.iteration.operator.perround.AbstractPerRoundWrapperOperator
 
notifyCheckpointAborted(long) - 类 中的方法org.apache.flink.iteration.operator.TailOperator
 
notifyCheckpointComplete(long) - 类 中的方法org.apache.flink.iteration.operator.allround.AbstractAllRoundWrapperOperator
 
notifyCheckpointComplete(long) - 类 中的方法org.apache.flink.iteration.operator.coordinator.HeadOperatorCoordinator
 
notifyCheckpointComplete(long) - 类 中的方法org.apache.flink.iteration.operator.perround.AbstractPerRoundWrapperOperator
 
notifyEpochWatermarkIncrement(IterationListener<?>, int) - 类 中的方法org.apache.flink.iteration.operator.AbstractWrapperOperator
 
notifyGloballyTerminating() - 类 中的方法org.apache.flink.iteration.operator.coordinator.SharedProgressAligner
 
notifyTerminatingOnInitialize() - 接口 中的方法org.apache.flink.iteration.operator.headprocessor.HeadOperatorRecordProcessor.Context
 
notReplay(DataStream<?>...) - 类 中的静态方法org.apache.flink.iteration.ReplayableDataStreamList
 

O

of(DataStream<?>...) - 类 中的静态方法org.apache.flink.iteration.DataStreamList
 
onAligned(GloballyAlignedEvent) - 类 中的方法org.apache.flink.iteration.operator.coordinator.HeadOperatorCoordinator
 
onAligned(GloballyAlignedEvent) - 接口 中的方法org.apache.flink.iteration.operator.coordinator.SharedProgressAlignerListener
 
onCheckpointAligned(CoordinatorCheckpointEvent) - 类 中的方法org.apache.flink.iteration.operator.coordinator.HeadOperatorCoordinator
 
onCheckpointAligned(CoordinatorCheckpointEvent) - 接口 中的方法org.apache.flink.iteration.operator.coordinator.SharedProgressAlignerListener
 
OneInputAllRoundWrapperOperator<IN,OUT> - org.apache.flink.iteration.operator.allround中的类
All-round wrapper for the one-input operator.
OneInputAllRoundWrapperOperator(StreamOperatorParameters<IterationRecord<OUT>>, StreamOperatorFactory<OUT>) - 类 的构造器org.apache.flink.iteration.operator.allround.OneInputAllRoundWrapperOperator
 
OneInputPerRoundWrapperOperator<IN,OUT> - org.apache.flink.iteration.operator.perround中的类
Per-round wrapper operator for the one-input operator.
OneInputPerRoundWrapperOperator(StreamOperatorParameters<IterationRecord<OUT>>, StreamOperatorFactory<OUT>) - 类 的构造器org.apache.flink.iteration.operator.perround.OneInputPerRoundWrapperOperator
 
OneInputTransformationTranslator - org.apache.flink.iteration.compile.translator中的类
Draft translator for the OneInputTransformation.
OneInputTransformationTranslator() - 类 的构造器org.apache.flink.iteration.compile.translator.OneInputTransformationTranslator
 
onEpochWatermark(int, String, int) - 类 中的方法org.apache.flink.iteration.progresstrack.OperatorEpochWatermarkTracker
 
onEpochWatermarkEvent(int, IterationRecord<?>) - 类 中的方法org.apache.flink.iteration.operator.AbstractWrapperOperator
 
onEpochWatermarkIncrement(int) - 类 中的方法org.apache.flink.iteration.operator.AbstractWrapperOperator
 
onEpochWatermarkIncrement(int) - 类 中的方法org.apache.flink.iteration.operator.allround.AbstractAllRoundWrapperOperator
 
onEpochWatermarkIncrement(int) - 类 中的方法org.apache.flink.iteration.operator.perround.AbstractPerRoundWrapperOperator
 
onEpochWatermarkIncrement(int) - 类 中的方法org.apache.flink.iteration.operator.ReplayOperator
 
onEpochWatermarkIncrement(int) - 接口 中的方法org.apache.flink.iteration.progresstrack.OperatorEpochWatermarkTrackerListener
Notifies a new round is aligned to a new epoch watermark.
onEpochWatermarkIncremented(int, IterationListener.Context, Collector<T>) - 接口 中的方法org.apache.flink.iteration.IterationListener
This callback is invoked every time the epoch watermark of this operator increments.
onGloballyAligned(GloballyAlignedEvent) - 接口 中的方法org.apache.flink.iteration.operator.headprocessor.HeadOperatorRecordProcessor
 
onGloballyAligned(GloballyAlignedEvent) - 类 中的方法org.apache.flink.iteration.operator.headprocessor.RegularHeadOperatorRecordProcessor
 
onGloballyAligned(GloballyAlignedEvent) - 类 中的方法org.apache.flink.iteration.operator.headprocessor.TerminatingHeadOperatorRecordProcessor
 
onIterationTerminated(IterationListener.Context, Collector<T>) - 接口 中的方法org.apache.flink.iteration.IterationListener
This callback is invoked after the execution of the iteration body has terminated.
open() - 类 中的方法org.apache.flink.iteration.operator.allround.AbstractAllRoundWrapperOperator
 
open() - 类 中的方法org.apache.flink.iteration.operator.InputOperator
 
open() - 类 中的方法org.apache.flink.iteration.operator.OutputOperator
 
open() - 类 中的方法org.apache.flink.iteration.operator.perround.AbstractPerRoundWrapperOperator
 
open() - 类 中的方法org.apache.flink.iteration.operator.TailOperator
 
OperatorEpochWatermarkTracker - org.apache.flink.iteration.progresstrack中的类
Tracks the epoch watermark from each input.
OperatorEpochWatermarkTrackerFactory - org.apache.flink.iteration.progresstrack中的类
OperatorEpochWatermarkTrackerFactory() - 类 的构造器org.apache.flink.iteration.progresstrack.OperatorEpochWatermarkTrackerFactory
 
OperatorEpochWatermarkTrackerListener - org.apache.flink.iteration.progresstrack中的接口
The listener of alignment.
operatorFactory - 类 中的变量org.apache.flink.iteration.operator.AbstractWrapperOperator
 
operatorStateBackend() - 类 中的方法org.apache.flink.iteration.proxy.state.ProxyStreamOperatorStateContext
 
OperatorStateUtils - org.apache.flink.iteration.operator中的类
Utility to deal with the states inside the operator.
OperatorStateUtils() - 类 的构造器org.apache.flink.iteration.operator.OperatorStateUtils
 
OperatorUtils - org.apache.flink.iteration.operator中的类
Utility class for operators.
OperatorUtils() - 类 的构造器org.apache.flink.iteration.operator.OperatorUtils
 
OperatorWrapper<T,R> - org.apache.flink.iteration.operator中的接口
Wrappers for the given operator factory.
org.apache.flink.iteration - 程序包 org.apache.flink.iteration
 
org.apache.flink.iteration.broadcast - 程序包 org.apache.flink.iteration.broadcast
 
org.apache.flink.iteration.checkpoint - 程序包 org.apache.flink.iteration.checkpoint
 
org.apache.flink.iteration.compile - 程序包 org.apache.flink.iteration.compile
 
org.apache.flink.iteration.compile.translator - 程序包 org.apache.flink.iteration.compile.translator
 
org.apache.flink.iteration.config - 程序包 org.apache.flink.iteration.config
 
org.apache.flink.iteration.datacache.nonkeyed - 程序包 org.apache.flink.iteration.datacache.nonkeyed
 
org.apache.flink.iteration.functions - 程序包 org.apache.flink.iteration.functions
 
org.apache.flink.iteration.operator - 程序包 org.apache.flink.iteration.operator
 
org.apache.flink.iteration.operator.allround - 程序包 org.apache.flink.iteration.operator.allround
 
org.apache.flink.iteration.operator.coordinator - 程序包 org.apache.flink.iteration.operator.coordinator
 
org.apache.flink.iteration.operator.event - 程序包 org.apache.flink.iteration.operator.event
 
org.apache.flink.iteration.operator.headprocessor - 程序包 org.apache.flink.iteration.operator.headprocessor
 
org.apache.flink.iteration.operator.perround - 程序包 org.apache.flink.iteration.operator.perround
 
org.apache.flink.iteration.progresstrack - 程序包 org.apache.flink.iteration.progresstrack
 
org.apache.flink.iteration.proxy - 程序包 org.apache.flink.iteration.proxy
 
org.apache.flink.iteration.proxy.state - 程序包 org.apache.flink.iteration.proxy.state
 
org.apache.flink.iteration.typeinfo - 程序包 org.apache.flink.iteration.typeinfo
 
org.apache.flink.iteration.utils - 程序包 org.apache.flink.iteration.utils
 
output(OutputTag<X>, X) - 接口 中的方法org.apache.flink.iteration.IterationListener.Context
Emits a record to the side output identified by the OutputTag.
output - 类 中的变量org.apache.flink.iteration.operator.AbstractWrapperOperator
 
output(StreamRecord<IterationRecord<?>>) - 接口 中的方法org.apache.flink.iteration.operator.headprocessor.HeadOperatorRecordProcessor.Context
 
output(OutputTag<IterationRecord<?>>, StreamRecord<IterationRecord<?>>) - 接口 中的方法org.apache.flink.iteration.operator.headprocessor.HeadOperatorRecordProcessor.Context
 
OutputOperator<T> - org.apache.flink.iteration.operator中的类
Output operator that unwraps IterationRecord into user record, and desert all the event records.
OutputOperator() - 类 的构造器org.apache.flink.iteration.operator.OutputOperator
 
OutputReflectionContext - org.apache.flink.iteration.broadcast中的类
The reflection utilities to parse the output and create the broadcast output.
OutputReflectionContext() - 类 的构造器org.apache.flink.iteration.broadcast.OutputReflectionContext
 

P

parameters - 类 中的变量org.apache.flink.iteration.operator.AbstractWrapperOperator
 
PartitionTransformationTranslator - org.apache.flink.iteration.compile.translator中的类
Draft translator for the PartitionTransformation.
PartitionTransformationTranslator() - 类 的构造器org.apache.flink.iteration.compile.translator.PartitionTransformationTranslator
 
PerRoundOperatorWrapper<T> - org.apache.flink.iteration.operator.perround中的类
The operator wrapper implementation for per-round wrappers.
PerRoundOperatorWrapper() - 类 的构造器org.apache.flink.iteration.operator.perround.PerRoundOperatorWrapper
 
prefix(String) - 类 中的方法org.apache.flink.iteration.proxy.state.StateNamePrefix
 
prepareSnapshotPreBarrier(long) - 类 中的方法org.apache.flink.iteration.operator.allround.AbstractAllRoundWrapperOperator
 
prepareSnapshotPreBarrier(long) - 类 中的方法org.apache.flink.iteration.operator.HeadOperator
 
prepareSnapshotPreBarrier(long) - 类 中的方法org.apache.flink.iteration.operator.perround.AbstractPerRoundWrapperOperator
 
prepareSnapshotPreBarrier(long) - 类 中的方法org.apache.flink.iteration.operator.TailOperator
 
process(DataStreamList) - 接口 中的方法org.apache.flink.iteration.IterationBody.PerRoundSubBody
 
process(DataStreamList, DataStreamList) - 接口 中的方法org.apache.flink.iteration.IterationBody
This method creates the graph for the iteration body.
processElement(I, ProcessFunction<I, O>.Context, Collector<O>) - 类 中的方法org.apache.flink.iteration.functions.EpochAwareAllRoundProcessFunction
 
processElement(I, int, ProcessFunction<I, O>.Context, Collector<O>) - 类 中的方法org.apache.flink.iteration.functions.EpochAwareAllRoundProcessFunction
 
processElement(StreamRecord<IterationRecord<IN>>) - 类 中的方法org.apache.flink.iteration.operator.allround.OneInputAllRoundWrapperOperator
 
processElement(StreamRecord<IterationRecord<?>>) - 类 中的方法org.apache.flink.iteration.operator.HeadOperator
 
processElement(StreamRecord<IterationRecord<?>>) - 接口 中的方法org.apache.flink.iteration.operator.headprocessor.HeadOperatorRecordProcessor
 
processElement(StreamRecord<IterationRecord<?>>) - 类 中的方法org.apache.flink.iteration.operator.headprocessor.RegularHeadOperatorRecordProcessor
 
processElement(StreamRecord<IterationRecord<?>>) - 类 中的方法org.apache.flink.iteration.operator.headprocessor.TerminatingHeadOperatorRecordProcessor
 
processElement(StreamRecord<T>) - 类 中的方法org.apache.flink.iteration.operator.InputOperator
 
processElement(StreamRecord<IterationRecord<T>>) - 类 中的方法org.apache.flink.iteration.operator.OutputOperator
 
processElement(StreamRecord<IterationRecord<IN>>) - 类 中的方法org.apache.flink.iteration.operator.perround.OneInputPerRoundWrapperOperator
 
processElement(StreamRecord<IterationRecord<?>>) - 类 中的方法org.apache.flink.iteration.operator.TailOperator
 
processElement1(I1, CoProcessFunction<I1, I2, O>.Context, Collector<O>) - 类 中的方法org.apache.flink.iteration.functions.EpochAwareCoProcessFunction
 
processElement1(I1, int, CoProcessFunction<I1, I2, O>.Context, Collector<O>) - 类 中的方法org.apache.flink.iteration.functions.EpochAwareCoProcessFunction
 
processElement1(StreamRecord<IterationRecord<IN1>>) - 类 中的方法org.apache.flink.iteration.operator.allround.TwoInputAllRoundWrapperOperator
 
processElement1(StreamRecord<IterationRecord<IN1>>) - 类 中的方法org.apache.flink.iteration.operator.perround.TwoInputPerRoundWrapperOperator
 
processElement1(StreamRecord<IterationRecord<T>>) - 类 中的方法org.apache.flink.iteration.operator.ReplayOperator
 
processElement2(I2, CoProcessFunction<I1, I2, O>.Context, Collector<O>) - 类 中的方法org.apache.flink.iteration.functions.EpochAwareCoProcessFunction
 
processElement2(I2, int, CoProcessFunction<I1, I2, O>.Context, Collector<O>) - 类 中的方法org.apache.flink.iteration.functions.EpochAwareCoProcessFunction
 
processElement2(StreamRecord<IterationRecord<IN2>>) - 类 中的方法org.apache.flink.iteration.operator.allround.TwoInputAllRoundWrapperOperator
 
processElement2(StreamRecord<IterationRecord<IN2>>) - 类 中的方法org.apache.flink.iteration.operator.perround.TwoInputPerRoundWrapperOperator
 
processElement2(StreamRecord<IterationRecord<Void>>) - 类 中的方法org.apache.flink.iteration.operator.ReplayOperator
 
processFeedback(StreamRecord<IterationRecord<?>>) - 类 中的方法org.apache.flink.iteration.operator.HeadOperator
 
processFeedbackElement(StreamRecord<IterationRecord<?>>) - 接口 中的方法org.apache.flink.iteration.operator.headprocessor.HeadOperatorRecordProcessor
 
processFeedbackElement(StreamRecord<IterationRecord<?>>) - 类 中的方法org.apache.flink.iteration.operator.headprocessor.RegularHeadOperatorRecordProcessor
 
processFeedbackElement(StreamRecord<IterationRecord<?>>) - 类 中的方法org.apache.flink.iteration.operator.headprocessor.TerminatingHeadOperatorRecordProcessor
 
processForEachWrappedOperator(BiConsumerWithException<Integer, S, Exception>) - 类 中的方法org.apache.flink.iteration.operator.perround.AbstractPerRoundWrapperOperator
 
processLatencyMarker(LatencyMarker) - 类 中的方法org.apache.flink.iteration.operator.allround.OneInputAllRoundWrapperOperator
 
processLatencyMarker(LatencyMarker) - 类 中的方法org.apache.flink.iteration.operator.perround.OneInputPerRoundWrapperOperator
 
processLatencyMarker1(LatencyMarker) - 类 中的方法org.apache.flink.iteration.operator.allround.TwoInputAllRoundWrapperOperator
 
processLatencyMarker1(LatencyMarker) - 类 中的方法org.apache.flink.iteration.operator.perround.TwoInputPerRoundWrapperOperator
 
processLatencyMarker2(LatencyMarker) - 类 中的方法org.apache.flink.iteration.operator.allround.TwoInputAllRoundWrapperOperator
 
processLatencyMarker2(LatencyMarker) - 类 中的方法org.apache.flink.iteration.operator.perround.TwoInputPerRoundWrapperOperator
 
processOperatorOrUdfIfSatisfy(StreamOperator<?>, Class<T>, ThrowingConsumer<T, Exception>) - 类 中的静态方法org.apache.flink.iteration.operator.OperatorUtils
 
processWatermark(Watermark) - 类 中的方法org.apache.flink.iteration.operator.allround.OneInputAllRoundWrapperOperator
 
processWatermark(Watermark) - 类 中的方法org.apache.flink.iteration.operator.perround.OneInputPerRoundWrapperOperator
 
processWatermark1(Watermark) - 类 中的方法org.apache.flink.iteration.operator.allround.TwoInputAllRoundWrapperOperator
 
processWatermark1(Watermark) - 类 中的方法org.apache.flink.iteration.operator.perround.TwoInputPerRoundWrapperOperator
 
processWatermark2(Watermark) - 类 中的方法org.apache.flink.iteration.operator.allround.TwoInputAllRoundWrapperOperator
 
processWatermark2(Watermark) - 类 中的方法org.apache.flink.iteration.operator.perround.TwoInputPerRoundWrapperOperator
 
processWatermarkStatus(WatermarkStatus) - 类 中的方法org.apache.flink.iteration.operator.allround.OneInputAllRoundWrapperOperator
 
processWatermarkStatus(WatermarkStatus) - 类 中的方法org.apache.flink.iteration.operator.perround.OneInputPerRoundWrapperOperator
 
processWatermarkStatus1(WatermarkStatus) - 类 中的方法org.apache.flink.iteration.operator.allround.TwoInputAllRoundWrapperOperator
 
processWatermarkStatus1(WatermarkStatus) - 类 中的方法org.apache.flink.iteration.operator.perround.TwoInputPerRoundWrapperOperator
 
processWatermarkStatus2(WatermarkStatus) - 类 中的方法org.apache.flink.iteration.operator.allround.TwoInputAllRoundWrapperOperator
 
processWatermarkStatus2(WatermarkStatus) - 类 中的方法org.apache.flink.iteration.operator.perround.TwoInputPerRoundWrapperOperator
 
ProxyInternalTimeServiceManager<K> - org.apache.flink.iteration.proxy.state中的类
Proxy InternalTimeServiceManager for the wrapped operators.
ProxyInternalTimeServiceManager(InternalTimeServiceManager<K>, StateNamePrefix) - 类 的构造器org.apache.flink.iteration.proxy.state.ProxyInternalTimeServiceManager
 
ProxyKeyedStateBackend<K> - org.apache.flink.iteration.proxy.state中的类
Proxy KeyedStateBackend for the wrapped operators.
ProxyKeyedStateBackend(CheckpointableKeyedStateBackend<K>, StateNamePrefix) - 类 的构造器org.apache.flink.iteration.proxy.state.ProxyKeyedStateBackend
 
ProxyKeySelector<T,KEY> - org.apache.flink.iteration.proxy中的类
Proxy key selector for the wrapped one.
ProxyKeySelector(KeySelector<T, KEY>) - 类 的构造器org.apache.flink.iteration.proxy.ProxyKeySelector
 
ProxyOperatorStateBackend - org.apache.flink.iteration.proxy.state中的类
Proxy OperatorStateBackend for the wrapped Operator.
ProxyOperatorStateBackend(OperatorStateBackend, StateNamePrefix) - 类 的构造器org.apache.flink.iteration.proxy.state.ProxyOperatorStateBackend
 
proxyOutput - 类 中的变量org.apache.flink.iteration.operator.AbstractWrapperOperator
 
ProxyOutput<T> - org.apache.flink.iteration.proxy中的类
Proxy output to provide to the wrapped operator.
ProxyOutput(Output<StreamRecord<IterationRecord<T>>>) - 类 的构造器org.apache.flink.iteration.proxy.ProxyOutput
 
ProxyStateSnapshotContext - org.apache.flink.iteration.proxy.state中的类
Proxy StateSnapshotContext for the wrapped operators.
ProxyStateSnapshotContext(StateSnapshotContext) - 类 的构造器org.apache.flink.iteration.proxy.state.ProxyStateSnapshotContext
 
ProxyStreamOperatorStateContext - org.apache.flink.iteration.proxy.state中的类
Proxy StreamOperatorStateContext for the wrapped operator.
ProxyStreamOperatorStateContext(StreamOperatorStateContext, String, Iterator<StatePartitionStreamProvider>, int) - 类 的构造器org.apache.flink.iteration.proxy.state.ProxyStreamOperatorStateContext
 
ProxyStreamPartitioner<T> - org.apache.flink.iteration.proxy中的类
Proxy stream partitioner for the wrapped one.
ProxyStreamPartitioner(StreamPartitioner<T>) - 类 的构造器org.apache.flink.iteration.proxy.ProxyStreamPartitioner
 

R

rawKeyedStateInputs() - 类 中的方法org.apache.flink.iteration.proxy.state.ProxyStreamOperatorStateContext
 
rawOperatorStateInputs() - 类 中的方法org.apache.flink.iteration.proxy.state.ProxyStreamOperatorStateContext
 
RecordWriterBroadcastOutput<OUT> - org.apache.flink.iteration.broadcast中的类
The broadcast output corresponding to a record writer output.
RecordWriterBroadcastOutput(RecordWriter<SerializationDelegate<StreamElement>>, TypeSerializer<StreamElement>) - 类 的构造器org.apache.flink.iteration.broadcast.RecordWriterBroadcastOutput
 
recover(InputStream, FileSystem, SupplierWithException<Path, IOException>) - 类 中的静态方法org.apache.flink.iteration.datacache.nonkeyed.DataCacheSnapshot
Recovers a data cache instance from the input stream.
ReduceTransformationTranslator - org.apache.flink.iteration.compile.translator中的类
Draft translator for the ReduceTransformation.
ReduceTransformationTranslator() - 类 的构造器org.apache.flink.iteration.compile.translator.ReduceTransformationTranslator
 
ReflectionUtils - org.apache.flink.iteration.utils中的类
Utility class to provide some reflection tools.
ReflectionUtils() - 类 的构造器org.apache.flink.iteration.utils.ReflectionUtils
 
registerAlignedListener(OperatorID, SharedProgressAlignerListener) - 类 中的方法org.apache.flink.iteration.operator.coordinator.SharedProgressAligner
 
registerFeedbackConsumer(FeedbackChannel<V>, FeedbackConsumer<V>, Executor) - 类 中的静态方法org.apache.flink.iteration.operator.OperatorUtils
Registers the specified feedbackConsumer to the feedbackChannel.
registerKeySelectionListener(KeyedStateBackend.KeySelectionListener<K>) - 类 中的方法org.apache.flink.iteration.proxy.state.ProxyKeyedStateBackend
 
RegularHeadOperatorRecordProcessor - org.apache.flink.iteration.operator.headprocessor中的类
Processes the event before we received the terminated global aligned event from the coordinator.
RegularHeadOperatorRecordProcessor(HeadOperatorRecordProcessor.Context) - 类 的构造器org.apache.flink.iteration.operator.headprocessor.RegularHeadOperatorRecordProcessor
 
removeProgressInfo(OperatorID) - 类 中的方法org.apache.flink.iteration.operator.coordinator.SharedProgressAligner
 
removeProgressInfo(OperatorID, int) - 类 中的方法org.apache.flink.iteration.operator.coordinator.SharedProgressAligner
 
replay(InputStream, TypeSerializer<T>, FeedbackConsumer<T>) - 类 中的静态方法org.apache.flink.iteration.datacache.nonkeyed.DataCacheSnapshot
Replays cached records in the data cache from the input stream into the target feedback consumer.
replay(DataStream<?>...) - 类 中的静态方法org.apache.flink.iteration.ReplayableDataStreamList
 
ReplayableDataStreamList - org.apache.flink.iteration中的类
A list of data streams and whether they need replayed.
ReplayableDataStreamList.NonReplayedDataStreamList - org.apache.flink.iteration中的类
A special ReplayableDataStreamList that all streams should be not replayed.
ReplayableDataStreamList.ReplayedDataStreamList - org.apache.flink.iteration中的类
A special ReplayableDataStreamList that all streams should be replayed.
ReplayedDataStreamList(List<DataStream<?>>) - 类 的构造器org.apache.flink.iteration.ReplayableDataStreamList.ReplayedDataStreamList
 
ReplayOperator<T> - org.apache.flink.iteration.operator中的类
Replays the data received in the round 0 in the following round.
ReplayOperator() - 类 的构造器org.apache.flink.iteration.operator.ReplayOperator
 
reportOrForwardLatencyMarker(LatencyMarker) - 类 中的方法org.apache.flink.iteration.operator.perround.AbstractPerRoundWrapperOperator
 
reportSubtaskProgress(OperatorID, int, SubtaskAlignedEvent) - 类 中的方法org.apache.flink.iteration.operator.coordinator.SharedProgressAligner
 
requestCheckpoint(long, int, CompletableFuture<byte[]>) - 类 中的方法org.apache.flink.iteration.operator.coordinator.SharedProgressAligner
 
resetToCheckpoint(long, byte[]) - 类 中的方法org.apache.flink.iteration.operator.coordinator.HeadOperatorCoordinator
 
run(SourceFunction.SourceContext<T>) - 类 中的方法org.apache.flink.iteration.compile.DraftExecutionEnvironment.EmptySource
 

S

savepoint() - 类 中的方法org.apache.flink.iteration.proxy.state.ProxyKeyedStateBackend
 
Segment - org.apache.flink.iteration.datacache.nonkeyed中的类
A segment contains the information about a cache unit.
selectChannel(SerializationDelegate<StreamRecord<IterationRecord<T>>>) - 类 中的方法org.apache.flink.iteration.proxy.ProxyStreamPartitioner
 
serialize(IterationRecord<T>, DataOutputView) - 类 中的方法org.apache.flink.iteration.typeinfo.IterationRecordSerializer
 
serializerNumber(int, DataOutputView) - 类 中的方法org.apache.flink.iteration.typeinfo.IterationRecordSerializer
Variant encoding for the epoch.
setCheckpointId(long) - 类 中的方法org.apache.flink.iteration.IterationRecord
 
setCheckpoints(SubtaskFeedbackKey<V>, Checkpoints<V>) - 类 中的方法org.apache.flink.iteration.checkpoint.CheckpointsBroker
 
setContextRound(Integer) - 类 中的方法org.apache.flink.iteration.proxy.ProxyOutput
 
setCriteriaStreamParallelism(int) - 类 中的方法org.apache.flink.iteration.operator.HeadOperatorFactory
 
setCurrentKey(Object) - 类 中的方法org.apache.flink.iteration.operator.allround.AbstractAllRoundWrapperOperator
 
setCurrentKey(Object) - 类 中的方法org.apache.flink.iteration.operator.perround.AbstractPerRoundWrapperOperator
 
setCurrentKey(K) - 类 中的方法org.apache.flink.iteration.proxy.state.ProxyKeyedStateBackend
 
setCurrentWrapper(OperatorWrapper<?, ?>) - 类 中的方法org.apache.flink.iteration.compile.DraftExecutionEnvironment
 
setEpoch(int) - 类 中的方法org.apache.flink.iteration.IterationRecord
 
setEpochSupplier(Supplier<Integer>) - 类 中的方法org.apache.flink.iteration.functions.EpochAwareAllRoundProcessFunction
 
setEpochSupplier(Supplier<Integer>) - 类 中的方法org.apache.flink.iteration.functions.EpochAwareCoProcessFunction
 
setEpochSupplier(Supplier<Integer>) - 接口 中的方法org.apache.flink.iteration.operator.allround.EpochAware
 
setIterationContextRound(Integer) - 类 中的方法org.apache.flink.iteration.operator.AbstractWrapperOperator
 
setKeyContextElement(StreamRecord<IterationRecord<IN>>) - 类 中的方法org.apache.flink.iteration.operator.allround.OneInputAllRoundWrapperOperator
 
setKeyContextElement1(StreamRecord<?>) - 类 中的方法org.apache.flink.iteration.operator.allround.AbstractAllRoundWrapperOperator
 
setKeyContextElement1(StreamRecord) - 类 中的方法org.apache.flink.iteration.operator.perround.AbstractPerRoundWrapperOperator
 
setKeyContextElement2(StreamRecord<?>) - 类 中的方法org.apache.flink.iteration.operator.allround.AbstractAllRoundWrapperOperator
 
setKeyContextElement2(StreamRecord) - 类 中的方法org.apache.flink.iteration.operator.perround.AbstractPerRoundWrapperOperator
 
setMailboxExecutor(MailboxExecutor) - 类 中的方法org.apache.flink.iteration.operator.HeadOperatorFactory
 
setOperatorLifeCycle(IterationConfig.OperatorLifeCycle) - 类 中的方法org.apache.flink.iteration.IterationConfig.IterationConfigBuilder
 
setSender(String) - 类 中的方法org.apache.flink.iteration.IterationRecord
 
setType(IterationRecord.Type) - 类 中的方法org.apache.flink.iteration.IterationRecord
 
setup(StreamTask<?, ?>, StreamConfig, Output<StreamRecord<IterationRecord<?>>>) - 类 中的方法org.apache.flink.iteration.operator.HeadOperator
 
setup(StreamTask<?, ?>, StreamConfig, Output<StreamRecord<IterationRecord<T>>>) - 类 中的方法org.apache.flink.iteration.operator.ReplayOperator
 
setup(StreamTask<?, ?>, StreamConfig, Output<StreamRecord<Void>>) - 类 中的方法org.apache.flink.iteration.operator.TailOperator
 
setup(int) - 类 中的方法org.apache.flink.iteration.proxy.ProxyStreamPartitioner
 
setValue(T) - 类 中的方法org.apache.flink.iteration.IterationRecord
 
SharedProgressAligner - org.apache.flink.iteration.operator.coordinator中的类
The progress aligner shared between multiple HeadOperatorCoordinator.
SharedProgressAlignerListener - org.apache.flink.iteration.operator.coordinator中的接口
The listener of the SharedProgressAligner.
SideOutputTransformationTranslator - org.apache.flink.iteration.compile.translator中的类
Draft translator for the SideOutputTransformation.
SideOutputTransformationTranslator() - 类 的构造器org.apache.flink.iteration.compile.translator.SideOutputTransformationTranslator
 
size() - 类 中的方法org.apache.flink.iteration.DataStreamList
Returns the number of data streams in this list.
snapshot(long, long, CheckpointStreamFactory, CheckpointOptions) - 类 中的方法org.apache.flink.iteration.proxy.state.ProxyKeyedStateBackend
 
snapshot(long, long, CheckpointStreamFactory, CheckpointOptions) - 类 中的方法org.apache.flink.iteration.proxy.state.ProxyOperatorStateBackend
 
snapshotConfiguration() - 类 中的方法org.apache.flink.iteration.typeinfo.IterationRecordSerializer
 
snapshotState(StateSnapshotContext) - 类 中的方法org.apache.flink.iteration.datacache.nonkeyed.ListStateWithCache
 
snapshotState(long, long, CheckpointOptions, CheckpointStreamFactory) - 类 中的方法org.apache.flink.iteration.operator.allround.AbstractAllRoundWrapperOperator
 
snapshotState(StateSnapshotContext) - 类 中的方法org.apache.flink.iteration.operator.HeadOperator
 
snapshotState() - 接口 中的方法org.apache.flink.iteration.operator.headprocessor.HeadOperatorRecordProcessor
 
snapshotState() - 类 中的方法org.apache.flink.iteration.operator.headprocessor.RegularHeadOperatorRecordProcessor
 
snapshotState() - 类 中的方法org.apache.flink.iteration.operator.headprocessor.TerminatingHeadOperatorRecordProcessor
 
snapshotState(long, long, CheckpointOptions, CheckpointStreamFactory) - 类 中的方法org.apache.flink.iteration.operator.perround.AbstractPerRoundWrapperOperator
 
snapshotState(StateSnapshotContext) - 类 中的方法org.apache.flink.iteration.operator.perround.AbstractPerRoundWrapperOperator
 
snapshotState(StateSnapshotContext) - 类 中的方法org.apache.flink.iteration.operator.ReplayOperator
 
snapshotToRawKeyedState(KeyedStateCheckpointOutputStream, String) - 类 中的方法org.apache.flink.iteration.proxy.state.ProxyInternalTimeServiceManager
 
start() - 类 中的方法org.apache.flink.iteration.operator.coordinator.HeadOperatorCoordinator
 
startLogging(long, OperatorStateCheckpointOutputStream) - 类 中的方法org.apache.flink.iteration.checkpoint.Checkpoints
 
StateNamePrefix - org.apache.flink.iteration.proxy.state中的类
The prefix for the state name.
StateNamePrefix(String) - 类 的构造器org.apache.flink.iteration.proxy.state.StateNamePrefix
 
streamConfig - 类 中的变量org.apache.flink.iteration.operator.AbstractWrapperOperator
 
SubtaskAlignedEvent - org.apache.flink.iteration.operator.event中的类
The event sent from HeadOperator to HeadOperatorCoordinator to notify the subtask has received the EpochWatermark for the specified round.
SubtaskAlignedEvent(int, long, boolean) - 类 的构造器org.apache.flink.iteration.operator.event.SubtaskAlignedEvent
 
subtaskFailed(int, Throwable) - 类 中的方法org.apache.flink.iteration.operator.coordinator.HeadOperatorCoordinator
 
subtaskReady(int, OperatorCoordinator.SubtaskGateway) - 类 中的方法org.apache.flink.iteration.operator.coordinator.HeadOperatorCoordinator
 
subtaskReset(int, long) - 类 中的方法org.apache.flink.iteration.operator.coordinator.HeadOperatorCoordinator
 

T

TailOperator - org.apache.flink.iteration.operator中的类
The tail operators is attached after each feedback operator to increment the round of each record.
TailOperator(IterationID, int) - 类 的构造器org.apache.flink.iteration.operator.TailOperator
 
TerminatingHeadOperatorRecordProcessor - org.apache.flink.iteration.operator.headprocessor中的类
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.
TerminatingHeadOperatorRecordProcessor(HeadOperatorRecordProcessor.Context) - 类 的构造器org.apache.flink.iteration.operator.headprocessor.TerminatingHeadOperatorRecordProcessor
 
TerminatingOnInitializeEvent - org.apache.flink.iteration.operator.event中的类
Notifies the HeadOperatorCoordinator that the status has been terminating on startup so that the coordinator would not emit CoordinatorCheckpointEvent.
toString() - 类 中的方法org.apache.flink.iteration.datacache.nonkeyed.Segment
 
toString() - 类 中的方法org.apache.flink.iteration.IterationRecord
 
toString() - 类 中的方法org.apache.flink.iteration.operator.event.CoordinatorCheckpointEvent
 
toString() - 类 中的方法org.apache.flink.iteration.operator.event.GloballyAlignedEvent
 
toString() - 类 中的方法org.apache.flink.iteration.operator.event.SubtaskAlignedEvent
 
toString() - 类 中的方法org.apache.flink.iteration.proxy.ProxyStreamPartitioner
 
toString() - 类 中的方法org.apache.flink.iteration.typeinfo.IterationRecordTypeInfo
 
translate(TF, OperatorWrapper<?, ?>, DraftTransformationTranslator.Context) - 接口 中的方法org.apache.flink.iteration.compile.DraftTransformationTranslator
 
translate(BroadcastStateTransformation<?, ?, ?>, OperatorWrapper<?, ?>, DraftTransformationTranslator.Context) - 类 中的方法org.apache.flink.iteration.compile.translator.BroadcastStateTransformationTranslator
 
translate(KeyedBroadcastStateTransformation<?, ?, ?, ?>, OperatorWrapper<?, ?>, DraftTransformationTranslator.Context) - 类 中的方法org.apache.flink.iteration.compile.translator.KeyedBroadcastStateTransformationTranslator
 
translate(KeyedMultipleInputTransformation<?>, OperatorWrapper<?, ?>, DraftTransformationTranslator.Context) - 类 中的方法org.apache.flink.iteration.compile.translator.KeyedMultipleInputTransformationTranslator
 
translate(MultipleInputTransformation<?>, OperatorWrapper<?, ?>, DraftTransformationTranslator.Context) - 类 中的方法org.apache.flink.iteration.compile.translator.MultipleInputTransformationTranslator
 
translate(OneInputTransformation<?, ?>, OperatorWrapper<?, ?>, DraftTransformationTranslator.Context) - 类 中的方法org.apache.flink.iteration.compile.translator.OneInputTransformationTranslator
 
translate(PartitionTransformation<?>, OperatorWrapper<?, ?>, DraftTransformationTranslator.Context) - 类 中的方法org.apache.flink.iteration.compile.translator.PartitionTransformationTranslator
 
translate(ReduceTransformation<?, ?>, OperatorWrapper<?, ?>, DraftTransformationTranslator.Context) - 类 中的方法org.apache.flink.iteration.compile.translator.ReduceTransformationTranslator
 
translate(SideOutputTransformation<?>, OperatorWrapper<?, ?>, DraftTransformationTranslator.Context) - 类 中的方法org.apache.flink.iteration.compile.translator.SideOutputTransformationTranslator
 
translate(TwoInputTransformation<?, ?, ?>, OperatorWrapper<?, ?>, DraftTransformationTranslator.Context) - 类 中的方法org.apache.flink.iteration.compile.translator.TwoInputTransformationTranslator
 
translate(UnionTransformation<?>, OperatorWrapper<?, ?>, DraftTransformationTranslator.Context) - 类 中的方法org.apache.flink.iteration.compile.translator.UnionTransformationTranslator
 
tryReadSegmentsToMemory(TypeSerializer<T>, MemorySegmentPool) - 类 中的方法org.apache.flink.iteration.datacache.nonkeyed.DataCacheSnapshot
Attempts to cache the segments in memory.
TwoInputAllRoundWrapperOperator<IN1,IN2,OUT> - org.apache.flink.iteration.operator.allround中的类
All-round wrapper for the two-inputs operator.
TwoInputAllRoundWrapperOperator(StreamOperatorParameters<IterationRecord<OUT>>, StreamOperatorFactory<OUT>) - 类 的构造器org.apache.flink.iteration.operator.allround.TwoInputAllRoundWrapperOperator
 
TwoInputPerRoundWrapperOperator<IN1,IN2,OUT> - org.apache.flink.iteration.operator.perround中的类
Per-round wrapper for the two-inputs operator.
TwoInputPerRoundWrapperOperator(StreamOperatorParameters<IterationRecord<OUT>>, StreamOperatorFactory<OUT>) - 类 的构造器org.apache.flink.iteration.operator.perround.TwoInputPerRoundWrapperOperator
 
TwoInputTransformationTranslator - org.apache.flink.iteration.compile.translator中的类
Draft translator for the TwoInputTransformation.
TwoInputTransformationTranslator() - 类 的构造器org.apache.flink.iteration.compile.translator.TwoInputTransformationTranslator
 

U

UnionTransformationTranslator - org.apache.flink.iteration.compile.translator中的类
Draft translator for the UnionTransformation.
UnionTransformationTranslator() - 类 的构造器org.apache.flink.iteration.compile.translator.UnionTransformationTranslator
 
uniqueSenderId - 类 中的变量org.apache.flink.iteration.operator.AbstractWrapperOperator
 
unregisterListener(OperatorID) - 类 中的方法org.apache.flink.iteration.operator.coordinator.SharedProgressAligner
 
update(List<T>) - 类 中的方法org.apache.flink.iteration.datacache.nonkeyed.ListStateWithCache
 
updateEpochToCoordinator(int, long) - 接口 中的方法org.apache.flink.iteration.operator.headprocessor.HeadOperatorRecordProcessor.Context
 

V

valueOf(String) - 枚举 中的静态方法org.apache.flink.iteration.IterationConfig.OperatorLifeCycle
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.iteration.IterationRecord.Type
返回带有指定名称的该类型的枚举常量。
values() - 枚举 中的静态方法org.apache.flink.iteration.IterationConfig.OperatorLifeCycle
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.iteration.IterationRecord.Type
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。

W

wrap(StreamOperatorParameters<IterationRecord<T>>, StreamOperatorFactory<T>) - 类 中的方法org.apache.flink.iteration.operator.allround.AllRoundOperatorWrapper
 
wrap(StreamOperatorParameters<R>, StreamOperatorFactory<T>) - 接口 中的方法org.apache.flink.iteration.operator.OperatorWrapper
 
wrap(StreamOperatorParameters<IterationRecord<T>>, StreamOperatorFactory<T>) - 类 中的方法org.apache.flink.iteration.operator.perround.PerRoundOperatorWrapper
 
wrapKeySelector(KeySelector<T, KEY>) - 类 中的方法org.apache.flink.iteration.operator.allround.AllRoundOperatorWrapper
 
wrapKeySelector(KeySelector<T, KEY>) - 接口 中的方法org.apache.flink.iteration.operator.OperatorWrapper
 
wrapKeySelector(KeySelector<T, KEY>) - 类 中的方法org.apache.flink.iteration.operator.perround.PerRoundOperatorWrapper
 
wrapOutputTag(OutputTag<T>) - 类 中的方法org.apache.flink.iteration.operator.allround.AllRoundOperatorWrapper
 
wrapOutputTag(OutputTag<T>) - 接口 中的方法org.apache.flink.iteration.operator.OperatorWrapper
 
wrapOutputTag(OutputTag<T>) - 类 中的方法org.apache.flink.iteration.operator.perround.PerRoundOperatorWrapper
 
wrappedOperator - 类 中的变量org.apache.flink.iteration.operator.allround.AbstractAllRoundWrapperOperator
 
WrapperOperatorFactory<OUT> - org.apache.flink.iteration.operator中的类
The factory to create the subclass of AbstractWrapperOperator.
WrapperOperatorFactory(StreamOperatorFactory<OUT>, OperatorWrapper<OUT, IterationRecord<OUT>>) - 类 的构造器org.apache.flink.iteration.operator.WrapperOperatorFactory
 
wrapStreamPartitioner(StreamPartitioner<T>) - 类 中的方法org.apache.flink.iteration.operator.allround.AllRoundOperatorWrapper
 
wrapStreamPartitioner(StreamPartitioner<T>) - 接口 中的方法org.apache.flink.iteration.operator.OperatorWrapper
 
wrapStreamPartitioner(StreamPartitioner<T>) - 类 中的方法org.apache.flink.iteration.operator.perround.PerRoundOperatorWrapper
 
writeSegmentsToFiles() - 类 中的方法org.apache.flink.iteration.datacache.nonkeyed.DataCacheWriter
Write the segments in this writer to files on disk.
writeTo(OutputStream) - 类 中的方法org.apache.flink.iteration.datacache.nonkeyed.DataCacheSnapshot
Writes the information about this data cache to an output stream.
A B C D E F G H I K L M N O P R S T U V W 
跳过导航链接

Copyright © 2019–2022 The Apache Software Foundation. All rights reserved.