- AbstractID - Class in org.apache.flink.util
-
A statistically unique identification number.
- AbstractID(byte[]) - Constructor for class org.apache.flink.util.AbstractID
-
Constructs a new ID with a specific bytes value.
- AbstractID(long, long) - Constructor for class org.apache.flink.util.AbstractID
-
Constructs a new abstract ID.
- AbstractID(AbstractID) - Constructor for class org.apache.flink.util.AbstractID
-
Creates a new abstract ID from the given one.
- AbstractID() - Constructor for class org.apache.flink.util.AbstractID
-
Constructs a new random ID from a uniform distribution.
- AbstractRichFunction - Class in org.apache.flink.api.common.functions
-
An abstract stub implementation for rich user-defined functions.
- AbstractRichFunction() - Constructor for class org.apache.flink.api.common.functions.AbstractRichFunction
-
- AbstractRuntimeUDFContext - Class in org.apache.flink.api.common.functions.util
-
A standalone implementation of the
RuntimeContext
, created by runtime UDF operators.
- AbstractRuntimeUDFContext(TaskInfo, ClassLoader, ExecutionConfig, Map<String, Accumulator<?, ?>>, Map<String, Future<Path>>) - Constructor for class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
-
- AbstractUdfOperator<OUT,FT extends Function> - Class in org.apache.flink.api.common.operators
-
Abstract superclass for all contracts that represent actual operators.
- AbstractUdfOperator(UserCodeWrapper<FT>, OperatorInformation<OUT>, String) - Constructor for class org.apache.flink.api.common.operators.AbstractUdfOperator
-
Creates a new abstract operator with the given name wrapping the given user function.
- accept(Visitor<Operator<?>>) - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase.PartialSolutionPlaceHolder
-
- accept(Visitor<Operator<?>>) - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase.SolutionSetPlaceHolder
-
- accept(Visitor<Operator<?>>) - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase.WorksetPlaceHolder
-
- accept(Visitor<Operator<?>>) - Method in class org.apache.flink.api.common.operators.DualInputOperator
-
- accept(Visitor<Operator<?>>) - Method in class org.apache.flink.api.common.operators.GenericDataSinkBase
-
Accepts the visitor and applies it this instance.
- accept(Visitor<Operator<?>>) - Method in class org.apache.flink.api.common.operators.GenericDataSourceBase
-
Accepts the visitor and applies it this instance.
- accept(Visitor<Operator<?>>) - Method in class org.apache.flink.api.common.operators.SingleInputOperator
-
Accepts the visitor and applies it this instance.
- accept(Visitor<Operator<?>>) - Method in class org.apache.flink.api.common.Plan
-
Traverses the job depth first from all data sinks on towards the sources.
- accept(Visitor<T>) - Method in interface org.apache.flink.util.Visitable
-
Contains the logic to invoke the visitor and continue the traversal.
- acceptFile(FileStatus) - Method in class org.apache.flink.api.common.io.FileInputFormat
-
A simple hook to filter files and directories from the input.
- accessField(Field, Object) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoComparator
-
This method is handling the IllegalAccess exceptions of Field.get()
- Accumulator<V,R extends Serializable> - Interface in org.apache.flink.api.common.accumulators
-
Accumulators collect distributed statistics or aggregates in a from user functions
and operators.
- AccumulatorHelper - Class in org.apache.flink.api.common.accumulators
-
- AccumulatorHelper() - Constructor for class org.apache.flink.api.common.accumulators.AccumulatorHelper
-
- add(V) - Method in interface org.apache.flink.api.common.accumulators.Accumulator
-
- add(Double) - Method in class org.apache.flink.api.common.accumulators.AverageAccumulator
-
- add(double) - Method in class org.apache.flink.api.common.accumulators.AverageAccumulator
-
- add(long) - Method in class org.apache.flink.api.common.accumulators.AverageAccumulator
-
- add(int) - Method in class org.apache.flink.api.common.accumulators.AverageAccumulator
-
- add(Double) - Method in class org.apache.flink.api.common.accumulators.DoubleCounter
-
- add(double) - Method in class org.apache.flink.api.common.accumulators.DoubleCounter
-
- add(Integer) - Method in class org.apache.flink.api.common.accumulators.Histogram
-
- add(Integer) - Method in class org.apache.flink.api.common.accumulators.IntCounter
-
- add(int) - Method in class org.apache.flink.api.common.accumulators.IntCounter
-
- add(T) - Method in class org.apache.flink.api.common.accumulators.ListAccumulator
-
- add(Long) - Method in class org.apache.flink.api.common.accumulators.LongCounter
-
- add(long) - Method in class org.apache.flink.api.common.accumulators.LongCounter
-
- add(T) - Method in class org.apache.flink.api.common.accumulators.SerializedListAccumulator
-
- add(T, TypeSerializer<T>) - Method in class org.apache.flink.api.common.accumulators.SerializedListAccumulator
-
- add(IN) - Method in interface org.apache.flink.api.common.state.MergingState
-
Updates the operator state accessible by
MergingState.get()
by adding the given value
to the list of values.
- add() - Method in class org.apache.flink.api.java.tuple.builder.Tuple0Builder
-
- add(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9) - Method in class org.apache.flink.api.java.tuple.builder.Tuple10Builder
-
- add(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10) - Method in class org.apache.flink.api.java.tuple.builder.Tuple11Builder
-
- add(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11) - Method in class org.apache.flink.api.java.tuple.builder.Tuple12Builder
-
- add(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12) - Method in class org.apache.flink.api.java.tuple.builder.Tuple13Builder
-
- add(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13) - Method in class org.apache.flink.api.java.tuple.builder.Tuple14Builder
-
- add(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14) - Method in class org.apache.flink.api.java.tuple.builder.Tuple15Builder
-
- add(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15) - Method in class org.apache.flink.api.java.tuple.builder.Tuple16Builder
-
- add(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16) - Method in class org.apache.flink.api.java.tuple.builder.Tuple17Builder
-
- add(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17) - Method in class org.apache.flink.api.java.tuple.builder.Tuple18Builder
-
- add(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18) - Method in class org.apache.flink.api.java.tuple.builder.Tuple19Builder
-
- add(T0) - Method in class org.apache.flink.api.java.tuple.builder.Tuple1Builder
-
- add(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19) - Method in class org.apache.flink.api.java.tuple.builder.Tuple20Builder
-
- add(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20) - Method in class org.apache.flink.api.java.tuple.builder.Tuple21Builder
-
- add(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, T21) - Method in class org.apache.flink.api.java.tuple.builder.Tuple22Builder
-
- add(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, T21, T22) - Method in class org.apache.flink.api.java.tuple.builder.Tuple23Builder
-
- add(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, T21, T22, T23) - Method in class org.apache.flink.api.java.tuple.builder.Tuple24Builder
-
- add(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, T21, T22, T23, T24) - Method in class org.apache.flink.api.java.tuple.builder.Tuple25Builder
-
- add(T0, T1) - Method in class org.apache.flink.api.java.tuple.builder.Tuple2Builder
-
- add(T0, T1, T2) - Method in class org.apache.flink.api.java.tuple.builder.Tuple3Builder
-
- add(T0, T1, T2, T3) - Method in class org.apache.flink.api.java.tuple.builder.Tuple4Builder
-
- add(T0, T1, T2, T3, T4) - Method in class org.apache.flink.api.java.tuple.builder.Tuple5Builder
-
- add(T0, T1, T2, T3, T4, T5) - Method in class org.apache.flink.api.java.tuple.builder.Tuple6Builder
-
- add(T0, T1, T2, T3, T4, T5, T6) - Method in class org.apache.flink.api.java.tuple.builder.Tuple7Builder
-
- add(T0, T1, T2, T3, T4, T5, T6, T7) - Method in class org.apache.flink.api.java.tuple.builder.Tuple8Builder
-
- add(T0, T1, T2, T3, T4, T5, T6, T7, T8) - Method in class org.apache.flink.api.java.tuple.builder.Tuple9Builder
-
- add(int, V) - Method in class org.apache.flink.types.ListValue
-
- add(V) - Method in class org.apache.flink.types.ListValue
-
- addAccumulator(String, Accumulator<V, A>) - Method in interface org.apache.flink.api.common.functions.RuntimeContext
-
Add this accumulator.
- addAccumulator(String, Accumulator<V, A>) - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
-
- addAll(AggregatorRegistry) - Method in class org.apache.flink.api.common.aggregators.AggregatorRegistry
-
- addAll(Configuration) - Method in class org.apache.flink.configuration.Configuration
-
- addAll(Configuration, String) - Method in class org.apache.flink.configuration.Configuration
-
Adds all entries from the given configuration into this configuration.
- addAll(Configuration) - Method in class org.apache.flink.configuration.UnmodifiableConfiguration
-
- addAll(Configuration, String) - Method in class org.apache.flink.configuration.UnmodifiableConfiguration
-
- addAll(Collection<? extends V>) - Method in class org.apache.flink.types.ListValue
-
- addAll(int, Collection<? extends V>) - Method in class org.apache.flink.types.ListValue
-
- addComparatorField(int, TypeComparator<?>) - Method in interface org.apache.flink.api.common.typeutils.CompositeType.TypeComparatorBuilder
-
- addDataSink(GenericDataSinkBase<?>) - Method in class org.apache.flink.api.common.Plan
-
Adds a data sink to the set of sinks in this program.
- addDefaultKryoSerializer(Class<?>, T) - Method in class org.apache.flink.api.common.ExecutionConfig
-
Adds a new Kryo default serializer to the Runtime.
- addDefaultKryoSerializer(Class<?>, Class<? extends Serializer<?>>) - Method in class org.apache.flink.api.common.ExecutionConfig
-
Adds a new Kryo default serializer to the Runtime.
- addField(Integer) - Method in class org.apache.flink.api.common.operators.util.FieldList
-
- addField(Integer) - Method in class org.apache.flink.api.common.operators.util.FieldSet
-
- addField(Value) - Method in class org.apache.flink.types.Record
-
- addFields(int...) - Method in class org.apache.flink.api.common.operators.util.FieldList
-
- addFields(FieldSet) - Method in class org.apache.flink.api.common.operators.util.FieldList
-
- addFields(int...) - Method in class org.apache.flink.api.common.operators.util.FieldSet
-
- addFields(FieldSet) - Method in class org.apache.flink.api.common.operators.util.FieldSet
-
- addFirstInput(Operator<IN1>...) - Method in class org.apache.flink.api.common.operators.DualInputOperator
-
- addFirstInputs(List<Operator<IN1>>) - Method in class org.apache.flink.api.common.operators.DualInputOperator
-
- addForwardedField(int, int, int) - Method in class org.apache.flink.api.common.operators.DualInputSemanticProperties
-
Adds, to the existing information, a field that is forwarded directly
from the source record(s) in the first input to the destination
record(s).
- addForwardedField(int, int) - Method in class org.apache.flink.api.common.operators.SingleInputSemanticProperties
-
Adds, to the existing information, a field that is forwarded directly
from the source record(s) to the destination record(s).
- addForwardedField(int, int) - Method in class org.apache.flink.api.common.operators.SingleInputSemanticProperties.AllFieldsForwardedProperties
-
- addInput(Operator<IN>...) - Method in class org.apache.flink.api.common.operators.GenericDataSinkBase
-
- addInput(Operator<IN>...) - Method in class org.apache.flink.api.common.operators.SingleInputOperator
-
- addInput(List<Operator<IN>>) - Method in class org.apache.flink.api.common.operators.SingleInputOperator
-
- addInputs(List<? extends Operator<IN>>) - Method in class org.apache.flink.api.common.operators.GenericDataSinkBase
-
- addReadFields(int, FieldSet) - Method in class org.apache.flink.api.common.operators.DualInputSemanticProperties
-
Adds, to the existing information, field(s) that are read in
the source record(s) from the first input.
- addReadFields(FieldSet) - Method in class org.apache.flink.api.common.operators.SingleInputSemanticProperties
-
Adds, to the existing information, field(s) that are read in
the source record(s).
- address - Variable in class org.apache.flink.core.memory.MemorySegment
-
The address to the data, relative to the heap memory byte array.
- addressLimit - Variable in class org.apache.flink.core.memory.MemorySegment
-
The address one byte after the last addressable byte.
- addSecondInput(Operator<IN2>...) - Method in class org.apache.flink.api.common.operators.DualInputOperator
-
- addSecondInputs(List<Operator<IN2>>) - Method in class org.apache.flink.api.common.operators.DualInputOperator
-
- addUniqueField(FieldSet) - Method in class org.apache.flink.api.common.operators.CompilerHints
-
Adds a FieldSet to be unique
- addUniqueField(int) - Method in class org.apache.flink.api.common.operators.CompilerHints
-
Adds a field as having only unique values.
- addUniqueFields(Set<FieldSet>) - Method in class org.apache.flink.api.common.operators.CompilerHints
-
Adds multiple FieldSets to be unique
- aggregate(T) - Method in interface org.apache.flink.api.common.aggregators.Aggregator
-
Aggregates the given element.
- aggregate(DoubleValue) - Method in class org.apache.flink.api.common.aggregators.DoubleSumAggregator
-
- aggregate(double) - Method in class org.apache.flink.api.common.aggregators.DoubleSumAggregator
-
Adds the given value to the current aggregate.
- aggregate(LongValue) - Method in class org.apache.flink.api.common.aggregators.LongSumAggregator
-
- aggregate(long) - Method in class org.apache.flink.api.common.aggregators.LongSumAggregator
-
Adds the given value to the current aggregate.
- aggregate(long) - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase.TerminationCriterionAggregator
-
- aggregate(LongValue) - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase.TerminationCriterionAggregator
-
- Aggregator<T extends Value> - Interface in org.apache.flink.api.common.aggregators
-
Aggregators are a means of aggregating values across parallel instances of a function.
- AggregatorRegistry - Class in org.apache.flink.api.common.aggregators
-
- AggregatorRegistry() - Constructor for class org.apache.flink.api.common.aggregators.AggregatorRegistry
-
- AggregatorWithName<T extends Value> - Class in org.apache.flink.api.common.aggregators
-
Simple utility class holding an
Aggregator
with the name it is registered under.
- AggregatorWithName(String, Aggregator<T>) - Constructor for class org.apache.flink.api.common.aggregators.AggregatorWithName
-
Creates a new instance for the given aggregator and name.
- AKKA_ASK_TIMEOUT - Static variable in class org.apache.flink.configuration.ConfigConstants
-
Timeout for all blocking calls on the cluster side
- AKKA_CLIENT_TIMEOUT - Static variable in class org.apache.flink.configuration.ConfigConstants
-
Timeout for all blocking calls on the client side
- AKKA_DISPATCHER_THROUGHPUT - Static variable in class org.apache.flink.configuration.ConfigConstants
-
Maximum number of messages until another actor is executed by the same thread
- AKKA_FRAMESIZE - Static variable in class org.apache.flink.configuration.ConfigConstants
-
Maximum framesize of akka messages
- AKKA_JVM_EXIT_ON_FATAL_ERROR - Static variable in class org.apache.flink.configuration.ConfigConstants
-
Exit JVM on fatal Akka errors
- AKKA_LOG_LIFECYCLE_EVENTS - Static variable in class org.apache.flink.configuration.ConfigConstants
-
Log lifecycle events
- AKKA_LOOKUP_TIMEOUT - Static variable in class org.apache.flink.configuration.ConfigConstants
-
Timeout for all blocking calls that look up remote actors
- AKKA_STARTUP_TIMEOUT - Static variable in class org.apache.flink.configuration.ConfigConstants
-
Timeout for the startup of the actor system
- AKKA_TCP_TIMEOUT - Static variable in class org.apache.flink.configuration.ConfigConstants
-
Akka TCP timeout
- AKKA_TRANSPORT_HEARTBEAT_INTERVAL - Static variable in class org.apache.flink.configuration.ConfigConstants
-
Heartbeat interval of the transport failure detector
- AKKA_TRANSPORT_HEARTBEAT_PAUSE - Static variable in class org.apache.flink.configuration.ConfigConstants
-
Allowed heartbeat pause for the transport failure detector
- AKKA_TRANSPORT_THRESHOLD - Static variable in class org.apache.flink.configuration.ConfigConstants
-
Detection threshold of transport failure detector
- AKKA_WATCH_HEARTBEAT_INTERVAL - Static variable in class org.apache.flink.configuration.ConfigConstants
-
Heartbeat interval of watch failure detector
- AKKA_WATCH_HEARTBEAT_PAUSE - Static variable in class org.apache.flink.configuration.ConfigConstants
-
Allowed heartbeat pause for the watch failure detector
- AKKA_WATCH_THRESHOLD - Static variable in class org.apache.flink.configuration.ConfigConstants
-
Detection threshold for the phi accrual watch failure detector
- AllFieldsForwardedProperties() - Constructor for class org.apache.flink.api.common.operators.SingleInputSemanticProperties.AllFieldsForwardedProperties
-
- allocateUnpooledSegment(int, Object) - Method in class org.apache.flink.core.memory.HeapMemorySegment.HeapMemorySegmentFactory
-
- allocateUnpooledSegment(int, Object) - Method in class org.apache.flink.core.memory.HybridMemorySegment.HybridMemorySegmentFactory
-
- allocateUnpooledSegment(int) - Static method in class org.apache.flink.core.memory.MemorySegmentFactory
-
Allocates some unpooled memory and creates a new memory segment that represents
that memory.
- allocateUnpooledSegment(int, Object) - Static method in class org.apache.flink.core.memory.MemorySegmentFactory
-
Allocates some unpooled memory and creates a new memory segment that represents
that memory.
- allocateUnpooledSegment(int, Object) - Method in interface org.apache.flink.core.memory.MemorySegmentFactory.Factory
-
Allocates some unpooled memory and creates a new memory segment that represents
that memory.
- analyzePojo(Class<OUT>, ArrayList<Type>, ParameterizedType, TypeInformation<IN1>, TypeInformation<IN2>) - Method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
- append(char) - Method in class org.apache.flink.types.StringValue
-
- append(CharSequence) - Method in class org.apache.flink.types.StringValue
-
- append(CharSequence, int, int) - Method in class org.apache.flink.types.StringValue
-
- append(StringValue) - Method in class org.apache.flink.types.StringValue
-
- append(StringValue, int, int) - Method in class org.apache.flink.types.StringValue
-
- appendOrdering(Integer, Class<? extends Key<?>>, Order) - Method in class org.apache.flink.api.common.operators.Ordering
-
Extends this ordering by appending an additional order requirement.
- areCompatible(Keys<?>) - Method in class org.apache.flink.api.common.operators.Keys
-
Check if two sets of keys are compatible to each other (matching types, key counts)
- arity - Variable in class org.apache.flink.api.java.typeutils.runtime.TupleSerializerBase
-
- arrayAwareToString(Object) - Static method in class org.apache.flink.util.StringUtils
-
This method calls
Object.toString()
on the given object, unless the
object is an array.
- arrayNext() - Method in class org.apache.flink.api.java.typeutils.runtime.DataInputDecoder
-
- arrayToString(Object) - Static method in class org.apache.flink.util.StringUtils
-
Returns a string representation of the given array.
- asArray(Class<U>) - Static method in class org.apache.flink.api.common.operators.AbstractUdfOperator
-
Generic utility function that wraps a single class object into an array of that class type.
- ascending - Variable in class org.apache.flink.api.common.typeutils.base.array.PrimitiveArrayComparator
-
- ascendingComparison - Variable in class org.apache.flink.api.common.typeutils.base.BasicTypeComparator
-
- AtomicType<T> - Interface in org.apache.flink.api.common.typeinfo
-
An atomic type is a type that is treated as one indivisible unit and where the entire type acts
as a key.
- available() - Method in class org.apache.flink.core.fs.local.LocalDataInputStream
-
- AverageAccumulator - Class in org.apache.flink.api.common.accumulators
-
An accumulator that computes the average value.
- AverageAccumulator() - Constructor for class org.apache.flink.api.common.accumulators.AverageAccumulator
-
- AVG_RECORD_BYTES_UNKNOWN - Static variable in interface org.apache.flink.api.common.io.statistics.BaseStatistics
-
Constant indicating that average record width is unknown.
- avgBytesPerRecord - Variable in class org.apache.flink.api.common.io.FileInputFormat.FileBaseStatistics
-
- AvroSchemaSerializer() - Constructor for class org.apache.flink.api.java.typeutils.runtime.kryo.Serializers.AvroSchemaSerializer
-
- AvroSerializer<T> - Class in org.apache.flink.api.java.typeutils.runtime
-
General purpose serialization.
- AvroSerializer(Class<T>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.AvroSerializer
-
- AvroSerializer(Class<T>, Class<? extends T>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.AvroSerializer
-
- AvroTypeInfo<T extends org.apache.avro.specific.SpecificRecordBase> - Class in org.apache.flink.api.java.typeutils
-
Special type information to generate a special AvroTypeInfo for Avro POJOs (implementing SpecificRecordBase, the typed Avro POJOs)
Proceeding: It uses a regular pojo type analysis and replaces all GenericType<CharSequence>
with a GenericType<avro.Utf8>
.
- AvroTypeInfo(Class<T>) - Constructor for class org.apache.flink.api.java.typeutils.AvroTypeInfo
-
- cacheFile - Variable in class org.apache.flink.api.common.Plan
-
Hash map for files in the distributed cache: registered name to cache entry.
- canEqual(Object) - Method in class org.apache.flink.api.common.ExecutionConfig
-
- canEqual(Object) - Method in class org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
-
- canEqual(Object) - Method in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
-
- canEqual(Object) - Method in class org.apache.flink.api.common.typeinfo.NothingTypeInfo
-
- canEqual(Object) - Method in class org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
-
- canEqual(Object) - Method in class org.apache.flink.api.common.typeinfo.TypeInformation
-
Returns true if the given object can be equaled with this object.
- canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.array.BooleanPrimitiveArraySerializer
-
- canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.array.BytePrimitiveArraySerializer
-
- canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.array.CharPrimitiveArraySerializer
-
- canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.array.DoublePrimitiveArraySerializer
-
- canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.array.FloatPrimitiveArraySerializer
-
- canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.array.IntPrimitiveArraySerializer
-
- canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.array.LongPrimitiveArraySerializer
-
- canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.array.ShortPrimitiveArraySerializer
-
- canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.array.StringArraySerializer
-
- canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.BooleanSerializer
-
- canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueSerializer
-
- canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.ByteSerializer
-
- canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.ByteValueSerializer
-
- canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.CharSerializer
-
- canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.CharValueSerializer
-
- canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.DateSerializer
-
- canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.DoubleSerializer
-
- canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueSerializer
-
- canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.EnumSerializer
-
- canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.FloatSerializer
-
- canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.FloatValueSerializer
-
- canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.GenericArraySerializer
-
- canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.IntSerializer
-
- canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.IntValueSerializer
-
- canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.LongSerializer
-
- canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.LongValueSerializer
-
- canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.ShortSerializer
-
- canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.ShortValueSerializer
-
- canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.StringSerializer
-
- canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.StringValueSerializer
-
- canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.VoidSerializer
-
- canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.CompositeType
-
- canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.TypeSerializer
-
Returns true if the given object can be equaled with this object.
- canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.EitherTypeInfo
-
- canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.EnumTypeInfo
-
- canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.GenericTypeInfo
-
- canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.MissingTypeInfo
-
- canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.ObjectArrayTypeInfo
-
- canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.PojoField
-
- canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo
-
- canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.runtime.AvroSerializer
-
- canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer
-
- canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.runtime.EitherSerializer
-
- canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer
-
- canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer
-
- canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.runtime.Tuple0Serializer
-
- canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializerBase
-
- canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.runtime.ValueSerializer
-
- canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.runtime.WritableSerializer
-
- canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfo
-
- canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfoBase
-
- canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.ValueTypeInfo
-
- canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.WritableTypeInfo
-
- canReadInt() - Method in class org.apache.flink.api.java.typeutils.runtime.NoFetchingInput
-
- canReadLong() - Method in class org.apache.flink.api.java.typeutils.runtime.NoFetchingInput
-
- 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
-
- CHAR_VALUE_TYPE_INFO - Static variable in class org.apache.flink.api.java.typeutils.ValueTypeInfo
-
- 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
-
- CharPrimitiveArrayComparator - Class in org.apache.flink.api.common.typeutils.base.array
-
- CharPrimitiveArrayComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.array.CharPrimitiveArrayComparator
-
- 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
-
- checkAndCoSort(int[], Class<?>[]) - Static method in class org.apache.flink.api.common.io.GenericCsvInputFormat
-
- 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
-
- checkForMonotonousOrder(int[], Class<?>[]) - Static method in class org.apache.flink.api.common.io.GenericCsvInputFormat
-
- ClassLoaderObjectInputStream(InputStream, ClassLoader) - Constructor for class org.apache.flink.util.InstantiationUtil.ClassLoaderObjectInputStream
-
- 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 interface org.apache.flink.api.common.state.State
-
Removes the value mapped under the current key.
- 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.
- 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 interface org.apache.flink.api.common.accumulators.Accumulator
-
Duplicates the accumulator.
- clone() - Method in class org.apache.flink.api.common.accumulators.AverageAccumulator
-
- clone() - Method in class org.apache.flink.api.common.accumulators.DoubleCounter
-
- clone() - Method in class org.apache.flink.api.common.accumulators.Histogram
-
- clone() - Method in class org.apache.flink.api.common.accumulators.IntCounter
-
- clone() - Method in class org.apache.flink.api.common.accumulators.ListAccumulator
-
- clone() - Method in class org.apache.flink.api.common.accumulators.LongCounter
-
- clone() - Method in class org.apache.flink.api.common.accumulators.SerializedListAccumulator
-
- 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.
- clone() - Method in class org.apache.flink.configuration.Configuration
-
- clone(T) - Static method in class org.apache.flink.util.InstantiationUtil
-
Clones the given serializable object using Java serialization.
- clone(T, ClassLoader) - Static method in class org.apache.flink.util.InstantiationUtil
-
Clones the given serializable object using Java serialization, using the given classloader to
resolve the cloned classes.
- close() - Method in class org.apache.flink.api.common.functions.AbstractRichFunction
-
- close() - Method in interface org.apache.flink.api.common.functions.RichFunction
-
Tear-down 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.GenericCsvInputFormat
-
- 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.api.common.io.ReplicatingInputFormat
-
- 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 interface org.apache.flink.util.Collector
-
Closes the collector.
- closeFunction(Function) - Static method in class org.apache.flink.api.common.functions.util.FunctionUtils
-
- CodeAnalysisMode - Enum in org.apache.flink.api.common
-
Specifies to which extent user-defined functions are analyzed in order
to give the Flink optimizer an insight of UDF internals and inform
the user about common implementation mistakes.
- 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
-
- CoGroupRawOperatorBase<IN1,IN2,OUT,FT extends CoGroupFunction<IN1,IN2,OUT>> - Class in org.apache.flink.api.common.operators.base
-
- CoGroupRawOperatorBase(UserCodeWrapper<FT>, BinaryOperatorInformation<IN1, IN2, OUT>, int[], int[], String) - Constructor for class org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase
-
- CoGroupRawOperatorBase(FT, BinaryOperatorInformation<IN1, IN2, OUT>, int[], int[], String) - Constructor for class org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase
-
- CoGroupRawOperatorBase(Class<? extends FT>, BinaryOperatorInformation<IN1, IN2, OUT>, int[], int[], String) - Constructor for class org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase
-
- CoGroupRawOperatorBase.SimpleListIterable<IN> - Class in org.apache.flink.api.common.operators.base
-
- CoGroupRawOperatorBase.SimpleListIterable.SimpleListIterator<IN> - Class in org.apache.flink.api.common.operators.base
-
- 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(ExecutionConfig) - Constructor for class org.apache.flink.api.common.operators.CollectionExecutor
-
- Collector<T> - Interface in org.apache.flink.util
-
Collects a record and forwards it.
- combine(Iterable<IN>) - Method in interface org.apache.flink.api.common.functions.CombineFunction
-
The combine method, called (potentially multiple timed) with subgroups of elements.
- combine(Iterable<IN>, Collector<OUT>) - Method in interface org.apache.flink.api.common.functions.GroupCombineFunction
-
The combine method, called (potentially multiple timed) with subgroups of elements.
- combine(Iterable<IN>, Collector<OUT>) - Method in class org.apache.flink.api.common.functions.RichGroupCombineFunction
-
- CombineFunction<IN,OUT> - Interface in org.apache.flink.api.common.functions
-
Generic interface used for combine functions ("combiners").
- commentCount - Variable in class org.apache.flink.api.common.io.GenericCsvInputFormat
-
- commentPrefix - Variable in class org.apache.flink.api.common.io.GenericCsvInputFormat
-
- CommonRangeBoundaries<T> - Class in org.apache.flink.api.common.distributions
-
- CommonRangeBoundaries(TypeComparator<T>, Object[][]) - Constructor for class org.apache.flink.api.common.distributions.CommonRangeBoundaries
-
- comparator - Variable in class org.apache.flink.api.common.typeutils.base.array.PrimitiveArrayComparator
-
- comparators - Variable in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
-
comparators for the key fields, in the same order as the key fields
- compare(boolean[], boolean[]) - Method in class org.apache.flink.api.common.typeutils.base.array.BooleanPrimitiveArrayComparator
-
- compare(byte[], byte[]) - Method in class org.apache.flink.api.common.typeutils.base.array.BytePrimitiveArrayComparator
-
- compare(char[], char[]) - Method in class org.apache.flink.api.common.typeutils.base.array.CharPrimitiveArrayComparator
-
- compare(double[], double[]) - Method in class org.apache.flink.api.common.typeutils.base.array.DoublePrimitiveArrayComparator
-
- compare(float[], float[]) - Method in class org.apache.flink.api.common.typeutils.base.array.FloatPrimitiveArrayComparator
-
- compare(int[], int[]) - Method in class org.apache.flink.api.common.typeutils.base.array.IntPrimitiveArrayComparator
-
- compare(long[], long[]) - Method in class org.apache.flink.api.common.typeutils.base.array.LongPrimitiveArrayComparator
-
- compare(short[], short[]) - Method in class org.apache.flink.api.common.typeutils.base.array.ShortPrimitiveArrayComparator
-
- compare(T, T) - Method in class org.apache.flink.api.common.typeutils.base.BasicTypeComparator
-
- compare(T, T) - Method in class org.apache.flink.api.common.typeutils.TypeComparator
-
Compares two records in serialized from.
- compare(T, T) - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueComparator
-
- compare(T, T) - Method in class org.apache.flink.api.java.typeutils.runtime.GenericTypeComparator
-
- compare(T, T) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoComparator
-
- compare(T, T) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparator
-
- compare(T, T) - Method in class org.apache.flink.api.java.typeutils.runtime.ValueComparator
-
- compare(T, T) - Method in class org.apache.flink.api.java.typeutils.runtime.WritableComparator
-
- compare(MemorySegment, int, int, int) - Method in class org.apache.flink.core.memory.MemorySegment
-
Compares two memory segment regions.
- 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.TypeComparator
-
- compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.array.PrimitiveArrayComparator
-
- 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.TypeComparator
-
Compares two records in serialized from.
- compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueComparator
-
- compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.GenericTypeComparator
-
- compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoComparator
-
- compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
-
- compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.ValueComparator
-
- compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.WritableComparator
-
- 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
-
- compareTo(AbstractID) - Method in class org.apache.flink.util.AbstractID
-
- compareToReference(TypeComparator<T>) - Method in class org.apache.flink.api.common.typeutils.base.array.PrimitiveArrayComparator
-
- 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<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
-
- compareToReference(TypeComparator<T>) - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueComparator
-
- compareToReference(TypeComparator<T>) - Method in class org.apache.flink.api.java.typeutils.runtime.GenericTypeComparator
-
- compareToReference(TypeComparator<T>) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoComparator
-
- compareToReference(TypeComparator<T>) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
-
- compareToReference(TypeComparator<T>) - Method in class org.apache.flink.api.java.typeutils.runtime.ValueComparator
-
- compareToReference(TypeComparator<T>) - Method in class org.apache.flink.api.java.typeutils.runtime.WritableComparator
-
- 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
-
Base type information class 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
-
- CompositeType.InvalidFieldReferenceException - Exception in org.apache.flink.api.common.typeutils
-
- CompositeType.TypeComparatorBuilder<T> - Interface 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
-
- computeLogicalKeyPositions() - Method in class org.apache.flink.api.common.operators.Keys
-
- computeLogicalKeyPositions() - Method in class org.apache.flink.api.common.operators.Keys.ExpressionKeys
-
- computeLogicalKeyPositions() - Method in class org.apache.flink.api.common.operators.Keys.SelectorFunctionKeys
-
- concatenate(Record) - Method in class org.apache.flink.types.Record
-
- CONFIG_KEY - Static variable in class org.apache.flink.api.common.ExecutionConfig
-
- 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 stores key/value pairs.
- Configuration() - Constructor for class org.apache.flink.configuration.Configuration
-
Creates a new empty configuration.
- Configuration(Configuration) - Constructor for class org.apache.flink.configuration.Configuration
-
Creates a new configuration with the copy of the given 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.
- configure(Configuration) - Method in class org.apache.flink.api.common.io.ReplicatingInputFormat
-
- 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(Map<String, Accumulator<?, ?>>) - Static method in class org.apache.flink.api.common.accumulators.AccumulatorHelper
-
- 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(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() - Method in class org.apache.flink.api.java.tuple.Tuple
-
Shallow tuple copy.
- copy() - Method in class org.apache.flink.api.java.tuple.Tuple0
-
Shallow tuple copy.
- copy() - Method in class org.apache.flink.api.java.tuple.Tuple1
-
Shallow tuple copy.
- copy() - Method in class org.apache.flink.api.java.tuple.Tuple10
-
Shallow tuple copy.
- copy() - Method in class org.apache.flink.api.java.tuple.Tuple11
-
Shallow tuple copy.
- copy() - Method in class org.apache.flink.api.java.tuple.Tuple12
-
Shallow tuple copy.
- copy() - Method in class org.apache.flink.api.java.tuple.Tuple13
-
Shallow tuple copy.
- copy() - Method in class org.apache.flink.api.java.tuple.Tuple14
-
Shallow tuple copy.
- copy() - Method in class org.apache.flink.api.java.tuple.Tuple15
-
Shallow tuple copy.
- copy() - Method in class org.apache.flink.api.java.tuple.Tuple16
-
Shallow tuple copy.
- copy() - Method in class org.apache.flink.api.java.tuple.Tuple17
-
Shallow tuple copy.
- copy() - Method in class org.apache.flink.api.java.tuple.Tuple18
-
Shallow tuple copy.
- copy() - Method in class org.apache.flink.api.java.tuple.Tuple19
-
Shallow tuple copy.
- copy() - Method in class org.apache.flink.api.java.tuple.Tuple2
-
Shallow tuple copy.
- copy() - Method in class org.apache.flink.api.java.tuple.Tuple20
-
Shallow tuple copy.
- copy() - Method in class org.apache.flink.api.java.tuple.Tuple21
-
Shallow tuple copy.
- copy() - Method in class org.apache.flink.api.java.tuple.Tuple22
-
Shallow tuple copy.
- copy() - Method in class org.apache.flink.api.java.tuple.Tuple23
-
Shallow tuple copy.
- copy() - Method in class org.apache.flink.api.java.tuple.Tuple24
-
Shallow tuple copy.
- copy() - Method in class org.apache.flink.api.java.tuple.Tuple25
-
Shallow tuple copy.
- copy() - Method in class org.apache.flink.api.java.tuple.Tuple3
-
Shallow tuple copy.
- copy() - Method in class org.apache.flink.api.java.tuple.Tuple4
-
Shallow tuple copy.
- copy() - Method in class org.apache.flink.api.java.tuple.Tuple5
-
Shallow tuple copy.
- copy() - Method in class org.apache.flink.api.java.tuple.Tuple6
-
Shallow tuple copy.
- copy() - Method in class org.apache.flink.api.java.tuple.Tuple7
-
Shallow tuple copy.
- copy() - Method in class org.apache.flink.api.java.tuple.Tuple8
-
Shallow tuple copy.
- copy() - Method in class org.apache.flink.api.java.tuple.Tuple9
-
Shallow tuple copy.
- copy(T) - Method in class org.apache.flink.api.java.typeutils.runtime.AvroSerializer
-
- copy(T, T) - Method in class org.apache.flink.api.java.typeutils.runtime.AvroSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.AvroSerializer
-
- copy(T) - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer
-
- copy(T, T) - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer
-
- copy(Either<L, R>) - Method in class org.apache.flink.api.java.typeutils.runtime.EitherSerializer
-
- copy(Either<L, R>, Either<L, R>) - Method in class org.apache.flink.api.java.typeutils.runtime.EitherSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.EitherSerializer
-
- copy(T) - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer
-
- copy(T, T) - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer
-
- copy(T, Kryo, TypeSerializer<T>) - Static method in class org.apache.flink.api.java.typeutils.runtime.KryoUtils
-
Tries to copy the given record from using the provided Kryo instance.
- copy(T, T, Kryo, TypeSerializer<T>) - Static method in class org.apache.flink.api.java.typeutils.runtime.KryoUtils
-
Tries to copy the given record from using the provided Kryo instance.
- copy(T) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer
-
- copy(T, T) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer
-
- copy(Tuple0) - Method in class org.apache.flink.api.java.typeutils.runtime.Tuple0Serializer
-
- copy(Tuple0, Tuple0) - Method in class org.apache.flink.api.java.typeutils.runtime.Tuple0Serializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.Tuple0Serializer
-
- copy(T) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializer
-
- copy(T, T) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializerBase
-
- copy(T) - Method in class org.apache.flink.api.java.typeutils.runtime.ValueSerializer
-
- copy(T, T) - Method in class org.apache.flink.api.java.typeutils.runtime.ValueSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.ValueSerializer
-
- copy(T) - Method in class org.apache.flink.api.java.typeutils.runtime.WritableSerializer
-
- copy(T, T) - Method in class org.apache.flink.api.java.typeutils.runtime.WritableSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.WritableSerializer
-
- copy() - Method in class org.apache.flink.types.BooleanValue
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.types.BooleanValue
-
- copy() - Method in class org.apache.flink.types.ByteValue
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.types.ByteValue
-
- copy() - Method in class org.apache.flink.types.CharValue
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.types.CharValue
-
- copy() - Method in interface org.apache.flink.types.CopyableValue
-
Performs a deep copy of this object into a new instance.
- copy(DataInputView, DataOutputView) - Method in interface org.apache.flink.types.CopyableValue
-
Copies the next serialized instance from source
to target
.
- copy() - Method in class org.apache.flink.types.DoubleValue
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.types.DoubleValue
-
- copy() - Method in class org.apache.flink.types.FloatValue
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.types.FloatValue
-
- copy() - Method in class org.apache.flink.types.IntValue
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.types.IntValue
-
- copy() - Method in class org.apache.flink.types.LongValue
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.types.LongValue
-
- copy() - Method in class org.apache.flink.types.NullValue
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.types.NullValue
-
- copy() - Method in class org.apache.flink.types.Record
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.types.Record
-
- copy() - Method in class org.apache.flink.types.ShortValue
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.types.ShortValue
-
- copy() - Method in class org.apache.flink.types.StringValue
-
- 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.
- CopyableValueComparator<T extends CopyableValue<T> & Comparable<T>> - Class in org.apache.flink.api.java.typeutils.runtime
-
Comparator for all Value types that extend Key
- CopyableValueComparator(boolean, Class<T>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.CopyableValueComparator
-
- CopyableValueSerializer<T extends CopyableValue<T>> - Class in org.apache.flink.api.java.typeutils.runtime
-
- CopyableValueSerializer(Class<T>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer
-
- 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
-
Performs a deep copy of this object into the target
instance.
- 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(InputStream) - Method in class org.apache.flink.api.common.io.compression.DeflateInflaterInputStreamFactory
-
- create(InputStream) - Method in class org.apache.flink.api.common.io.compression.GzipInflaterInputStreamFactory
-
- create(InputStream) - Method in interface org.apache.flink.api.common.io.compression.InflaterInputStreamFactory
-
- create(Kryo, Input, Class<Collection>) - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.Serializers.SpecificInstanceCollectionSerializer
-
- 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, ExecutionConfig) - Method in interface org.apache.flink.api.common.typeinfo.AtomicType
-
Creates a comparator for this type.
- createComparator(boolean, ExecutionConfig) - Method in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
-
- createComparator(boolean, ExecutionConfig) - Method in class org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
-
- createComparator(int[], boolean[], int, ExecutionConfig) - Method in class org.apache.flink.api.common.typeutils.CompositeType
-
Generic implementation of the comparator creation.
- createComparator() - Method in interface org.apache.flink.api.common.typeutils.TypeComparatorFactory
-
- createComparator(boolean, ExecutionConfig) - Method in class org.apache.flink.api.java.typeutils.EnumTypeInfo
-
- createComparator(boolean, ExecutionConfig) - Method in class org.apache.flink.api.java.typeutils.GenericTypeInfo
-
- createComparator() - Method in class org.apache.flink.api.java.typeutils.runtime.RuntimeComparatorFactory
-
- createComparator(boolean, ExecutionConfig) - Method in class org.apache.flink.api.java.typeutils.ValueTypeInfo
-
- createComparator(boolean, ExecutionConfig) - Method in class org.apache.flink.api.java.typeutils.WritableTypeInfo
-
- createComparator12(TypeComparator<T1>, TypeComparator<T2>) - Method in interface org.apache.flink.api.common.typeutils.TypePairComparatorFactory
-
- createComparator12(TypeComparator<T1>, TypeComparator<T2>) - Method in class org.apache.flink.api.java.typeutils.runtime.RuntimePairComparatorFactory
-
- createComparator21(TypeComparator<T1>, TypeComparator<T2>) - Method in interface org.apache.flink.api.common.typeutils.TypePairComparatorFactory
-
- createComparator21(TypeComparator<T1>, TypeComparator<T2>) - Method in class org.apache.flink.api.java.typeutils.runtime.RuntimePairComparatorFactory
-
- createCopy(Kryo, Collection) - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.Serializers.SpecificInstanceCollectionSerializer
-
- createCopy() - Method in class org.apache.flink.types.Record
-
Creates an exact copy of this record.
- createFoldingState(FoldingStateDescriptor<T, ACC>) - Method in interface org.apache.flink.api.common.state.StateBackend
-
- 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 class org.apache.flink.api.common.io.ReplicatingInputFormat
-
- 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.TypeSerializer
-
Creates a new instance of the data type.
- createInstance() - Method in class org.apache.flink.api.java.typeutils.runtime.AvroSerializer
-
- createInstance() - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer
-
- createInstance() - Method in class org.apache.flink.api.java.typeutils.runtime.EitherSerializer
-
- createInstance() - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer
-
- createInstance() - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer
-
- createInstance() - Method in class org.apache.flink.api.java.typeutils.runtime.Tuple0Serializer
-
- createInstance(Object[]) - Method in class org.apache.flink.api.java.typeutils.runtime.Tuple0Serializer
-
- createInstance() - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializer
-
- createInstance(Object[]) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializer
-
- createInstance(Object[]) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializerBase
-
- createInstance() - Method in class org.apache.flink.api.java.typeutils.runtime.ValueSerializer
-
- createInstance() - Method in class org.apache.flink.api.java.typeutils.runtime.WritableSerializer
-
- createListState(ListStateDescriptor<T>) - Method in interface org.apache.flink.api.common.state.StateBackend
-
- createLocalExecutor(Configuration) - 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.
- createOrReuseInstance(Object[], T) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializer
-
- createOrReuseInstance(Object[], T) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializerBase
-
- createProber(TypeComparator<PT>, TypePairComparator<PT, BT>) - Method in class org.apache.flink.api.common.operators.util.JoinHashMap
-
- createReducingState(ReducingStateDescriptor<T>) - Method in interface org.apache.flink.api.common.state.StateBackend
-
- createRemoteExecutor(String, int, Configuration, URL[], URL[]) - Static method in class org.apache.flink.api.common.PlanExecutor
-
Creates an executor that runs the plan on a remote environment.
- createSerializer(ExecutionConfig) - Method in class org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
-
- createSerializer(ExecutionConfig) - Method in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
-
- createSerializer(ExecutionConfig) - Method in class org.apache.flink.api.common.typeinfo.NothingTypeInfo
-
- createSerializer(ExecutionConfig) - Method in class org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
-
- createSerializer(ExecutionConfig) - Method in class org.apache.flink.api.common.typeinfo.TypeInformation
-
Creates a serializer for the type.
- createSerializer(ExecutionConfig) - Method in class org.apache.flink.api.java.typeutils.EitherTypeInfo
-
- createSerializer(ExecutionConfig) - Method in class org.apache.flink.api.java.typeutils.EnumTypeInfo
-
- createSerializer(ExecutionConfig) - Method in class org.apache.flink.api.java.typeutils.GenericTypeInfo
-
- createSerializer(ExecutionConfig) - Method in class org.apache.flink.api.java.typeutils.MissingTypeInfo
-
- createSerializer(ExecutionConfig) - Method in class org.apache.flink.api.java.typeutils.ObjectArrayTypeInfo
-
- createSerializer(ExecutionConfig) - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo
-
- createSerializer(ExecutionConfig) - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfo
-
- createSerializer(ExecutionConfig) - Method in class org.apache.flink.api.java.typeutils.ValueTypeInfo
-
- createSerializer(ExecutionConfig) - Method in class org.apache.flink.api.java.typeutils.WritableTypeInfo
-
- createSocket(int) - Method in interface org.apache.flink.util.NetUtils.SocketFactory
-
- createSocketFromPorts(Iterator<Integer>, NetUtils.SocketFactory) - Static method in class org.apache.flink.util.NetUtils
-
Tries to allocate a socket from the given sets of ports.
- createStatistics(List<FileStatus>, FileInputFormat.FileBaseStatistics) - Method in class org.apache.flink.api.common.io.BinaryInputFormat
-
Fill in the statistics.
- createTypeComparator(ExecutionConfig) - Method in interface org.apache.flink.api.common.typeutils.CompositeType.TypeComparatorBuilder
-
- createTypeComparatorBuilder() - Method in class org.apache.flink.api.common.typeutils.CompositeType
-
- createTypeComparatorBuilder() - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo
-
- createTypeComparatorBuilder() - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfo
-
- createTypeInfo(Class<T>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
- createTypeInfo(Type) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
- createTypeInfo(Object, Class<?>, Class<?>, int) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
- createTypeInfo(Class<?>, Class<?>, int, TypeInformation<IN1>, TypeInformation<IN2>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
- 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.BooleanParser
-
- createValue() - Method in class org.apache.flink.types.parser.BooleanValueParser
-
- 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
-
- createValueState(ValueStateDescriptor<T>) - Method in interface org.apache.flink.api.common.state.StateBackend
-
- 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.CrossHint - Enum in org.apache.flink.api.common.operators.base
-
The cross hint tells the system which sizes to expect from the data sets
- 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.
- currentSplit - Variable in class org.apache.flink.api.common.io.FileInputFormat
-
The current split that this parallel instance must consume.
- DataDistribution - Interface in org.apache.flink.api.common.distributions
-
- DataInputDecoder - Class in org.apache.flink.api.java.typeutils.runtime
-
- DataInputDecoder() - Constructor for class org.apache.flink.api.java.typeutils.runtime.DataInputDecoder
-
- 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.api.java.typeutils.runtime
-
- DataInputViewStream(DataInputView) - Constructor for class org.apache.flink.api.java.typeutils.runtime.DataInputViewStream
-
- DataInputViewStreamWrapper - Class in org.apache.flink.core.memory
-
- DataInputViewStreamWrapper(InputStream) - Constructor for class org.apache.flink.core.memory.DataInputViewStreamWrapper
-
- DataOutputEncoder - Class in org.apache.flink.api.java.typeutils.runtime
-
- DataOutputEncoder() - Constructor for class org.apache.flink.api.java.typeutils.runtime.DataOutputEncoder
-
- 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.api.java.typeutils.runtime
-
- DataOutputViewStream(DataOutputView) - Constructor for class org.apache.flink.api.java.typeutils.runtime.DataOutputViewStream
-
- DataOutputViewStreamWrapper - Class in org.apache.flink.core.memory
-
- DataOutputViewStreamWrapper(OutputStream) - Constructor for class org.apache.flink.core.memory.DataOutputViewStreamWrapper
-
- 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
-
- decorateInputStream(FSDataInputStream, FileInputSplit) - Method in class org.apache.flink.api.common.io.FileInputFormat
-
This method allows to wrap/decorate the raw
FSDataInputStream
for a certain file split, e.g., for decoding.
- DEFAULT_AKKA_ASK_TIMEOUT - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- DEFAULT_AKKA_CLIENT_TIMEOUT - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- DEFAULT_AKKA_DISPATCHER_THROUGHPUT - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- DEFAULT_AKKA_FRAMESIZE - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- DEFAULT_AKKA_LOG_LIFECYCLE_EVENTS - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- DEFAULT_AKKA_LOOKUP_TIMEOUT - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- DEFAULT_AKKA_TRANSPORT_HEARTBEAT_INTERVAL - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- DEFAULT_AKKA_TRANSPORT_HEARTBEAT_PAUSE - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- DEFAULT_AKKA_TRANSPORT_THRESHOLD - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- DEFAULT_AKKA_WATCH_THRESHOLD - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- DEFAULT_BLOB_FETCH_BACKLOG - Static variable in class org.apache.flink.configuration.ConfigConstants
-
Default BLOB fetch connection backlog.
- DEFAULT_BLOB_FETCH_CONCURRENT - Static variable in class org.apache.flink.configuration.ConfigConstants
-
Default number of concurrent BLOB fetch operations.
- DEFAULT_BLOB_FETCH_RETRIES - Static variable in class org.apache.flink.configuration.ConfigConstants
-
Default number of retries for failed BLOB fetches.
- DEFAULT_BLOB_SERVER_PORT - Static variable in class org.apache.flink.configuration.ConfigConstants
-
Default BLOB server port.
- 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_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_FILESYSTEM_SCHEME - Static variable in class org.apache.flink.configuration.ConfigConstants
-
The default filesystem to be used, if no other scheme is specified in the
user-provided URI (= local filesystem)
- 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_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_BACK_PRESSURE_CLEAN_UP_INTERVAL - Static variable in class org.apache.flink.configuration.ConfigConstants
-
Time after which cached stats are cleaned up.
- DEFAULT_JOB_MANAGER_WEB_BACK_PRESSURE_DELAY - Static variable in class org.apache.flink.configuration.ConfigConstants
-
Delay between samples to determine back pressure.
- DEFAULT_JOB_MANAGER_WEB_BACK_PRESSURE_NUM_SAMPLES - Static variable in class org.apache.flink.configuration.ConfigConstants
-
Number of samples to take to determine back pressure.
- DEFAULT_JOB_MANAGER_WEB_BACK_PRESSURE_REFRESH_INTERVAL - Static variable in class org.apache.flink.configuration.ConfigConstants
-
Time after which available stats are deprecated and need to be refreshed (by resampling).
- DEFAULT_JOB_MANAGER_WEB_CHECKPOINTS_DISABLE - Static variable in class org.apache.flink.configuration.ConfigConstants
-
Default flag to disable checkpoint stats.
- DEFAULT_JOB_MANAGER_WEB_CHECKPOINTS_HISTORY_SIZE - Static variable in class org.apache.flink.configuration.ConfigConstants
-
Default number of checkpoints to remember for recent history.
- DEFAULT_JOB_MANAGER_WEB_FRONTEND_PORT - Static variable in class org.apache.flink.configuration.ConfigConstants
-
The config key for the port of the JobManager web frontend.
- DEFAULT_JOB_MANAGER_WEB_SUBMIT_ENABLED - Static variable in class org.apache.flink.configuration.ConfigConstants
-
By default, submitting jobs from the web-frontend is allowed.
- 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_LOCAL_NUMBER_JOB_MANAGER - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- DEFAULT_LOCAL_NUMBER_TASK_MANAGER - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- 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_PARALLELISM - Static variable in class org.apache.flink.configuration.ConfigConstants
-
The default parallelism for operations.
- DEFAULT_PARALLELISM_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
-
The config parameter defining the default parallelism for jobs.
- DEFAULT_RECOVERY_JOB_MANAGER_PORT - Static variable in class org.apache.flink.configuration.ConfigConstants
-
Default port used by the job manager if not in standalone recovery mode.
- DEFAULT_RECOVERY_MODE - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- DEFAULT_RUNTIME_HASH_JOIN_BLOOM_FILTERS - Static variable in class org.apache.flink.configuration.ConfigConstants
-
Default setting for the switch for hash join bloom filters for spilled partitions.
- 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_STATE_BACKEND - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- 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_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_MAX_REGISTRATION_DURATION - Static variable in class org.apache.flink.configuration.ConfigConstants
-
The default task manager's maximum registration duration
- DEFAULT_TASK_MANAGER_MEMORY_PRE_ALLOCATE - Static variable in class org.apache.flink.configuration.ConfigConstants
-
The default setting for TaskManager memory eager allocation of managed memory
- DEFAULT_TASK_MANAGER_MEMORY_SEGMENT_SIZE - Static variable in class org.apache.flink.configuration.ConfigConstants
-
Default size of memory segments in the network stack and the memory manager.
- DEFAULT_TASK_MANAGER_NETWORK_DEFAULT_IO_MODE - Static variable in class org.apache.flink.configuration.ConfigConstants
-
The implementation to use for spillable/spilled intermediate results, which have both
synchronous and asynchronous implementations: "sync" or "async".
- 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_YARN_APPLICATION_MASTER_PORT - Static variable in class org.apache.flink.configuration.ConfigConstants
-
Default port for the application master is 0, which means
the operating system assigns an ephemeral port
- DEFAULT_YARN_HEAP_CUTOFF_RATIO - Static variable in class org.apache.flink.configuration.ConfigConstants
-
Relative amount of memory to subtract from the requested memory.
- DEFAULT_YARN_MIN_HEAP_CUTOFF - Static variable in class org.apache.flink.configuration.ConfigConstants
-
Minimum amount of Heap memory to subtract from the requested TaskManager size.
- DEFAULT_ZOOKEEPER_CHECKPOINT_COUNTER_PATH - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- DEFAULT_ZOOKEEPER_CHECKPOINTS_PATH - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- DEFAULT_ZOOKEEPER_CLIENT_PORT - Static variable in class org.apache.flink.configuration.ConfigConstants
-
ZooKeeper default client port.
- DEFAULT_ZOOKEEPER_CONNECTION_TIMEOUT - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- DEFAULT_ZOOKEEPER_DIR_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- DEFAULT_ZOOKEEPER_INIT_LIMIT - Static variable in class org.apache.flink.configuration.ConfigConstants
-
ZooKeeper default init limit.
- DEFAULT_ZOOKEEPER_JOBGRAPHS_PATH - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- DEFAULT_ZOOKEEPER_LATCH_PATH - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- DEFAULT_ZOOKEEPER_LEADER_PATH - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- DEFAULT_ZOOKEEPER_LEADER_PORT - Static variable in class org.apache.flink.configuration.ConfigConstants
-
ZooKeeper default leader port.
- DEFAULT_ZOOKEEPER_MAX_RETRY_ATTEMPTS - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- DEFAULT_ZOOKEEPER_PEER_PORT - Static variable in class org.apache.flink.configuration.ConfigConstants
-
ZooKeeper default peer port.
- DEFAULT_ZOOKEEPER_RETRY_WAIT - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- DEFAULT_ZOOKEEPER_SESSION_TIMEOUT - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- DEFAULT_ZOOKEEPER_SYNC_LIMIT - Static variable in class org.apache.flink.configuration.ConfigConstants
-
ZooKeeper default sync limit.
- 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.
- DeflateInflaterInputStreamFactory - Class in org.apache.flink.api.common.io.compression
-
Factory for input streams that decompress the "deflate" compression format.
- DeflateInflaterInputStreamFactory() - Constructor for class org.apache.flink.api.common.io.compression.DeflateInflaterInputStreamFactory
-
- 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
-
- delimiterNext(byte[], int, byte[]) - Static method in class org.apache.flink.types.parser.FieldParser
-
Checks if the delimiter starts at the given start position of the byte array.
- 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.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.api.java.typeutils.runtime.AvroSerializer
-
- deserialize(T, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.AvroSerializer
-
- deserialize(DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer
-
- deserialize(T, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer
-
- deserialize(DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.EitherSerializer
-
- deserialize(Either<L, R>, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.EitherSerializer
-
- deserialize(DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer
-
- deserialize(T, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer
-
- deserialize(DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer
-
- deserialize(T, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer
-
- deserialize(DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.Tuple0Serializer
-
- deserialize(Tuple0, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.Tuple0Serializer
-
- deserialize(DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializer
-
- deserialize(T, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializer
-
- deserialize(DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.ValueSerializer
-
- deserialize(T, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.ValueSerializer
-
- deserialize(DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.WritableSerializer
-
- deserialize(T, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.WritableSerializer
-
- deserialize(DataInputView) - Method in class org.apache.flink.types.Record
-
- deserializeAccumulators(Map<String, SerializedValue<Object>>, ClassLoader) - Static method in class org.apache.flink.api.common.accumulators.AccumulatorHelper
-
Takes the serialized accumulator results and tries to deserialize them using the provided
class loader.
- deserializedFields1 - Variable in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
-
- deserializedFields2 - Variable in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
-
- deserializeFromByteArray(TypeSerializer<T>, byte[]) - Static method in class org.apache.flink.util.InstantiationUtil
-
- deserializeFromByteArray(TypeSerializer<T>, T, byte[]) - Static method in class org.apache.flink.util.InstantiationUtil
-
- deserializeList(ArrayList<byte[]>, TypeSerializer<T>) - Static method in class org.apache.flink.api.common.accumulators.SerializedListAccumulator
-
- deserializeObject(byte[], ClassLoader) - Static method in class org.apache.flink.util.InstantiationUtil
-
- deserializeValue(ClassLoader) - Method in class org.apache.flink.util.SerializedValue
-
- dim - Variable in class org.apache.flink.api.common.distributions.SimpleDistribution
-
- disableAutoTypeRegistration() - Method in class org.apache.flink.api.common.ExecutionConfig
-
Control whether Flink is automatically registering all types in the user programs with
Kryo.
- disableClosureCleaner() - Method in class org.apache.flink.api.common.ExecutionConfig
-
Disables the ClosureCleaner.
- disableForceAvro() - Method in class org.apache.flink.api.common.ExecutionConfig
-
- disableForceKryo() - Method in class org.apache.flink.api.common.ExecutionConfig
-
Disable use of Kryo serializer for all POJOs.
- disableObjectReuse() - Method in class org.apache.flink.api.common.ExecutionConfig
-
Disables reusing objects that Flink internally uses for deserialization and passing
data to user-code functions.
- disableSysoutLogging() - Method in class org.apache.flink.api.common.ExecutionConfig
-
Disables the printing of progress update messages to System.out
- 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(Map<String, Future<Path>>) - 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
-
- DOUBLE_VALUE_TYPE_INFO - Static variable in class org.apache.flink.api.java.typeutils.ValueTypeInfo
-
- 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
-
An accumulator that sums up double
values.
- 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
-
- DoublePrimitiveArrayComparator - Class in org.apache.flink.api.common.typeutils.base.array
-
- DoublePrimitiveArrayComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.array.DoublePrimitiveArrayComparator
-
- 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.array.BooleanPrimitiveArrayComparator
-
- duplicate() - Method in class org.apache.flink.api.common.typeutils.base.array.BytePrimitiveArrayComparator
-
- duplicate() - Method in class org.apache.flink.api.common.typeutils.base.array.CharPrimitiveArrayComparator
-
- duplicate() - Method in class org.apache.flink.api.common.typeutils.base.array.DoublePrimitiveArrayComparator
-
- duplicate() - Method in class org.apache.flink.api.common.typeutils.base.array.FloatPrimitiveArrayComparator
-
- duplicate() - Method in class org.apache.flink.api.common.typeutils.base.array.IntPrimitiveArrayComparator
-
- duplicate() - Method in class org.apache.flink.api.common.typeutils.base.array.LongPrimitiveArrayComparator
-
- duplicate() - Method in class org.apache.flink.api.common.typeutils.base.array.ShortPrimitiveArrayComparator
-
- 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.EnumSerializer
-
- duplicate() - Method in class org.apache.flink.api.common.typeutils.base.FloatComparator
-
- duplicate() - Method in class org.apache.flink.api.common.typeutils.base.GenericArraySerializer
-
- 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.base.TypeSerializerSingleton
-
- duplicate() - Method in class org.apache.flink.api.common.typeutils.TypeComparator
-
Creates a copy of this class.
- duplicate() - Method in class org.apache.flink.api.common.typeutils.TypeSerializer
-
Creates a deep copy of this serializer if it is necessary, i.e.
- duplicate() - Method in class org.apache.flink.api.java.typeutils.runtime.AvroSerializer
-
- duplicate() - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueComparator
-
- duplicate() - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer
-
- duplicate() - Method in class org.apache.flink.api.java.typeutils.runtime.EitherSerializer
-
- duplicate() - Method in class org.apache.flink.api.java.typeutils.runtime.GenericTypeComparator
-
- duplicate() - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer
-
- duplicate() - Method in class org.apache.flink.api.java.typeutils.runtime.PojoComparator
-
- duplicate() - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer
-
- duplicate() - Method in class org.apache.flink.api.java.typeutils.runtime.Tuple0Serializer
-
- duplicate() - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparator
-
- duplicate() - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializer
-
- duplicate() - Method in class org.apache.flink.api.java.typeutils.runtime.ValueComparator
-
- duplicate() - Method in class org.apache.flink.api.java.typeutils.runtime.ValueSerializer
-
- duplicate() - Method in class org.apache.flink.api.java.typeutils.runtime.WritableComparator
-
- duplicate() - Method in class org.apache.flink.api.java.typeutils.runtime.WritableSerializer
-
- f0 - Variable in class org.apache.flink.api.java.tuple.Tuple1
-
Field 0 of the tuple.
- f0 - Variable in class org.apache.flink.api.java.tuple.Tuple10
-
Field 0 of the tuple.
- f0 - Variable in class org.apache.flink.api.java.tuple.Tuple11
-
Field 0 of the tuple.
- f0 - Variable in class org.apache.flink.api.java.tuple.Tuple12
-
Field 0 of the tuple.
- f0 - Variable in class org.apache.flink.api.java.tuple.Tuple13
-
Field 0 of the tuple.
- f0 - Variable in class org.apache.flink.api.java.tuple.Tuple14
-
Field 0 of the tuple.
- f0 - Variable in class org.apache.flink.api.java.tuple.Tuple15
-
Field 0 of the tuple.
- f0 - Variable in class org.apache.flink.api.java.tuple.Tuple16
-
Field 0 of the tuple.
- f0 - Variable in class org.apache.flink.api.java.tuple.Tuple17
-
Field 0 of the tuple.
- f0 - Variable in class org.apache.flink.api.java.tuple.Tuple18
-
Field 0 of the tuple.
- f0 - Variable in class org.apache.flink.api.java.tuple.Tuple19
-
Field 0 of the tuple.
- f0 - Variable in class org.apache.flink.api.java.tuple.Tuple2
-
Field 0 of the tuple.
- f0 - Variable in class org.apache.flink.api.java.tuple.Tuple20
-
Field 0 of the tuple.
- f0 - Variable in class org.apache.flink.api.java.tuple.Tuple21
-
Field 0 of the tuple.
- f0 - Variable in class org.apache.flink.api.java.tuple.Tuple22
-
Field 0 of the tuple.
- f0 - Variable in class org.apache.flink.api.java.tuple.Tuple23
-
Field 0 of the tuple.
- f0 - Variable in class org.apache.flink.api.java.tuple.Tuple24
-
Field 0 of the tuple.
- f0 - Variable in class org.apache.flink.api.java.tuple.Tuple25
-
Field 0 of the tuple.
- f0 - Variable in class org.apache.flink.api.java.tuple.Tuple3
-
Field 0 of the tuple.
- f0 - Variable in class org.apache.flink.api.java.tuple.Tuple4
-
Field 0 of the tuple.
- f0 - Variable in class org.apache.flink.api.java.tuple.Tuple5
-
Field 0 of the tuple.
- f0 - Variable in class org.apache.flink.api.java.tuple.Tuple6
-
Field 0 of the tuple.
- f0 - Variable in class org.apache.flink.api.java.tuple.Tuple7
-
Field 0 of the tuple.
- f0 - Variable in class org.apache.flink.api.java.tuple.Tuple8
-
Field 0 of the tuple.
- f0 - Variable in class org.apache.flink.api.java.tuple.Tuple9
-
Field 0 of the tuple.
- f1 - Variable in class org.apache.flink.api.java.tuple.Tuple10
-
Field 1 of the tuple.
- f1 - Variable in class org.apache.flink.api.java.tuple.Tuple11
-
Field 1 of the tuple.
- f1 - Variable in class org.apache.flink.api.java.tuple.Tuple12
-
Field 1 of the tuple.
- f1 - Variable in class org.apache.flink.api.java.tuple.Tuple13
-
Field 1 of the tuple.
- f1 - Variable in class org.apache.flink.api.java.tuple.Tuple14
-
Field 1 of the tuple.
- f1 - Variable in class org.apache.flink.api.java.tuple.Tuple15
-
Field 1 of the tuple.
- f1 - Variable in class org.apache.flink.api.java.tuple.Tuple16
-
Field 1 of the tuple.
- f1 - Variable in class org.apache.flink.api.java.tuple.Tuple17
-
Field 1 of the tuple.
- f1 - Variable in class org.apache.flink.api.java.tuple.Tuple18
-
Field 1 of the tuple.
- f1 - Variable in class org.apache.flink.api.java.tuple.Tuple19
-
Field 1 of the tuple.
- f1 - Variable in class org.apache.flink.api.java.tuple.Tuple2
-
Field 1 of the tuple.
- f1 - Variable in class org.apache.flink.api.java.tuple.Tuple20
-
Field 1 of the tuple.
- f1 - Variable in class org.apache.flink.api.java.tuple.Tuple21
-
Field 1 of the tuple.
- f1 - Variable in class org.apache.flink.api.java.tuple.Tuple22
-
Field 1 of the tuple.
- f1 - Variable in class org.apache.flink.api.java.tuple.Tuple23
-
Field 1 of the tuple.
- f1 - Variable in class org.apache.flink.api.java.tuple.Tuple24
-
Field 1 of the tuple.
- f1 - Variable in class org.apache.flink.api.java.tuple.Tuple25
-
Field 1 of the tuple.
- f1 - Variable in class org.apache.flink.api.java.tuple.Tuple3
-
Field 1 of the tuple.
- f1 - Variable in class org.apache.flink.api.java.tuple.Tuple4
-
Field 1 of the tuple.
- f1 - Variable in class org.apache.flink.api.java.tuple.Tuple5
-
Field 1 of the tuple.
- f1 - Variable in class org.apache.flink.api.java.tuple.Tuple6
-
Field 1 of the tuple.
- f1 - Variable in class org.apache.flink.api.java.tuple.Tuple7
-
Field 1 of the tuple.
- f1 - Variable in class org.apache.flink.api.java.tuple.Tuple8
-
Field 1 of the tuple.
- f1 - Variable in class org.apache.flink.api.java.tuple.Tuple9
-
Field 1 of the tuple.
- f10 - Variable in class org.apache.flink.api.java.tuple.Tuple11
-
Field 10 of the tuple.
- f10 - Variable in class org.apache.flink.api.java.tuple.Tuple12
-
Field 10 of the tuple.
- f10 - Variable in class org.apache.flink.api.java.tuple.Tuple13
-
Field 10 of the tuple.
- f10 - Variable in class org.apache.flink.api.java.tuple.Tuple14
-
Field 10 of the tuple.
- f10 - Variable in class org.apache.flink.api.java.tuple.Tuple15
-
Field 10 of the tuple.
- f10 - Variable in class org.apache.flink.api.java.tuple.Tuple16
-
Field 10 of the tuple.
- f10 - Variable in class org.apache.flink.api.java.tuple.Tuple17
-
Field 10 of the tuple.
- f10 - Variable in class org.apache.flink.api.java.tuple.Tuple18
-
Field 10 of the tuple.
- f10 - Variable in class org.apache.flink.api.java.tuple.Tuple19
-
Field 10 of the tuple.
- f10 - Variable in class org.apache.flink.api.java.tuple.Tuple20
-
Field 10 of the tuple.
- f10 - Variable in class org.apache.flink.api.java.tuple.Tuple21
-
Field 10 of the tuple.
- f10 - Variable in class org.apache.flink.api.java.tuple.Tuple22
-
Field 10 of the tuple.
- f10 - Variable in class org.apache.flink.api.java.tuple.Tuple23
-
Field 10 of the tuple.
- f10 - Variable in class org.apache.flink.api.java.tuple.Tuple24
-
Field 10 of the tuple.
- f10 - Variable in class org.apache.flink.api.java.tuple.Tuple25
-
Field 10 of the tuple.
- f11 - Variable in class org.apache.flink.api.java.tuple.Tuple12
-
Field 11 of the tuple.
- f11 - Variable in class org.apache.flink.api.java.tuple.Tuple13
-
Field 11 of the tuple.
- f11 - Variable in class org.apache.flink.api.java.tuple.Tuple14
-
Field 11 of the tuple.
- f11 - Variable in class org.apache.flink.api.java.tuple.Tuple15
-
Field 11 of the tuple.
- f11 - Variable in class org.apache.flink.api.java.tuple.Tuple16
-
Field 11 of the tuple.
- f11 - Variable in class org.apache.flink.api.java.tuple.Tuple17
-
Field 11 of the tuple.
- f11 - Variable in class org.apache.flink.api.java.tuple.Tuple18
-
Field 11 of the tuple.
- f11 - Variable in class org.apache.flink.api.java.tuple.Tuple19
-
Field 11 of the tuple.
- f11 - Variable in class org.apache.flink.api.java.tuple.Tuple20
-
Field 11 of the tuple.
- f11 - Variable in class org.apache.flink.api.java.tuple.Tuple21
-
Field 11 of the tuple.
- f11 - Variable in class org.apache.flink.api.java.tuple.Tuple22
-
Field 11 of the tuple.
- f11 - Variable in class org.apache.flink.api.java.tuple.Tuple23
-
Field 11 of the tuple.
- f11 - Variable in class org.apache.flink.api.java.tuple.Tuple24
-
Field 11 of the tuple.
- f11 - Variable in class org.apache.flink.api.java.tuple.Tuple25
-
Field 11 of the tuple.
- f12 - Variable in class org.apache.flink.api.java.tuple.Tuple13
-
Field 12 of the tuple.
- f12 - Variable in class org.apache.flink.api.java.tuple.Tuple14
-
Field 12 of the tuple.
- f12 - Variable in class org.apache.flink.api.java.tuple.Tuple15
-
Field 12 of the tuple.
- f12 - Variable in class org.apache.flink.api.java.tuple.Tuple16
-
Field 12 of the tuple.
- f12 - Variable in class org.apache.flink.api.java.tuple.Tuple17
-
Field 12 of the tuple.
- f12 - Variable in class org.apache.flink.api.java.tuple.Tuple18
-
Field 12 of the tuple.
- f12 - Variable in class org.apache.flink.api.java.tuple.Tuple19
-
Field 12 of the tuple.
- f12 - Variable in class org.apache.flink.api.java.tuple.Tuple20
-
Field 12 of the tuple.
- f12 - Variable in class org.apache.flink.api.java.tuple.Tuple21
-
Field 12 of the tuple.
- f12 - Variable in class org.apache.flink.api.java.tuple.Tuple22
-
Field 12 of the tuple.
- f12 - Variable in class org.apache.flink.api.java.tuple.Tuple23
-
Field 12 of the tuple.
- f12 - Variable in class org.apache.flink.api.java.tuple.Tuple24
-
Field 12 of the tuple.
- f12 - Variable in class org.apache.flink.api.java.tuple.Tuple25
-
Field 12 of the tuple.
- f13 - Variable in class org.apache.flink.api.java.tuple.Tuple14
-
Field 13 of the tuple.
- f13 - Variable in class org.apache.flink.api.java.tuple.Tuple15
-
Field 13 of the tuple.
- f13 - Variable in class org.apache.flink.api.java.tuple.Tuple16
-
Field 13 of the tuple.
- f13 - Variable in class org.apache.flink.api.java.tuple.Tuple17
-
Field 13 of the tuple.
- f13 - Variable in class org.apache.flink.api.java.tuple.Tuple18
-
Field 13 of the tuple.
- f13 - Variable in class org.apache.flink.api.java.tuple.Tuple19
-
Field 13 of the tuple.
- f13 - Variable in class org.apache.flink.api.java.tuple.Tuple20
-
Field 13 of the tuple.
- f13 - Variable in class org.apache.flink.api.java.tuple.Tuple21
-
Field 13 of the tuple.
- f13 - Variable in class org.apache.flink.api.java.tuple.Tuple22
-
Field 13 of the tuple.
- f13 - Variable in class org.apache.flink.api.java.tuple.Tuple23
-
Field 13 of the tuple.
- f13 - Variable in class org.apache.flink.api.java.tuple.Tuple24
-
Field 13 of the tuple.
- f13 - Variable in class org.apache.flink.api.java.tuple.Tuple25
-
Field 13 of the tuple.
- f14 - Variable in class org.apache.flink.api.java.tuple.Tuple15
-
Field 14 of the tuple.
- f14 - Variable in class org.apache.flink.api.java.tuple.Tuple16
-
Field 14 of the tuple.
- f14 - Variable in class org.apache.flink.api.java.tuple.Tuple17
-
Field 14 of the tuple.
- f14 - Variable in class org.apache.flink.api.java.tuple.Tuple18
-
Field 14 of the tuple.
- f14 - Variable in class org.apache.flink.api.java.tuple.Tuple19
-
Field 14 of the tuple.
- f14 - Variable in class org.apache.flink.api.java.tuple.Tuple20
-
Field 14 of the tuple.
- f14 - Variable in class org.apache.flink.api.java.tuple.Tuple21
-
Field 14 of the tuple.
- f14 - Variable in class org.apache.flink.api.java.tuple.Tuple22
-
Field 14 of the tuple.
- f14 - Variable in class org.apache.flink.api.java.tuple.Tuple23
-
Field 14 of the tuple.
- f14 - Variable in class org.apache.flink.api.java.tuple.Tuple24
-
Field 14 of the tuple.
- f14 - Variable in class org.apache.flink.api.java.tuple.Tuple25
-
Field 14 of the tuple.
- f15 - Variable in class org.apache.flink.api.java.tuple.Tuple16
-
Field 15 of the tuple.
- f15 - Variable in class org.apache.flink.api.java.tuple.Tuple17
-
Field 15 of the tuple.
- f15 - Variable in class org.apache.flink.api.java.tuple.Tuple18
-
Field 15 of the tuple.
- f15 - Variable in class org.apache.flink.api.java.tuple.Tuple19
-
Field 15 of the tuple.
- f15 - Variable in class org.apache.flink.api.java.tuple.Tuple20
-
Field 15 of the tuple.
- f15 - Variable in class org.apache.flink.api.java.tuple.Tuple21
-
Field 15 of the tuple.
- f15 - Variable in class org.apache.flink.api.java.tuple.Tuple22
-
Field 15 of the tuple.
- f15 - Variable in class org.apache.flink.api.java.tuple.Tuple23
-
Field 15 of the tuple.
- f15 - Variable in class org.apache.flink.api.java.tuple.Tuple24
-
Field 15 of the tuple.
- f15 - Variable in class org.apache.flink.api.java.tuple.Tuple25
-
Field 15 of the tuple.
- f16 - Variable in class org.apache.flink.api.java.tuple.Tuple17
-
Field 16 of the tuple.
- f16 - Variable in class org.apache.flink.api.java.tuple.Tuple18
-
Field 16 of the tuple.
- f16 - Variable in class org.apache.flink.api.java.tuple.Tuple19
-
Field 16 of the tuple.
- f16 - Variable in class org.apache.flink.api.java.tuple.Tuple20
-
Field 16 of the tuple.
- f16 - Variable in class org.apache.flink.api.java.tuple.Tuple21
-
Field 16 of the tuple.
- f16 - Variable in class org.apache.flink.api.java.tuple.Tuple22
-
Field 16 of the tuple.
- f16 - Variable in class org.apache.flink.api.java.tuple.Tuple23
-
Field 16 of the tuple.
- f16 - Variable in class org.apache.flink.api.java.tuple.Tuple24
-
Field 16 of the tuple.
- f16 - Variable in class org.apache.flink.api.java.tuple.Tuple25
-
Field 16 of the tuple.
- f17 - Variable in class org.apache.flink.api.java.tuple.Tuple18
-
Field 17 of the tuple.
- f17 - Variable in class org.apache.flink.api.java.tuple.Tuple19
-
Field 17 of the tuple.
- f17 - Variable in class org.apache.flink.api.java.tuple.Tuple20
-
Field 17 of the tuple.
- f17 - Variable in class org.apache.flink.api.java.tuple.Tuple21
-
Field 17 of the tuple.
- f17 - Variable in class org.apache.flink.api.java.tuple.Tuple22
-
Field 17 of the tuple.
- f17 - Variable in class org.apache.flink.api.java.tuple.Tuple23
-
Field 17 of the tuple.
- f17 - Variable in class org.apache.flink.api.java.tuple.Tuple24
-
Field 17 of the tuple.
- f17 - Variable in class org.apache.flink.api.java.tuple.Tuple25
-
Field 17 of the tuple.
- f18 - Variable in class org.apache.flink.api.java.tuple.Tuple19
-
Field 18 of the tuple.
- f18 - Variable in class org.apache.flink.api.java.tuple.Tuple20
-
Field 18 of the tuple.
- f18 - Variable in class org.apache.flink.api.java.tuple.Tuple21
-
Field 18 of the tuple.
- f18 - Variable in class org.apache.flink.api.java.tuple.Tuple22
-
Field 18 of the tuple.
- f18 - Variable in class org.apache.flink.api.java.tuple.Tuple23
-
Field 18 of the tuple.
- f18 - Variable in class org.apache.flink.api.java.tuple.Tuple24
-
Field 18 of the tuple.
- f18 - Variable in class org.apache.flink.api.java.tuple.Tuple25
-
Field 18 of the tuple.
- f19 - Variable in class org.apache.flink.api.java.tuple.Tuple20
-
Field 19 of the tuple.
- f19 - Variable in class org.apache.flink.api.java.tuple.Tuple21
-
Field 19 of the tuple.
- f19 - Variable in class org.apache.flink.api.java.tuple.Tuple22
-
Field 19 of the tuple.
- f19 - Variable in class org.apache.flink.api.java.tuple.Tuple23
-
Field 19 of the tuple.
- f19 - Variable in class org.apache.flink.api.java.tuple.Tuple24
-
Field 19 of the tuple.
- f19 - Variable in class org.apache.flink.api.java.tuple.Tuple25
-
Field 19 of the tuple.
- f2 - Variable in class org.apache.flink.api.java.tuple.Tuple10
-
Field 2 of the tuple.
- f2 - Variable in class org.apache.flink.api.java.tuple.Tuple11
-
Field 2 of the tuple.
- f2 - Variable in class org.apache.flink.api.java.tuple.Tuple12
-
Field 2 of the tuple.
- f2 - Variable in class org.apache.flink.api.java.tuple.Tuple13
-
Field 2 of the tuple.
- f2 - Variable in class org.apache.flink.api.java.tuple.Tuple14
-
Field 2 of the tuple.
- f2 - Variable in class org.apache.flink.api.java.tuple.Tuple15
-
Field 2 of the tuple.
- f2 - Variable in class org.apache.flink.api.java.tuple.Tuple16
-
Field 2 of the tuple.
- f2 - Variable in class org.apache.flink.api.java.tuple.Tuple17
-
Field 2 of the tuple.
- f2 - Variable in class org.apache.flink.api.java.tuple.Tuple18
-
Field 2 of the tuple.
- f2 - Variable in class org.apache.flink.api.java.tuple.Tuple19
-
Field 2 of the tuple.
- f2 - Variable in class org.apache.flink.api.java.tuple.Tuple20
-
Field 2 of the tuple.
- f2 - Variable in class org.apache.flink.api.java.tuple.Tuple21
-
Field 2 of the tuple.
- f2 - Variable in class org.apache.flink.api.java.tuple.Tuple22
-
Field 2 of the tuple.
- f2 - Variable in class org.apache.flink.api.java.tuple.Tuple23
-
Field 2 of the tuple.
- f2 - Variable in class org.apache.flink.api.java.tuple.Tuple24
-
Field 2 of the tuple.
- f2 - Variable in class org.apache.flink.api.java.tuple.Tuple25
-
Field 2 of the tuple.
- f2 - Variable in class org.apache.flink.api.java.tuple.Tuple3
-
Field 2 of the tuple.
- f2 - Variable in class org.apache.flink.api.java.tuple.Tuple4
-
Field 2 of the tuple.
- f2 - Variable in class org.apache.flink.api.java.tuple.Tuple5
-
Field 2 of the tuple.
- f2 - Variable in class org.apache.flink.api.java.tuple.Tuple6
-
Field 2 of the tuple.
- f2 - Variable in class org.apache.flink.api.java.tuple.Tuple7
-
Field 2 of the tuple.
- f2 - Variable in class org.apache.flink.api.java.tuple.Tuple8
-
Field 2 of the tuple.
- f2 - Variable in class org.apache.flink.api.java.tuple.Tuple9
-
Field 2 of the tuple.
- f20 - Variable in class org.apache.flink.api.java.tuple.Tuple21
-
Field 20 of the tuple.
- f20 - Variable in class org.apache.flink.api.java.tuple.Tuple22
-
Field 20 of the tuple.
- f20 - Variable in class org.apache.flink.api.java.tuple.Tuple23
-
Field 20 of the tuple.
- f20 - Variable in class org.apache.flink.api.java.tuple.Tuple24
-
Field 20 of the tuple.
- f20 - Variable in class org.apache.flink.api.java.tuple.Tuple25
-
Field 20 of the tuple.
- f21 - Variable in class org.apache.flink.api.java.tuple.Tuple22
-
Field 21 of the tuple.
- f21 - Variable in class org.apache.flink.api.java.tuple.Tuple23
-
Field 21 of the tuple.
- f21 - Variable in class org.apache.flink.api.java.tuple.Tuple24
-
Field 21 of the tuple.
- f21 - Variable in class org.apache.flink.api.java.tuple.Tuple25
-
Field 21 of the tuple.
- f22 - Variable in class org.apache.flink.api.java.tuple.Tuple23
-
Field 22 of the tuple.
- f22 - Variable in class org.apache.flink.api.java.tuple.Tuple24
-
Field 22 of the tuple.
- f22 - Variable in class org.apache.flink.api.java.tuple.Tuple25
-
Field 22 of the tuple.
- f23 - Variable in class org.apache.flink.api.java.tuple.Tuple24
-
Field 23 of the tuple.
- f23 - Variable in class org.apache.flink.api.java.tuple.Tuple25
-
Field 23 of the tuple.
- f24 - Variable in class org.apache.flink.api.java.tuple.Tuple25
-
Field 24 of the tuple.
- f3 - Variable in class org.apache.flink.api.java.tuple.Tuple10
-
Field 3 of the tuple.
- f3 - Variable in class org.apache.flink.api.java.tuple.Tuple11
-
Field 3 of the tuple.
- f3 - Variable in class org.apache.flink.api.java.tuple.Tuple12
-
Field 3 of the tuple.
- f3 - Variable in class org.apache.flink.api.java.tuple.Tuple13
-
Field 3 of the tuple.
- f3 - Variable in class org.apache.flink.api.java.tuple.Tuple14
-
Field 3 of the tuple.
- f3 - Variable in class org.apache.flink.api.java.tuple.Tuple15
-
Field 3 of the tuple.
- f3 - Variable in class org.apache.flink.api.java.tuple.Tuple16
-
Field 3 of the tuple.
- f3 - Variable in class org.apache.flink.api.java.tuple.Tuple17
-
Field 3 of the tuple.
- f3 - Variable in class org.apache.flink.api.java.tuple.Tuple18
-
Field 3 of the tuple.
- f3 - Variable in class org.apache.flink.api.java.tuple.Tuple19
-
Field 3 of the tuple.
- f3 - Variable in class org.apache.flink.api.java.tuple.Tuple20
-
Field 3 of the tuple.
- f3 - Variable in class org.apache.flink.api.java.tuple.Tuple21
-
Field 3 of the tuple.
- f3 - Variable in class org.apache.flink.api.java.tuple.Tuple22
-
Field 3 of the tuple.
- f3 - Variable in class org.apache.flink.api.java.tuple.Tuple23
-
Field 3 of the tuple.
- f3 - Variable in class org.apache.flink.api.java.tuple.Tuple24
-
Field 3 of the tuple.
- f3 - Variable in class org.apache.flink.api.java.tuple.Tuple25
-
Field 3 of the tuple.
- f3 - Variable in class org.apache.flink.api.java.tuple.Tuple4
-
Field 3 of the tuple.
- f3 - Variable in class org.apache.flink.api.java.tuple.Tuple5
-
Field 3 of the tuple.
- f3 - Variable in class org.apache.flink.api.java.tuple.Tuple6
-
Field 3 of the tuple.
- f3 - Variable in class org.apache.flink.api.java.tuple.Tuple7
-
Field 3 of the tuple.
- f3 - Variable in class org.apache.flink.api.java.tuple.Tuple8
-
Field 3 of the tuple.
- f3 - Variable in class org.apache.flink.api.java.tuple.Tuple9
-
Field 3 of the tuple.
- f4 - Variable in class org.apache.flink.api.java.tuple.Tuple10
-
Field 4 of the tuple.
- f4 - Variable in class org.apache.flink.api.java.tuple.Tuple11
-
Field 4 of the tuple.
- f4 - Variable in class org.apache.flink.api.java.tuple.Tuple12
-
Field 4 of the tuple.
- f4 - Variable in class org.apache.flink.api.java.tuple.Tuple13
-
Field 4 of the tuple.
- f4 - Variable in class org.apache.flink.api.java.tuple.Tuple14
-
Field 4 of the tuple.
- f4 - Variable in class org.apache.flink.api.java.tuple.Tuple15
-
Field 4 of the tuple.
- f4 - Variable in class org.apache.flink.api.java.tuple.Tuple16
-
Field 4 of the tuple.
- f4 - Variable in class org.apache.flink.api.java.tuple.Tuple17
-
Field 4 of the tuple.
- f4 - Variable in class org.apache.flink.api.java.tuple.Tuple18
-
Field 4 of the tuple.
- f4 - Variable in class org.apache.flink.api.java.tuple.Tuple19
-
Field 4 of the tuple.
- f4 - Variable in class org.apache.flink.api.java.tuple.Tuple20
-
Field 4 of the tuple.
- f4 - Variable in class org.apache.flink.api.java.tuple.Tuple21
-
Field 4 of the tuple.
- f4 - Variable in class org.apache.flink.api.java.tuple.Tuple22
-
Field 4 of the tuple.
- f4 - Variable in class org.apache.flink.api.java.tuple.Tuple23
-
Field 4 of the tuple.
- f4 - Variable in class org.apache.flink.api.java.tuple.Tuple24
-
Field 4 of the tuple.
- f4 - Variable in class org.apache.flink.api.java.tuple.Tuple25
-
Field 4 of the tuple.
- f4 - Variable in class org.apache.flink.api.java.tuple.Tuple5
-
Field 4 of the tuple.
- f4 - Variable in class org.apache.flink.api.java.tuple.Tuple6
-
Field 4 of the tuple.
- f4 - Variable in class org.apache.flink.api.java.tuple.Tuple7
-
Field 4 of the tuple.
- f4 - Variable in class org.apache.flink.api.java.tuple.Tuple8
-
Field 4 of the tuple.
- f4 - Variable in class org.apache.flink.api.java.tuple.Tuple9
-
Field 4 of the tuple.
- f5 - Variable in class org.apache.flink.api.java.tuple.Tuple10
-
Field 5 of the tuple.
- f5 - Variable in class org.apache.flink.api.java.tuple.Tuple11
-
Field 5 of the tuple.
- f5 - Variable in class org.apache.flink.api.java.tuple.Tuple12
-
Field 5 of the tuple.
- f5 - Variable in class org.apache.flink.api.java.tuple.Tuple13
-
Field 5 of the tuple.
- f5 - Variable in class org.apache.flink.api.java.tuple.Tuple14
-
Field 5 of the tuple.
- f5 - Variable in class org.apache.flink.api.java.tuple.Tuple15
-
Field 5 of the tuple.
- f5 - Variable in class org.apache.flink.api.java.tuple.Tuple16
-
Field 5 of the tuple.
- f5 - Variable in class org.apache.flink.api.java.tuple.Tuple17
-
Field 5 of the tuple.
- f5 - Variable in class org.apache.flink.api.java.tuple.Tuple18
-
Field 5 of the tuple.
- f5 - Variable in class org.apache.flink.api.java.tuple.Tuple19
-
Field 5 of the tuple.
- f5 - Variable in class org.apache.flink.api.java.tuple.Tuple20
-
Field 5 of the tuple.
- f5 - Variable in class org.apache.flink.api.java.tuple.Tuple21
-
Field 5 of the tuple.
- f5 - Variable in class org.apache.flink.api.java.tuple.Tuple22
-
Field 5 of the tuple.
- f5 - Variable in class org.apache.flink.api.java.tuple.Tuple23
-
Field 5 of the tuple.
- f5 - Variable in class org.apache.flink.api.java.tuple.Tuple24
-
Field 5 of the tuple.
- f5 - Variable in class org.apache.flink.api.java.tuple.Tuple25
-
Field 5 of the tuple.
- f5 - Variable in class org.apache.flink.api.java.tuple.Tuple6
-
Field 5 of the tuple.
- f5 - Variable in class org.apache.flink.api.java.tuple.Tuple7
-
Field 5 of the tuple.
- f5 - Variable in class org.apache.flink.api.java.tuple.Tuple8
-
Field 5 of the tuple.
- f5 - Variable in class org.apache.flink.api.java.tuple.Tuple9
-
Field 5 of the tuple.
- f6 - Variable in class org.apache.flink.api.java.tuple.Tuple10
-
Field 6 of the tuple.
- f6 - Variable in class org.apache.flink.api.java.tuple.Tuple11
-
Field 6 of the tuple.
- f6 - Variable in class org.apache.flink.api.java.tuple.Tuple12
-
Field 6 of the tuple.
- f6 - Variable in class org.apache.flink.api.java.tuple.Tuple13
-
Field 6 of the tuple.
- f6 - Variable in class org.apache.flink.api.java.tuple.Tuple14
-
Field 6 of the tuple.
- f6 - Variable in class org.apache.flink.api.java.tuple.Tuple15
-
Field 6 of the tuple.
- f6 - Variable in class org.apache.flink.api.java.tuple.Tuple16
-
Field 6 of the tuple.
- f6 - Variable in class org.apache.flink.api.java.tuple.Tuple17
-
Field 6 of the tuple.
- f6 - Variable in class org.apache.flink.api.java.tuple.Tuple18
-
Field 6 of the tuple.
- f6 - Variable in class org.apache.flink.api.java.tuple.Tuple19
-
Field 6 of the tuple.
- f6 - Variable in class org.apache.flink.api.java.tuple.Tuple20
-
Field 6 of the tuple.
- f6 - Variable in class org.apache.flink.api.java.tuple.Tuple21
-
Field 6 of the tuple.
- f6 - Variable in class org.apache.flink.api.java.tuple.Tuple22
-
Field 6 of the tuple.
- f6 - Variable in class org.apache.flink.api.java.tuple.Tuple23
-
Field 6 of the tuple.
- f6 - Variable in class org.apache.flink.api.java.tuple.Tuple24
-
Field 6 of the tuple.
- f6 - Variable in class org.apache.flink.api.java.tuple.Tuple25
-
Field 6 of the tuple.
- f6 - Variable in class org.apache.flink.api.java.tuple.Tuple7
-
Field 6 of the tuple.
- f6 - Variable in class org.apache.flink.api.java.tuple.Tuple8
-
Field 6 of the tuple.
- f6 - Variable in class org.apache.flink.api.java.tuple.Tuple9
-
Field 6 of the tuple.
- f7 - Variable in class org.apache.flink.api.java.tuple.Tuple10
-
Field 7 of the tuple.
- f7 - Variable in class org.apache.flink.api.java.tuple.Tuple11
-
Field 7 of the tuple.
- f7 - Variable in class org.apache.flink.api.java.tuple.Tuple12
-
Field 7 of the tuple.
- f7 - Variable in class org.apache.flink.api.java.tuple.Tuple13
-
Field 7 of the tuple.
- f7 - Variable in class org.apache.flink.api.java.tuple.Tuple14
-
Field 7 of the tuple.
- f7 - Variable in class org.apache.flink.api.java.tuple.Tuple15
-
Field 7 of the tuple.
- f7 - Variable in class org.apache.flink.api.java.tuple.Tuple16
-
Field 7 of the tuple.
- f7 - Variable in class org.apache.flink.api.java.tuple.Tuple17
-
Field 7 of the tuple.
- f7 - Variable in class org.apache.flink.api.java.tuple.Tuple18
-
Field 7 of the tuple.
- f7 - Variable in class org.apache.flink.api.java.tuple.Tuple19
-
Field 7 of the tuple.
- f7 - Variable in class org.apache.flink.api.java.tuple.Tuple20
-
Field 7 of the tuple.
- f7 - Variable in class org.apache.flink.api.java.tuple.Tuple21
-
Field 7 of the tuple.
- f7 - Variable in class org.apache.flink.api.java.tuple.Tuple22
-
Field 7 of the tuple.
- f7 - Variable in class org.apache.flink.api.java.tuple.Tuple23
-
Field 7 of the tuple.
- f7 - Variable in class org.apache.flink.api.java.tuple.Tuple24
-
Field 7 of the tuple.
- f7 - Variable in class org.apache.flink.api.java.tuple.Tuple25
-
Field 7 of the tuple.
- f7 - Variable in class org.apache.flink.api.java.tuple.Tuple8
-
Field 7 of the tuple.
- f7 - Variable in class org.apache.flink.api.java.tuple.Tuple9
-
Field 7 of the tuple.
- f8 - Variable in class org.apache.flink.api.java.tuple.Tuple10
-
Field 8 of the tuple.
- f8 - Variable in class org.apache.flink.api.java.tuple.Tuple11
-
Field 8 of the tuple.
- f8 - Variable in class org.apache.flink.api.java.tuple.Tuple12
-
Field 8 of the tuple.
- f8 - Variable in class org.apache.flink.api.java.tuple.Tuple13
-
Field 8 of the tuple.
- f8 - Variable in class org.apache.flink.api.java.tuple.Tuple14
-
Field 8 of the tuple.
- f8 - Variable in class org.apache.flink.api.java.tuple.Tuple15
-
Field 8 of the tuple.
- f8 - Variable in class org.apache.flink.api.java.tuple.Tuple16
-
Field 8 of the tuple.
- f8 - Variable in class org.apache.flink.api.java.tuple.Tuple17
-
Field 8 of the tuple.
- f8 - Variable in class org.apache.flink.api.java.tuple.Tuple18
-
Field 8 of the tuple.
- f8 - Variable in class org.apache.flink.api.java.tuple.Tuple19
-
Field 8 of the tuple.
- f8 - Variable in class org.apache.flink.api.java.tuple.Tuple20
-
Field 8 of the tuple.
- f8 - Variable in class org.apache.flink.api.java.tuple.Tuple21
-
Field 8 of the tuple.
- f8 - Variable in class org.apache.flink.api.java.tuple.Tuple22
-
Field 8 of the tuple.
- f8 - Variable in class org.apache.flink.api.java.tuple.Tuple23
-
Field 8 of the tuple.
- f8 - Variable in class org.apache.flink.api.java.tuple.Tuple24
-
Field 8 of the tuple.
- f8 - Variable in class org.apache.flink.api.java.tuple.Tuple25
-
Field 8 of the tuple.
- f8 - Variable in class org.apache.flink.api.java.tuple.Tuple9
-
Field 8 of the tuple.
- f9 - Variable in class org.apache.flink.api.java.tuple.Tuple10
-
Field 9 of the tuple.
- f9 - Variable in class org.apache.flink.api.java.tuple.Tuple11
-
Field 9 of the tuple.
- f9 - Variable in class org.apache.flink.api.java.tuple.Tuple12
-
Field 9 of the tuple.
- f9 - Variable in class org.apache.flink.api.java.tuple.Tuple13
-
Field 9 of the tuple.
- f9 - Variable in class org.apache.flink.api.java.tuple.Tuple14
-
Field 9 of the tuple.
- f9 - Variable in class org.apache.flink.api.java.tuple.Tuple15
-
Field 9 of the tuple.
- f9 - Variable in class org.apache.flink.api.java.tuple.Tuple16
-
Field 9 of the tuple.
- f9 - Variable in class org.apache.flink.api.java.tuple.Tuple17
-
Field 9 of the tuple.
- f9 - Variable in class org.apache.flink.api.java.tuple.Tuple18
-
Field 9 of the tuple.
- f9 - Variable in class org.apache.flink.api.java.tuple.Tuple19
-
Field 9 of the tuple.
- f9 - Variable in class org.apache.flink.api.java.tuple.Tuple20
-
Field 9 of the tuple.
- f9 - Variable in class org.apache.flink.api.java.tuple.Tuple21
-
Field 9 of the tuple.
- f9 - Variable in class org.apache.flink.api.java.tuple.Tuple22
-
Field 9 of the tuple.
- f9 - Variable in class org.apache.flink.api.java.tuple.Tuple23
-
Field 9 of the tuple.
- f9 - Variable in class org.apache.flink.api.java.tuple.Tuple24
-
Field 9 of the tuple.
- f9 - Variable in class org.apache.flink.api.java.tuple.Tuple25
-
Field 9 of the tuple.
- FACTORY - Static variable in class org.apache.flink.core.memory.HeapMemorySegment
-
- FACTORY - Static variable in class org.apache.flink.core.memory.HybridMemorySegment
-
- FALSE - Static variable in class org.apache.flink.types.BooleanValue
-
- fieldIncluded - Variable in class org.apache.flink.api.common.io.GenericCsvInputFormat
-
- 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
-
- fieldNames - Variable in class org.apache.flink.api.java.typeutils.TupleTypeInfo
-
- 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.
- fieldSerializers - Variable in class org.apache.flink.api.java.typeutils.runtime.TupleSerializerBase
-
- 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.
- 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.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.
- 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 Rich 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.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 - Variable in class org.apache.flink.api.common.io.FileInputFormat
-
The path to the file that contains the input.
- 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.
- FILESYSTEM_SCHEME - Static variable in class org.apache.flink.configuration.ConfigConstants
-
Key to specify the default filesystem to be used by a job.
- 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
-
A filter function is a predicate applied individually to each record.
- 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(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.
- fixedDelayRestart(int, long) - Static method in class org.apache.flink.api.common.restartstrategy.RestartStrategies
-
Generates a FixedDelayRestartStrategyConfiguration.
- 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
-
- FLOAT_VALUE_TYPE_INFO - Static variable in class org.apache.flink.api.java.typeutils.ValueTypeInfo
-
- 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
-
- FloatPrimitiveArrayComparator - Class in org.apache.flink.api.common.typeutils.base.array
-
- FloatPrimitiveArrayComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.array.FloatPrimitiveArrayComparator
-
- 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.api.java.typeutils.runtime.DataOutputEncoder
-
- flush() - Method in class org.apache.flink.core.fs.FSDataOutputStream
-
- flush() - Method in class org.apache.flink.core.fs.local.LocalDataOutputStream
-
- fold(T, O) - Method in interface org.apache.flink.api.common.functions.FoldFunction
-
The core method of FoldFunction, combining two values into one value of the same type.
- fold(T, O) - Method in class org.apache.flink.api.common.functions.RichFoldFunction
-
- FoldFunction<O,T> - Interface in org.apache.flink.api.common.functions
-
Base interface for Fold functions.
- FoldingState<T,ACC> - Interface in org.apache.flink.api.common.state
-
State
interface for folding state.
- FoldingStateDescriptor<T,ACC> - Class in org.apache.flink.api.common.state
-
- FoldingStateDescriptor(String, ACC, FoldFunction<T, ACC>, Class<ACC>) - Constructor for class org.apache.flink.api.common.state.FoldingStateDescriptor
-
Creates a new FoldingStateDescriptor
with the given name, type, and initial value.
- FoldingStateDescriptor(String, ACC, FoldFunction<T, ACC>, TypeInformation<ACC>) - Constructor for class org.apache.flink.api.common.state.FoldingStateDescriptor
-
Creates a new FoldingStateDescriptor
with the given name and default value.
- FoldingStateDescriptor(String, ACC, FoldFunction<T, ACC>, TypeSerializer<ACC>) - Constructor for class org.apache.flink.api.common.state.FoldingStateDescriptor
-
Creates a new ValueStateDescriptor
with the given name and default value.
- format(LoggingEvent) - Method in class org.apache.flink.util.MavenForkNumberPrefixLayout
-
- formatWrapper - Variable in class org.apache.flink.api.common.operators.GenericDataSinkBase
-
- formatWrapper - Variable in class org.apache.flink.api.common.operators.GenericDataSourceBase
-
- FractionalTypeInfo<T> - Class in org.apache.flink.api.common.typeinfo
-
Type information for numeric fractional primitive types (double, float).
- FractionalTypeInfo(Class<T>, Class<?>[], TypeSerializer<T>, Class<? extends TypeComparator<T>>) - Constructor for class org.apache.flink.api.common.typeinfo.FractionalTypeInfo
-
- free() - Method in class org.apache.flink.core.memory.HeapMemorySegment
-
- free() - Method in class org.apache.flink.core.memory.MemorySegment
-
Frees this memory segment.
- fromByteArray(byte[]) - Static method in class org.apache.flink.api.common.JobID
-
Creates a new JobID from the given byte sequence.
- fromByteBuffer(ByteBuffer) - Static method in class org.apache.flink.api.common.JobID
-
- fromHexString(String) - Static method in class org.apache.flink.api.common.JobID
-
- fromJobSubmissionResult(JobSubmissionResult) - Static method in class org.apache.flink.api.common.JobExecutionResult
-
Returns a dummy object for wrapping a JobSubmissionResult
- 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
-
The base interface for all user-defined functions.
- FunctionUtils - Class in org.apache.flink.api.common.functions.util
-
Utility class that contains helper methods to work with Flink
Function
class.
- generate() - Static method in class org.apache.flink.api.common.JobID
-
Creates a new (statistically) random JobID.
- 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
-
- 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.
- GenericDataSourceBase.SplitDataProperties<T> - Interface in org.apache.flink.api.common.operators
-
- GenericInputFormat<OT> - Class in org.apache.flink.api.common.io
-
Generic base class for all Rich 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(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
-
- GenericTypeComparator<T extends Comparable<T>> - Class in org.apache.flink.api.java.typeutils.runtime
-
TypeComparator for all types that extend Comparable.
- GenericTypeComparator(boolean, TypeSerializer<T>, Class<T>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.GenericTypeComparator
-
- GenericTypeInfo<T> - Class in org.apache.flink.api.java.typeutils
-
- GenericTypeInfo(Class<T>) - Constructor for class org.apache.flink.api.java.typeutils.GenericTypeInfo
-
- get(int) - Method in class org.apache.flink.api.common.operators.util.FieldList
-
- get() - Method in interface org.apache.flink.api.common.state.MergingState
-
Returns the current value for the state.
- 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.HeapMemorySegment
-
- get(int, byte[]) - Method in class org.apache.flink.core.memory.HeapMemorySegment
-
- get(int, byte[], int, int) - Method in class org.apache.flink.core.memory.HeapMemorySegment
-
- get(DataOutput, int, int) - Method in class org.apache.flink.core.memory.HeapMemorySegment
-
- get(int, ByteBuffer, int) - Method in class org.apache.flink.core.memory.HeapMemorySegment
-
- get(int) - Method in class org.apache.flink.core.memory.HybridMemorySegment
-
- get(int, byte[]) - Method in class org.apache.flink.core.memory.HybridMemorySegment
-
- get(int, byte[], int, int) - Method in class org.apache.flink.core.memory.HybridMemorySegment
-
- get(DataOutput, int, int) - Method in class org.apache.flink.core.memory.HybridMemorySegment
-
- get(int, ByteBuffer, int) - Method in class org.apache.flink.core.memory.HybridMemorySegment
-
- 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
-
- 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
-
Gets the accumulator with the given name.
- 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
-
Gets all accumulators produced by the job.
- getAllAccumulators() - Method in interface org.apache.flink.api.common.functions.RuntimeContext
-
- getAllAccumulators() - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
-
- getAllDeclaredFields(Class<?>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
recursively determine all declared fields
This is required because class.getFields() is not returning fields defined
in parent classes.
- 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
-
Gets the arity of this type - the number of fields without nesting.
- getArity() - Method in class org.apache.flink.api.java.tuple.Tuple
-
Gets the number of field in the tuple (the tuple arity).
- getArity() - Method in class org.apache.flink.api.java.tuple.Tuple0
-
- getArity() - Method in class org.apache.flink.api.java.tuple.Tuple1
-
- getArity() - Method in class org.apache.flink.api.java.tuple.Tuple10
-
- getArity() - Method in class org.apache.flink.api.java.tuple.Tuple11
-
- getArity() - Method in class org.apache.flink.api.java.tuple.Tuple12
-
- getArity() - Method in class org.apache.flink.api.java.tuple.Tuple13
-
- getArity() - Method in class org.apache.flink.api.java.tuple.Tuple14
-
- getArity() - Method in class org.apache.flink.api.java.tuple.Tuple15
-
- getArity() - Method in class org.apache.flink.api.java.tuple.Tuple16
-
- getArity() - Method in class org.apache.flink.api.java.tuple.Tuple17
-
- getArity() - Method in class org.apache.flink.api.java.tuple.Tuple18
-
- getArity() - Method in class org.apache.flink.api.java.tuple.Tuple19
-
- getArity() - Method in class org.apache.flink.api.java.tuple.Tuple2
-
- getArity() - Method in class org.apache.flink.api.java.tuple.Tuple20
-
- getArity() - Method in class org.apache.flink.api.java.tuple.Tuple21
-
- getArity() - Method in class org.apache.flink.api.java.tuple.Tuple22
-
- getArity() - Method in class org.apache.flink.api.java.tuple.Tuple23
-
- getArity() - Method in class org.apache.flink.api.java.tuple.Tuple24
-
- getArity() - Method in class org.apache.flink.api.java.tuple.Tuple25
-
- getArity() - Method in class org.apache.flink.api.java.tuple.Tuple3
-
- getArity() - Method in class org.apache.flink.api.java.tuple.Tuple4
-
- getArity() - Method in class org.apache.flink.api.java.tuple.Tuple5
-
- getArity() - Method in class org.apache.flink.api.java.tuple.Tuple6
-
- getArity() - Method in class org.apache.flink.api.java.tuple.Tuple7
-
- getArity() - Method in class org.apache.flink.api.java.tuple.Tuple8
-
- getArity() - Method in class org.apache.flink.api.java.tuple.Tuple9
-
- getArity() - Method in class org.apache.flink.api.java.typeutils.EitherTypeInfo
-
- getArity() - Method in class org.apache.flink.api.java.typeutils.EnumTypeInfo
-
- getArity() - Method in class org.apache.flink.api.java.typeutils.GenericTypeInfo
-
- getArity() - Method in class org.apache.flink.api.java.typeutils.MissingTypeInfo
-
- getArity() - Method in class org.apache.flink.api.java.typeutils.ObjectArrayTypeInfo
-
- getArity() - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo
-
- getArity() - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializerBase
-
- getArity() - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfoBase
-
- getArity() - Method in class org.apache.flink.api.java.typeutils.ValueTypeInfo
-
- getArity() - Method in class org.apache.flink.api.java.typeutils.WritableTypeInfo
-
- getArray() - Method in class org.apache.flink.core.memory.HeapMemorySegment
-
Gets the byte array that backs this memory segment.
- getArray() - Method in class org.apache.flink.core.memory.HybridMemorySegment
-
- getAttemptNumber() - Method in interface org.apache.flink.api.common.functions.RuntimeContext
-
Gets the attempt number of this parallel subtask.
- getAttemptNumber() - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
-
- getAttemptNumber() - Method in class org.apache.flink.api.common.TaskInfo
-
Gets the attempt number of this parallel subtask.
- getAutoWatermarkInterval() - Method in class org.apache.flink.api.common.ExecutionConfig
-
Returns the interval of the automatic watermark emission.
- getAvailablePort() - Static method in class org.apache.flink.util.NetUtils
-
Find a non-occupied port.
- 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
-
- getBasicAndBasicValueTupleTypeInfo(Class<?>...) - Static method in class org.apache.flink.api.java.typeutils.TupleTypeInfo
-
- getBasicTupleTypeInfo(Class<?>...) - Static method in class org.apache.flink.api.java.typeutils.TupleTypeInfo
-
- 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
-
- getBinaryOperatorReturnType(Function, Class<?>, boolean, boolean, TypeInformation<IN1>, TypeInformation<IN2>, String, boolean) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
Returns the binary operator's return type.
- getBinaryOperatorReturnType(Function, Class<?>, int, int, TypeInformation<IN1>, TypeInformation<IN2>, String, boolean) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
Returns the binary operator's return type.
- 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.HeapMemorySegment
-
- getBoolean(int) - Method in class org.apache.flink.core.memory.HybridMemorySegment
-
- 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.util.AbstractID
-
Gets the bytes underlying this ID.
- 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 a char value from the given position, in the system's native byte order.
- getCharArray() - Method in class org.apache.flink.types.StringValue
-
Returns this StringValue's internal character data.
- getCharBigEndian(int) - Method in class org.apache.flink.core.memory.MemorySegment
-
Reads an character value (16 bit, 2 bytes) from the given position, in big-endian byte order.
- getCharLittleEndian(int) - Method in class org.apache.flink.core.memory.MemorySegment
-
Reads an character value (16 bit, 2 bytes) from the given position, in little-endian byte order.
- 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.
- getCodeAnalysisMode() - Method in class org.apache.flink.api.common.ExecutionConfig
-
- getCoGroupReturnTypes(CoGroupFunction<IN1, IN2, OUT>, TypeInformation<IN1>, TypeInformation<IN2>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
- getCoGroupReturnTypes(CoGroupFunction<IN1, IN2, OUT>, TypeInformation<IN1>, TypeInformation<IN2>, String, boolean) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
- getCommentPrefix() - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
-
- getCommonFileExtensions() - Method in class org.apache.flink.api.common.io.compression.DeflateInflaterInputStreamFactory
-
- getCommonFileExtensions() - Method in class org.apache.flink.api.common.io.compression.GzipInflaterInputStreamFactory
-
- getCommonFileExtensions() - Method in interface org.apache.flink.api.common.io.compression.InflaterInputStreamFactory
-
Lists a collection of typical file extensions (e.g., "gz", "gzip") that are associated with the compression
algorithm in the
InflaterInputStream
T
.
- getCompilerHints() - Method in class org.apache.flink.api.common.operators.Operator
-
Gets the compiler hints for this contract instance.
- getComponentClass() - Method in class org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
-
Gets the class that represents the component type.
- getComponentInfo() - Method in class org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
-
- getComponentInfo() - Method in class org.apache.flink.api.java.typeutils.ObjectArrayTypeInfo
-
- getComponentType() - Method in class org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
-
Gets the type information of the component type.
- 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
-
- getConvergenceCriterion() - Method in class org.apache.flink.api.common.aggregators.AggregatorRegistry
-
- getConvergenceCriterionAggregatorName() - Method in class org.apache.flink.api.common.aggregators.AggregatorRegistry
-
- getCorrectHostnamePort(String) - Static method in class org.apache.flink.util.NetUtils
-
Method to validate if the given String represents a hostname:port.
- getCrossHint() - Method in class org.apache.flink.api.common.operators.base.CrossOperatorBase
-
- getCrossReturnTypes(CrossFunction<IN1, IN2, OUT>, TypeInformation<IN1>, TypeInformation<IN2>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
- getCrossReturnTypes(CrossFunction<IN1, IN2, OUT>, TypeInformation<IN1>, TypeInformation<IN2>, String, boolean) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
- 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
-
- getDataSinks() - Method in class org.apache.flink.api.common.Plan
-
Gets all the data sinks of this job.
- getDataType() - Method in interface org.apache.flink.api.common.typeutils.TypeSerializerFactory
-
- getDataType() - Method in class org.apache.flink.api.java.typeutils.runtime.RuntimeSerializerFactory
-
- getDeclaredField(Class<?>, String) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
- 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.
- getDefaultKryoSerializerClasses() - Method in class org.apache.flink.api.common.ExecutionConfig
-
Returns the registered default Kryo Serializer classes.
- getDefaultKryoSerializers() - Method in class org.apache.flink.api.common.ExecutionConfig
-
Returns the registered default Kryo Serializers.
- getDefaultParallelism() - Method in class org.apache.flink.api.common.Plan
-
Gets the default parallelism for this job.
- getDefaultValue() - Method in class org.apache.flink.api.common.state.StateDescriptor
-
Returns the default value.
- getDelayBetweenAttempts() - Method in class org.apache.flink.api.common.restartstrategy.RestartStrategies.FixedDelayRestartStrategyConfiguration
-
- 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.
- getDescription() - Method in class org.apache.flink.api.common.restartstrategy.RestartStrategies.FixedDelayRestartStrategyConfiguration
-
- getDescription() - Method in class org.apache.flink.api.common.restartstrategy.RestartStrategies.NoRestartStrategyConfiguration
-
- getDescription() - Method in class org.apache.flink.api.common.restartstrategy.RestartStrategies.RestartStrategyConfiguration
-
Returns a description which is shown in the web interface
- 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
-
- getDirectoryFileName(int) - Method in class org.apache.flink.api.common.io.FileOutputFormat
-
- 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
-
- getExecutionConfig() - Method in interface org.apache.flink.api.common.functions.RuntimeContext
-
- getExecutionConfig() - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
-
- getExecutionConfig() - Method in class org.apache.flink.api.common.Plan
-
Gets the execution config object.
- getExecutionMode() - Method in class org.apache.flink.api.common.ExecutionConfig
-
Gets the execution mode used to execute the program.
- getExecutionRetryDelay() - Method in class org.apache.flink.api.common.ExecutionConfig
-
- getFactory() - Static method in class org.apache.flink.core.memory.MemorySegmentFactory
-
Gets the factory.
- getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple
-
Gets the field at the specified position.
- getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple0
-
- getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple1
-
- getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple10
-
- getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple11
-
- getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple12
-
- getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple13
-
- getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple14
-
- getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple15
-
- getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple16
-
- getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple17
-
- getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple18
-
- getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple19
-
- getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple2
-
- getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple20
-
- getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple21
-
- getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple22
-
- getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple23
-
- getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple24
-
- getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple25
-
- getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple3
-
- getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple4
-
- getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple5
-
- getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple6
-
- getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple7
-
- getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple8
-
- getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple9
-
- getField() - Method in class org.apache.flink.api.java.typeutils.PojoField
-
- 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
-
- getFieldIndex(String) - Method in class org.apache.flink.api.common.typeutils.CompositeType
-
Returns the field index of the composite field of the given name.
- getFieldIndex(String) - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo
-
- getFieldIndex(String) - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfo
-
- getFieldInto(int, Value) - Method in class org.apache.flink.types.Record
-
Gets the field at the given position.
- getFieldName() - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo.NamedFlatFieldDescriptor
-
- getFieldNames() - Method in class org.apache.flink.api.common.typeutils.CompositeType
-
Returns the names of the composite fields of this type.
- getFieldNames() - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo
-
- getFieldNames() - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfo
-
- getFieldNotNull(int) - Method in class org.apache.flink.api.java.tuple.Tuple
-
Gets the field at the specified position, throws NullFieldException if the field is null.
- 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
-
- 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.
- 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
-
- getFlatComparator(List<TypeComparator>) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoComparator
-
- getFlatComparator(List<TypeComparator>) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
-
- getFlatComparators() - Method in class org.apache.flink.api.common.typeutils.base.array.PrimitiveArrayComparator
-
- 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.TypeComparator
-
Get the field comparators.
- getFlatComparators() - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueComparator
-
- getFlatComparators() - Method in class org.apache.flink.api.java.typeutils.runtime.GenericTypeComparator
-
- getFlatComparators() - Method in class org.apache.flink.api.java.typeutils.runtime.ValueComparator
-
- getFlatComparators() - Method in class org.apache.flink.api.java.typeutils.runtime.WritableComparator
-
- getFlatFields(String) - Method in class org.apache.flink.api.common.typeutils.CompositeType
-
Returns the flat field descriptors for the given field expression.
- getFlatFields(String, int, List<CompositeType.FlatFieldDescriptor>) - Method in class org.apache.flink.api.common.typeutils.CompositeType
-
Computes the flat field descriptors for the given field expression with the given offset.
- getFlatFields(String, int, List<CompositeType.FlatFieldDescriptor>) - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo
-
- getFlatFields(String, int, List<CompositeType.FlatFieldDescriptor>) - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfoBase
-
- getFlatJoinReturnTypes(FlatJoinFunction<IN1, IN2, OUT>, TypeInformation<IN1>, TypeInformation<IN2>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
- getFlatJoinReturnTypes(FlatJoinFunction<IN1, IN2, OUT>, TypeInformation<IN1>, TypeInformation<IN2>, String, boolean) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
- getFlatMapReturnTypes(FlatMapFunction<IN, OUT>, TypeInformation<IN>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
- getFlatMapReturnTypes(FlatMapFunction<IN, OUT>, TypeInformation<IN>, String, boolean) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
- 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.
- getFoldFunction() - Method in class org.apache.flink.api.common.state.FoldingStateDescriptor
-
Returns the fold function to be used for the folding state.
- getFoldReturnTypes(FoldFunction<IN, OUT>, TypeInformation<IN>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
- getFoldReturnTypes(FoldFunction<IN, OUT>, TypeInformation<IN>, String, boolean) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
- getForClass(Class<X>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
Creates type information from a given Class such as Integer, String[] or POJOs.
- 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.
- getForObject(X) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
- getForwardingSourceField(int, int) - Method in class org.apache.flink.api.common.operators.DualInputSemanticProperties
-
- getForwardingSourceField(int, int) - Method in class org.apache.flink.api.common.operators.SemanticProperties.EmptySemanticProperties
-
- getForwardingSourceField(int, int) - Method in interface org.apache.flink.api.common.operators.SemanticProperties
-
Returns the index of the source field on the given input from which the target field
has been unmodified copied by a function.
- getForwardingSourceField(int, int) - Method in class org.apache.flink.api.common.operators.SingleInputSemanticProperties.AllFieldsForwardedProperties
-
- getForwardingSourceField(int, int) - Method in class org.apache.flink.api.common.operators.SingleInputSemanticProperties
-
- getForwardingTargetFields(int, int) - Method in class org.apache.flink.api.common.operators.DualInputSemanticProperties
-
- getForwardingTargetFields(int, int) - Method in class org.apache.flink.api.common.operators.SemanticProperties.EmptySemanticProperties
-
- getForwardingTargetFields(int, int) - Method in interface org.apache.flink.api.common.operators.SemanticProperties
-
Returns the indexes of all target fields to which a source field has been
unmodified copied by a function.
- getForwardingTargetFields(int, int) - Method in class org.apache.flink.api.common.operators.SingleInputSemanticProperties.AllFieldsForwardedProperties
-
- getForwardingTargetFields(int, int) - Method in class org.apache.flink.api.common.operators.SingleInputSemanticProperties
-
- getFunctionName() - Method in class org.apache.flink.api.java.typeutils.MissingTypeInfo
-
- 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
-
- getGenericParameters() - Method in class org.apache.flink.api.common.typeinfo.TypeInformation
-
Returns the generic parameters of this type.
- getGlobalJobParameters() - Method in class org.apache.flink.api.common.ExecutionConfig
-
- getGroupCombineReturnTypes(GroupCombineFunction<IN, OUT>, TypeInformation<IN>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
- getGroupCombineReturnTypes(GroupCombineFunction<IN, OUT>, TypeInformation<IN>, String, boolean) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
- getGroupOrder(int) - Method in class org.apache.flink.api.common.operators.base.CoGroupOperatorBase
-
Gets the value order for an input, i.e.
- getGroupOrder(int) - Method in class org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase
-
Gets the value order for an input, i.e.
- getGroupOrder() - Method in class org.apache.flink.api.common.operators.base.GroupCombineOperatorBase
-
Gets the order of elements within a reduce group.
- 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.
- getGroupOrderForInputOne() - Method in class org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase
-
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.
- getGroupOrderForInputTwo() - Method in class org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase
-
Gets the order of elements within a group for the second input.
- getGroupReduceReturnTypes(GroupReduceFunction<IN, OUT>, TypeInformation<IN>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
- getGroupReduceReturnTypes(GroupReduceFunction<IN, OUT>, TypeInformation<IN>, String, boolean) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
- 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
-
- getHomeDirectory() - Method in class org.apache.flink.core.fs.FileSystem
-
Returns the path of the user's home directory in this file system.
- getHomeDirectory() - Method in class org.apache.flink.core.fs.local.LocalFileSystem
-
- 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 this parallel subtask.
- getIndexOfThisSubtask() - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
-
- getIndexOfThisSubtask() - Method in class org.apache.flink.api.common.TaskInfo
-
Gets the number of this parallel subtask.
- getInflaterInputStreamFactory(String) - Static method in class org.apache.flink.api.common.io.FileInputFormat
-
- 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
-
Tries to get the PrimitiveArrayTypeInfo for an array.
- getInfoFor(Class<T>, TypeInformation<C>) - Static method in class org.apache.flink.api.java.typeutils.ObjectArrayTypeInfo
-
- getInfoFor(TypeInformation<C>) - Static method in class org.apache.flink.api.java.typeutils.ObjectArrayTypeInfo
-
- 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.
- getInputFormatTypes(InputFormat<IN, ?>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
- 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(S[]) - Method in class org.apache.flink.api.common.io.ReplicatingInputFormat
-
- 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.Keys.SelectorFunctionKeys
-
- getInputType() - Method in class org.apache.flink.api.common.operators.UnaryOperatorInformation
-
- getInputView() - Method in class org.apache.flink.api.java.typeutils.runtime.DataInputViewStream
-
- getInstance() - Static method in class org.apache.flink.api.common.io.compression.DeflateInflaterInputStreamFactory
-
- getInstance() - Static method in class org.apache.flink.api.common.io.compression.GzipInflaterInputStreamFactory
-
- 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
-
Deprecated.
- 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
-
- getIterationRuntimeContext() - Method in interface org.apache.flink.api.common.functions.RichFunction
-
Gets a specialized version of the
RuntimeContext
, which has additional information
about the iteration in which the function is executed.
- getJobID() - Method in class org.apache.flink.api.common.JobSubmissionResult
-
Returns the JobID assigned to the job by the Flink runtime.
- getJobId() - Method in class org.apache.flink.api.common.Plan
-
Gets the ID of the job that the dataflow plan belongs to.
- 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
-
- getJoinReturnTypes(JoinFunction<IN1, IN2, OUT>, TypeInformation<IN1>, TypeInformation<IN2>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
- getJoinReturnTypes(JoinFunction<IN1, IN2, OUT>, TypeInformation<IN1>, TypeInformation<IN2>, String, boolean) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
- getKey(IN) - Method in interface org.apache.flink.api.java.functions.KeySelector
-
User-defined function that extracts the key from an arbitrary object.
- 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
-
- getKeyExtractor() - Method in class org.apache.flink.api.common.operators.Keys.SelectorFunctionKeys
-
- getKeyFields() - Method in class org.apache.flink.api.java.typeutils.runtime.PojoComparator
-
- getKeyFieldTypes() - Method in class org.apache.flink.api.common.operators.Keys.ExpressionKeys
-
- getKeyFieldTypes() - Method in class org.apache.flink.api.common.operators.Keys
-
- getKeyFieldTypes() - Method in class org.apache.flink.api.common.operators.Keys.SelectorFunctionKeys
-
- getKeyPositions() - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
-
- getKeySelectorTypes(KeySelector<IN, OUT>, TypeInformation<IN>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
- getKeySelectorTypes(KeySelector<IN, OUT>, TypeInformation<IN>, String, boolean) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
- getKeyType() - Method in class org.apache.flink.api.common.operators.Keys.SelectorFunctionKeys
-
- getKeyValueState(String, Class<S>, S) - Method in interface org.apache.flink.api.common.functions.RuntimeContext
-
- getKeyValueState(String, TypeInformation<S>, S) - Method in interface org.apache.flink.api.common.functions.RuntimeContext
-
- getKeyValueState(String, Class<S>, S) - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
-
Deprecated.
- getKeyValueState(String, TypeInformation<S>, S) - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
-
Deprecated.
- getKryo() - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer
-
- 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.BooleanParser
-
- getLastResult() - Method in class org.apache.flink.types.parser.BooleanValueParser
-
- 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
-
- getLeftType() - Method in class org.apache.flink.api.java.typeutils.EitherTypeInfo
-
- 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.TypeSerializer
-
Gets the length of the data type, if it is a fix length data type.
- getLength() - Method in class org.apache.flink.api.java.typeutils.runtime.AvroSerializer
-
- getLength() - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer
-
- getLength() - Method in class org.apache.flink.api.java.typeutils.runtime.EitherSerializer
-
- getLength() - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer
-
- getLength() - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer
-
- getLength() - Method in class org.apache.flink.api.java.typeutils.runtime.Tuple0Serializer
-
- getLength() - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializerBase
-
- getLength() - Method in class org.apache.flink.api.java.typeutils.runtime.ValueSerializer
-
- getLength() - Method in class org.apache.flink.api.java.typeutils.runtime.WritableSerializer
-
- 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
-
- getLineLengthLimit() - Method in class org.apache.flink.api.common.io.DelimitedInputFormat
-
- getListState(ListStateDescriptor<T>) - Method in interface org.apache.flink.api.common.functions.RuntimeContext
-
Gets a handle to the system's key/value list state.
- getListState(ListStateDescriptor<T>) - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
-
- 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.AverageAccumulator
-
- 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.ListAccumulator
-
- getLocalValue() - Method in class org.apache.flink.api.common.accumulators.LongCounter
-
- getLocalValue() - Method in class org.apache.flink.api.common.accumulators.SerializedListAccumulator
-
- getLocalValuePrimitive() - 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.
- getLowerPart() - Method in class org.apache.flink.util.AbstractID
-
Gets the lower 64 bits of the ID.
- getMapPartitionReturnTypes(MapPartitionFunction<IN, OUT>, TypeInformation<IN>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
- getMapPartitionReturnTypes(MapPartitionFunction<IN, OUT>, TypeInformation<IN>, String, boolean) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
- getMapReturnTypes(MapFunction<IN, OUT>, TypeInformation<IN>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
- getMapReturnTypes(MapFunction<IN, OUT>, TypeInformation<IN>, String, boolean) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
- 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 class org.apache.flink.util.SplittableIterator
-
The maximum number of splits into which this iterator can be split up.
- 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.api.common.state.StateDescriptor
-
Returns the name of this StateDescriptor
.
- getName() - Method in class org.apache.flink.core.fs.Path
-
Returns the final component of this path, i.e., everything that follows the last separator.
- getNetRuntime() - Method in class org.apache.flink.api.common.JobExecutionResult
-
Gets the net execution time of the job, i.e., the execution time in the parallel system,
without the pre-flight steps like the optimizer.
- getNetRuntime(TimeUnit) - Method in class org.apache.flink.api.common.JobExecutionResult
-
Gets the net execution time of the job, i.e., the execution time in the parallel system,
without the pre-flight steps like the optimizer in a desired time unit.
- getNextInputSplit(String, int) - Method in class org.apache.flink.api.common.io.DefaultInputSplitAssigner
-
- getNextInputSplit(String, int) - Method in class org.apache.flink.api.common.io.LocatableInputSplitAssigner
-
- getNextInputSplit(String, int) - Method in class org.apache.flink.api.common.io.ReplicatingInputSplitAssigner
-
- getNextInputSplit(String, int) - 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.array.PrimitiveArrayComparator
-
- 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.TypeComparator
-
Gets the number of bytes that the normalized key would maximally take.
- getNormalizeKeyLen() - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueComparator
-
- getNormalizeKeyLen() - Method in class org.apache.flink.api.java.typeutils.runtime.GenericTypeComparator
-
- getNormalizeKeyLen() - Method in class org.apache.flink.api.java.typeutils.runtime.PojoComparator
-
- getNormalizeKeyLen() - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
-
- getNormalizeKeyLen() - Method in class org.apache.flink.api.java.typeutils.runtime.ValueComparator
-
- getNormalizeKeyLen() - Method in class org.apache.flink.api.java.typeutils.runtime.WritableComparator
-
- getNumberOfExecutionRetries() - Method in class org.apache.flink.api.common.ExecutionConfig
-
- 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
-
- getNumberOfKeyFields() - Method in class org.apache.flink.api.common.operators.Keys.ExpressionKeys
-
- getNumberOfKeyFields() - Method in class org.apache.flink.api.common.operators.Keys
-
- getNumberOfKeyFields() - Method in class org.apache.flink.api.common.operators.Keys.SelectorFunctionKeys
-
- 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 parallelism with which the parallel task runs.
- getNumberOfParallelSubtasks() - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
-
- getNumberOfParallelSubtasks() - Method in class org.apache.flink.api.common.TaskInfo
-
Gets the parallelism with which the parallel task runs.
- 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.
- getNumLineSamples() - Method in class org.apache.flink.api.common.io.DelimitedInputFormat
-
- getNumSplits() - Method in class org.apache.flink.api.common.io.FileInputFormat
-
- getOffHeapBuffer() - Method in class org.apache.flink.core.memory.HybridMemorySegment
-
Gets the buffer that owns the memory of this memory segment.
- 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
-
- getOuterJoinType() - Method in class org.apache.flink.api.common.operators.base.OuterJoinOperatorBase
-
- 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.
- getOwner() - Method in class org.apache.flink.core.memory.MemorySegment
-
Gets the owner of this memory segment.
- getParallelism() - Method in class org.apache.flink.api.common.ExecutionConfig
-
Gets the parallelism with which operation are executed by default.
- getParallelism() - Method in class org.apache.flink.api.common.operators.Operator
-
Gets the parallelism for this contract instance.
- getParameters() - Method in class org.apache.flink.api.common.operators.Operator
-
Gets the stub parameters of this contract.
- getParameterType(Class<?>, Class<?>, int) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
- getParent() - Method in class org.apache.flink.core.fs.Path
-
Returns the parent of a path, i.e., everything that precedes the last separator
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
-
- getPartitionerTypes(Partitioner<T>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
- getPartitionerTypes(Partitioner<T>, String, boolean) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
- getPartitionMethod() - Method in class org.apache.flink.api.common.operators.base.PartitionOperatorBase
-
- getPartitionOrdering() - Method in class org.apache.flink.api.common.operators.base.SortPartitionOperatorBase
-
- 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.
- getPojoFieldAt(int) - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo
-
- getPortRangeFromString(String) - Static method in class org.apache.flink.util.NetUtils
-
Returns an iterator over available ports defined by the range definition.
- getPos() - Method in class org.apache.flink.api.common.io.InputStreamFSInputWrapper
-
- getPos() - Method in class org.apache.flink.core.fs.FSDataInputStream
-
Get the current position in the input stream.
- getPos() - Method in class org.apache.flink.core.fs.local.LocalDataInputStream
-
- 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
-
- getProducedType() - Method in interface org.apache.flink.api.java.typeutils.ResultTypeQueryable
-
Gets the data type (as a
TypeInformation
) produced by this function or input format.
- 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.
- getRangeIndex(T) - Method in class org.apache.flink.api.common.distributions.CommonRangeBoundaries
-
- getRangeIndex(T) - Method in interface org.apache.flink.api.common.distributions.RangeBoundaries
-
Get the range index of record.
- getReadFields(int) - Method in class org.apache.flink.api.common.operators.DualInputSemanticProperties
-
- getReadFields(int) - Method in class org.apache.flink.api.common.operators.SemanticProperties.EmptySemanticProperties
-
- getReadFields(int) - Method in interface org.apache.flink.api.common.operators.SemanticProperties
-
Returns the position indexes of all fields of an input that are accessed by a function.
- getReadFields(int) - Method in class org.apache.flink.api.common.operators.SingleInputSemanticProperties
-
- getRecordCount() - Method in class org.apache.flink.api.common.io.BlockInfo
-
Returns the recordCount.
- getReduceFunction() - Method in class org.apache.flink.api.common.state.ReducingStateDescriptor
-
Returns the reduce function to be used for the reducing state.
- getReducingState(ReducingStateDescriptor<T>) - Method in interface org.apache.flink.api.common.functions.RuntimeContext
-
Gets a handle to the system's key/value list state.
- getReducingState(ReducingStateDescriptor<T>) - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
-
- getRegisteredKryoTypes() - Method in class org.apache.flink.api.common.ExecutionConfig
-
Returns the registered Kryo types.
- getRegisteredPojoTypes() - Method in class org.apache.flink.api.common.ExecutionConfig
-
Returns the registered POJO types.
- getRegisteredTypesWithKryoSerializerClasses() - Method in class org.apache.flink.api.common.ExecutionConfig
-
Returns the registered types with their Kryo Serializer classes.
- getRegisteredTypesWithKryoSerializers() - Method in class org.apache.flink.api.common.ExecutionConfig
-
Returns the registered types with Kryo Serializers.
- getReplicatedInputFormat() - Method in class org.apache.flink.api.common.io.ReplicatingInputFormat
-
- 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
-
- getRestartAttempts() - Method in class org.apache.flink.api.common.restartstrategy.RestartStrategies.FixedDelayRestartStrategyConfiguration
-
- getRestartStrategy() - Method in class org.apache.flink.api.common.ExecutionConfig
-
Returns the restart strategy which has been set for the current job.
- getRestartStrategyConfiguration() - Method in class org.apache.flink.api.common.Plan
-
Returns the specified restart strategy configuration.
- getResultsFormated(Map<String, Object>) - Static method in class org.apache.flink.api.common.accumulators.AccumulatorHelper
-
- getRightType() - Method in class org.apache.flink.api.java.typeutils.EitherTypeInfo
-
- 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, such as the
parallelism of the function, the subtask index of the function, or the name of
the of the task that executes the function.
- getRuntimeContext() - Method in class org.apache.flink.api.common.io.ReplicatingInputFormat
-
- getRuntimeContext() - Method in class org.apache.flink.api.common.io.RichInputFormat
-
- getRuntimeContext() - Method in class org.apache.flink.api.common.io.RichOutputFormat
-
- 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.base.SortPartitionOperatorBase
-
- 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.ExecutionConfig.SerializableSerializer
-
- getSerializer() - Method in class org.apache.flink.api.common.state.StateDescriptor
-
Returns the
TypeSerializer
that can be used to serialize the value in the state.
- getSerializer() - Method in interface org.apache.flink.api.common.typeutils.TypeSerializerFactory
-
- getSerializer() - Method in class org.apache.flink.api.java.typeutils.runtime.RuntimeSerializerFactory
-
- getSessionTimeout() - Method in class org.apache.flink.api.common.Plan
-
- 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.
- getShortBigEndian(int) - Method in class org.apache.flink.core.memory.MemorySegment
-
Reads an short integer value (16 bit, 2 bytes) from the given position, in big-endian byte order.
- getShortLittleEndian(int) - Method in class org.apache.flink.core.memory.MemorySegment
-
Reads an short integer value (16 bit, 2 bytes) from the given position, in little-endian byte order.
- getShortName() - Method in enum org.apache.flink.api.common.operators.Order
-
- getSizeOfSerializedState() - Method in class org.apache.flink.util.SerializedValue
-
Gets the size of the serialized state.
- 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.SplittableIterator
-
Splits this iterator into n partitions and returns the i-th partition
out of those.
- getSplitDataProperties() - Method in class org.apache.flink.api.common.operators.GenericDataSourceBase
-
Returns the data properties of this data source's splits.
- getSplitGroupKeys() - Method in interface org.apache.flink.api.common.operators.GenericDataSourceBase.SplitDataProperties
-
- 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
-
- getSplitOrder() - Method in interface org.apache.flink.api.common.operators.GenericDataSourceBase.SplitDataProperties
-
- getSplitPartitioner() - Method in interface org.apache.flink.api.common.operators.GenericDataSourceBase.SplitDataProperties
-
- getSplitPartitionKeys() - Method in interface org.apache.flink.api.common.operators.GenericDataSourceBase.SplitDataProperties
-
- 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.
- getState(ValueStateDescriptor<T>) - Method in interface org.apache.flink.api.common.functions.RuntimeContext
-
Gets a handle to the system's key/value state.
- getState(ValueStateDescriptor<T>) - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
-
- 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.
- getStatistics(BaseStatistics) - Method in class org.apache.flink.api.common.io.ReplicatingInputFormat
-
- 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
-
- getTaskName() - Method in class org.apache.flink.api.common.TaskInfo
-
Returns the name of the task
- getTaskNameWithSubtasks() - Method in interface org.apache.flink.api.common.functions.RuntimeContext
-
- getTaskNameWithSubtasks() - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
-
- getTaskNameWithSubtasks() - Method in class org.apache.flink.api.common.TaskInfo
-
- 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
-
Gets the number of logical fields in this type.
- getTotalFields() - Method in class org.apache.flink.api.java.typeutils.EitherTypeInfo
-
- getTotalFields() - Method in class org.apache.flink.api.java.typeutils.EnumTypeInfo
-
- getTotalFields() - Method in class org.apache.flink.api.java.typeutils.GenericTypeInfo
-
- getTotalFields() - Method in class org.apache.flink.api.java.typeutils.MissingTypeInfo
-
- getTotalFields() - Method in class org.apache.flink.api.java.typeutils.ObjectArrayTypeInfo
-
- getTotalFields() - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo
-
- getTotalFields() - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfoBase
-
- getTotalFields() - Method in class org.apache.flink.api.java.typeutils.ValueTypeInfo
-
- getTotalFields() - Method in class org.apache.flink.api.java.typeutils.WritableTypeInfo
-
- 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
-
- getTupleClass(int) - Static method in class org.apache.flink.api.java.tuple.Tuple
-
Gets the class corresponding to the tuple of the given arity (dimensions).
- getTupleClass() - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializerBase
-
- 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(String) - Method in class org.apache.flink.api.common.typeutils.CompositeType
-
Returns the type of the (nested) field at the given field expression position.
- getTypeAt(int) - Method in class org.apache.flink.api.common.typeutils.CompositeType
-
Returns the type of the (unnested) field at the given field position.
- getTypeAt(String) - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo
-
- getTypeAt(int) - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo
-
- getTypeAt(String) - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfoBase
-
- getTypeAt(int) - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfoBase
-
- 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
-
Gets the class of the type represented by this type information.
- getTypeClass() - Method in class org.apache.flink.api.common.typeutils.CompositeType
-
Returns the type class of the composite type
- getTypeClass() - Method in class org.apache.flink.api.java.typeutils.EitherTypeInfo
-
- getTypeClass() - Method in class org.apache.flink.api.java.typeutils.EnumTypeInfo
-
- getTypeClass() - Method in class org.apache.flink.api.java.typeutils.GenericTypeInfo
-
- getTypeClass() - Method in class org.apache.flink.api.java.typeutils.MissingTypeInfo
-
- getTypeClass() - Method in class org.apache.flink.api.java.typeutils.ObjectArrayTypeInfo
-
- getTypeClass() - Method in class org.apache.flink.api.java.typeutils.ValueTypeInfo
-
- getTypeClass() - Method in class org.apache.flink.api.java.typeutils.WritableTypeInfo
-
- getTypeException() - Method in class org.apache.flink.api.java.typeutils.MissingTypeInfo
-
- getTypeInfo() - Method in class org.apache.flink.api.common.typeinfo.TypeHint
-
Gets the type information described by this TypeHint.
- getTypeInformation() - Method in class org.apache.flink.api.java.typeutils.PojoField
-
- getTypes() - Method in class org.apache.flink.api.common.operators.Ordering
-
- getUnaryOperatorReturnType(Function, Class<?>, boolean, boolean, TypeInformation<IN>, String, boolean) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
Returns the unary operator's return type.
- getUnaryOperatorReturnType(Function, Class<?>, int, int, TypeInformation<IN>, String, boolean) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
Returns the unary operator's return type.
- getUniqueFields() - Method in class org.apache.flink.api.common.operators.CompilerHints
-
Gets the FieldSets that are unique
- getUpperPart() - Method in class org.apache.flink.util.AbstractID
-
Gets the upper 64 bits of the ID.
- 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
-
- GlobalConfiguration - Class in org.apache.flink.configuration
-
Global configuration object for Flink.
- GlobalJobParameters() - Constructor for class org.apache.flink.api.common.ExecutionConfig.GlobalJobParameters
-
- GroupCombineFunction<IN,OUT> - Interface in org.apache.flink.api.common.functions
-
Generic interface used for combine functions ("combiners").
- GroupCombineOperatorBase<IN,OUT,FT extends GroupCombineFunction<IN,OUT>> - Class in org.apache.flink.api.common.operators.base
-
Base operator for the combineGroup transformation.
- GroupCombineOperatorBase(FT, UnaryOperatorInformation<IN, OUT>, int[], String) - Constructor for class org.apache.flink.api.common.operators.base.GroupCombineOperatorBase
-
- 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
-
- GzipInflaterInputStreamFactory - Class in org.apache.flink.api.common.io.compression
-
Factory for input streams that decompress the GZIP compression format.
- GzipInflaterInputStreamFactory() - Constructor for class org.apache.flink.api.common.io.compression.GzipInflaterInputStreamFactory
-
- IllegalConfigurationException - Exception in org.apache.flink.configuration
-
An
IllegalConfigurationException
is thrown when
the values in a given
Configuration
are not valid.
- IllegalConfigurationException(String) - Constructor for exception org.apache.flink.configuration.IllegalConfigurationException
-
Constructs an new IllegalConfigurationException with the given error message.
- IllegalConfigurationException(String, Throwable) - Constructor for exception org.apache.flink.configuration.IllegalConfigurationException
-
Constructs an new IllegalConfigurationException 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.
- IncompatibleKeysException(String) - Constructor for exception org.apache.flink.api.common.operators.Keys.IncompatibleKeysException
-
- IncompatibleKeysException(TypeInformation<?>, TypeInformation<?>) - Constructor for exception org.apache.flink.api.common.operators.Keys.IncompatibleKeysException
-
- indexes - Variable in class org.apache.flink.api.common.operators.Ordering
-
- indexOf(Object) - Method in class org.apache.flink.types.ListValue
-
- INFLATER_INPUT_STREAM_FACTORIES - Static variable in class org.apache.flink.api.common.io.FileInputFormat
-
A mapping of file extensions to decompression algorithms based on DEFLATE.
- InflaterInputStreamFactory<T extends InflaterInputStream> - Interface in org.apache.flink.api.common.io.compression
-
- 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
-
The method that reads the data elements from the broadcast variable and
creates the transformed data structure.
- initializeFactory(MemorySegmentFactory.Factory) - Static method in class org.apache.flink.core.memory.MemorySegmentFactory
-
Initializes this factory with the given concrete factory.
- initializeFields(T) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer
-
- 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.
- InitializeOnMaster - Interface in org.apache.flink.api.common.io
-
This interface may be implemented by
OutputFormat
s to have the master initialize them globally.
- initializeSerializerUnlessSet(ExecutionConfig) - Method in class org.apache.flink.api.common.state.StateDescriptor
-
Initializes the serializer, unless it has been initialized before.
- initializeTypeComparatorBuilder(int) - Method in interface org.apache.flink.api.common.typeutils.CompositeType.TypeComparatorBuilder
-
- 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.
- InnerJoinOperatorBase<IN1,IN2,OUT,FT extends FlatJoinFunction<IN1,IN2,OUT>> - Class in org.apache.flink.api.common.operators.base
-
- InnerJoinOperatorBase(UserCodeWrapper<FT>, BinaryOperatorInformation<IN1, IN2, OUT>, int[], int[], String) - Constructor for class org.apache.flink.api.common.operators.base.InnerJoinOperatorBase
-
- InnerJoinOperatorBase(FT, BinaryOperatorInformation<IN1, IN2, OUT>, int[], int[], String) - Constructor for class org.apache.flink.api.common.operators.base.InnerJoinOperatorBase
-
- InnerJoinOperatorBase(Class<? extends FT>, BinaryOperatorInformation<IN1, IN2, OUT>, int[], int[], String) - Constructor for class org.apache.flink.api.common.operators.base.InnerJoinOperatorBase
-
- 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
-
- InputStreamFSInputWrapper - Class in org.apache.flink.api.common.io
-
- InputStreamFSInputWrapper(InputStream) - Constructor for class org.apache.flink.api.common.io.InputStreamFSInputWrapper
-
- 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
- InputTypeConfigurable - Interface in org.apache.flink.api.java.typeutils
-
OutputFormat
s can implement this interface to be configured
with the data type they will operate on.
- inputView - Variable in class org.apache.flink.api.java.typeutils.runtime.DataInputViewStream
-
- 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
-
- INSTANCE - Static variable in class org.apache.flink.api.java.tuple.Tuple0
-
An immutable reusable Tuple0 instance
- INSTANCE - Static variable in class org.apache.flink.api.java.typeutils.runtime.Tuple0Serializer
-
- 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.
- instantiateDeserializationUtils() - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
-
- InstantiationUtil - Class in org.apache.flink.util
-
Utility class to create instances from class objects and checking failure reasons.
- InstantiationUtil.ClassLoaderObjectInputStream - Class in org.apache.flink.util
-
A custom ObjectInputStream that can also load user-code using a
user-code ClassLoader.
- 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
-
- INT_VALUE_TYPE_INFO - Static variable in class org.apache.flink.api.java.typeutils.ValueTypeInfo
-
- 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
-
An accumulator that sums up Integer
values.
- IntCounter() - Constructor for class org.apache.flink.api.common.accumulators.IntCounter
-
- IntegerTypeInfo<T> - Class in org.apache.flink.api.common.typeinfo
-
Type information for numeric integer primitive types: int, long, byte, short, character.
- IntegerTypeInfo(Class<T>, Class<?>[], TypeSerializer<T>, Class<? extends TypeComparator<T>>) - Constructor for class org.apache.flink.api.common.typeinfo.IntegerTypeInfo
-
- 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
-
- IntPrimitiveArrayComparator - Class in org.apache.flink.api.common.typeutils.base.array
-
- IntPrimitiveArrayComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.array.IntPrimitiveArrayComparator
-
- 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
-
- InvalidFieldReferenceException(String) - Constructor for exception org.apache.flink.api.common.typeutils.CompositeType.InvalidFieldReferenceException
-
- invalidLineCount - Variable in class org.apache.flink.api.common.io.GenericCsvInputFormat
-
- 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
-
Creates a new exception with the given message and cause.
- InvalidSemanticAnnotationException(String) - Constructor for exception org.apache.flink.api.common.operators.SemanticProperties.InvalidSemanticAnnotationException
-
- InvalidSemanticAnnotationException(String, Throwable) - Constructor for exception org.apache.flink.api.common.operators.SemanticProperties.InvalidSemanticAnnotationException
-
- 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.array.PrimitiveArrayComparator
-
- invertNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.BasicTypeComparator
-
- 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.
- invertNormalizedKey() - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueComparator
-
- invertNormalizedKey() - Method in class org.apache.flink.api.java.typeutils.runtime.GenericTypeComparator
-
- invertNormalizedKey() - Method in class org.apache.flink.api.java.typeutils.runtime.PojoComparator
-
- invertNormalizedKey() - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
-
- invertNormalizedKey() - Method in class org.apache.flink.api.java.typeutils.runtime.ValueComparator
-
- invertNormalizedKey() - Method in class org.apache.flink.api.java.typeutils.runtime.WritableComparator
-
- invertNormKey - Variable in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
-
- 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.
- ipAddressAndPortToUrlString(InetAddress, int) - Static method in class org.apache.flink.util.NetUtils
-
Encodes an IP address and port to be included in URL.
- ipAddressToUrlString(InetAddress) - Static method in class org.apache.flink.util.NetUtils
-
Encodes an IP address properly as a URL string.
- isAbsolute() - Method in class org.apache.flink.core.fs.Path
-
Checks if the directory of this path is absolute.
- isAutoTypeRegistrationDisabled() - Method in class org.apache.flink.api.common.ExecutionConfig
-
- 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
-
Checks if this type information represents a basic type.
- isBasicType() - Method in class org.apache.flink.api.java.typeutils.EitherTypeInfo
-
- isBasicType() - Method in class org.apache.flink.api.java.typeutils.EnumTypeInfo
-
- isBasicType() - Method in class org.apache.flink.api.java.typeutils.GenericTypeInfo
-
- isBasicType() - Method in class org.apache.flink.api.java.typeutils.MissingTypeInfo
-
- isBasicType() - Method in class org.apache.flink.api.java.typeutils.ObjectArrayTypeInfo
-
- isBasicType() - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo
-
- isBasicType() - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfoBase
-
- isBasicType() - Method in class org.apache.flink.api.java.typeutils.ValueTypeInfo
-
- isBasicType() - Method in class org.apache.flink.api.java.typeutils.WritableTypeInfo
-
- isBasicValueType() - Method in class org.apache.flink.api.java.typeutils.ValueTypeInfo
-
- isCaseClass() - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfoBase
-
- isClassType(Type) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
- 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
-
- isCombinableFirst() - Method in class org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase
-
- isCombinableSecond() - Method in class org.apache.flink.api.common.operators.base.CoGroupOperatorBase
-
- isCombinableSecond() - Method in class org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase
-
- 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.api.common.operators.Keys
-
- isEmpty() - Method in class org.apache.flink.types.ListValue
-
- isEmpty() - Method in class org.apache.flink.types.MapValue
-
- isExactMatch(FieldList) - Method in class org.apache.flink.api.common.operators.util.FieldList
-
- isExecutable - Variable in class org.apache.flink.api.common.cache.DistributedCache.DistributedCacheEntry
-
- isForceAvroEnabled() - Method in class org.apache.flink.api.common.ExecutionConfig
-
- isForceKryoEnabled() - Method in class org.apache.flink.api.common.ExecutionConfig
-
- 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 the memory segment was 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.TypeSerializer
-
Gets whether the type is an immutable type.
- isImmutableType() - Method in class org.apache.flink.api.java.typeutils.runtime.AvroSerializer
-
- isImmutableType() - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer
-
- isImmutableType() - Method in class org.apache.flink.api.java.typeutils.runtime.EitherSerializer
-
- isImmutableType() - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer
-
- isImmutableType() - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer
-
- isImmutableType() - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializerBase
-
- isImmutableType() - Method in class org.apache.flink.api.java.typeutils.runtime.ValueSerializer
-
- isImmutableType() - Method in class org.apache.flink.api.java.typeutils.runtime.WritableSerializer
-
- isInitialized() - Static method in class org.apache.flink.core.memory.MemorySegmentFactory
-
Checks whether this memory segment factory has been initialized (with a type to produce).
- 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
-
Checks whether this type can be used as a key.
- isKeyType() - Method in class org.apache.flink.api.common.typeutils.CompositeType
-
- isKeyType() - Method in class org.apache.flink.api.java.typeutils.EitherTypeInfo
-
- isKeyType() - Method in class org.apache.flink.api.java.typeutils.EnumTypeInfo
-
- isKeyType() - Method in class org.apache.flink.api.java.typeutils.GenericTypeInfo
-
- isKeyType() - Method in class org.apache.flink.api.java.typeutils.MissingTypeInfo
-
- isKeyType() - Method in class org.apache.flink.api.java.typeutils.ObjectArrayTypeInfo
-
- isKeyType() - Method in class org.apache.flink.api.java.typeutils.ValueTypeInfo
-
- isKeyType() - Method in class org.apache.flink.api.java.typeutils.WritableTypeInfo
-
- isLeft() - Method in class org.apache.flink.types.Either
-
- 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.array.PrimitiveArrayComparator
-
- 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.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.
- isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueComparator
-
- isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.java.typeutils.runtime.GenericTypeComparator
-
- isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoComparator
-
- isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
-
- isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.java.typeutils.runtime.ValueComparator
-
- isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.java.typeutils.runtime.WritableComparator
-
- isNull(int) - Method in class org.apache.flink.types.Record
-
- isObjectReuseEnabled() - Method in class org.apache.flink.api.common.ExecutionConfig
-
Returns whether object reuse has been enabled or disabled.
- isOffHeap() - Method in class org.apache.flink.core.memory.MemorySegment
-
Checks whether this memory segment is backed by off-heap memory.
- 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
-
- isPrintingStatusDuringExecution() - Method in class org.apache.flink.api.common.PlanExecutor
-
Gets whether the executor prints progress results to "standard out" (
System.out
).
- 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.
- isRight() - Method in class org.apache.flink.types.Either
-
- isRunning() - Method in class org.apache.flink.api.common.PlanExecutor
-
Checks if this executor is currently running.
- isSerializerInitialized() - Method in class org.apache.flink.api.common.state.StateDescriptor
-
Checks whether the serializer has been initialized.
- 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.
- isSortKey(int, TypeInformation<?>) - Static method in class org.apache.flink.api.common.operators.Keys.ExpressionKeys
-
- isSortKey(String, TypeInformation<?>) - Static method in class org.apache.flink.api.common.operators.Keys.ExpressionKeys
-
- isSortKeyType() - Method in class org.apache.flink.api.common.typeinfo.TypeInformation
-
Checks whether this type can be used as a key for sorting.
- isSortKeyType() - Method in class org.apache.flink.api.common.typeutils.CompositeType
-
- isSortKeyType() - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo
-
- isSysoutLoggingEnabled() - Method in class org.apache.flink.api.common.ExecutionConfig
-
Gets whether progress update messages should be printed to System.out
- 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
-
Checks if this type information represents a Tuple type.
- isTupleType() - Method in class org.apache.flink.api.java.typeutils.EitherTypeInfo
-
- isTupleType() - Method in class org.apache.flink.api.java.typeutils.EnumTypeInfo
-
- isTupleType() - Method in class org.apache.flink.api.java.typeutils.GenericTypeInfo
-
- isTupleType() - Method in class org.apache.flink.api.java.typeutils.MissingTypeInfo
-
- isTupleType() - Method in class org.apache.flink.api.java.typeutils.ObjectArrayTypeInfo
-
- isTupleType() - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo
-
- isTupleType() - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfoBase
-
- isTupleType() - Method in class org.apache.flink.api.java.typeutils.ValueTypeInfo
-
- isTupleType() - Method in class org.apache.flink.api.java.typeutils.WritableTypeInfo
-
- 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.base.CoGroupRawOperatorBase.SimpleListIterable
-
- 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
-
- 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.
- PARALLELISM_AUTO_MAX - Static variable in class org.apache.flink.api.common.ExecutionConfig
-
The constant to use for the parallelism, if the system should use the number
of currently available slots.
- parameters - Variable in class org.apache.flink.api.common.operators.Operator
-
- parse(String) - Static method in class org.apache.flink.api.java.typeutils.TypeInfoParser
-
Generates an instance of TypeInformation
by parsing a type
information string.
- 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, byte[], Boolean) - Method in class org.apache.flink.types.parser.BooleanParser
-
- parseField(byte[], int, int, byte[], BooleanValue) - Method in class org.apache.flink.types.parser.BooleanValueParser
-
- parseField(byte[], int, int, byte[], 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, byte[], ByteValue) - Method in class org.apache.flink.types.parser.ByteValueParser
-
- parseField(byte[], int, int, byte[], 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, byte[], DoubleValue) - Method in class org.apache.flink.types.parser.DoubleValueParser
-
- parseField(byte[], int, int, byte[], T) - Method in class org.apache.flink.types.parser.FieldParser
-
Parses the value of a field from the byte array.
- parseField(byte[], int, int, byte[], 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, byte[], FloatValue) - Method in class org.apache.flink.types.parser.FloatValueParser
-
- parseField(byte[], int, int, byte[], 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, byte[], IntValue) - Method in class org.apache.flink.types.parser.IntValueParser
-
- parseField(byte[], int, int, byte[], 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, byte[], LongValue) - Method in class org.apache.flink.types.parser.LongValueParser
-
- parseField(byte[], int, int, byte[], 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, byte[], ShortValue) - Method in class org.apache.flink.types.parser.ShortValueParser
-
- parseField(byte[], int, int, byte[], String) - Method in class org.apache.flink.types.parser.StringParser
-
- parseField(byte[], int, int, byte[], 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 represents Flink programs, in the form of dataflow plans.
- Plan(Collection<? extends GenericDataSinkBase<?>>, String) - Constructor for class org.apache.flink.api.common.Plan
-
Creates a new dataflow 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 executes a Flink program's dataflow plan.
- PlanExecutor() - Constructor for class org.apache.flink.api.common.PlanExecutor
-
- PojoComparator<T> - Class in org.apache.flink.api.java.typeutils.runtime
-
- PojoComparator(Field[], TypeComparator<?>[], TypeSerializer<T>, Class<T>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.PojoComparator
-
- PojoField - Class in org.apache.flink.api.java.typeutils
-
Represent a field definition for
PojoTypeInfo
type of objects.
- PojoField(Field, TypeInformation<?>) - Constructor for class org.apache.flink.api.java.typeutils.PojoField
-
- PojoSerializer<T> - Class in org.apache.flink.api.java.typeutils.runtime
-
- PojoSerializer(Class<T>, TypeSerializer<?>[], Field[], ExecutionConfig) - Constructor for class org.apache.flink.api.java.typeutils.runtime.PojoSerializer
-
- PojoTypeInfo<T> - Class in org.apache.flink.api.java.typeutils
-
TypeInformation for "Java Beans"-style types.
- PojoTypeInfo(Class<T>, List<PojoField>) - Constructor for class org.apache.flink.api.java.typeutils.PojoTypeInfo
-
- PojoTypeInfo.NamedFlatFieldDescriptor - Class in org.apache.flink.api.java.typeutils
-
- postVisit(T) - Method in interface org.apache.flink.util.Visitor
-
- preVisit(T) - Method in interface org.apache.flink.util.Visitor
-
- PrimitiveArrayComparator<T,C extends BasicTypeComparator> - Class in org.apache.flink.api.common.typeutils.base.array
-
- PrimitiveArrayComparator(boolean, C) - Constructor for class org.apache.flink.api.common.typeutils.base.array.PrimitiveArrayComparator
-
- PrimitiveArrayTypeInfo<T> - Class in org.apache.flink.api.common.typeinfo
-
- privateDuplicate(TupleComparatorBase<T>) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
-
- 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.HeapMemorySegment
-
- put(int, byte[]) - Method in class org.apache.flink.core.memory.HeapMemorySegment
-
- put(int, byte[], int, int) - Method in class org.apache.flink.core.memory.HeapMemorySegment
-
- put(DataInput, int, int) - Method in class org.apache.flink.core.memory.HeapMemorySegment
-
- put(int, ByteBuffer, int) - Method in class org.apache.flink.core.memory.HeapMemorySegment
-
- put(int, byte) - Method in class org.apache.flink.core.memory.HybridMemorySegment
-
- put(int, byte[]) - Method in class org.apache.flink.core.memory.HybridMemorySegment
-
- put(int, byte[], int, int) - Method in class org.apache.flink.core.memory.HybridMemorySegment
-
- put(DataInput, int, int) - Method in class org.apache.flink.core.memory.HybridMemorySegment
-
- put(int, ByteBuffer, int) - Method in class org.apache.flink.core.memory.HybridMemorySegment
-
- 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.HeapMemorySegment
-
- putBoolean(int, boolean) - Method in class org.apache.flink.core.memory.HybridMemorySegment
-
- 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 a char value to teh given position, in the system's native byte order.
- putCharBigEndian(int, char) - Method in class org.apache.flink.core.memory.MemorySegment
-
Writes the given character (16 bit, 2 bytes) to the given position in big-endian
byte order.
- putCharLittleEndian(int, char) - Method in class org.apache.flink.core.memory.MemorySegment
-
Writes the given character (16 bit, 2 bytes) to the given position in little-endian
byte order.
- 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(T, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.array.PrimitiveArrayComparator
-
- 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(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.
- putNormalizedKey(T, MemorySegment, int, int) - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueComparator
-
- putNormalizedKey(T, MemorySegment, int, int) - Method in class org.apache.flink.api.java.typeutils.runtime.GenericTypeComparator
-
- putNormalizedKey(T, MemorySegment, int, int) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoComparator
-
- putNormalizedKey(T, MemorySegment, int, int) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparator
-
- putNormalizedKey(T, MemorySegment, int, int) - Method in class org.apache.flink.api.java.typeutils.runtime.ValueComparator
-
- putNormalizedKey(T, MemorySegment, int, int) - Method in class org.apache.flink.api.java.typeutils.runtime.WritableComparator
-
- 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.
- putShortBigEndian(int, short) - Method in class org.apache.flink.core.memory.MemorySegment
-
Writes the given short integer value (16 bit, 2 bytes) to the given position in big-endian
byte order.
- putShortLittleEndian(int, short) - Method in class org.apache.flink.core.memory.MemorySegment
-
Writes the given short integer value (16 bit, 2 bytes) to the given position in little-endian
byte order.
- seek(long) - Method in class org.apache.flink.api.common.io.InputStreamFSInputWrapper
-
- 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
-
- SELECT_ALL_CHAR - Static variable in class org.apache.flink.api.common.operators.Keys.ExpressionKeys
-
- SELECT_ALL_CHAR_SCALA - Static variable in class org.apache.flink.api.common.operators.Keys.ExpressionKeys
-
- SelectorFunctionKeys(KeySelector<T, K>, TypeInformation<T>, TypeInformation<K>) - Constructor for class org.apache.flink.api.common.operators.Keys.SelectorFunctionKeys
-
- SemanticProperties - Interface in org.apache.flink.api.common.operators
-
Container for the semantic properties associated to an operator.
- SemanticProperties.EmptySemanticProperties - Class in org.apache.flink.api.common.operators
-
- SemanticProperties.InvalidSemanticAnnotationException - Exception in org.apache.flink.api.common.operators
-
- 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).
- SerializableSerializer(T) - Constructor for class org.apache.flink.api.common.ExecutionConfig.SerializableSerializer
-
- 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(T, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.TypeSerializer
-
Serializes the given record to the given target output view.
- serialize(T, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.AvroSerializer
-
- serialize(T, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer
-
- serialize(Either<L, R>, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.EitherSerializer
-
- serialize(T, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer
-
- serialize(T, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer
-
- serialize(Tuple0, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.Tuple0Serializer
-
- serialize(T, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializer
-
- serialize(T, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.ValueSerializer
-
- serialize(T, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.WritableSerializer
-
- 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
-
- SerializedListAccumulator<T> - Class in org.apache.flink.api.common.accumulators
-
This accumulator stores a collection of objects in serialized form, so that the stored objects
are not affected by modifications to the original objects.
- SerializedListAccumulator() - Constructor for class org.apache.flink.api.common.accumulators.SerializedListAccumulator
-
- 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
-
- SerializedValue<T> - Class in org.apache.flink.util
-
This class is used to transfer (via serialization) objects whose classes are not available
in the system class loader.
- SerializedValue(T) - Constructor for class org.apache.flink.util.SerializedValue
-
- serializeObject(Object) - Static method in class org.apache.flink.util.InstantiationUtil
-
- Serializers - Class in org.apache.flink.api.java.typeutils.runtime.kryo
-
Class containing utilities for the serializers of the Flink Runtime.
- Serializers() - Constructor for class org.apache.flink.api.java.typeutils.runtime.kryo.Serializers
-
- serializers - Variable in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
-
serializers to deserialize the first n fields for comparison
- Serializers.AvroSchemaSerializer - Class in org.apache.flink.api.java.typeutils.runtime.kryo
-
Slow serialization approach for Avro schemas.
- Serializers.SpecificInstanceCollectionSerializer<T extends Collection> - Class in org.apache.flink.api.java.typeutils.runtime.kryo
-
Special serializer for Java collections enforcing certain instance types.
- Serializers.SpecificInstanceCollectionSerializerForArrayList - Class in org.apache.flink.api.java.typeutils.runtime.kryo
-
- serializeToByteArray(TypeSerializer<T>, T) - Static method in class org.apache.flink.util.InstantiationUtil
-
- 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.
- setAutoWatermarkInterval(long) - Method in class org.apache.flink.api.common.ExecutionConfig
-
Sets the interval of the automatic watermark emission.
- 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.
- setCodeAnalysisMode(CodeAnalysisMode) - Method in class org.apache.flink.api.common.ExecutionConfig
-
- 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
-
- setCombinableFirst(boolean) - Method in class org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase
-
- setCombinableSecond(boolean) - Method in class org.apache.flink.api.common.operators.base.CoGroupOperatorBase
-
- setCombinableSecond(boolean) - Method in class org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase
-
- setCommentPrefix(byte[]) - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
-
- setCommentPrefix(char) - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
-
- setCommentPrefix(String) - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
-
- setCommentPrefix(String, String) - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
-
- setCommentPrefix(String, Charset) - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
-
- setCrossHint(CrossOperatorBase.CrossHint) - Method in class org.apache.flink.api.common.operators.base.CrossOperatorBase
-
- 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 parallelism for this plan.
- setDefaultScheme(Configuration) - Static method in class org.apache.flink.core.fs.FileSystem
-
Sets the default filesystem scheme based on the user-specified configuration parameter
fs.default-scheme
.
- 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
-
- 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.
- setExecutionConfig(ExecutionConfig) - Method in class org.apache.flink.api.common.Plan
-
Sets the runtime config object defining execution parameters.
- setExecutionMode(ExecutionMode) - Method in class org.apache.flink.api.common.ExecutionConfig
-
Sets the execution mode to execute the program.
- setExecutionRetryDelay(long) - Method in class org.apache.flink.api.common.ExecutionConfig
-
- setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple
-
Sets the field at the specified position.
- setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple0
-
- setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple1
-
- setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple10
-
- setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple11
-
- setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple12
-
- setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple13
-
- setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple14
-
- setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple15
-
- setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple16
-
- setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple17
-
- setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple18
-
- setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple19
-
- setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple2
-
- setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple20
-
- setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple21
-
- setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple22
-
- setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple23
-
- setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple24
-
- setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple25
-
- setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple3
-
- setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple4
-
- setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple5
-
- setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple6
-
- setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple7
-
- setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple8
-
- setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple9
-
- setField(int, Value) - Method in class org.apache.flink.types.Record
-
Sets the field at the given position to the given value.
- setFieldDelimiter(byte[]) - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
-
- setFieldDelimiter(char) - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
-
- setFieldDelimiter(String) - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
-
- setFields(T0) - Method in class org.apache.flink.api.java.tuple.Tuple1
-
Sets new values to all fields of the tuple.
- setFields(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9) - Method in class org.apache.flink.api.java.tuple.Tuple10
-
Sets new values to all fields of the tuple.
- setFields(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10) - Method in class org.apache.flink.api.java.tuple.Tuple11
-
Sets new values to all fields of the tuple.
- setFields(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11) - Method in class org.apache.flink.api.java.tuple.Tuple12
-
Sets new values to all fields of the tuple.
- setFields(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12) - Method in class org.apache.flink.api.java.tuple.Tuple13
-
Sets new values to all fields of the tuple.
- setFields(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13) - Method in class org.apache.flink.api.java.tuple.Tuple14
-
Sets new values to all fields of the tuple.
- setFields(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14) - Method in class org.apache.flink.api.java.tuple.Tuple15
-
Sets new values to all fields of the tuple.
- setFields(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15) - Method in class org.apache.flink.api.java.tuple.Tuple16
-
Sets new values to all fields of the tuple.
- setFields(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16) - Method in class org.apache.flink.api.java.tuple.Tuple17
-
Sets new values to all fields of the tuple.
- setFields(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17) - Method in class org.apache.flink.api.java.tuple.Tuple18
-
Sets new values to all fields of the tuple.
- setFields(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18) - Method in class org.apache.flink.api.java.tuple.Tuple19
-
Sets new values to all fields of the tuple.
- setFields(T0, T1) - Method in class org.apache.flink.api.java.tuple.Tuple2
-
Sets new values to all fields of the tuple.
- setFields(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19) - Method in class org.apache.flink.api.java.tuple.Tuple20
-
Sets new values to all fields of the tuple.
- setFields(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20) - Method in class org.apache.flink.api.java.tuple.Tuple21
-
Sets new values to all fields of the tuple.
- setFields(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, T21) - Method in class org.apache.flink.api.java.tuple.Tuple22
-
Sets new values to all fields of the tuple.
- setFields(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, T21, T22) - Method in class org.apache.flink.api.java.tuple.Tuple23
-
Sets new values to all fields of the tuple.
- setFields(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, T21, T22, T23) - Method in class org.apache.flink.api.java.tuple.Tuple24
-
Sets new values to all fields of the tuple.
- setFields(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, T21, T22, T23, T24) - Method in class org.apache.flink.api.java.tuple.Tuple25
-
Sets new values to all fields of the tuple.
- setFields(T0, T1, T2) - Method in class org.apache.flink.api.java.tuple.Tuple3
-
Sets new values to all fields of the tuple.
- setFields(T0, T1, T2, T3) - Method in class org.apache.flink.api.java.tuple.Tuple4
-
Sets new values to all fields of the tuple.
- setFields(T0, T1, T2, T3, T4) - Method in class org.apache.flink.api.java.tuple.Tuple5
-
Sets new values to all fields of the tuple.
- setFields(T0, T1, T2, T3, T4, T5) - Method in class org.apache.flink.api.java.tuple.Tuple6
-
Sets new values to all fields of the tuple.
- setFields(T0, T1, T2, T3, T4, T5, T6) - Method in class org.apache.flink.api.java.tuple.Tuple7
-
Sets new values to all fields of the tuple.
- setFields(T0, T1, T2, T3, T4, T5, T6, T7) - Method in class org.apache.flink.api.java.tuple.Tuple8
-
Sets new values to all fields of the tuple.
- setFields(T0, T1, T2, T3, T4, T5, T6, T7, T8) - Method in class org.apache.flink.api.java.tuple.Tuple9
-
Sets new values to all fields of the tuple.
- 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.
- setFunctionRuntimeContext(Function, RuntimeContext) - Static method in class org.apache.flink.api.common.functions.util.FunctionUtils
-
- setGlobalJobParameters(ExecutionConfig.GlobalJobParameters) - Method in class org.apache.flink.api.common.ExecutionConfig
-
Register a custom, serializable user configuration object.
- 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(int, Ordering) - Method in class org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase
-
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.GroupCombineOperatorBase
-
Sets the order of the elements within a reduce group.
- 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.
- setGroupOrderForInputOne(Ordering) - Method in class org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase
-
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.
- setGroupOrderForInputTwo(Ordering) - Method in class org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase
-
Sets the order of the elements within a group for the second input.
- setIn(DataInput) - Method in class org.apache.flink.api.java.typeutils.runtime.DataInputDecoder
-
- 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
-
- setInputType(TypeInformation<?>, ExecutionConfig) - Method in interface org.apache.flink.api.java.typeutils.InputTypeConfigurable
-
Method that is called on an
OutputFormat
when it is passed to
the DataSet's output method.
- setInteger(String, int) - Method in class org.apache.flink.configuration.Configuration
-
Adds the given key/value pair to the configuration object.
- setItemCount(long) - Method in class org.apache.flink.api.java.typeutils.runtime.DataOutputEncoder
-
- setJobId(JobID) - Method in class org.apache.flink.api.common.Plan
-
Sets the ID of the job that the dataflow plan belongs to.
- 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
-
- 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
-
- setOut(DataOutput) - Method in class org.apache.flink.api.java.typeutils.runtime.DataOutputEncoder
-
- setOuterJoinType(OuterJoinOperatorBase.OuterJoinType) - Method in class org.apache.flink.api.common.operators.base.OuterJoinOperatorBase
-
- 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
-
- setParallelism(int) - Method in class org.apache.flink.api.common.ExecutionConfig
-
Sets the parallelism for operations executed through this environment.
- setParallelism(int) - Method in class org.apache.flink.api.common.operators.Operator
-
Sets the parallelism for this contract instance.
- 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.
- setPrintStatusDuringExecution(boolean) - Method in class org.apache.flink.api.common.PlanExecutor
-
Sets whether the executor should print progress results to "standard out" (
System.out
).
- 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.array.PrimitiveArrayComparator
-
- 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(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.
- setReference(T) - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueComparator
-
- setReference(T) - Method in class org.apache.flink.api.java.typeutils.runtime.GenericTypeComparator
-
- setReference(T) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoComparator
-
- setReference(T) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparator
-
- setReference(T) - Method in class org.apache.flink.api.java.typeutils.runtime.ValueComparator
-
- setReference(T) - Method in class org.apache.flink.api.java.typeutils.runtime.WritableComparator
-
- setRestartStrategy(RestartStrategies.RestartStrategyConfiguration) - Method in class org.apache.flink.api.common.ExecutionConfig
-
Sets the restart strategy to be used for recovery.
- 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.
- setRuntimeContext(RuntimeContext) - Method in class org.apache.flink.api.common.io.ReplicatingInputFormat
-
- setRuntimeContext(RuntimeContext) - Method in class org.apache.flink.api.common.io.RichInputFormat
-
- setRuntimeContext(RuntimeContext) - Method in class org.apache.flink.api.common.io.RichOutputFormat
-
- 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
-
- setSessionTimeout(long) - Method in class org.apache.flink.api.common.Plan
-
- 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).
- setSplitDataProperties(GenericDataSourceBase.SplitDataProperties<OUT>) - Method in class org.apache.flink.api.common.operators.GenericDataSourceBase
-
Sets properties of input splits for this data source.
- 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.
- 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
-
- SHORT_VALUE_TYPE_INFO - Static variable in class org.apache.flink.api.java.typeutils.ValueTypeInfo
-
- 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
-
- ShortPrimitiveArrayComparator - Class in org.apache.flink.api.common.typeutils.base.array
-
- ShortPrimitiveArrayComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.array.ShortPrimitiveArrayComparator
-
- 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
-
- shouldAutocastTo(BasicTypeInfo<?>) - Method in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
-
Returns whether this type should be automatically casted to
the target type in an arithmetic operation.
- showControlCharacters(String) - Static method in class org.apache.flink.util.StringUtils
-
Replaces control characters by their escape-coded version.
- SimpleAccumulator<T extends Serializable> - 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
-
- SimpleListIterable(List<IN>, TypeComparator<IN>, TypeSerializer<IN>) - Constructor for class org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase.SimpleListIterable
-
- SimpleListIterator(List<IN>, TypeSerializer<IN>) - Constructor for class org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase.SimpleListIterable.SimpleListIterator
-
- 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.AllFieldsForwardedProperties - 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 - Variable in class org.apache.flink.core.memory.MemorySegment
-
The size in bytes of the memory segment
- 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 - Static variable in class org.apache.flink.util.AbstractID
-
The size of the ID in byte
- SIZE_MISMATCH_MESSAGE - Static variable in exception org.apache.flink.api.common.operators.Keys.IncompatibleKeysException
-
- 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.api.java.typeutils.runtime.DataInputViewStream
-
- skip(int) - Method in class org.apache.flink.api.java.typeutils.runtime.NoFetchingInput
-
- skip(long) - Method in class org.apache.flink.core.fs.local.LocalDataInputStream
-
- skipArray() - Method in class org.apache.flink.api.java.typeutils.runtime.DataInputDecoder
-
- skipBytes() - Method in class org.apache.flink.api.java.typeutils.runtime.DataInputDecoder
-
- 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.DataInputViewStreamWrapper
-
- 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.DataOutputViewStreamWrapper
-
- skipFields(byte[], int, int, byte[]) - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
-
- skipFixed(int) - Method in class org.apache.flink.api.java.typeutils.runtime.DataInputDecoder
-
- skipMap() - Method in class org.apache.flink.api.java.typeutils.runtime.DataInputDecoder
-
- skipString() - Method in class org.apache.flink.api.java.typeutils.runtime.DataInputDecoder
-
- socketAddressToUrlString(InetSocketAddress) - Static method in class org.apache.flink.util.NetUtils
-
Encodes an IP address and port to be included in URL.
- SolutionSetPlaceHolder(DeltaIterationBase<ST, ?>, OperatorInformation<ST>) - Constructor for class org.apache.flink.api.common.operators.base.DeltaIterationBase.SolutionSetPlaceHolder
-
- SortPartitionOperatorBase<IN> - Class in org.apache.flink.api.common.operators.base
-
- SortPartitionOperatorBase(UnaryOperatorInformation<IN, IN>, Ordering, String) - Constructor for class org.apache.flink.api.common.operators.base.SortPartitionOperatorBase
-
- SpecificInstanceCollectionSerializer(Class<T>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.kryo.Serializers.SpecificInstanceCollectionSerializer
-
- SpecificInstanceCollectionSerializerForArrayList() - Constructor for class org.apache.flink.api.java.typeutils.runtime.kryo.Serializers.SpecificInstanceCollectionSerializerForArrayList
-
- split(int) - Method in class org.apache.flink.util.NumberSequenceIterator
-
- split(int) - Method in class org.apache.flink.util.SplittableIterator
-
Splits this iterator into a number disjoint iterators.
- 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> - Class in org.apache.flink.util
-
Abstract base class for iterators that can split themselves into multiple disjoint
iterators.
- SplittableIterator() - Constructor for class org.apache.flink.util.SplittableIterator
-
- start() - Method in class org.apache.flink.api.common.PlanExecutor
-
Starts the program executor.
- startItem() - Method in class org.apache.flink.api.java.typeutils.runtime.DataOutputEncoder
-
- 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.
- State - Interface in org.apache.flink.api.common.state
-
Interface that different types of partitioned state must implement.
- STATE_BACKEND - Static variable in class org.apache.flink.configuration.ConfigConstants
-
State backend for checkpoints;
- StateBackend - Interface in org.apache.flink.api.common.state
-
The
StateBackend
is used by
StateDescriptor
instances to create actual state
representations.
- StateDescriptor<S extends State,T> - Class in org.apache.flink.api.common.state
-
Base class for state descriptors.
- StateDescriptor(String, TypeSerializer<T>, T) - Constructor for class org.apache.flink.api.common.state.StateDescriptor
-
Create a new StateDescriptor
with the given name and the given type serializer.
- StateDescriptor(String, TypeInformation<T>, T) - Constructor for class org.apache.flink.api.common.state.StateDescriptor
-
Create a new StateDescriptor
with the given name and the given type information.
- StateDescriptor(String, Class<T>, T) - Constructor for class org.apache.flink.api.common.state.StateDescriptor
-
Create a new StateDescriptor
with the given name and the given type information.
- statisticsKey - Variable in class org.apache.flink.api.common.operators.GenericDataSourceBase
-
- stop() - Method in interface org.apache.flink.api.common.functions.StoppableFunction
-
Stops the source.
- stop() - Method in class org.apache.flink.api.common.PlanExecutor
-
Shuts down the plan executor and releases all local resources.
- StoppableFunction - Interface in org.apache.flink.api.common.functions
-
Must be implemented by stoppable functions, eg, source functions of streaming jobs.
- 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;
- StrictlyLocalAssignment - Interface in org.apache.flink.api.common.io
-
- 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
-
- STRING_VALUE_TYPE_INFO - Static variable in class org.apache.flink.api.java.typeutils.ValueTypeInfo
-
- 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
-
- 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.TypeComparator
-
- supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.array.PrimitiveArrayComparator
-
- 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.TypeComparator
-
Checks whether the data type supports the creation of a normalized key for comparison.
- supportsNormalizedKey() - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueComparator
-
- supportsNormalizedKey() - Method in class org.apache.flink.api.java.typeutils.runtime.GenericTypeComparator
-
- supportsNormalizedKey() - Method in class org.apache.flink.api.java.typeutils.runtime.PojoComparator
-
- supportsNormalizedKey() - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
-
- supportsNormalizedKey() - Method in class org.apache.flink.api.java.typeutils.runtime.ValueComparator
-
- supportsNormalizedKey() - Method in class org.apache.flink.api.java.typeutils.runtime.WritableComparator
-
- supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.common.typeutils.base.array.PrimitiveArrayComparator
-
- 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.TypeComparator
-
Check whether this comparator supports to serialize the record in a format that replaces its keys by a normalized
key.
- supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueComparator
-
- supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.java.typeutils.runtime.GenericTypeComparator
-
- supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.java.typeutils.runtime.PojoComparator
-
- supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
-
- supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.java.typeutils.runtime.ValueComparator
-
- supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.java.typeutils.runtime.WritableComparator
-
- swap() - Method in class org.apache.flink.api.java.tuple.Tuple2
-
Returns a shallow copy of the tuple with swapped values.
- swapBytes(byte[], MemorySegment, int, int, int) - Method in class org.apache.flink.core.memory.MemorySegment
-
Swaps bytes between two memory segments, using the given auxiliary buffer.
- sync() - Method in class org.apache.flink.core.fs.FSDataOutputStream
-
- sync() - Method in class org.apache.flink.core.fs.local.LocalDataOutputStream
-
- TASK_MANAGER_DATA_PORT_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
-
The config parameter defining the task manager's data port from the configuration.
- 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.
- 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.
- TASK_MANAGER_HOSTNAME_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
-
The config parameter defining the task manager's hostname.
- TASK_MANAGER_IPC_PORT_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
-
The config parameter defining the task manager's IPC port from the configuration.
- TASK_MANAGER_MAX_REGISTRATION_DURATION - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- TASK_MANAGER_MEMORY_FRACTION_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
-
The config parameter defining the fraction of free memory allocated by the memory manager.
- TASK_MANAGER_MEMORY_OFF_HEAP_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
-
The config parameter defining the memory allocation method (JVM heap or off-heap).
- TASK_MANAGER_MEMORY_PRE_ALLOCATE_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
-
The config parameter for specifying whether TaskManager managed memory should be preallocated
when the TaskManager is starting.
- TASK_MANAGER_MEMORY_SEGMENT_SIZE_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
-
Config parameter defining the size of memory buffers used by the network stack and the memory manager.
- TASK_MANAGER_MEMORY_SIZE_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
-
The config parameter defining the amount of memory to be allocated by the task manager's
memory manager (in megabytes).
- TASK_MANAGER_NETWORK_DEFAULT_IO_MODE - Static variable in class org.apache.flink.configuration.ConfigConstants
-
The implementation to use for spillable/spilled intermediate results, which have both
synchronous and asynchronous implementations: "sync" or "async".
- TASK_MANAGER_NETWORK_NUM_BUFFERS_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
-
The config parameter defining the number of buffers used in the network stack.
- TASK_MANAGER_NUM_TASK_SLOTS - Static variable in class org.apache.flink.configuration.ConfigConstants
-
The config parameter defining the number of task slots of a task manager.
- TASK_MANAGER_TMP_DIR_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
-
The config parameter defining the directories for temporary files.
- TaskInfo - Class in org.apache.flink.api.common
-
Encapsulates task-specific information: name, index of subtask, parallelism and attempt number.
- TaskInfo(String, int, int, int) - Constructor for class org.apache.flink.api.common.TaskInfo
-
- TERMINATION_CRITERION_AGGREGATOR_NAME - Static variable in class org.apache.flink.api.common.operators.base.BulkIterationBase
-
- terminationCriterion - Variable in class org.apache.flink.api.common.operators.base.BulkIterationBase
-
- TerminationCriterionAggregationConvergence() - Constructor for class org.apache.flink.api.common.operators.base.BulkIterationBase.TerminationCriterionAggregationConvergence
-
- TerminationCriterionAggregator() - Constructor for class org.apache.flink.api.common.operators.base.BulkIterationBase.TerminationCriterionAggregator
-
- TerminationCriterionMapper() - Constructor for class org.apache.flink.api.common.operators.base.BulkIterationBase.TerminationCriterionMapper
-
- testForUnsplittable(FileStatus) - Method in class org.apache.flink.api.common.io.FileInputFormat
-
- toArray() - Method in class org.apache.flink.api.common.operators.util.FieldSet
-
Transforms the field set into an array of field IDs.
- toArray() - Method in class org.apache.flink.types.ListValue
-
- toArray(T[]) - Method in class org.apache.flink.types.ListValue
-
- toFieldList() - Method in class org.apache.flink.api.common.operators.util.FieldList
-
- toFieldList() - Method in class org.apache.flink.api.common.operators.util.FieldSet
-
Turns the FieldSet into an ordered FieldList.
- toLowerCase(StringValue) - Static method in class org.apache.flink.util.SimpleStringUtils
-
Converts the given StringValue
into a lower case variant.
- toMap() - Method in class org.apache.flink.api.common.ExecutionConfig.GlobalJobParameters
-
Convert UserConfig into a Map<String, String>
representation.
- toMap() - Method in class org.apache.flink.configuration.Configuration
-
- toResultMap(Map<String, Accumulator<?, ?>>) - Static method in class org.apache.flink.api.common.accumulators.AccumulatorHelper
-
Transform the Map with accumulators into a Map containing only the
results
- toString() - Method in class org.apache.flink.api.common.accumulators.AverageAccumulator
-
- toString() - Method in class org.apache.flink.api.common.accumulators.DoubleCounter
-
- toString() - Method in class org.apache.flink.api.common.accumulators.Histogram
-
- toString() - Method in class org.apache.flink.api.common.accumulators.IntCounter
-
- toString() - Method in class org.apache.flink.api.common.accumulators.ListAccumulator
-
- toString() - Method in class org.apache.flink.api.common.accumulators.LongCounter
-
- toString() - Method in class org.apache.flink.api.common.accumulators.SerializedListAccumulator
-
- toString() - Method in class org.apache.flink.api.common.io.FileInputFormat.FileBaseStatistics
-
- toString() - Method in class org.apache.flink.api.common.io.FileInputFormat
-
- toString() - Method in class org.apache.flink.api.common.operators.DualInputSemanticProperties
-
- toString() - Method in class org.apache.flink.api.common.operators.GenericDataSinkBase
-
- toString() - Method in class org.apache.flink.api.common.operators.GenericDataSourceBase
-
- toString() - Method in class org.apache.flink.api.common.operators.Keys.ExpressionKeys
-
- toString() - Method in class org.apache.flink.api.common.operators.Keys.SelectorFunctionKeys
-
- toString() - Method in class org.apache.flink.api.common.operators.Operator
-
- toString() - Method in class org.apache.flink.api.common.operators.OperatorInformation
-
- toString() - Method in class org.apache.flink.api.common.operators.Ordering
-
- toString() - Method in class org.apache.flink.api.common.operators.SingleInputSemanticProperties
-
- toString() - Method in class org.apache.flink.api.common.operators.util.FieldSet
-
- toString() - Method in class org.apache.flink.api.common.state.StateDescriptor
-
- toString() - Method in class org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
-
- toString() - Method in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
-
- toString() - Method in class org.apache.flink.api.common.typeinfo.NothingTypeInfo
-
- toString() - Method in class org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
-
- toString() - Method in class org.apache.flink.api.common.typeinfo.TypeHint
-
- toString() - Method in class org.apache.flink.api.common.typeinfo.TypeInformation
-
- toString() - Method in class org.apache.flink.api.common.typeutils.base.GenericArraySerializer
-
- toString() - Method in class org.apache.flink.api.common.typeutils.CompositeType.FlatFieldDescriptor
-
- toString() - Method in class org.apache.flink.api.common.typeutils.CompositeType
-
- toString() - Method in class org.apache.flink.api.java.tuple.Tuple0
-
Creates a string representation of the tuple in the form "()"
- toString() - Method in class org.apache.flink.api.java.tuple.Tuple1
-
Creates a string representation of the tuple in the form
(f0),
where the individual fields are the value returned by calling
Object.toString()
on that field.
- toString() - Method in class org.apache.flink.api.java.tuple.Tuple10
-
Creates a string representation of the tuple in the form
(f0, f1, f2, f3, f4, f5, f6, f7, f8, f9),
where the individual fields are the value returned by calling
Object.toString()
on that field.
- toString() - Method in class org.apache.flink.api.java.tuple.Tuple11
-
Creates a string representation of the tuple in the form
(f0, f1, f2, f3, f4, f5, f6, f7, f8, f9, f10),
where the individual fields are the value returned by calling
Object.toString()
on that field.
- toString() - Method in class org.apache.flink.api.java.tuple.Tuple12
-
Creates a string representation of the tuple in the form
(f0, f1, f2, f3, f4, f5, f6, f7, f8, f9, f10, f11),
where the individual fields are the value returned by calling
Object.toString()
on that field.
- toString() - Method in class org.apache.flink.api.java.tuple.Tuple13
-
Creates a string representation of the tuple in the form
(f0, f1, f2, f3, f4, f5, f6, f7, f8, f9, f10, f11, f12),
where the individual fields are the value returned by calling
Object.toString()
on that field.
- toString() - Method in class org.apache.flink.api.java.tuple.Tuple14
-
Creates a string representation of the tuple in the form
(f0, f1, f2, f3, f4, f5, f6, f7, f8, f9, f10, f11, f12, f13),
where the individual fields are the value returned by calling
Object.toString()
on that field.
- toString() - Method in class org.apache.flink.api.java.tuple.Tuple15
-
Creates a string representation of the tuple in the form
(f0, f1, f2, f3, f4, f5, f6, f7, f8, f9, f10, f11, f12, f13, f14),
where the individual fields are the value returned by calling
Object.toString()
on that field.
- toString() - Method in class org.apache.flink.api.java.tuple.Tuple16
-
Creates a string representation of the tuple in the form
(f0, f1, f2, f3, f4, f5, f6, f7, f8, f9, f10, f11, f12, f13, f14, f15),
where the individual fields are the value returned by calling
Object.toString()
on that field.
- toString() - Method in class org.apache.flink.api.java.tuple.Tuple17
-
Creates a string representation of the tuple in the form
(f0, f1, f2, f3, f4, f5, f6, f7, f8, f9, f10, f11, f12, f13, f14, f15, f16),
where the individual fields are the value returned by calling
Object.toString()
on that field.
- toString() - Method in class org.apache.flink.api.java.tuple.Tuple18
-
Creates a string representation of the tuple in the form
(f0, f1, f2, f3, f4, f5, f6, f7, f8, f9, f10, f11, f12, f13, f14, f15, f16, f17),
where the individual fields are the value returned by calling
Object.toString()
on that field.
- toString() - Method in class org.apache.flink.api.java.tuple.Tuple19
-
Creates a string representation of the tuple in the form
(f0, f1, f2, f3, f4, f5, f6, f7, f8, f9, f10, f11, f12, f13, f14, f15, f16, f17, f18),
where the individual fields are the value returned by calling
Object.toString()
on that field.
- toString() - Method in class org.apache.flink.api.java.tuple.Tuple2
-
Creates a string representation of the tuple in the form
(f0, f1),
where the individual fields are the value returned by calling
Object.toString()
on that field.
- toString() - Method in class org.apache.flink.api.java.tuple.Tuple20
-
Creates a string representation of the tuple in the form
(f0, f1, f2, f3, f4, f5, f6, f7, f8, f9, f10, f11, f12, f13, f14, f15, f16, f17, f18, f19),
where the individual fields are the value returned by calling
Object.toString()
on that field.
- toString() - Method in class org.apache.flink.api.java.tuple.Tuple21
-
Creates a string representation of the tuple in the form
(f0, f1, f2, f3, f4, f5, f6, f7, f8, f9, f10, f11, f12, f13, f14, f15, f16, f17, f18, f19, f20),
where the individual fields are the value returned by calling
Object.toString()
on that field.
- toString() - Method in class org.apache.flink.api.java.tuple.Tuple22
-
Creates a string representation of the tuple in the form
(f0, f1, f2, f3, f4, f5, f6, f7, f8, f9, f10, f11, f12, f13, f14, f15, f16, f17, f18, f19, f20, f21),
where the individual fields are the value returned by calling
Object.toString()
on that field.
- toString() - Method in class org.apache.flink.api.java.tuple.Tuple23
-
Creates a string representation of the tuple in the form
(f0, f1, f2, f3, f4, f5, f6, f7, f8, f9, f10, f11, f12, f13, f14, f15, f16, f17, f18, f19, f20, f21, f22),
where the individual fields are the value returned by calling
Object.toString()
on that field.
- toString() - Method in class org.apache.flink.api.java.tuple.Tuple24
-
Creates a string representation of the tuple in the form
(f0, f1, f2, f3, f4, f5, f6, f7, f8, f9, f10, f11, f12, f13, f14, f15, f16, f17, f18, f19, f20, f21, f22, f23),
where the individual fields are the value returned by calling
Object.toString()
on that field.
- toString() - Method in class org.apache.flink.api.java.tuple.Tuple25
-
Creates a string representation of the tuple in the form
(f0, f1, f2, f3, f4, f5, f6, f7, f8, f9, f10, f11, f12, f13, f14, f15, f16, f17, f18, f19, f20, f21, f22, f23, f24),
where the individual fields are the value returned by calling
Object.toString()
on that field.
- toString() - Method in class org.apache.flink.api.java.tuple.Tuple3
-
Creates a string representation of the tuple in the form
(f0, f1, f2),
where the individual fields are the value returned by calling
Object.toString()
on that field.
- toString() - Method in class org.apache.flink.api.java.tuple.Tuple4
-
Creates a string representation of the tuple in the form
(f0, f1, f2, f3),
where the individual fields are the value returned by calling
Object.toString()
on that field.
- toString() - Method in class org.apache.flink.api.java.tuple.Tuple5
-
Creates a string representation of the tuple in the form
(f0, f1, f2, f3, f4),
where the individual fields are the value returned by calling
Object.toString()
on that field.
- toString() - Method in class org.apache.flink.api.java.tuple.Tuple6
-
Creates a string representation of the tuple in the form
(f0, f1, f2, f3, f4, f5),
where the individual fields are the value returned by calling
Object.toString()
on that field.
- toString() - Method in class org.apache.flink.api.java.tuple.Tuple7
-
Creates a string representation of the tuple in the form
(f0, f1, f2, f3, f4, f5, f6),
where the individual fields are the value returned by calling
Object.toString()
on that field.
- toString() - Method in class org.apache.flink.api.java.tuple.Tuple8
-
Creates a string representation of the tuple in the form
(f0, f1, f2, f3, f4, f5, f6, f7),
where the individual fields are the value returned by calling
Object.toString()
on that field.
- toString() - Method in class org.apache.flink.api.java.tuple.Tuple9
-
Creates a string representation of the tuple in the form
(f0, f1, f2, f3, f4, f5, f6, f7, f8),
where the individual fields are the value returned by calling
Object.toString()
on that field.
- toString() - Method in class org.apache.flink.api.java.typeutils.EitherTypeInfo
-
- toString() - Method in class org.apache.flink.api.java.typeutils.EnumTypeInfo
-
- toString() - Method in class org.apache.flink.api.java.typeutils.GenericTypeInfo
-
- toString() - Method in class org.apache.flink.api.java.typeutils.MissingTypeInfo
-
- toString() - Method in class org.apache.flink.api.java.typeutils.ObjectArrayTypeInfo
-
- toString() - Method in class org.apache.flink.api.java.typeutils.PojoField
-
- toString() - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo.NamedFlatFieldDescriptor
-
- toString() - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo
-
- toString() - Method in class org.apache.flink.api.java.typeutils.runtime.Tuple0Serializer
-
- toString() - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfo
-
- toString() - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfoBase
-
- toString() - Method in class org.apache.flink.api.java.typeutils.ValueTypeInfo
-
- toString() - Method in class org.apache.flink.api.java.typeutils.WritableTypeInfo
-
- toString() - Method in class org.apache.flink.configuration.Configuration
-
- toString() - Method in class org.apache.flink.core.fs.FileInputSplit
-
- toString() - Method in class org.apache.flink.core.fs.Path
-
- toString() - Method in class org.apache.flink.core.io.GenericInputSplit
-
- toString() - Method in class org.apache.flink.core.io.LocatableInputSplit
-
- toString() - Method in class org.apache.flink.types.BooleanValue
-
- toString() - Method in class org.apache.flink.types.ByteValue
-
- toString() - Method in class org.apache.flink.types.CharValue
-
- toString() - Method in class org.apache.flink.types.DoubleValue
-
- toString() - Method in class org.apache.flink.types.Either.Left
-
- toString() - Method in class org.apache.flink.types.Either.Right
-
- toString() - Method in class org.apache.flink.types.FloatValue
-
- toString() - Method in class org.apache.flink.types.IntValue
-
- toString() - Method in class org.apache.flink.types.ListValue
-
- toString() - Method in class org.apache.flink.types.LongValue
-
- toString() - Method in class org.apache.flink.types.MapValue
-
- toString() - Method in class org.apache.flink.types.NullValue
-
- toString() - Method in class org.apache.flink.types.Pair
-
- toString() - Method in class org.apache.flink.types.ShortValue
-
- toString() - Method in class org.apache.flink.types.StringValue
-
- toString() - Method in class org.apache.flink.util.AbstractID
-
- toString() - Method in class org.apache.flink.util.SerializedValue
-
- toUri() - Method in class org.apache.flink.core.fs.Path
-
Converts the path object to a
URI
.
- TraversableOnceException - Exception in org.apache.flink.util
-
An exception, indicating that an
Iterable
can only be traversed once, but has been attempted
to traverse an additional time.
- TraversableOnceException() - Constructor for exception org.apache.flink.util.TraversableOnceException
-
Creates a new exception with a default message.
- TRUE - Static variable in class org.apache.flink.types.BooleanValue
-
- tryCleanupOnError() - Method in interface org.apache.flink.api.common.io.CleanupWhenUnsuccessful
-
Hook that is called upon an unsuccessful execution.
- tryCleanupOnError() - Method in class org.apache.flink.api.common.io.FileOutputFormat
-
- tryRethrowIOException(Throwable) - Static method in class org.apache.flink.util.ExceptionUtils
-
Tries to throw the given Throwable
in scenarios where the signatures allows only IOExceptions
(and RuntimeException and Error).
- Tuple - Class in org.apache.flink.api.java.tuple
-
The base class of all tuples.
- Tuple() - Constructor for class org.apache.flink.api.java.tuple.Tuple
-
- Tuple0 - Class in org.apache.flink.api.java.tuple
-
A tuple with 0 fields.
- Tuple0() - Constructor for class org.apache.flink.api.java.tuple.Tuple0
-
- Tuple0Builder - Class in org.apache.flink.api.java.tuple.builder
-
- Tuple0Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple0Builder
-
- Tuple0Serializer - Class in org.apache.flink.api.java.typeutils.runtime
-
- Tuple1<T0> - Class in org.apache.flink.api.java.tuple
-
A tuple with 1 fields.
- Tuple1() - Constructor for class org.apache.flink.api.java.tuple.Tuple1
-
Creates a new tuple where all fields are null.
- Tuple1(T0) - Constructor for class org.apache.flink.api.java.tuple.Tuple1
-
Creates a new tuple and assigns the given values to the tuple's fields.
- Tuple10<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9> - Class in org.apache.flink.api.java.tuple
-
A tuple with 10 fields.
- Tuple10() - Constructor for class org.apache.flink.api.java.tuple.Tuple10
-
Creates a new tuple where all fields are null.
- Tuple10(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9) - Constructor for class org.apache.flink.api.java.tuple.Tuple10
-
Creates a new tuple and assigns the given values to the tuple's fields.
- Tuple10Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9> - Class in org.apache.flink.api.java.tuple.builder
-
- Tuple10Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple10Builder
-
- Tuple11<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10> - Class in org.apache.flink.api.java.tuple
-
A tuple with 11 fields.
- Tuple11() - Constructor for class org.apache.flink.api.java.tuple.Tuple11
-
Creates a new tuple where all fields are null.
- Tuple11(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10) - Constructor for class org.apache.flink.api.java.tuple.Tuple11
-
Creates a new tuple and assigns the given values to the tuple's fields.
- Tuple11Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10> - Class in org.apache.flink.api.java.tuple.builder
-
- Tuple11Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple11Builder
-
- Tuple12<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11> - Class in org.apache.flink.api.java.tuple
-
A tuple with 12 fields.
- Tuple12() - Constructor for class org.apache.flink.api.java.tuple.Tuple12
-
Creates a new tuple where all fields are null.
- Tuple12(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11) - Constructor for class org.apache.flink.api.java.tuple.Tuple12
-
Creates a new tuple and assigns the given values to the tuple's fields.
- Tuple12Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11> - Class in org.apache.flink.api.java.tuple.builder
-
- Tuple12Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple12Builder
-
- Tuple13<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12> - Class in org.apache.flink.api.java.tuple
-
A tuple with 13 fields.
- Tuple13() - Constructor for class org.apache.flink.api.java.tuple.Tuple13
-
Creates a new tuple where all fields are null.
- Tuple13(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12) - Constructor for class org.apache.flink.api.java.tuple.Tuple13
-
Creates a new tuple and assigns the given values to the tuple's fields.
- Tuple13Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12> - Class in org.apache.flink.api.java.tuple.builder
-
- Tuple13Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple13Builder
-
- Tuple14<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13> - Class in org.apache.flink.api.java.tuple
-
A tuple with 14 fields.
- Tuple14() - Constructor for class org.apache.flink.api.java.tuple.Tuple14
-
Creates a new tuple where all fields are null.
- Tuple14(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13) - Constructor for class org.apache.flink.api.java.tuple.Tuple14
-
Creates a new tuple and assigns the given values to the tuple's fields.
- Tuple14Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13> - Class in org.apache.flink.api.java.tuple.builder
-
- Tuple14Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple14Builder
-
- Tuple15<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14> - Class in org.apache.flink.api.java.tuple
-
A tuple with 15 fields.
- Tuple15() - Constructor for class org.apache.flink.api.java.tuple.Tuple15
-
Creates a new tuple where all fields are null.
- Tuple15(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14) - Constructor for class org.apache.flink.api.java.tuple.Tuple15
-
Creates a new tuple and assigns the given values to the tuple's fields.
- Tuple15Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14> - Class in org.apache.flink.api.java.tuple.builder
-
- Tuple15Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple15Builder
-
- Tuple16<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15> - Class in org.apache.flink.api.java.tuple
-
A tuple with 16 fields.
- Tuple16() - Constructor for class org.apache.flink.api.java.tuple.Tuple16
-
Creates a new tuple where all fields are null.
- Tuple16(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15) - Constructor for class org.apache.flink.api.java.tuple.Tuple16
-
Creates a new tuple and assigns the given values to the tuple's fields.
- Tuple16Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15> - Class in org.apache.flink.api.java.tuple.builder
-
- Tuple16Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple16Builder
-
- Tuple17<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16> - Class in org.apache.flink.api.java.tuple
-
A tuple with 17 fields.
- Tuple17() - Constructor for class org.apache.flink.api.java.tuple.Tuple17
-
Creates a new tuple where all fields are null.
- Tuple17(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16) - Constructor for class org.apache.flink.api.java.tuple.Tuple17
-
Creates a new tuple and assigns the given values to the tuple's fields.
- Tuple17Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16> - Class in org.apache.flink.api.java.tuple.builder
-
- Tuple17Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple17Builder
-
- Tuple18<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17> - Class in org.apache.flink.api.java.tuple
-
A tuple with 18 fields.
- Tuple18() - Constructor for class org.apache.flink.api.java.tuple.Tuple18
-
Creates a new tuple where all fields are null.
- Tuple18(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17) - Constructor for class org.apache.flink.api.java.tuple.Tuple18
-
Creates a new tuple and assigns the given values to the tuple's fields.
- Tuple18Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17> - Class in org.apache.flink.api.java.tuple.builder
-
- Tuple18Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple18Builder
-
- Tuple19<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18> - Class in org.apache.flink.api.java.tuple
-
A tuple with 19 fields.
- Tuple19() - Constructor for class org.apache.flink.api.java.tuple.Tuple19
-
Creates a new tuple where all fields are null.
- Tuple19(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18) - Constructor for class org.apache.flink.api.java.tuple.Tuple19
-
Creates a new tuple and assigns the given values to the tuple's fields.
- Tuple19Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18> - Class in org.apache.flink.api.java.tuple.builder
-
- Tuple19Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple19Builder
-
- Tuple1Builder<T0> - Class in org.apache.flink.api.java.tuple.builder
-
- Tuple1Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple1Builder
-
- Tuple2<T0,T1> - Class in org.apache.flink.api.java.tuple
-
A tuple with 2 fields.
- Tuple2() - Constructor for class org.apache.flink.api.java.tuple.Tuple2
-
Creates a new tuple where all fields are null.
- Tuple2(T0, T1) - Constructor for class org.apache.flink.api.java.tuple.Tuple2
-
Creates a new tuple and assigns the given values to the tuple's fields.
- Tuple20<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19> - Class in org.apache.flink.api.java.tuple
-
A tuple with 20 fields.
- Tuple20() - Constructor for class org.apache.flink.api.java.tuple.Tuple20
-
Creates a new tuple where all fields are null.
- Tuple20(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19) - Constructor for class org.apache.flink.api.java.tuple.Tuple20
-
Creates a new tuple and assigns the given values to the tuple's fields.
- Tuple20Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19> - Class in org.apache.flink.api.java.tuple.builder
-
- Tuple20Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple20Builder
-
- Tuple21<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20> - Class in org.apache.flink.api.java.tuple
-
A tuple with 21 fields.
- Tuple21() - Constructor for class org.apache.flink.api.java.tuple.Tuple21
-
Creates a new tuple where all fields are null.
- Tuple21(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20) - Constructor for class org.apache.flink.api.java.tuple.Tuple21
-
Creates a new tuple and assigns the given values to the tuple's fields.
- Tuple21Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20> - Class in org.apache.flink.api.java.tuple.builder
-
- Tuple21Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple21Builder
-
- Tuple22<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20,T21> - Class in org.apache.flink.api.java.tuple
-
A tuple with 22 fields.
- Tuple22() - Constructor for class org.apache.flink.api.java.tuple.Tuple22
-
Creates a new tuple where all fields are null.
- Tuple22(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, T21) - Constructor for class org.apache.flink.api.java.tuple.Tuple22
-
Creates a new tuple and assigns the given values to the tuple's fields.
- Tuple22Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20,T21> - Class in org.apache.flink.api.java.tuple.builder
-
- Tuple22Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple22Builder
-
- Tuple23<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20,T21,T22> - Class in org.apache.flink.api.java.tuple
-
A tuple with 23 fields.
- Tuple23() - Constructor for class org.apache.flink.api.java.tuple.Tuple23
-
Creates a new tuple where all fields are null.
- Tuple23(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, T21, T22) - Constructor for class org.apache.flink.api.java.tuple.Tuple23
-
Creates a new tuple and assigns the given values to the tuple's fields.
- Tuple23Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20,T21,T22> - Class in org.apache.flink.api.java.tuple.builder
-
- Tuple23Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple23Builder
-
- Tuple24<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20,T21,T22,T23> - Class in org.apache.flink.api.java.tuple
-
A tuple with 24 fields.
- Tuple24() - Constructor for class org.apache.flink.api.java.tuple.Tuple24
-
Creates a new tuple where all fields are null.
- Tuple24(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, T21, T22, T23) - Constructor for class org.apache.flink.api.java.tuple.Tuple24
-
Creates a new tuple and assigns the given values to the tuple's fields.
- Tuple24Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20,T21,T22,T23> - Class in org.apache.flink.api.java.tuple.builder
-
- Tuple24Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple24Builder
-
- Tuple25<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20,T21,T22,T23,T24> - Class in org.apache.flink.api.java.tuple
-
A tuple with 25 fields.
- Tuple25() - Constructor for class org.apache.flink.api.java.tuple.Tuple25
-
Creates a new tuple where all fields are null.
- Tuple25(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, T21, T22, T23, T24) - Constructor for class org.apache.flink.api.java.tuple.Tuple25
-
Creates a new tuple and assigns the given values to the tuple's fields.
- Tuple25Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20,T21,T22,T23,T24> - Class in org.apache.flink.api.java.tuple.builder
-
- Tuple25Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple25Builder
-
- Tuple2Builder<T0,T1> - Class in org.apache.flink.api.java.tuple.builder
-
- Tuple2Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple2Builder
-
- Tuple3<T0,T1,T2> - Class in org.apache.flink.api.java.tuple
-
A tuple with 3 fields.
- Tuple3() - Constructor for class org.apache.flink.api.java.tuple.Tuple3
-
Creates a new tuple where all fields are null.
- Tuple3(T0, T1, T2) - Constructor for class org.apache.flink.api.java.tuple.Tuple3
-
Creates a new tuple and assigns the given values to the tuple's fields.
- Tuple3Builder<T0,T1,T2> - Class in org.apache.flink.api.java.tuple.builder
-
- Tuple3Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple3Builder
-
- Tuple4<T0,T1,T2,T3> - Class in org.apache.flink.api.java.tuple
-
A tuple with 4 fields.
- Tuple4() - Constructor for class org.apache.flink.api.java.tuple.Tuple4
-
Creates a new tuple where all fields are null.
- Tuple4(T0, T1, T2, T3) - Constructor for class org.apache.flink.api.java.tuple.Tuple4
-
Creates a new tuple and assigns the given values to the tuple's fields.
- Tuple4Builder<T0,T1,T2,T3> - Class in org.apache.flink.api.java.tuple.builder
-
- Tuple4Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple4Builder
-
- Tuple5<T0,T1,T2,T3,T4> - Class in org.apache.flink.api.java.tuple
-
A tuple with 5 fields.
- Tuple5() - Constructor for class org.apache.flink.api.java.tuple.Tuple5
-
Creates a new tuple where all fields are null.
- Tuple5(T0, T1, T2, T3, T4) - Constructor for class org.apache.flink.api.java.tuple.Tuple5
-
Creates a new tuple and assigns the given values to the tuple's fields.
- Tuple5Builder<T0,T1,T2,T3,T4> - Class in org.apache.flink.api.java.tuple.builder
-
- Tuple5Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple5Builder
-
- Tuple6<T0,T1,T2,T3,T4,T5> - Class in org.apache.flink.api.java.tuple
-
A tuple with 6 fields.
- Tuple6() - Constructor for class org.apache.flink.api.java.tuple.Tuple6
-
Creates a new tuple where all fields are null.
- Tuple6(T0, T1, T2, T3, T4, T5) - Constructor for class org.apache.flink.api.java.tuple.Tuple6
-
Creates a new tuple and assigns the given values to the tuple's fields.
- Tuple6Builder<T0,T1,T2,T3,T4,T5> - Class in org.apache.flink.api.java.tuple.builder
-
- Tuple6Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple6Builder
-
- Tuple7<T0,T1,T2,T3,T4,T5,T6> - Class in org.apache.flink.api.java.tuple
-
A tuple with 7 fields.
- Tuple7() - Constructor for class org.apache.flink.api.java.tuple.Tuple7
-
Creates a new tuple where all fields are null.
- Tuple7(T0, T1, T2, T3, T4, T5, T6) - Constructor for class org.apache.flink.api.java.tuple.Tuple7
-
Creates a new tuple and assigns the given values to the tuple's fields.
- Tuple7Builder<T0,T1,T2,T3,T4,T5,T6> - Class in org.apache.flink.api.java.tuple.builder
-
- Tuple7Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple7Builder
-
- Tuple8<T0,T1,T2,T3,T4,T5,T6,T7> - Class in org.apache.flink.api.java.tuple
-
A tuple with 8 fields.
- Tuple8() - Constructor for class org.apache.flink.api.java.tuple.Tuple8
-
Creates a new tuple where all fields are null.
- Tuple8(T0, T1, T2, T3, T4, T5, T6, T7) - Constructor for class org.apache.flink.api.java.tuple.Tuple8
-
Creates a new tuple and assigns the given values to the tuple's fields.
- Tuple8Builder<T0,T1,T2,T3,T4,T5,T6,T7> - Class in org.apache.flink.api.java.tuple.builder
-
- Tuple8Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple8Builder
-
- Tuple9<T0,T1,T2,T3,T4,T5,T6,T7,T8> - Class in org.apache.flink.api.java.tuple
-
A tuple with 9 fields.
- Tuple9() - Constructor for class org.apache.flink.api.java.tuple.Tuple9
-
Creates a new tuple where all fields are null.
- Tuple9(T0, T1, T2, T3, T4, T5, T6, T7, T8) - Constructor for class org.apache.flink.api.java.tuple.Tuple9
-
Creates a new tuple and assigns the given values to the tuple's fields.
- Tuple9Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8> - Class in org.apache.flink.api.java.tuple.builder
-
- Tuple9Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple9Builder
-
- tupleClass - Variable in class org.apache.flink.api.java.typeutils.runtime.TupleSerializerBase
-
- TupleComparator<T extends Tuple> - Class in org.apache.flink.api.java.typeutils.runtime
-
- TupleComparator(int[], TypeComparator<?>[], TypeSerializer<?>[]) - Constructor for class org.apache.flink.api.java.typeutils.runtime.TupleComparator
-
- TupleComparatorBase<T> - Class in org.apache.flink.api.java.typeutils.runtime
-
- TupleComparatorBase(int[], TypeComparator<?>[], TypeSerializer<?>[]) - Constructor for class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
-
- TupleComparatorBase(TupleComparatorBase<T>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
-
- TupleSerializer<T extends Tuple> - Class in org.apache.flink.api.java.typeutils.runtime
-
- TupleSerializer(Class<T>, TypeSerializer<?>[]) - Constructor for class org.apache.flink.api.java.typeutils.runtime.TupleSerializer
-
- TupleSerializerBase<T> - Class in org.apache.flink.api.java.typeutils.runtime
-
- TupleSerializerBase(Class<T>, TypeSerializer<?>[]) - Constructor for class org.apache.flink.api.java.typeutils.runtime.TupleSerializerBase
-
- TupleTypeInfo<T extends Tuple> - Class in org.apache.flink.api.java.typeutils
-
- TupleTypeInfo(TypeInformation<?>...) - Constructor for class org.apache.flink.api.java.typeutils.TupleTypeInfo
-
- TupleTypeInfo(Class<T>, TypeInformation<?>...) - Constructor for class org.apache.flink.api.java.typeutils.TupleTypeInfo
-
- TupleTypeInfoBase<T> - Class in org.apache.flink.api.java.typeutils
-
- TupleTypeInfoBase(Class<T>, TypeInformation<?>...) - Constructor for class org.apache.flink.api.java.typeutils.TupleTypeInfoBase
-
- TypeComparable<T> - Class in org.apache.flink.api.common.operators.util
-
Wrapper that is used to store elements for which we have a TypeComparator in a Hash Map.
- TypeComparable(T, TypeComparator<T>) - Constructor for class org.apache.flink.api.common.operators.util.TypeComparable
-
- TypeComparator<T> - Class in org.apache.flink.api.common.typeutils
-
This interface describes the methods that are required for a data type to be handled by the pact
runtime.
- TypeComparator() - Constructor for class org.apache.flink.api.common.typeutils.TypeComparator
-
- TypeComparatorFactory<T> - Interface in org.apache.flink.api.common.typeutils
-
- TypeExtractor - Class in org.apache.flink.api.java.typeutils
-
A utility for reflection analysis on classes, to determine the return type of implementations of transformation
functions.
- TypeExtractor() - Constructor for class org.apache.flink.api.java.typeutils.TypeExtractor
-
- TypeHint<T> - Class in org.apache.flink.api.common.typeinfo
-
A utility class for describing generic types.
- TypeHint() - Constructor for class org.apache.flink.api.common.typeinfo.TypeHint
-
Creates a hint for the generic type in the class signature.
- TypeInfoParser - Class in org.apache.flink.api.java.typeutils
-
- TypeInfoParser() - Constructor for class org.apache.flink.api.java.typeutils.TypeInfoParser
-
- TypeInformation<T> - Class in org.apache.flink.api.common.typeinfo
-
TypeInformation is the core class of Flink's type system.
- TypeInformation() - Constructor for class org.apache.flink.api.common.typeinfo.TypeInformation
-
- TypePairComparator<T1,T2> - Class in org.apache.flink.api.common.typeutils
-
This interface defines the method required by the runtime to use data types in join-like operations.
- TypePairComparator() - Constructor for class org.apache.flink.api.common.typeutils.TypePairComparator
-
- TypePairComparatorFactory<T1,T2> - Interface in org.apache.flink.api.common.typeutils
-
- types - Variable in class org.apache.flink.api.common.operators.Ordering
-
- types - Variable in class org.apache.flink.api.java.typeutils.TupleTypeInfoBase
-
- TypeSerializer<T> - Class in org.apache.flink.api.common.typeutils
-
This interface describes the methods that are required for a data type to be handled by the pact
runtime.
- TypeSerializer() - Constructor for class org.apache.flink.api.common.typeutils.TypeSerializer
-
- TypeSerializerFactory<T> - Interface in org.apache.flink.api.common.typeutils
-
- TypeSerializerSingleton<T> - Class in org.apache.flink.api.common.typeutils.base
-
- TypeSerializerSingleton() - Constructor for class org.apache.flink.api.common.typeutils.base.TypeSerializerSingleton
-
- typeToClass(Type) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-