Interface and Description |
---|
org.apache.flink.runtime.state.internal.InternalFoldingState
will be removed in a future version
|
org.apache.flink.migration.runtime.state.KvStateSnapshot
Internal class for savepoint backwards compatibility. Don't use for other purposes.
|
org.apache.flink.migration.runtime.state.memory.MigrationRestoreSnapshot
Internal class for savepoint backwards compatibility. Don't use for other purposes.
|
org.apache.flink.migration.runtime.state.StateHandle
Internal class for savepoint backwards compatibility. Don't use for other purposes.
|
org.apache.flink.migration.runtime.state.StateObject
Internal class for savepoint backwards compatibility. Don't use for other purposes.
|
org.apache.flink.migration.runtime.state.StreamStateHandle
Internal class for savepoint backwards compatibility. Don't use for other purposes.
|
Class and Description |
---|
org.apache.flink.migration.runtime.state.AbstractCloseableHandle
Internal class for savepoint backwards compatibility. Don't use for other purposes.
|
org.apache.flink.migration.runtime.state.filesystem.AbstractFileStateHandle
Internal class for savepoint backwards compatibility. Don't use for other purposes.
|
org.apache.flink.migration.runtime.state.filesystem.AbstractFsStateSnapshot
Internal class for savepoint backwards compatibility. Don't use for other purposes.
|
org.apache.flink.migration.runtime.state.memory.AbstractMemStateSnapshot
Internal class for savepoint backwards compatibility. Don't use for other purposes.
|
org.apache.flink.migration.runtime.state.memory.AbstractMigrationRestoreStrategy
Internal class for savepoint backwards compatibility. Don't use for other purposes.
|
org.apache.flink.migration.runtime.state.AbstractStateBackend
Internal class for savepoint backwards compatibility. Don't use for other purposes.
|
org.apache.flink.migration.runtime.state.memory.ByteStreamStateHandle
Internal class for savepoint backwards compatibility. Don't use for other purposes.
|
org.apache.flink.migration.runtime.state.filesystem.FileSerializableStateHandle
Internal class for savepoint backwards compatibility. Don't use for other purposes.
|
org.apache.flink.migration.runtime.state.filesystem.FileStreamStateHandle
Internal class for savepoint backwards compatibility. Don't use for other purposes.
|
org.apache.flink.migration.runtime.state.filesystem.FsFoldingState
Internal class for savepoint backwards compatibility. Don't use for other purposes.
|
org.apache.flink.migration.runtime.state.filesystem.FsListState
Internal class for savepoint backwards compatibility. Don't use for other purposes.
|
org.apache.flink.migration.runtime.state.filesystem.FsReducingState
Internal class for savepoint backwards compatibility. Don't use for other purposes.
|
org.apache.flink.migration.runtime.state.filesystem.FsStateBackend
Internal class for savepoint backwards compatibility. Don't use for other purposes.
|
org.apache.flink.migration.runtime.state.filesystem.FsValueState
Internal class for savepoint backwards compatibility. Don't use for other purposes.
|
org.apache.flink.runtime.state.heap.HeapFoldingState
will be removed in a future version
|
org.apache.flink.migration.runtime.checkpoint.KeyGroupState
Internal class for savepoint backwards compatibility. Don't use for other purposes.
|
org.apache.flink.migration.api.common.state.ListStateDescriptor
Internal class for savepoint backwards compatibility. Don't use for other purposes.
|
org.apache.flink.migration.runtime.state.memory.MemFoldingState
Internal class for savepoint backwards compatibility. Don't use for other purposes.
|
org.apache.flink.migration.runtime.state.memory.MemListState
Internal class for savepoint backwards compatibility. Don't use for other purposes.
|
org.apache.flink.migration.runtime.state.memory.MemReducingState
Internal class for savepoint backwards compatibility. Don't use for other purposes.
|
org.apache.flink.migration.runtime.state.memory.MemValueState
Internal class for savepoint backwards compatibility. Don't use for other purposes.
|
org.apache.flink.migration.state.MigrationKeyGroupStateHandle
Internal class for savepoint backwards compatibility. Don't use for other purposes.
|
org.apache.flink.migration.MigrationNamespaceSerializerProxy
Internal class for savepoint backwards compatibility. Don't use for other purposes.
|
org.apache.flink.migration.state.MigrationStreamStateHandle
Internal class for savepoint backwards compatibility. Don't use for other purposes.
|
org.apache.flink.migration.streaming.runtime.tasks.StreamTaskState
Internal class for savepoint backwards compatibility. Don't use for other purposes.
|
org.apache.flink.migration.streaming.runtime.tasks.StreamTaskStateList
Internal class for savepoint backwards compatibility. Don't use for other purposes.
|
org.apache.flink.migration.runtime.checkpoint.SubtaskState
Internal class for savepoint backwards compatibility. Don't use for other purposes.
|
org.apache.flink.migration.runtime.checkpoint.TaskState
Internal class for savepoint backwards compatibility. Don't use for other purposes.
|
org.apache.flink.runtime.checkpoint.TaskState
Internal class for savepoint backwards compatibility. Don't use for other purposes.
|
Method and Description |
---|
org.apache.flink.runtime.checkpoint.savepoint.SavepointV2.convertToOperatorStateSavepointV2(Map<JobVertexID, ExecutionJobVertex>, Savepoint)
Only kept for backwards-compatibility with versions < 1.3. Will be removed in the future.
|
org.apache.flink.runtime.state.AbstractKeyedStateBackend.createFoldingState(TypeSerializer<N>, FoldingStateDescriptor<T, ACC>)
will be removed in a future version
|
org.apache.flink.runtime.state.TaskStateHandles.getLegacyOperatorState()
Non-repartitionable operator state that has been deprecated.
Can be removed when we remove the APIs for non-repartitionable operator state.
|
org.apache.flink.runtime.checkpoint.OperatorSubtaskState.getLegacyOperatorState()
Non-repartitionable operator state that has been deprecated.
Can be removed when we remove the APIs for non-repartitionable operator state.
|
org.apache.flink.runtime.checkpoint.SubtaskState.getLegacyOperatorState()
Non-repartitionable operator state that has been deprecated.
Can be removed when we remove the APIs for non-repartitionable operator state.
|
org.apache.flink.runtime.state.DefaultOperatorStateBackend.getOperatorState(ListStateDescriptor<S>)
This was deprecated as part of a refinement to the function names.
Please use
DefaultOperatorStateBackend.getListState(ListStateDescriptor) instead. |
org.apache.flink.runtime.state.DefaultOperatorStateBackend.getSerializableListState(String)
Using Java serialization for persisting state is not encouraged.
Please use
DefaultOperatorStateBackend.getListState(ListStateDescriptor) instead. |
org.apache.flink.runtime.checkpoint.savepoint.Savepoint.getTaskStates()
Only kept for backwards-compatibility with versionS < 1.3. Will be removed in the future.
|
org.apache.flink.runtime.operators.hash.InMemoryPartition.overwriteRecordAt(long, T)
Don't use this, overwrites record and causes inconsistency or data loss for
overwriting everything but records of the exact same size
|
Constructor and Description |
---|
org.apache.flink.runtime.minicluster.MiniCluster(Configuration)
Use
MiniCluster.MiniCluster(MiniClusterConfiguration) instead. |
org.apache.flink.runtime.minicluster.MiniCluster(Configuration, boolean)
Use
MiniCluster.MiniCluster(MiniClusterConfiguration) instead. |
org.apache.flink.runtime.checkpoint.savepoint.SavepointV2(long, Collection<TaskState>)
Only kept for backwards-compatibility with versions < 1.3. Will be removed in the future.
|
org.apache.flink.runtime.leaderretrieval.StandaloneLeaderRetrievalService(String) |
Copyright © 2014–2017 The Apache Software Foundation. All rights reserved.