Class DescriptorProperties
- java.lang.Object
-
- org.apache.flink.table.descriptors.DescriptorProperties
-
@Deprecated @Internal public class DescriptorProperties extends Object
Deprecated.This utility will be dropped soon.DynamicTableFactoryis based onConfigOptionand catalogs useCatalogPropertiesUtil.Utility class for having a unified string-based representation of Table API related classes such as TableSchema, TypeInformation, etc.Note to implementers: Please try to reuse key names as much as possible. Key-names should be hierarchical and lower case. Use "-" instead of dots or camel case. E.g., connector.schema.start-from = from-earliest. Try not to use the higher level in a key-name. E.g., instead of connector.kafka.kafka-version use connector.kafka.version.
Properties with key normalization enabled contain only lower-case keys.
-
-
Field Summary
Fields Modifier and Type Field Description static StringCOMMENTDeprecated.static StringDATA_TYPEDeprecated.static StringEXPRDeprecated.static StringINDEXDeprecated.static StringINDEX_COLUMNSDeprecated.static StringINDEX_NAMEDeprecated.static StringMETADATADeprecated.static StringNAMEDeprecated.static StringPARTITION_KEYSDeprecated.static StringPRIMARY_KEY_COLUMNSDeprecated.static StringPRIMARY_KEY_NAMEDeprecated.static StringTYPEDeprecated.static StringVIRTUALDeprecated.static StringWATERMARKDeprecated.static StringWATERMARK_ROWTIMEDeprecated.static StringWATERMARK_STRATEGYDeprecated.static StringWATERMARK_STRATEGY_DATA_TYPEDeprecated.static StringWATERMARK_STRATEGY_EXPRDeprecated.
-
Constructor Summary
Constructors Constructor Description DescriptorProperties()Deprecated.DescriptorProperties(boolean normalizeKeys)Deprecated.
-
Method Summary
All Methods Static Methods Instance Methods Concrete Methods Deprecated Methods Modifier and Type Method Description Map<String,String>asMap()Deprecated.Returns the properties as a map copy.Map<String,String>asPrefixedMap(String prefix)Deprecated.Returns the properties as a map copy with a prefix key.booleancontainsKey(String key)Deprecated.Returns if the given key is contained.booleanequals(Object o)Deprecated.<E> List<E>getArray(String key, Function<String,E> keyMapper)Deprecated.Returns all array elements under a given existing key.BigDecimalgetBigDecimal(String key)Deprecated.Returns a big decimal value under the given existing key.booleangetBoolean(String key)Deprecated.Returns a boolean value under the given existing key.bytegetByte(String key)Deprecated.Returns a byte value under the given existing key.CharactergetCharacter(String key)Deprecated.Returns a character value under the given existing key.<T> Class<T>getClass(String key, Class<T> superClass)Deprecated.Returns a class value under the given existing key.DataTypegetDataType(String key)Deprecated.Returns the DataType under the given existing key.doublegetDouble(String key)Deprecated.Returns a double value under the given existing key.DurationgetDuration(String key)Deprecated.Returns a javaDurationunder the given existing key.List<Map<String,String>>getFixedIndexedProperties(String key, List<String> subKeys)Deprecated.Returns the property keys of fixed indexed properties.floatgetFloat(String key)Deprecated.Returns a float value under the given given existing key.Map<String,String>getIndexedProperty(String key, String subKey)Deprecated.Returns all properties under a given key that contains an index in between.intgetInt(String key)Deprecated.Returns an integer value under the given existing key.longgetLong(String key)Deprecated.Returns a long value under the given existing key.org.apache.flink.configuration.MemorySizegetMemorySize(String key)Deprecated.Returns a FlinkMemorySizeunder the given existing key.<E> Optional<List<E>>getOptionalArray(String key, Function<String,E> keyMapper)Deprecated.Returns all array elements under a given key if it exists.Optional<BigDecimal>getOptionalBigDecimal(String key)Deprecated.Returns a big decimal value under the given key if it exists.Optional<Boolean>getOptionalBoolean(String key)Deprecated.Returns a boolean value under the given key if it exists.Optional<Byte>getOptionalByte(String key)Deprecated.Returns a byte value under the given key if it exists.Optional<Character>getOptionalCharacter(String key)Deprecated.Returns a character value under the given key if it exists.<T> Optional<Class<T>>getOptionalClass(String key, Class<T> superClass)Deprecated.Returns a class value under the given key if it exists.Optional<DataType>getOptionalDataType(String key)Deprecated.Returns the DataType under the given key if it exists.Optional<Double>getOptionalDouble(String key)Deprecated.Returns a double value under the given key if it exists.Optional<Duration>getOptionalDuration(String key)Deprecated.Returns a JavaDurationunder the given key if it exists.Optional<Float>getOptionalFloat(String key)Deprecated.Returns a float value under the given key if it exists.Optional<Integer>getOptionalInt(String key)Deprecated.Returns an integer value under the given key if it exists.Optional<Long>getOptionalLong(String key)Deprecated.Returns a long value under the given key if it exists.Optional<org.apache.flink.configuration.MemorySize>getOptionalMemorySize(String key)Deprecated.Returns a FlinkMemorySizeunder the given key if it exists.Optional<Short>getOptionalShort(String key)Deprecated.Returns a short value under the given key if it exists.Optional<String>getOptionalString(String key)Deprecated.Returns a string value under the given key if it exists.Optional<TableSchema>getOptionalTableSchema(String key)Deprecated.Returns a table schema under the given key if it exists.Optional<org.apache.flink.api.common.typeinfo.TypeInformation<?>>getOptionalType(String key)Deprecated.Returns the type information under the given key if it exists.List<String>getPartitionKeys()Deprecated.Returns partition keys.Map<String,String>getPropertiesWithPrefix(String prefix)Deprecated.Returns a map of properties whose key starts with the given prefix, and the prefix is removed upon return.shortgetShort(String key)Deprecated.Returns a short value under the given existing key.StringgetString(String key)Deprecated.Returns a string value under the given existing key.TableSchemagetTableSchema(String key)Deprecated.Returns a table schema under the given existing key.org.apache.flink.api.common.typeinfo.TypeInformation<?>getType(String key)Deprecated.Returns the type information under the given existing key.List<Map<String,String>>getVariableIndexedProperties(String key, List<String> requiredSubKeys)Deprecated.Returns the property keys of variable indexed properties.inthashCode()Deprecated.booleanhasPrefix(String prefix)Deprecated.Returns if a given prefix exists in the properties.booleanisValue(String key, String value)Deprecated.Returns if a value under key is exactly equal to the given value.static Consumer<String>noValidation()Deprecated.Returns an empty validation logic.voidputBoolean(String key, boolean b)Deprecated.Adds a boolean under the given key.voidputCharacter(String key, char c)Deprecated.Adds a character under the given key.voidputClass(String key, Class<?> clazz)Deprecated.Adds a class under the given key.voidputIndexedFixedProperties(String key, List<String> subKeys, List<List<String>> subKeyValues)Deprecated.Adds an indexed sequence of properties (with sub-properties) under a common key.voidputIndexedOptionalProperties(String key, List<String> subKeys, List<List<String>> subKeyValues)Deprecated.Adds an indexed sequence of properties (with sub-properties) under a common key.voidputIndexedVariableProperties(String key, List<Map<String,String>> subKeyValues)Deprecated.Adds an indexed mapping of properties under a common key.voidputInt(String key, int i)Deprecated.Adds an integer under the given key.voidputLong(String key, long l)Deprecated.Adds a long under the given key.voidputMemorySize(String key, org.apache.flink.configuration.MemorySize size)Deprecated.Adds a FlinkMemorySizeunder the given key.voidputPartitionKeys(List<String> keys)Deprecated.Adds table partition keys.voidputProperties(Map<String,String> properties)Deprecated.Adds a set of properties.voidputProperties(DescriptorProperties otherProperties)Deprecated.Adds a set of descriptor properties.voidputPropertiesWithPrefix(String prefix, Map<String,String> prop)Deprecated.Adds a properties map by appending the given prefix to element keys with a dot.voidputString(String key, String str)Deprecated.Adds a string under the given key.voidputTableSchema(String key, TableSchema schema)Deprecated.Adds a table schema under the given key.StringtoString()Deprecated.static StringtoString(String str)Deprecated.static StringtoString(String key, String value)Deprecated.static StringtoString(Map<String,String> propertyMap)Deprecated.voidvalidateArray(String key, Consumer<String> elementValidation, int minLength)Deprecated.Validates an array of values.voidvalidateArray(String key, Consumer<String> elementValidation, int minLength, int maxLength)Deprecated.Validates an array of values.voidvalidateBigDecimal(String key, boolean isOptional)Deprecated.Validates a big decimal property.voidvalidateBigDecimal(String key, boolean isOptional, BigDecimal min, BigDecimal max)Deprecated.Validates a big decimal property.voidvalidateBoolean(String key, boolean isOptional)Deprecated.Validates that a boolean value is present under the given key.voidvalidateByte(String key, boolean isOptional)Deprecated.Validates a byte property.voidvalidateByte(String key, boolean isOptional, byte min)Deprecated.Validates a byte property.voidvalidateByte(String key, boolean isOptional, byte min, byte max)Deprecated.Validates a byte property.voidvalidateDataType(String key, String fallbackKey, boolean isOptional)Deprecated.Validates a data type property.voidvalidateDouble(String key, boolean isOptional)Deprecated.Validates a double property.voidvalidateDouble(String key, boolean isOptional, double min)Deprecated.Validates a double property.voidvalidateDouble(String key, boolean isOptional, double min, double max)Deprecated.Validates a double property.voidvalidateDuration(String key, boolean isOptional, int precision)Deprecated.Validates a JavaDuration.voidvalidateDuration(String key, boolean isOptional, int precision, long min)Deprecated.Validates a JavaDuration.voidvalidateDuration(String key, boolean isOptional, int precision, long min, long max)Deprecated.Validates a JavaDuration.voidvalidateEnum(String key, boolean isOptional, Map<String,Consumer<String>> enumValidation)Deprecated.Validates an enum property with a set of validation logic for each enum value.voidvalidateEnumValues(String key, boolean isOptional, List<String> values)Deprecated.Validates an enum property with a set of enum values.voidvalidateExclusion(String key)Deprecated.Validates that the given key is not included in these properties.voidvalidateFixedIndexedProperties(String key, boolean allowEmpty, Map<String,Consumer<String>> subKeyValidation)Deprecated.Validation for fixed indexed properties.voidvalidateFloat(String key, boolean isOptional)Deprecated.Validates a float property.voidvalidateFloat(String key, boolean isOptional, float min)Deprecated.Validates a float property.voidvalidateFloat(String key, boolean isOptional, float min, float max)Deprecated.Validates a float property.voidvalidateInt(String key, boolean isOptional)Deprecated.Validates an integer property.voidvalidateInt(String key, boolean isOptional, int min)Deprecated.Validates an integer property.voidvalidateInt(String key, boolean isOptional, int min, int max)Deprecated.Validates an integer property.voidvalidateLong(String key, boolean isOptional)Deprecated.Validates an long property.voidvalidateLong(String key, boolean isOptional, long min)Deprecated.Validates an long property.voidvalidateLong(String key, boolean isOptional, long min, long max)Deprecated.Validates an long property.voidvalidateMemorySize(String key, boolean isOptional, int precision)Deprecated.Validates a FlinkMemorySize.voidvalidateMemorySize(String key, boolean isOptional, int precision, long min)Deprecated.Validates a FlinkMemorySize.voidvalidateMemorySize(String key, boolean isOptional, int precision, long min, long max)Deprecated.Validates a FlinkMemorySize.voidvalidatePrefixExclusion(String prefix)Deprecated.Validates that the given prefix is not included in these properties.voidvalidateShort(String key, boolean isOptional)Deprecated.Validates a short property.voidvalidateShort(String key, boolean isOptional, short min)Deprecated.Validates a short property.voidvalidateShort(String key, boolean isOptional, short min, short max)Deprecated.Validates a short property.voidvalidateString(String key, boolean isOptional)Deprecated.Validates a string property.voidvalidateString(String key, boolean isOptional, int minLen)Deprecated.Validates a string property.voidvalidateString(String key, boolean isOptional, int minLen, int maxLen)Deprecated.Validates a string property.voidvalidateTableSchema(String key, boolean isOptional)Deprecated.Validates a table schema property.voidvalidateType(String key, boolean isOptional, boolean requireRow)Deprecated.Validates a type property.voidvalidateValue(String key, String value, boolean isOptional)Deprecated.Validates that a certain value is present under the given key.DescriptorPropertieswithoutKeys(List<String> keys)Deprecated.Returns a new properties instance with the given keys removed.
-
-
-
Field Detail
-
NAME
public static final String NAME
Deprecated.- See Also:
- Constant Field Values
-
TYPE
public static final String TYPE
Deprecated.- See Also:
- Constant Field Values
-
DATA_TYPE
public static final String DATA_TYPE
Deprecated.- See Also:
- Constant Field Values
-
EXPR
public static final String EXPR
Deprecated.- See Also:
- Constant Field Values
-
METADATA
public static final String METADATA
Deprecated.- See Also:
- Constant Field Values
-
VIRTUAL
public static final String VIRTUAL
Deprecated.- See Also:
- Constant Field Values
-
PARTITION_KEYS
public static final String PARTITION_KEYS
Deprecated.- See Also:
- Constant Field Values
-
WATERMARK
public static final String WATERMARK
Deprecated.- See Also:
- Constant Field Values
-
WATERMARK_ROWTIME
public static final String WATERMARK_ROWTIME
Deprecated.- See Also:
- Constant Field Values
-
WATERMARK_STRATEGY
public static final String WATERMARK_STRATEGY
Deprecated.- See Also:
- Constant Field Values
-
WATERMARK_STRATEGY_EXPR
public static final String WATERMARK_STRATEGY_EXPR
Deprecated.- See Also:
- Constant Field Values
-
WATERMARK_STRATEGY_DATA_TYPE
public static final String WATERMARK_STRATEGY_DATA_TYPE
Deprecated.- See Also:
- Constant Field Values
-
PRIMARY_KEY_NAME
public static final String PRIMARY_KEY_NAME
Deprecated.- See Also:
- Constant Field Values
-
PRIMARY_KEY_COLUMNS
public static final String PRIMARY_KEY_COLUMNS
Deprecated.- See Also:
- Constant Field Values
-
INDEX
public static final String INDEX
Deprecated.- See Also:
- Constant Field Values
-
INDEX_NAME
public static final String INDEX_NAME
Deprecated.- See Also:
- Constant Field Values
-
INDEX_COLUMNS
public static final String INDEX_COLUMNS
Deprecated.- See Also:
- Constant Field Values
-
COMMENT
public static final String COMMENT
Deprecated.- See Also:
- Constant Field Values
-
-
Method Detail
-
putProperties
public void putProperties(Map<String,String> properties)
Deprecated.Adds a set of properties.
-
putProperties
public void putProperties(DescriptorProperties otherProperties)
Deprecated.Adds a set of descriptor properties.
-
putPropertiesWithPrefix
public void putPropertiesWithPrefix(String prefix, Map<String,String> prop)
Deprecated.Adds a properties map by appending the given prefix to element keys with a dot.For example: for prefix "flink" and a map of a single property with key "k" and value "v". The added property will be as key "flink.k" and value "v".
-
putClass
public void putClass(String key, Class<?> clazz)
Deprecated.Adds a class under the given key.
-
putString
public void putString(String key, String str)
Deprecated.Adds a string under the given key.
-
putBoolean
public void putBoolean(String key, boolean b)
Deprecated.Adds a boolean under the given key.
-
putLong
public void putLong(String key, long l)
Deprecated.Adds a long under the given key.
-
putInt
public void putInt(String key, int i)
Deprecated.Adds an integer under the given key.
-
putCharacter
public void putCharacter(String key, char c)
Deprecated.Adds a character under the given key.
-
putTableSchema
public void putTableSchema(String key, TableSchema schema)
Deprecated.Adds a table schema under the given key.
-
putPartitionKeys
public void putPartitionKeys(List<String> keys)
Deprecated.Adds table partition keys.
-
putMemorySize
public void putMemorySize(String key, org.apache.flink.configuration.MemorySize size)
Deprecated.Adds a FlinkMemorySizeunder the given key.
-
putIndexedFixedProperties
public void putIndexedFixedProperties(String key, List<String> subKeys, List<List<String>> subKeyValues)
Deprecated.Adds an indexed sequence of properties (with sub-properties) under a common key.For example:
schema.fields.0.type = INT, schema.fields.0.name = test schema.fields.1.type = LONG, schema.fields.1.name = test2The arity of each subKeyValues must match the arity of propertyKeys.
-
putIndexedOptionalProperties
public void putIndexedOptionalProperties(String key, List<String> subKeys, List<List<String>> subKeyValues)
Deprecated.Adds an indexed sequence of properties (with sub-properties) under a common key. Different withputIndexedFixedProperties(java.lang.String, java.util.List<java.lang.String>, java.util.List<java.util.List<java.lang.String>>), this method supports the properties value to be null, which would be ignore. The sub-properties should at least have one non-null value.For example:
schema.fields.0.type = INT, schema.fields.0.name = test schema.fields.1.type = LONG, schema.fields.1.name = test2 schema.fields.2.type = LONG, schema.fields.2.name = test3, schema.fields.2.expr = test2 + 1The arity of each subKeyValues must match the arity of propertyKeys.
-
putIndexedVariableProperties
public void putIndexedVariableProperties(String key, List<Map<String,String>> subKeyValues)
Deprecated.Adds an indexed mapping of properties under a common key.For example:
schema.fields.0.type = INT, schema.fields.0.name = test schema.fields.1.name = test2The arity of the subKeyValues can differ.
-
getOptionalString
public Optional<String> getOptionalString(String key)
Deprecated.Returns a string value under the given key if it exists.
-
getString
public String getString(String key)
Deprecated.Returns a string value under the given existing key.
-
getOptionalCharacter
public Optional<Character> getOptionalCharacter(String key)
Deprecated.Returns a character value under the given key if it exists.
-
getCharacter
public Character getCharacter(String key)
Deprecated.Returns a character value under the given existing key.
-
getOptionalClass
public <T> Optional<Class<T>> getOptionalClass(String key, Class<T> superClass)
Deprecated.Returns a class value under the given key if it exists.
-
getClass
public <T> Class<T> getClass(String key, Class<T> superClass)
Deprecated.Returns a class value under the given existing key.
-
getOptionalBigDecimal
public Optional<BigDecimal> getOptionalBigDecimal(String key)
Deprecated.Returns a big decimal value under the given key if it exists.
-
getBigDecimal
public BigDecimal getBigDecimal(String key)
Deprecated.Returns a big decimal value under the given existing key.
-
getOptionalBoolean
public Optional<Boolean> getOptionalBoolean(String key)
Deprecated.Returns a boolean value under the given key if it exists.
-
getBoolean
public boolean getBoolean(String key)
Deprecated.Returns a boolean value under the given existing key.
-
getOptionalByte
public Optional<Byte> getOptionalByte(String key)
Deprecated.Returns a byte value under the given key if it exists.
-
getByte
public byte getByte(String key)
Deprecated.Returns a byte value under the given existing key.
-
getOptionalDouble
public Optional<Double> getOptionalDouble(String key)
Deprecated.Returns a double value under the given key if it exists.
-
getDouble
public double getDouble(String key)
Deprecated.Returns a double value under the given existing key.
-
getOptionalFloat
public Optional<Float> getOptionalFloat(String key)
Deprecated.Returns a float value under the given key if it exists.
-
getFloat
public float getFloat(String key)
Deprecated.Returns a float value under the given given existing key.
-
getOptionalInt
public Optional<Integer> getOptionalInt(String key)
Deprecated.Returns an integer value under the given key if it exists.
-
getInt
public int getInt(String key)
Deprecated.Returns an integer value under the given existing key.
-
getOptionalLong
public Optional<Long> getOptionalLong(String key)
Deprecated.Returns a long value under the given key if it exists.
-
getLong
public long getLong(String key)
Deprecated.Returns a long value under the given existing key.
-
getOptionalShort
public Optional<Short> getOptionalShort(String key)
Deprecated.Returns a short value under the given key if it exists.
-
getShort
public short getShort(String key)
Deprecated.Returns a short value under the given existing key.
-
getOptionalType
public Optional<org.apache.flink.api.common.typeinfo.TypeInformation<?>> getOptionalType(String key)
Deprecated.Returns the type information under the given key if it exists.
-
getType
public org.apache.flink.api.common.typeinfo.TypeInformation<?> getType(String key)
Deprecated.Returns the type information under the given existing key.
-
getOptionalDataType
public Optional<DataType> getOptionalDataType(String key)
Deprecated.Returns the DataType under the given key if it exists.
-
getDataType
public DataType getDataType(String key)
Deprecated.Returns the DataType under the given existing key.
-
getOptionalTableSchema
public Optional<TableSchema> getOptionalTableSchema(String key)
Deprecated.Returns a table schema under the given key if it exists.
-
getTableSchema
public TableSchema getTableSchema(String key)
Deprecated.Returns a table schema under the given existing key.
-
getOptionalMemorySize
public Optional<org.apache.flink.configuration.MemorySize> getOptionalMemorySize(String key)
Deprecated.Returns a FlinkMemorySizeunder the given key if it exists.
-
getMemorySize
public org.apache.flink.configuration.MemorySize getMemorySize(String key)
Deprecated.Returns a FlinkMemorySizeunder the given existing key.
-
getOptionalDuration
public Optional<Duration> getOptionalDuration(String key)
Deprecated.Returns a JavaDurationunder the given key if it exists.
-
getDuration
public Duration getDuration(String key)
Deprecated.Returns a javaDurationunder the given existing key.
-
getFixedIndexedProperties
public List<Map<String,String>> getFixedIndexedProperties(String key, List<String> subKeys)
Deprecated.Returns the property keys of fixed indexed properties.For example:
schema.fields.0.type = INT, schema.fields.0.name = test schema.fields.1.type = LONG, schema.fields.1.name = test2getFixedIndexedProperties("schema.fields", List("type", "name")) leads to:
0: Map("type" -> "schema.fields.0.type", "name" -> "schema.fields.0.name") 1: Map("type" -> "schema.fields.1.type", "name" -> "schema.fields.1.name")
-
getVariableIndexedProperties
public List<Map<String,String>> getVariableIndexedProperties(String key, List<String> requiredSubKeys)
Deprecated.Returns the property keys of variable indexed properties.For example:
schema.fields.0.type = INT, schema.fields.0.name = test schema.fields.1.type = LONGgetFixedIndexedProperties("schema.fields", List("type")) leads to:
0: Map("type" -> "schema.fields.0.type", "name" -> "schema.fields.0.name") 1: Map("type" -> "schema.fields.1.type")
-
getIndexedProperty
public Map<String,String> getIndexedProperty(String key, String subKey)
Deprecated.Returns all properties under a given key that contains an index in between.E.g. rowtime.0.name -> returns all rowtime.#.name properties
-
getOptionalArray
public <E> Optional<List<E>> getOptionalArray(String key, Function<String,E> keyMapper)
Deprecated.Returns all array elements under a given key if it exists.For example:
primary-key.0 = field1 primary-key.1 = field2leads to: List(field1, field2)
or:
primary-key = field1leads to: List(field1)
The key mapper gets the key of the current value e.g. "primary-key.1".
-
getArray
public <E> List<E> getArray(String key, Function<String,E> keyMapper)
Deprecated.Returns all array elements under a given existing key.
-
isValue
public boolean isValue(String key, String value)
Deprecated.Returns if a value under key is exactly equal to the given value.
-
getPropertiesWithPrefix
public Map<String,String> getPropertiesWithPrefix(String prefix)
Deprecated.Returns a map of properties whose key starts with the given prefix, and the prefix is removed upon return.For example, for prefix "flink" and a map of a single property with key "flink.k" and value "v", this method will return it as key "k" and value "v" by identifying and removing the prefix "flink".
-
validateString
public void validateString(String key, boolean isOptional)
Deprecated.Validates a string property.
-
validateString
public void validateString(String key, boolean isOptional, int minLen)
Deprecated.Validates a string property. The boundaries are inclusive.
-
validateString
public void validateString(String key, boolean isOptional, int minLen, int maxLen)
Deprecated.Validates a string property. The boundaries are inclusive.
-
validateInt
public void validateInt(String key, boolean isOptional)
Deprecated.Validates an integer property.
-
validateInt
public void validateInt(String key, boolean isOptional, int min)
Deprecated.Validates an integer property. The boundaries are inclusive.
-
validateInt
public void validateInt(String key, boolean isOptional, int min, int max)
Deprecated.Validates an integer property. The boundaries are inclusive.
-
validateLong
public void validateLong(String key, boolean isOptional)
Deprecated.Validates an long property.
-
validateLong
public void validateLong(String key, boolean isOptional, long min)
Deprecated.Validates an long property. The boundaries are inclusive.
-
validateLong
public void validateLong(String key, boolean isOptional, long min, long max)
Deprecated.Validates an long property. The boundaries are inclusive.
-
validateValue
public void validateValue(String key, String value, boolean isOptional)
Deprecated.Validates that a certain value is present under the given key.
-
validateBoolean
public void validateBoolean(String key, boolean isOptional)
Deprecated.Validates that a boolean value is present under the given key.
-
validateDouble
public void validateDouble(String key, boolean isOptional)
Deprecated.Validates a double property.
-
validateDouble
public void validateDouble(String key, boolean isOptional, double min)
Deprecated.Validates a double property. The boundaries are inclusive.
-
validateDouble
public void validateDouble(String key, boolean isOptional, double min, double max)
Deprecated.Validates a double property. The boundaries are inclusive.
-
validateBigDecimal
public void validateBigDecimal(String key, boolean isOptional)
Deprecated.Validates a big decimal property.
-
validateBigDecimal
public void validateBigDecimal(String key, boolean isOptional, BigDecimal min, BigDecimal max)
Deprecated.Validates a big decimal property. The boundaries are inclusive.
-
validateByte
public void validateByte(String key, boolean isOptional)
Deprecated.Validates a byte property.
-
validateByte
public void validateByte(String key, boolean isOptional, byte min)
Deprecated.Validates a byte property. The boundaries are inclusive.
-
validateByte
public void validateByte(String key, boolean isOptional, byte min, byte max)
Deprecated.Validates a byte property. The boundaries are inclusive.
-
validateFloat
public void validateFloat(String key, boolean isOptional)
Deprecated.Validates a float property.
-
validateFloat
public void validateFloat(String key, boolean isOptional, float min)
Deprecated.Validates a float property. The boundaries are inclusive.
-
validateFloat
public void validateFloat(String key, boolean isOptional, float min, float max)
Deprecated.Validates a float property. The boundaries are inclusive.
-
validateShort
public void validateShort(String key, boolean isOptional)
Deprecated.Validates a short property.
-
validateShort
public void validateShort(String key, boolean isOptional, short min)
Deprecated.Validates a short property. The boundaries are inclusive.
-
validateShort
public void validateShort(String key, boolean isOptional, short min, short max)
Deprecated.Validates a short property. The boundaries are inclusive.
-
validateFixedIndexedProperties
public void validateFixedIndexedProperties(String key, boolean allowEmpty, Map<String,Consumer<String>> subKeyValidation)
Deprecated.Validation for fixed indexed properties.For example:
schema.fields.0.data-type = INT, schema.fields.0.name = test schema.fields.1.data-type = BIGINT, schema.fields.1.name = test2The subKeyValidation map must define e.g. "data-type" and "name" and a validation logic for the given full key.
-
validateTableSchema
public void validateTableSchema(String key, boolean isOptional)
Deprecated.Validates a table schema property.
-
validateMemorySize
public void validateMemorySize(String key, boolean isOptional, int precision)
Deprecated.Validates a FlinkMemorySize.The precision defines the allowed minimum unit in bytes (e.g. 1024 would only allow KB).
-
validateMemorySize
public void validateMemorySize(String key, boolean isOptional, int precision, long min)
Deprecated.Validates a FlinkMemorySize. The boundaries are inclusive and in bytes.The precision defines the allowed minimum unit in bytes (e.g. 1024 would only allow KB).
-
validateMemorySize
public void validateMemorySize(String key, boolean isOptional, int precision, long min, long max)
Deprecated.Validates a FlinkMemorySize. The boundaries are inclusive and in bytes.The precision defines the allowed minimum unit in bytes (e.g. 1024 would only allow KB).
-
validateDuration
public void validateDuration(String key, boolean isOptional, int precision)
Deprecated.Validates a JavaDuration.The precision defines the allowed minimum unit in milliseconds (e.g. 1000 would only allow seconds).
-
validateDuration
public void validateDuration(String key, boolean isOptional, int precision, long min)
Deprecated.Validates a JavaDuration. The boundaries are inclusive and in milliseconds.The precision defines the allowed minimum unit in milliseconds (e.g. 1000 would only allow seconds).
-
validateDuration
public void validateDuration(String key, boolean isOptional, int precision, long min, long max)
Deprecated.Validates a JavaDuration. The boundaries are inclusive and in milliseconds.The precision defines the allowed minimum unit in milliseconds (e.g. 1000 would only allow seconds).
-
validateEnum
public void validateEnum(String key, boolean isOptional, Map<String,Consumer<String>> enumValidation)
Deprecated.Validates an enum property with a set of validation logic for each enum value.
-
validateEnumValues
public void validateEnumValues(String key, boolean isOptional, List<String> values)
Deprecated.Validates an enum property with a set of enum values.
-
validateType
public void validateType(String key, boolean isOptional, boolean requireRow)
Deprecated.Validates a type property.
-
validateDataType
public void validateDataType(String key, String fallbackKey, boolean isOptional)
Deprecated.Validates a data type property.
-
validateArray
public void validateArray(String key, Consumer<String> elementValidation, int minLength)
Deprecated.Validates an array of values.For example:
primary-key.0 = field1 primary-key.1 = field2leads to: List(field1, field2)
or:
primary-key = field1The validation consumer gets the key of the current value e.g. "primary-key.1".
-
validateArray
public void validateArray(String key, Consumer<String> elementValidation, int minLength, int maxLength)
Deprecated.Validates an array of values.For example:
primary-key.0 = field1 primary-key.1 = field2leads to: List(field1, field2)
or:
primary-key = field1The validation consumer gets the key of the current value e.g. "primary-key.1".
-
validatePrefixExclusion
public void validatePrefixExclusion(String prefix)
Deprecated.Validates that the given prefix is not included in these properties.
-
validateExclusion
public void validateExclusion(String key)
Deprecated.Validates that the given key is not included in these properties.
-
containsKey
public boolean containsKey(String key)
Deprecated.Returns if the given key is contained.
-
hasPrefix
public boolean hasPrefix(String prefix)
Deprecated.Returns if a given prefix exists in the properties.
-
asPrefixedMap
public Map<String,String> asPrefixedMap(String prefix)
Deprecated.Returns the properties as a map copy with a prefix key.
-
withoutKeys
public DescriptorProperties withoutKeys(List<String> keys)
Deprecated.Returns a new properties instance with the given keys removed.
-
noValidation
public static Consumer<String> noValidation()
Deprecated.Returns an empty validation logic.
-
-