Package | Description |
---|---|
org.apache.flink.runtime.rest.messages.checkpoints |
Modifier and Type | Method and Description |
---|---|
CheckpointConfigInfo.ProcessingMode |
CheckpointConfigInfo.ProcessingModeDeserializer.deserialize(org.apache.flink.shaded.jackson2.com.fasterxml.jackson.core.JsonParser jsonParser,
org.apache.flink.shaded.jackson2.com.fasterxml.jackson.databind.DeserializationContext deserializationContext) |
static CheckpointConfigInfo.ProcessingMode |
CheckpointConfigInfo.ProcessingMode.valueOf(String name)
Returns the enum constant of this type with the specified name.
|
static CheckpointConfigInfo.ProcessingMode[] |
CheckpointConfigInfo.ProcessingMode.values()
Returns an array containing the constants of this enum type, in
the order they are declared.
|
Modifier and Type | Method and Description |
---|---|
void |
CheckpointConfigInfo.ProcessingModeSerializer.serialize(CheckpointConfigInfo.ProcessingMode mode,
org.apache.flink.shaded.jackson2.com.fasterxml.jackson.core.JsonGenerator generator,
org.apache.flink.shaded.jackson2.com.fasterxml.jackson.databind.SerializerProvider serializerProvider) |
Constructor and Description |
---|
CheckpointConfigInfo(CheckpointConfigInfo.ProcessingMode processingMode,
long checkpointInterval,
long checkpointTimeout,
long minPauseBetweenCheckpoints,
int maxConcurrentCheckpoints,
CheckpointConfigInfo.ExternalizedCheckpointInfo externalizedCheckpointInfo,
String stateBackend,
boolean unalignedCheckpoints,
int tolerableFailedCheckpoints) |
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.