Uses of Class
org.apache.flink.util.TernaryBoolean
-
-
Uses of TernaryBoolean in org.apache.flink.api.common.serialization
Methods in org.apache.flink.api.common.serialization that return TernaryBoolean Modifier and Type Method Description TernaryBoolean
SerializerConfig. isForceKryoAvroEnabled()
Returns whether forces Flink to register Apache Avro classes in Kryo serializer.TernaryBoolean
SerializerConfigImpl. isForceKryoAvroEnabled()
-
Uses of TernaryBoolean in org.apache.flink.contrib.streaming.state
Constructors in org.apache.flink.contrib.streaming.state with parameters of type TernaryBoolean Constructor Description EmbeddedRocksDBStateBackend(TernaryBoolean enableIncrementalCheckpointing)
Deprecated. -
Uses of TernaryBoolean in org.apache.flink.runtime.executiongraph
Methods in org.apache.flink.runtime.executiongraph that return TernaryBoolean Modifier and Type Method Description TernaryBoolean
AccessExecutionGraph. isChangelogStateBackendEnabled()
Returns whether the state changelog is enabled for this ExecutionGraph.TernaryBoolean
ArchivedExecutionGraph. isChangelogStateBackendEnabled()
TernaryBoolean
DefaultExecutionGraph. isChangelogStateBackendEnabled()
Constructors in org.apache.flink.runtime.executiongraph with parameters of type TernaryBoolean Constructor Description ArchivedExecutionGraph(JobID jobID, String jobName, Map<JobVertexID,ArchivedExecutionJobVertex> tasks, List<ArchivedExecutionJobVertex> verticesInCreationOrder, long[] stateTimestamps, JobStatus state, JobType jobType, ErrorInfo failureCause, String jsonPlan, StringifiedAccumulatorResult[] archivedUserAccumulators, Map<String,SerializedValue<OptionalFailure<Object>>> serializedUserAccumulators, ArchivedExecutionConfig executionConfig, boolean isStoppable, CheckpointCoordinatorConfiguration jobCheckpointingConfiguration, CheckpointStatsSnapshot checkpointStatsSnapshot, String stateBackendName, String checkpointStorageName, TernaryBoolean stateChangelogEnabled, String changelogStorageName)
-
Uses of TernaryBoolean in org.apache.flink.runtime.jobgraph.tasks
Methods in org.apache.flink.runtime.jobgraph.tasks that return TernaryBoolean Modifier and Type Method Description TernaryBoolean
JobCheckpointingSettings. isChangelogStateBackendEnabled()
TernaryBoolean
JobCheckpointingSettings. isStateBackendUseManagedMemory()
Constructors in org.apache.flink.runtime.jobgraph.tasks with parameters of type TernaryBoolean Constructor Description JobCheckpointingSettings(CheckpointCoordinatorConfiguration checkpointCoordinatorConfiguration, SerializedValue<StateBackend> defaultStateBackend, TernaryBoolean changelogStateBackendEnabled, SerializedValue<CheckpointStorage> defaultCheckpointStorage, SerializedValue<MasterTriggerRestoreHook.Factory[]> masterHooks)
JobCheckpointingSettings(CheckpointCoordinatorConfiguration checkpointCoordinatorConfiguration, SerializedValue<StateBackend> defaultStateBackend, TernaryBoolean changelogStateBackendEnabled, SerializedValue<CheckpointStorage> defaultCheckpointStorage, SerializedValue<MasterTriggerRestoreHook.Factory[]> masterHooks, TernaryBoolean stateBackendUseManagedMemory)
-
Uses of TernaryBoolean in org.apache.flink.runtime.source.coordinator
Methods in org.apache.flink.runtime.source.coordinator that return TernaryBoolean Modifier and Type Method Description TernaryBoolean
SourceCoordinatorContext. isBacklog()
Returns whether the Source is processing backlog data. -
Uses of TernaryBoolean in org.apache.flink.state.rocksdb
Constructors in org.apache.flink.state.rocksdb with parameters of type TernaryBoolean Constructor Description EmbeddedRocksDBStateBackend(TernaryBoolean enableIncrementalCheckpointing)
Creates a newEmbeddedRocksDBStateBackend
for storing local state. -
Uses of TernaryBoolean in org.apache.flink.streaming.api.environment
Methods in org.apache.flink.streaming.api.environment that return TernaryBoolean Modifier and Type Method Description TernaryBoolean
StreamExecutionEnvironment. isChangelogStateBackendEnabled()
Gets the enable status of change log for state backend. -
Uses of TernaryBoolean in org.apache.flink.streaming.api.graph
Methods in org.apache.flink.streaming.api.graph that return TernaryBoolean Modifier and Type Method Description TernaryBoolean
StreamConfig. isChangelogStateBackendEnabled(ClassLoader cl)
Methods in org.apache.flink.streaming.api.graph with parameters of type TernaryBoolean Modifier and Type Method Description void
StreamConfig. setChangelogStateBackendEnabled(TernaryBoolean enabled)
-
Uses of TernaryBoolean in org.apache.flink.util
Methods in org.apache.flink.util that return TernaryBoolean Modifier and Type Method Description static TernaryBoolean
TernaryBoolean. fromBoolean(boolean bool)
static TernaryBoolean
TernaryBoolean. fromBoxedBoolean(Boolean bool)
Converts the given boxed Boolean to a TernaryBoolean.static TernaryBoolean
TernaryBoolean. mergeTernaryBooleanWithConfig(TernaryBoolean original, ConfigOption<Boolean> configOption, ReadableConfig config)
Merges an existing value with a config, accepting the config's value only if the existing value is undefined.TernaryBoolean
TernaryBoolean. resolveUndefined(boolean valueForUndefined)
Gets the boolean value corresponding to this value.static TernaryBoolean
TernaryBoolean. valueOf(String name)
Returns the enum constant of this type with the specified name.static TernaryBoolean[]
TernaryBoolean. values()
Returns an array containing the constants of this enum type, in the order they are declared.Methods in org.apache.flink.util with parameters of type TernaryBoolean Modifier and Type Method Description static TernaryBoolean
TernaryBoolean. mergeTernaryBooleanWithConfig(TernaryBoolean original, ConfigOption<Boolean> configOption, ReadableConfig config)
Merges an existing value with a config, accepting the config's value only if the existing value is undefined.
-