public class Checkpoints<T> extends Object implements AutoCloseable
| 构造器和说明 |
|---|
Checkpoints(org.apache.flink.api.common.typeutils.TypeSerializer<T> typeSerializer,
org.apache.flink.core.fs.FileSystem fileSystem,
org.apache.flink.util.function.SupplierWithException<org.apache.flink.core.fs.Path,IOException> pathSupplier) |
| 限定符和类型 | 方法和说明 |
|---|---|
void |
abort(long checkpointId) |
void |
append(T element) |
void |
close() |
void |
commitCheckpointsUntil(long checkpointId) |
org.apache.flink.core.fs.FileSystem |
getFileSystem() |
org.apache.flink.util.function.SupplierWithException<org.apache.flink.core.fs.Path,IOException> |
getPathSupplier() |
org.apache.flink.api.common.typeutils.TypeSerializer<T> |
getTypeSerializer() |
void |
startLogging(long checkpointId,
org.apache.flink.runtime.state.OperatorStateCheckpointOutputStream outputStream) |
public Checkpoints(org.apache.flink.api.common.typeutils.TypeSerializer<T> typeSerializer, org.apache.flink.core.fs.FileSystem fileSystem, org.apache.flink.util.function.SupplierWithException<org.apache.flink.core.fs.Path,IOException> pathSupplier)
public org.apache.flink.api.common.typeutils.TypeSerializer<T> getTypeSerializer()
public org.apache.flink.core.fs.FileSystem getFileSystem()
public org.apache.flink.util.function.SupplierWithException<org.apache.flink.core.fs.Path,IOException> getPathSupplier()
public void startLogging(long checkpointId,
org.apache.flink.runtime.state.OperatorStateCheckpointOutputStream outputStream)
throws IOException
IOExceptionpublic void abort(long checkpointId)
public void append(T element) throws IOException
IOExceptionpublic void commitCheckpointsUntil(long checkpointId)
public void close()
close 在接口中 AutoCloseableCopyright © 2019–2022 The Apache Software Foundation. All rights reserved.