- cacheFile - Variable in class org.apache.flink.api.common.Plan
-
Hash map for files in the distributed cache: registered name to cache entry.
- CHAR_ARRAY_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
-
- CHAR_PRIMITIVE_ARRAY_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
-
- CHAR_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
-
- charAt(int) - Method in class org.apache.flink.core.io.StringRecord
-
Returns the Unicode Scalar Value (32-bit integer value) for the character
at position
.
- charAt(int) - Method in class org.apache.flink.types.StringValue
-
- CharComparator - Class in org.apache.flink.api.common.typeutils.base
-
- CharComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.CharComparator
-
- CharPrimitiveArraySerializer - Class in org.apache.flink.api.common.typeutils.base.array
-
A serializer for char arrays.
- CharPrimitiveArraySerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.array.CharPrimitiveArraySerializer
-
- CharSerializer - Class in org.apache.flink.api.common.typeutils.base
-
- CharSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.CharSerializer
-
- CharValue - Class in org.apache.flink.types
-
Boxed serializable and comparable character type, representing the primitive
type char
.
- CharValue() - Constructor for class org.apache.flink.types.CharValue
-
Initializes the encapsulated char with 0.
- CharValue(char) - Constructor for class org.apache.flink.types.CharValue
-
Initializes the encapsulated char with the provided value.
- CharValueSerializer - Class in org.apache.flink.api.common.typeutils.base
-
- CharValueSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.CharValueSerializer
-
- checkAndExtractLambdaMethod(Function) - Static method in class org.apache.flink.api.common.functions.util.FunctionUtils
-
- checkForInstantiation(Class<?>) - Static method in class org.apache.flink.util.InstantiationUtil
-
Performs a standard check whether the class can be instantiated by Class#newInstance()
.
- checkForInstantiationError(Class<?>) - Static method in class org.apache.flink.util.InstantiationUtil
-
- ClassUtils - Class in org.apache.flink.util
-
Utility class which provides various methods for dynamic class loading.
- CleanupWhenUnsuccessful - Interface in org.apache.flink.api.common.io
-
OutputFormat
s may implement this interface to run a cleanup hook when the execution is not successful.
- clear() - Method in class org.apache.flink.core.io.StringRecord
-
Clear the string to empty.
- clear() - Method in class org.apache.flink.types.ListValue
-
- clear() - Method in class org.apache.flink.types.MapValue
-
- clear() - Method in class org.apache.flink.types.Record
-
Clears the record.
- clearAllBroadcastVariables() - Method in class org.apache.flink.api.common.functions.util.RuntimeUDFContext
-
- clearBroadcastVariable(String) - Method in class org.apache.flink.api.common.functions.util.RuntimeUDFContext
-
- clearFirstInput() - Method in class org.apache.flink.api.common.operators.DualInputOperator
-
Clears this operator's first input.
- clearInputs() - Method in class org.apache.flink.api.common.operators.SingleInputOperator
-
Removes all inputs.
- clearProperties() - Method in class org.apache.flink.api.common.operators.DualInputSemanticProperties
-
Clears the object.
- clearProperties() - Method in class org.apache.flink.api.common.operators.SemanticProperties
-
Clears the object.
- clearProperties() - Method in class org.apache.flink.api.common.operators.SingleInputSemanticProperties
-
Clears the object.
- clearSecondInput() - Method in class org.apache.flink.api.common.operators.DualInputOperator
-
Clears this operator's second input.
- clearUniqueFields() - Method in class org.apache.flink.api.common.operators.CompilerHints
-
- clone() - Method in class org.apache.flink.api.common.operators.Ordering
-
- clone() - Method in class org.apache.flink.api.common.operators.util.FieldSet
-
Since instances of FieldSet are strictly immutable, this method does not actually clone,
but it only returns the original instance.
- close() - Method in class org.apache.flink.api.common.functions.AbstractRichFunction
-
- close() - Method in interface org.apache.flink.api.common.functions.RichFunction
-
Teardown method for the user code.
- close() - Method in class org.apache.flink.api.common.functions.util.CopyingListCollector
-
- close() - Method in class org.apache.flink.api.common.functions.util.ListCollector
-
- close() - Method in class org.apache.flink.api.common.io.BinaryOutputFormat.BlockBasedOutput
-
- close() - Method in class org.apache.flink.api.common.io.BinaryOutputFormat
-
- close() - Method in class org.apache.flink.api.common.io.DelimitedInputFormat
-
Closes the input by releasing all buffers and closing the file input stream.
- close() - Method in class org.apache.flink.api.common.io.FileInputFormat
-
Closes the file input stream of the input format.
- close() - Method in class org.apache.flink.api.common.io.FileOutputFormat
-
- close() - Method in class org.apache.flink.api.common.io.GenericInputFormat
-
- close() - Method in interface org.apache.flink.api.common.io.InputFormat
-
Method that marks the end of the life-cycle of an input split.
- close() - Method in interface org.apache.flink.api.common.io.OutputFormat
-
Method that marks the end of the life-cycle of parallel output instance.
- close() - Method in class org.apache.flink.core.fs.local.LocalDataInputStream
-
- close() - Method in class org.apache.flink.core.fs.local.LocalDataOutputStream
-
- close() - Method in class org.apache.flink.core.memory.OutputViewDataOutputStreamWrapper
-
- close() - Method in interface org.apache.flink.util.Collector
-
Closes the collector.
- closeFunction(Function) - Static method in class org.apache.flink.api.common.functions.util.FunctionUtils
-
- coGroup(Iterable<IN1>, Iterable<IN2>, Collector<O>) - Method in interface org.apache.flink.api.common.functions.CoGroupFunction
-
This method must be implemented to provide a user implementation of a
coGroup.
- coGroup(Iterable<IN1>, Iterable<IN2>, Collector<OUT>) - Method in class org.apache.flink.api.common.functions.RichCoGroupFunction
-
- CoGroupFunction<IN1,IN2,O> - Interface in org.apache.flink.api.common.functions
-
The interface for CoGroup functions.
- CoGroupOperatorBase<IN1,IN2,OUT,FT extends CoGroupFunction<IN1,IN2,OUT>> - Class in org.apache.flink.api.common.operators.base
-
- CoGroupOperatorBase(UserCodeWrapper<FT>, BinaryOperatorInformation<IN1, IN2, OUT>, int[], int[], String) - Constructor for class org.apache.flink.api.common.operators.base.CoGroupOperatorBase
-
- CoGroupOperatorBase(FT, BinaryOperatorInformation<IN1, IN2, OUT>, int[], int[], String) - Constructor for class org.apache.flink.api.common.operators.base.CoGroupOperatorBase
-
- CoGroupOperatorBase(Class<? extends FT>, BinaryOperatorInformation<IN1, IN2, OUT>, int[], int[], String) - Constructor for class org.apache.flink.api.common.operators.base.CoGroupOperatorBase
-
- collect(T) - Method in class org.apache.flink.api.common.functions.util.CopyingListCollector
-
- collect(T) - Method in class org.apache.flink.api.common.functions.util.ListCollector
-
- collect(T) - Method in interface org.apache.flink.util.Collector
-
Emits a record.
- collection - Variable in class org.apache.flink.api.common.operators.util.FieldSet
-
- CollectionExecutor - Class in org.apache.flink.api.common.operators
-
Execution utility for serial, local, collection-based executions of Flink programs.
- CollectionExecutor() - Constructor for class org.apache.flink.api.common.operators.CollectionExecutor
-
- CollectionExecutor(boolean) - Constructor for class org.apache.flink.api.common.operators.CollectionExecutor
-
- Collector<T> - Interface in org.apache.flink.util
-
Collects a record and forwards it.
- CollectorMapOperatorBase<IN,OUT,FT extends GenericCollectorMap<IN,OUT>> - Class in org.apache.flink.api.common.operators.base
-
Deprecated.
- CollectorMapOperatorBase(UserCodeWrapper<FT>, UnaryOperatorInformation<IN, OUT>, String) - Constructor for class org.apache.flink.api.common.operators.base.CollectorMapOperatorBase
-
Deprecated.
- CollectorMapOperatorBase(FT, UnaryOperatorInformation<IN, OUT>, String) - Constructor for class org.apache.flink.api.common.operators.base.CollectorMapOperatorBase
-
Deprecated.
- CollectorMapOperatorBase(Class<? extends FT>, UnaryOperatorInformation<IN, OUT>, String) - Constructor for class org.apache.flink.api.common.operators.base.CollectorMapOperatorBase
-
Deprecated.
- combine(Iterable<T>) - Method in interface org.apache.flink.api.common.functions.CombineFunction
-
The combine method, called (potentially multiple timed) with subgroups of elements.
- combine(Iterable<T>, Collector<T>) - Method in interface org.apache.flink.api.common.functions.FlatCombineFunction
-
The combine method, called (potentially multiple timed) with subgroups of elements.
- combine(Iterable<T>, Collector<T>) - Method in class org.apache.flink.api.common.functions.RichFlatCombineFunction
-
- combine(Iterable<IN>, Collector<IN>) - Method in class org.apache.flink.api.common.functions.RichGroupReduceFunction
-
The combine methods pre-reduces elements.
- CombineFunction<T> - Interface in org.apache.flink.api.common.functions
-
Generic interface used for combine functions ("combiners").
- compare(T, T) - Method in class org.apache.flink.api.common.typeutils.base.BasicTypeComparator
-
- compare(Record, Record) - Method in class org.apache.flink.api.common.typeutils.record.RecordComparator
-
- compare(T, T) - Method in class org.apache.flink.api.common.typeutils.TypeComparator
-
Compares two records in serialized from.
- compare(MemorySegment, MemorySegment, int, int, int) - Static method in class org.apache.flink.core.memory.MemorySegment
-
- compareAccumulatorTypes(Object, Class<? extends Accumulator>, Class<? extends Accumulator>) - Static method in class org.apache.flink.api.common.accumulators.AccumulatorHelper
-
- compareAgainstReference(Comparable[]) - Method in class org.apache.flink.api.common.typeutils.record.RecordComparator
-
- compareAgainstReference(Comparable[]) - Method in class org.apache.flink.api.common.typeutils.TypeComparator
-
- compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.BooleanComparator
-
- compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.ByteComparator
-
- compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.CharComparator
-
- compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.DateComparator
-
- compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.DoubleComparator
-
- compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.EnumComparator
-
- compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.FloatComparator
-
- compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.IntComparator
-
- compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.LongComparator
-
- compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.ShortComparator
-
- compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.StringComparator
-
- compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.record.RecordComparator
-
- compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.TypeComparator
-
Compares two records in serialized from.
- compareTo(BlockLocation) - Method in class org.apache.flink.core.fs.local.LocalBlockLocation
-
- compareTo(Object) - Method in class org.apache.flink.core.fs.Path
-
- compareTo(BooleanValue) - Method in class org.apache.flink.types.BooleanValue
-
- compareTo(ByteValue) - Method in class org.apache.flink.types.ByteValue
-
- compareTo(CharValue) - Method in class org.apache.flink.types.CharValue
-
- compareTo(DoubleValue) - Method in class org.apache.flink.types.DoubleValue
-
- compareTo(FloatValue) - Method in class org.apache.flink.types.FloatValue
-
- compareTo(IntValue) - Method in class org.apache.flink.types.IntValue
-
- compareTo(LongValue) - Method in class org.apache.flink.types.LongValue
-
- compareTo(NullValue) - Method in class org.apache.flink.types.NullValue
-
- compareTo(Pair<U, V>) - Method in class org.apache.flink.types.Pair
-
- compareTo(ShortValue) - Method in class org.apache.flink.types.ShortValue
-
- compareTo(StringValue) - Method in class org.apache.flink.types.StringValue
-
- compareToReference(TypeComparator<T>) - Method in class org.apache.flink.api.common.typeutils.base.BasicTypeComparator
-
- compareToReference(T2) - Method in class org.apache.flink.api.common.typeutils.GenericPairComparator
-
- compareToReference(TypeComparator<Record>) - Method in class org.apache.flink.api.common.typeutils.record.RecordComparator
-
- compareToReference(Record) - Method in class org.apache.flink.api.common.typeutils.record.RecordPairComparator
-
- compareToReference(TypeComparator<T>) - Method in class org.apache.flink.api.common.typeutils.TypeComparator
-
This method compares the element that has been set as reference in this type accessor, to the
element set as reference in the given type accessor.
- compareToReference(T2) - Method in class org.apache.flink.api.common.typeutils.TypePairComparator
-
- CompilerHints - Class in org.apache.flink.api.common.operators
-
A class encapsulating compiler hints describing the behavior of the user function.
- CompilerHints() - Constructor for class org.apache.flink.api.common.operators.CompilerHints
-
- compilerHints - Variable in class org.apache.flink.api.common.operators.Operator
-
- complementBlockInfo(BlockInfo) - Method in class org.apache.flink.api.common.io.BinaryOutputFormat
-
- CompositeType<T> - Class in org.apache.flink.api.common.typeutils
-
Type Information for Tuple and Pojo types
The class is taking care of serialization and comparators for Tuples as well.
- CompositeType(Class<T>) - Constructor for class org.apache.flink.api.common.typeutils.CompositeType
-
- CompositeType.FlatFieldDescriptor - Class in org.apache.flink.api.common.typeutils
-
- CompositeTypeComparator<T> - Class in org.apache.flink.api.common.typeutils
-
- CompositeTypeComparator() - Constructor for class org.apache.flink.api.common.typeutils.CompositeTypeComparator
-
- concatenate(Record) - Method in class org.apache.flink.types.Record
-
- config - Variable in class org.apache.flink.api.common.io.FileInputFormat.AbstractConfigBuilder
-
The configuration into which the parameters will be written.
- config - Variable in class org.apache.flink.api.common.io.FileOutputFormat.AbstractConfigBuilder
-
The configuration into which the parameters will be written.
- CONFIG_KEY - Static variable in class org.apache.flink.api.common.ExecutionConfig
-
- ConfigBuilder(Configuration) - Constructor for class org.apache.flink.api.common.io.DelimitedInputFormat.ConfigBuilder
-
Creates a new builder for the given configuration.
- ConfigBuilder(Configuration) - Constructor for class org.apache.flink.api.common.io.FileInputFormat.ConfigBuilder
-
Creates a new builder for the given configuration.
- ConfigBuilder(Configuration) - Constructor for class org.apache.flink.api.common.io.FileOutputFormat.ConfigBuilder
-
Creates a new builder for the given configuration.
- ConfigConstants - Class in org.apache.flink.configuration
-
This class contains all constants for the configuration.
- Configuration - Class in org.apache.flink.configuration
-
Lightweight configuration object which can store key/value pairs.
- Configuration() - Constructor for class org.apache.flink.configuration.Configuration
-
- configure(Configuration) - Method in class org.apache.flink.api.common.io.BinaryInputFormat
-
- configure(Configuration) - Method in class org.apache.flink.api.common.io.BinaryOutputFormat
-
- configure(Configuration) - Method in class org.apache.flink.api.common.io.DelimitedInputFormat
-
Configures this input format by reading the path to the file from the configuration andge the string that
defines the record delimiter.
- configure(Configuration) - Method in class org.apache.flink.api.common.io.FileInputFormat
-
Configures the file input format by reading the file path from the configuration.
- configure(Configuration) - Method in class org.apache.flink.api.common.io.FileOutputFormat
-
- configure(Configuration) - Method in class org.apache.flink.api.common.io.GenericInputFormat
-
- configure(Configuration) - Method in interface org.apache.flink.api.common.io.InputFormat
-
Configures this input format.
- configure(Configuration) - Method in interface org.apache.flink.api.common.io.OutputFormat
-
Configures this output format.
- configureDelimitedFormat(FileDataSourceBase<?>) - Static method in class org.apache.flink.api.common.io.DelimitedInputFormat
-
Creates a configuration builder that can be used to set the input format's parameters to the config in a fluent
fashion.
- configureFileFormat(GenericDataSourceBase<?, ?>) - Static method in class org.apache.flink.api.common.io.FileInputFormat
-
Creates a configuration builder that can be used to set the input format's parameters to the config in a fluent
fashion.
- configureFileFormat(FileDataSinkBase<?>) - Static method in class org.apache.flink.api.common.io.FileOutputFormat
-
Creates a configuration builder that can be used to set the input format's parameters to the config in a fluent
fashion.
- constructTestPath(Class<?>, String) - Static method in class org.apache.flink.core.fs.Path
-
- constructTestURI(Class<?>, String) - Static method in class org.apache.flink.core.fs.Path
-
- containingIteration - Variable in class org.apache.flink.api.common.operators.base.DeltaIterationBase.SolutionSetPlaceHolder
-
- contains(Integer) - Method in class org.apache.flink.api.common.operators.util.FieldSet
-
- contains(Object) - Method in class org.apache.flink.types.ListValue
-
- containsAll(Collection<?>) - Method in class org.apache.flink.types.ListValue
-
- containsKey(String) - Method in class org.apache.flink.configuration.Configuration
-
Checks whether there is an entry with the specified key
- containsKey(Object) - Method in class org.apache.flink.types.MapValue
-
- containsValue(Object) - Method in class org.apache.flink.types.MapValue
-
- ConvergenceCriterion<T extends Value> - Interface in org.apache.flink.api.common.aggregators
-
Used to check for convergence.
- convertBoxedJavaType(Object) - Static method in class org.apache.flink.types.JavaToValueConverter
-
- convertValueType(Value) - Static method in class org.apache.flink.types.JavaToValueConverter
-
- copy(boolean[]) - Method in class org.apache.flink.api.common.typeutils.base.array.BooleanPrimitiveArraySerializer
-
- copy(boolean[], boolean[]) - Method in class org.apache.flink.api.common.typeutils.base.array.BooleanPrimitiveArraySerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.array.BooleanPrimitiveArraySerializer
-
- copy(byte[]) - Method in class org.apache.flink.api.common.typeutils.base.array.BytePrimitiveArraySerializer
-
- copy(byte[], byte[]) - Method in class org.apache.flink.api.common.typeutils.base.array.BytePrimitiveArraySerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.array.BytePrimitiveArraySerializer
-
- copy(char[]) - Method in class org.apache.flink.api.common.typeutils.base.array.CharPrimitiveArraySerializer
-
- copy(char[], char[]) - Method in class org.apache.flink.api.common.typeutils.base.array.CharPrimitiveArraySerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.array.CharPrimitiveArraySerializer
-
- copy(double[]) - Method in class org.apache.flink.api.common.typeutils.base.array.DoublePrimitiveArraySerializer
-
- copy(double[], double[]) - Method in class org.apache.flink.api.common.typeutils.base.array.DoublePrimitiveArraySerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.array.DoublePrimitiveArraySerializer
-
- copy(float[]) - Method in class org.apache.flink.api.common.typeutils.base.array.FloatPrimitiveArraySerializer
-
- copy(float[], float[]) - Method in class org.apache.flink.api.common.typeutils.base.array.FloatPrimitiveArraySerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.array.FloatPrimitiveArraySerializer
-
- copy(int[]) - Method in class org.apache.flink.api.common.typeutils.base.array.IntPrimitiveArraySerializer
-
- copy(int[], int[]) - Method in class org.apache.flink.api.common.typeutils.base.array.IntPrimitiveArraySerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.array.IntPrimitiveArraySerializer
-
- copy(long[]) - Method in class org.apache.flink.api.common.typeutils.base.array.LongPrimitiveArraySerializer
-
- copy(long[], long[]) - Method in class org.apache.flink.api.common.typeutils.base.array.LongPrimitiveArraySerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.array.LongPrimitiveArraySerializer
-
- copy(short[]) - Method in class org.apache.flink.api.common.typeutils.base.array.ShortPrimitiveArraySerializer
-
- copy(short[], short[]) - Method in class org.apache.flink.api.common.typeutils.base.array.ShortPrimitiveArraySerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.array.ShortPrimitiveArraySerializer
-
- copy(String[]) - Method in class org.apache.flink.api.common.typeutils.base.array.StringArraySerializer
-
- copy(String[], String[]) - Method in class org.apache.flink.api.common.typeutils.base.array.StringArraySerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.array.StringArraySerializer
-
- copy(Boolean) - Method in class org.apache.flink.api.common.typeutils.base.BooleanSerializer
-
- copy(Boolean, Boolean) - Method in class org.apache.flink.api.common.typeutils.base.BooleanSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.BooleanSerializer
-
- copy(BooleanValue) - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueSerializer
-
- copy(BooleanValue, BooleanValue) - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueSerializer
-
- copy(Byte) - Method in class org.apache.flink.api.common.typeutils.base.ByteSerializer
-
- copy(Byte, Byte) - Method in class org.apache.flink.api.common.typeutils.base.ByteSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.ByteSerializer
-
- copy(ByteValue) - Method in class org.apache.flink.api.common.typeutils.base.ByteValueSerializer
-
- copy(ByteValue, ByteValue) - Method in class org.apache.flink.api.common.typeutils.base.ByteValueSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.ByteValueSerializer
-
- copy(Character) - Method in class org.apache.flink.api.common.typeutils.base.CharSerializer
-
- copy(Character, Character) - Method in class org.apache.flink.api.common.typeutils.base.CharSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.CharSerializer
-
- copy(CharValue) - Method in class org.apache.flink.api.common.typeutils.base.CharValueSerializer
-
- copy(CharValue, CharValue) - Method in class org.apache.flink.api.common.typeutils.base.CharValueSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.CharValueSerializer
-
- copy(Date) - Method in class org.apache.flink.api.common.typeutils.base.DateSerializer
-
- copy(Date, Date) - Method in class org.apache.flink.api.common.typeutils.base.DateSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.DateSerializer
-
- copy(Double) - Method in class org.apache.flink.api.common.typeutils.base.DoubleSerializer
-
- copy(Double, Double) - Method in class org.apache.flink.api.common.typeutils.base.DoubleSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.DoubleSerializer
-
- copy(DoubleValue) - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueSerializer
-
- copy(DoubleValue, DoubleValue) - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueSerializer
-
- copy(T) - Method in class org.apache.flink.api.common.typeutils.base.EnumSerializer
-
- copy(T, T) - Method in class org.apache.flink.api.common.typeutils.base.EnumSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.EnumSerializer
-
- copy(Float) - Method in class org.apache.flink.api.common.typeutils.base.FloatSerializer
-
- copy(Float, Float) - Method in class org.apache.flink.api.common.typeutils.base.FloatSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.FloatSerializer
-
- copy(FloatValue) - Method in class org.apache.flink.api.common.typeutils.base.FloatValueSerializer
-
- copy(FloatValue, FloatValue) - Method in class org.apache.flink.api.common.typeutils.base.FloatValueSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.FloatValueSerializer
-
- copy(C[]) - Method in class org.apache.flink.api.common.typeutils.base.GenericArraySerializer
-
- copy(C[], C[]) - Method in class org.apache.flink.api.common.typeutils.base.GenericArraySerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.GenericArraySerializer
-
- copy(Integer) - Method in class org.apache.flink.api.common.typeutils.base.IntSerializer
-
- copy(Integer, Integer) - Method in class org.apache.flink.api.common.typeutils.base.IntSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.IntSerializer
-
- copy(IntValue) - Method in class org.apache.flink.api.common.typeutils.base.IntValueSerializer
-
- copy(IntValue, IntValue) - Method in class org.apache.flink.api.common.typeutils.base.IntValueSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.IntValueSerializer
-
- copy(Long) - Method in class org.apache.flink.api.common.typeutils.base.LongSerializer
-
- copy(Long, Long) - Method in class org.apache.flink.api.common.typeutils.base.LongSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.LongSerializer
-
- copy(LongValue) - Method in class org.apache.flink.api.common.typeutils.base.LongValueSerializer
-
- copy(LongValue, LongValue) - Method in class org.apache.flink.api.common.typeutils.base.LongValueSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.LongValueSerializer
-
- copy(Short) - Method in class org.apache.flink.api.common.typeutils.base.ShortSerializer
-
- copy(Short, Short) - Method in class org.apache.flink.api.common.typeutils.base.ShortSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.ShortSerializer
-
- copy(ShortValue) - Method in class org.apache.flink.api.common.typeutils.base.ShortValueSerializer
-
- copy(ShortValue, ShortValue) - Method in class org.apache.flink.api.common.typeutils.base.ShortValueSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.ShortValueSerializer
-
- copy(String) - Method in class org.apache.flink.api.common.typeutils.base.StringSerializer
-
- copy(String, String) - Method in class org.apache.flink.api.common.typeutils.base.StringSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.StringSerializer
-
- copy(StringValue) - Method in class org.apache.flink.api.common.typeutils.base.StringValueSerializer
-
- copy(StringValue, StringValue) - Method in class org.apache.flink.api.common.typeutils.base.StringValueSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.StringValueSerializer
-
- copy(Void) - Method in class org.apache.flink.api.common.typeutils.base.VoidSerializer
-
- copy(Void, Void) - Method in class org.apache.flink.api.common.typeutils.base.VoidSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.VoidSerializer
-
- copy(Record) - Method in class org.apache.flink.api.common.typeutils.record.RecordSerializer
-
- copy(Record, Record) - Method in class org.apache.flink.api.common.typeutils.record.RecordSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.record.RecordSerializer
-
- copy(T) - Method in class org.apache.flink.api.common.typeutils.TypeSerializer
-
Creates a deep copy of the given element in a new element.
- copy(T, T) - Method in class org.apache.flink.api.common.typeutils.TypeSerializer
-
Creates a copy from the given element.
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.TypeSerializer
-
Copies exactly one record from the source input view to the target output view.
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.types.BooleanValue
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.types.ByteValue
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.types.CharValue
-
- copy(DataInputView, DataOutputView) - Method in interface org.apache.flink.types.CopyableValue
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.types.DoubleValue
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.types.FloatValue
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.types.IntValue
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.types.LongValue
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.types.NullValue
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.types.Record
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.types.ShortValue
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.types.StringValue
-
- CopyableValue<T> - Interface in org.apache.flink.types
-
Interface to be implemented by basic types that support to be copied efficiently.
- copyFrom(CompilerHints) - Method in class org.apache.flink.api.common.operators.CompilerHints
-
- copyFrom(Record, int[], int[]) - Method in class org.apache.flink.types.Record
-
Bin-copies fields from a source record to this record.
- CopyingIterator<E> - Class in org.apache.flink.api.common.functions.util
-
- CopyingIterator(Iterator<E>, TypeSerializer<E>) - Constructor for class org.apache.flink.api.common.functions.util.CopyingIterator
-
- CopyingListCollector<T> - Class in org.apache.flink.api.common.functions.util
-
- CopyingListCollector(List<T>, TypeSerializer<T>) - Constructor for class org.apache.flink.api.common.functions.util.CopyingListCollector
-
- copyNormalizedKey(MemorySegment, int, int) - Method in class org.apache.flink.types.BooleanValue
-
- copyNormalizedKey(MemorySegment, int, int) - Method in class org.apache.flink.types.ByteValue
-
- copyNormalizedKey(MemorySegment, int, int) - Method in class org.apache.flink.types.CharValue
-
- copyNormalizedKey(MemorySegment, int, int) - Method in class org.apache.flink.types.IntValue
-
- copyNormalizedKey(MemorySegment, int, int) - Method in class org.apache.flink.types.LongValue
-
- copyNormalizedKey(MemorySegment, int, int) - Method in interface org.apache.flink.types.NormalizableKey
-
Writes a normalized key for the given record into the target byte array, starting at the specified position
an writing exactly the given number of bytes.
- copyNormalizedKey(MemorySegment, int, int) - Method in class org.apache.flink.types.NullValue
-
- copyNormalizedKey(MemorySegment, int, int) - Method in class org.apache.flink.types.ShortValue
-
- copyNormalizedKey(MemorySegment, int, int) - Method in class org.apache.flink.types.StringValue
-
- copyString(DataInput, DataOutput) - Static method in class org.apache.flink.types.StringValue
-
- copyTo(int, MemorySegment, int, int) - Method in class org.apache.flink.core.memory.MemorySegment
-
Bulk copy method.
- copyTo(BooleanValue) - Method in class org.apache.flink.types.BooleanValue
-
- copyTo(ByteValue) - Method in class org.apache.flink.types.ByteValue
-
- copyTo(CharValue) - Method in class org.apache.flink.types.CharValue
-
- copyTo(T) - Method in interface org.apache.flink.types.CopyableValue
-
- copyTo(DoubleValue) - Method in class org.apache.flink.types.DoubleValue
-
- copyTo(FloatValue) - Method in class org.apache.flink.types.FloatValue
-
- copyTo(IntValue) - Method in class org.apache.flink.types.IntValue
-
- copyTo(LongValue) - Method in class org.apache.flink.types.LongValue
-
- copyTo(NullValue) - Method in class org.apache.flink.types.NullValue
-
- copyTo(Record) - Method in class org.apache.flink.types.Record
-
- copyTo(ShortValue) - Method in class org.apache.flink.types.ShortValue
-
- copyTo(StringValue) - Method in class org.apache.flink.types.StringValue
-
- create(Path, boolean, int, short, long) - Method in class org.apache.flink.core.fs.FileSystem
-
Opens an FSDataOutputStream at the indicated Path.
- create(Path, boolean) - Method in class org.apache.flink.core.fs.FileSystem
-
Opens an FSDataOutputStream at the indicated Path.
- create(Path, boolean, int, short, long) - Method in class org.apache.flink.core.fs.local.LocalFileSystem
-
- create(Path, boolean) - Method in class org.apache.flink.core.fs.local.LocalFileSystem
-
- createBlockInfo() - Method in class org.apache.flink.api.common.io.BinaryInputFormat
-
- createBlockInfo() - Method in class org.apache.flink.api.common.io.BinaryOutputFormat
-
- createComparator(boolean) - Method in interface org.apache.flink.api.common.typeinfo.AtomicType
-
- createComparator(boolean) - Method in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
-
- createComparator(int[], boolean[], int) - Method in class org.apache.flink.api.common.typeutils.CompositeType
-
Generic implementation of the comparator creation.
- createComparator() - Method in class org.apache.flink.api.common.typeutils.record.RecordComparatorFactory
-
- createComparator() - Method in interface org.apache.flink.api.common.typeutils.TypeComparatorFactory
-
- createComparator12(TypeComparator<Record>, TypeComparator<Record>) - Method in class org.apache.flink.api.common.typeutils.record.RecordPairComparatorFactory
-
- createComparator12(TypeComparator<T1>, TypeComparator<T2>) - Method in interface org.apache.flink.api.common.typeutils.TypePairComparatorFactory
-
- createComparator21(TypeComparator<Record>, TypeComparator<Record>) - Method in class org.apache.flink.api.common.typeutils.record.RecordPairComparatorFactory
-
- createComparator21(TypeComparator<T1>, TypeComparator<T2>) - Method in interface org.apache.flink.api.common.typeutils.TypePairComparatorFactory
-
- createCopy() - Method in class org.apache.flink.types.Record
-
Creates an exact copy of this record.
- createInputSplits(int) - Method in class org.apache.flink.api.common.io.BinaryInputFormat
-
- createInputSplits(int) - Method in class org.apache.flink.api.common.io.FileInputFormat
-
Computes the input splits for the file.
- createInputSplits(int) - Method in class org.apache.flink.api.common.io.GenericInputFormat
-
- createInputSplits(int) - Method in interface org.apache.flink.api.common.io.InputFormat
-
Creates the different splits of the input that can be processed in parallel.
- createInputSplits(int) - Method in interface org.apache.flink.core.io.InputSplitSource
-
Computes the input splits.
- createInstance() - Method in class org.apache.flink.api.common.typeutils.base.array.BooleanPrimitiveArraySerializer
-
- createInstance() - Method in class org.apache.flink.api.common.typeutils.base.array.BytePrimitiveArraySerializer
-
- createInstance() - Method in class org.apache.flink.api.common.typeutils.base.array.CharPrimitiveArraySerializer
-
- createInstance() - Method in class org.apache.flink.api.common.typeutils.base.array.DoublePrimitiveArraySerializer
-
- createInstance() - Method in class org.apache.flink.api.common.typeutils.base.array.FloatPrimitiveArraySerializer
-
- createInstance() - Method in class org.apache.flink.api.common.typeutils.base.array.IntPrimitiveArraySerializer
-
- createInstance() - Method in class org.apache.flink.api.common.typeutils.base.array.LongPrimitiveArraySerializer
-
- createInstance() - Method in class org.apache.flink.api.common.typeutils.base.array.ShortPrimitiveArraySerializer
-
- createInstance() - Method in class org.apache.flink.api.common.typeutils.base.array.StringArraySerializer
-
- createInstance() - Method in class org.apache.flink.api.common.typeutils.base.BooleanSerializer
-
- createInstance() - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueSerializer
-
- createInstance() - Method in class org.apache.flink.api.common.typeutils.base.ByteSerializer
-
- createInstance() - Method in class org.apache.flink.api.common.typeutils.base.ByteValueSerializer
-
- createInstance() - Method in class org.apache.flink.api.common.typeutils.base.CharSerializer
-
- createInstance() - Method in class org.apache.flink.api.common.typeutils.base.CharValueSerializer
-
- createInstance() - Method in class org.apache.flink.api.common.typeutils.base.DateSerializer
-
- createInstance() - Method in class org.apache.flink.api.common.typeutils.base.DoubleSerializer
-
- createInstance() - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueSerializer
-
- createInstance() - Method in class org.apache.flink.api.common.typeutils.base.EnumSerializer
-
- createInstance() - Method in class org.apache.flink.api.common.typeutils.base.FloatSerializer
-
- createInstance() - Method in class org.apache.flink.api.common.typeutils.base.FloatValueSerializer
-
- createInstance() - Method in class org.apache.flink.api.common.typeutils.base.GenericArraySerializer
-
- createInstance() - Method in class org.apache.flink.api.common.typeutils.base.IntSerializer
-
- createInstance() - Method in class org.apache.flink.api.common.typeutils.base.IntValueSerializer
-
- createInstance() - Method in class org.apache.flink.api.common.typeutils.base.LongSerializer
-
- createInstance() - Method in class org.apache.flink.api.common.typeutils.base.LongValueSerializer
-
- createInstance() - Method in class org.apache.flink.api.common.typeutils.base.ShortSerializer
-
- createInstance() - Method in class org.apache.flink.api.common.typeutils.base.ShortValueSerializer
-
- createInstance() - Method in class org.apache.flink.api.common.typeutils.base.StringSerializer
-
- createInstance() - Method in class org.apache.flink.api.common.typeutils.base.StringValueSerializer
-
- createInstance() - Method in class org.apache.flink.api.common.typeutils.base.VoidSerializer
-
- createInstance() - Method in class org.apache.flink.api.common.typeutils.record.RecordSerializer
-
- createInstance() - Method in class org.apache.flink.api.common.typeutils.TypeSerializer
-
Creates a new instance of the data type.
- createLocalExecutor() - Static method in class org.apache.flink.api.common.PlanExecutor
-
Creates an executor that runs the plan locally in a multi-threaded environment.
- createNewOrderingUpToIndex(int) - Method in class org.apache.flink.api.common.operators.Ordering
-
Creates a new ordering the represents an ordering on a prefix of the fields.
- createProber(TypeComparator<PT>, TypePairComparator<PT, BT>) - Method in class org.apache.flink.api.common.operators.util.JoinHashMap
-
- createRemoteExecutor(String, int, String...) - Static method in class org.apache.flink.api.common.PlanExecutor
-
Creates an executor that runs the plan on a remote environment.
- createSerializer() - Method in class org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
-
- createSerializer() - Method in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
-
- createSerializer() - Method in class org.apache.flink.api.common.typeinfo.NothingTypeInfo
-
- createSerializer() - Method in class org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
-
- createSerializer() - Method in class org.apache.flink.api.common.typeinfo.TypeInformation
-
- createStatistics(List<FileStatus>, FileInputFormat.FileBaseStatistics) - Method in class org.apache.flink.api.common.io.BinaryInputFormat
-
Fill in the statistics.
- createUnionCascade(List<? extends Operator<T>>) - Static method in class org.apache.flink.api.common.operators.Operator
-
Takes a list of operators and creates a cascade of unions of this inputs, if needed.
- createUnionCascade(Operator<T>...) - Static method in class org.apache.flink.api.common.operators.Operator
-
Takes a list of operators and creates a cascade of unions of this inputs, if needed.
- createUnionCascade(Operator<T>, Operator<T>...) - Static method in class org.apache.flink.api.common.operators.Operator
-
Takes a single Operator and a list of operators and creates a cascade of unions of this inputs, if needed.
- createValue() - Method in class org.apache.flink.types.parser.ByteParser
-
- createValue() - Method in class org.apache.flink.types.parser.ByteValueParser
-
- createValue() - Method in class org.apache.flink.types.parser.DoubleParser
-
- createValue() - Method in class org.apache.flink.types.parser.DoubleValueParser
-
- createValue() - Method in class org.apache.flink.types.parser.FieldParser
-
Returns an instance of the parsed value type.
- createValue() - Method in class org.apache.flink.types.parser.FloatParser
-
- createValue() - Method in class org.apache.flink.types.parser.FloatValueParser
-
- createValue() - Method in class org.apache.flink.types.parser.IntParser
-
- createValue() - Method in class org.apache.flink.types.parser.IntValueParser
-
- createValue() - Method in class org.apache.flink.types.parser.LongParser
-
- createValue() - Method in class org.apache.flink.types.parser.LongValueParser
-
- createValue() - Method in class org.apache.flink.types.parser.ShortParser
-
- createValue() - Method in class org.apache.flink.types.parser.ShortValueParser
-
- createValue() - Method in class org.apache.flink.types.parser.StringParser
-
- createValue() - Method in class org.apache.flink.types.parser.StringValueParser
-
- cross(IN1, IN2) - Method in interface org.apache.flink.api.common.functions.CrossFunction
-
Cross UDF method.
- cross(IN1, IN2) - Method in class org.apache.flink.api.common.functions.RichCrossFunction
-
- CrossFunction<IN1,IN2,OUT> - Interface in org.apache.flink.api.common.functions
-
Interface for Cross functions.
- CrossOperatorBase<IN1,IN2,OUT,FT extends CrossFunction<IN1,IN2,OUT>> - Class in org.apache.flink.api.common.operators.base
-
- CrossOperatorBase(UserCodeWrapper<FT>, BinaryOperatorInformation<IN1, IN2, OUT>, String) - Constructor for class org.apache.flink.api.common.operators.base.CrossOperatorBase
-
- CrossOperatorBase(FT, BinaryOperatorInformation<IN1, IN2, OUT>, String) - Constructor for class org.apache.flink.api.common.operators.base.CrossOperatorBase
-
- CrossOperatorBase(Class<? extends FT>, BinaryOperatorInformation<IN1, IN2, OUT>, String) - Constructor for class org.apache.flink.api.common.operators.base.CrossOperatorBase
-
- CrossOperatorBase.CrossWithLarge - Interface in org.apache.flink.api.common.operators.base
-
Marker interface to declare the second input as the larger one.
- CrossOperatorBase.CrossWithSmall - Interface in org.apache.flink.api.common.operators.base
-
Marker interface to declare the second input as the smaller one.
- CUR_DIR - Static variable in class org.apache.flink.core.fs.Path
-
Character denoting the current directory.
- DataDistribution - Interface in org.apache.flink.api.common.distributions
-
- DataInputView - Interface in org.apache.flink.core.memory
-
This interface defines a view over some memory that can be used to sequentially read the contents of the memory.
- DataInputViewStream - Class in org.apache.flink.core.memory
-
- DataInputViewStream(DataInputView) - Constructor for class org.apache.flink.core.memory.DataInputViewStream
-
- DataOutputView - Interface in org.apache.flink.core.memory
-
This interface defines a view over some memory that can be used to sequentially write contents to the memory.
- DataOutputViewStream - Class in org.apache.flink.core.memory
-
- DataOutputViewStream(DataOutputView) - Constructor for class org.apache.flink.core.memory.DataOutputViewStream
-
- DATE_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
-
- DateComparator - Class in org.apache.flink.api.common.typeutils.base
-
- DateComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.DateComparator
-
- DateSerializer - Class in org.apache.flink.api.common.typeutils.base
-
- DateSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.DateSerializer
-
- decode(byte[]) - Static method in class org.apache.flink.core.io.StringRecord
-
Converts the provided byte array to a String using the UTF-8 encoding.
- decode(byte[], int, int) - Static method in class org.apache.flink.core.io.StringRecord
-
- decode(byte[], int, int, boolean) - Static method in class org.apache.flink.core.io.StringRecord
-
Converts the provided byte array to a String using the UTF-8 encoding.
- DEFAULT_DEFAULT_INSTANCE_TYPE_INDEX - Static variable in class org.apache.flink.configuration.ConfigConstants
-
The default index for the default instance type.
- DEFAULT_DELIMITED_FORMAT_MAX_LINE_SAMPLES - Static variable in class org.apache.flink.configuration.ConfigConstants
-
The default maximum number of line samples taken by the delimited input format.
- DEFAULT_DELIMITED_FORMAT_MAX_SAMPLE_LEN - Static variable in class org.apache.flink.configuration.ConfigConstants
-
The default maximum sample length before sampling is aborted (2 MiBytes).
- DEFAULT_DELIMITED_FORMAT_MIN_LINE_SAMPLES - Static variable in class org.apache.flink.configuration.ConfigConstants
-
The default minimum number of line samples taken by the delimited input format.
- DEFAULT_EXECUTION_RETRIES - Static variable in class org.apache.flink.configuration.ConfigConstants
-
The default number of execution retries.
- DEFAULT_EXECUTION_RETRIES_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
-
Config parameter for the number of re-tries for failed tasks.
- DEFAULT_FILESYSTEM_ALWAYS_CREATE_DIRECTORY - Static variable in class org.apache.flink.configuration.ConfigConstants
-
The default behavior for output directory creating (create only directory when parallelism > 1).
- DEFAULT_FILESYSTEM_OVERWRITE - Static variable in class org.apache.flink.configuration.ConfigConstants
-
The default behavior with respect to overwriting existing files (= not overwrite)
- DEFAULT_FS_STREAM_OPENING_TIMEOUT - Static variable in class org.apache.flink.configuration.ConfigConstants
-
The default timeout for filesystem stream opening: infinite (means max long milliseconds).
- DEFAULT_INSTANCE_TYPE - Static variable in class org.apache.flink.configuration.ConfigConstants
-
The default definition for an instance type, if no other configuration is provided.
- DEFAULT_JOB_MANAGER_DEAD_TASKMANAGER_TIMEOUT - Static variable in class org.apache.flink.configuration.ConfigConstants
-
Default number of seconds after which a task manager is marked as failed.
- DEFAULT_JOB_MANAGER_IPC_HANDLERS - Static variable in class org.apache.flink.configuration.ConfigConstants
-
The default number of handler threads for the jobmanager RPC service.
- DEFAULT_JOB_MANAGER_IPC_PORT - Static variable in class org.apache.flink.configuration.ConfigConstants
-
The default network port to connect to for communication with the job manager.
- DEFAULT_JOB_MANAGER_WEB_ARCHIVE_COUNT - Static variable in class org.apache.flink.configuration.ConfigConstants
-
The default number of archived jobs for the jobmanager
- DEFAULT_JOB_MANAGER_WEB_FRONTEND_PORT - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- DEFAULT_JOB_MANAGER_WEB_PATH_NAME - Static variable in class org.apache.flink.configuration.ConfigConstants
-
The default directory name of the info server
- DEFAULT_JOB_MANAGER_WEB_ROOT_PATH - Static variable in class org.apache.flink.configuration.ConfigConstants
-
The default path of the directory for info server containing the web documents.
- DEFAULT_JOBCLIENT_POLLING_INTERVAL - Static variable in class org.apache.flink.configuration.ConfigConstants
-
The default value for the JobClient's polling interval.
- DEFAULT_LIBRARY_CACHE_MANAGER_CLEANUP_INTERVAL - Static variable in class org.apache.flink.configuration.ConfigConstants
-
The default library cache manager cleanup interval in seconds
- DEFAULT_MEMORY_MANAGER_MEMORY_FRACTION - Static variable in class org.apache.flink.configuration.ConfigConstants
-
The default fraction of the free memory allocated by the task manager's memory manager.
- DEFAULT_PARALLELIZATION_DEGREE - Static variable in class org.apache.flink.configuration.ConfigConstants
-
The default degree of parallelism for operations.
- DEFAULT_PARALLELIZATION_DEGREE_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
-
The config parameter defining the default degree of parallelism for jobs.
- DEFAULT_SORT_SPILLING_THRESHOLD - Static variable in class org.apache.flink.configuration.ConfigConstants
-
The default percentage of the sort memory to be full before data is spilled.
- DEFAULT_SORT_SPILLING_THRESHOLD_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
-
Key for the default spilling threshold.
- DEFAULT_SPILLING_MAX_FAN - Static variable in class org.apache.flink.configuration.ConfigConstants
-
The default value for the maximum spilling fan in/out.
- DEFAULT_SPILLING_MAX_FAN_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
-
Parameter for the maximum fan for out-of-core algorithms.
- DEFAULT_TASK_MANAGER_DATA_PORT - Static variable in class org.apache.flink.configuration.ConfigConstants
-
The default network port the task manager expects to receive transfer envelopes on.
- DEFAULT_TASK_MANAGER_DEBUG_MEMORY_USAGE_LOG_INTERVAL_MS - Static variable in class org.apache.flink.configuration.ConfigConstants
-
The interval (in ms) for the log thread to log the current memory usage.
- DEFAULT_TASK_MANAGER_DEBUG_MEMORY_USAGE_START_LOG_THREAD - Static variable in class org.apache.flink.configuration.ConfigConstants
-
Flag indicating whether to start a thread, which repeatedly logs the memory usage of the JVM.
- DEFAULT_TASK_MANAGER_HEARTBEAT_INTERVAL - Static variable in class org.apache.flink.configuration.ConfigConstants
-
The default interval for TaskManager heart beats (5000 msecs).
- DEFAULT_TASK_MANAGER_IPC_PORT - Static variable in class org.apache.flink.configuration.ConfigConstants
-
The default network port the task manager expects incoming IPC connections.
- DEFAULT_TASK_MANAGER_MEMORY_LAZY_ALLOCATION - Static variable in class org.apache.flink.configuration.ConfigConstants
-
The default setting for the memory manager lazy allocation feature.
- DEFAULT_TASK_MANAGER_NET_NETTY_HIGH_WATER_MARK - Static variable in class org.apache.flink.configuration.ConfigConstants
-
Default high water mark used in NettyConnectionManager for the Bootstrap.
- DEFAULT_TASK_MANAGER_NET_NETTY_LOW_WATER_MARK - Static variable in class org.apache.flink.configuration.ConfigConstants
-
Default low water mark used in NettyConnectionManager for the Bootstrap.
- DEFAULT_TASK_MANAGER_NET_NUM_IN_THREADS - Static variable in class org.apache.flink.configuration.ConfigConstants
-
Default number of incoming network IO threads (e.g.
- DEFAULT_TASK_MANAGER_NET_NUM_OUT_THREADS - Static variable in class org.apache.flink.configuration.ConfigConstants
-
Default number of outgoing network IO threads (e.g.
- DEFAULT_TASK_MANAGER_NETWORK_BUFFER_SIZE - Static variable in class org.apache.flink.configuration.ConfigConstants
-
Default size of network stack buffers.
- DEFAULT_TASK_MANAGER_NETWORK_NUM_BUFFERS - Static variable in class org.apache.flink.configuration.ConfigConstants
-
Default number of buffers used in the network stack.
- DEFAULT_TASK_MANAGER_TMP_PATH - Static variable in class org.apache.flink.configuration.ConfigConstants
-
The default directory for temporary files of the task manager.
- DEFAULT_WEB_ACCESS_FILE_PATH - Static variable in class org.apache.flink.configuration.ConfigConstants
-
The default path to the file containing the list of access privileged users and passwords.
- DEFAULT_WEB_JOB_STORAGE_DIR - Static variable in class org.apache.flink.configuration.ConfigConstants
-
The default directory to store uploaded jobs in.
- DEFAULT_WEB_PLAN_DUMP_DIR - Static variable in class org.apache.flink.configuration.ConfigConstants
-
The default directory for temporary plan dumps from the web frontend.
- DEFAULT_WEB_ROOT_DIR - Static variable in class org.apache.flink.configuration.ConfigConstants
-
The default path of the directory containing the web documents.
- DEFAULT_WEB_TMP_DIR - Static variable in class org.apache.flink.configuration.ConfigConstants
-
The default directory to store temporary objects (e.g.
- DEFAULT_WEBCLIENT_PORT - Static variable in class org.apache.flink.configuration.ConfigConstants
-
The default port to launch the web frontend server on.
- DEFAULT_YARN_AM_RPC_PORT - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- DefaultInputSplitAssigner - Class in org.apache.flink.api.common.io
-
- DefaultInputSplitAssigner(InputSplit[]) - Constructor for class org.apache.flink.api.common.io.DefaultInputSplitAssigner
-
- DefaultInputSplitAssigner(Collection<? extends InputSplit>) - Constructor for class org.apache.flink.api.common.io.DefaultInputSplitAssigner
-
- defaultParallelism - Variable in class org.apache.flink.api.common.Plan
-
The default parallelism to use for nodes that have no explicitly specified parallelism.
- DEFLATE_SUFFIX - Static variable in class org.apache.flink.api.common.io.FileInputFormat
-
Files with that suffix are unsplittable at a file level
and compressed.
- delete(Path, boolean) - Method in class org.apache.flink.core.fs.FileSystem
-
Delete a file.
- delete(Path, boolean) - Method in class org.apache.flink.core.fs.local.LocalFileSystem
-
- DELIMITED_FORMAT_MAX_LINE_SAMPLES_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
-
The maximum number of line samples to be taken by the delimited input format, if no
other value is specified for the data source.
- DELIMITED_FORMAT_MAX_SAMPLE_LENGTH_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
-
The maximum length of a single sampled record before the sampling is aborted.
- DELIMITED_FORMAT_MIN_LINE_SAMPLES_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
-
The minimum number of line samples to be taken by the delimited input format, if no
other value is specified for the data source.
- DelimitedInputFormat<OT> - Class in org.apache.flink.api.common.io
-
Base implementation for input formats that split the input at a delimiter into records.
- DelimitedInputFormat() - Constructor for class org.apache.flink.api.common.io.DelimitedInputFormat
-
- DelimitedInputFormat(Path) - Constructor for class org.apache.flink.api.common.io.DelimitedInputFormat
-
- DelimitedInputFormat.AbstractConfigBuilder<T> - Class in org.apache.flink.api.common.io
-
Abstract builder used to set parameters to the input format's configuration in a fluent way.
- DelimitedInputFormat.ConfigBuilder - Class in org.apache.flink.api.common.io
-
A builder used to set parameters to the input format's configuration in a fluent way.
- DeltaIterationBase<ST,WT> - Class in org.apache.flink.api.common.operators.base
-
A DeltaIteration is similar to a
BulkIterationBase
,
but maintains state across the individual iteration steps.
- DeltaIterationBase(BinaryOperatorInformation<ST, WT, ST>, int) - Constructor for class org.apache.flink.api.common.operators.base.DeltaIterationBase
-
- DeltaIterationBase(BinaryOperatorInformation<ST, WT, ST>, int[]) - Constructor for class org.apache.flink.api.common.operators.base.DeltaIterationBase
-
- DeltaIterationBase(BinaryOperatorInformation<ST, WT, ST>, int, String) - Constructor for class org.apache.flink.api.common.operators.base.DeltaIterationBase
-
- DeltaIterationBase(BinaryOperatorInformation<ST, WT, ST>, int[], String) - Constructor for class org.apache.flink.api.common.operators.base.DeltaIterationBase
-
- DeltaIterationBase.SolutionSetPlaceHolder<ST> - Class in org.apache.flink.api.common.operators.base
-
Specialized operator to use as a recognizable place-holder for the solution set input to the
step function.
- DeltaIterationBase.WorksetPlaceHolder<WT> - Class in org.apache.flink.api.common.operators.base
-
Specialized operator to use as a recognizable place-holder for the working set input to the
step function.
- depth() - Method in class org.apache.flink.core.fs.Path
-
Returns the number of elements in this path.
- DeserializationException - Exception in org.apache.flink.types
-
An exception specifying that the deserialization caused an error.
- DeserializationException() - Constructor for exception org.apache.flink.types.DeserializationException
-
Constructs an DeserializationException
with null
as its error detail message.
- DeserializationException(String, Throwable) - Constructor for exception org.apache.flink.types.DeserializationException
-
Constructs an DeserializationException
with the specified detail message
and cause.
- DeserializationException(String) - Constructor for exception org.apache.flink.types.DeserializationException
-
Constructs an DeserializationException
with the specified detail message.
- DeserializationException(Throwable) - Constructor for exception org.apache.flink.types.DeserializationException
-
Constructs an DeserializationException
with the specified cause.
- deserialize(T, DataInputView) - Method in class org.apache.flink.api.common.io.BinaryInputFormat
-
- deserialize(T, DataInputView) - Method in class org.apache.flink.api.common.io.SerializedInputFormat
-
- deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.array.BooleanPrimitiveArraySerializer
-
- deserialize(boolean[], DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.array.BooleanPrimitiveArraySerializer
-
- deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.array.BytePrimitiveArraySerializer
-
- deserialize(byte[], DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.array.BytePrimitiveArraySerializer
-
- deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.array.CharPrimitiveArraySerializer
-
- deserialize(char[], DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.array.CharPrimitiveArraySerializer
-
- deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.array.DoublePrimitiveArraySerializer
-
- deserialize(double[], DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.array.DoublePrimitiveArraySerializer
-
- deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.array.FloatPrimitiveArraySerializer
-
- deserialize(float[], DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.array.FloatPrimitiveArraySerializer
-
- deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.array.IntPrimitiveArraySerializer
-
- deserialize(int[], DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.array.IntPrimitiveArraySerializer
-
- deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.array.LongPrimitiveArraySerializer
-
- deserialize(long[], DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.array.LongPrimitiveArraySerializer
-
- deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.array.ShortPrimitiveArraySerializer
-
- deserialize(short[], DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.array.ShortPrimitiveArraySerializer
-
- deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.array.StringArraySerializer
-
- deserialize(String[], DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.array.StringArraySerializer
-
- deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.BooleanSerializer
-
- deserialize(Boolean, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.BooleanSerializer
-
- deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueSerializer
-
- deserialize(BooleanValue, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueSerializer
-
- deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.ByteSerializer
-
- deserialize(Byte, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.ByteSerializer
-
- deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.ByteValueSerializer
-
- deserialize(ByteValue, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.ByteValueSerializer
-
- deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.CharSerializer
-
- deserialize(Character, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.CharSerializer
-
- deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.CharValueSerializer
-
- deserialize(CharValue, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.CharValueSerializer
-
- deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.DateSerializer
-
- deserialize(Date, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.DateSerializer
-
- deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.DoubleSerializer
-
- deserialize(Double, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.DoubleSerializer
-
- deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueSerializer
-
- deserialize(DoubleValue, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueSerializer
-
- deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.EnumSerializer
-
- deserialize(T, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.EnumSerializer
-
- deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.FloatSerializer
-
- deserialize(Float, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.FloatSerializer
-
- deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.FloatValueSerializer
-
- deserialize(FloatValue, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.FloatValueSerializer
-
- deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.GenericArraySerializer
-
- deserialize(C[], DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.GenericArraySerializer
-
- deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.IntSerializer
-
- deserialize(Integer, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.IntSerializer
-
- deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.IntValueSerializer
-
- deserialize(IntValue, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.IntValueSerializer
-
- deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.LongSerializer
-
- deserialize(Long, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.LongSerializer
-
- deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.LongValueSerializer
-
- deserialize(LongValue, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.LongValueSerializer
-
- deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.ShortSerializer
-
- deserialize(Short, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.ShortSerializer
-
- deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.ShortValueSerializer
-
- deserialize(ShortValue, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.ShortValueSerializer
-
- deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.StringSerializer
-
- deserialize(String, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.StringSerializer
-
- deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.StringValueSerializer
-
- deserialize(StringValue, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.StringValueSerializer
-
- deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.VoidSerializer
-
- deserialize(Void, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.VoidSerializer
-
- deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.record.RecordSerializer
-
- deserialize(Record, DataInputView) - Method in class org.apache.flink.api.common.typeutils.record.RecordSerializer
-
- deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.TypeSerializer
-
De-serializes a record from the given source input view.
- deserialize(T, DataInputView) - Method in class org.apache.flink.api.common.typeutils.TypeSerializer
-
De-serializes a record from the given source input view into the given reuse record instance if mutable.
- deserialize(DataInputView) - Method in class org.apache.flink.types.Record
-
- deserializeFromByteArray(TypeSerializer<T>, byte[]) - Static method in class org.apache.flink.util.InstantiationUtil
-
- deserializeObject(byte[], ClassLoader) - Static method in class org.apache.flink.util.InstantiationUtil
-
- dim - Variable in class org.apache.flink.api.common.distributions.SimpleDistribution
-
- disableClosureCleaner() - Method in class org.apache.flink.api.common.ExecutionConfig
-
Disables the ClosureCleaner.
- DistributedCache - Class in org.apache.flink.api.common.cache
-
DistributedCache provides static methods to write the registered cache files into job configuration or decode
them from job configuration.
- DistributedCache() - Constructor for class org.apache.flink.api.common.cache.DistributedCache
-
- DistributedCache.DistributedCacheEntry - Class in org.apache.flink.api.common.cache
-
- DistributedCacheEntry(String, Boolean) - Constructor for class org.apache.flink.api.common.cache.DistributedCache.DistributedCacheEntry
-
- DOUBLE_ARRAY_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
-
- DOUBLE_PRIMITIVE_ARRAY_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
-
- DOUBLE_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
-
- DoubleComparator - Class in org.apache.flink.api.common.typeutils.base
-
- DoubleComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.DoubleComparator
-
- DoubleCounter - Class in org.apache.flink.api.common.accumulators
-
- DoubleCounter() - Constructor for class org.apache.flink.api.common.accumulators.DoubleCounter
-
- DoubleParser - Class in org.apache.flink.types.parser
-
Parses a text field into a Double.
- DoubleParser() - Constructor for class org.apache.flink.types.parser.DoubleParser
-
- DoublePrimitiveArraySerializer - Class in org.apache.flink.api.common.typeutils.base.array
-
A serializer for double arrays.
- DoublePrimitiveArraySerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.array.DoublePrimitiveArraySerializer
-
- DoubleSerializer - Class in org.apache.flink.api.common.typeutils.base
-
- DoubleSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.DoubleSerializer
-
- DoubleSumAggregator - Class in org.apache.flink.api.common.aggregators
-
- DoubleSumAggregator() - Constructor for class org.apache.flink.api.common.aggregators.DoubleSumAggregator
-
- DoubleValue - Class in org.apache.flink.types
-
Boxed serializable and comparable double precision floating point type, representing the primitive
type double
.
- DoubleValue() - Constructor for class org.apache.flink.types.DoubleValue
-
Initializes the encapsulated double with 0.0.
- DoubleValue(double) - Constructor for class org.apache.flink.types.DoubleValue
-
Initializes the encapsulated double with the provided value.
- DoubleValueParser - Class in org.apache.flink.types.parser
-
Parses a text field into a DoubleValue.
- DoubleValueParser() - Constructor for class org.apache.flink.types.parser.DoubleValueParser
-
- DoubleValueSerializer - Class in org.apache.flink.api.common.typeutils.base
-
- DoubleValueSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.DoubleValueSerializer
-
- DoubleZeroConvergence - Class in org.apache.flink.api.common.aggregators
-
- DoubleZeroConvergence() - Constructor for class org.apache.flink.api.common.aggregators.DoubleZeroConvergence
-
- DualInputOperator<IN1,IN2,OUT,FT extends Function> - Class in org.apache.flink.api.common.operators
-
Abstract operator superclass for for all operators that have two inputs, like "Join", "CoGroup", or "Cross".
- DualInputOperator(UserCodeWrapper<FT>, BinaryOperatorInformation<IN1, IN2, OUT>, String) - Constructor for class org.apache.flink.api.common.operators.DualInputOperator
-
Creates a new abstract dual-input Pact with the given name wrapping the given user function.
- DualInputOperator(UserCodeWrapper<FT>, BinaryOperatorInformation<IN1, IN2, OUT>, int[], int[], String) - Constructor for class org.apache.flink.api.common.operators.DualInputOperator
-
Creates a new abstract dual-input operator with the given name wrapping the given user function.
- DualInputSemanticProperties - Class in org.apache.flink.api.common.operators
-
Container for the semantic properties associated to a dual input operator.
- DualInputSemanticProperties() - Constructor for class org.apache.flink.api.common.operators.DualInputSemanticProperties
-
- duplicate() - Method in class org.apache.flink.api.common.typeutils.base.BooleanComparator
-
- duplicate() - Method in class org.apache.flink.api.common.typeutils.base.ByteComparator
-
- duplicate() - Method in class org.apache.flink.api.common.typeutils.base.CharComparator
-
- duplicate() - Method in class org.apache.flink.api.common.typeutils.base.DateComparator
-
- duplicate() - Method in class org.apache.flink.api.common.typeutils.base.DoubleComparator
-
- duplicate() - Method in class org.apache.flink.api.common.typeutils.base.EnumComparator
-
- duplicate() - Method in class org.apache.flink.api.common.typeutils.base.FloatComparator
-
- duplicate() - Method in class org.apache.flink.api.common.typeutils.base.IntComparator
-
- duplicate() - Method in class org.apache.flink.api.common.typeutils.base.LongComparator
-
- duplicate() - Method in class org.apache.flink.api.common.typeutils.base.ShortComparator
-
- duplicate() - Method in class org.apache.flink.api.common.typeutils.base.StringComparator
-
- duplicate() - Method in class org.apache.flink.api.common.typeutils.record.RecordComparator
-
- duplicate() - Method in class org.apache.flink.api.common.typeutils.TypeComparator
-
Creates a copy of this class.
- FALSE - Static variable in class org.apache.flink.types.BooleanValue
-
- FieldList - Class in org.apache.flink.api.common.operators.util
-
Immutable ordered list of fields IDs.
- FieldList() - Constructor for class org.apache.flink.api.common.operators.util.FieldList
-
- FieldList(int) - Constructor for class org.apache.flink.api.common.operators.util.FieldList
-
- FieldList(Integer) - Constructor for class org.apache.flink.api.common.operators.util.FieldList
-
- FieldList(int...) - Constructor for class org.apache.flink.api.common.operators.util.FieldList
-
- FieldParser<T> - Class in org.apache.flink.types.parser
-
A FieldParser is used parse a field from a sequence of bytes.
- FieldParser() - Constructor for class org.apache.flink.types.parser.FieldParser
-
- FieldParser.ParseErrorState - Enum in org.apache.flink.types.parser
-
An enumeration of different types of errors that may occur.
- FieldSet - Class in org.apache.flink.api.common.operators.util
-
Immutable unordered collection of fields IDs.
- FieldSet() - Constructor for class org.apache.flink.api.common.operators.util.FieldSet
-
Creates a new empty set of fields.
- FieldSet(Integer) - Constructor for class org.apache.flink.api.common.operators.util.FieldSet
-
Creates a set with one field.
- FieldSet(int...) - Constructor for class org.apache.flink.api.common.operators.util.FieldSet
-
Creates a set with the given fields.
- FieldSet(int[], boolean) - Constructor for class org.apache.flink.api.common.operators.util.FieldSet
-
Creates a set with the given fields.
- FieldSet(Collection<Integer>) - Constructor for class org.apache.flink.api.common.operators.util.FieldSet
-
- FILE_PARAMETER_KEY - Static variable in class org.apache.flink.api.common.io.FileOutputFormat
-
The key under which the name of the target path is stored in the configuration.
- FileBaseStatistics(long, long, float) - Constructor for class org.apache.flink.api.common.io.FileInputFormat.FileBaseStatistics
-
Creates a new statistics object.
- FileDataSinkBase<IN> - Class in org.apache.flink.api.common.operators.base
-
Operator for nodes which act as data sinks, storing the data they receive in a file instead of sending it to another
contract.
- FileDataSinkBase(FileOutputFormat<IN>, UnaryOperatorInformation<IN, Nothing>, String, String) - Constructor for class org.apache.flink.api.common.operators.base.FileDataSinkBase
-
Creates a FileDataSink with the provided
FileOutputFormat
implementation
and the given name, writing to the file indicated by the given path.
- FileDataSinkBase(UserCodeWrapper<FileOutputFormat<IN>>, UnaryOperatorInformation<IN, Nothing>, String, String) - Constructor for class org.apache.flink.api.common.operators.base.FileDataSinkBase
-
Creates a FileDataSink with the provided
FileOutputFormat
implementation
and the given name, writing to the file indicated by the given path.
- FileDataSourceBase<OUT> - Class in org.apache.flink.api.common.operators.base
-
Operator for input nodes which read data from files.
- FileDataSourceBase(FileInputFormat<OUT>, OperatorInformation<OUT>, String, String) - Constructor for class org.apache.flink.api.common.operators.base.FileDataSourceBase
-
Creates a new instance for the given file using the given file input format.
- FileDataSourceBase(FileInputFormat<OUT>, OperatorInformation<OUT>, String) - Constructor for class org.apache.flink.api.common.operators.base.FileDataSourceBase
-
Creates a new instance for the given file using the given input format.
- FileDataSourceBase(Class<? extends FileInputFormat<OUT>>, OperatorInformation<OUT>, String, String) - Constructor for class org.apache.flink.api.common.operators.base.FileDataSourceBase
-
Creates a new instance for the given file using the given file input format.
- FileDataSourceBase(Class<? extends FileInputFormat<OUT>>, OperatorInformation<OUT>, String) - Constructor for class org.apache.flink.api.common.operators.base.FileDataSourceBase
-
Creates a new instance for the given file using the given input format.
- FileInputFormat<OT> - Class in org.apache.flink.api.common.io
-
- FileInputFormat() - Constructor for class org.apache.flink.api.common.io.FileInputFormat
-
- FileInputFormat(Path) - Constructor for class org.apache.flink.api.common.io.FileInputFormat
-
- FileInputFormat.AbstractConfigBuilder<T> - Class in org.apache.flink.api.common.io
-
Abstract builder used to set parameters to the input format's configuration in a fluent way.
- FileInputFormat.ConfigBuilder - Class in org.apache.flink.api.common.io
-
A builder used to set parameters to the input format's configuration in a fluent way.
- FileInputFormat.FileBaseStatistics - Class in org.apache.flink.api.common.io
-
Encapsulation of the basic statistics the optimizer obtains about a file.
- FileInputFormat.InputSplitOpenThread - Class in org.apache.flink.api.common.io
-
Obtains a DataInputStream in an thread that is not interrupted.
- FileInputSplit - Class in org.apache.flink.core.fs
-
A file input split provides information on a particular part of a file, possibly
hosted on a distributed file system and replicated among several hosts.
- FileInputSplit(int, Path, long, long, String[]) - Constructor for class org.apache.flink.core.fs.FileInputSplit
-
Constructs a split with host information.
- FileInputSplit() - Constructor for class org.apache.flink.core.fs.FileInputSplit
-
Default constructor for deserialization.
- fileModTime - Variable in class org.apache.flink.api.common.io.FileInputFormat.FileBaseStatistics
-
- FileOutputFormat<IT> - Class in org.apache.flink.api.common.io
-
The abstract base class for all output formats that are file based.
- FileOutputFormat() - Constructor for class org.apache.flink.api.common.io.FileOutputFormat
-
- FileOutputFormat(Path) - Constructor for class org.apache.flink.api.common.io.FileOutputFormat
-
- FileOutputFormat.AbstractConfigBuilder<T> - Class in org.apache.flink.api.common.io
-
A builder used to set parameters to the output format's configuration in a fluent way.
- FileOutputFormat.ConfigBuilder - Class in org.apache.flink.api.common.io
-
A builder used to set parameters to the input format's configuration in a fluent way.
- FileOutputFormat.OutputDirectoryMode - Enum in org.apache.flink.api.common.io
-
Behavior for creating output directories.
- filePath - Variable in class org.apache.flink.api.common.cache.DistributedCache.DistributedCacheEntry
-
- filePath(String) - Method in class org.apache.flink.api.common.io.FileInputFormat.AbstractConfigBuilder
-
Sets the path to the file or directory to be read by this file input format.
- filePath - Variable in class org.apache.flink.api.common.io.FileInputFormat
-
The path to the file that contains the input.
- filePath - Variable in class org.apache.flink.api.common.operators.base.FileDataSinkBase
-
- filePath - Variable in class org.apache.flink.api.common.operators.base.FileDataSourceBase
-
- fileSize - Variable in class org.apache.flink.api.common.io.FileInputFormat.FileBaseStatistics
-
- FileStatus - Interface in org.apache.flink.core.fs
-
Interface that represents the client side information for a file
independent of the file system.
- FileSystem - Class in org.apache.flink.core.fs
-
An abstract base class for a fairly generic file system.
- FileSystem() - Constructor for class org.apache.flink.core.fs.FileSystem
-
- FileSystem.FSKey - Class in org.apache.flink.core.fs
-
An auxiliary class to identify a file system by its scheme and its authority.
- FileSystem.WriteMode - Enum in org.apache.flink.core.fs
-
Enumeration for write modes.
- FILESYSTEM_DEFAULT_OVERWRITE_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
-
Key to specify whether the file systems should simply overwrite existing files.
- FILESYSTEM_OUTPUT_ALWAYS_CREATE_DIRECTORY_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
-
Key to specify whether the file systems should always create a directory for the output, even with a parallelism of one.
- filter(T) - Method in interface org.apache.flink.api.common.functions.FilterFunction
-
The filter function that evaluates the predicate.
- filter(T) - Method in class org.apache.flink.api.common.functions.RichFilterFunction
-
- FilterFunction<T> - Interface in org.apache.flink.api.common.functions
-
base interface for Filter functions.
- FilterOperatorBase<T,FT extends FlatMapFunction<T,T>> - Class in org.apache.flink.api.common.operators.base
-
- FilterOperatorBase(UserCodeWrapper<FT>, UnaryOperatorInformation<T, T>, String) - Constructor for class org.apache.flink.api.common.operators.base.FilterOperatorBase
-
- FilterOperatorBase(FT, UnaryOperatorInformation<T, T>, String) - Constructor for class org.apache.flink.api.common.operators.base.FilterOperatorBase
-
- FilterOperatorBase(Class<? extends FT>, UnaryOperatorInformation<T, T>, String) - Constructor for class org.apache.flink.api.common.operators.base.FilterOperatorBase
-
- finalizeGlobal(int) - Method in interface org.apache.flink.api.common.io.FinalizeOnMaster
-
The method is invoked on the master (JobManager) after all (parallel) instances of an OutputFormat finished.
- FinalizeOnMaster - Interface in org.apache.flink.api.common.io
-
This interface may be implemented by
OutputFormat
s to have the master finalize them globally.
- find(String) - Method in class org.apache.flink.core.io.StringRecord
-
- find(String, int) - Method in class org.apache.flink.core.io.StringRecord
-
Finds any occurrence of what
in the backing buffer, starting
as position start
.
- find(CharSequence) - Method in class org.apache.flink.types.StringValue
-
Finds any occurrence of the str
character sequence in this StringValue.
- find(CharSequence, int) - Method in class org.apache.flink.types.StringValue
-
Finds any occurrence of the str
character sequence in this StringValue.
- FlatCombineFunction<T> - Interface in org.apache.flink.api.common.functions
-
Generic interface used for combine functions ("combiners").
- FlatFieldDescriptor(int, TypeInformation<?>) - Constructor for class org.apache.flink.api.common.typeutils.CompositeType.FlatFieldDescriptor
-
- FlatJoinFunction<IN1,IN2,OUT> - Interface in org.apache.flink.api.common.functions
-
Interface for Join functions.
- flatMap(T, Collector<O>) - Method in interface org.apache.flink.api.common.functions.FlatMapFunction
-
The core method of the FlatMapFunction.
- flatMap(IN, Collector<OUT>) - Method in class org.apache.flink.api.common.functions.RichFlatMapFunction
-
- flatMap(X, Collector<X>) - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase.TerminationCriterionMapper
-
- FlatMapFunction<T,O> - Interface in org.apache.flink.api.common.functions
-
Base interface for flatMap functions.
- FlatMapOperatorBase<IN,OUT,FT extends FlatMapFunction<IN,OUT>> - Class in org.apache.flink.api.common.operators.base
-
- FlatMapOperatorBase(UserCodeWrapper<FT>, UnaryOperatorInformation<IN, OUT>, String) - Constructor for class org.apache.flink.api.common.operators.base.FlatMapOperatorBase
-
- FlatMapOperatorBase(FT, UnaryOperatorInformation<IN, OUT>, String) - Constructor for class org.apache.flink.api.common.operators.base.FlatMapOperatorBase
-
- FlatMapOperatorBase(Class<? extends FT>, UnaryOperatorInformation<IN, OUT>, String) - Constructor for class org.apache.flink.api.common.operators.base.FlatMapOperatorBase
-
- FLINK_BASE_DIR_PATH_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
-
The key to the Flink base directory path
- FLINK_JVM_OPTIONS - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- FLOAT_ARRAY_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
-
- FLOAT_PRIMITIVE_ARRAY_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
-
- FLOAT_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
-
- FloatComparator - Class in org.apache.flink.api.common.typeutils.base
-
- FloatComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.FloatComparator
-
- FloatParser - Class in org.apache.flink.types.parser
-
Parses a text field into a
Float
.
- FloatParser() - Constructor for class org.apache.flink.types.parser.FloatParser
-
- FloatPrimitiveArraySerializer - Class in org.apache.flink.api.common.typeutils.base.array
-
A serializer for float arrays.
- FloatPrimitiveArraySerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.array.FloatPrimitiveArraySerializer
-
- FloatSerializer - Class in org.apache.flink.api.common.typeutils.base
-
- FloatSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.FloatSerializer
-
- FloatValue - Class in org.apache.flink.types
-
Boxed serializable and comparable single precision floating point type, representing the primitive
type float
.
- FloatValue() - Constructor for class org.apache.flink.types.FloatValue
-
Initializes the encapsulated float with 0.0.
- FloatValue(float) - Constructor for class org.apache.flink.types.FloatValue
-
Initializes the encapsulated float with the provided value.
- FloatValueParser - Class in org.apache.flink.types.parser
-
- FloatValueParser() - Constructor for class org.apache.flink.types.parser.FloatValueParser
-
- FloatValueSerializer - Class in org.apache.flink.api.common.typeutils.base
-
- FloatValueSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.FloatValueSerializer
-
- flush() - Method in class org.apache.flink.core.memory.OutputViewDataOutputStreamWrapper
-
- formatWrapper - Variable in class org.apache.flink.api.common.operators.GenericDataSinkBase
-
- formatWrapper - Variable in class org.apache.flink.api.common.operators.GenericDataSourceBase
-
- free() - Method in class org.apache.flink.core.memory.MemorySegment
-
- FS_STREAM_OPENING_TIMEOUT_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
-
The config parameter defining the timeout for filesystem stream opening.
- FSDataInputStream - Class in org.apache.flink.core.fs
-
Interface for a data input stream to a file on a
FileSystem
.
- FSDataInputStream() - Constructor for class org.apache.flink.core.fs.FSDataInputStream
-
- FSDataOutputStream - Class in org.apache.flink.core.fs
-
Interface for a data output stream to a file on a
FileSystem
.
- FSDataOutputStream() - Constructor for class org.apache.flink.core.fs.FSDataOutputStream
-
- FSKey(String, String) - Constructor for class org.apache.flink.core.fs.FileSystem.FSKey
-
Creates a file system key from a given scheme and an
authority.
- Function - Interface in org.apache.flink.api.common.functions
-
An base interface for all user-defined functions.
- FunctionUtils - Class in org.apache.flink.api.common.functions.util
-
- FunctionUtils() - Constructor for class org.apache.flink.api.common.functions.util.FunctionUtils
-
- GenericArraySerializer<C> - Class in org.apache.flink.api.common.typeutils.base
-
A serializer for arrays of objects.
- GenericArraySerializer(Class<C>, TypeSerializer<C>) - Constructor for class org.apache.flink.api.common.typeutils.base.GenericArraySerializer
-
- GenericCollectorMap<T,O> - Interface in org.apache.flink.api.common.functions
-
Deprecated.
- GenericCsvInputFormat<OT> - Class in org.apache.flink.api.common.io
-
- GenericCsvInputFormat() - Constructor for class org.apache.flink.api.common.io.GenericCsvInputFormat
-
- GenericCsvInputFormat(Path) - Constructor for class org.apache.flink.api.common.io.GenericCsvInputFormat
-
- GenericDataSinkBase<IN> - Class in org.apache.flink.api.common.operators
-
Operator for nodes that act as data sinks, storing the data they receive.
- GenericDataSinkBase(OutputFormat<IN>, UnaryOperatorInformation<IN, Nothing>, String) - Constructor for class org.apache.flink.api.common.operators.GenericDataSinkBase
-
Creates a GenericDataSink with the provided
OutputFormat
implementation
and the given name.
- GenericDataSinkBase(UserCodeWrapper<? extends OutputFormat<IN>>, UnaryOperatorInformation<IN, Nothing>, String) - Constructor for class org.apache.flink.api.common.operators.GenericDataSinkBase
-
Creates a GenericDataSink with the provided
OutputFormat
implementation
and the given name.
- GenericDataSourceBase<OUT,T extends InputFormat<OUT,?>> - Class in org.apache.flink.api.common.operators
-
Abstract superclass for data sources in a Pact plan.
- GenericDataSourceBase(T, OperatorInformation<OUT>, String) - Constructor for class org.apache.flink.api.common.operators.GenericDataSourceBase
-
Creates a new instance for the given file using the given input format.
- GenericDataSourceBase(T, OperatorInformation<OUT>) - Constructor for class org.apache.flink.api.common.operators.GenericDataSourceBase
-
Creates a new instance for the given file using the given input format, using the default name.
- GenericDataSourceBase(Class<? extends T>, OperatorInformation<OUT>, String) - Constructor for class org.apache.flink.api.common.operators.GenericDataSourceBase
-
Creates a new instance for the given file using the given input format.
- GenericDataSourceBase(Class<? extends T>, OperatorInformation<OUT>) - Constructor for class org.apache.flink.api.common.operators.GenericDataSourceBase
-
Creates a new instance for the given file using the given input format, using the default name.
- GenericInputFormat<OT> - Class in org.apache.flink.api.common.io
-
Generic base class for all inputs that are not based on files.
- GenericInputFormat() - Constructor for class org.apache.flink.api.common.io.GenericInputFormat
-
- GenericInputSplit - Class in org.apache.flink.core.io
-
A generic input split that has only a partition number.
- GenericInputSplit() - Constructor for class org.apache.flink.core.io.GenericInputSplit
-
Default constructor for instantiation during de-serialization.
- GenericInputSplit(int, int) - Constructor for class org.apache.flink.core.io.GenericInputSplit
-
Creates a generic input split with the given split number.
- GenericPairComparator<T1,T2> - Class in org.apache.flink.api.common.typeutils
-
- GenericPairComparator(TypeComparator<T1>, TypeComparator<T2>) - Constructor for class org.apache.flink.api.common.typeutils.GenericPairComparator
-
- get(int) - Method in class org.apache.flink.api.common.operators.util.FieldList
-
- get() - Static method in class org.apache.flink.api.common.typeutils.record.RecordPairComparatorFactory
-
Gets an instance of the comparator factory.
- get() - Static method in class org.apache.flink.api.common.typeutils.record.RecordSerializer
-
- get() - Static method in class org.apache.flink.api.common.typeutils.record.RecordSerializerFactory
-
Gets an instance of the serializer factory.
- get(URI) - Static method in class org.apache.flink.core.fs.FileSystem
-
Returns a reference to the
FileSystem
instance for accessing the
file system identified by the given
URI
.
- get(int) - Method in class org.apache.flink.core.memory.MemorySegment
-
Reads the byte at the given position.
- get(int, byte[]) - Method in class org.apache.flink.core.memory.MemorySegment
-
Bulk get method.
- get(int, byte[], int, int) - Method in class org.apache.flink.core.memory.MemorySegment
-
Bulk get method.
- get(DataOutput, int, int) - Method in class org.apache.flink.core.memory.MemorySegment
-
Bulk get method.
- get(int, ByteBuffer, int) - Method in class org.apache.flink.core.memory.MemorySegment
-
Bulk get method.
- get() - Method in class org.apache.flink.types.BooleanValue
-
- get(int) - Method in class org.apache.flink.types.ListValue
-
- get(Object) - Method in class org.apache.flink.types.MapValue
-
- getAccessTime() - Method in interface org.apache.flink.core.fs.FileStatus
-
Get the access time of the file.
- getAccessTime() - Method in class org.apache.flink.core.fs.local.LocalFileStatus
-
- getAccumulatedRecordCount() - Method in class org.apache.flink.api.common.io.BlockInfo
-
Returns the accumulated record count.
- getAccumulator(String) - Method in interface org.apache.flink.api.common.functions.RuntimeContext
-
Get an existing accumulator object.
- getAccumulator(String) - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
-
- getAccumulatorResult(String) - Method in class org.apache.flink.api.common.JobExecutionResult
-
- getAccumulatorsFormated(Map<?, Accumulator<?, ?>>) - Static method in class org.apache.flink.api.common.accumulators.AccumulatorHelper
-
- getAggregate() - Method in interface org.apache.flink.api.common.aggregators.Aggregator
-
Gets the aggregator's current aggregate.
- getAggregate() - Method in class org.apache.flink.api.common.aggregators.DoubleSumAggregator
-
- getAggregate() - Method in class org.apache.flink.api.common.aggregators.LongSumAggregator
-
- getAggregate() - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase.TerminationCriterionAggregator
-
- getAggregator() - Method in class org.apache.flink.api.common.aggregators.AggregatorWithName
-
Gets the aggregator.
- getAggregators() - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase
-
- getAggregators() - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase
-
- getAggregators() - Method in interface org.apache.flink.api.common.operators.IterationOperator
-
- getAllAccumulatorResults() - Method in class org.apache.flink.api.common.JobExecutionResult
-
- getAllAccumulators() - Method in interface org.apache.flink.api.common.functions.RuntimeContext
-
For system internal usage only.
- getAllAccumulators() - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
-
- getAllRegisteredAggregators() - Method in class org.apache.flink.api.common.aggregators.AggregatorRegistry
-
- getArity() - Method in class org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
-
- getArity() - Method in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
-
- getArity() - Method in class org.apache.flink.api.common.typeinfo.NothingTypeInfo
-
- getArity() - Method in class org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
-
- getArity() - Method in class org.apache.flink.api.common.typeinfo.TypeInformation
-
- getAverageRecordWidth() - Method in class org.apache.flink.api.common.io.FileInputFormat.FileBaseStatistics
-
Gets the estimated average number of bytes per record.
- getAverageRecordWidth() - Method in interface org.apache.flink.api.common.io.statistics.BaseStatistics
-
Gets the average width of a record, in bytes.
- getAvgOutputRecordSize() - Method in class org.apache.flink.api.common.operators.CompilerHints
-
- getBinaryLength() - Method in class org.apache.flink.types.BooleanValue
-
- getBinaryLength() - Method in class org.apache.flink.types.ByteValue
-
- getBinaryLength() - Method in class org.apache.flink.types.CharValue
-
- getBinaryLength() - Method in interface org.apache.flink.types.CopyableValue
-
Gets the length of the data type when it is serialized, in bytes.
- getBinaryLength() - Method in class org.apache.flink.types.DoubleValue
-
- getBinaryLength() - Method in class org.apache.flink.types.FloatValue
-
- getBinaryLength() - Method in class org.apache.flink.types.IntValue
-
- getBinaryLength() - Method in class org.apache.flink.types.LongValue
-
- getBinaryLength() - Method in class org.apache.flink.types.NullValue
-
- getBinaryLength() - Method in class org.apache.flink.types.Record
-
- getBinaryLength() - Method in class org.apache.flink.types.ShortValue
-
- getBinaryLength() - Method in class org.apache.flink.types.StringValue
-
- getBlockSize() - Method in interface org.apache.flink.core.fs.FileStatus
-
Get the block size of the file.
- getBlockSize() - Method in class org.apache.flink.core.fs.local.LocalFileStatus
-
- getBoolean(String, boolean) - Method in class org.apache.flink.configuration.Configuration
-
Returns the value associated with the given key as a boolean.
- getBoolean(String, boolean) - Static method in class org.apache.flink.configuration.GlobalConfiguration
-
Returns the value associated with the given key as a boolean.
- getBoolean(int) - Method in class org.apache.flink.core.memory.MemorySegment
-
Reads one byte at the given position and returns its boolean
representation.
- getBroadcastInputs() - Method in class org.apache.flink.api.common.operators.AbstractUdfOperator
-
Returns the input, or null, if none is set.
- getBroadcastInputs() - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase
-
The BulkIteration meta operator cannot have broadcast inputs.
- getBroadcastInputs() - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase
-
DeltaIteration meta operator cannot have broadcast inputs.
- getBroadcastVariable(String) - Method in interface org.apache.flink.api.common.functions.RuntimeContext
-
Returns the result bound to the broadcast variable identified by the
given name
.
- getBroadcastVariable(String) - Method in class org.apache.flink.api.common.functions.util.RuntimeUDFContext
-
- getBroadcastVariableWithInitializer(String, BroadcastVariableInitializer<T, C>) - Method in interface org.apache.flink.api.common.functions.RuntimeContext
-
Returns the result bound to the broadcast variable identified by the
given name
.
- getBroadcastVariableWithInitializer(String, BroadcastVariableInitializer<T, C>) - Method in class org.apache.flink.api.common.functions.util.RuntimeUDFContext
-
- getBucketBoundary(int, int) - Method in interface org.apache.flink.api.common.distributions.DataDistribution
-
Returns the i'th bucket's upper bound, given that the distribution is to be
split into totalBuckets
buckets.
- getBucketBoundary(int, int) - Method in class org.apache.flink.api.common.distributions.SimpleDistribution
-
- getBucketBoundary(int, int) - Method in class org.apache.flink.api.common.distributions.SimpleIntegerDistribution
-
- getBucketBoundary(int, int) - Method in class org.apache.flink.api.common.distributions.UniformDoubleDistribution
-
- getBucketBoundary(int, int) - Method in class org.apache.flink.api.common.distributions.UniformIntegerDistribution
-
- getBufferSize() - Method in class org.apache.flink.api.common.io.DelimitedInputFormat
-
- getBuildComparator() - Method in class org.apache.flink.api.common.operators.util.JoinHashMap
-
- getBuildSerializer() - Method in class org.apache.flink.api.common.operators.util.JoinHashMap
-
- getBytes(String, byte[]) - Method in class org.apache.flink.configuration.Configuration
-
Returns the value associated with the given key as a byte array.
- getBytes() - Method in class org.apache.flink.core.io.StringRecord
-
- getCachedFiles() - Method in class org.apache.flink.api.common.Plan
-
return the registered caches files
- getChar(int) - Method in class org.apache.flink.core.memory.MemorySegment
-
Reads two memory at the given position, composing them into a char value
according to the current byte order.
- getCharArray() - Method in class org.apache.flink.types.StringValue
-
Returns this StringValue's internal character data.
- getClass(String, Class<? extends T>, ClassLoader) - Method in class org.apache.flink.configuration.Configuration
-
Returns the class associated with the given key as a string.
- getCompilerHints() - Method in class org.apache.flink.api.common.operators.Operator
-
Gets the compiler hints for this contract instance.
- getComponentInfo() - Method in class org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
-
- getComponentTypeClass() - Method in class org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
-
- getConfiguration() - Static method in class org.apache.flink.configuration.GlobalConfiguration
-
Gets a
Configuration
object with the values of this GlobalConfiguration
- getContainingBulkIteration() - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase.PartialSolutionPlaceHolder
-
- getContainingWorksetIteration() - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase.SolutionSetPlaceHolder
-
- getContainingWorksetIteration() - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase.WorksetPlaceHolder
-
- getContractClass(Class<?>) - Static method in class org.apache.flink.api.common.operators.util.OperatorUtil
-
- getConvergenceCriterion() - Method in class org.apache.flink.api.common.aggregators.AggregatorRegistry
-
- getConvergenceCriterionAggregatorName() - Method in class org.apache.flink.api.common.aggregators.AggregatorRegistry
-
- getCurrent() - Method in class org.apache.flink.api.common.operators.util.ListKeyGroupedIterator.ValuesIterator
-
- getCurrent() - Method in class org.apache.flink.util.NumberSequenceIterator
-
- getCurrentOperatingSystem() - Static method in enum org.apache.flink.util.OperatingSystem
-
Gets the operating system that the JVM runs on from the java system properties.
- getCustomPartitioner() - Method in class org.apache.flink.api.common.operators.base.CoGroupOperatorBase
-
- getCustomPartitioner() - Method in class org.apache.flink.api.common.operators.base.GroupReduceOperatorBase
-
- getCustomPartitioner() - Method in class org.apache.flink.api.common.operators.base.JoinOperatorBase
-
- getCustomPartitioner() - Method in class org.apache.flink.api.common.operators.base.PartitionOperatorBase
-
- getCustomPartitioner() - Method in class org.apache.flink.api.common.operators.base.ReduceOperatorBase
-
- getDataDistribution() - Method in class org.apache.flink.api.common.operators.GenericDataSinkBase
-
Gets the distribution to use for the range partitioning.
- getDataSinks() - Method in class org.apache.flink.api.common.Plan
-
Gets all the data sinks of this job.
- getDataType() - Method in class org.apache.flink.api.common.typeutils.record.RecordSerializerFactory
-
- getDataType() - Method in interface org.apache.flink.api.common.typeutils.TypeSerializerFactory
-
- getDefaultBlockSize() - Method in class org.apache.flink.core.fs.FileSystem
-
Return the number of bytes that large input files should be optimally be split into to minimize I/O time.
- getDefaultParallelism() - Method in class org.apache.flink.api.common.Plan
-
Gets the default degree of parallelism for this job.
- getDegreeOfParallelism() - Method in class org.apache.flink.api.common.ExecutionConfig
-
Gets the degree of parallelism with which operation are executed by default.
- getDegreeOfParallelism() - Method in class org.apache.flink.api.common.operators.Operator
-
Gets the degree of parallelism for this contract instance.
- getDelimiter() - Method in class org.apache.flink.api.common.io.DelimitedInputFormat
-
- getDescription() - Method in interface org.apache.flink.api.common.ProgramDescription
-
Returns a description of the plan that is generated by the assembler and
also of the arguments if they are available.
- getDescriptionPrefix() - Method in class org.apache.flink.api.common.operators.util.FieldList
-
- getDescriptionPrefix() - Method in class org.apache.flink.api.common.operators.util.FieldSet
-
- getDescriptionSuffix() - Method in class org.apache.flink.api.common.operators.util.FieldList
-
- getDescriptionSuffix() - Method in class org.apache.flink.api.common.operators.util.FieldSet
-
- getDistributedCache() - Method in interface org.apache.flink.api.common.functions.RuntimeContext
-
Returns the
DistributedCache
to get the local temporary file copies of files otherwise not
locally accessible.
- getDistributedCache() - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
-
- getDouble(String, double) - Method in class org.apache.flink.configuration.Configuration
-
Returns the value associated with the given key as a double.
- getDouble(int) - Method in class org.apache.flink.core.memory.MemorySegment
-
Reads a double-precision floating point value (64bit, 8 bytes) from the given position, in the system's
native byte order.
- getDoubleBigEndian(int) - Method in class org.apache.flink.core.memory.MemorySegment
-
Reads a double-precision floating point value (64bit, 8 bytes) from the given position, in big endian
byte order.
- getDoubleCounter(String) - Method in interface org.apache.flink.api.common.functions.RuntimeContext
-
Convenience function to create a counter object for doubles.
- getDoubleCounter(String) - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
-
- getDoubleLittleEndian(int) - Method in class org.apache.flink.core.memory.MemorySegment
-
Reads a double-precision floating point value (64bit, 8 bytes) from the given position, in little endian
byte order.
- getErrorState() - Method in class org.apache.flink.types.parser.FieldParser
-
- getField(int, Class<T>) - Method in class org.apache.flink.types.Record
-
Gets the field at the given position from the record.
- getField(int, T) - Method in class org.apache.flink.types.Record
-
Gets the field at the given position.
- getFieldDelimiter() - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
-
- getFieldInto(int, Value) - Method in class org.apache.flink.types.Record
-
Gets the field at the given position.
- getFieldNumber(int) - Method in class org.apache.flink.api.common.operators.Ordering
-
- getFieldNumber() - Method in exception org.apache.flink.types.KeyFieldOutOfBoundsException
-
Gets the field number that was attempted to access.
- getFieldNumber() - Method in exception org.apache.flink.types.NullKeyFieldException
-
Gets the field number that was attempted to access.
- getFieldOrders() - Method in class org.apache.flink.api.common.operators.Ordering
-
- getFieldParsers() - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
-
- getFieldPos() - Method in exception org.apache.flink.types.NullFieldException
-
Gets the field number that was attempted to access.
- getFieldPositions() - Method in class org.apache.flink.api.common.operators.Ordering
-
- getFieldsInto(int[], Value[]) - Method in class org.apache.flink.types.Record
-
Gets the fields at the given positions into an array.
- getFieldsIntoCheckingNull(int[], Value[]) - Method in class org.apache.flink.types.Record
-
Gets the fields at the given positions into an array.
- getFieldSortDirections() - Method in class org.apache.flink.api.common.operators.Ordering
-
- getFile(String) - Method in class org.apache.flink.api.common.cache.DistributedCache
-
- getFile() - Method in class org.apache.flink.core.fs.local.LocalFileStatus
-
- getFileBlockLocations(FileStatus, long, long) - Method in class org.apache.flink.core.fs.FileSystem
-
Return an array containing hostnames, offset and size of
portions of the given file.
- getFileBlockLocations(FileStatus, long, long) - Method in class org.apache.flink.core.fs.local.LocalFileSystem
-
- getFilePath() - Method in class org.apache.flink.api.common.io.FileInputFormat
-
- getFilePath() - Method in class org.apache.flink.api.common.operators.base.FileDataSinkBase
-
Returns the configured file path where the output is written to.
- getFilePath() - Method in class org.apache.flink.api.common.operators.base.FileDataSourceBase
-
Returns the file path from which the input is read.
- getFiles() - Method in class org.apache.flink.api.common.io.BinaryInputFormat
-
- getFileStats(FileInputFormat.FileBaseStatistics, Path, FileSystem, ArrayList<FileStatus>) - Method in class org.apache.flink.api.common.io.FileInputFormat
-
- getFileStatus(Path) - Method in class org.apache.flink.core.fs.FileSystem
-
Return a file status object that represents the path.
- getFileStatus(Path) - Method in class org.apache.flink.core.fs.local.LocalFileSystem
-
- getFileSystem() - Method in class org.apache.flink.core.fs.Path
-
Returns the FileSystem that owns this Path.
- getFileSystemByName(String) - Static method in class org.apache.flink.util.ClassUtils
-
Searches for a file system class by its name and attempts to load it.
- getFilterFactor() - Method in class org.apache.flink.api.common.operators.CompilerHints
-
- getFirst() - Method in class org.apache.flink.types.Pair
-
Returns the first encapsulated pair element.
- getFirstInput() - Method in class org.apache.flink.api.common.operators.DualInputOperator
-
Returns the first input, or null, if none is set.
- getFirstInputType() - Method in class org.apache.flink.api.common.operators.BinaryOperatorInformation
-
- getFirstRecordStart() - Method in class org.apache.flink.api.common.io.BlockInfo
-
Returns the firstRecordStart.
- getFlatComparator(List<TypeComparator>) - Method in class org.apache.flink.api.common.typeutils.CompositeTypeComparator
-
- getFlatComparators() - Method in class org.apache.flink.api.common.typeutils.base.BasicTypeComparator
-
- getFlatComparators() - Method in class org.apache.flink.api.common.typeutils.CompositeTypeComparator
-
- getFlatComparators() - Method in class org.apache.flink.api.common.typeutils.record.RecordComparator
-
- getFlatComparators() - Method in class org.apache.flink.api.common.typeutils.TypeComparator
-
Get the field comparators.
- getFloat(String, float) - Method in class org.apache.flink.configuration.Configuration
-
Returns the value associated with the given key as a float.
- getFloat(String, float) - Static method in class org.apache.flink.configuration.GlobalConfiguration
-
Returns the value associated with the given key as a float.
- getFloat(int) - Method in class org.apache.flink.core.memory.MemorySegment
-
Reads a single-precision floating point value (32bit, 4 bytes) from the given position, in the system's
native byte order.
- getFloatBigEndian(int) - Method in class org.apache.flink.core.memory.MemorySegment
-
Reads a single-precision floating point value (32bit, 4 bytes) from the given position, in big endian
byte order.
- getFloatLittleEndian(int) - Method in class org.apache.flink.core.memory.MemorySegment
-
Reads a single-precision floating point value (32bit, 4 bytes) from the given position, in little endian
byte order.
- getFormatWrapper() - Method in class org.apache.flink.api.common.operators.GenericDataSinkBase
-
Gets the class describing this sinks output format.
- getFormatWrapper() - Method in class org.apache.flink.api.common.operators.GenericDataSourceBase
-
Gets the class describing the input format.
- getForwardedField(int) - Method in class org.apache.flink.api.common.operators.SingleInputSemanticProperties.AllFieldsConstantProperties
-
- getForwardedField(int) - Method in class org.apache.flink.api.common.operators.SingleInputSemanticProperties
-
Gets the fields in the destination record where the source
field is forwarded.
- getForwardedField1(int) - Method in class org.apache.flink.api.common.operators.DualInputSemanticProperties
-
Gets the fields in the destination record where the source
field from the first input is forwarded.
- getForwardedField2(int) - Method in class org.apache.flink.api.common.operators.DualInputSemanticProperties
-
Gets the fields in the destination record where the source
field from the second input is forwarded.
- getFunctionRuntimeContext(Function, RuntimeContext) - Static method in class org.apache.flink.api.common.functions.util.FunctionUtils
-
- getGenericFieldTypes() - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
-
- getGroupOrder(int) - Method in class org.apache.flink.api.common.operators.base.CoGroupOperatorBase
-
Gets the value order for an input, i.e.
- getGroupOrder() - Method in class org.apache.flink.api.common.operators.base.GroupReduceOperatorBase
-
Gets the order of elements within a reduce group.
- getGroupOrderForInputOne() - Method in class org.apache.flink.api.common.operators.base.CoGroupOperatorBase
-
Gets the order of elements within a group for the first input.
- getGroupOrderForInputTwo() - Method in class org.apache.flink.api.common.operators.base.CoGroupOperatorBase
-
Gets the order of elements within a group for the second input.
- getHadoopWrapperClassNameForFileSystem(String) - Method in interface org.apache.flink.core.fs.HadoopFileSystemWrapper
-
Test whether the HadoopWrapper can wrap the given file system scheme.
- getHistogram(String) - Method in interface org.apache.flink.api.common.functions.RuntimeContext
-
Convenience function to create a counter object for histograms.
- getHistogram(String) - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
-
- getHostnameFromFQDN(String) - Static method in class org.apache.flink.util.NetUtils
-
Turn a fully qualified domain name (fqdn) into a hostname.
- getHostnames() - Method in class org.apache.flink.core.io.LocatableInputSplit
-
Returns the names of the hosts storing the data this input split refers to
- getHosts() - Method in interface org.apache.flink.core.fs.BlockLocation
-
Get the list of hosts (hostname) hosting this block.
- getHosts() - Method in class org.apache.flink.core.fs.local.LocalBlockLocation
-
- getIndexOfThisSubtask() - Method in interface org.apache.flink.api.common.functions.RuntimeContext
-
Gets the number of the parallel subtask.
- getIndexOfThisSubtask() - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
-
- getInfoFor(Class<X>) - Static method in class org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
-
- getInfoFor(Class<X>) - Static method in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
-
- getInfoFor(Class<X>) - Static method in class org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
-
- getInfoSize() - Method in class org.apache.flink.api.common.io.BlockInfo
-
- getInitialSolutionSet() - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase
-
Returns the initial solution set input, or null, if none is set.
- getInitialWorkset() - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase
-
Returns the initial workset input, or null, if none is set.
- getInput() - Method in class org.apache.flink.api.common.operators.GenericDataSinkBase
-
Returns this operator's input operator.
- getInput() - Method in class org.apache.flink.api.common.operators.SingleInputOperator
-
Returns the input operator or data source, or null, if none is set.
- getInputSplitAssigner(FileInputSplit[]) - Method in class org.apache.flink.api.common.io.FileInputFormat
-
- getInputSplitAssigner(GenericInputSplit[]) - Method in class org.apache.flink.api.common.io.GenericInputFormat
-
- getInputSplitAssigner(T[]) - Method in interface org.apache.flink.api.common.io.InputFormat
-
Gets the type of the input splits that are processed by this input format.
- getInputSplitAssigner(T[]) - Method in interface org.apache.flink.core.io.InputSplitSource
-
Returns the assigner for the input splits.
- getInputSplits() - Method in class org.apache.flink.api.common.io.BinaryInputFormat
-
- getInputType() - Method in class org.apache.flink.api.common.operators.UnaryOperatorInformation
-
- getInstance() - Static method in class org.apache.flink.types.NullValue
-
Returns the NullValue singleton instance.
- getInt(int) - Method in class org.apache.flink.core.memory.MemorySegment
-
Reads an int value (32bit, 4 bytes) from the given position, in the system's native byte order.
- getIntBigEndian(int) - Method in class org.apache.flink.core.memory.MemorySegment
-
Reads an int value (32bit, 4 bytes) from the given position, in big endian byte order.
- getIntCounter(String) - Method in interface org.apache.flink.api.common.functions.RuntimeContext
-
Convenience function to create a counter object for integers.
- getIntCounter(String) - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
-
- getIntCounterResult(String) - Method in class org.apache.flink.api.common.JobExecutionResult
-
- getInteger(String, int) - Method in class org.apache.flink.configuration.Configuration
-
Returns the value associated with the given key as an integer.
- getInteger(String, int) - Static method in class org.apache.flink.configuration.GlobalConfiguration
-
Returns the value associated with the given key as an integer.
- getIntLittleEndian(int) - Method in class org.apache.flink.core.memory.MemorySegment
-
Reads an int value (32bit, 4 bytes) from the given position, in little endian byte order.
- getInvolvedIndexes() - Method in class org.apache.flink.api.common.operators.Ordering
-
- getIterationAggregator(String) - Method in interface org.apache.flink.api.common.functions.IterationRuntimeContext
-
- getIterationRuntimeContext() - Method in class org.apache.flink.api.common.functions.AbstractRichFunction
-
- getJobName() - Method in class org.apache.flink.api.common.Plan
-
Gets the name of this job.
- getJoinHint() - Method in class org.apache.flink.api.common.operators.base.JoinOperatorBase
-
- getKey(String, int, List<CompositeType.FlatFieldDescriptor>) - Method in class org.apache.flink.api.common.typeutils.CompositeType
-
Returns the keyPosition for the given fieldPosition, offsetted by the given offset
- getKeyClasses() - Method in interface org.apache.flink.api.common.operators.RecordOperator
-
Gets the key classes that this operator works on.
- getKeyColumns(int) - Method in class org.apache.flink.api.common.operators.AbstractUdfOperator
-
Gets the column numbers of the key fields in the input records for the given input.
- getKeyColumns(int) - Method in class org.apache.flink.api.common.operators.DualInputOperator
-
- getKeyColumns(int) - Method in class org.apache.flink.api.common.operators.SingleInputOperator
-
- getKeyPositions() - Method in class org.apache.flink.api.common.typeutils.record.RecordComparator
-
- getKeysAsCopy(Record) - Method in class org.apache.flink.api.common.typeutils.record.RecordComparator
-
- getKeyTypes() - Method in class org.apache.flink.api.common.typeutils.record.RecordComparator
-
- getLastModificationTime() - Method in class org.apache.flink.api.common.io.FileInputFormat.FileBaseStatistics
-
Gets the timestamp of the last modification.
- getLastResult() - Method in class org.apache.flink.types.parser.ByteParser
-
- getLastResult() - Method in class org.apache.flink.types.parser.ByteValueParser
-
- getLastResult() - Method in class org.apache.flink.types.parser.DoubleParser
-
- getLastResult() - Method in class org.apache.flink.types.parser.DoubleValueParser
-
- getLastResult() - Method in class org.apache.flink.types.parser.FieldParser
-
Gets the parsed field.
- getLastResult() - Method in class org.apache.flink.types.parser.FloatParser
-
- getLastResult() - Method in class org.apache.flink.types.parser.FloatValueParser
-
- getLastResult() - Method in class org.apache.flink.types.parser.IntParser
-
- getLastResult() - Method in class org.apache.flink.types.parser.IntValueParser
-
- getLastResult() - Method in class org.apache.flink.types.parser.LongParser
-
- getLastResult() - Method in class org.apache.flink.types.parser.LongValueParser
-
- getLastResult() - Method in class org.apache.flink.types.parser.ShortParser
-
- getLastResult() - Method in class org.apache.flink.types.parser.ShortValueParser
-
- getLastResult() - Method in class org.apache.flink.types.parser.StringParser
-
- getLastResult() - Method in class org.apache.flink.types.parser.StringValueParser
-
- getLen() - Method in interface org.apache.flink.core.fs.FileStatus
-
Return the length of this file
- getLen() - Method in class org.apache.flink.core.fs.local.LocalFileStatus
-
- getLength() - Method in class org.apache.flink.api.common.typeutils.base.array.BooleanPrimitiveArraySerializer
-
- getLength() - Method in class org.apache.flink.api.common.typeutils.base.array.BytePrimitiveArraySerializer
-
- getLength() - Method in class org.apache.flink.api.common.typeutils.base.array.CharPrimitiveArraySerializer
-
- getLength() - Method in class org.apache.flink.api.common.typeutils.base.array.DoublePrimitiveArraySerializer
-
- getLength() - Method in class org.apache.flink.api.common.typeutils.base.array.FloatPrimitiveArraySerializer
-
- getLength() - Method in class org.apache.flink.api.common.typeutils.base.array.IntPrimitiveArraySerializer
-
- getLength() - Method in class org.apache.flink.api.common.typeutils.base.array.LongPrimitiveArraySerializer
-
- getLength() - Method in class org.apache.flink.api.common.typeutils.base.array.ShortPrimitiveArraySerializer
-
- getLength() - Method in class org.apache.flink.api.common.typeutils.base.array.StringArraySerializer
-
- getLength() - Method in class org.apache.flink.api.common.typeutils.base.BooleanSerializer
-
- getLength() - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueSerializer
-
- getLength() - Method in class org.apache.flink.api.common.typeutils.base.ByteSerializer
-
- getLength() - Method in class org.apache.flink.api.common.typeutils.base.ByteValueSerializer
-
- getLength() - Method in class org.apache.flink.api.common.typeutils.base.CharSerializer
-
- getLength() - Method in class org.apache.flink.api.common.typeutils.base.CharValueSerializer
-
- getLength() - Method in class org.apache.flink.api.common.typeutils.base.DateSerializer
-
- getLength() - Method in class org.apache.flink.api.common.typeutils.base.DoubleSerializer
-
- getLength() - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueSerializer
-
- getLength() - Method in class org.apache.flink.api.common.typeutils.base.EnumSerializer
-
- getLength() - Method in class org.apache.flink.api.common.typeutils.base.FloatSerializer
-
- getLength() - Method in class org.apache.flink.api.common.typeutils.base.FloatValueSerializer
-
- getLength() - Method in class org.apache.flink.api.common.typeutils.base.GenericArraySerializer
-
- getLength() - Method in class org.apache.flink.api.common.typeutils.base.IntSerializer
-
- getLength() - Method in class org.apache.flink.api.common.typeutils.base.IntValueSerializer
-
- getLength() - Method in class org.apache.flink.api.common.typeutils.base.LongSerializer
-
- getLength() - Method in class org.apache.flink.api.common.typeutils.base.LongValueSerializer
-
- getLength() - Method in class org.apache.flink.api.common.typeutils.base.ShortSerializer
-
- getLength() - Method in class org.apache.flink.api.common.typeutils.base.ShortValueSerializer
-
- getLength() - Method in class org.apache.flink.api.common.typeutils.base.StringSerializer
-
- getLength() - Method in class org.apache.flink.api.common.typeutils.base.StringValueSerializer
-
- getLength() - Method in class org.apache.flink.api.common.typeutils.base.VoidSerializer
-
- getLength() - Method in class org.apache.flink.api.common.typeutils.record.RecordSerializer
-
- getLength() - Method in class org.apache.flink.api.common.typeutils.TypeSerializer
-
Gets the length of the data type, if it is a fix length data type.
- getLength() - Method in interface org.apache.flink.core.fs.BlockLocation
-
Get the length of the block.
- getLength() - Method in class org.apache.flink.core.fs.FileInputSplit
-
Returns the number of bytes in the file to process.
- getLength() - Method in class org.apache.flink.core.fs.local.LocalBlockLocation
-
- getLength() - Method in class org.apache.flink.core.io.StringRecord
-
Returns the number of bytes in the byte array
- getLineLengthLimit() - Method in class org.apache.flink.api.common.io.DelimitedInputFormat
-
- getLocalFileSystem() - Static method in class org.apache.flink.core.fs.FileSystem
-
Returns a reference to the
FileSystem
instance for accessing the
local file system.
- getLocalOrder() - Method in class org.apache.flink.api.common.operators.GenericDataSinkBase
-
Gets the order, in which the data sink writes its data locally.
- getLocalValue() - Method in interface org.apache.flink.api.common.accumulators.Accumulator
-
- getLocalValue() - Method in class org.apache.flink.api.common.accumulators.DoubleCounter
-
- getLocalValue() - Method in class org.apache.flink.api.common.accumulators.Histogram
-
- getLocalValue() - Method in class org.apache.flink.api.common.accumulators.IntCounter
-
- getLocalValue() - Method in class org.apache.flink.api.common.accumulators.LongCounter
-
- getLong(String, long) - Method in class org.apache.flink.configuration.Configuration
-
Returns the value associated with the given key as a long.
- getLong(String, long) - Static method in class org.apache.flink.configuration.GlobalConfiguration
-
Returns the value associated with the given key as a long integer.
- getLong(int) - Method in class org.apache.flink.core.memory.MemorySegment
-
Reads a long value (64bit, 8 bytes) from the given position, in the system's native byte order.
- getLongBigEndian(int) - Method in class org.apache.flink.core.memory.MemorySegment
-
Reads a long integer value (64bit, 8 bytes) from the given position, in big endian byte order.
- getLongCounter(String) - Method in interface org.apache.flink.api.common.functions.RuntimeContext
-
Convenience function to create a counter object for longs.
- getLongCounter(String) - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
-
- getLongLittleEndian(int) - Method in class org.apache.flink.core.memory.MemorySegment
-
Reads a long integer value (64bit, 8 bytes) from the given position, in little endian byte order.
- getMaximumNumberOfIterations() - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase
-
- getMaximumNumberOfIterations() - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase
-
- getMaximumNumberOfSplits() - Method in class org.apache.flink.util.NumberSequenceIterator
-
- getMaximumNumberOfSplits() - Method in interface org.apache.flink.util.SplittableIterator
-
- getMaximumParallelism() - Method in class org.apache.flink.api.common.Plan
-
- getMaxNormalizedKeyLen() - Method in class org.apache.flink.types.BooleanValue
-
- getMaxNormalizedKeyLen() - Method in class org.apache.flink.types.ByteValue
-
- getMaxNormalizedKeyLen() - Method in class org.apache.flink.types.CharValue
-
- getMaxNormalizedKeyLen() - Method in class org.apache.flink.types.IntValue
-
- getMaxNormalizedKeyLen() - Method in class org.apache.flink.types.LongValue
-
- getMaxNormalizedKeyLen() - Method in interface org.apache.flink.types.NormalizableKey
-
Gets the maximal length of normalized keys that the data type would produce to determine
the order of instances solely by the normalized key.
- getMaxNormalizedKeyLen() - Method in class org.apache.flink.types.NullValue
-
- getMaxNormalizedKeyLen() - Method in class org.apache.flink.types.ShortValue
-
- getMaxNormalizedKeyLen() - Method in class org.apache.flink.types.StringValue
-
- getMinSplitSize() - Method in class org.apache.flink.api.common.io.FileInputFormat
-
- getModificationTime() - Method in interface org.apache.flink.core.fs.FileStatus
-
Get the modification time of the file.
- getModificationTime() - Method in class org.apache.flink.core.fs.local.LocalFileStatus
-
- getName() - Method in class org.apache.flink.api.common.aggregators.AggregatorWithName
-
Gets the name that the aggregator is registered under.
- getName() - Method in class org.apache.flink.api.common.operators.Operator
-
Gets the name of the contract instance.
- getName() - Method in class org.apache.flink.core.fs.Path
-
Returns the final component of this path.
- getNetRuntime() - Method in class org.apache.flink.api.common.JobExecutionResult
-
- getNewComparator() - Method in class org.apache.flink.api.common.typeutils.CompositeType
-
Get the actual comparator we've initialized.
- getNextInputSplit(String) - Method in class org.apache.flink.api.common.io.DefaultInputSplitAssigner
-
- getNextInputSplit(String) - Method in class org.apache.flink.api.common.io.LocatableInputSplitAssigner
-
- getNextInputSplit(String) - Method in interface org.apache.flink.core.io.InputSplitAssigner
-
Returns the next input split that shall be consumed.
- getNextPartialSolution() - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase
-
- getNextWorkset() - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase
-
Gets the contract that has been set as the next workset.
- getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.BooleanComparator
-
- getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.ByteComparator
-
- getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.CharComparator
-
- getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.DateComparator
-
- getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.DoubleComparator
-
- getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.EnumComparator
-
- getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.FloatComparator
-
- getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.IntComparator
-
- getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.LongComparator
-
- getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.ShortComparator
-
- getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.StringComparator
-
- getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.record.RecordComparator
-
- getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.TypeComparator
-
Gets the number of bytes that the normalized key would maximally take.
- getNumberOfBlocks(FileStatus) - Method in class org.apache.flink.core.fs.FileSystem
-
Returns the number of blocks this file/directory consists of
assuming the file system's standard block size.
- getNumberOfExecutionRetries() - Method in class org.apache.flink.api.common.ExecutionConfig
-
Gets the number of times the system will try to re-execute failed tasks.
- getNumberOfExecutionRetries() - Method in class org.apache.flink.api.common.Plan
-
Gets the number of times the system will try to re-execute failed tasks.
- getNumberOfFields() - Method in interface org.apache.flink.api.common.distributions.DataDistribution
-
The number of fields in the (composite) key.
- getNumberOfFields() - Method in class org.apache.flink.api.common.distributions.SimpleDistribution
-
- getNumberOfFields() - Method in class org.apache.flink.api.common.distributions.SimpleIntegerDistribution
-
- getNumberOfFields() - Method in class org.apache.flink.api.common.distributions.UniformDoubleDistribution
-
- getNumberOfFields() - Method in class org.apache.flink.api.common.distributions.UniformIntegerDistribution
-
- getNumberOfFields() - Method in class org.apache.flink.api.common.operators.Ordering
-
- getNumberOfFieldsTotal() - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
-
- getNumberOfInputs() - Method in class org.apache.flink.api.common.operators.AbstractUdfOperator
-
Gets the number of inputs for this operator.
- getNumberOfInputs() - Method in class org.apache.flink.api.common.operators.DualInputOperator
-
- getNumberOfInputs() - Method in class org.apache.flink.api.common.operators.SingleInputOperator
-
- getNumberOfLocalAssignments() - Method in class org.apache.flink.api.common.io.LocatableInputSplitAssigner
-
- getNumberOfNonNullFields() - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
-
- getNumberOfParallelSubtasks() - Method in interface org.apache.flink.api.common.functions.RuntimeContext
-
Gets the degree of parallelism with which the parallel task runs.
- getNumberOfParallelSubtasks() - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
-
- getNumberOfRecords() - Method in class org.apache.flink.api.common.io.FileInputFormat.FileBaseStatistics
-
Gets the estimates number of records in the file, computed as the file size divided by the
average record width, rounded up.
- getNumberOfRecords() - Method in interface org.apache.flink.api.common.io.statistics.BaseStatistics
-
Gets the number of records in the input (= base cardinality).
- getNumberOfRemoteAssignments() - Method in class org.apache.flink.api.common.io.LocatableInputSplitAssigner
-
- getNumFields() - Method in class org.apache.flink.types.Record
-
Gets the number of fields currently in the record.
- getNumInputs(Class<? extends Operator<?>>) - Static method in class org.apache.flink.api.common.operators.util.OperatorUtil
-
Returns the number of inputs for the given
Operator
type.
Currently, it can be 0, 1, or 2.
- getNumLineSamples() - Method in class org.apache.flink.api.common.io.DelimitedInputFormat
-
- getNumSplits() - Method in class org.apache.flink.api.common.io.FileInputFormat
-
- getOffset() - Method in interface org.apache.flink.core.fs.BlockLocation
-
Get the start offset of the file associated with this block.
- getOffset() - Method in class org.apache.flink.core.fs.local.LocalBlockLocation
-
- getOpenTimeout() - Method in class org.apache.flink.api.common.io.FileInputFormat
-
- getOperatorInfo() - Method in class org.apache.flink.api.common.operators.DualInputOperator
-
Gets the information about the operators input/output types.
- getOperatorInfo() - Method in class org.apache.flink.api.common.operators.Operator
-
Gets the information about the operators input/output types.
- getOperatorInfo() - Method in class org.apache.flink.api.common.operators.SingleInputOperator
-
Gets the information about the operators input/output types.
- getOptimizerPlanAsJSON(Plan) - Method in class org.apache.flink.api.common.PlanExecutor
-
Gets the programs execution plan in a JSON format.
- getOrder(int) - Method in class org.apache.flink.api.common.operators.Ordering
-
- getOutputCardinality() - Method in class org.apache.flink.api.common.operators.CompilerHints
-
- getOutputDirectoryMode() - Method in class org.apache.flink.api.common.io.FileOutputFormat
-
- getOutputFilePath() - Method in class org.apache.flink.api.common.io.FileOutputFormat
-
- getOutputSize() - Method in class org.apache.flink.api.common.operators.CompilerHints
-
- getOutputType() - Method in class org.apache.flink.api.common.operators.OperatorInformation
-
Gets the return type of the user code function.
- getParameters() - Method in class org.apache.flink.api.common.operators.Operator
-
Gets the stub parameters of this contract.
- getParent() - Method in class org.apache.flink.core.fs.Path
-
Returns the parent of a path or null
if at root.
- getParserForType(Class<T>) - Static method in class org.apache.flink.types.parser.FieldParser
-
Gets the parser for the type specified by the given class.
- getPartialSolution() - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase
-
- getPartitionMethod() - Method in class org.apache.flink.api.common.operators.base.PartitionOperatorBase
-
- getPartitionOrdering() - Method in class org.apache.flink.api.common.operators.GenericDataSinkBase
-
Gets the record ordering over which the sink partitions in ranges.
- getPath() - Method in class org.apache.flink.core.fs.FileInputSplit
-
Returns the path of the file containing this split's data.
- getPath() - Method in interface org.apache.flink.core.fs.FileStatus
-
Returns the corresponding Path to the FileStatus.
- getPath() - Method in class org.apache.flink.core.fs.local.LocalFileStatus
-
- getPlan(String...) - Method in interface org.apache.flink.api.common.Program
-
The method which is invoked by the compiler to get the job that is then compiled into an
executable schedule.
- getPosition() - Method in class org.apache.flink.api.common.typeutils.CompositeType.FlatFieldDescriptor
-
- getPostPassClassName() - Method in class org.apache.flink.api.common.Plan
-
Gets the optimizer post-pass class for this job.
- getPreviousIterationAggregate(String) - Method in interface org.apache.flink.api.common.functions.IterationRuntimeContext
-
- getProtocolByName(String) - Static method in class org.apache.flink.util.ClassUtils
-
Searches for a protocol class by its name and attempts to load it.
- getRandomString(Random, int, int) - Static method in class org.apache.flink.util.StringUtils
-
Creates a random string with a length within the given interval.
- getRandomString(Random, int, int, char, char) - Static method in class org.apache.flink.util.StringUtils
-
Creates a random string with a length within the given interval.
- getReadFields() - Method in class org.apache.flink.api.common.operators.SingleInputSemanticProperties.AllFieldsConstantProperties
-
- getReadFields() - Method in class org.apache.flink.api.common.operators.SingleInputSemanticProperties
-
Gets the field(s) in the source record(s) that are read.
- getReadFields1() - Method in class org.apache.flink.api.common.operators.DualInputSemanticProperties
-
Gets the field(s) in the source record(s) from the first input
that are read.
- getReadFields2() - Method in class org.apache.flink.api.common.operators.DualInputSemanticProperties
-
Gets the field(s) in the source record(s) from the second input
that are read.
- getRecordByName(String) - Static method in class org.apache.flink.util.ClassUtils
-
Searches for a record class by its name and attempts to load it.
- getRecordCount() - Method in class org.apache.flink.api.common.io.BlockInfo
-
Returns the recordCount.
- getReplication() - Method in interface org.apache.flink.core.fs.FileStatus
-
Get the replication factor of a file.
- getReplication() - Method in class org.apache.flink.core.fs.local.LocalFileStatus
-
- getResultsFormated(Map<String, Object>) - Static method in class org.apache.flink.api.common.accumulators.AccumulatorHelper
-
- getRuntimeContext() - Method in class org.apache.flink.api.common.functions.AbstractRichFunction
-
- getRuntimeContext() - Method in interface org.apache.flink.api.common.functions.RichFunction
-
Gets the context that contains information about the UDF's runtime.
- getSecond() - Method in class org.apache.flink.types.Pair
-
Returns the second encapsulated pair element.
- getSecondInput() - Method in class org.apache.flink.api.common.operators.DualInputOperator
-
Returns the second input, or null, if none is set.
- getSecondInputType() - Method in class org.apache.flink.api.common.operators.BinaryOperatorInformation
-
- getSemanticProperties() - Method in class org.apache.flink.api.common.operators.base.PartitionOperatorBase
-
- getSemanticProperties() - Method in class org.apache.flink.api.common.operators.DualInputOperator
-
- getSemanticProperties() - Method in class org.apache.flink.api.common.operators.SingleInputOperator
-
- getSerializer() - Method in class org.apache.flink.api.common.typeutils.record.RecordSerializerFactory
-
- getSerializer() - Method in interface org.apache.flink.api.common.typeutils.TypeSerializerFactory
-
- getShort(int) - Method in class org.apache.flink.core.memory.MemorySegment
-
Reads two memory at the given position, composing them into a short value
according to the current byte order.
- getShortName() - Method in enum org.apache.flink.api.common.operators.Order
-
- getSolutionSet() - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase
-
Gets the contract that represents the solution set for the step function.
- getSolutionSetDelta() - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase
-
Gets the contract that has been set as the solution set delta.
- getSolutionSetKeyFields() - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase
-
- getSplit(int, int) - Method in class org.apache.flink.util.NumberSequenceIterator
-
- getSplit(int, int) - Method in interface org.apache.flink.util.SplittableIterator
-
- getSplitLength() - Method in class org.apache.flink.api.common.io.FileInputFormat
-
Gets the length or remaining length of the current split.
- getSplitNumber() - Method in class org.apache.flink.core.io.GenericInputSplit
-
- getSplitNumber() - Method in interface org.apache.flink.core.io.InputSplit
-
Returns the number of this input split.
- getSplitNumber() - Method in class org.apache.flink.core.io.LocatableInputSplit
-
- getSplitStart() - Method in class org.apache.flink.api.common.io.FileInputFormat
-
Gets the start of the current split.
- getStart() - Method in class org.apache.flink.core.fs.FileInputSplit
-
Returns the position of the first byte in the file to process.
- getStatistics(BaseStatistics) - Method in class org.apache.flink.api.common.io.BinaryInputFormat
-
- getStatistics(BaseStatistics) - Method in class org.apache.flink.api.common.io.DelimitedInputFormat
-
- getStatistics(BaseStatistics) - Method in class org.apache.flink.api.common.io.FileInputFormat
-
Obtains basic file statistics containing only file size.
- getStatistics(BaseStatistics) - Method in class org.apache.flink.api.common.io.GenericInputFormat
-
- getStatistics(BaseStatistics) - Method in interface org.apache.flink.api.common.io.InputFormat
-
Gets the basic statistics from the input described by this format.
- getStatisticsKey() - Method in class org.apache.flink.api.common.operators.GenericDataSourceBase
-
Gets the key under which statistics about this data source may be obtained from the
statistics cache.
- getString(String, String) - Method in class org.apache.flink.configuration.Configuration
-
Returns the value associated with the given key as a string.
- getString(String, String) - Static method in class org.apache.flink.configuration.GlobalConfiguration
-
Returns the value associated with the given key as a string.
- getSuperstepNumber() - Method in interface org.apache.flink.api.common.functions.IterationRuntimeContext
-
Gets the number of the current superstep.
- getSuperTemplateTypes(Class<?>) - Static method in class org.apache.flink.util.ReflectionUtil
-
- getSuperTemplateTypes(Class<?>, Class<?>) - Static method in class org.apache.flink.util.ReflectionUtil
-
- getTaskName() - Method in interface org.apache.flink.api.common.functions.RuntimeContext
-
Returns the name of the task in which the UDF runs, as assigned during plan construction.
- getTaskName() - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
-
- getTemplateType(Class<?>, int) - Static method in class org.apache.flink.util.ReflectionUtil
-
- getTemplateType(Class<?>, Class<?>, int) - Static method in class org.apache.flink.util.ReflectionUtil
-
- getTemplateType1(Class<?>) - Static method in class org.apache.flink.util.ReflectionUtil
-
- getTemplateType2(Class<?>) - Static method in class org.apache.flink.util.ReflectionUtil
-
- getTemplateType3(Class<?>) - Static method in class org.apache.flink.util.ReflectionUtil
-
- getTemplateType4(Class<?>) - Static method in class org.apache.flink.util.ReflectionUtil
-
- getTemplateType5(Class<?>) - Static method in class org.apache.flink.util.ReflectionUtil
-
- getTemplateType6(Class<?>) - Static method in class org.apache.flink.util.ReflectionUtil
-
- getTemplateType7(Class<?>) - Static method in class org.apache.flink.util.ReflectionUtil
-
- getTemplateType8(Class<?>) - Static method in class org.apache.flink.util.ReflectionUtil
-
- getTemplateTypes(ParameterizedType) - Static method in class org.apache.flink.util.ReflectionUtil
-
- getTemplateTypes(Class<?>) - Static method in class org.apache.flink.util.ReflectionUtil
-
- getTerminationCriterion() - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase
-
- getTo() - Method in class org.apache.flink.util.NumberSequenceIterator
-
- getTotalFields() - Method in class org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
-
- getTotalFields() - Method in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
-
- getTotalFields() - Method in class org.apache.flink.api.common.typeinfo.NothingTypeInfo
-
- getTotalFields() - Method in class org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
-
- getTotalFields() - Method in class org.apache.flink.api.common.typeinfo.TypeInformation
-
- getTotalInputSize() - Method in class org.apache.flink.api.common.io.FileInputFormat.FileBaseStatistics
-
Gets the file size.
- getTotalInputSize() - Method in interface org.apache.flink.api.common.io.statistics.BaseStatistics
-
Gets the total size of the input.
- getTotalNumberOfSplits() - Method in class org.apache.flink.core.io.GenericInputSplit
-
- getType(int) - Method in class org.apache.flink.api.common.operators.Ordering
-
- getType() - Method in class org.apache.flink.api.common.typeutils.CompositeType.FlatFieldDescriptor
-
- getTypeAt(int) - Method in class org.apache.flink.api.common.typeutils.CompositeType
-
- getTypeClass() - Method in class org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
-
- getTypeClass() - Method in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
-
- getTypeClass() - Method in class org.apache.flink.api.common.typeinfo.NothingTypeInfo
-
- getTypeClass() - Method in class org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
-
- getTypeClass() - Method in class org.apache.flink.api.common.typeinfo.TypeInformation
-
- getTypes() - Method in class org.apache.flink.api.common.operators.Ordering
-
- getUniqueFields() - Method in class org.apache.flink.api.common.operators.CompilerHints
-
Gets the FieldSets that are unique
- getUri() - Method in class org.apache.flink.core.fs.FileSystem
-
Returns a URI whose scheme and authority identify this file system.
- getUri() - Method in class org.apache.flink.core.fs.local.LocalFileSystem
-
- getUserCodeAnnotation(Class<A>) - Method in class org.apache.flink.api.common.operators.util.UserCodeClassWrapper
-
- getUserCodeAnnotation(Class<A>) - Method in class org.apache.flink.api.common.operators.util.UserCodeObjectWrapper
-
- getUserCodeAnnotation(Class<A>) - Method in interface org.apache.flink.api.common.operators.util.UserCodeWrapper
-
Gets an annotation that pertains to the user code class.
- getUserCodeClass() - Method in class org.apache.flink.api.common.operators.util.UserCodeClassWrapper
-
- getUserCodeClass() - Method in class org.apache.flink.api.common.operators.util.UserCodeObjectWrapper
-
- getUserCodeClass() - Method in interface org.apache.flink.api.common.operators.util.UserCodeWrapper
-
Gets the class of the user code.
- getUserCodeClassLoader() - Method in interface org.apache.flink.api.common.functions.RuntimeContext
-
Gets the ClassLoader to load classes that were are not in system's classpath, but are part of the
jar file of a user job.
- getUserCodeClassLoader() - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
-
- getUserCodeObject(Class<? super T>, ClassLoader) - Method in class org.apache.flink.api.common.operators.util.UserCodeClassWrapper
-
- getUserCodeObject() - Method in class org.apache.flink.api.common.operators.util.UserCodeClassWrapper
-
- getUserCodeObject(Class<? super T>, ClassLoader) - Method in class org.apache.flink.api.common.operators.util.UserCodeObjectWrapper
-
- getUserCodeObject() - Method in class org.apache.flink.api.common.operators.util.UserCodeObjectWrapper
-
- getUserCodeObject(Class<? super T>, ClassLoader) - Method in interface org.apache.flink.api.common.operators.util.UserCodeWrapper
-
Gets the user code object, which may be either a function or an input or output format.
- getUserCodeObject() - Method in interface org.apache.flink.api.common.operators.util.UserCodeWrapper
-
Gets the user code object.
- getUserCodeWrapper() - Method in class org.apache.flink.api.common.operators.AbstractUdfOperator
-
Gets the function that is held by this operator.
- getUserCodeWrapper() - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase.PartialSolutionPlaceHolder
-
- getUserCodeWrapper() - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase.SolutionSetPlaceHolder
-
- getUserCodeWrapper() - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase.WorksetPlaceHolder
-
- getUserCodeWrapper() - Method in class org.apache.flink.api.common.operators.GenericDataSinkBase
-
Gets the class describing the output format.
- getUserCodeWrapper() - Method in class org.apache.flink.api.common.operators.GenericDataSourceBase
-
Gets the class describing the input format.
- getUserCodeWrapper() - Method in class org.apache.flink.api.common.operators.Operator
-
Gets the user code wrapper.
- getValue() - Method in class org.apache.flink.types.BooleanValue
-
- getValue() - Method in class org.apache.flink.types.ByteValue
-
Returns the value of the encapsulated byte.
- getValue() - Method in class org.apache.flink.types.CharValue
-
Returns the value of the encapsulated char.
- getValue() - Method in class org.apache.flink.types.DoubleValue
-
Returns the value of the encapsulated primitive double.
- getValue() - Method in class org.apache.flink.types.FloatValue
-
Returns the value of the encapsulated primitive float.
- getValue() - Method in class org.apache.flink.types.IntValue
-
Returns the value of the encapsulated int.
- getValue() - Method in class org.apache.flink.types.LongValue
-
Returns the value of the encapsulated long.
- getValue() - Method in class org.apache.flink.types.ShortValue
-
Returns the value of the encapsulated short.
- getValue() - Method in class org.apache.flink.types.StringValue
-
Gets this StringValue as a String.
- getValues() - Method in class org.apache.flink.api.common.operators.util.ListKeyGroupedIterator
-
Returns an iterator over all values that belong to the current key.
- getWorkingDirectory() - Method in class org.apache.flink.core.fs.FileSystem
-
Returns the path of the file system's current working directory.
- getWorkingDirectory() - Method in class org.apache.flink.core.fs.local.LocalFileSystem
-
- getWorkset() - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase
-
Gets the contract that represents the workset for the step function.
- getWriteMode() - Method in class org.apache.flink.api.common.io.FileOutputFormat
-
- getWrittenFields() - Method in class org.apache.flink.api.common.operators.SemanticProperties
-
Gets the field(s) in the destination record(s) that are written.
- getWrittenFields() - Method in class org.apache.flink.api.common.operators.SingleInputSemanticProperties.AllFieldsConstantProperties
-
- GlobalConfiguration - Class in org.apache.flink.configuration
-
Global configuration object for Flink.
- GroupReduceFunction<T,O> - Interface in org.apache.flink.api.common.functions
-
The interface for group reduce functions.
- GroupReduceOperatorBase<IN,OUT,FT extends GroupReduceFunction<IN,OUT>> - Class in org.apache.flink.api.common.operators.base
-
- GroupReduceOperatorBase(UserCodeWrapper<FT>, UnaryOperatorInformation<IN, OUT>, int[], String) - Constructor for class org.apache.flink.api.common.operators.base.GroupReduceOperatorBase
-
- GroupReduceOperatorBase(FT, UnaryOperatorInformation<IN, OUT>, int[], String) - Constructor for class org.apache.flink.api.common.operators.base.GroupReduceOperatorBase
-
- GroupReduceOperatorBase(Class<? extends FT>, UnaryOperatorInformation<IN, OUT>, int[], String) - Constructor for class org.apache.flink.api.common.operators.base.GroupReduceOperatorBase
-
- GroupReduceOperatorBase(UserCodeWrapper<FT>, UnaryOperatorInformation<IN, OUT>, String) - Constructor for class org.apache.flink.api.common.operators.base.GroupReduceOperatorBase
-
- GroupReduceOperatorBase(FT, UnaryOperatorInformation<IN, OUT>, String) - Constructor for class org.apache.flink.api.common.operators.base.GroupReduceOperatorBase
-
- GroupReduceOperatorBase(Class<? extends FT>, UnaryOperatorInformation<IN, OUT>, String) - Constructor for class org.apache.flink.api.common.operators.base.GroupReduceOperatorBase
-
- groupsFields(FieldSet) - Method in class org.apache.flink.api.common.operators.Ordering
-
- IllegalConfigurationException - Exception in org.apache.flink.configuration
-
An IllegalConfigurationException
is thrown when the user
has configured job vertices in a way that either conflicts
with the expected usage of the respective task of the configuration
of the Nephele framework.
- IllegalConfigurationException(String) - Constructor for exception org.apache.flink.configuration.IllegalConfigurationException
-
Constructs an new illegal configuration exception with the given error message.
- IllegalConfigurationException(String, Throwable) - Constructor for exception org.apache.flink.configuration.IllegalConfigurationException
-
Constructs an new illegal configuration exception with the given error message
and a given cause.
- includeConfiguration(Configuration) - Static method in class org.apache.flink.configuration.GlobalConfiguration
-
Merges the given
Configuration
object into the global
configuration.
- indexes - Variable in class org.apache.flink.api.common.operators.Ordering
-
- indexOf(Object) - Method in class org.apache.flink.types.ListValue
-
- InflaterInputStreamFSInputWrapper - Class in org.apache.flink.api.common.io
-
- InflaterInputStreamFSInputWrapper(FSDataInputStream) - Constructor for class org.apache.flink.api.common.io.InflaterInputStreamFSInputWrapper
-
- initialize(URI) - Method in class org.apache.flink.core.fs.FileSystem
-
Called after a new FileSystem instance is constructed.
- initialize(URI) - Method in class org.apache.flink.core.fs.local.LocalFileSystem
-
- initializeBroadcastVariable(Iterable<T>) - Method in interface org.apache.flink.api.common.functions.BroadcastVariableInitializer
-
- initializeGlobal(int) - Method in class org.apache.flink.api.common.io.FileOutputFormat
-
Initialization of the distributed file system if it is used.
- initializeGlobal(int) - Method in interface org.apache.flink.api.common.io.InitializeOnMaster
-
The method is invoked on the master (JobManager) before the distributed program execution starts.
- initializeNewComparator(int) - Method in class org.apache.flink.api.common.typeutils.CompositeType
-
Initializes the internal state inside a Composite type to create a new comparator
(such as the lists / arrays for the fields and field comparators)
- InitializeOnMaster - Interface in org.apache.flink.api.common.io
-
This interface may be implemented by
OutputFormat
s to have the master initialize them globally.
- initOutPathDistFS(Path, FileSystem.WriteMode, boolean) - Method in class org.apache.flink.core.fs.FileSystem
-
Initializes output directories on distributed file systems according to the given write mode.
- initOutPathLocalFS(Path, FileSystem.WriteMode, boolean) - Method in class org.apache.flink.core.fs.FileSystem
-
Initializes output directories on local file systems according to the given write mode.
- input - Variable in class org.apache.flink.api.common.operators.GenericDataSinkBase
-
- input - Variable in class org.apache.flink.api.common.operators.SingleInputOperator
-
The input which produces the data consumed by this operator.
- input1 - Variable in class org.apache.flink.api.common.operators.DualInputOperator
-
The operator producing the first input.
- input2 - Variable in class org.apache.flink.api.common.operators.DualInputOperator
-
The operator producing the second input.
- InputFormat<OT,T extends InputSplit> - Interface in org.apache.flink.api.common.io
-
The base interface for data sources that produces records.
- InputSplit - Interface in org.apache.flink.core.io
-
This interface must be implemented by all kind of input splits that can be assigned to input formats.
- InputSplitAssigner - Interface in org.apache.flink.core.io
-
An input split assigner distributes the
InputSplit
s among the instances on which a
data source exists.
- InputSplitOpenThread(FileInputSplit, long) - Constructor for class org.apache.flink.api.common.io.FileInputFormat.InputSplitOpenThread
-
- InputSplitSource<T extends InputSplit> - Interface in org.apache.flink.core.io
-
- inputType - Variable in class org.apache.flink.api.common.operators.UnaryOperatorInformation
-
Input Type of the operator
- inputType1 - Variable in class org.apache.flink.api.common.operators.BinaryOperatorInformation
-
Input type of the first input
- inputType2 - Variable in class org.apache.flink.api.common.operators.BinaryOperatorInformation
-
Input type of the second input
- InputViewDataInputStreamWrapper - Class in org.apache.flink.core.memory
-
- InputViewDataInputStreamWrapper(DataInputStream) - Constructor for class org.apache.flink.core.memory.InputViewDataInputStreamWrapper
-
- InputViewObjectInputStreamWrapper - Class in org.apache.flink.core.memory
-
- InputViewObjectInputStreamWrapper(ObjectInputStream) - Constructor for class org.apache.flink.core.memory.InputViewObjectInputStreamWrapper
-
- insertOrReplace(BT) - Method in class org.apache.flink.api.common.operators.util.JoinHashMap
-
- INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.array.BooleanPrimitiveArraySerializer
-
- INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.array.BytePrimitiveArraySerializer
-
- INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.array.CharPrimitiveArraySerializer
-
- INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.array.DoublePrimitiveArraySerializer
-
- INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.array.FloatPrimitiveArraySerializer
-
- INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.array.IntPrimitiveArraySerializer
-
- INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.array.LongPrimitiveArraySerializer
-
- INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.array.ShortPrimitiveArraySerializer
-
- INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.array.StringArraySerializer
-
- INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.BooleanSerializer
-
- INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.BooleanValueSerializer
-
- INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.ByteSerializer
-
- INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.ByteValueSerializer
-
- INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.CharSerializer
-
- INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.CharValueSerializer
-
- INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.DateSerializer
-
- INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.DoubleSerializer
-
- INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.DoubleValueSerializer
-
- INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.FloatSerializer
-
- INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.FloatValueSerializer
-
- INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.IntSerializer
-
- INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.IntValueSerializer
-
- INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.LongSerializer
-
- INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.LongValueSerializer
-
- INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.ShortSerializer
-
- INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.ShortValueSerializer
-
- INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.StringSerializer
-
- INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.StringValueSerializer
-
- INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.VoidSerializer
-
- instantiate(Class<T>, Class<? super T>) - Static method in class org.apache.flink.util.InstantiationUtil
-
Creates a new instance of the given class.
- instantiate(Class<T>) - Static method in class org.apache.flink.util.InstantiationUtil
-
Creates a new instance of the given class.
- InstantiationUtil - Class in org.apache.flink.util
-
Utility class to create instances from class objects and checking failure reasons.
- INT_ARRAY_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
-
- INT_PRIMITIVE_ARRAY_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
-
- INT_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
-
- IntComparator - Class in org.apache.flink.api.common.typeutils.base
-
- IntComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.IntComparator
-
- IntCounter - Class in org.apache.flink.api.common.accumulators
-
- IntCounter() - Constructor for class org.apache.flink.api.common.accumulators.IntCounter
-
- IntParser - Class in org.apache.flink.types.parser
-
Parses a decimal text field into a IntValue.
- IntParser() - Constructor for class org.apache.flink.types.parser.IntParser
-
- IntPrimitiveArraySerializer - Class in org.apache.flink.api.common.typeutils.base.array
-
A serializer for int arrays.
- IntPrimitiveArraySerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.array.IntPrimitiveArraySerializer
-
- IntSerializer - Class in org.apache.flink.api.common.typeutils.base
-
- IntSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.IntSerializer
-
- IntValue - Class in org.apache.flink.types
-
Boxed serializable and comparable integer type, representing the primitive
type int
.
- IntValue() - Constructor for class org.apache.flink.types.IntValue
-
Initializes the encapsulated int with 0.
- IntValue(int) - Constructor for class org.apache.flink.types.IntValue
-
Initializes the encapsulated int with the provided value.
- IntValueParser - Class in org.apache.flink.types.parser
-
Parses a decimal text field into a IntValue.
- IntValueParser() - Constructor for class org.apache.flink.types.parser.IntValueParser
-
- IntValueSerializer - Class in org.apache.flink.api.common.typeutils.base
-
- IntValueSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.IntValueSerializer
-
- InvalidProgramException - Exception in org.apache.flink.api.common
-
An exception thrown to indicate that the composed program is invalid.
- InvalidProgramException() - Constructor for exception org.apache.flink.api.common.InvalidProgramException
-
Creates a new exception with no message.
- InvalidProgramException(String) - Constructor for exception org.apache.flink.api.common.InvalidProgramException
-
Creates a new exception with the given message.
- InvalidProgramException(String, Throwable) - Constructor for exception org.apache.flink.api.common.InvalidProgramException
-
- InvalidTypesException - Exception in org.apache.flink.api.common.functions
-
A special case of the
InvalidProgramException
, indicating that the types used in
an operation are invalid or inconsistent.
- InvalidTypesException() - Constructor for exception org.apache.flink.api.common.functions.InvalidTypesException
-
Creates a new exception with no message.
- InvalidTypesException(String) - Constructor for exception org.apache.flink.api.common.functions.InvalidTypesException
-
Creates a new exception with the given message.
- InvalidTypesException(String, Throwable) - Constructor for exception org.apache.flink.api.common.functions.InvalidTypesException
-
- invertNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.BasicTypeComparator
-
- invertNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.record.RecordComparator
-
- invertNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.TypeComparator
-
Flag whether normalized key comparisons should be inverted key should be interpreted
inverted, i.e.
- IOReadableWritable - Interface in org.apache.flink.core.io
-
This interface must be implemented by every class whose objects have to be serialized to their binary representation
and vice-versa.
- isAbsolute() - Method in class org.apache.flink.core.fs.Path
-
Checks if the directory of this path is absolute.
- isBasicType() - Method in class org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
-
- isBasicType() - Method in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
-
- isBasicType() - Method in class org.apache.flink.api.common.typeinfo.NothingTypeInfo
-
- isBasicType() - Method in class org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
-
- isBasicType() - Method in class org.apache.flink.api.common.typeinfo.TypeInformation
-
- isBoxedTypeOrString(Class<?>) - Static method in class org.apache.flink.util.ClassUtils
-
- isClosureCleanerEnabled() - Method in class org.apache.flink.api.common.ExecutionConfig
-
Returns whether the ClosureCleaner is enabled.
- isCombinable() - Method in class org.apache.flink.api.common.operators.base.GroupReduceOperatorBase
-
Checks whether the operation is combinable.
- isCombinableFirst() - Method in class org.apache.flink.api.common.operators.base.CoGroupOperatorBase
-
- isCombinableSecond() - Method in class org.apache.flink.api.common.operators.base.CoGroupOperatorBase
-
- isConverged(int, T) - Method in interface org.apache.flink.api.common.aggregators.ConvergenceCriterion
-
Decide whether the iterative algorithm has converged
- isConverged(int, DoubleValue) - Method in class org.apache.flink.api.common.aggregators.DoubleZeroConvergence
-
Returns true, if the aggregator value is zero, false otherwise.
- isConverged(int, LongValue) - Method in class org.apache.flink.api.common.aggregators.LongZeroConvergence
-
Returns true, if the aggregator value is zero, false otherwise.
- isConverged(int, LongValue) - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase.TerminationCriterionAggregationConvergence
-
- isDir() - Method in interface org.apache.flink.core.fs.FileStatus
-
Checks if this object represents a directory.
- isDir() - Method in class org.apache.flink.core.fs.local.LocalFileStatus
-
- isDistributedFS() - Method in class org.apache.flink.core.fs.FileSystem
-
Returns true if this is a distributed file system, false otherwise.
- isDistributedFS() - Method in class org.apache.flink.core.fs.local.LocalFileSystem
-
- isEmpty() - Method in class org.apache.flink.types.ListValue
-
- isEmpty() - Method in class org.apache.flink.types.MapValue
-
- isExecutable - Variable in class org.apache.flink.api.common.cache.DistributedCache.DistributedCacheEntry
-
- isFreeBSD() - Static method in enum org.apache.flink.util.OperatingSystem
-
Checks whether the operating system this JVM runs on is FreeBSD.
- isFreed() - Method in class org.apache.flink.core.memory.MemorySegment
-
Checks whether this memory segment has already been freed.
- isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.array.BooleanPrimitiveArraySerializer
-
- isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.array.BytePrimitiveArraySerializer
-
- isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.array.CharPrimitiveArraySerializer
-
- isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.array.DoublePrimitiveArraySerializer
-
- isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.array.FloatPrimitiveArraySerializer
-
- isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.array.IntPrimitiveArraySerializer
-
- isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.array.LongPrimitiveArraySerializer
-
- isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.array.ShortPrimitiveArraySerializer
-
- isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.array.StringArraySerializer
-
- isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.BooleanSerializer
-
- isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueSerializer
-
- isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.ByteSerializer
-
- isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.ByteValueSerializer
-
- isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.CharSerializer
-
- isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.CharValueSerializer
-
- isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.DateSerializer
-
- isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.DoubleSerializer
-
- isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueSerializer
-
- isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.EnumSerializer
-
- isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.FloatSerializer
-
- isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.FloatValueSerializer
-
- isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.GenericArraySerializer
-
- isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.IntSerializer
-
- isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.IntValueSerializer
-
- isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.LongSerializer
-
- isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.LongValueSerializer
-
- isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.ShortSerializer
-
- isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.ShortValueSerializer
-
- isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.StringSerializer
-
- isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.StringValueSerializer
-
- isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.VoidSerializer
-
- isImmutableType() - Method in class org.apache.flink.api.common.typeutils.record.RecordSerializer
-
- isImmutableType() - Method in class org.apache.flink.api.common.typeutils.TypeSerializer
-
Gets whether the type is an immutable type.
- isKeyType() - Method in class org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
-
- isKeyType() - Method in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
-
- isKeyType() - Method in class org.apache.flink.api.common.typeinfo.NothingTypeInfo
-
- isKeyType() - Method in class org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
-
- isKeyType() - Method in class org.apache.flink.api.common.typeinfo.TypeInformation
-
- isLenient() - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
-
- isLinux() - Static method in enum org.apache.flink.util.OperatingSystem
-
Checks whether the operating system this JVM runs on is Linux.
- isMac() - Static method in enum org.apache.flink.util.OperatingSystem
-
Checks whether the operating system this JVM runs on is Windows.
- isMetBy(Ordering) - Method in class org.apache.flink.api.common.operators.Ordering
-
- isNonStaticInnerClass(Class<?>) - Static method in class org.apache.flink.util.InstantiationUtil
-
Checks, whether the class is an inner class that is not statically accessible.
- isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.BooleanComparator
-
- isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.ByteComparator
-
- isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.CharComparator
-
- isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.DateComparator
-
- isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.DoubleComparator
-
- isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.EnumComparator
-
- isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.FloatComparator
-
- isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.IntComparator
-
- isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.LongComparator
-
- isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.ShortComparator
-
- isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.StringComparator
-
- isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.record.RecordComparator
-
- isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.TypeComparator
-
Checks, whether the given number of bytes for a normalized is only a prefix to determine the order of elements
of the data type for which this comparator provides the comparison methods.
- isNull(int) - Method in class org.apache.flink.types.Record
-
- isOrdered() - Method in enum org.apache.flink.api.common.operators.Order
-
Checks, if this enum constant represents in fact an order.
- isOrderEqualOnFirstNFields(Ordering, int) - Method in class org.apache.flink.api.common.operators.Ordering
-
- isPrimitiveOrBoxedOrString(Class<?>) - Static method in class org.apache.flink.util.ClassUtils
-
- isProperClass(Class<?>) - Static method in class org.apache.flink.util.InstantiationUtil
-
Checks, whether the class is a proper class, i.e.
- isPublic(Class<?>) - Static method in class org.apache.flink.util.InstantiationUtil
-
Checks, whether the given class is public.
- isSkippingFirstLineAsHeader() - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
-
- isSolutionSetUnManaged() - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase
-
gets whether the solution set is in managed or unmanaged memory.
- isStateful() - Method in class org.apache.flink.api.common.typeutils.base.array.BooleanPrimitiveArraySerializer
-
- isStateful() - Method in class org.apache.flink.api.common.typeutils.base.array.BytePrimitiveArraySerializer
-
- isStateful() - Method in class org.apache.flink.api.common.typeutils.base.array.CharPrimitiveArraySerializer
-
- isStateful() - Method in class org.apache.flink.api.common.typeutils.base.array.DoublePrimitiveArraySerializer
-
- isStateful() - Method in class org.apache.flink.api.common.typeutils.base.array.FloatPrimitiveArraySerializer
-
- isStateful() - Method in class org.apache.flink.api.common.typeutils.base.array.IntPrimitiveArraySerializer
-
- isStateful() - Method in class org.apache.flink.api.common.typeutils.base.array.LongPrimitiveArraySerializer
-
- isStateful() - Method in class org.apache.flink.api.common.typeutils.base.array.ShortPrimitiveArraySerializer
-
- isStateful() - Method in class org.apache.flink.api.common.typeutils.base.array.StringArraySerializer
-
- isStateful() - Method in class org.apache.flink.api.common.typeutils.base.BooleanSerializer
-
- isStateful() - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueSerializer
-
- isStateful() - Method in class org.apache.flink.api.common.typeutils.base.ByteSerializer
-
- isStateful() - Method in class org.apache.flink.api.common.typeutils.base.ByteValueSerializer
-
- isStateful() - Method in class org.apache.flink.api.common.typeutils.base.CharSerializer
-
- isStateful() - Method in class org.apache.flink.api.common.typeutils.base.CharValueSerializer
-
- isStateful() - Method in class org.apache.flink.api.common.typeutils.base.DateSerializer
-
- isStateful() - Method in class org.apache.flink.api.common.typeutils.base.DoubleSerializer
-
- isStateful() - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueSerializer
-
- isStateful() - Method in class org.apache.flink.api.common.typeutils.base.EnumSerializer
-
- isStateful() - Method in class org.apache.flink.api.common.typeutils.base.FloatSerializer
-
- isStateful() - Method in class org.apache.flink.api.common.typeutils.base.FloatValueSerializer
-
- isStateful() - Method in class org.apache.flink.api.common.typeutils.base.GenericArraySerializer
-
- isStateful() - Method in class org.apache.flink.api.common.typeutils.base.IntSerializer
-
- isStateful() - Method in class org.apache.flink.api.common.typeutils.base.IntValueSerializer
-
- isStateful() - Method in class org.apache.flink.api.common.typeutils.base.LongSerializer
-
- isStateful() - Method in class org.apache.flink.api.common.typeutils.base.LongValueSerializer
-
- isStateful() - Method in class org.apache.flink.api.common.typeutils.base.ShortSerializer
-
- isStateful() - Method in class org.apache.flink.api.common.typeutils.base.ShortValueSerializer
-
- isStateful() - Method in class org.apache.flink.api.common.typeutils.base.StringSerializer
-
- isStateful() - Method in class org.apache.flink.api.common.typeutils.base.StringValueSerializer
-
- isStateful() - Method in class org.apache.flink.api.common.typeutils.base.VoidSerializer
-
- isStateful() - Method in class org.apache.flink.api.common.typeutils.record.RecordSerializer
-
- isStateful() - Method in class org.apache.flink.api.common.typeutils.TypeSerializer
-
Gets whether the serializer is stateful.
- isTupleType() - Method in class org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
-
- isTupleType() - Method in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
-
- isTupleType() - Method in class org.apache.flink.api.common.typeinfo.NothingTypeInfo
-
- isTupleType() - Method in class org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
-
- isTupleType() - Method in class org.apache.flink.api.common.typeinfo.TypeInformation
-
- isValidSubset(FieldSet) - Method in class org.apache.flink.api.common.operators.util.FieldList
-
- isValidSubset(FieldList) - Method in class org.apache.flink.api.common.operators.util.FieldList
-
- isValidSubset(FieldSet) - Method in class org.apache.flink.api.common.operators.util.FieldSet
-
Checks if the given set of fields is a valid subset of this set of fields.
- isValidUnorderedPrefix(FieldSet) - Method in class org.apache.flink.api.common.operators.util.FieldList
-
- isWindows() - Static method in enum org.apache.flink.util.OperatingSystem
-
Checks whether the operating system this JVM runs on is Windows.
- IterableIterator<E> - Interface in org.apache.flink.util
-
- IterationOperator - Interface in org.apache.flink.api.common.operators
-
- IterationRuntimeContext - Interface in org.apache.flink.api.common.functions
-
- iterator() - Method in class org.apache.flink.api.common.functions.util.CopyingIterator
-
- iterator() - Method in class org.apache.flink.api.common.operators.util.FieldSet
-
- iterator() - Method in class org.apache.flink.api.common.operators.util.ListKeyGroupedIterator.ValuesIterator
-
- iterator() - Method in class org.apache.flink.types.ListValue
-
- iterator() - Method in class org.apache.flink.util.TraversableOnceIterable
-
- Pair<U extends Key<U>,V extends Key<V>> - Class in org.apache.flink.types
-
Generic pair base type.
- Pair() - Constructor for class org.apache.flink.types.Pair
-
Initializes both encapsulated pair elements with empty objects.
- Pair(U, V) - Constructor for class org.apache.flink.types.Pair
-
Initializes the encapsulated pair elements with the provided values.
- parameters - Variable in class org.apache.flink.api.common.operators.Operator
-
- ParseException - Exception in org.apache.flink.api.common.io
-
Exception indicating that the parsing of input contents has failed because the data
does not match the configured parser.
- ParseException() - Constructor for exception org.apache.flink.api.common.io.ParseException
-
- ParseException(String) - Constructor for exception org.apache.flink.api.common.io.ParseException
-
- ParseException(Throwable) - Constructor for exception org.apache.flink.api.common.io.ParseException
-
- ParseException(String, Throwable) - Constructor for exception org.apache.flink.api.common.io.ParseException
-
- parseField(byte[], int, int, char, Byte) - Method in class org.apache.flink.types.parser.ByteParser
-
- parseField(byte[], int, int) - Static method in class org.apache.flink.types.parser.ByteParser
-
Static utility to parse a field of type byte from a byte sequence that represents text characters
(such as when read from a file stream).
- parseField(byte[], int, int, char) - Static method in class org.apache.flink.types.parser.ByteParser
-
Static utility to parse a field of type byte from a byte sequence that represents text characters
(such as when read from a file stream).
- parseField(byte[], int, int, char, ByteValue) - Method in class org.apache.flink.types.parser.ByteValueParser
-
- parseField(byte[], int, int, char, Double) - Method in class org.apache.flink.types.parser.DoubleParser
-
- parseField(byte[], int, int) - Static method in class org.apache.flink.types.parser.DoubleParser
-
Static utility to parse a field of type double from a byte sequence that represents text characters
(such as when read from a file stream).
- parseField(byte[], int, int, char) - Static method in class org.apache.flink.types.parser.DoubleParser
-
Static utility to parse a field of type double from a byte sequence that represents text characters
(such as when read from a file stream).
- parseField(byte[], int, int, char, DoubleValue) - Method in class org.apache.flink.types.parser.DoubleValueParser
-
- parseField(byte[], int, int, char, T) - Method in class org.apache.flink.types.parser.FieldParser
-
Parses the value of a field from the byte array.
- parseField(byte[], int, int, char, Float) - Method in class org.apache.flink.types.parser.FloatParser
-
- parseField(byte[], int, int) - Static method in class org.apache.flink.types.parser.FloatParser
-
Static utility to parse a field of type float from a byte sequence that represents text characters
(such as when read from a file stream).
- parseField(byte[], int, int, char) - Static method in class org.apache.flink.types.parser.FloatParser
-
Static utility to parse a field of type float from a byte sequence that represents text characters
(such as when read from a file stream).
- parseField(byte[], int, int, char, FloatValue) - Method in class org.apache.flink.types.parser.FloatValueParser
-
- parseField(byte[], int, int, char, Integer) - Method in class org.apache.flink.types.parser.IntParser
-
- parseField(byte[], int, int) - Static method in class org.apache.flink.types.parser.IntParser
-
Static utility to parse a field of type int from a byte sequence that represents text characters
(such as when read from a file stream).
- parseField(byte[], int, int, char) - Static method in class org.apache.flink.types.parser.IntParser
-
Static utility to parse a field of type int from a byte sequence that represents text characters
(such as when read from a file stream).
- parseField(byte[], int, int, char, IntValue) - Method in class org.apache.flink.types.parser.IntValueParser
-
- parseField(byte[], int, int, char, Long) - Method in class org.apache.flink.types.parser.LongParser
-
- parseField(byte[], int, int) - Static method in class org.apache.flink.types.parser.LongParser
-
Static utility to parse a field of type long from a byte sequence that represents text characters
(such as when read from a file stream).
- parseField(byte[], int, int, char) - Static method in class org.apache.flink.types.parser.LongParser
-
Static utility to parse a field of type long from a byte sequence that represents text characters
(such as when read from a file stream).
- parseField(byte[], int, int, char, LongValue) - Method in class org.apache.flink.types.parser.LongValueParser
-
- parseField(byte[], int, int, char, Short) - Method in class org.apache.flink.types.parser.ShortParser
-
- parseField(byte[], int, int) - Static method in class org.apache.flink.types.parser.ShortParser
-
Static utility to parse a field of type short from a byte sequence that represents text characters
(such as when read from a file stream).
- parseField(byte[], int, int, char) - Static method in class org.apache.flink.types.parser.ShortParser
-
Static utility to parse a field of type short from a byte sequence that represents text characters
(such as when read from a file stream).
- parseField(byte[], int, int, char, ShortValue) - Method in class org.apache.flink.types.parser.ShortValueParser
-
- parseField(byte[], int, int, char, String) - Method in class org.apache.flink.types.parser.StringParser
-
- parseField(byte[], int, int, char, StringValue) - Method in class org.apache.flink.types.parser.StringValueParser
-
- parseRecord(Object[], byte[], int, int) - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
-
- PartialSolutionPlaceHolder(BulkIterationBase<OT>, OperatorInformation<OT>) - Constructor for class org.apache.flink.api.common.operators.base.BulkIterationBase.PartialSolutionPlaceHolder
-
- partition(K, int) - Method in interface org.apache.flink.api.common.functions.Partitioner
-
Computes the partition for the given key.
- Partitioner<K> - Interface in org.apache.flink.api.common.functions
-
Function to implement a custom partition assignment for keys.
- partitionNumber - Variable in class org.apache.flink.api.common.io.GenericInputFormat
-
The partition of this split.
- PartitionOperatorBase<IN> - Class in org.apache.flink.api.common.operators.base
-
- PartitionOperatorBase(UnaryOperatorInformation<IN, IN>, PartitionOperatorBase.PartitionMethod, int[], String) - Constructor for class org.apache.flink.api.common.operators.base.PartitionOperatorBase
-
- PartitionOperatorBase(UnaryOperatorInformation<IN, IN>, PartitionOperatorBase.PartitionMethod, String) - Constructor for class org.apache.flink.api.common.operators.base.PartitionOperatorBase
-
- PartitionOperatorBase.PartitionMethod - Enum in org.apache.flink.api.common.operators.base
-
- Path - Class in org.apache.flink.core.fs
-
- Path() - Constructor for class org.apache.flink.core.fs.Path
-
Constructs a new (empty) path object (used to reconstruct path object after RPC call).
- Path(URI) - Constructor for class org.apache.flink.core.fs.Path
-
Constructs a path object from a given URI.
- Path(String, String) - Constructor for class org.apache.flink.core.fs.Path
-
Resolve a child path against a parent path.
- Path(Path, String) - Constructor for class org.apache.flink.core.fs.Path
-
Resolve a child path against a parent path.
- Path(String, Path) - Constructor for class org.apache.flink.core.fs.Path
-
Resolve a child path against a parent path.
- Path(Path, Path) - Constructor for class org.apache.flink.core.fs.Path
-
Resolve a child path against a parent path.
- Path(String) - Constructor for class org.apache.flink.core.fs.Path
-
Construct a path from a String.
- Path(String, String, String) - Constructor for class org.apache.flink.core.fs.Path
-
Construct a Path from a scheme, an authority and a path string.
- PATH_HADOOP_CONFIG - Static variable in class org.apache.flink.configuration.ConfigConstants
-
Path to Hadoop configuration
- Plan - Class in org.apache.flink.api.common
-
This class encapsulates a single job (an instantiated data flow), together with some parameters.
- Plan(Collection<? extends GenericDataSinkBase<?>>, String) - Constructor for class org.apache.flink.api.common.Plan
-
Creates a new program plan with the given name, describing the data flow that ends at the
given data sinks.
- Plan(Collection<? extends GenericDataSinkBase<?>>, String, int) - Constructor for class org.apache.flink.api.common.Plan
-
Creates a new program plan with the given name and default parallelism, describing the data flow that ends
at the given data sinks.
- Plan(GenericDataSinkBase<?>, String) - Constructor for class org.apache.flink.api.common.Plan
-
Creates a new program plan with the given name, containing initially a single data sink.
- Plan(GenericDataSinkBase<?>, String, int) - Constructor for class org.apache.flink.api.common.Plan
-
Creates a new program plan with the given name and default parallelism, containing initially a single data
sink.
- Plan(Collection<? extends GenericDataSinkBase<?>>) - Constructor for class org.apache.flink.api.common.Plan
-
Creates a new program plan, describing the data flow that ends at the
given data sinks.
- Plan(Collection<? extends GenericDataSinkBase<?>>, int) - Constructor for class org.apache.flink.api.common.Plan
-
Creates a new program plan with the given default parallelism, describing the data flow that ends at the
given data sinks.
- Plan(GenericDataSinkBase<?>) - Constructor for class org.apache.flink.api.common.Plan
-
Creates a new program plan with single data sink.
- Plan(GenericDataSinkBase<?>, int) - Constructor for class org.apache.flink.api.common.Plan
-
Creates a new program plan with single data sink and the given default parallelism.
- PlanExecutor - Class in org.apache.flink.api.common
-
A PlanExecutor runs a plan.
- PlanExecutor() - Constructor for class org.apache.flink.api.common.PlanExecutor
-
- postVisit(T) - Method in interface org.apache.flink.util.Visitor
-
- preVisit(T) - Method in interface org.apache.flink.util.Visitor
-
- PrimitiveArrayTypeInfo<T> - Class in org.apache.flink.api.common.typeinfo
-
- Prober(TypeComparator<PT>, TypePairComparator<PT, BT>) - Constructor for class org.apache.flink.api.common.operators.util.JoinHashMap.Prober
-
- Program - Interface in org.apache.flink.api.common
-
A Program represents and end-to-end Flink program.
- ProgramDescription - Interface in org.apache.flink.api.common
-
Implementing this interface allows a Program to have a description
of the plan which can be shown to the user.
- put(int, byte) - Method in class org.apache.flink.core.memory.MemorySegment
-
Writes the given byte into this buffer at the given position.
- put(int, byte[]) - Method in class org.apache.flink.core.memory.MemorySegment
-
Bulk put method.
- put(int, byte[], int, int) - Method in class org.apache.flink.core.memory.MemorySegment
-
Bulk put method.
- put(DataInput, int, int) - Method in class org.apache.flink.core.memory.MemorySegment
-
Bulk put method.
- put(int, ByteBuffer, int) - Method in class org.apache.flink.core.memory.MemorySegment
-
Bulk put method.
- put(K, V) - Method in class org.apache.flink.types.MapValue
-
- putAll(Map<? extends K, ? extends V>) - Method in class org.apache.flink.types.MapValue
-
- putBoolean(int, boolean) - Method in class org.apache.flink.core.memory.MemorySegment
-
Writes one byte containing the byte value into this buffer at the given
position.
- putChar(int, char) - Method in class org.apache.flink.core.memory.MemorySegment
-
Writes two memory containing the given char value, in the current byte
order, into this buffer at the given position.
- putDouble(int, double) - Method in class org.apache.flink.core.memory.MemorySegment
-
Writes the given double-precision floating-point value (64bit, 8 bytes) to the given position in the
system's native byte order.
- putDoubleBigEndian(int, double) - Method in class org.apache.flink.core.memory.MemorySegment
-
Writes the given double-precision floating-point value (64bit, 8 bytes) to the given position in big endian
byte order.
- putDoubleLittleEndian(int, double) - Method in class org.apache.flink.core.memory.MemorySegment
-
Writes the given double-precision floating-point value (64bit, 8 bytes) to the given position in little endian
byte order.
- putFloat(int, float) - Method in class org.apache.flink.core.memory.MemorySegment
-
Writes the given single-precision float value (32bit, 4 bytes) to the given position in the system's native
byte order.
- putFloatBigEndian(int, float) - Method in class org.apache.flink.core.memory.MemorySegment
-
Writes the given single-precision float value (32bit, 4 bytes) to the given position in big endian
byte order.
- putFloatLittleEndian(int, float) - Method in class org.apache.flink.core.memory.MemorySegment
-
Writes the given single-precision float value (32bit, 4 bytes) to the given position in little endian
byte order.
- putInt(int, int) - Method in class org.apache.flink.core.memory.MemorySegment
-
Writes the given int value (32bit, 4 bytes) to the given position in the system's native
byte order.
- putIntBigEndian(int, int) - Method in class org.apache.flink.core.memory.MemorySegment
-
Writes the given int value (32bit, 4 bytes) to the given position in big endian
byte order.
- putIntLittleEndian(int, int) - Method in class org.apache.flink.core.memory.MemorySegment
-
Writes the given int value (32bit, 4 bytes) to the given position in little endian
byte order.
- putLong(int, long) - Method in class org.apache.flink.core.memory.MemorySegment
-
Writes the given long value (64bit, 8 bytes) to the given position in the system's native
byte order.
- putLongBigEndian(int, long) - Method in class org.apache.flink.core.memory.MemorySegment
-
Writes the given long value (64bit, 8 bytes) to the given position in big endian
byte order.
- putLongLittleEndian(int, long) - Method in class org.apache.flink.core.memory.MemorySegment
-
Writes the given long value (64bit, 8 bytes) to the given position in little endian
byte order.
- putNormalizedKey(Boolean, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.BooleanComparator
-
- putNormalizedKey(Byte, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.ByteComparator
-
- putNormalizedKey(Character, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.CharComparator
-
- putNormalizedKey(Date, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.DateComparator
-
- putNormalizedKey(Double, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.DoubleComparator
-
- putNormalizedKey(T, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.EnumComparator
-
- putNormalizedKey(Float, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.FloatComparator
-
- putNormalizedKey(Integer, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.IntComparator
-
- putNormalizedKey(Long, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.LongComparator
-
- putNormalizedKey(Short, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.ShortComparator
-
- putNormalizedKey(String, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.StringComparator
-
- putNormalizedKey(Record, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.record.RecordComparator
-
- putNormalizedKey(T, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.TypeComparator
-
Writes a normalized key for the given record into the target byte array, starting at the specified position
an writing exactly the given number of bytes.
- putShort(int, short) - Method in class org.apache.flink.core.memory.MemorySegment
-
Writes the given short value into this buffer at the given position, using
the native byte order of the system.
- seek(long) - Method in class org.apache.flink.api.common.io.InflaterInputStreamFSInputWrapper
-
- seek(long) - Method in class org.apache.flink.core.fs.FSDataInputStream
-
Seek to the given offset from the start of the file.
- seek(long) - Method in class org.apache.flink.core.fs.local.LocalDataInputStream
-
- SeekableDataInputView - Interface in org.apache.flink.core.memory
-
- SeekableDataOutputView - Interface in org.apache.flink.core.memory
-
- SemanticProperties - Class in org.apache.flink.api.common.operators
-
Container for the semantic properties associated to an operator.
- SemanticProperties() - Constructor for class org.apache.flink.api.common.operators.SemanticProperties
-
- SEPARATOR - Static variable in class org.apache.flink.core.fs.Path
-
The directory separator, a slash.
- SEPARATOR_CHAR - Static variable in class org.apache.flink.core.fs.Path
-
The directory separator, a slash (character).
- serialize(T, DataOutputView) - Method in class org.apache.flink.api.common.io.BinaryOutputFormat
-
- serialize(T, DataOutputView) - Method in class org.apache.flink.api.common.io.SerializedOutputFormat
-
- serialize(boolean[], DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.array.BooleanPrimitiveArraySerializer
-
- serialize(byte[], DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.array.BytePrimitiveArraySerializer
-
- serialize(char[], DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.array.CharPrimitiveArraySerializer
-
- serialize(double[], DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.array.DoublePrimitiveArraySerializer
-
- serialize(float[], DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.array.FloatPrimitiveArraySerializer
-
- serialize(int[], DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.array.IntPrimitiveArraySerializer
-
- serialize(long[], DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.array.LongPrimitiveArraySerializer
-
- serialize(short[], DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.array.ShortPrimitiveArraySerializer
-
- serialize(String[], DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.array.StringArraySerializer
-
- serialize(Boolean, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.BooleanSerializer
-
- serialize(BooleanValue, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueSerializer
-
- serialize(Byte, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.ByteSerializer
-
- serialize(ByteValue, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.ByteValueSerializer
-
- serialize(Character, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.CharSerializer
-
- serialize(CharValue, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.CharValueSerializer
-
- serialize(Date, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.DateSerializer
-
- serialize(Double, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.DoubleSerializer
-
- serialize(DoubleValue, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueSerializer
-
- serialize(T, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.EnumSerializer
-
- serialize(Float, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.FloatSerializer
-
- serialize(FloatValue, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.FloatValueSerializer
-
- serialize(C[], DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.GenericArraySerializer
-
- serialize(Integer, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.IntSerializer
-
- serialize(IntValue, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.IntValueSerializer
-
- serialize(Long, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.LongSerializer
-
- serialize(LongValue, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.LongValueSerializer
-
- serialize(Short, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.ShortSerializer
-
- serialize(ShortValue, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.ShortValueSerializer
-
- serialize(String, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.StringSerializer
-
- serialize(StringValue, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.StringValueSerializer
-
- serialize(Void, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.VoidSerializer
-
- serialize(Record, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.record.RecordSerializer
-
- serialize(T, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.TypeSerializer
-
Serializes the given record to the given target output view.
- serialize(DataOutputView) - Method in class org.apache.flink.types.Record
-
Writes this record to the given output view.
- SerializedInputFormat<T extends IOReadableWritable> - Class in org.apache.flink.api.common.io
-
Reads elements by deserializing them with their regular serialization/deserialization functionality.
- SerializedInputFormat() - Constructor for class org.apache.flink.api.common.io.SerializedInputFormat
-
- SerializedOutputFormat<T extends IOReadableWritable> - Class in org.apache.flink.api.common.io
-
Stores elements by serializing them with their regular serialization/deserialization functionality.
- SerializedOutputFormat() - Constructor for class org.apache.flink.api.common.io.SerializedOutputFormat
-
- serializeObject(Object) - Static method in class org.apache.flink.util.InstantiationUtil
-
- serializeToByteArray(TypeSerializer<T>, T) - Static method in class org.apache.flink.util.InstantiationUtil
-
- set(String) - Method in class org.apache.flink.core.io.StringRecord
-
Set to contain the contents of a string.
- set(byte[]) - Method in class org.apache.flink.core.io.StringRecord
-
Set to a utf8 byte array
- set(StringRecord) - Method in class org.apache.flink.core.io.StringRecord
-
copy a text.
- set(byte[], int, int) - Method in class org.apache.flink.core.io.StringRecord
-
Set the Text to range of bytes
- set(boolean) - Method in class org.apache.flink.types.BooleanValue
-
- set(int, V) - Method in class org.apache.flink.types.ListValue
-
- setAccumulatedRecordCount(long) - Method in class org.apache.flink.api.common.io.BlockInfo
-
Sets the accumulatedRecordCount to the specified value.
- setAvgOutputRecordSize(float) - Method in class org.apache.flink.api.common.operators.CompilerHints
-
- setBoolean(String, boolean) - Method in class org.apache.flink.configuration.Configuration
-
Adds the given key/value pair to the configuration object.
- setBroadcastVariable(String, List<?>) - Method in class org.apache.flink.api.common.functions.util.RuntimeUDFContext
-
- setBroadcastVariable(String, Operator<?>) - Method in class org.apache.flink.api.common.operators.AbstractUdfOperator
-
Binds the result produced by a plan rooted at root
to a variable
used by the UDF wrapped in this operator.
- setBroadcastVariable(String, Operator<?>) - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase
-
The BulkIteration meta operator cannot have broadcast inputs.
- setBroadcastVariable(String, Operator<?>) - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase
-
The DeltaIteration meta operator cannot have broadcast inputs.
- setBroadcastVariables(Map<String, Operator<T>>) - Method in class org.apache.flink.api.common.operators.AbstractUdfOperator
-
Clears all previous broadcast inputs and binds the given inputs as
broadcast variables of this operator.
- setBroadcastVariables(Map<String, Operator<X>>) - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase
-
The BulkIteration meta operator cannot have broadcast inputs.
- setBroadcastVariables(Map<String, Operator<X>>) - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase
-
The DeltaIteration meta operator cannot have broadcast inputs.
- setBufferSize(int) - Method in class org.apache.flink.api.common.io.DelimitedInputFormat
-
- setBytes(String, byte[]) - Method in class org.apache.flink.configuration.Configuration
-
Adds the given byte array to the configuration object.
- setClass(String, Class<?>) - Method in class org.apache.flink.configuration.Configuration
-
Adds the given key/value pair to the configuration object.
- setCombinable(boolean) - Method in class org.apache.flink.api.common.operators.base.GroupReduceOperatorBase
-
Marks the group reduce operation as combinable.
- setCombinableFirst(boolean) - Method in class org.apache.flink.api.common.operators.base.CoGroupOperatorBase
-
- setCombinableSecond(boolean) - Method in class org.apache.flink.api.common.operators.base.CoGroupOperatorBase
-
- setCopyTasks(Map<String, FutureTask<Path>>) - Method in class org.apache.flink.api.common.cache.DistributedCache
-
- setCustomPartitioner(Partitioner<?>) - Method in class org.apache.flink.api.common.operators.base.CoGroupOperatorBase
-
- setCustomPartitioner(Partitioner<?>) - Method in class org.apache.flink.api.common.operators.base.GroupReduceOperatorBase
-
- setCustomPartitioner(Partitioner<?>) - Method in class org.apache.flink.api.common.operators.base.JoinOperatorBase
-
- setCustomPartitioner(Partitioner<?>) - Method in class org.apache.flink.api.common.operators.base.PartitionOperatorBase
-
- setCustomPartitioner(Partitioner<?>) - Method in class org.apache.flink.api.common.operators.base.ReduceOperatorBase
-
- setDefaultParallelism(int) - Method in class org.apache.flink.api.common.Plan
-
Sets the default degree of parallelism for this plan.
- setDegreeOfParallelism(int) - Method in class org.apache.flink.api.common.ExecutionConfig
-
Sets the degree of parallelism (DOP) for operations executed through this environment.
- setDegreeOfParallelism(int) - Method in class org.apache.flink.api.common.operators.Operator
-
Sets the degree of parallelism for this contract instance.
- setDelimiter(byte[]) - Method in class org.apache.flink.api.common.io.DelimitedInputFormat
-
- setDelimiter(char) - Method in class org.apache.flink.api.common.io.DelimitedInputFormat
-
- setDelimiter(String) - Method in class org.apache.flink.api.common.io.DelimitedInputFormat
-
- setDelimiter(String, String) - Method in class org.apache.flink.api.common.io.DelimitedInputFormat
-
- setDelimiter(String, Charset) - Method in class org.apache.flink.api.common.io.DelimitedInputFormat
-
- setDouble(String, double) - Method in class org.apache.flink.configuration.Configuration
-
Adds the given key/value pair to the configuration object.
- setErrorState(FieldParser.ParseErrorState) - Method in class org.apache.flink.types.parser.FieldParser
-
Sets the error state of the parser.
- setField(int, Value) - Method in class org.apache.flink.types.Record
-
Sets the field at the given position to the given value.
- setFieldDelimiter(char) - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
-
- setFieldsGeneric(int[], Class<?>[]) - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
-
- setFieldsGeneric(boolean[], Class<?>[]) - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
-
- setFieldTypesGeneric(Class<?>...) - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
-
- setFilePath(String) - Method in class org.apache.flink.api.common.io.FileInputFormat
-
- setFilePath(Path) - Method in class org.apache.flink.api.common.io.FileInputFormat
-
- setFilterFactor(float) - Method in class org.apache.flink.api.common.operators.CompilerHints
-
- setFirst(U) - Method in class org.apache.flink.types.Pair
-
Sets the first encapsulated pair element to the specified value.
- setFirstInput(Operator<IN1>) - Method in class org.apache.flink.api.common.operators.DualInputOperator
-
Clears all previous connections and connects the first input to the task wrapped in this contract
- setFirstInput(Operator<IN1>...) - Method in class org.apache.flink.api.common.operators.DualInputOperator
-
- setFirstInputs(List<Operator<IN1>>) - Method in class org.apache.flink.api.common.operators.DualInputOperator
-
- setFirstRecordStart(long) - Method in class org.apache.flink.api.common.io.BlockInfo
-
Sets the firstRecordStart to the specified value.
- setFloat(String, float) - Method in class org.apache.flink.configuration.Configuration
-
Adds the given key/value pair to the configuration object.
- setForwardedField(int, FieldSet) - Method in class org.apache.flink.api.common.operators.SingleInputSemanticProperties.AllFieldsConstantProperties
-
- setForwardedField(int, FieldSet) - Method in class org.apache.flink.api.common.operators.SingleInputSemanticProperties
-
Sets a field that is forwarded directly from the source
record(s) to multiple fields in the destination record(s).
- setForwardedField1(int, FieldSet) - Method in class org.apache.flink.api.common.operators.DualInputSemanticProperties
-
Sets a field that is forwarded directly from the source
record(s) in the first input to multiple fields in the
destination record(s).
- setForwardedField2(int, FieldSet) - Method in class org.apache.flink.api.common.operators.DualInputSemanticProperties
-
Sets a field that is forwarded directly from the source
record(s) in the second input to multiple fields in the
destination record(s).
- setFunctionRuntimeContext(Function, RuntimeContext) - Static method in class org.apache.flink.api.common.functions.util.FunctionUtils
-
- setGlobalOrder(Ordering) - Method in class org.apache.flink.api.common.operators.GenericDataSinkBase
-
Sets the order in which the sink must write its data.
- setGlobalOrder(Ordering, DataDistribution) - Method in class org.apache.flink.api.common.operators.GenericDataSinkBase
-
Sets the order in which the sink must write its data.
- setGroupOrder(int, Ordering) - Method in class org.apache.flink.api.common.operators.base.CoGroupOperatorBase
-
Sets the order of the elements within a group for the given input.
- setGroupOrder(Ordering) - Method in class org.apache.flink.api.common.operators.base.GroupReduceOperatorBase
-
Sets the order of the elements within a reduce group.
- setGroupOrderForInputOne(Ordering) - Method in class org.apache.flink.api.common.operators.base.CoGroupOperatorBase
-
Sets the order of the elements within a group for the first input.
- setGroupOrderForInputTwo(Ordering) - Method in class org.apache.flink.api.common.operators.base.CoGroupOperatorBase
-
Sets the order of the elements within a group for the second input.
- setInitialSolutionSet(Operator<ST>) - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase
-
Sets the given input as the initial solution set.
- setInitialWorkset(Operator<WT>) - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase
-
Sets the given input as the initial workset.
- setInput(Operator<IN>) - Method in class org.apache.flink.api.common.operators.GenericDataSinkBase
-
Sets the given operator as the input to this operator.
- setInput(Operator<IN>) - Method in class org.apache.flink.api.common.operators.SingleInputOperator
-
Sets the given operator as the input to this operator.
- setInput(Operator<IN>...) - Method in class org.apache.flink.api.common.operators.SingleInputOperator
-
- setInputs(Operator<IN>...) - Method in class org.apache.flink.api.common.operators.GenericDataSinkBase
-
- setInputs(List<Operator<IN>>) - Method in class org.apache.flink.api.common.operators.GenericDataSinkBase
-
- setInputs(List<Operator<IN>>) - Method in class org.apache.flink.api.common.operators.SingleInputOperator
-
- setInputs(Operator<?>, List<List<Operator>>) - Static method in class org.apache.flink.api.common.operators.util.OperatorUtil
-
Sets the inputs of the given
Operator
.
Currently, the list can have 0, 1, or 2 elements and the number of elements must match the type of the contract.
- setInteger(String, int) - Method in class org.apache.flink.configuration.Configuration
-
Adds the given key/value pair to the configuration object.
- setJobName(String) - Method in class org.apache.flink.api.common.Plan
-
Sets the jobName for this Plan.
- setJoinHint(JoinOperatorBase.JoinHint) - Method in class org.apache.flink.api.common.operators.base.JoinOperatorBase
-
- setLength(int) - Method in class org.apache.flink.types.StringValue
-
Sets a new length for the string.
- setLenient(boolean) - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
-
- setLineLengthLimit(int) - Method in class org.apache.flink.api.common.io.DelimitedInputFormat
-
- setLocalOrder(Ordering) - Method in class org.apache.flink.api.common.operators.GenericDataSinkBase
-
Sets the order in which the sink must write its data within each fragment in the distributed
file system.
- setLong(String, long) - Method in class org.apache.flink.configuration.Configuration
-
Adds the given key/value pair to the configuration object.
- setMaximumNumberOfIterations(int) - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase
-
- setMaximumNumberOfIterations(int) - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase
-
- setMinSplitSize(long) - Method in class org.apache.flink.api.common.io.FileInputFormat
-
- setName(String) - Method in class org.apache.flink.api.common.operators.Operator
-
Sets the name of the contract instance.
- setNextPartialSolution(Operator<T>) - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase
-
- setNextWorkset(Operator<WT>) - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase
-
Sets the contract of the step function that represents the next workset.
- setNull(int) - Method in class org.apache.flink.types.Record
-
Sets the field at the given position to null
.
- setNull(long) - Method in class org.apache.flink.types.Record
-
Sets the fields to null
using the given bit mask.
- setNull(long[]) - Method in class org.apache.flink.types.Record
-
Sets the fields to null
using the given bit mask.
- setNumberOfExecutionRetries(int) - Method in class org.apache.flink.api.common.ExecutionConfig
-
Sets the number of times that failed tasks are re-executed.
- setNumberOfExecutionRetries(int) - Method in class org.apache.flink.api.common.Plan
-
Sets the number of times that failed tasks are re-executed.
- setNumFields(int) - Method in class org.apache.flink.types.Record
-
Sets the number of fields in the record.
- setNumLineSamples(int) - Method in class org.apache.flink.api.common.io.DelimitedInputFormat
-
- setNumSplits(int) - Method in class org.apache.flink.api.common.io.FileInputFormat
-
- setOpenTimeout(long) - Method in class org.apache.flink.api.common.io.FileInputFormat
-
- setOutputCardinality(long) - Method in class org.apache.flink.api.common.operators.CompilerHints
-
- setOutputDirectoryMode(FileOutputFormat.OutputDirectoryMode) - Method in class org.apache.flink.api.common.io.FileOutputFormat
-
- setOutputFilePath(Path) - Method in class org.apache.flink.api.common.io.FileOutputFormat
-
- setOutputSize(long) - Method in class org.apache.flink.api.common.operators.CompilerHints
-
- setParameter(String, String) - Method in class org.apache.flink.api.common.operators.Operator
-
Sets a stub parameters in the configuration of this contract.
- setParameter(String, int) - Method in class org.apache.flink.api.common.operators.Operator
-
Sets a stub parameters in the configuration of this contract.
- setParameter(String, boolean) - Method in class org.apache.flink.api.common.operators.Operator
-
Sets a stub parameters in the configuration of this contract.
- setRangePartitioned(Ordering) - Method in class org.apache.flink.api.common.operators.GenericDataSinkBase
-
Sets the sink to partition the records into ranges over the given ordering.
- setRangePartitioned(Ordering, DataDistribution) - Method in class org.apache.flink.api.common.operators.GenericDataSinkBase
-
Sets the sink to partition the records into ranges over the given ordering.
- setReadFields(FieldSet) - Method in class org.apache.flink.api.common.operators.SingleInputSemanticProperties.AllFieldsConstantProperties
-
- setReadFields(FieldSet) - Method in class org.apache.flink.api.common.operators.SingleInputSemanticProperties
-
Sets the field(s) that are read in the source record(s).
- setReadFields1(FieldSet) - Method in class org.apache.flink.api.common.operators.DualInputSemanticProperties
-
Sets the field(s) that are read in the source record(s) from the first
input.
- setReadFields2(FieldSet) - Method in class org.apache.flink.api.common.operators.DualInputSemanticProperties
-
Sets the field(s) that are read in the source record(s) from the second
input.
- setReadPosition(long) - Method in interface org.apache.flink.core.memory.SeekableDataInputView
-
Sets the read pointer to the given position.
- setRecordCount(long) - Method in class org.apache.flink.api.common.io.BlockInfo
-
Sets the recordCount to the specified value.
- setReference(T) - Method in class org.apache.flink.api.common.typeutils.base.BasicTypeComparator
-
- setReference(T1) - Method in class org.apache.flink.api.common.typeutils.GenericPairComparator
-
- setReference(Record) - Method in class org.apache.flink.api.common.typeutils.record.RecordComparator
-
- setReference(Record) - Method in class org.apache.flink.api.common.typeutils.record.RecordPairComparator
-
- setReference(T) - Method in class org.apache.flink.api.common.typeutils.TypeComparator
-
- setReference(T1) - Method in class org.apache.flink.api.common.typeutils.TypePairComparator
-
Sets the reference for comparisons.
- setRuntimeContext(RuntimeContext) - Method in class org.apache.flink.api.common.functions.AbstractRichFunction
-
- setRuntimeContext(RuntimeContext) - Method in interface org.apache.flink.api.common.functions.RichFunction
-
Sets the function's runtime context.
- setSecond(V) - Method in class org.apache.flink.types.Pair
-
Sets the second encapsulated pair element to the specified value.
- setSecondInput(Operator<IN2>) - Method in class org.apache.flink.api.common.operators.DualInputOperator
-
Clears all previous connections and connects the second input to the task wrapped in this contract
- setSecondInput(Operator<IN2>...) - Method in class org.apache.flink.api.common.operators.DualInputOperator
-
- setSecondInputs(List<Operator<IN2>>) - Method in class org.apache.flink.api.common.operators.DualInputOperator
-
- setSemanticProperties(DualInputSemanticProperties) - Method in class org.apache.flink.api.common.operators.DualInputOperator
-
- setSemanticProperties(SingleInputSemanticProperties) - Method in class org.apache.flink.api.common.operators.SingleInputOperator
-
- setSkipFirstLineAsHeader(boolean) - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
-
- setSolutionSetDelta(Operator<ST>) - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase
-
Sets the contract of the step function that represents the solution set delta.
- setSolutionSetUnManaged(boolean) - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase
-
Sets whether to keep the solution set in managed memory (safe against heap exhaustion) or unmanaged memory
(objects on heap).
- setStatisticsKey(String) - Method in class org.apache.flink.api.common.operators.GenericDataSourceBase
-
Sets the key under which statistics about this data source may be obtained from the
statistics cache.
- setString(String, String) - Method in class org.apache.flink.configuration.Configuration
-
Adds the given key/value pair to the configuration object.
- setStringToTokenize(StringValue) - Method in class org.apache.flink.util.SimpleStringUtils.WhitespaceTokenizer
-
Sets the string to be tokenized and resets the state of the tokenizer.
- setTerminationCriterion(Operator<X>) - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase
-
- setValue(boolean) - Method in class org.apache.flink.types.BooleanValue
-
- setValue(BooleanValue) - Method in class org.apache.flink.types.BooleanValue
-
- setValue(byte) - Method in class org.apache.flink.types.ByteValue
-
Sets the encapsulated byte to the specified value.
- setValue(ByteValue) - Method in class org.apache.flink.types.ByteValue
-
- setValue(char) - Method in class org.apache.flink.types.CharValue
-
Sets the encapsulated char to the specified value.
- setValue(CharValue) - Method in class org.apache.flink.types.CharValue
-
- setValue(double) - Method in class org.apache.flink.types.DoubleValue
-
Sets the value of the encapsulated primitive double.
- setValue(DoubleValue) - Method in class org.apache.flink.types.DoubleValue
-
- setValue(float) - Method in class org.apache.flink.types.FloatValue
-
Sets the value of the encapsulated primitive float.
- setValue(FloatValue) - Method in class org.apache.flink.types.FloatValue
-
- setValue(int) - Method in class org.apache.flink.types.IntValue
-
Sets the encapsulated int to the specified value.
- setValue(IntValue) - Method in class org.apache.flink.types.IntValue
-
- setValue(long) - Method in class org.apache.flink.types.LongValue
-
Sets the value of the encapsulated long to the specified value.
- setValue(LongValue) - Method in class org.apache.flink.types.LongValue
-
- setValue(T) - Method in interface org.apache.flink.types.ResettableValue
-
Sets the encapsulated value to another value
- setValue(short) - Method in class org.apache.flink.types.ShortValue
-
Sets the encapsulated short to the specified value.
- setValue(ShortValue) - Method in class org.apache.flink.types.ShortValue
-
- setValue(CharSequence) - Method in class org.apache.flink.types.StringValue
-
Sets the value of the StringValue to the given string.
- setValue(StringValue) - Method in class org.apache.flink.types.StringValue
-
Sets the value of the StringValue to the given string.
- setValue(StringValue, int, int) - Method in class org.apache.flink.types.StringValue
-
Sets the value of the StringValue to a substring of the given string.
- setValue(CharSequence, int, int) - Method in class org.apache.flink.types.StringValue
-
Sets the value of the StringValue to a substring of the given string.
- setValue(CharBuffer) - Method in class org.apache.flink.types.StringValue
-
Sets the contents of this string to the contents of the given CharBuffer.
- setValue(char[], int, int) - Method in class org.apache.flink.types.StringValue
-
Sets the value of the StringValue to a substring of the given value.
- setValueAscii(byte[], int, int) - Method in class org.apache.flink.types.StringValue
-
Sets the value of this StringValue
, assuming that the binary data is ASCII coded.
- setWriteMode(FileSystem.WriteMode) - Method in class org.apache.flink.api.common.io.FileOutputFormat
-
- setWritePosition(long) - Method in interface org.apache.flink.core.memory.SeekableDataOutputView
-
Sets the write pointer to the given position.
- setWrittenFields(FieldSet) - Method in class org.apache.flink.api.common.operators.SemanticProperties
-
Sets the field(s) that are written in the destination record(s).
- setWrittenFields(FieldSet) - Method in class org.apache.flink.api.common.operators.SingleInputSemanticProperties.AllFieldsConstantProperties
-
- SHORT_ARRAY_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
-
- SHORT_PRIMITIVE_ARRAY_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
-
- SHORT_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
-
- ShortComparator - Class in org.apache.flink.api.common.typeutils.base
-
- ShortComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.ShortComparator
-
- ShortParser - Class in org.apache.flink.types.parser
-
Parses a decimal text field into a
Short
.
- ShortParser() - Constructor for class org.apache.flink.types.parser.ShortParser
-
- ShortPrimitiveArraySerializer - Class in org.apache.flink.api.common.typeutils.base.array
-
A serializer for short arrays.
- ShortPrimitiveArraySerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.array.ShortPrimitiveArraySerializer
-
- ShortSerializer - Class in org.apache.flink.api.common.typeutils.base
-
- ShortSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.ShortSerializer
-
- ShortValue - Class in org.apache.flink.types
-
Boxed serializable and comparable short integer type, representing the primitive
type short
.
- ShortValue() - Constructor for class org.apache.flink.types.ShortValue
-
Initializes the encapsulated short with 0.
- ShortValue(short) - Constructor for class org.apache.flink.types.ShortValue
-
Initializes the encapsulated short with the provided value.
- ShortValueParser - Class in org.apache.flink.types.parser
-
- ShortValueParser() - Constructor for class org.apache.flink.types.parser.ShortValueParser
-
- ShortValueSerializer - Class in org.apache.flink.api.common.typeutils.base
-
- ShortValueSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.ShortValueSerializer
-
- showControlCharacters(String) - Static method in class org.apache.flink.util.StringUtils
-
Replaces control characters by their escape-coded version.
- SimpleAccumulator<T> - Interface in org.apache.flink.api.common.accumulators
-
Similar to Accumulator, but the type of items to add and the result value
must be the same.
- SimpleDistribution - Class in org.apache.flink.api.common.distributions
-
- SimpleDistribution() - Constructor for class org.apache.flink.api.common.distributions.SimpleDistribution
-
- SimpleDistribution(Key<?>[]) - Constructor for class org.apache.flink.api.common.distributions.SimpleDistribution
-
- SimpleDistribution(Key<?>[][]) - Constructor for class org.apache.flink.api.common.distributions.SimpleDistribution
-
- SimpleIntegerDistribution - Class in org.apache.flink.api.common.distributions
-
- SimpleIntegerDistribution() - Constructor for class org.apache.flink.api.common.distributions.SimpleIntegerDistribution
-
- SimpleIntegerDistribution(int[]) - Constructor for class org.apache.flink.api.common.distributions.SimpleIntegerDistribution
-
- SimpleIntegerDistribution(IntValue[]) - Constructor for class org.apache.flink.api.common.distributions.SimpleIntegerDistribution
-
- SimpleIntegerDistribution(IntValue[][]) - Constructor for class org.apache.flink.api.common.distributions.SimpleIntegerDistribution
-
- SimpleStringUtils - Class in org.apache.flink.util
-
Utility class for efficient string operations on strings.
- SimpleStringUtils.WhitespaceTokenizer - Class in org.apache.flink.util
-
A tokenizer for string values that uses whitespace characters as token delimiters.
- SingleInputOperator<IN,OUT,FT extends Function> - Class in org.apache.flink.api.common.operators
-
Abstract superclass for for all operators that have one input like "map" or "reduce".
- SingleInputOperator(UserCodeWrapper<FT>, UnaryOperatorInformation<IN, OUT>, int[], String) - Constructor for class org.apache.flink.api.common.operators.SingleInputOperator
-
Creates a new abstract single-input operator with the given name wrapping the given user function.
- SingleInputOperator(UserCodeWrapper<FT>, UnaryOperatorInformation<IN, OUT>, String) - Constructor for class org.apache.flink.api.common.operators.SingleInputOperator
-
Creates a new abstract single-input operator with the given name wrapping the given user function.
- SingleInputSemanticProperties - Class in org.apache.flink.api.common.operators
-
Container for the semantic properties associated to a single input operator.
- SingleInputSemanticProperties() - Constructor for class org.apache.flink.api.common.operators.SingleInputSemanticProperties
-
- SingleInputSemanticProperties.AllFieldsConstantProperties - Class in org.apache.flink.api.common.operators
-
- sinks - Variable in class org.apache.flink.api.common.Plan
-
A collection of all sinks in the plan.
- size() - Method in class org.apache.flink.api.common.operators.util.FieldSet
-
- size() - Method in class org.apache.flink.core.memory.MemorySegment
-
Gets the size of the memory segment, in bytes.
- size() - Method in class org.apache.flink.types.ListValue
-
- size() - Method in class org.apache.flink.types.MapValue
-
- SIZE_UNKNOWN - Static variable in interface org.apache.flink.api.common.io.statistics.BaseStatistics
-
Constant indicating that the input size is unknown.
- skip(long) - Method in class org.apache.flink.core.fs.local.LocalDataInputStream
-
- skip(DataInput) - Static method in class org.apache.flink.core.io.StringRecord
-
Skips over one Text in the input.
- skipBytes(int) - Method in class org.apache.flink.core.memory.InputViewDataInputStreamWrapper
-
- skipBytes(int) - Method in class org.apache.flink.core.memory.InputViewObjectInputStreamWrapper
-
- skipBytesToRead(int) - Method in interface org.apache.flink.core.memory.DataInputView
-
Skips numBytes
bytes of memory.
- skipBytesToRead(int) - Method in class org.apache.flink.core.memory.InputViewDataInputStreamWrapper
-
- skipBytesToRead(int) - Method in class org.apache.flink.core.memory.InputViewObjectInputStreamWrapper
-
- skipBytesToWrite(int) - Method in interface org.apache.flink.core.memory.DataOutputView
-
Skips numBytes
bytes memory.
- skipBytesToWrite(int) - Method in class org.apache.flink.core.memory.OutputViewDataOutputStreamWrapper
-
- skipBytesToWrite(int) - Method in class org.apache.flink.core.memory.OutputViewObjectOutputStreamWrapper
-
- skipFields(byte[], int, int, char) - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
-
- skipFully(DataInput, int) - Static method in class org.apache.flink.core.io.StringRecord
-
- SolutionSetPlaceHolder(DeltaIterationBase<ST, ?>, OperatorInformation<ST>) - Constructor for class org.apache.flink.api.common.operators.base.DeltaIterationBase.SolutionSetPlaceHolder
-
- split(int) - Method in class org.apache.flink.util.NumberSequenceIterator
-
- split(int) - Method in interface org.apache.flink.util.SplittableIterator
-
- splitLength - Variable in class org.apache.flink.api.common.io.FileInputFormat
-
The length of the split that this parallel instance must consume.
- splitStart - Variable in class org.apache.flink.api.common.io.FileInputFormat
-
The start of the split that this parallel instance must consume.
- SplittableIterator<T> - Interface in org.apache.flink.util
-
- startRecord() - Method in class org.apache.flink.api.common.io.BinaryOutputFormat.BlockBasedOutput
-
- startsWith(CharSequence, int) - Method in class org.apache.flink.types.StringValue
-
Checks whether the substring, starting at the specified index, starts with the given prefix string.
- startsWith(CharSequence) - Method in class org.apache.flink.types.StringValue
-
Checks whether this StringValue starts with the given prefix string.
- statisticsKey - Variable in class org.apache.flink.api.common.operators.GenericDataSourceBase
-
- stream - Variable in class org.apache.flink.api.common.io.FileInputFormat
-
The input stream reading from the input file.
- stream - Variable in class org.apache.flink.api.common.io.FileOutputFormat
-
The stream to which the data is written;
- STRING_ARRAY_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
-
- STRING_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
-
- StringArraySerializer - Class in org.apache.flink.api.common.typeutils.base.array
-
A serializer for String arrays.
- StringArraySerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.array.StringArraySerializer
-
- StringComparator - Class in org.apache.flink.api.common.typeutils.base
-
- StringComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.StringComparator
-
- stringifyException(Throwable) - Static method in class org.apache.flink.util.ExceptionUtils
-
Makes a string representation of the exception's stack trace, or "(null)", if the
exception is null.
- stringifyException(Throwable) - Static method in class org.apache.flink.util.StringUtils
-
Makes a string representation of the exception.
- StringParser - Class in org.apache.flink.types.parser
-
Converts a variable length field of a byte array into a
String
.
- StringParser() - Constructor for class org.apache.flink.types.parser.StringParser
-
- StringRecord - Class in org.apache.flink.core.io
-
This class stores text using standard UTF8 encoding.
- StringRecord() - Constructor for class org.apache.flink.core.io.StringRecord
-
- StringRecord(String) - Constructor for class org.apache.flink.core.io.StringRecord
-
Construct from a string.
- StringRecord(StringRecord) - Constructor for class org.apache.flink.core.io.StringRecord
-
Construct from another text.
- StringRecord(byte[]) - Constructor for class org.apache.flink.core.io.StringRecord
-
Construct from a byte array.
- StringSerializer - Class in org.apache.flink.api.common.typeutils.base
-
- StringSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.StringSerializer
-
- StringUtils - Class in org.apache.flink.util
-
Utility class to convert objects into strings in vice-versa.
- StringValue - Class in org.apache.flink.types
-
Mutable string data type that implements the Key interface.
- StringValue() - Constructor for class org.apache.flink.types.StringValue
-
Initializes the encapsulated String object with an empty string.
- StringValue(CharSequence) - Constructor for class org.apache.flink.types.StringValue
-
Initializes this StringValue to the value of the given string.
- StringValue(StringValue) - Constructor for class org.apache.flink.types.StringValue
-
Initializes this StringValue to a copy the given StringValue.
- StringValue(StringValue, int, int) - Constructor for class org.apache.flink.types.StringValue
-
Initializes the StringValue to a sub-string of the given StringValue.
- StringValueParser - Class in org.apache.flink.types.parser
-
Converts a variable length field of a byte array into a
StringValue
.
- StringValueParser() - Constructor for class org.apache.flink.types.parser.StringValueParser
-
- StringValueSerializer - Class in org.apache.flink.api.common.typeutils.base
-
- StringValueSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.StringValueSerializer
-
- subList(int, int) - Method in class org.apache.flink.types.ListValue
-
- subSequence(int, int) - Method in class org.apache.flink.types.StringValue
-
- substring(int) - Method in class org.apache.flink.types.StringValue
-
Returns a new StringValuestring that is a substring of this string.
- substring(int, int) - Method in class org.apache.flink.types.StringValue
-
Returns a new StringValuestring that is a substring of this string.
- substring(StringValue, int) - Method in class org.apache.flink.types.StringValue
-
Copies a substring of this string into the given target StringValue.
- substring(StringValue, int, int) - Method in class org.apache.flink.types.StringValue
-
Copies a substring of this string into the given target StringValue.
- suffix(String) - Method in class org.apache.flink.core.fs.Path
-
Adds a suffix to the final name in the path.
- supportsCompareAgainstReference() - Method in class org.apache.flink.api.common.typeutils.record.RecordComparator
-
- supportsCompareAgainstReference() - Method in class org.apache.flink.api.common.typeutils.TypeComparator
-
- supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.BooleanComparator
-
- supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.ByteComparator
-
- supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.CharComparator
-
- supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.DateComparator
-
- supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.DoubleComparator
-
- supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.EnumComparator
-
- supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.FloatComparator
-
- supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.IntComparator
-
- supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.LongComparator
-
- supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.ShortComparator
-
- supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.StringComparator
-
- supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.record.RecordComparator
-
- supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.TypeComparator
-
Checks whether the data type supports the creation of a normalized key for comparison.
- supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.common.typeutils.base.BasicTypeComparator
-
- supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.common.typeutils.base.StringComparator
-
- supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.common.typeutils.record.RecordComparator
-
- supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.common.typeutils.TypeComparator
-
Check whether this comparator supports to serialize the record in a format that replaces its keys by a normalized
key.
- swapBytes(MemorySegment, MemorySegment, byte[], int, int, int) - Static method in class org.apache.flink.core.memory.MemorySegment
-