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

A

acknowledgeCheckpoint(long, CheckpointMetrics) - 类 中的方法org.apache.flink.state.api.runtime.SavepointEnvironment
 
acknowledgeCheckpoint(long, CheckpointMetrics, TaskStateSnapshot) - 类 中的方法org.apache.flink.state.api.runtime.SavepointEnvironment
 
addAccumulator(String, Accumulator<V, A>) - 类 中的方法org.apache.flink.state.api.runtime.SavepointRuntimeContext
 
addOperator(String, BootstrapTransformation<?>) - 类 中的方法org.apache.flink.state.api.runtime.metadata.SavepointMetadata
 
aggregate(String, AggregateFunction<T, ACC, R>, TypeInformation<K>, TypeInformation<T>, TypeInformation<R>) - 类 中的方法org.apache.flink.state.api.EvictingWindowReader
Reads window state generated using an AggregateFunction.
aggregate(String, AggregateFunction<T, ACC, R>, WindowReaderFunction<R, OUT, K, W>, TypeInformation<K>, TypeInformation<T>, TypeInformation<OUT>) - 类 中的方法org.apache.flink.state.api.EvictingWindowReader
Reads window state generated using an AggregateFunction.
aggregate(AggregateFunction<T, ACC, R>, WindowReaderFunction<R, OUT, KEY, W>, TypeInformation<KEY>, TypeSerializer<W>, TypeInformation<ACC>) - 类 中的静态方法org.apache.flink.state.api.input.operator.WindowReaderOperator
 
aggregate(AggregateFunction<T, ACC, R>) - 类 中的方法org.apache.flink.state.api.WindowedOperatorTransformation
Applies the given aggregation function to each window.
aggregate(AggregateFunction<T, ACC, R>, TypeInformation<ACC>) - 类 中的方法org.apache.flink.state.api.WindowedOperatorTransformation
Applies the given aggregation function to each window.
aggregate(AggregateFunction<T, ACC, V>, WindowFunction<V, R, K, W>) - 类 中的方法org.apache.flink.state.api.WindowedOperatorTransformation
Applies the given window function to each window.
aggregate(AggregateFunction<T, ACC, V>, WindowFunction<V, R, K, W>, TypeInformation<ACC>) - 类 中的方法org.apache.flink.state.api.WindowedOperatorTransformation
Applies the given window function to each window.
aggregate(AggregateFunction<T, ACC, V>, ProcessWindowFunction<V, R, K, W>) - 类 中的方法org.apache.flink.state.api.WindowedOperatorTransformation
Applies the given window function to each window.
aggregate(AggregateFunction<T, ACC, V>, ProcessWindowFunction<V, R, K, W>, TypeInformation<ACC>) - 类 中的方法org.apache.flink.state.api.WindowedOperatorTransformation
Applies the given window function to each window.
aggregate(String, AggregateFunction<T, ACC, R>, TypeInformation<K>, TypeInformation<ACC>, TypeInformation<R>) - 类 中的方法org.apache.flink.state.api.WindowReader
Reads window state generated using an AggregateFunction.
aggregate(String, AggregateFunction<T, ACC, R>, WindowReaderFunction<R, OUT, K, W>, TypeInformation<K>, TypeInformation<ACC>, TypeInformation<OUT>) - 类 中的方法org.apache.flink.state.api.WindowReader
Reads window state generated using an AggregateFunction.
AggregateEvictingWindowReaderFunction<IN,ACC,R,OUT,KEY,W extends org.apache.flink.streaming.api.windowing.windows.Window> - org.apache.flink.state.api.input.operator.window中的类
A wrapper for reading an evicting window operator with an aggregate function.
AggregateEvictingWindowReaderFunction(WindowReaderFunction<R, OUT, KEY, W>, AggregateFunction<IN, ACC, R>) - 类 的构造器org.apache.flink.state.api.input.operator.window.AggregateEvictingWindowReaderFunction
 
aggregatingState() - 接口 中的静态方法org.apache.flink.state.api.input.operator.window.WindowContents
 
apply(WindowFunction<T, R, K, W>) - 类 中的方法org.apache.flink.state.api.WindowedOperatorTransformation
Applies the given window function to each window.
apply(WindowFunction<T, R, K, W>, TypeInformation<R>) - 类 中的方法org.apache.flink.state.api.WindowedOperatorTransformation
Applies the given window function to each window.
assignTimestamps(Timestamper<T>) - 类 中的方法org.apache.flink.state.api.OneInputOperatorTransformation
Assigns an event time timestamp to each record.
assignTimestamps(TimestampAssigner<T>) - 类 中的方法org.apache.flink.state.api.OneInputOperatorTransformation
Assigns an event time timestamp to each record.

B

BootstrapTransformation<T> - org.apache.flink.state.api中的类
A BootstrapTransformation represents a procedure of writing new operator state into a Savepoint.
BootstrapTransformationWithID<T> - org.apache.flink.state.api.runtime中的类
A simple container class that represents a newly bootstrapped operator state within savepoints.
BootstrapTransformationWithID(OperatorID, BootstrapTransformation<T>) - 类 的构造器org.apache.flink.state.api.runtime.BootstrapTransformationWithID
 
bootstrapWith(DataSet<T>) - 类 中的静态方法org.apache.flink.state.api.OperatorTransformation
Create a new OperatorTransformation from a DataSet.
BoundedOneInputStreamTaskRunner<IN> - org.apache.flink.state.api.output中的类
A RichMapPartitionFunction that serves as the runtime for a BoundedStreamTask.
BoundedOneInputStreamTaskRunner(StreamConfig, int, Timestamper<IN>) - 类 的构造器org.apache.flink.state.api.output.BoundedOneInputStreamTaskRunner
BroadcastStateBootstrapFunction<IN> - org.apache.flink.state.api.functions中的类
Interface for writing elements to broadcast state.
BroadcastStateBootstrapFunction() - 类 的构造器org.apache.flink.state.api.functions.BroadcastStateBootstrapFunction
 
BroadcastStateBootstrapFunction.Context - org.apache.flink.state.api.functions中的接口
Context that BroadcastStateBootstrapFunction's can use for getting additional data about an input record.
BroadcastStateBootstrapOperator<IN> - org.apache.flink.state.api.output.operators中的类
A StreamOperator for executing BroadcastStateBootstrapFunction's.
BroadcastStateBootstrapOperator(long, Path, BroadcastStateBootstrapFunction<IN>) - 类 的构造器org.apache.flink.state.api.output.operators.BroadcastStateBootstrapOperator
 
BroadcastStateInputFormat<K,V> - org.apache.flink.state.api.input中的类
The input format for reading BroadcastState.
BroadcastStateInputFormat(OperatorState, MapStateDescriptor<K, V>) - 类 的构造器org.apache.flink.state.api.input.BroadcastStateInputFormat
Creates an input format for reading broadcast state from an operator in a savepoint.
build() - 类 中的方法org.apache.flink.state.api.runtime.SavepointEnvironment.Builder
 
Builder(RuntimeContext, int) - 类 的构造器org.apache.flink.state.api.runtime.SavepointEnvironment.Builder
 

C

close() - 类 中的方法org.apache.flink.state.api.input.KeyedStateInputFormat
 
close() - 类 中的方法org.apache.flink.state.api.input.MultiStateKeyIterator
 
close() - 类 中的方法org.apache.flink.state.api.input.operator.StateReaderOperator
 
close() - 类 中的方法org.apache.flink.state.api.input.operator.window.EvictingWindowReaderFunction
 
close() - 类 中的方法org.apache.flink.state.api.output.FileCopyFunction
 
close() - 类 中的方法org.apache.flink.state.api.output.operators.StateBootstrapWrapperOperator
 
close() - 类 中的方法org.apache.flink.state.api.output.SavepointOutputFormat
 
configure(Configuration) - 类 中的方法org.apache.flink.state.api.input.KeyedStateInputFormat
 
configure(Configuration) - 类 中的方法org.apache.flink.state.api.output.FileCopyFunction
 
configure(Configuration) - 类 中的方法org.apache.flink.state.api.output.SavepointOutputFormat
 
contents(S) - 接口 中的方法org.apache.flink.state.api.input.operator.window.WindowContents
 
Context() - 类 的构造器org.apache.flink.state.api.functions.KeyedStateBootstrapFunction.Context
 
create(StateBackend, int) - 类 中的静态方法org.apache.flink.state.api.Savepoint
Creates a new savepoint.
createInputSplits(int) - 类 中的方法org.apache.flink.state.api.input.KeyedStateInputFormat
 
createOperator(long, Path) - 接口 中的方法org.apache.flink.state.api.SavepointWriterOperatorFactory
Creates a StreamOperator to be used for generating and snapshotting state.
currentProcessingTime() - 接口 中的方法org.apache.flink.state.api.functions.BroadcastStateBootstrapFunction.Context
Returns the current processing time.
currentProcessingTime() - 接口 中的方法org.apache.flink.state.api.functions.StateBootstrapFunction.Context
Returns the current processing time.
currentProcessingTime() - 类 中的方法org.apache.flink.state.api.output.operators.LazyTimerService
 
currentWatermark() - 类 中的方法org.apache.flink.state.api.output.operators.LazyTimerService
 

D

declineCheckpoint(long, CheckpointException) - 类 中的方法org.apache.flink.state.api.runtime.SavepointEnvironment
 
deleteEventTimeTimer(long) - 类 中的方法org.apache.flink.state.api.output.operators.LazyTimerService
 
deleteProcessingTimeTimer(long) - 类 中的方法org.apache.flink.state.api.output.operators.LazyTimerService
 
disableStateRegistration() - 类 中的方法org.apache.flink.state.api.runtime.SavepointRuntimeContext
 

E

endInput() - 类 中的方法org.apache.flink.state.api.output.operators.BroadcastStateBootstrapOperator
 
endInput() - 类 中的方法org.apache.flink.state.api.output.operators.KeyedStateBootstrapOperator
 
endInput() - 类 中的方法org.apache.flink.state.api.output.operators.StateBootstrapOperator
 
endInput() - 类 中的方法org.apache.flink.state.api.output.operators.StateBootstrapWrapperOperator
 
equals(Object) - 类 中的方法org.apache.flink.state.api.output.TaggedOperatorSubtaskState
 
evictingWindow(WindowReaderFunction<StreamRecord<T>, OUT, KEY, W>, TypeInformation<KEY>, TypeSerializer<W>, TypeInformation<T>, ExecutionConfig) - 类 中的静态方法org.apache.flink.state.api.input.operator.WindowReaderOperator
 
EvictingWindowReader<W extends org.apache.flink.streaming.api.windowing.windows.Window> - org.apache.flink.state.api中的类
This class provides entry points for reading keyed state written out using the WindowOperator.
EvictingWindowReaderFunction<IN,R,OUT,KEY,W extends org.apache.flink.streaming.api.windowing.windows.Window> - org.apache.flink.state.api.input.operator.window中的类
Wrapper for reading state from an evicting window operator.
EvictingWindowReaderFunction(WindowReaderFunction<R, OUT, KEY, W>) - 类 的构造器org.apache.flink.state.api.input.operator.window.EvictingWindowReaderFunction
 
evictor(Evictor<? super T, ? super W>) - 类 中的方法org.apache.flink.state.api.WindowedOperatorTransformation
Sets the Evictor that should be used to evict elements from a window before emission.
evictor() - 类 中的方法org.apache.flink.state.api.WindowReader
Reads from a window that uses an evictor.
ExistingSavepoint - org.apache.flink.state.api中的类
An existing savepoint.

F

failExternally(Throwable) - 类 中的方法org.apache.flink.state.api.runtime.SavepointEnvironment
 
FileCopyFunction - org.apache.flink.state.api.output中的类
This output format copies files from an existing savepoint into a new directory.
FileCopyFunction(String) - 类 的构造器org.apache.flink.state.api.output.FileCopyFunction
 
finish() - 类 中的方法org.apache.flink.state.api.output.operators.StateBootstrapWrapperOperator
 
flatMap(OperatorState, Collector<Path>) - 类 中的方法org.apache.flink.state.api.output.StatePathExtractor
 
fromUid(String) - 类 中的静态方法org.apache.flink.state.api.runtime.OperatorIDGenerator
Generate OperatorID's from uid's.
function - 类 中的变量org.apache.flink.state.api.input.operator.StateReaderOperator
 

G

getAccumulator(String) - 类 中的方法org.apache.flink.state.api.runtime.SavepointRuntimeContext
 
getAccumulatorRegistry() - 类 中的方法org.apache.flink.state.api.runtime.SavepointEnvironment
 
getAggregatingState(AggregatingStateDescriptor<IN, ACC, OUT>) - 类 中的方法org.apache.flink.state.api.runtime.SavepointRuntimeContext
 
getAllInputGates() - 类 中的方法org.apache.flink.state.api.runtime.SavepointEnvironment
 
getAllWriters() - 类 中的方法org.apache.flink.state.api.runtime.SavepointEnvironment
 
getAttemptNumber() - 类 中的方法org.apache.flink.state.api.runtime.SavepointRuntimeContext
 
getBootstrapTransformation() - 类 中的方法org.apache.flink.state.api.runtime.BootstrapTransformationWithID
 
getBroadcastState(MapStateDescriptor<K, V>) - 接口 中的方法org.apache.flink.state.api.functions.BroadcastStateBootstrapFunction.Context
Fetches the BroadcastState with the specified name.
getBroadcastVariable(String) - 类 中的方法org.apache.flink.state.api.runtime.SavepointRuntimeContext
 
getBroadcastVariableManager() - 类 中的方法org.apache.flink.state.api.runtime.SavepointEnvironment
 
getBroadcastVariableWithInitializer(String, BroadcastVariableInitializer<T, C>) - 类 中的方法org.apache.flink.state.api.runtime.SavepointRuntimeContext
 
getChainingStrategy() - 类 中的方法org.apache.flink.state.api.output.operators.StateBootstrapWrapperOperator
 
getCurrentKey() - 类 中的方法org.apache.flink.state.api.functions.KeyedStateBootstrapFunction.Context
Get key of the element being processed.
getCurrentKey() - 类 中的方法org.apache.flink.state.api.input.operator.StateReaderOperator
 
getCurrentKey() - 类 中的方法org.apache.flink.state.api.output.operators.StateBootstrapWrapperOperator
 
getCurrentProcessingTime() - 类 中的方法org.apache.flink.state.api.runtime.NeverFireProcessingTimeService
 
getDistributedCache() - 类 中的方法org.apache.flink.state.api.runtime.SavepointRuntimeContext
 
getDistributedCacheEntries() - 类 中的方法org.apache.flink.state.api.runtime.SavepointEnvironment
 
getDoubleCounter(String) - 类 中的方法org.apache.flink.state.api.runtime.SavepointRuntimeContext
 
getElements(OperatorStateBackend) - 类 中的方法org.apache.flink.state.api.input.BroadcastStateInputFormat
 
getElements(OperatorStateBackend) - 类 中的方法org.apache.flink.state.api.input.ListStateInputFormat
 
getElements(OperatorStateBackend) - 类 中的方法org.apache.flink.state.api.input.UnionStateInputFormat
 
getExecutionConfig() - 类 中的方法org.apache.flink.state.api.input.operator.StateReaderOperator
 
getExecutionConfig() - 类 中的方法org.apache.flink.state.api.runtime.SavepointEnvironment
 
getExecutionConfig() - 类 中的方法org.apache.flink.state.api.runtime.SavepointRuntimeContext
 
getExecutionId() - 类 中的方法org.apache.flink.state.api.runtime.SavepointEnvironment
 
getExistingOperators() - 类 中的方法org.apache.flink.state.api.runtime.metadata.SavepointMetadata
 
getExternalResourceInfoProvider() - 类 中的方法org.apache.flink.state.api.runtime.SavepointEnvironment
 
getExternalResourceInfos(String) - 类 中的方法org.apache.flink.state.api.runtime.SavepointRuntimeContext
 
getGlobalAggregateManager() - 类 中的方法org.apache.flink.state.api.runtime.SavepointEnvironment
 
getHistogram(String) - 类 中的方法org.apache.flink.state.api.runtime.SavepointRuntimeContext
 
getIndexOfThisSubtask() - 类 中的方法org.apache.flink.state.api.runtime.SavepointRuntimeContext
 
getInputGate(int) - 类 中的方法org.apache.flink.state.api.runtime.SavepointEnvironment
 
getInputSplitAssigner(KeyGroupRangeInputSplit[]) - 类 中的方法org.apache.flink.state.api.input.KeyedStateInputFormat
 
getInputSplitProvider() - 类 中的方法org.apache.flink.state.api.runtime.SavepointEnvironment
 
getIntCounter(String) - 类 中的方法org.apache.flink.state.api.runtime.SavepointRuntimeContext
 
getInternalTimerService(String) - 类 中的方法org.apache.flink.state.api.input.operator.StateReaderOperator
 
getIOManager() - 类 中的方法org.apache.flink.state.api.runtime.SavepointEnvironment
 
getJobConfiguration() - 类 中的方法org.apache.flink.state.api.runtime.SavepointEnvironment
 
getJobID() - 类 中的方法org.apache.flink.state.api.runtime.SavepointEnvironment
 
getJobId() - 类 中的方法org.apache.flink.state.api.runtime.SavepointRuntimeContext
 
getJobVertexId() - 类 中的方法org.apache.flink.state.api.runtime.SavepointEnvironment
 
getKey(IN) - 类 中的方法org.apache.flink.state.api.output.partitioner.HashSelector
 
getKeyedStateBackend() - 类 中的方法org.apache.flink.state.api.input.operator.StateReaderOperator
 
getKeysAndNamespaces(SavepointRuntimeContext) - 类 中的方法org.apache.flink.state.api.input.operator.KeyedStateReaderOperator
 
getKeysAndNamespaces(SavepointRuntimeContext) - 类 中的方法org.apache.flink.state.api.input.operator.StateReaderOperator
 
getKeysAndNamespaces(SavepointRuntimeContext) - 类 中的方法org.apache.flink.state.api.input.operator.WindowReaderOperator
 
getKeyType() - 类 中的方法org.apache.flink.state.api.input.operator.StateReaderOperator
 
getListState(ListStateDescriptor<T>) - 类 中的方法org.apache.flink.state.api.runtime.SavepointRuntimeContext
 
getLongCounter(String) - 类 中的方法org.apache.flink.state.api.runtime.SavepointRuntimeContext
 
getMapState(MapStateDescriptor<UK, UV>) - 类 中的方法org.apache.flink.state.api.runtime.SavepointRuntimeContext
 
getMasterStates() - 类 中的方法org.apache.flink.state.api.runtime.metadata.SavepointMetadata
 
getMaxNumberOfParallelSubtasks() - 类 中的方法org.apache.flink.state.api.runtime.SavepointRuntimeContext
 
getMaxParallelism() - 类 中的方法org.apache.flink.state.api.runtime.metadata.SavepointMetadata
 
getMemoryManager() - 类 中的方法org.apache.flink.state.api.runtime.SavepointEnvironment
 
getMetricGroup() - 类 中的方法org.apache.flink.state.api.output.operators.StateBootstrapWrapperOperator
 
getMetricGroup() - 类 中的方法org.apache.flink.state.api.runtime.SavepointEnvironment
 
getMetricGroup() - 类 中的方法org.apache.flink.state.api.runtime.SavepointRuntimeContext
 
getNewOperators() - 类 中的方法org.apache.flink.state.api.runtime.metadata.SavepointMetadata
 
getNumberOfParallelSubtasks() - 类 中的方法org.apache.flink.state.api.runtime.SavepointRuntimeContext
 
getNumKeyGroups() - 类 中的方法org.apache.flink.state.api.input.splits.KeyGroupRangeInputSplit
 
getOperatorCoordinatorEventGateway() - 类 中的方法org.apache.flink.state.api.runtime.SavepointEnvironment
 
getOperatorID() - 类 中的方法org.apache.flink.state.api.output.operators.StateBootstrapWrapperOperator
 
getOperatorID() - 类 中的方法org.apache.flink.state.api.runtime.BootstrapTransformationWithID
 
getOperatorState(String) - 类 中的方法org.apache.flink.state.api.runtime.metadata.SavepointMetadata
 
getPrioritizedManagedOperatorState() - 类 中的方法org.apache.flink.state.api.input.splits.OperatorStateInputSplit
 
getPrioritizedOperatorSubtaskState() - 类 中的方法org.apache.flink.state.api.input.splits.KeyGroupRangeInputSplit
 
getReducingState(ReducingStateDescriptor<T>) - 类 中的方法org.apache.flink.state.api.runtime.SavepointRuntimeContext
 
getSplitNumber() - 类 中的方法org.apache.flink.state.api.input.splits.KeyGroupRangeInputSplit
 
getSplitNumber() - 类 中的方法org.apache.flink.state.api.input.splits.OperatorStateInputSplit
 
getState(ValueStateDescriptor<T>) - 类 中的方法org.apache.flink.state.api.runtime.SavepointRuntimeContext
 
getStateDescriptors() - 类 中的方法org.apache.flink.state.api.runtime.SavepointRuntimeContext
 
getStatistics(BaseStatistics) - 类 中的方法org.apache.flink.state.api.input.KeyedStateInputFormat
 
getTaskConfiguration() - 类 中的方法org.apache.flink.state.api.runtime.SavepointEnvironment
 
getTaskEventDispatcher() - 类 中的方法org.apache.flink.state.api.runtime.SavepointEnvironment
 
getTaskInfo() - 类 中的方法org.apache.flink.state.api.runtime.SavepointEnvironment
 
getTaskKvStateRegistry() - 类 中的方法org.apache.flink.state.api.runtime.SavepointEnvironment
 
getTaskManagerInfo() - 类 中的方法org.apache.flink.state.api.runtime.SavepointEnvironment
 
getTaskName() - 类 中的方法org.apache.flink.state.api.runtime.SavepointRuntimeContext
 
getTaskNameWithSubtasks() - 类 中的方法org.apache.flink.state.api.runtime.SavepointRuntimeContext
 
getTaskStateManager() - 类 中的方法org.apache.flink.state.api.runtime.SavepointEnvironment
 
getThroughputCalculator() - 类 中的方法org.apache.flink.state.api.runtime.SavepointEnvironment
 
getUserCodeClassLoader() - 类 中的方法org.apache.flink.state.api.runtime.SavepointEnvironment
 
getUserCodeClassLoader() - 类 中的方法org.apache.flink.state.api.runtime.SavepointRuntimeContext
 
getWriter(int) - 类 中的方法org.apache.flink.state.api.runtime.SavepointEnvironment
 
globalState() - 接口 中的方法org.apache.flink.state.api.functions.WindowReaderFunction.Context
State accessor for per-key global state.

H

hasBroadcastVariable(String) - 类 中的方法org.apache.flink.state.api.runtime.SavepointRuntimeContext
 
hashCode() - 类 中的方法org.apache.flink.state.api.output.TaggedOperatorSubtaskState
 
HashSelector<IN> - org.apache.flink.state.api.output.partitioner中的类
A wrapper around a KeySelector that returns the Object.hashCode() of the returned key.
HashSelector(KeySelector<IN, ?>) - 类 的构造器org.apache.flink.state.api.output.partitioner.HashSelector
 
hasNext() - 类 中的方法org.apache.flink.state.api.input.MultiStateKeyIterator
 

I

index - 类 中的变量org.apache.flink.state.api.output.TaggedOperatorSubtaskState
 
initializeState(StreamTaskStateInitializer) - 类 中的方法org.apache.flink.state.api.output.operators.StateBootstrapWrapperOperator
 
instance() - 类 中的静态方法org.apache.flink.state.api.runtime.VoidTriggerable
 
isTerminated() - 类 中的方法org.apache.flink.state.api.runtime.NeverFireProcessingTimeService
 

K

keyBy(KeySelector<T, K>) - 类 中的方法org.apache.flink.state.api.OneInputOperatorTransformation
It creates a new KeyedOperatorTransformation that uses the provided key for partitioning its operator states.
keyBy(KeySelector<T, K>, TypeInformation<K>) - 类 中的方法org.apache.flink.state.api.OneInputOperatorTransformation
It creates a new KeyedOperatorTransformation that uses the provided key with explicit type information for partitioning its operator states.
keyBy(int...) - 类 中的方法org.apache.flink.state.api.OneInputOperatorTransformation
Partitions the operator state of a OperatorTransformation by the given key positions.
keyBy(String...) - 类 中的方法org.apache.flink.state.api.OneInputOperatorTransformation
Partitions the operator state of a OperatorTransformation using field expressions.
KeyedOperatorTransformation<K,T> - org.apache.flink.state.api中的类
A KeyedOperatorTransformation represents a OneInputOperatorTransformation on which operator state is partitioned by key using a provided KeySelector.
KeyedStateBootstrapFunction<K,IN> - org.apache.flink.state.api.functions中的类
A function that writes keyed state to a new operator.
KeyedStateBootstrapFunction() - 类 的构造器org.apache.flink.state.api.functions.KeyedStateBootstrapFunction
 
KeyedStateBootstrapFunction.Context - org.apache.flink.state.api.functions中的类
Information available in an invocation of KeyedStateBootstrapFunction.processElement(Object, Context).
KeyedStateBootstrapOperator<K,IN> - org.apache.flink.state.api.output.operators中的类
A StreamOperator for executing KeyedStateBootstrapFunction's.
KeyedStateBootstrapOperator(long, Path, KeyedStateBootstrapFunction<K, IN>) - 类 的构造器org.apache.flink.state.api.output.operators.KeyedStateBootstrapOperator
 
KeyedStateInputFormat<K,N,OUT> - org.apache.flink.state.api.input中的类
Input format for reading partitioned state.
KeyedStateInputFormat(OperatorState, StateBackend, Configuration, StateReaderOperator<?, K, N, OUT>) - 类 的构造器org.apache.flink.state.api.input.KeyedStateInputFormat
Creates an input format for reading partitioned state from an operator in a savepoint.
KeyedStateReaderFunction<K,OUT> - org.apache.flink.state.api.functions中的类
A function that processes keys from a restored operator For every key KeyedStateReaderFunction.readKey(Object, Context, Collector) is invoked.
KeyedStateReaderFunction() - 类 的构造器org.apache.flink.state.api.functions.KeyedStateReaderFunction
 
KeyedStateReaderFunction.Context - org.apache.flink.state.api.functions中的接口
Context that KeyedStateReaderFunction's can use for getting additional data about an input record.
KeyedStateReaderOperator<KEY,OUT> - org.apache.flink.state.api.input.operator中的类
KeyedStateReaderOperator(KeyedStateReaderFunction<KEY, OUT>, TypeInformation<KEY>) - 类 的构造器org.apache.flink.state.api.input.operator.KeyedStateReaderOperator
 
KeyGroupRangeInputSplit - org.apache.flink.state.api.input.splits中的类
An input split representing a key-group range from a savepoint.
KeyGroupRangeInputSplit(List<KeyedStateHandle>, List<KeyedStateHandle>, int, int) - 类 的构造器org.apache.flink.state.api.input.splits.KeyGroupRangeInputSplit
 
KeyGroupRangePartitioner - org.apache.flink.state.api.output.partitioner中的类
A partitioner that selects the target channel based on the key group index.
KeyGroupRangePartitioner(int) - 类 的构造器org.apache.flink.state.api.output.partitioner.KeyGroupRangePartitioner
 

L

LazyTimerService - org.apache.flink.state.api.output.operators中的类
A timer service that initializes its internal timer service lazily.
listState() - 接口 中的静态方法org.apache.flink.state.api.input.operator.window.WindowContents
 
ListStateInputFormat<OT> - org.apache.flink.state.api.input中的类
Input format for reading operator list state.
ListStateInputFormat(OperatorState, ListStateDescriptor<OT>) - 类 的构造器org.apache.flink.state.api.input.ListStateInputFormat
Creates an input format for reading list state from an operator in a savepoint.
load(ExecutionEnvironment, String, StateBackend) - 类 中的静态方法org.apache.flink.state.api.Savepoint
Loads an existing savepoint.
loadSavepointMetadata(String) - 类 中的静态方法org.apache.flink.state.api.runtime.SavepointLoader
Takes the given string (representing a pointer to a checkpoint) and resolves it to a file status for the checkpoint's metadata file.

M

mapPartition(Iterable<IN>, Collector<TaggedOperatorSubtaskState>) - 类 中的方法org.apache.flink.state.api.output.BoundedOneInputStreamTaskRunner
 
MergeOperatorStates - org.apache.flink.state.api.output中的类
A reducer that aggregates multiple OperatorState's into a single CheckpointMetadata.
MergeOperatorStates(Collection<MasterState>) - 类 的构造器org.apache.flink.state.api.output.MergeOperatorStates
 
metadata - 类 中的变量org.apache.flink.state.api.WritableSavepoint
The savepoint metadata, which maintains the current set of existing / newly added operator states.
MultiStateKeyIterator<K> - org.apache.flink.state.api.input中的类
An iterator for reading all keys in a state backend across multiple partitioned states.
MultiStateKeyIterator(List<? extends StateDescriptor<?, ?>>, KeyedStateBackend<K>) - 类 的构造器org.apache.flink.state.api.input.MultiStateKeyIterator
 

N

namespaceSerializer - 类 中的变量org.apache.flink.state.api.input.operator.StateReaderOperator
 
NeverFireProcessingTimeService - org.apache.flink.state.api.runtime中的类
A processing time service whose timers never fire so all timers are included in savepoints.
NeverFireProcessingTimeService() - 类 的构造器org.apache.flink.state.api.runtime.NeverFireProcessingTimeService
 
NewSavepoint - org.apache.flink.state.api中的类
A new savepoint.
next() - 类 中的方法org.apache.flink.state.api.input.MultiStateKeyIterator
 
nextRecord(OUT) - 类 中的方法org.apache.flink.state.api.input.KeyedStateInputFormat
 
notifyCheckpointComplete(long) - 类 中的方法org.apache.flink.state.api.output.operators.StateBootstrapWrapperOperator
 

O

OneInputOperatorTransformation<T> - org.apache.flink.state.api中的类
OneInputOperatorTransformation represents a user defined transformation applied on an OperatorTransformation with one input.
onEventTime(InternalTimer<K, N>) - 类 中的方法org.apache.flink.state.api.runtime.VoidTriggerable
 
onProcessingTime(InternalTimer<K, N>) - 类 中的方法org.apache.flink.state.api.runtime.VoidTriggerable
 
open(Configuration) - 类 中的方法org.apache.flink.state.api.functions.KeyedStateReaderFunction
Initialization method for the function.
open(KeyGroupRangeInputSplit) - 类 中的方法org.apache.flink.state.api.input.KeyedStateInputFormat
 
open() - 类 中的方法org.apache.flink.state.api.input.operator.KeyedStateReaderOperator
 
open() - 类 中的方法org.apache.flink.state.api.input.operator.StateReaderOperator
 
open(Configuration) - 类 中的方法org.apache.flink.state.api.input.operator.window.EvictingWindowReaderFunction
 
open() - 类 中的方法org.apache.flink.state.api.input.operator.WindowReaderOperator
 
open(Configuration) - 类 中的方法org.apache.flink.state.api.output.BoundedOneInputStreamTaskRunner
 
open(int, int) - 类 中的方法org.apache.flink.state.api.output.FileCopyFunction
 
open() - 类 中的方法org.apache.flink.state.api.output.operators.BroadcastStateBootstrapOperator
 
open() - 类 中的方法org.apache.flink.state.api.output.operators.KeyedStateBootstrapOperator
 
open() - 类 中的方法org.apache.flink.state.api.output.operators.StateBootstrapOperator
 
open() - 类 中的方法org.apache.flink.state.api.output.operators.StateBootstrapWrapperOperator
 
open(Configuration) - 类 中的方法org.apache.flink.state.api.output.OperatorSubtaskStateReducer
 
open(int, int) - 类 中的方法org.apache.flink.state.api.output.SavepointOutputFormat
 
openInputFormat() - 类 中的方法org.apache.flink.state.api.input.KeyedStateInputFormat
 
OperatorIDGenerator - org.apache.flink.state.api.runtime中的类
Utility for generating Operator Id's from uid strings.
OperatorStateInputSplit - org.apache.flink.state.api.input.splits中的类
An input split containing state handles for operator state.
OperatorStateInputSplit(StateObjectCollection<OperatorStateHandle>, int) - 类 的构造器org.apache.flink.state.api.input.splits.OperatorStateInputSplit
 
OperatorSubtaskStateReducer - org.apache.flink.state.api.output中的类
A reducer that aggregates all OperatorSubtaskState's for a particular operator into a single OperatorState.
OperatorSubtaskStateReducer(OperatorID, int) - 类 的构造器org.apache.flink.state.api.output.OperatorSubtaskStateReducer
 
OperatorTransformation - org.apache.flink.state.api中的类
This class provides the entry point for building BootstrapTransformations, which represents procedures to bootstrap new operator states with a given DataSet.
org.apache.flink.state.api - 程序包 org.apache.flink.state.api
 
org.apache.flink.state.api.functions - 程序包 org.apache.flink.state.api.functions
 
org.apache.flink.state.api.input - 程序包 org.apache.flink.state.api.input
 
org.apache.flink.state.api.input.operator - 程序包 org.apache.flink.state.api.input.operator
 
org.apache.flink.state.api.input.operator.window - 程序包 org.apache.flink.state.api.input.operator.window
 
org.apache.flink.state.api.input.splits - 程序包 org.apache.flink.state.api.input.splits
 
org.apache.flink.state.api.output - 程序包 org.apache.flink.state.api.output
 
org.apache.flink.state.api.output.operators - 程序包 org.apache.flink.state.api.output.operators
 
org.apache.flink.state.api.output.partitioner - 程序包 org.apache.flink.state.api.output.partitioner
 
org.apache.flink.state.api.runtime - 程序包 org.apache.flink.state.api.runtime
 
org.apache.flink.state.api.runtime.metadata - 程序包 org.apache.flink.state.api.runtime.metadata
 

P

partition(Integer, int) - 类 中的方法org.apache.flink.state.api.output.partitioner.KeyGroupRangePartitioner
 
PassThroughReader<KEY,W extends org.apache.flink.streaming.api.windowing.windows.Window,IN> - org.apache.flink.state.api.input.operator.window中的类
A WindowReaderFunction that just emits each input element.
PassThroughReader() - 类 的构造器org.apache.flink.state.api.input.operator.window.PassThroughReader
 
prepareSnapshotPreBarrier(long) - 类 中的方法org.apache.flink.state.api.output.operators.StateBootstrapWrapperOperator
 
process(String, WindowReaderFunction<T, OUT, K, W>, TypeInformation<K>, TypeInformation<T>, TypeInformation<OUT>) - 类 中的方法org.apache.flink.state.api.EvictingWindowReader
Reads window state generated without any preaggregation such as WindowedStream#apply and WindowedStream#process.
process(WindowReaderFunction<T, OUT, KEY, W>, TypeInformation<KEY>, TypeSerializer<W>, TypeInformation<T>) - 类 中的静态方法org.apache.flink.state.api.input.operator.WindowReaderOperator
 
process(ProcessWindowFunction<T, R, K, W>) - 类 中的方法org.apache.flink.state.api.WindowedOperatorTransformation
Applies the given window function to each window.
process(String, WindowReaderFunction<T, OUT, K, W>, TypeInformation<K>, TypeInformation<T>, TypeInformation<OUT>) - 类 中的方法org.apache.flink.state.api.WindowReader
Reads window state generated without any preaggregation such as WindowedStream#apply and WindowedStream#process.
processElement(IN, BroadcastStateBootstrapFunction.Context) - 类 中的方法org.apache.flink.state.api.functions.BroadcastStateBootstrapFunction
Writes the given value to operator state.
processElement(IN, KeyedStateBootstrapFunction<K, IN>.Context) - 类 中的方法org.apache.flink.state.api.functions.KeyedStateBootstrapFunction
Process one element from the input stream.
processElement(IN, StateBootstrapFunction.Context) - 类 中的方法org.apache.flink.state.api.functions.StateBootstrapFunction
Writes the given value to operator state.
processElement(KEY, VoidNamespace, Collector<OUT>) - 类 中的方法org.apache.flink.state.api.input.operator.KeyedStateReaderOperator
 
processElement(KEY, N, Collector<OUT>) - 类 中的方法org.apache.flink.state.api.input.operator.StateReaderOperator
 
processElement(KEY, W, Collector<OUT>) - 类 中的方法org.apache.flink.state.api.input.operator.WindowReaderOperator
 
processElement(StreamRecord<IN>) - 类 中的方法org.apache.flink.state.api.output.operators.BroadcastStateBootstrapOperator
 
processElement(StreamRecord<IN>) - 类 中的方法org.apache.flink.state.api.output.operators.KeyedStateBootstrapOperator
 
processElement(StreamRecord<IN>) - 类 中的方法org.apache.flink.state.api.output.operators.StateBootstrapOperator
 
processElement(StreamRecord<IN>) - 类 中的方法org.apache.flink.state.api.output.operators.StateBootstrapWrapperOperator
 
ProcessEvictingWindowReader<IN,OUT,KEY,W extends org.apache.flink.streaming.api.windowing.windows.Window> - org.apache.flink.state.api.input.operator.window中的类
A wrapper function for reading an evicting window with no pre-aggregation.
ProcessEvictingWindowReader(WindowReaderFunction<IN, OUT, KEY, W>) - 类 的构造器org.apache.flink.state.api.input.operator.window.ProcessEvictingWindowReader
 
processLatencyMarker(LatencyMarker) - 类 中的方法org.apache.flink.state.api.output.operators.StateBootstrapWrapperOperator
 
processWatermark(Watermark) - 类 中的方法org.apache.flink.state.api.output.operators.StateBootstrapWrapperOperator
 
processWatermarkStatus(WatermarkStatus) - 类 中的方法org.apache.flink.state.api.output.operators.StateBootstrapWrapperOperator
 

Q

quiesce() - 类 中的方法org.apache.flink.state.api.runtime.NeverFireProcessingTimeService
 

R

reachedEnd() - 类 中的方法org.apache.flink.state.api.input.KeyedStateInputFormat
 
readBroadcastState(String, String, TypeInformation<K>, TypeInformation<V>) - 类 中的方法org.apache.flink.state.api.ExistingSavepoint
Read operator BroadcastState from a Savepoint.
readBroadcastState(String, String, TypeInformation<K>, TypeInformation<V>, TypeSerializer<K>, TypeSerializer<V>) - 类 中的方法org.apache.flink.state.api.ExistingSavepoint
Read operator BroadcastState from a Savepoint when a custom serializer was used; e.g., a different serializer than the one returned by TypeInformation#createSerializer.
readKey(K, KeyedStateReaderFunction.Context, Collector<OUT>) - 类 中的方法org.apache.flink.state.api.functions.KeyedStateReaderFunction
Process one key from the restored state backend.
readKeyedState(String, KeyedStateReaderFunction<K, OUT>) - 类 中的方法org.apache.flink.state.api.ExistingSavepoint
Read keyed state from an operator in a Savepoint.
readKeyedState(String, KeyedStateReaderFunction<K, OUT>, TypeInformation<K>, TypeInformation<OUT>) - 类 中的方法org.apache.flink.state.api.ExistingSavepoint
Read keyed state from an operator in a Savepoint.
readListState(String, String, TypeInformation<T>) - 类 中的方法org.apache.flink.state.api.ExistingSavepoint
Read operator ListState from a Savepoint.
readListState(String, String, TypeInformation<T>, TypeSerializer<T>) - 类 中的方法org.apache.flink.state.api.ExistingSavepoint
Read operator ListState from a Savepoint when a custom serializer was used; e.g., a different serializer than the one returned by TypeInformation#createSerializer.
readUnionState(String, String, TypeInformation<T>) - 类 中的方法org.apache.flink.state.api.ExistingSavepoint
Read operator UnionState from a Savepoint.
readUnionState(String, String, TypeInformation<T>, TypeSerializer<T>) - 类 中的方法org.apache.flink.state.api.ExistingSavepoint
Read operator UnionState from a Savepoint when a custom serializer was used; e.g., a different serializer than the one returned by TypeInformation#createSerializer.
readWindow(KEY, WindowReaderFunction.Context<W>, Iterable<IN>, Collector<OUT>) - 类 中的方法org.apache.flink.state.api.functions.WindowReaderFunction
Evaluates the window and outputs none or several elements.
readWindow(KEY, WindowReaderFunction.Context<W>, Iterable<StreamRecord<IN>>, Collector<OUT>) - 类 中的方法org.apache.flink.state.api.input.operator.window.EvictingWindowReaderFunction
 
readWindow(KEY, WindowReaderFunction.Context<W>, Iterable<IN>, Collector<IN>) - 类 中的方法org.apache.flink.state.api.input.operator.window.PassThroughReader
 
reduce(String, ReduceFunction<T>, TypeInformation<K>, TypeInformation<T>) - 类 中的方法org.apache.flink.state.api.EvictingWindowReader
Reads window state generated using a ReduceFunction.
reduce(String, ReduceFunction<T>, WindowReaderFunction<T, OUT, K, W>, TypeInformation<K>, TypeInformation<T>, TypeInformation<OUT>) - 类 中的方法org.apache.flink.state.api.EvictingWindowReader
Reads window state generated using a ReduceFunction.
reduce(ReduceFunction<T>, WindowReaderFunction<T, OUT, KEY, W>, TypeInformation<KEY>, TypeSerializer<W>, TypeInformation<T>) - 类 中的静态方法org.apache.flink.state.api.input.operator.WindowReaderOperator
 
reduce(Iterable<OperatorState>, Collector<CheckpointMetadata>) - 类 中的方法org.apache.flink.state.api.output.MergeOperatorStates
 
reduce(Iterable<TaggedOperatorSubtaskState>, Collector<OperatorState>) - 类 中的方法org.apache.flink.state.api.output.OperatorSubtaskStateReducer
 
reduce(ReduceFunction<T>) - 类 中的方法org.apache.flink.state.api.WindowedOperatorTransformation
Applies a reduce function to the window.
reduce(ReduceFunction<T>, WindowFunction<T, R, K, W>) - 类 中的方法org.apache.flink.state.api.WindowedOperatorTransformation
Applies the given window function to each window.
reduce(ReduceFunction<T>, ProcessWindowFunction<T, R, K, W>) - 类 中的方法org.apache.flink.state.api.WindowedOperatorTransformation
Applies the given window function to each window.
reduce(String, ReduceFunction<T>, TypeInformation<K>, TypeInformation<T>) - 类 中的方法org.apache.flink.state.api.WindowReader
Reads window state generated using a ReduceFunction.
reduce(String, ReduceFunction<T>, WindowReaderFunction<T, OUT, K, W>, TypeInformation<K>, TypeInformation<T>, TypeInformation<OUT>) - 类 中的方法org.apache.flink.state.api.WindowReader
Reads window state generated using a ReduceFunction.
ReduceEvictingWindowReaderFunction<IN,OUT,KEY,W extends org.apache.flink.streaming.api.windowing.windows.Window> - org.apache.flink.state.api.input.operator.window中的类
A wrapper function for reading state from an evicting window operator with a reduce function.
ReduceEvictingWindowReaderFunction(WindowReaderFunction<IN, OUT, KEY, W>, ReduceFunction<IN>) - 类 的构造器org.apache.flink.state.api.input.operator.window.ReduceEvictingWindowReaderFunction
 
reducingState() - 接口 中的静态方法org.apache.flink.state.api.input.operator.window.WindowContents
 
registeredEventTimeTimers() - 接口 中的方法org.apache.flink.state.api.functions.KeyedStateReaderFunction.Context
 
registeredEventTimeTimers() - 接口 中的方法org.apache.flink.state.api.functions.WindowReaderFunction.Context
 
registeredProcessingTimeTimers() - 接口 中的方法org.apache.flink.state.api.functions.KeyedStateReaderFunction.Context
 
registeredProcessingTimeTimers() - 接口 中的方法org.apache.flink.state.api.functions.WindowReaderFunction.Context
 
registerEventTimeTimer(long) - 类 中的方法org.apache.flink.state.api.output.operators.LazyTimerService
 
registerProcessingTimeTimer(long) - 类 中的方法org.apache.flink.state.api.output.operators.LazyTimerService
 
registerTimer(long, ProcessingTimeCallback) - 类 中的方法org.apache.flink.state.api.runtime.NeverFireProcessingTimeService
 
registerUserCodeClassLoaderReleaseHookIfAbsent(String, Runnable) - 类 中的方法org.apache.flink.state.api.runtime.SavepointRuntimeContext
 
remove() - 类 中的方法org.apache.flink.state.api.input.MultiStateKeyIterator
Removes the current key from ALL known states in the state backend.
removeOperator(String) - 类 中的方法org.apache.flink.state.api.runtime.metadata.SavepointMetadata
 
removeOperator(String) - 类 中的方法org.apache.flink.state.api.WritableSavepoint
Drop an existing operator from the savepoint.

S

Savepoint - org.apache.flink.state.api中的类
This class provides entry points for loading an existing savepoint, or a new empty savepoint.
SavepointEnvironment - org.apache.flink.state.api.runtime中的类
A minimally implemented Environment that provides the functionality required to run the state-processor-api.
SavepointEnvironment.Builder - org.apache.flink.state.api.runtime中的类
SavepointLoader - org.apache.flink.state.api.runtime中的类
Utility class for loading CheckpointMetadata metadata.
SavepointMetadata - org.apache.flink.state.api.runtime.metadata中的类
Savepoint metadata that can be modified.
SavepointMetadata(int, Collection<MasterState>, Collection<OperatorState>) - 类 的构造器org.apache.flink.state.api.runtime.metadata.SavepointMetadata
 
SavepointOutputFormat - org.apache.flink.state.api.output中的类
An output format to serialize CheckpointMetadata metadata to distributed storage.
SavepointOutputFormat(Path) - 类 的构造器org.apache.flink.state.api.output.SavepointOutputFormat
 
SavepointRuntimeContext - org.apache.flink.state.api.runtime中的类
A streaming RuntimeContext which delegates to the underlying batch RuntimeContext along with a specified KeyedStateStore.
SavepointRuntimeContext(RuntimeContext, KeyedStateStore) - 类 的构造器org.apache.flink.state.api.runtime.SavepointRuntimeContext
 
SavepointWriterOperatorFactory - org.apache.flink.state.api中的接口
Creates a savepoint writing operator from a savepoint path.
scheduleAtFixedRate(ProcessingTimeCallback, long, long) - 类 中的方法org.apache.flink.state.api.runtime.NeverFireProcessingTimeService
 
scheduleWithFixedDelay(ProcessingTimeCallback, long, long) - 类 中的方法org.apache.flink.state.api.runtime.NeverFireProcessingTimeService
 
setChainingStrategy(ChainingStrategy) - 类 中的方法org.apache.flink.state.api.output.operators.StateBootstrapWrapperOperator
 
setConfiguration(Configuration) - 类 中的方法org.apache.flink.state.api.runtime.SavepointEnvironment.Builder
 
setCurrentKey(Object) - 类 中的方法org.apache.flink.state.api.input.operator.StateReaderOperator
 
setCurrentKey(Object) - 类 中的方法org.apache.flink.state.api.output.operators.StateBootstrapWrapperOperator
 
setKeyContextElement1(StreamRecord<?>) - 类 中的方法org.apache.flink.state.api.output.operators.StateBootstrapWrapperOperator
 
setKeyContextElement2(StreamRecord<?>) - 类 中的方法org.apache.flink.state.api.output.operators.StateBootstrapWrapperOperator
 
setMaxParallelism(int) - 类 中的方法org.apache.flink.state.api.OneInputOperatorTransformation
Sets the maximum parallelism of this operator.
setPrioritizedOperatorSubtaskState(PrioritizedOperatorSubtaskState) - 类 中的方法org.apache.flink.state.api.runtime.SavepointEnvironment.Builder
 
setRuntimeContext(RuntimeContext) - 类 中的方法org.apache.flink.state.api.input.operator.window.EvictingWindowReaderFunction
 
setSubtaskIndex(int) - 类 中的方法org.apache.flink.state.api.runtime.SavepointEnvironment.Builder
 
setup(ExecutionConfig, KeyedStateBackend<KEY>, InternalTimeServiceManager<KEY>, SavepointRuntimeContext) - 类 中的方法org.apache.flink.state.api.input.operator.StateReaderOperator
 
setup(StreamTask<?, ?>, StreamConfig, Output<StreamRecord<TaggedOperatorSubtaskState>>) - 类 中的方法org.apache.flink.state.api.output.operators.StateBootstrapWrapperOperator
 
shutdownService() - 类 中的方法org.apache.flink.state.api.runtime.NeverFireProcessingTimeService
 
shutdownServiceUninterruptible(long) - 类 中的方法org.apache.flink.state.api.runtime.NeverFireProcessingTimeService
 
snapshot(OP, int, long, boolean, boolean, Configuration, Path) - 类 中的静态方法org.apache.flink.state.api.output.SnapshotUtils
 
snapshotState(long, long, CheckpointOptions, CheckpointStreamFactory) - 类 中的方法org.apache.flink.state.api.output.operators.StateBootstrapWrapperOperator
 
SnapshotUtils - org.apache.flink.state.api.output中的类
Takes a final snapshot of the state of an operator subtask.
state - 类 中的变量org.apache.flink.state.api.output.TaggedOperatorSubtaskState
 
stateBackend - 类 中的变量org.apache.flink.state.api.WritableSavepoint
The state backend to use when writing this savepoint.
StateBootstrapFunction<IN> - org.apache.flink.state.api.functions中的类
Interface for writing elements to operator state.
StateBootstrapFunction() - 类 的构造器org.apache.flink.state.api.functions.StateBootstrapFunction
 
StateBootstrapFunction.Context - org.apache.flink.state.api.functions中的接口
Context that StateBootstrapFunction's can use for getting additional data about an input record.
StateBootstrapOperator<IN> - org.apache.flink.state.api.output.operators中的类
A StreamOperator for executing StateBootstrapFunction's.
StateBootstrapOperator(long, Path, StateBootstrapFunction<IN>) - 类 的构造器org.apache.flink.state.api.output.operators.StateBootstrapOperator
 
StateBootstrapWrapperOperator<IN,OUT,OP extends org.apache.flink.streaming.api.operators.AbstractStreamOperator<OUT> & org.apache.flink.streaming.api.operators.OneInputStreamOperator<IN,OUT>> - org.apache.flink.state.api.output.operators中的类
Wraps an existing operator so it can be bootstrapped.
StateBootstrapWrapperOperator(long, Path, OP) - 类 的构造器org.apache.flink.state.api.output.operators.StateBootstrapWrapperOperator
 
StatePathExtractor - org.apache.flink.state.api.output中的类
Extracts all file paths that are part of the provided OperatorState.
StatePathExtractor() - 类 的构造器org.apache.flink.state.api.output.StatePathExtractor
 
StateReaderOperator<F extends org.apache.flink.api.common.functions.Function,KEY,N,OUT> - org.apache.flink.state.api.input.operator中的类
Base class for executing functions that read keyed state.
StateReaderOperator(F, TypeInformation<KEY>, TypeSerializer<N>) - 类 的构造器org.apache.flink.state.api.input.operator.StateReaderOperator
 

T

TaggedOperatorSubtaskState - org.apache.flink.state.api.output中的类
A simple wrapper pojo that tags OperatorSubtaskState with metadata.
TaggedOperatorSubtaskState(int, OperatorSubtaskState) - 类 的构造器org.apache.flink.state.api.output.TaggedOperatorSubtaskState
 
timerService() - 类 中的方法org.apache.flink.state.api.functions.KeyedStateBootstrapFunction.Context
A TimerService for querying time and registering timers.
timestamp(T) - 接口 中的方法org.apache.flink.state.api.functions.Timestamper
 
timestamp(T) - 类 中的方法org.apache.flink.state.api.output.TimestampAssignerWrapper
 
TimestampAssignerWrapper<T> - org.apache.flink.state.api.output中的类
Wraps an existing TimestampAssigner into a Timestamper.
TimestampAssignerWrapper(TimestampAssigner<T>) - 类 的构造器org.apache.flink.state.api.output.TimestampAssignerWrapper
 
Timestamper<T> - org.apache.flink.state.api.functions中的接口
Assigns an event time timestamp to the given record.
toString() - 类 中的方法org.apache.flink.state.api.output.TaggedOperatorSubtaskState
 
transform(Iterable<StreamRecord<IN>>) - 类 中的方法org.apache.flink.state.api.input.operator.window.AggregateEvictingWindowReaderFunction
 
transform(Iterable<StreamRecord<IN>>) - 类 中的方法org.apache.flink.state.api.input.operator.window.EvictingWindowReaderFunction
 
transform(Iterable<StreamRecord<IN>>) - 类 中的方法org.apache.flink.state.api.input.operator.window.ProcessEvictingWindowReader
 
transform(Iterable<StreamRecord<IN>>) - 类 中的方法org.apache.flink.state.api.input.operator.window.ReduceEvictingWindowReaderFunction
 
transform(KeyedStateBootstrapFunction<K, T>) - 类 中的方法org.apache.flink.state.api.KeyedOperatorTransformation
Applies the given KeyedStateBootstrapFunction on the keyed input.
transform(SavepointWriterOperatorFactory) - 类 中的方法org.apache.flink.state.api.KeyedOperatorTransformation
Method for passing user defined operators along with the type information that will transform the OperatorTransformation.
transform(StateBootstrapFunction<T>) - 类 中的方法org.apache.flink.state.api.OneInputOperatorTransformation
Applies the given StateBootstrapFunction on the non-keyed input.
transform(BroadcastStateBootstrapFunction<T>) - 类 中的方法org.apache.flink.state.api.OneInputOperatorTransformation
Applies the given BroadcastStateBootstrapFunction on the non-keyed input.
transform(SavepointWriterOperatorFactory) - 类 中的方法org.apache.flink.state.api.OneInputOperatorTransformation
Method for passing user defined operators along with the type information that will transform the OperatorTransformation.
trigger(Trigger<? super T, ? super W>) - 类 中的方法org.apache.flink.state.api.WindowedOperatorTransformation
Sets the Trigger that should be used to trigger window emission.
triggerState(StateDescriptor<S, ?>) - 接口 中的方法org.apache.flink.state.api.functions.WindowReaderFunction.Context
Retrieves a State object that can be used to interact with fault-tolerant state that is scoped to the trigger which corresponds to the current window.

U

UnionStateInputFormat<OT> - org.apache.flink.state.api.input中的类
Input format for reading operator union state.
UnionStateInputFormat(OperatorState, ListStateDescriptor<OT>) - 类 的构造器org.apache.flink.state.api.input.UnionStateInputFormat
Creates an input format for reading union state from an operator in a savepoint.

V

VoidTriggerable<K,N> - org.apache.flink.state.api.runtime中的类
A Triggerable that does nothing.

W

window(WindowAssigner<?, W>) - 类 中的方法org.apache.flink.state.api.ExistingSavepoint
Read window state from an operator in a Savepoint.
window(TypeSerializer<W>) - 类 中的方法org.apache.flink.state.api.ExistingSavepoint
Read window state from an operator in a Savepoint.
window() - 接口 中的方法org.apache.flink.state.api.functions.WindowReaderFunction.Context
Returns the window that is being evaluated.
window(WindowAssigner<? super T, W>) - 类 中的方法org.apache.flink.state.api.KeyedOperatorTransformation
Windows this transformation into a WindowedOperatorTransformation, which bootstraps state that can be restored by a WindowOperator.
WindowContents<S extends org.apache.flink.api.common.state.State,IN> - org.apache.flink.state.api.input.operator.window中的接口
An abstraction for transforming any State type into an iterable over its contents.
WindowedOperatorTransformation<T,K,W extends org.apache.flink.streaming.api.windowing.windows.Window> - org.apache.flink.state.api中的类
A WindowedOperatorTransformation represents a OneInputOperatorTransformation for bootstrapping window state.
WindowReader<W extends org.apache.flink.streaming.api.windowing.windows.Window> - org.apache.flink.state.api中的类
This class provides entry points for reading keyed state written out using the WindowOperator.
WindowReaderFunction<IN,OUT,KEY,W extends org.apache.flink.streaming.api.windowing.windows.Window> - org.apache.flink.state.api.functions中的类
Base abstract class for functions that are evaluated over keyed (grouped) windows using a context for retrieving extra information.
WindowReaderFunction() - 类 的构造器org.apache.flink.state.api.functions.WindowReaderFunction
 
WindowReaderFunction.Context<W extends org.apache.flink.streaming.api.windowing.windows.Window> - org.apache.flink.state.api.functions中的接口
The context holding window metadata.
WindowReaderOperator<S extends org.apache.flink.api.common.state.State,KEY,IN,W extends org.apache.flink.streaming.api.windowing.windows.Window,OUT> - org.apache.flink.state.api.input.operator中的类
A StateReaderOperator for reading WindowOperator state.
windowState() - 接口 中的方法org.apache.flink.state.api.functions.WindowReaderFunction.Context
State accessor for per-key and per-window state.
withConfiguration(ConfigOption<T>, T) - 类 中的方法org.apache.flink.state.api.WritableSavepoint
Sets a configuration that will be applied to the stream operators used to bootstrap a new savepoint.
withOperator(String, BootstrapTransformation<T>) - 类 中的方法org.apache.flink.state.api.WritableSavepoint
Adds a new operator to the savepoint.
WritableSavepoint<F extends WritableSavepoint> - org.apache.flink.state.api中的类
A WritableSavepoint is any savepoint that can be written to from a batch context.
write(String) - 类 中的方法org.apache.flink.state.api.WritableSavepoint
Write out a new or updated savepoint.
writeRecord(Path) - 类 中的方法org.apache.flink.state.api.output.FileCopyFunction
 
writeRecord(CheckpointMetadata) - 类 中的方法org.apache.flink.state.api.output.SavepointOutputFormat
 
A B C D E F G H I K L M N O P Q R S T U V W 
跳过导航链接

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