跳过导航链接
A B C D E F G H I J K L M N O P Q R S T U V W X Y Z 

A

absentKeysOrValues() - 类 中的方法org.apache.flink.util.LinkedOptionalMap
Returns the key names of any keys or values that are absent.
absoluteTimeMillis() - 类 中的方法org.apache.flink.util.clock.Clock
Gets the current absolute time, in milliseconds.
absoluteTimeMillis() - 类 中的方法org.apache.flink.util.clock.ManualClock
 
absoluteTimeMillis() - 类 中的方法org.apache.flink.util.clock.SystemClock
 
absolutizePath(Path) - 类 中的静态方法org.apache.flink.util.FileUtils
Absolutize the given path if it is relative.
AbstractCloseableRegistry<C extends Closeable,T> - org.apache.flink.util中的类
This is the abstract base class for registries that allow to register instances of Closeable, which are all closed if this registry is closed.
AbstractCloseableRegistry(Map<Closeable, T>) - 类 的构造器org.apache.flink.util.AbstractCloseableRegistry
 
AbstractDeserializationSchema<T> - org.apache.flink.api.common.serialization中的类
The deserialization schema describes how to turn the byte messages delivered by certain data sources (for example Apache Kafka) into data types (Java/Scala objects) that are processed by Flink.
AbstractDeserializationSchema() - 类 的构造器org.apache.flink.api.common.serialization.AbstractDeserializationSchema
Creates a new AbstractDeserializationSchema and tries to infer the type returned by this DeserializationSchema.
AbstractDeserializationSchema(Class<T>) - 类 的构造器org.apache.flink.api.common.serialization.AbstractDeserializationSchema
Creates an AbstractDeserializationSchema that returns the TypeInformation indicated by the given class.
AbstractDeserializationSchema(TypeHint<T>) - 类 的构造器org.apache.flink.api.common.serialization.AbstractDeserializationSchema
Creates an AbstractDeserializationSchema that returns the TypeInformation indicated by the given type hint.
AbstractDeserializationSchema(TypeInformation<T>) - 类 的构造器org.apache.flink.api.common.serialization.AbstractDeserializationSchema
Creates an AbstractDeserializationSchema that returns the given TypeInformation for the produced type.
AbstractID - org.apache.flink.util中的类
A statistically unique identification number.
AbstractID(byte[]) - 类 的构造器org.apache.flink.util.AbstractID
Constructs a new ID with a specific bytes value.
AbstractID(long, long) - 类 的构造器org.apache.flink.util.AbstractID
Constructs a new abstract ID.
AbstractID(AbstractID) - 类 的构造器org.apache.flink.util.AbstractID
Copy constructor: Creates a new abstract ID from the given one.
AbstractID() - 类 的构造器org.apache.flink.util.AbstractID
Constructs a new random ID from a uniform distribution.
AbstractRichFunction - org.apache.flink.api.common.functions中的类
An abstract stub implementation for rich user-defined functions.
AbstractRichFunction() - 类 的构造器org.apache.flink.api.common.functions.AbstractRichFunction
 
AbstractRuntimeUDFContext - org.apache.flink.api.common.functions.util中的类
A standalone implementation of the RuntimeContext, created by runtime UDF operators.
AbstractRuntimeUDFContext(TaskInfo, UserCodeClassLoader, ExecutionConfig, Map<String, Accumulator<?, ?>>, Map<String, Future<Path>>, OperatorMetricGroup) - 类 的构造器org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
 
AbstractUdfOperator<OUT,FT extends Function> - org.apache.flink.api.common.operators中的类
Abstract superclass for all contracts that represent actual operators.
AbstractUdfOperator(UserCodeWrapper<FT>, OperatorInformation<OUT>, String) - 类 的构造器org.apache.flink.api.common.operators.AbstractUdfOperator
Creates a new abstract operator with the given name wrapping the given user function.
accept(Visitor<Operator<?>>) - 类 中的方法org.apache.flink.api.common.operators.base.BulkIterationBase.PartialSolutionPlaceHolder
 
accept(Visitor<Operator<?>>) - 类 中的方法org.apache.flink.api.common.operators.base.DeltaIterationBase.SolutionSetPlaceHolder
 
accept(Visitor<Operator<?>>) - 类 中的方法org.apache.flink.api.common.operators.base.DeltaIterationBase.WorksetPlaceHolder
 
accept(Visitor<Operator<?>>) - 类 中的方法org.apache.flink.api.common.operators.DualInputOperator
 
accept(Visitor<Operator<?>>) - 类 中的方法org.apache.flink.api.common.operators.GenericDataSinkBase
Accepts the visitor and applies it this instance.
accept(Visitor<Operator<?>>) - 类 中的方法org.apache.flink.api.common.operators.GenericDataSourceBase
Accepts the visitor and applies it this instance.
accept(Visitor<Operator<?>>) - 类 中的方法org.apache.flink.api.common.operators.SingleInputOperator
Accepts the visitor and applies it this instance.
accept(Visitor<Operator<?>>) - 类 中的方法org.apache.flink.api.common.Plan
Traverses the job depth first from all data sinks on towards the sources.
accept(T) - 接口 中的方法org.apache.flink.util.concurrent.FutureConsumerWithException
 
accept(T, U) - 接口 中的方法org.apache.flink.util.function.BiConsumerWithException
Performs this operation on the given arguments.
accept(S, T, U, V) - 接口 中的方法org.apache.flink.util.function.QuadConsumer
Performs this operation on the given arguments.
accept(T) - 接口 中的方法org.apache.flink.util.function.ThrowingConsumer
Performs this operation on the given argument.
accept(S, T, U) - 接口 中的方法org.apache.flink.util.function.TriConsumer
Performs this operation on the given arguments.
accept(S, T, U) - 接口 中的方法org.apache.flink.util.function.TriConsumerWithException
Performs this operation on the given arguments.
accept(String, K, V) - 接口 中的方法org.apache.flink.util.LinkedOptionalMap.ConsumerWithException
 
accept(Visitor<T>) - 接口 中的方法org.apache.flink.util.Visitable
Contains the logic to invoke the visitor and continue the traversal.
acceptFile(FileStatus) - 类 中的方法org.apache.flink.api.common.io.FileInputFormat
A simple hook to filter files and directories from the input.
acceptWithException(T) - 接口 中的方法org.apache.flink.util.concurrent.FutureConsumerWithException
 
acceptWithoutTimeout(ServerSocket) - 类 中的静态方法org.apache.flink.util.NetUtils
Calls ServerSocket.accept() on the provided server socket, suppressing any thrown SocketTimeoutExceptions.
ACCESS_CONTROL_ALLOW_ORIGIN - 类 中的静态变量org.apache.flink.configuration.WebOptions
The config parameter defining the Access-Control-Allow-Origin header for all responses from the web-frontend.
accessField(Field, Object) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.PojoComparator
This method is handling the IllegalAccess exceptions of Field.get()
Accumulator<V,R extends Serializable> - org.apache.flink.api.common.accumulators中的接口
Accumulators collect distributed statistics or aggregates in a from user functions and operators.
AccumulatorHelper - org.apache.flink.api.common.accumulators中的类
Helper functions for the interaction with Accumulator.
AccumulatorHelper() - 类 的构造器org.apache.flink.api.common.accumulators.AccumulatorHelper
 
acquire(int) - 接口 中的方法org.apache.flink.api.common.io.ratelimiting.FlinkConnectorRateLimiter
Acquires permits for the rate limiter.
acquire(int) - 类 中的方法org.apache.flink.api.common.io.ratelimiting.GuavaFlinkConnectorRateLimiter
 
acquireResource() - 类 中的方法org.apache.flink.util.ResourceGuard
Acquired access from one new client for the guarded resource.
adapterForIterator(Iterator<T>) - 接口 中的静态方法org.apache.flink.util.CloseableIterator
 
adapterForIterator(Iterator<T>, AutoCloseable) - 接口 中的静态方法org.apache.flink.util.CloseableIterator
 
add(V) - 接口 中的方法org.apache.flink.api.common.accumulators.Accumulator
 
add(Double) - 类 中的方法org.apache.flink.api.common.accumulators.AverageAccumulator
 
add(double) - 类 中的方法org.apache.flink.api.common.accumulators.AverageAccumulator
 
add(long) - 类 中的方法org.apache.flink.api.common.accumulators.AverageAccumulator
 
add(int) - 类 中的方法org.apache.flink.api.common.accumulators.AverageAccumulator
 
add(Double) - 类 中的方法org.apache.flink.api.common.accumulators.DoubleCounter
Consider using DoubleCounter.add(double) instead for primitive double values
add(double) - 类 中的方法org.apache.flink.api.common.accumulators.DoubleCounter
 
add(Double) - 类 中的方法org.apache.flink.api.common.accumulators.DoubleMaximum
Consider using DoubleMaximum.add(double) instead for primitive double values
add(double) - 类 中的方法org.apache.flink.api.common.accumulators.DoubleMaximum
 
add(Double) - 类 中的方法org.apache.flink.api.common.accumulators.DoubleMinimum
Consider using DoubleMinimum.add(double) instead for primitive double values
add(double) - 类 中的方法org.apache.flink.api.common.accumulators.DoubleMinimum
 
add(Integer) - 类 中的方法org.apache.flink.api.common.accumulators.Histogram
 
add(Integer) - 类 中的方法org.apache.flink.api.common.accumulators.IntCounter
Consider using IntCounter.add(int) instead for primitive int values
add(int) - 类 中的方法org.apache.flink.api.common.accumulators.IntCounter
 
add(Integer) - 类 中的方法org.apache.flink.api.common.accumulators.IntMaximum
Consider using IntMaximum.add(int) instead for primitive integer values
add(int) - 类 中的方法org.apache.flink.api.common.accumulators.IntMaximum
 
add(Integer) - 类 中的方法org.apache.flink.api.common.accumulators.IntMinimum
Consider using IntMinimum.add(int) instead for primitive integer values
add(int) - 类 中的方法org.apache.flink.api.common.accumulators.IntMinimum
 
add(T) - 类 中的方法org.apache.flink.api.common.accumulators.ListAccumulator
 
add(Long) - 类 中的方法org.apache.flink.api.common.accumulators.LongCounter
Consider using LongCounter.add(long) instead for primitive long values
add(long) - 类 中的方法org.apache.flink.api.common.accumulators.LongCounter
 
add(Long) - 类 中的方法org.apache.flink.api.common.accumulators.LongMaximum
Consider using LongMaximum.add(long) instead for primitive long values
add(long) - 类 中的方法org.apache.flink.api.common.accumulators.LongMaximum
 
add(Long) - 类 中的方法org.apache.flink.api.common.accumulators.LongMinimum
Consider using LongMinimum.add(long) instead for primitive long values
add(long) - 类 中的方法org.apache.flink.api.common.accumulators.LongMinimum
 
add(T) - 类 中的方法org.apache.flink.api.common.accumulators.SerializedListAccumulator
 
add(T, TypeSerializer<T>) - 类 中的方法org.apache.flink.api.common.accumulators.SerializedListAccumulator
 
add(IN, ACC) - 接口 中的方法org.apache.flink.api.common.functions.AggregateFunction
Adds the given input value to the given accumulator, returning the new accumulator value.
add(IN, ACC) - 类 中的方法org.apache.flink.api.common.functions.RichAggregateFunction
 
add(IN) - 接口 中的方法org.apache.flink.api.common.state.AppendingState
Updates the operator state accessible by AppendingState.get() by adding the given value to the list of values.
add() - 类 中的方法org.apache.flink.api.java.tuple.builder.Tuple0Builder
 
add(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9) - 类 中的方法org.apache.flink.api.java.tuple.builder.Tuple10Builder
 
add(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10) - 类 中的方法org.apache.flink.api.java.tuple.builder.Tuple11Builder
 
add(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11) - 类 中的方法org.apache.flink.api.java.tuple.builder.Tuple12Builder
 
add(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12) - 类 中的方法org.apache.flink.api.java.tuple.builder.Tuple13Builder
 
add(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13) - 类 中的方法org.apache.flink.api.java.tuple.builder.Tuple14Builder
 
add(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14) - 类 中的方法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) - 类 中的方法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) - 类 中的方法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) - 类 中的方法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) - 类 中的方法org.apache.flink.api.java.tuple.builder.Tuple19Builder
 
add(T0) - 类 中的方法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) - 类 中的方法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) - 类 中的方法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) - 类 中的方法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) - 类 中的方法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) - 类 中的方法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) - 类 中的方法org.apache.flink.api.java.tuple.builder.Tuple25Builder
 
add(T0, T1) - 类 中的方法org.apache.flink.api.java.tuple.builder.Tuple2Builder
 
add(T0, T1, T2) - 类 中的方法org.apache.flink.api.java.tuple.builder.Tuple3Builder
 
add(T0, T1, T2, T3) - 类 中的方法org.apache.flink.api.java.tuple.builder.Tuple4Builder
 
add(T0, T1, T2, T3, T4) - 类 中的方法org.apache.flink.api.java.tuple.builder.Tuple5Builder
 
add(T0, T1, T2, T3, T4, T5) - 类 中的方法org.apache.flink.api.java.tuple.builder.Tuple6Builder
 
add(T0, T1, T2, T3, T4, T5, T6) - 类 中的方法org.apache.flink.api.java.tuple.builder.Tuple7Builder
 
add(T0, T1, T2, T3, T4, T5, T6, T7) - 类 中的方法org.apache.flink.api.java.tuple.builder.Tuple8Builder
 
add(T0, T1, T2, T3, T4, T5, T6, T7, T8) - 类 中的方法org.apache.flink.api.java.tuple.builder.Tuple9Builder
 
add(BlockElement) - 类 中的方法org.apache.flink.configuration.description.Description.DescriptionBuilder
Block of description add.
add(MemorySize) - 类 中的方法org.apache.flink.configuration.MemorySize
 
add(int, V) - 类 中的方法org.apache.flink.types.ListValue
 
add(V) - 类 中的方法org.apache.flink.types.ListValue
 
add(Iterator<T>) - 类 中的方法org.apache.flink.util.UnionIterator
 
addAccumulator(String, Accumulator<V, A>) - 接口 中的方法org.apache.flink.api.common.functions.RuntimeContext
Add this accumulator.
addAccumulator(String, Accumulator<V, A>) - 类 中的方法org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
 
addAll(AggregatorRegistry) - 类 中的方法org.apache.flink.api.common.aggregators.AggregatorRegistry
 
addAll(List<T>) - 接口 中的方法org.apache.flink.api.common.state.ListState
Updates the operator state accessible by AppendingState.get() by adding the given values to existing list of values.
addAll(Configuration) - 类 中的方法org.apache.flink.configuration.Configuration
 
addAll(Configuration, String) - 类 中的方法org.apache.flink.configuration.Configuration
Adds all entries from the given configuration into this configuration.
addAll(Configuration) - 类 中的方法org.apache.flink.configuration.DelegatingConfiguration
 
addAll(Configuration, String) - 类 中的方法org.apache.flink.configuration.DelegatingConfiguration
 
addAll(Configuration) - 类 中的方法org.apache.flink.configuration.UnmodifiableConfiguration
 
addAll(Configuration, String) - 类 中的方法org.apache.flink.configuration.UnmodifiableConfiguration
 
addAll(Collection<? extends V>) - 类 中的方法org.apache.flink.types.ListValue
 
addAll(int, Collection<? extends V>) - 类 中的方法org.apache.flink.types.ListValue
 
addAllToProperties(Properties) - 类 中的方法org.apache.flink.configuration.Configuration
Adds all entries in this Configuration to the given Properties.
addAllToProperties(Properties) - 类 中的方法org.apache.flink.configuration.DelegatingConfiguration
 
addAllToProperties(Properties) - 类 中的方法org.apache.flink.configuration.UnmodifiableConfiguration
 
addAvroGenericDataArrayRegistration(LinkedHashMap<String, KryoRegistration>) - 类 中的方法org.apache.flink.api.java.typeutils.AvroUtils
Registers a special Serializer for GenericData.Array.
addAvroSerializersIfRequired(ExecutionConfig, Class<?>) - 类 中的方法org.apache.flink.api.java.typeutils.AvroUtils
Loads the utility class from flink-avro and adds Avro-specific serializers.
addCloseableInternal(Closeable, T) - 类 中的方法org.apache.flink.util.AbstractCloseableRegistry
Adds a mapping to the registry map, respecting locking.
addComparatorField(int, TypeComparator<?>) - 接口 中的方法org.apache.flink.api.common.typeutils.CompositeType.TypeComparatorBuilder
 
addDataSink(GenericDataSinkBase<?>) - 类 中的方法org.apache.flink.api.common.Plan
Adds a data sink to the set of sinks in this program.
addDefaultKryoSerializer(Class<?>, T) - 类 中的方法org.apache.flink.api.common.ExecutionConfig
Adds a new Kryo default serializer to the Runtime.
addDefaultKryoSerializer(Class<?>, Class<? extends Serializer<?>>) - 类 中的方法org.apache.flink.api.common.ExecutionConfig
Adds a new Kryo default serializer to the Runtime.
addElement(T) - 接口 中的方法org.apache.flink.api.common.serialization.BulkWriter
Adds an element to the encoder.
addField(Integer) - 类 中的方法org.apache.flink.api.common.operators.util.FieldList
 
addField(Integer) - 类 中的方法org.apache.flink.api.common.operators.util.FieldSet
 
addField(Value) - 类 中的方法org.apache.flink.types.Record
 
addFields(int...) - 类 中的方法org.apache.flink.api.common.operators.util.FieldList
 
addFields(FieldSet) - 类 中的方法org.apache.flink.api.common.operators.util.FieldList
 
addFields(int...) - 类 中的方法org.apache.flink.api.common.operators.util.FieldSet
 
addFields(FieldSet) - 类 中的方法org.apache.flink.api.common.operators.util.FieldSet
 
addFirstInput(Operator<IN1>...) - 类 中的方法org.apache.flink.api.common.operators.DualInputOperator
已过时。
This method will be removed in future versions. Use the Union operator instead.
addFirstInputs(List<Operator<IN1>>) - 类 中的方法org.apache.flink.api.common.operators.DualInputOperator
已过时。
This method will be removed in future versions. Use the Union operator instead.
addForwardedField(int, int, int) - 类 中的方法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) - 类 中的方法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) - 类 中的方法org.apache.flink.api.common.operators.SingleInputSemanticProperties.AllFieldsForwardedProperties
 
addInput(Operator<IN>...) - 类 中的方法org.apache.flink.api.common.operators.GenericDataSinkBase
已过时。
This method will be removed in future versions. Use the Union operator instead.
addInput(Operator<IN>...) - 类 中的方法org.apache.flink.api.common.operators.SingleInputOperator
已过时。
This method will be removed in future versions. Use the Union operator instead.
addInput(List<Operator<IN>>) - 类 中的方法org.apache.flink.api.common.operators.SingleInputOperator
已过时。
This method will be removed in future versions. Use the Union operator instead.
addInputs(List<? extends Operator<IN>>) - 类 中的方法org.apache.flink.api.common.operators.GenericDataSinkBase
已过时。
This method will be removed in future versions. Use the Union operator instead.
addList(List<T>) - 类 中的方法org.apache.flink.util.UnionIterator
 
addReader(int) - 类 中的方法org.apache.flink.api.connector.source.lib.util.IteratorSourceEnumerator
 
addReader(int) - 接口 中的方法org.apache.flink.api.connector.source.SplitEnumerator
Add a new source reader with the given subtask ID.
addReadFields(int, FieldSet) - 类 中的方法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) - 类 中的方法org.apache.flink.api.common.operators.SingleInputSemanticProperties
Adds, to the existing information, field(s) that are read in the source record(s).
ADDRESS - 类 中的静态变量org.apache.flink.configuration.JobManagerOptions
The config parameter defining the network address to connect to for communication with the job manager.
ADDRESS - 类 中的静态变量org.apache.flink.configuration.RestOptions
The address that should be used by clients to connect to the server.
ADDRESS - 类 中的静态变量org.apache.flink.configuration.WebOptions
已过时。
addSecondInput(Operator<IN2>...) - 类 中的方法org.apache.flink.api.common.operators.DualInputOperator
已过时。
This method will be removed in future versions. Use the Union operator instead.
addSecondInputs(List<Operator<IN2>>) - 类 中的方法org.apache.flink.api.common.operators.DualInputOperator
已过时。
This method will be removed in future versions. Use the Union operator instead.
addShutdownHook(AutoCloseable, String, Logger) - 类 中的静态方法org.apache.flink.util.ShutdownHookUtil
Adds a shutdown hook to the JVM and returns the Thread, which has been registered.
addShutdownHookThread(Thread, String, Logger) - 类 中的静态方法org.apache.flink.util.ShutdownHookUtil
Adds a shutdown hook to the JVM.
addSplits(List<SplitT>) - 类 中的方法org.apache.flink.api.connector.source.lib.util.IteratorSourceReader
 
addSplits(List<SplitT>) - 接口 中的方法org.apache.flink.api.connector.source.SourceReader
Adds a list of splits for this reader to read.
addSplitsBack(List<SplitT>, int) - 类 中的方法org.apache.flink.api.connector.source.lib.util.IteratorSourceEnumerator
 
addSplitsBack(List<SplitT>, int) - 接口 中的方法org.apache.flink.api.connector.source.SplitEnumerator
Add a split back to the split enumerator.
addUniqueField(FieldSet) - 类 中的方法org.apache.flink.api.common.operators.CompilerHints
Adds a FieldSet to be unique
addUniqueField(int) - 类 中的方法org.apache.flink.api.common.operators.CompilerHints
Adds a field as having only unique values.
addUniqueFields(Set<FieldSet>) - 类 中的方法org.apache.flink.api.common.operators.CompilerHints
Adds multiple FieldSets to be unique
advanceTime(long, TimeUnit) - 类 中的方法org.apache.flink.util.clock.ManualClock
Advances the time by the given duration.
advanceTime(Duration) - 类 中的方法org.apache.flink.util.clock.ManualClock
Advances the time by the given duration.
aggregate(T) - 接口 中的方法org.apache.flink.api.common.aggregators.Aggregator
Aggregates the given element.
aggregate(DoubleValue) - 类 中的方法org.apache.flink.api.common.aggregators.DoubleSumAggregator
 
aggregate(double) - 类 中的方法org.apache.flink.api.common.aggregators.DoubleSumAggregator
Adds the given value to the current aggregate.
aggregate(LongValue) - 类 中的方法org.apache.flink.api.common.aggregators.LongSumAggregator
 
aggregate(long) - 类 中的方法org.apache.flink.api.common.aggregators.LongSumAggregator
Adds the given value to the current aggregate.
aggregate(long) - 类 中的方法org.apache.flink.api.common.operators.base.BulkIterationBase.TerminationCriterionAggregator
 
aggregate(LongValue) - 类 中的方法org.apache.flink.api.common.operators.base.BulkIterationBase.TerminationCriterionAggregator
 
AggregateFunction<IN,ACC,OUT> - org.apache.flink.api.common.functions中的接口
The AggregateFunction is a flexible aggregation function, characterized by the following features: The aggregates may use different types for input values, intermediate aggregates, and result type, to support a wide range of aggregation types.
AggregatingState<IN,OUT> - org.apache.flink.api.common.state中的接口
State interface for aggregating state, based on an AggregateFunction.
AggregatingStateDescriptor<IN,ACC,OUT> - org.apache.flink.api.common.state中的类
A StateDescriptor for AggregatingState.
AggregatingStateDescriptor(String, AggregateFunction<IN, ACC, OUT>, Class<ACC>) - 类 的构造器org.apache.flink.api.common.state.AggregatingStateDescriptor
Creates a new state descriptor with the given name, function, and type.
AggregatingStateDescriptor(String, AggregateFunction<IN, ACC, OUT>, TypeInformation<ACC>) - 类 的构造器org.apache.flink.api.common.state.AggregatingStateDescriptor
Creates a new ReducingStateDescriptor with the given name and default value.
AggregatingStateDescriptor(String, AggregateFunction<IN, ACC, OUT>, TypeSerializer<ACC>) - 类 的构造器org.apache.flink.api.common.state.AggregatingStateDescriptor
Creates a new ValueStateDescriptor with the given name and default value.
Aggregator<T extends Value> - org.apache.flink.api.common.aggregators中的接口
Aggregators are a means of aggregating values across parallel instances of a function.
AggregatorRegistry - org.apache.flink.api.common.aggregators中的类
A registry for iteration Aggregators.
AggregatorRegistry() - 类 的构造器org.apache.flink.api.common.aggregators.AggregatorRegistry
 
AggregatorWithName<T extends Value> - org.apache.flink.api.common.aggregators中的类
Simple utility class holding an Aggregator with the name it is registered under.
AggregatorWithName(String, Aggregator<T>) - 类 的构造器org.apache.flink.api.common.aggregators.AggregatorWithName
Creates a new instance for the given aggregator and name.
AKKA_ASK_TIMEOUT - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
AKKA_CLIENT_TIMEOUT - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
Use ClientOptions#CLIENT_TIMEOUT instead.
AKKA_DISPATCHER_THROUGHPUT - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
AKKA_FRAMESIZE - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
AKKA_JVM_EXIT_ON_FATAL_ERROR - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
AKKA_LOG_LIFECYCLE_EVENTS - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
AKKA_LOOKUP_TIMEOUT - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
AKKA_SSL_ENABLED - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
AKKA_STARTUP_TIMEOUT - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
AKKA_TCP_TIMEOUT - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
AKKA_TRANSPORT_HEARTBEAT_INTERVAL - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
Use AkkaOptions#TRANSPORT_HEARTBEAT_INTERVAL instead.
AKKA_TRANSPORT_HEARTBEAT_PAUSE - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
Use AkkaOptions#TRANSPORT_HEARTBEAT_PAUSE instead.
AKKA_TRANSPORT_THRESHOLD - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
Use AkkaOptions#TRANSPORT_THRESHOLD instead.
AKKA_WATCH_HEARTBEAT_INTERVAL - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
This option is no longer used and has no effect on Flink.
AKKA_WATCH_HEARTBEAT_PAUSE - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
This option is no longer used and has no effect on Flink.
AKKA_WATCH_THRESHOLD - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
This option is no longer used and has no effect on Flink.
AkkaOptions - org.apache.flink.configuration中的类
Akka configuration options.
AkkaOptions() - 类 的构造器org.apache.flink.configuration.AkkaOptions
 
AlgorithmOptions - org.apache.flink.configuration中的类
Configuration parameters for join/sort algorithms.
AlgorithmOptions() - 类 的构造器org.apache.flink.configuration.AlgorithmOptions
 
AllFieldsForwardedProperties() - 类 的构造器org.apache.flink.api.common.operators.SingleInputSemanticProperties.AllFieldsForwardedProperties
 
allocateOffHeapUnsafeMemory(int) - 类 中的静态方法org.apache.flink.core.memory.MemorySegmentFactory
 
allocateOffHeapUnsafeMemory(int, Object, Runnable) - 类 中的静态方法org.apache.flink.core.memory.MemorySegmentFactory
Allocates an off-heap unsafe memory and creates a new memory segment to represent that memory.
allocateUnpooledOffHeapMemory(int) - 类 中的静态方法org.apache.flink.core.memory.MemorySegmentFactory
Allocates some unpooled off-heap memory and creates a new memory segment that represents that memory.
allocateUnpooledOffHeapMemory(int, Object) - 类 中的静态方法org.apache.flink.core.memory.MemorySegmentFactory
Allocates some unpooled off-heap memory and creates a new memory segment that represents that memory.
allocateUnpooledSegment(int) - 类 中的静态方法org.apache.flink.core.memory.MemorySegmentFactory
Allocates some unpooled memory and creates a new memory segment that represents that memory.
allocateUnpooledSegment(int, Object) - 类 中的静态方法org.apache.flink.core.memory.MemorySegmentFactory
Allocates some unpooled memory and creates a new memory segment that represents that memory.
ALLOWED_FALLBACK_FILESYSTEMS - 类 中的静态变量org.apache.flink.configuration.CoreOptions
 
ALWAYS_PARENT_FIRST_LOADER_PATTERNS - 类 中的静态变量org.apache.flink.configuration.CoreOptions
The namespace patterns for classes that are loaded with a preference from the parent classloader, meaning the application class path, rather than any user code jar file.
ALWAYS_PARENT_FIRST_LOADER_PATTERNS_ADDITIONAL - 类 中的静态变量org.apache.flink.configuration.CoreOptions
 
analyzePojo(Type, List<Type>, TypeInformation<IN1>, TypeInformation<IN2>) - 类 中的方法org.apache.flink.api.java.typeutils.TypeExtractor
 
append(char) - 类 中的方法org.apache.flink.types.StringValue
 
append(CharSequence) - 类 中的方法org.apache.flink.types.StringValue
 
append(CharSequence, int, int) - 类 中的方法org.apache.flink.types.StringValue
 
append(StringValue) - 类 中的方法org.apache.flink.types.StringValue
 
append(StringValue, int, int) - 类 中的方法org.apache.flink.types.StringValue
 
AppendingState<IN,OUT> - org.apache.flink.api.common.state中的接口
Base interface for partitioned state that supports adding elements and inspecting the current state.
appendOrdering(Integer, Class<? extends Comparable<?>>, Order) - 类 中的方法org.apache.flink.api.common.operators.Ordering
Extends this ordering by appending an additional order requirement.
apply(T, U) - 接口 中的方法org.apache.flink.util.function.BiFunctionWithException
Apply the given values t and u to obtain the resulting value.
apply(T) - 接口 中的方法org.apache.flink.util.function.FunctionWithException
Calls this function.
apply(long) - 接口 中的方法org.apache.flink.util.function.LongFunctionWithException
Applies this function to the given argument.
apply(S, T, U, V) - 接口 中的方法org.apache.flink.util.function.QuadFunction
Applies this function to the given arguments.
apply(S, T, U) - 接口 中的方法org.apache.flink.util.function.TriFunction
Applies this function to the given arguments.
apply(S, T, U) - 接口 中的方法org.apache.flink.util.function.TriFunctionWithException
Applies this function to the given arguments.
applyRegistrations(Kryo, Collection<KryoRegistration>) - 类 中的静态方法org.apache.flink.api.java.typeutils.runtime.KryoUtils
Apply a list of KryoRegistration to a Kryo instance.
applyToAllWhileSuppressingExceptions(Iterable<T>, ThrowingConsumer<T, ? extends Exception>) - 类 中的静态方法org.apache.flink.util.LambdaUtil
This method supplies all elements from the input to the consumer.
archive() - 接口 中的方法org.apache.flink.api.common.Archiveable
 
archive() - 类 中的方法org.apache.flink.api.common.ExecutionConfig
 
ARCHIVE_COUNT - 类 中的静态变量org.apache.flink.configuration.WebOptions
The config parameter defining the number of archived jobs for the JobManager.
ARCHIVE_DIR - 类 中的静态变量org.apache.flink.configuration.JobManagerOptions
The location where the JobManager stores the archives of completed jobs.
Archiveable<T extends Serializable> - org.apache.flink.api.common中的接口
 
ArchivedExecutionConfig - org.apache.flink.api.common中的类
Serializable class which is created when archiving the job.
ArchivedExecutionConfig(ExecutionConfig) - 类 的构造器org.apache.flink.api.common.ArchivedExecutionConfig
 
ArchivedExecutionConfig(String, String, int, int, boolean, Map<String, String>) - 类 的构造器org.apache.flink.api.common.ArchivedExecutionConfig
 
areCompatible(Keys<?>) - 类 中的方法org.apache.flink.api.common.operators.Keys
Check if two sets of keys are compatible to each other (matching types, key counts)
arity - 类 中的变量org.apache.flink.api.java.typeutils.runtime.TupleSerializerBase
 
arrayAwareToString(Object) - 类 中的静态方法org.apache.flink.util.StringUtils
Converts the given object into a string representation by calling Object.toString() and formatting (possibly nested) arrays and null.
ArrayUtils - org.apache.flink.util中的类
Utility class for Java arrays.
ArrayUtils() - 类 的构造器org.apache.flink.util.ArrayUtils
 
asArray(Class<U>) - 类 中的静态方法org.apache.flink.api.common.operators.AbstractUdfOperator
Generic utility function that wraps a single class object into an array of that class type.
asCallable(RunnableWithException, T) - 类 中的静态方法org.apache.flink.util.function.FunctionUtils
Converts RunnableWithException into a Callable that will return the result.
ascending - 类 中的变量org.apache.flink.api.common.typeutils.base.array.PrimitiveArrayComparator
 
ascendingComparison - 类 中的变量org.apache.flink.api.common.typeutils.base.BasicTypeComparator
 
ascendingComparison - 类 中的变量org.apache.flink.api.common.typeutils.base.LocalDateComparator
 
ascendingComparison - 类 中的变量org.apache.flink.api.common.typeutils.base.LocalDateTimeComparator
 
AscendingTimestampsWatermarks<T> - org.apache.flink.api.common.eventtime中的类
A watermark generator that assumes monotonically ascending timestamps within the stream split and periodically generates watermarks based on that assumption.
AscendingTimestampsWatermarks() - 类 的构造器org.apache.flink.api.common.eventtime.AscendingTimestampsWatermarks
Creates a new watermark generator with for ascending timestamps.
asClassLoader() - 类 中的方法org.apache.flink.util.SimpleUserCodeClassLoader
 
asClassLoader() - 接口 中的方法org.apache.flink.util.UserCodeClassLoader
Obtains the actual class loader.
ASK_TIMEOUT - 类 中的静态变量org.apache.flink.configuration.AkkaOptions
ASK_TIMEOUT_DURATION - 类 中的静态变量org.apache.flink.configuration.AkkaOptions
Timeout for akka ask calls.
asList() - 类 中的方法org.apache.flink.configuration.ConfigOptions.TypedConfigOptionBuilder
Defines that the option's type should be a list of previously defined atomic type.
assembleDynamicConfigsStr(Map<String, String>) - 类 中的静态方法org.apache.flink.configuration.ConfigurationUtils
Creates a dynamic parameter list String of the passed configuration map.
assertNoException(CompletableFuture<?>) - 类 中的静态方法org.apache.flink.util.concurrent.FutureUtils
Asserts that the given CompletableFuture is not completed exceptionally.
assertThrowable(Throwable, Class<T>) - 类 中的静态方法org.apache.flink.util.ExceptionUtils
The same as ExceptionUtils.findThrowable(Throwable, Class), but rethrows original exception if the expected exception was not found.
assertThrowable(T, Predicate<Throwable>) - 类 中的静态方法org.apache.flink.util.ExceptionUtils
The same as ExceptionUtils.findThrowable(Throwable, Predicate), but rethrows original exception if the expected exception was not found.
assertThrowableWithMessage(Throwable, String) - 类 中的静态方法org.apache.flink.util.ExceptionUtils
The same as ExceptionUtils.findThrowableWithMessage(Throwable, String), but rethrows original exception if the expected exception was not found.
assignment() - 类 中的方法org.apache.flink.api.connector.source.SplitsAssignment
 
assignSplit(SplitT, int) - 接口 中的方法org.apache.flink.api.connector.source.SplitEnumeratorContext
Assigns a single split.
assignSplits(SplitsAssignment<SplitT>) - 接口 中的方法org.apache.flink.api.connector.source.SplitEnumeratorContext
Assign the splits.
ASYNC_SNAPSHOTS - 类 中的静态变量org.apache.flink.configuration.CheckpointingOptions
已过时。
Checkpoints are aways asynchronous.
AtomicType<T> - 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.
ATTACHED - 类 中的静态变量org.apache.flink.configuration.DeploymentOptions
 
AUTO_GENERATE_UIDS - 类 中的静态变量org.apache.flink.configuration.PipelineOptions
 
AUTO_TYPE_REGISTRATION - 类 中的静态变量org.apache.flink.configuration.PipelineOptions
 
AUTO_WATERMARK_INTERVAL - 类 中的静态变量org.apache.flink.configuration.PipelineOptions
 
AutoCloseableAsync - org.apache.flink.util中的接口
Closeable interface which allows to close a resource in a non blocking fashion.
available() - 类 中的方法org.apache.flink.core.fs.FSDataInputStreamWrapper
 
available() - 类 中的方法org.apache.flink.core.fs.local.LocalDataInputStream
 
available() - 类 中的方法org.apache.flink.core.memory.DataInputDeserializer
 
available() - 类 中的方法org.apache.flink.core.memory.MemorySegmentInputStreamWithPos
 
AverageAccumulator - org.apache.flink.api.common.accumulators中的类
An accumulator that computes the average value.
AverageAccumulator() - 类 的构造器org.apache.flink.api.common.accumulators.AverageAccumulator
 
AVG_RECORD_BYTES_UNKNOWN - 接口 中的静态变量org.apache.flink.api.common.io.statistics.BaseStatistics
Constant indicating that average record width is unknown.
avgBytesPerRecord - 类 中的变量org.apache.flink.api.common.io.FileInputFormat.FileBaseStatistics
 
AvroUtils - org.apache.flink.api.java.typeutils中的类
Utility methods for dealing with Avro types.
AvroUtils() - 类 的构造器org.apache.flink.api.java.typeutils.AvroUtils
 
AWAIT_LEADER_TIMEOUT - 类 中的静态变量org.apache.flink.configuration.RestOptions
The time in ms that the client waits for the leader address, e.g., Dispatcher or WebMonitorEndpoint.

B

BACKPRESSURE_CLEANUP_INTERVAL - 类 中的静态变量org.apache.flink.configuration.WebOptions
已过时。
- no longer used.
BACKPRESSURE_DELAY - 类 中的静态变量org.apache.flink.configuration.WebOptions
已过时。
- no longer used.
BACKPRESSURE_NUM_SAMPLES - 类 中的静态变量org.apache.flink.configuration.WebOptions
已过时。
- no longer used.
BACKPRESSURE_REFRESH_INTERVAL - 类 中的静态变量org.apache.flink.configuration.WebOptions
已过时。
- no longer used.
BackwardsCompatibleSerializerSnapshot<T> - org.apache.flink.api.common.typeutils中的类
A utility TypeSerializerConfigSnapshot that is used for backwards compatibility purposes.
BackwardsCompatibleSerializerSnapshot(TypeSerializer<T>) - 类 的构造器org.apache.flink.api.common.typeutils.BackwardsCompatibleSerializerSnapshot
 
BaseStatistics - org.apache.flink.api.common.io.statistics中的接口
Interface describing the basic statistics that can be obtained from the input.
BasicArrayTypeInfo<T,C> - org.apache.flink.api.common.typeinfo中的类
Type information for arrays boxed primitive types.
BasicTypeComparator<T extends Comparable<T>> - org.apache.flink.api.common.typeutils.base中的类
 
BasicTypeComparator(boolean) - 类 的构造器org.apache.flink.api.common.typeutils.base.BasicTypeComparator
 
BasicTypeInfo<T> - org.apache.flink.api.common.typeinfo中的类
Type information for primitive types (int, long, double, byte, ...), String, Date, Void, BigInteger, and BigDecimal.
BasicTypeInfo(Class<T>, Class<?>[], TypeSerializer<T>, Class<? extends TypeComparator<T>>) - 类 的构造器org.apache.flink.api.common.typeinfo.BasicTypeInfo
 
BATCH_SHUFFLE_MODE - 类 中的静态变量org.apache.flink.configuration.ExecutionOptions
 
BatchShuffleMode - org.apache.flink.api.common中的枚举
Defines how data is exchanged between tasks in batch ExecutionOptions.RUNTIME_MODE if the shuffling behavior has not been set explicitly for an individual exchange.
BiConsumerWithException<T,U,E extends Throwable> - org.apache.flink.util.function中的接口
A checked extension of the BiConsumer interface.
BiFunctionWithException<T,U,R,E extends Throwable> - org.apache.flink.util.function中的接口
BiFunction interface which can throw exceptions.
BIG_DEC - 类 中的静态变量org.apache.flink.api.common.typeinfo.Types
Returns type information for BigDecimal.
BIG_DEC_TYPE_INFO - 类 中的静态变量org.apache.flink.api.common.typeinfo.BasicTypeInfo
 
BIG_INT - 类 中的静态变量org.apache.flink.api.common.typeinfo.Types
Returns type information for BigInteger.
BIG_INT_TYPE_INFO - 类 中的静态变量org.apache.flink.api.common.typeinfo.BasicTypeInfo
 
BigDecComparator - org.apache.flink.api.common.typeutils.base中的类
Comparator for comparing BigDecimal values.
BigDecComparator(boolean) - 类 的构造器org.apache.flink.api.common.typeutils.base.BigDecComparator
 
BigDecParser - org.apache.flink.types.parser中的类
Parses a text field into a BigDecimal.
BigDecParser() - 类 的构造器org.apache.flink.types.parser.BigDecParser
 
BigDecSerializer - org.apache.flink.api.common.typeutils.base中的类
Serializer for serializing/deserializing BigDecimal values including null values.
BigDecSerializer() - 类 的构造器org.apache.flink.api.common.typeutils.base.BigDecSerializer
 
BigDecSerializer.BigDecSerializerSnapshot - org.apache.flink.api.common.typeutils.base中的类
Serializer configuration snapshot for compatibility and format evolution.
BigDecSerializerSnapshot() - 类 的构造器org.apache.flink.api.common.typeutils.base.BigDecSerializer.BigDecSerializerSnapshot
 
BigIntComparator - org.apache.flink.api.common.typeutils.base中的类
Comparator for comparing BigInteger values.
BigIntComparator(boolean) - 类 的构造器org.apache.flink.api.common.typeutils.base.BigIntComparator
 
BigIntParser - org.apache.flink.types.parser中的类
Parses a text field into a BigInteger.
BigIntParser() - 类 的构造器org.apache.flink.types.parser.BigIntParser
 
BigIntSerializer - org.apache.flink.api.common.typeutils.base中的类
Serializer for serializing/deserializing BigInteger values including null values.
BigIntSerializer() - 类 的构造器org.apache.flink.api.common.typeutils.base.BigIntSerializer
 
BigIntSerializer.BigIntSerializerSnapshot - org.apache.flink.api.common.typeutils.base中的类
Serializer configuration snapshot for compatibility and format evolution.
BigIntSerializerSnapshot() - 类 的构造器org.apache.flink.api.common.typeutils.base.BigIntSerializer.BigIntSerializerSnapshot
 
BinaryInputFormat<T> - org.apache.flink.api.common.io中的类
Base class for all input formats that use blocks of fixed size.
BinaryInputFormat() - 类 的构造器org.apache.flink.api.common.io.BinaryInputFormat
 
BinaryInputFormat.BlockBasedInput - org.apache.flink.api.common.io中的类
Reads the content of a block of data.
BinaryOperatorInformation<IN1,IN2,OUT> - org.apache.flink.api.common.operators中的类
A class for holding information about a single input operator, such as input/output TypeInformation.
BinaryOperatorInformation(TypeInformation<IN1>, TypeInformation<IN2>, TypeInformation<OUT>) - 类 的构造器org.apache.flink.api.common.operators.BinaryOperatorInformation
 
BinaryOutputFormat<T> - org.apache.flink.api.common.io中的类
 
BinaryOutputFormat() - 类 的构造器org.apache.flink.api.common.io.BinaryOutputFormat
 
BinaryOutputFormat.BlockBasedOutput - org.apache.flink.api.common.io中的类
Writes a block info at the end of the blocks.
BIND_ADDRESS - 类 中的静态变量org.apache.flink.configuration.RestOptions
The address that the server binds itself to.
BIND_HOST - 类 中的静态变量org.apache.flink.configuration.JobManagerOptions
The local address of the network interface that the job manager binds to.
BIND_HOST - 类 中的静态变量org.apache.flink.configuration.TaskManagerOptions
The local address of the network interface that the task manager binds to.
BIND_PORT - 类 中的静态变量org.apache.flink.configuration.RestOptions
The port range that the server could bind itself to.
bitMix(int) - 类 中的静态方法org.apache.flink.util.MathUtils
Bit-mixing for pseudo-randomization of integers (e.g., to guard against bad hash functions).
BLOB_FETCH_BACKLOG_KEY - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
BLOB_FETCH_CONCURRENT_KEY - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
BLOB_FETCH_RETRIES_KEY - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
BLOB_SERVER_PORT - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
BLOB_SERVICE_SSL_ENABLED - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
BLOB_STORAGE_DIRECTORY_KEY - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
blobKey - 类 中的变量org.apache.flink.api.common.cache.DistributedCache.DistributedCacheEntry
 
BlobServerOptions - org.apache.flink.configuration中的类
Configuration options for the BlobServer and BlobCache.
BlobServerOptions() - 类 的构造器org.apache.flink.configuration.BlobServerOptions
 
BLOCK_SIZE_PARAMETER_KEY - 类 中的静态变量org.apache.flink.api.common.io.BinaryInputFormat
The config parameter which defines the fixed length of a record.
BLOCK_SIZE_PARAMETER_KEY - 类 中的静态变量org.apache.flink.api.common.io.BinaryOutputFormat
The config parameter which defines the fixed length of a record.
BlockBasedInput(FSDataInputStream, int) - 类 的构造器org.apache.flink.api.common.io.BinaryInputFormat.BlockBasedInput
 
BlockBasedInput(FSDataInputStream, int, long) - 类 的构造器org.apache.flink.api.common.io.BinaryInputFormat.BlockBasedInput
 
BlockBasedOutput(OutputStream, int) - 类 的构造器org.apache.flink.api.common.io.BinaryOutputFormat.BlockBasedOutput
 
BlockElement - org.apache.flink.configuration.description中的接口
Part of description that represents a block e.g. some text, linebreak or a list.
BlockInfo - org.apache.flink.api.common.io中的类
A block of 24 bytes written at the end of a block in a binary file, and containing i) the number of records in the block, ii) the accumulated number of records, and iii) the offset of the first record in the block.
BlockInfo() - 类 的构造器org.apache.flink.api.common.io.BlockInfo
 
BLOCKING_SHUFFLE_COMPRESSION_ENABLED - 类 中的静态变量org.apache.flink.configuration.NettyShuffleEnvironmentOptions
Boolean flag indicating whether the shuffle data will be compressed for blocking shuffle mode.
BlockLocation - org.apache.flink.core.fs中的接口
A BlockLocation lists hosts, offset and length of block.
BOOLEAN - 类 中的静态变量org.apache.flink.api.common.typeinfo.Types
Returns type information for both a primitive boolean and Boolean.
BOOLEAN_ARRAY_TYPE_INFO - 类 中的静态变量org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
 
BOOLEAN_PRIMITIVE_ARRAY_TYPE_INFO - 类 中的静态变量org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
 
BOOLEAN_TYPE_INFO - 类 中的静态变量org.apache.flink.api.common.typeinfo.BasicTypeInfo
 
BOOLEAN_VALUE_TYPE_INFO - 类 中的静态变量org.apache.flink.api.java.typeutils.ValueTypeInfo
 
BooleanComparator - org.apache.flink.api.common.typeutils.base中的类
 
BooleanComparator(boolean) - 类 的构造器org.apache.flink.api.common.typeutils.base.BooleanComparator
 
BooleanParser - org.apache.flink.types.parser中的类
 
BooleanParser() - 类 的构造器org.apache.flink.types.parser.BooleanParser
 
BooleanPrimitiveArrayComparator - org.apache.flink.api.common.typeutils.base.array中的类
 
BooleanPrimitiveArrayComparator(boolean) - 类 的构造器org.apache.flink.api.common.typeutils.base.array.BooleanPrimitiveArrayComparator
 
BooleanPrimitiveArraySerializer - org.apache.flink.api.common.typeutils.base.array中的类
A serializer for boolean arrays.
BooleanPrimitiveArraySerializer() - 类 的构造器org.apache.flink.api.common.typeutils.base.array.BooleanPrimitiveArraySerializer
 
BooleanPrimitiveArraySerializer.BooleanPrimitiveArraySerializerSnapshot - org.apache.flink.api.common.typeutils.base.array中的类
Serializer configuration snapshot for compatibility and format evolution.
BooleanPrimitiveArraySerializerSnapshot() - 类 的构造器org.apache.flink.api.common.typeutils.base.array.BooleanPrimitiveArraySerializer.BooleanPrimitiveArraySerializerSnapshot
 
BooleanSerializer - org.apache.flink.api.common.typeutils.base中的类
Type serializer for Boolean.
BooleanSerializer() - 类 的构造器org.apache.flink.api.common.typeutils.base.BooleanSerializer
 
BooleanSerializer.BooleanSerializerSnapshot - org.apache.flink.api.common.typeutils.base中的类
Serializer configuration snapshot for compatibility and format evolution.
BooleanSerializerSnapshot() - 类 的构造器org.apache.flink.api.common.typeutils.base.BooleanSerializer.BooleanSerializerSnapshot
 
booleanType() - 类 中的方法org.apache.flink.configuration.ConfigOptions.OptionBuilder
Defines that the value of the option should be of Boolean type.
BooleanValue - org.apache.flink.types中的类
Boxed serializable and comparable boolean type, representing the primitive type boolean.
BooleanValue() - 类 的构造器org.apache.flink.types.BooleanValue
 
BooleanValue(boolean) - 类 的构造器org.apache.flink.types.BooleanValue
 
BooleanValueComparator - org.apache.flink.api.common.typeutils.base中的类
Specialized comparator for BooleanValue based on CopyableValueComparator.
BooleanValueComparator(boolean) - 类 的构造器org.apache.flink.api.common.typeutils.base.BooleanValueComparator
 
BooleanValueParser - org.apache.flink.types.parser中的类
 
BooleanValueParser() - 类 的构造器org.apache.flink.types.parser.BooleanValueParser
 
BooleanValueSerializer - org.apache.flink.api.common.typeutils.base中的类
 
BooleanValueSerializer() - 类 的构造器org.apache.flink.api.common.typeutils.base.BooleanValueSerializer
 
BooleanValueSerializer.BooleanValueSerializerSnapshot - org.apache.flink.api.common.typeutils.base中的类
Serializer configuration snapshot for compatibility and format evolution.
BooleanValueSerializerSnapshot() - 类 的构造器org.apache.flink.api.common.typeutils.base.BooleanValueSerializer.BooleanValueSerializerSnapshot
 
Boundedness - org.apache.flink.api.connector.source中的枚举
The boundedness of a stream.
BoundedOutOfOrdernessWatermarks<T> - org.apache.flink.api.common.eventtime中的类
A WatermarkGenerator for situations where records are out of order, but you can place an upper bound on how far the events are out of order.
BoundedOutOfOrdernessWatermarks(Duration) - 类 的构造器org.apache.flink.api.common.eventtime.BoundedOutOfOrdernessWatermarks
Creates a new watermark generator with the given out-of-orderness bound.
broadcastInputs - 类 中的变量org.apache.flink.api.common.operators.AbstractUdfOperator
The extra inputs which parameterize the user function.
BroadcastState<K,V> - org.apache.flink.api.common.state中的接口
A type of state that can be created to store the state of a BroadcastStream.
BroadcastVariableInitializer<T,O> - org.apache.flink.api.common.functions中的接口
A broadcast variable initializer can be used to transform a broadcast variable into another format during initialization.
buffer - 类 中的变量org.apache.flink.core.memory.ByteArrayOutputStreamWithPos
 
BUFFER_DEBLOAT_ENABLED - 类 中的静态变量org.apache.flink.configuration.TaskManagerOptions
 
BUFFER_DEBLOAT_PERIOD - 类 中的静态变量org.apache.flink.configuration.TaskManagerOptions
The period between recalculation the relevant size of the buffer.
BUFFER_DEBLOAT_SAMPLES - 类 中的静态变量org.apache.flink.configuration.TaskManagerOptions
The number of samples requires for the buffer size adjustment.
BUFFER_DEBLOAT_TARGET - 类 中的静态变量org.apache.flink.configuration.TaskManagerOptions
The total time for which automated adjusted buffers should be fully consumed.
BUFFER_DEBLOAT_THRESHOLD_PERCENTAGES - 类 中的静态变量org.apache.flink.configuration.TaskManagerOptions
Difference between the new and the old buffer size for applying the new value(in percent).
BUFFER_TIMEOUT - 类 中的静态变量org.apache.flink.configuration.ExecutionOptions
 
bufferTimeout - 类 中的变量org.apache.flink.api.dag.Transformation
 
build() - 类 中的方法org.apache.flink.api.common.operators.ResourceSpec.Builder
 
build() - 类 中的方法org.apache.flink.api.common.operators.SlotSharingGroup.Builder
Build the SlotSharingGroup.
build() - 类 中的方法org.apache.flink.api.common.state.StateTtlConfig.Builder
 
build() - 类 中的方法org.apache.flink.api.java.tuple.builder.Tuple0Builder
 
build() - 类 中的方法org.apache.flink.api.java.tuple.builder.Tuple10Builder
 
build() - 类 中的方法org.apache.flink.api.java.tuple.builder.Tuple11Builder
 
build() - 类 中的方法org.apache.flink.api.java.tuple.builder.Tuple12Builder
 
build() - 类 中的方法org.apache.flink.api.java.tuple.builder.Tuple13Builder
 
build() - 类 中的方法org.apache.flink.api.java.tuple.builder.Tuple14Builder
 
build() - 类 中的方法org.apache.flink.api.java.tuple.builder.Tuple15Builder
 
build() - 类 中的方法org.apache.flink.api.java.tuple.builder.Tuple16Builder
 
build() - 类 中的方法org.apache.flink.api.java.tuple.builder.Tuple17Builder
 
build() - 类 中的方法org.apache.flink.api.java.tuple.builder.Tuple18Builder
 
build() - 类 中的方法org.apache.flink.api.java.tuple.builder.Tuple19Builder
 
build() - 类 中的方法org.apache.flink.api.java.tuple.builder.Tuple1Builder
 
build() - 类 中的方法org.apache.flink.api.java.tuple.builder.Tuple20Builder
 
build() - 类 中的方法org.apache.flink.api.java.tuple.builder.Tuple21Builder
 
build() - 类 中的方法org.apache.flink.api.java.tuple.builder.Tuple22Builder
 
build() - 类 中的方法org.apache.flink.api.java.tuple.builder.Tuple23Builder
 
build() - 类 中的方法org.apache.flink.api.java.tuple.builder.Tuple24Builder
 
build() - 类 中的方法org.apache.flink.api.java.tuple.builder.Tuple25Builder
 
build() - 类 中的方法org.apache.flink.api.java.tuple.builder.Tuple2Builder
 
build() - 类 中的方法org.apache.flink.api.java.tuple.builder.Tuple3Builder
 
build() - 类 中的方法org.apache.flink.api.java.tuple.builder.Tuple4Builder
 
build() - 类 中的方法org.apache.flink.api.java.tuple.builder.Tuple5Builder
 
build() - 类 中的方法org.apache.flink.api.java.tuple.builder.Tuple6Builder
 
build() - 类 中的方法org.apache.flink.api.java.tuple.builder.Tuple7Builder
 
build() - 类 中的方法org.apache.flink.api.java.tuple.builder.Tuple8Builder
 
build() - 类 中的方法org.apache.flink.api.java.tuple.builder.Tuple9Builder
 
build() - 类 中的方法org.apache.flink.configuration.description.Description.DescriptionBuilder
Creates description representation.
build() - 类 中的方法org.apache.flink.util.concurrent.ExecutorThreadFactory.Builder
 
Builder(Time) - 类 的构造器org.apache.flink.api.common.state.StateTtlConfig.Builder
 
builder() - 类 中的静态方法org.apache.flink.configuration.description.Description
 
Builder() - 类 的构造器org.apache.flink.util.concurrent.ExecutorThreadFactory.Builder
 
BulkIterationBase<T> - org.apache.flink.api.common.operators.base中的类
 
BulkIterationBase(UnaryOperatorInformation<T, T>) - 类 的构造器org.apache.flink.api.common.operators.base.BulkIterationBase
 
BulkIterationBase(UnaryOperatorInformation<T, T>, String) - 类 的构造器org.apache.flink.api.common.operators.base.BulkIterationBase
 
BulkIterationBase.PartialSolutionPlaceHolder<OT> - org.apache.flink.api.common.operators.base中的类
Specialized operator to use as a recognizable place-holder for the input to the step function when composing the nested data flow.
BulkIterationBase.TerminationCriterionAggregationConvergence - org.apache.flink.api.common.operators.base中的类
Convergence for the termination criterion is reached if no tuple is output at current iteration for the termination criterion branch
BulkIterationBase.TerminationCriterionAggregator - org.apache.flink.api.common.operators.base中的类
Aggregator that basically only adds 1 for every output tuple of the termination criterion branch
BulkIterationBase.TerminationCriterionMapper<X> - org.apache.flink.api.common.operators.base中的类
Special Mapper that is added before a termination criterion and is only a container for an special aggregator
BulkWriter<T> - org.apache.flink.api.common.serialization中的接口
An encoder that encodes data in a bulk fashion, encoding many records together at a time.
BulkWriter.Factory<T> - org.apache.flink.api.common.serialization中的接口
A factory that creates a BulkWriter.
BYTE - 类 中的静态变量org.apache.flink.api.common.typeinfo.Types
Returns type information for both a primitive byte and Byte.
BYTE_ARRAY_TYPE_INFO - 类 中的静态变量org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
 
BYTE_PRIMITIVE_ARRAY_TYPE_INFO - 类 中的静态变量org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
 
BYTE_TYPE_INFO - 类 中的静态变量org.apache.flink.api.common.typeinfo.BasicTypeInfo
 
BYTE_VALUE_TYPE_INFO - 类 中的静态变量org.apache.flink.api.java.typeutils.ValueTypeInfo
 
ByteArrayInputStreamWithPos - org.apache.flink.core.memory中的类
Un-synchronized stream similar to Java's ByteArrayInputStream that also exposes the current position.
ByteArrayInputStreamWithPos() - 类 的构造器org.apache.flink.core.memory.ByteArrayInputStreamWithPos
 
ByteArrayInputStreamWithPos(byte[]) - 类 的构造器org.apache.flink.core.memory.ByteArrayInputStreamWithPos
 
ByteArrayInputStreamWithPos(byte[], int, int) - 类 的构造器org.apache.flink.core.memory.ByteArrayInputStreamWithPos
 
ByteArrayOutputStreamWithPos - org.apache.flink.core.memory中的类
Un-synchronized stream similar to Java's ByteArrayOutputStream that also exposes the current position.
ByteArrayOutputStreamWithPos() - 类 的构造器org.apache.flink.core.memory.ByteArrayOutputStreamWithPos
 
ByteArrayOutputStreamWithPos(int) - 类 的构造器org.apache.flink.core.memory.ByteArrayOutputStreamWithPos
 
ByteComparator - org.apache.flink.api.common.typeutils.base中的类
 
ByteComparator(boolean) - 类 的构造器org.apache.flink.api.common.typeutils.base.ByteComparator
 
ByteParser - org.apache.flink.types.parser中的类
 
ByteParser() - 类 的构造器org.apache.flink.types.parser.ByteParser
 
BytePrimitiveArrayComparator - org.apache.flink.api.common.typeutils.base.array中的类
 
BytePrimitiveArrayComparator(boolean) - 类 的构造器org.apache.flink.api.common.typeutils.base.array.BytePrimitiveArrayComparator
 
BytePrimitiveArraySerializer - org.apache.flink.api.common.typeutils.base.array中的类
A serializer for byte arrays.
BytePrimitiveArraySerializer() - 类 的构造器org.apache.flink.api.common.typeutils.base.array.BytePrimitiveArraySerializer
 
BytePrimitiveArraySerializer.BytePrimitiveArraySerializerSnapshot - org.apache.flink.api.common.typeutils.base.array中的类
Serializer configuration snapshot for compatibility and format evolution.
BytePrimitiveArraySerializerSnapshot() - 类 的构造器org.apache.flink.api.common.typeutils.base.array.BytePrimitiveArraySerializer.BytePrimitiveArraySerializerSnapshot
 
ByteSerializer - org.apache.flink.api.common.typeutils.base中的类
Type serializer for Byte.
ByteSerializer() - 类 的构造器org.apache.flink.api.common.typeutils.base.ByteSerializer
 
ByteSerializer.ByteSerializerSnapshot - org.apache.flink.api.common.typeutils.base中的类
Serializer configuration snapshot for compatibility and format evolution.
ByteSerializerSnapshot() - 类 的构造器org.apache.flink.api.common.typeutils.base.ByteSerializer.ByteSerializerSnapshot
 
byteToHexString(byte[], int, int) - 类 中的静态方法org.apache.flink.util.StringUtils
Given an array of bytes it will convert the bytes to a hex string representation of the bytes.
byteToHexString(byte[]) - 类 中的静态方法org.apache.flink.util.StringUtils
Given an array of bytes it will convert the bytes to a hex string representation of the bytes.
ByteValue - org.apache.flink.types中的类
Boxed serializable and comparable byte type, representing the primitive type byte (signed 8 bit integer).
ByteValue() - 类 的构造器org.apache.flink.types.ByteValue
Initializes the encapsulated byte with 0.
ByteValue(byte) - 类 的构造器org.apache.flink.types.ByteValue
Initializes the encapsulated byte with the provided value.
ByteValueComparator - org.apache.flink.api.common.typeutils.base中的类
Specialized comparator for ByteValue based on CopyableValueComparator.
ByteValueComparator(boolean) - 类 的构造器org.apache.flink.api.common.typeutils.base.ByteValueComparator
 
ByteValueParser - org.apache.flink.types.parser中的类
Parses a decimal text field into a ByteValue.
ByteValueParser() - 类 的构造器org.apache.flink.types.parser.ByteValueParser
 
ByteValueSerializer - org.apache.flink.api.common.typeutils.base中的类
 
ByteValueSerializer() - 类 的构造器org.apache.flink.api.common.typeutils.base.ByteValueSerializer
 
ByteValueSerializer.ByteValueSerializerSnapshot - org.apache.flink.api.common.typeutils.base中的类
Serializer configuration snapshot for compatibility and format evolution.
ByteValueSerializerSnapshot() - 类 的构造器org.apache.flink.api.common.typeutils.base.ByteValueSerializer.ByteValueSerializerSnapshot
 
Bzip2InputStreamFactory - org.apache.flink.api.common.io.compression中的类
Factory for Bzip2 decompressors.
Bzip2InputStreamFactory() - 类 的构造器org.apache.flink.api.common.io.compression.Bzip2InputStreamFactory
 

C

CACHED_FILES - 类 中的静态变量org.apache.flink.configuration.PipelineOptions
 
cacheFile - 类 中的变量org.apache.flink.api.common.Plan
Hash map for files in the distributed cache: registered name to cache entry.
callAsync(Callable<T>, BiConsumer<T, Throwable>) - 接口 中的方法org.apache.flink.api.connector.source.SplitEnumeratorContext
Invoke the callable and handover the return value to the handler which will be executed by the source coordinator.
callAsync(Callable<T>, BiConsumer<T, Throwable>, long, long) - 接口 中的方法org.apache.flink.api.connector.source.SplitEnumeratorContext
Invoke the given callable periodically and handover the return value to the handler which will be executed by the source coordinator.
canBePrefixMap(ConfigOption<?>) - 类 中的静态方法org.apache.flink.configuration.ConfigurationUtils
Maps can be represented in two ways.
cancel() - 接口 中的方法org.apache.flink.core.execution.JobClient
Cancels the associated job.
cancel(boolean) - 类 中的方法org.apache.flink.util.concurrent.NeverCompleteFuture
 
CANCEL_ENABLE - 类 中的静态变量org.apache.flink.configuration.WebOptions
Config parameter indicating whether jobs can be cancel from the web-frontend.
canEqual(Object) - 类 中的方法org.apache.flink.api.common.ExecutionConfig
 
canEqual(Object) - 类 中的方法org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
 
canEqual(Object) - 类 中的方法org.apache.flink.api.common.typeinfo.BasicTypeInfo
 
canEqual(Object) - 类 中的方法org.apache.flink.api.common.typeinfo.LocalTimeTypeInfo
 
canEqual(Object) - 类 中的方法org.apache.flink.api.common.typeinfo.NothingTypeInfo
 
canEqual(Object) - 类 中的方法org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
 
canEqual(Object) - 类 中的方法org.apache.flink.api.common.typeinfo.SqlTimeTypeInfo
 
canEqual(Object) - 类 中的方法org.apache.flink.api.common.typeinfo.TypeInformation
Returns true if the given object can be equaled with this object.
canEqual(Object) - 类 中的方法org.apache.flink.api.common.typeutils.CompositeType
 
canEqual(Object) - 类 中的方法org.apache.flink.api.java.typeutils.EitherTypeInfo
 
canEqual(Object) - 类 中的方法org.apache.flink.api.java.typeutils.EnumTypeInfo
 
canEqual(Object) - 类 中的方法org.apache.flink.api.java.typeutils.GenericTypeInfo
 
canEqual(Object) - 类 中的方法org.apache.flink.api.java.typeutils.ListTypeInfo
 
canEqual(Object) - 类 中的方法org.apache.flink.api.java.typeutils.MapTypeInfo
 
canEqual(Object) - 类 中的方法org.apache.flink.api.java.typeutils.MissingTypeInfo
 
canEqual(Object) - 类 中的方法org.apache.flink.api.java.typeutils.MultisetTypeInfo
 
canEqual(Object) - 类 中的方法org.apache.flink.api.java.typeutils.ObjectArrayTypeInfo
 
canEqual(Object) - 类 中的方法org.apache.flink.api.java.typeutils.PojoTypeInfo
 
canEqual(Object) - 类 中的方法org.apache.flink.api.java.typeutils.RowTypeInfo
 
canEqual(Object) - 类 中的方法org.apache.flink.api.java.typeutils.TupleTypeInfo
 
canEqual(Object) - 类 中的方法org.apache.flink.api.java.typeutils.TupleTypeInfoBase
 
canEqual(Object) - 类 中的方法org.apache.flink.api.java.typeutils.ValueTypeInfo
 
canReadInt() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.NoFetchingInput
 
canReadLong() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.NoFetchingInput
 
CAPTURE_ASK_CALLSTACK - 类 中的静态变量org.apache.flink.configuration.AkkaOptions
Flag whether to capture call stacks for RPC ask calls.
CHAR - 类 中的静态变量org.apache.flink.api.common.typeinfo.Types
Returns type information for both a primitive char and Character.
CHAR_ARRAY_TYPE_INFO - 类 中的静态变量org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
 
CHAR_PRIMITIVE_ARRAY_TYPE_INFO - 类 中的静态变量org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
 
CHAR_TYPE_INFO - 类 中的静态变量org.apache.flink.api.common.typeinfo.BasicTypeInfo
 
CHAR_VALUE_TYPE_INFO - 类 中的静态变量org.apache.flink.api.java.typeutils.ValueTypeInfo
 
charAt(int) - 类 中的方法org.apache.flink.types.StringValue
 
CharComparator - org.apache.flink.api.common.typeutils.base中的类
 
CharComparator(boolean) - 类 的构造器org.apache.flink.api.common.typeutils.base.CharComparator
 
CharPrimitiveArrayComparator - org.apache.flink.api.common.typeutils.base.array中的类
 
CharPrimitiveArrayComparator(boolean) - 类 的构造器org.apache.flink.api.common.typeutils.base.array.CharPrimitiveArrayComparator
 
CharPrimitiveArraySerializer - org.apache.flink.api.common.typeutils.base.array中的类
A serializer for char arrays.
CharPrimitiveArraySerializer() - 类 的构造器org.apache.flink.api.common.typeutils.base.array.CharPrimitiveArraySerializer
 
CharPrimitiveArraySerializer.CharPrimitiveArraySerializerSnapshot - org.apache.flink.api.common.typeutils.base.array中的类
Serializer configuration snapshot for compatibility and format evolution.
CharPrimitiveArraySerializerSnapshot() - 类 的构造器org.apache.flink.api.common.typeutils.base.array.CharPrimitiveArraySerializer.CharPrimitiveArraySerializerSnapshot
 
CharSerializer - org.apache.flink.api.common.typeutils.base中的类
Type serializer for Character.
CharSerializer() - 类 的构造器org.apache.flink.api.common.typeutils.base.CharSerializer
 
CharSerializer.CharSerializerSnapshot - org.apache.flink.api.common.typeutils.base中的类
Serializer configuration snapshot for compatibility and format evolution.
CharSerializerSnapshot() - 类 的构造器org.apache.flink.api.common.typeutils.base.CharSerializer.CharSerializerSnapshot
 
CharValue - org.apache.flink.types中的类
Boxed serializable and comparable character type, representing the primitive type char.
CharValue() - 类 的构造器org.apache.flink.types.CharValue
Initializes the encapsulated char with 0.
CharValue(char) - 类 的构造器org.apache.flink.types.CharValue
Initializes the encapsulated char with the provided value.
CharValueComparator - org.apache.flink.api.common.typeutils.base中的类
Specialized comparator for CharValue based on CopyableValueComparator.
CharValueComparator(boolean) - 类 的构造器org.apache.flink.api.common.typeutils.base.CharValueComparator
 
CharValueSerializer - org.apache.flink.api.common.typeutils.base中的类
 
CharValueSerializer() - 类 的构造器org.apache.flink.api.common.typeutils.base.CharValueSerializer
 
CharValueSerializer.CharValueSerializerSnapshot - org.apache.flink.api.common.typeutils.base中的类
Serializer configuration snapshot for compatibility and format evolution.
CharValueSerializerSnapshot() - 类 的构造器org.apache.flink.api.common.typeutils.base.CharValueSerializer.CharValueSerializerSnapshot
 
CHECK_LEAKED_CLASSLOADER - 类 中的静态变量org.apache.flink.configuration.CoreOptions
 
CHECK_MULTIPLE_FREE_PROPERTY - 类 中的静态变量org.apache.flink.core.memory.MemorySegment
System property for activating multiple free segment check, for testing purpose.
checkAndCoSort(int[], Class<?>[]) - 类 中的静态方法org.apache.flink.api.common.io.GenericCsvInputFormat
 
checkAndExtractLambda(Function) - 类 中的静态方法org.apache.flink.api.java.typeutils.TypeExtractionUtils
Checks if the given function has been implemented using a Java 8 lambda.
checkArgument(boolean) - 类 中的静态方法org.apache.flink.util.Preconditions
Checks the given boolean condition, and throws an IllegalArgumentException if the condition is not met (evaluates to false).
checkArgument(boolean, Object) - 类 中的静态方法org.apache.flink.util.Preconditions
Checks the given boolean condition, and throws an IllegalArgumentException if the condition is not met (evaluates to false).
checkArgument(boolean, String, Object...) - 类 中的静态方法org.apache.flink.util.Preconditions
Checks the given boolean condition, and throws an IllegalArgumentException if the condition is not met (evaluates to false).
checkCompletedNormally(CompletableFuture<?>) - 类 中的静态方法org.apache.flink.util.Preconditions
Ensures that future has completed normally.
checked(Supplier<R>) - 接口 中的静态方法org.apache.flink.util.function.CheckedSupplier
 
checkedDownCast(long) - 类 中的静态方法org.apache.flink.util.MathUtils
Casts the given value to a 32 bit integer, if it can be safely done.
CheckedSupplier<R> - org.apache.flink.util.function中的接口
Similar to Supplier but can throw Exception.
checkElementIndex(int, int) - 类 中的静态方法org.apache.flink.util.Preconditions
Ensures that the given index is valid for an array, list or string of the given size.
checkElementIndex(int, int, String) - 类 中的静态方法org.apache.flink.util.Preconditions
Ensures that the given index is valid for an array, list or string of the given size.
checkExit(int) - 类 中的方法org.apache.flink.core.security.FlinkSecurityManager
 
checkForInstantiation(Class<?>) - 类 中的静态方法org.apache.flink.util.InstantiationUtil
Performs a standard check whether the class can be instantiated by Class#newInstance().
checkForInstantiationError(Class<?>) - 类 中的静态方法org.apache.flink.util.InstantiationUtil
 
checkForMonotonousOrder(int[], Class<?>[]) - 类 中的静态方法org.apache.flink.api.common.io.GenericCsvInputFormat
 
checkIfNullSupported(TypeSerializer<T>) - 类 中的静态方法org.apache.flink.api.java.typeutils.runtime.NullableSerializer
This method checks if serializer supports null value.
checkInterrupted(Throwable) - 类 中的静态方法org.apache.flink.util.ExceptionUtils
Checks whether the given exception is a InterruptedException and sets the interrupted flag accordingly.
checkJarFile(URL) - 类 中的静态方法org.apache.flink.util.JarUtils
 
checkNotNull(T) - 类 中的静态方法org.apache.flink.util.Preconditions
Ensures that the given object reference is not null.
checkNotNull(T, String) - 类 中的静态方法org.apache.flink.util.Preconditions
Ensures that the given object reference is not null.
checkNotNull(T, String, Object...) - 类 中的静态方法org.apache.flink.util.Preconditions
Ensures that the given object reference is not null.
checkPermission(Permission) - 类 中的方法org.apache.flink.core.security.FlinkSecurityManager
 
checkPermission(Permission, Object) - 类 中的方法org.apache.flink.core.security.FlinkSecurityManager
 
CHECKPOINT_STORAGE - 类 中的静态变量org.apache.flink.configuration.CheckpointingOptions
The checkpoint storage used to checkpoint state for recovery.
CheckpointableInputFormat<S extends InputSplit,T extends Serializable> - org.apache.flink.api.common.io中的接口
An interface that describes InputFormats that allow checkpointing/restoring their state.
CheckpointingOptions - org.apache.flink.configuration中的类
A collection of all configuration options that relate to checkpoints and savepoints.
CheckpointingOptions() - 类 的构造器org.apache.flink.configuration.CheckpointingOptions
 
CheckpointListener - org.apache.flink.api.common.state中的接口
This interface is typically only needed for transactional interaction with the "outside world", like committing external side effects on checkpoints.
CHECKPOINTS_DIRECTORY - 类 中的静态变量org.apache.flink.configuration.CheckpointingOptions
The default directory used for storing the data files and meta data of checkpoints in a Flink supported filesystem.
CHECKPOINTS_DIRECTORY_KEY - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
CHECKPOINTS_HISTORY_SIZE - 类 中的静态变量org.apache.flink.configuration.WebOptions
Config parameter defining the number of checkpoints to remember for recent history.
checkState(boolean) - 类 中的静态方法org.apache.flink.util.Preconditions
Checks the given boolean condition, and throws an IllegalStateException if the condition is not met (evaluates to false).
checkState(boolean, Object) - 类 中的静态方法org.apache.flink.util.Preconditions
Checks the given boolean condition, and throws an IllegalStateException if the condition is not met (evaluates to false).
checkState(boolean, String, Object...) - 类 中的静态方法org.apache.flink.util.Preconditions
Checks the given boolean condition, and throws an IllegalStateException if the condition is not met (evaluates to false).
checkStateAndGet(CompletableFuture<T>) - 类 中的静态方法org.apache.flink.util.concurrent.FutureUtils
Perform check state that future has completed normally and return the result.
ChildFirstClassLoader - org.apache.flink.util中的类
A variant of the URLClassLoader that first loads from the URLs and only after that from the parent.
ChildFirstClassLoader(URL[], ClassLoader, String[], Consumer<Throwable>) - 类 的构造器org.apache.flink.util.ChildFirstClassLoader
 
CLASS_FILE_EXTENSION - 类 中的静态变量org.apache.flink.util.FileUtils
 
classLoader - 类 中的变量org.apache.flink.util.InstantiationUtil.ClassLoaderObjectInputStream
 
CLASSLOADER_RESOLVE_ORDER - 类 中的静态变量org.apache.flink.configuration.CoreOptions
Defines the class resolution strategy when loading classes from user code, meaning whether to first check the user code jar ("child-first") or the application classpath ("parent-first") The default settings indicate to load classes first from the user code jar, which means that user code jars can include and load different dependencies than Flink uses (transitively).
ClassLoaderObjectInputStream(InputStream, ClassLoader) - 类 的构造器org.apache.flink.util.InstantiationUtil.ClassLoaderObjectInputStream
 
CLASSPATHS - 类 中的静态变量org.apache.flink.configuration.PipelineOptions
A list of URLs that are added to the classpath of each user code classloader of the program.
clean(Object, ExecutionConfig.ClosureCleanerLevel, boolean) - 类 中的静态方法org.apache.flink.api.java.ClosureCleaner
Tries to clean the closure of the given object, if the object is a non-static inner class.
cleanDirectory(File) - 类 中的静态方法org.apache.flink.util.FileUtils
Removes all files contained within a directory, without removing the directory itself.
cleanup(Logger, AutoCloseable...) - 类 中的静态方法org.apache.flink.util.IOUtils
Close the AutoCloseable objects and ignore any Exception or null pointers.
CLEANUP_INTERVAL - 类 中的静态变量org.apache.flink.configuration.BlobServerOptions
Cleanup interval of the blob caches at the task managers (in seconds).
cleanupFullSnapshot() - 类 中的方法org.apache.flink.api.common.state.StateTtlConfig.Builder
Cleanup expired state in full snapshot on checkpoint.
cleanupIncrementally(int, boolean) - 类 中的方法org.apache.flink.api.common.state.StateTtlConfig.Builder
Cleanup expired state incrementally cleanup local state.
cleanupInRocksdbCompactFilter(long) - 类 中的方法org.apache.flink.api.common.state.StateTtlConfig.Builder
Cleanup expired state while Rocksdb compaction is running.
cleanupRecoverableState(RecoverableWriter.ResumeRecoverable) - 类 中的方法org.apache.flink.core.fs.local.LocalRecoverableWriter
 
cleanupRecoverableState(RecoverableWriter.ResumeRecoverable) - 接口 中的方法org.apache.flink.core.fs.RecoverableWriter
Frees up any resources that were previously occupied in order to be able to recover from a (potential) failure.
CleanupWhenUnsuccessful - org.apache.flink.api.common.io中的接口
OutputFormats may implement this interface to run a cleanup hook when the execution is not successful.
clear() - 接口 中的方法org.apache.flink.api.common.state.State
Removes the value mapped under the current key.
clear() - 类 中的方法org.apache.flink.core.memory.DataOutputSerializer
 
clear() - 类 中的方法org.apache.flink.types.ListValue
 
clear() - 类 中的方法org.apache.flink.types.MapValue
 
clear() - 类 中的方法org.apache.flink.types.Record
Clears the record.
clear() - 类 中的方法org.apache.flink.types.Row
Clears all fields of this row.
clear() - 类 中的方法org.apache.flink.util.UnionIterator
 
clearAllBroadcastVariables() - 类 中的方法org.apache.flink.api.common.functions.util.RuntimeUDFContext
 
clearBroadcastVariable(String) - 类 中的方法org.apache.flink.api.common.functions.util.RuntimeUDFContext
 
clearFirstInput() - 类 中的方法org.apache.flink.api.common.operators.DualInputOperator
Clears this operator's first input.
clearInputs() - 类 中的方法org.apache.flink.api.common.operators.SingleInputOperator
Removes all inputs.
clearSecondInput() - 类 中的方法org.apache.flink.api.common.operators.DualInputOperator
Clears this operator's second input.
clearUniqueFields() - 类 中的方法org.apache.flink.api.common.operators.CompilerHints
 
CLIENT_CONNECT_TIMEOUT_SECONDS - 类 中的静态变量org.apache.flink.configuration.NettyShuffleEnvironmentOptions
 
CLIENT_MAX_CONTENT_LENGTH - 类 中的静态变量org.apache.flink.configuration.RestOptions
The maximum content length that the client will handle.
CLIENT_NETWORK_THREADS - 类 中的静态变量org.apache.flink.configuration.QueryableStateOptions
Number of network (event loop) threads for the KvState client (0 => Use number of available cores).
CLIENT_SOCKET_WORKER_POOL_SIZE_FACTOR - 类 中的静态变量org.apache.flink.configuration.AkkaOptions
 
CLIENT_SOCKET_WORKER_POOL_SIZE_MAX - 类 中的静态变量org.apache.flink.configuration.AkkaOptions
 
CLIENT_SOCKET_WORKER_POOL_SIZE_MIN - 类 中的静态变量org.apache.flink.configuration.AkkaOptions
 
CLIENT_TIMEOUT - 类 中的静态变量org.apache.flink.configuration.AkkaOptions
已过时。
Use the ClientOptions.CLIENT_TIMEOUT instead.
Clock - org.apache.flink.util.clock中的类
A clock that gives access to time.
Clock() - 类 的构造器org.apache.flink.util.clock.Clock
 
clone() - 接口 中的方法org.apache.flink.api.common.accumulators.Accumulator
Duplicates the accumulator.
clone() - 类 中的方法org.apache.flink.api.common.accumulators.AverageAccumulator
 
clone() - 类 中的方法org.apache.flink.api.common.accumulators.DoubleCounter
 
clone() - 类 中的方法org.apache.flink.api.common.accumulators.DoubleMaximum
 
clone() - 类 中的方法org.apache.flink.api.common.accumulators.DoubleMinimum
 
clone() - 类 中的方法org.apache.flink.api.common.accumulators.Histogram
 
clone() - 类 中的方法org.apache.flink.api.common.accumulators.IntCounter
 
clone() - 类 中的方法org.apache.flink.api.common.accumulators.IntMaximum
 
clone() - 类 中的方法org.apache.flink.api.common.accumulators.IntMinimum
 
clone() - 类 中的方法org.apache.flink.api.common.accumulators.ListAccumulator
 
clone() - 类 中的方法org.apache.flink.api.common.accumulators.LongCounter
 
clone() - 类 中的方法org.apache.flink.api.common.accumulators.LongMaximum
 
clone() - 类 中的方法org.apache.flink.api.common.accumulators.LongMinimum
 
clone() - 类 中的方法org.apache.flink.api.common.accumulators.SerializedListAccumulator
 
clone() - 类 中的方法org.apache.flink.api.common.operators.Ordering
 
clone() - 类 中的方法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() - 类 中的方法org.apache.flink.configuration.Configuration
 
clone() - 类 中的方法org.apache.flink.configuration.DelegatingConfiguration
 
clone(T) - 类 中的静态方法org.apache.flink.util.InstantiationUtil
Clones the given serializable object using Java serialization.
clone(T, ClassLoader) - 类 中的静态方法org.apache.flink.util.InstantiationUtil
Clones the given serializable object using Java serialization, using the given classloader to resolve the cloned classes.
close() - 类 中的方法org.apache.flink.api.common.functions.AbstractRichFunction
 
close() - 接口 中的方法org.apache.flink.api.common.functions.RichFunction
Tear-down method for the user code.
close() - 类 中的方法org.apache.flink.api.common.functions.util.CopyingListCollector
 
close() - 类 中的方法org.apache.flink.api.common.functions.util.ListCollector
 
close() - 类 中的方法org.apache.flink.api.common.io.BinaryOutputFormat.BlockBasedOutput
 
close() - 类 中的方法org.apache.flink.api.common.io.BinaryOutputFormat
 
close() - 类 中的方法org.apache.flink.api.common.io.DelimitedInputFormat
Closes the input by releasing all buffers and closing the file input stream.
close() - 类 中的方法org.apache.flink.api.common.io.FileInputFormat
Closes the file input stream of the input format.
close() - 类 中的方法org.apache.flink.api.common.io.FileOutputFormat
 
close() - 类 中的方法org.apache.flink.api.common.io.GenericCsvInputFormat
 
close() - 类 中的方法org.apache.flink.api.common.io.GenericInputFormat
 
close() - 接口 中的方法org.apache.flink.api.common.io.InputFormat
Method that marks the end of the life-cycle of an input split.
close() - 类 中的方法org.apache.flink.api.common.io.InputStreamFSInputWrapper
 
close() - 接口 中的方法org.apache.flink.api.common.io.OutputFormat
Method that marks the end of the life-cycle of parallel output instance.
close() - 接口 中的方法org.apache.flink.api.common.io.ratelimiting.FlinkConnectorRateLimiter
 
close() - 类 中的方法org.apache.flink.api.common.io.ratelimiting.GuavaFlinkConnectorRateLimiter
 
close() - 类 中的方法org.apache.flink.api.common.io.ReplicatingInputFormat
 
close() - 类 中的方法org.apache.flink.api.connector.source.lib.util.IteratorSourceEnumerator
 
close() - 类 中的方法org.apache.flink.api.connector.source.lib.util.IteratorSourceReader
 
close() - 接口 中的方法org.apache.flink.api.connector.source.SplitEnumerator
Called to close the enumerator, in case it holds on to any resources, like threads or network connections.
close() - 类 中的方法org.apache.flink.core.fs.ClosingFSDataInputStream
 
close() - 类 中的方法org.apache.flink.core.fs.ClosingFSDataOutputStream
 
close() - 类 中的方法org.apache.flink.core.fs.FSDataInputStreamWrapper
 
close() - 类 中的方法org.apache.flink.core.fs.FSDataOutputStream
Closes the output stream.
close() - 类 中的方法org.apache.flink.core.fs.FSDataOutputStreamWrapper
 
close() - 类 中的方法org.apache.flink.core.fs.local.LocalDataInputStream
 
close() - 类 中的方法org.apache.flink.core.fs.local.LocalDataOutputStream
 
close() - 类 中的方法org.apache.flink.core.fs.RecoverableFsDataOutputStream
Closes this stream.
close() - 类 中的方法org.apache.flink.core.fs.SafetyNetCloseableRegistry
 
close() - 类 中的方法org.apache.flink.core.memory.ByteArrayOutputStreamWithPos
 
close() - 类 中的方法org.apache.flink.core.memory.MemorySegmentInputStreamWithPos
 
close() - 类 中的方法org.apache.flink.core.plugin.PluginLoader
 
close() - 类 中的方法org.apache.flink.util.AbstractCloseableRegistry
 
close() - 接口 中的方法org.apache.flink.util.AutoCloseableAsync
 
close() - 类 中的方法org.apache.flink.util.CloseableIterable.Empty
 
close() - 类 中的方法org.apache.flink.util.CloseableIterator.IteratorAdapter
 
close() - 接口 中的方法org.apache.flink.util.Collector
Closes the collector.
close() - 类 中的方法org.apache.flink.util.ResourceGuard
Closed the resource guard.
close() - 类 中的方法org.apache.flink.util.ResourceGuard.Lease
 
close() - 类 中的方法org.apache.flink.util.TemporaryClassLoaderContext
 
CloseableIterable<T> - org.apache.flink.util中的接口
This interface represents an iterable that is also closeable.
CloseableIterable.Empty<T> - org.apache.flink.util中的类
Empty iterator.
CloseableIterator<T> - org.apache.flink.util中的接口
This interface represents an Iterator that is also AutoCloseable.
CloseableIterator.IteratorAdapter<E> - org.apache.flink.util中的类
Adapter from Iterator to CloseableIterator.
CloseableRegistry - org.apache.flink.core.fs中的类
This class allows to register instances of Closeable, which are all closed if this registry is closed.
CloseableRegistry() - 类 的构造器org.apache.flink.core.fs.CloseableRegistry
 
closeableToRef - 类 中的变量org.apache.flink.util.AbstractCloseableRegistry
Map from tracked Closeables to some associated meta data.
closeAll(AutoCloseable...) - 类 中的静态方法org.apache.flink.util.IOUtils
 
closeAll(Iterable<? extends AutoCloseable>) - 类 中的静态方法org.apache.flink.util.IOUtils
Closes all AutoCloseable objects in the parameter, suppressing exceptions.
closeAllQuietly(AutoCloseable...) - 类 中的静态方法org.apache.flink.util.IOUtils
Closes all elements in the iterable with closeQuietly().
closeAllQuietly(Iterable<? extends AutoCloseable>) - 类 中的静态方法org.apache.flink.util.IOUtils
Closes all elements in the iterable with closeQuietly().
closeAsync() - 接口 中的方法org.apache.flink.util.AutoCloseableAsync
Trigger the closing of the resource and return the corresponding close future.
closed - 类 中的变量org.apache.flink.core.fs.RefCountedFile
 
closeForCommit() - 类 中的方法org.apache.flink.core.fs.RecoverableFsDataOutputStream
Closes the stream, ensuring persistence of all data (similar to FSDataOutputStream.sync()).
closeFunction(Function) - 类 中的静态方法org.apache.flink.api.common.functions.util.FunctionUtils
 
closeInputFormat() - 类 中的方法org.apache.flink.api.common.io.ReplicatingInputFormat
 
closeInputFormat() - 类 中的方法org.apache.flink.api.common.io.RichInputFormat
Closes this InputFormat instance.
closeInterruptibly() - 类 中的方法org.apache.flink.util.ResourceGuard
 
closeQuietly(AutoCloseable) - 类 中的静态方法org.apache.flink.util.IOUtils
Closes the given AutoCloseable.
closeSafetyNetAndGuardedResourcesForThread() - 类 中的静态方法org.apache.flink.core.fs.FileSystemSafetyNet
Closes the safety net for a thread.
closeSocket(Socket) - 类 中的静态方法org.apache.flink.util.IOUtils
Closes the socket ignoring IOException.
closeStream(Closeable) - 类 中的静态方法org.apache.flink.util.IOUtils
Closes the stream ignoring IOException.
closeUninterruptibly() - 类 中的方法org.apache.flink.util.ResourceGuard
If the current thread is interrupted while waiting for the close method to complete, then it will continue to wait.
ClosingFSDataInputStream - org.apache.flink.core.fs中的类
This class is a WrappingProxy for FSDataInputStream that is used to implement a safety net against unclosed streams.
ClosingFSDataOutputStream - org.apache.flink.core.fs中的类
This class is a WrappingProxy for FSDataOutputStream that is used to implement a safety net against unclosed streams.
ClosingFSDataOutputStream(FSDataOutputStream, SafetyNetCloseableRegistry) - 类 的构造器org.apache.flink.core.fs.ClosingFSDataOutputStream
 
CLOSURE_CLEANER_LEVEL - 类 中的静态变量org.apache.flink.configuration.PipelineOptions
 
ClosureCleaner - org.apache.flink.api.java中的类
The closure cleaner is a utility that tries to truncate the closure (enclosing instance) of non-static inner classes (created for inline transformation functions).
ClosureCleaner() - 类 的构造器org.apache.flink.api.java.ClosureCleaner
 
CLUSTER_IO_EXECUTOR_POOL_SIZE - 类 中的静态变量org.apache.flink.configuration.ClusterOptions
 
CLUSTER_SERVICES_SHUTDOWN_TIMEOUT - 类 中的静态变量org.apache.flink.configuration.ClusterOptions
 
ClusterOptions - org.apache.flink.configuration中的类
Options which control the cluster behaviour.
ClusterOptions() - 类 的构造器org.apache.flink.configuration.ClusterOptions
 
ClusterOptions.UncaughtExceptionHandleMode - org.apache.flink.configuration中的枚举
 
ClusterOptions.UserSystemExitMode - org.apache.flink.configuration中的枚举
The mode of how to handle user code attempting to exit JVM.
code(String) - 类 中的静态方法org.apache.flink.configuration.description.TextElement
Creates a block of text formatted as code.
CodeAnalysisMode - org.apache.flink.api.common中的枚举
已过时。
The code analysis code has been removed and this enum has no effect. NOTE It can not be removed from the codebase for now, because it had been serialized as part of the ExecutionConfig which in turn had been serialized as part of the PojoSerializer.

This class can be removed when we drop support for pre 1.8 serializer snapshots that contained java serialized serializers (TypeSerializerConfigSnapshot).

coGroup(Iterable<IN1>, Iterable<IN2>, Collector<O>) - 接口 中的方法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>) - 类 中的方法org.apache.flink.api.common.functions.RichCoGroupFunction
 
CoGroupFunction<IN1,IN2,O> - org.apache.flink.api.common.functions中的接口
The interface for CoGroup functions.
CoGroupOperatorBase<IN1,IN2,OUT,FT extends CoGroupFunction<IN1,IN2,OUT>> - org.apache.flink.api.common.operators.base中的类
 
CoGroupOperatorBase(UserCodeWrapper<FT>, BinaryOperatorInformation<IN1, IN2, OUT>, int[], int[], String) - 类 的构造器org.apache.flink.api.common.operators.base.CoGroupOperatorBase
 
CoGroupOperatorBase(FT, BinaryOperatorInformation<IN1, IN2, OUT>, int[], int[], String) - 类 的构造器org.apache.flink.api.common.operators.base.CoGroupOperatorBase
 
CoGroupOperatorBase(Class<? extends FT>, BinaryOperatorInformation<IN1, IN2, OUT>, int[], int[], String) - 类 的构造器org.apache.flink.api.common.operators.base.CoGroupOperatorBase
 
CoGroupRawOperatorBase<IN1,IN2,OUT,FT extends CoGroupFunction<IN1,IN2,OUT>> - org.apache.flink.api.common.operators.base中的类
 
CoGroupRawOperatorBase(UserCodeWrapper<FT>, BinaryOperatorInformation<IN1, IN2, OUT>, int[], int[], String) - 类 的构造器org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase
 
CoGroupRawOperatorBase(FT, BinaryOperatorInformation<IN1, IN2, OUT>, int[], int[], String) - 类 的构造器org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase
 
CoGroupRawOperatorBase(Class<? extends FT>, BinaryOperatorInformation<IN1, IN2, OUT>, int[], int[], String) - 类 的构造器org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase
 
CoGroupRawOperatorBase.SimpleListIterable<IN> - org.apache.flink.api.common.operators.base中的类
 
CoGroupRawOperatorBase.SimpleListIterable.SimpleListIterator<IN> - org.apache.flink.api.common.operators.base中的类
 
collect(T) - 类 中的方法org.apache.flink.api.common.functions.util.CopyingListCollector
 
collect(T) - 类 中的方法org.apache.flink.api.common.functions.util.ListCollector
 
collect(T) - 接口 中的方法org.apache.flink.api.connector.source.ReaderOutput
Emit a record without a timestamp.
collect(T, long) - 接口 中的方法org.apache.flink.api.connector.source.ReaderOutput
Emit a record with a timestamp.
collect(T) - 接口 中的方法org.apache.flink.api.connector.source.SourceOutput
Emit a record without a timestamp.
collect(T, long) - 接口 中的方法org.apache.flink.api.connector.source.SourceOutput
Emit a record with a timestamp.
collect(T) - 接口 中的方法org.apache.flink.util.Collector
Emits a record.
collection - 类 中的变量org.apache.flink.api.common.operators.util.FieldSet
 
CollectionExecutor - org.apache.flink.api.common.operators中的类
Execution utility for serial, local, collection-based executions of Flink programs.
CollectionExecutor(ExecutionConfig) - 类 的构造器org.apache.flink.api.common.operators.CollectionExecutor
 
CollectionSerializerConfigSnapshot<C extends Collection<T>,T> - org.apache.flink.api.common.typeutils.base中的类
已过时。
this snapshot class should no longer be used by any serializers as their snapshot.
CollectionSerializerConfigSnapshot() - 类 的构造器org.apache.flink.api.common.typeutils.base.CollectionSerializerConfigSnapshot
已过时。
This empty nullary constructor is required for deserializing the configuration.
CollectionSerializerConfigSnapshot(TypeSerializer<T>) - 类 的构造器org.apache.flink.api.common.typeutils.base.CollectionSerializerConfigSnapshot
已过时。
 
CollectionUtil - org.apache.flink.util中的类
Simple utility to work with Java collections.
Collector<T> - org.apache.flink.util中的接口
Collects a record and forwards it.
combine(Iterable<IN>) - 接口 中的方法org.apache.flink.api.common.functions.CombineFunction
The combine method, called (potentially multiple timed) with subgroups of elements.
combine(Iterable<IN>, Collector<OUT>) - 接口 中的方法org.apache.flink.api.common.functions.GroupCombineFunction
The combine method, called (potentially multiple timed) with subgroups of elements.
combine(Iterable<IN>, Collector<OUT>) - 类 中的方法org.apache.flink.api.common.functions.RichGroupCombineFunction
 
combine(List<CommT>) - 接口 中的方法org.apache.flink.api.connector.sink.GlobalCommitter
Compute an aggregated committable from a list of committables.
combineAll(Collection<? extends CompletableFuture<? extends T>>) - 类 中的静态方法org.apache.flink.util.concurrent.FutureUtils
Creates a future that is complete once multiple other futures completed.
CombineFunction<IN,OUT> - org.apache.flink.api.common.functions中的接口
Generic interface used for combine functions ("combiners").
commentCount - 类 中的变量org.apache.flink.api.common.io.GenericCsvInputFormat
 
commentPrefix - 类 中的变量org.apache.flink.api.common.io.GenericCsvInputFormat
 
commit(List<CommT>) - 接口 中的方法org.apache.flink.api.connector.sink.Committer
Commit the given list of CommT.
commit(List<GlobalCommT>) - 接口 中的方法org.apache.flink.api.connector.sink.GlobalCommitter
Commit the given list of GlobalCommT.
commit() - 接口 中的方法org.apache.flink.core.fs.RecoverableFsDataOutputStream.Committer
Commits the file, making it visible.
commitAfterRecovery() - 接口 中的方法org.apache.flink.core.fs.RecoverableFsDataOutputStream.Committer
Commits the file, making it visible.
Committer<CommT> - org.apache.flink.api.connector.sink中的接口
The Committer is responsible for committing the data staged by the sink.
CommonRangeBoundaries<T> - org.apache.flink.api.common.distributions中的类
 
CommonRangeBoundaries(TypeComparator<T>, Object[][]) - 类 的构造器org.apache.flink.api.common.distributions.CommonRangeBoundaries
 
comparator - 类 中的变量org.apache.flink.api.common.typeutils.base.array.PrimitiveArrayComparator
 
comparators - 类 中的变量org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
comparators for the key fields, in the same order as the key fields
compare(boolean[], boolean[]) - 类 中的方法org.apache.flink.api.common.typeutils.base.array.BooleanPrimitiveArrayComparator
 
compare(byte[], byte[]) - 类 中的方法org.apache.flink.api.common.typeutils.base.array.BytePrimitiveArrayComparator
 
compare(char[], char[]) - 类 中的方法org.apache.flink.api.common.typeutils.base.array.CharPrimitiveArrayComparator
 
compare(double[], double[]) - 类 中的方法org.apache.flink.api.common.typeutils.base.array.DoublePrimitiveArrayComparator
 
compare(float[], float[]) - 类 中的方法org.apache.flink.api.common.typeutils.base.array.FloatPrimitiveArrayComparator
 
compare(int[], int[]) - 类 中的方法org.apache.flink.api.common.typeutils.base.array.IntPrimitiveArrayComparator
 
compare(long[], long[]) - 类 中的方法org.apache.flink.api.common.typeutils.base.array.LongPrimitiveArrayComparator
 
compare(short[], short[]) - 类 中的方法org.apache.flink.api.common.typeutils.base.array.ShortPrimitiveArrayComparator
 
compare(T, T) - 类 中的方法org.apache.flink.api.common.typeutils.base.BasicTypeComparator
 
compare(BooleanValue, BooleanValue) - 类 中的方法org.apache.flink.api.common.typeutils.base.BooleanValueComparator
 
compare(ByteValue, ByteValue) - 类 中的方法org.apache.flink.api.common.typeutils.base.ByteValueComparator
 
compare(CharValue, CharValue) - 类 中的方法org.apache.flink.api.common.typeutils.base.CharValueComparator
 
compare(DoubleValue, DoubleValue) - 类 中的方法org.apache.flink.api.common.typeutils.base.DoubleValueComparator
 
compare(FloatValue, FloatValue) - 类 中的方法org.apache.flink.api.common.typeutils.base.FloatValueComparator
 
compare(IntValue, IntValue) - 类 中的方法org.apache.flink.api.common.typeutils.base.IntValueComparator
 
compare(LocalDate, LocalDate) - 类 中的方法org.apache.flink.api.common.typeutils.base.LocalDateComparator
 
compare(LocalDateTime, LocalDateTime) - 类 中的方法org.apache.flink.api.common.typeutils.base.LocalDateTimeComparator
 
compare(LongValue, LongValue) - 类 中的方法org.apache.flink.api.common.typeutils.base.LongValueComparator
 
compare(NullValue, NullValue) - 类 中的方法org.apache.flink.api.common.typeutils.base.NullValueComparator
 
compare(ShortValue, ShortValue) - 类 中的方法org.apache.flink.api.common.typeutils.base.ShortValueComparator
 
compare(StringValue, StringValue) - 类 中的方法org.apache.flink.api.common.typeutils.base.StringValueComparator
 
compare(T, T) - 类 中的方法org.apache.flink.api.common.typeutils.TypeComparator
Compares two records in object form.
compare(T, T) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.CopyableValueComparator
 
compare(T, T) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.GenericTypeComparator
 
compare(T, T) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.NullAwareComparator
 
compare(T, T) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.PojoComparator
 
compare(Row, Row) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.RowComparator
 
compare(T, T) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.TupleComparator
 
compare(T, T) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.ValueComparator
 
compare(MemorySegment, int, int, int) - 类 中的方法org.apache.flink.core.memory.MemorySegment
Compares two memory segment regions.
compare(MemorySegment, int, int, int, int) - 类 中的方法org.apache.flink.core.memory.MemorySegment
Compares two memory segment regions with different length.
compareAccumulatorTypes(Object, Class<? extends Accumulator>, Class<? extends Accumulator>) - 类 中的静态方法org.apache.flink.api.common.accumulators.AccumulatorHelper
Compare both classes and throw UnsupportedOperationException if they differ.
compareAgainstReference(Comparable[]) - 类 中的方法org.apache.flink.api.common.typeutils.TypeComparator
 
compareRows(List<Row>, List<Row>) - 类 中的静态方法org.apache.flink.types.RowUtils
Compares two Lists of Row for deep equality.
compareRows(List<Row>, List<Row>, boolean) - 类 中的静态方法org.apache.flink.types.RowUtils
Compares two Lists of Row for deep equality.
compareSerialized(DataInputView, DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.array.PrimitiveArrayComparator
 
compareSerialized(DataInputView, DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.BigDecComparator
 
compareSerialized(DataInputView, DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.BigIntComparator
 
compareSerialized(DataInputView, DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.BooleanComparator
 
compareSerialized(DataInputView, DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.BooleanValueComparator
 
compareSerialized(DataInputView, DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.ByteComparator
 
compareSerialized(DataInputView, DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.ByteValueComparator
 
compareSerialized(DataInputView, DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.CharComparator
 
compareSerialized(DataInputView, DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.CharValueComparator
 
compareSerialized(DataInputView, DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.DateComparator
 
compareSerialized(DataInputView, DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.DoubleComparator
 
compareSerialized(DataInputView, DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.DoubleValueComparator
 
compareSerialized(DataInputView, DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.EnumComparator
 
compareSerialized(DataInputView, DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.FloatComparator
 
compareSerialized(DataInputView, DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.FloatValueComparator
 
compareSerialized(DataInputView, DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.InstantComparator
 
compareSerialized(DataInputView, DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.IntComparator
 
compareSerialized(DataInputView, DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.IntValueComparator
 
compareSerialized(DataInputView, DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.LocalDateComparator
 
compareSerialized(DataInputView, DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.LocalDateTimeComparator
 
compareSerialized(DataInputView, DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.LocalTimeComparator
 
compareSerialized(DataInputView, DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.LongComparator
 
compareSerialized(DataInputView, DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.LongValueComparator
 
compareSerialized(DataInputView, DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.NullValueComparator
 
compareSerialized(DataInputView, DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.ShortComparator
 
compareSerialized(DataInputView, DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.ShortValueComparator
 
compareSerialized(DataInputView, DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.SqlTimestampComparator
 
compareSerialized(DataInputView, DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.StringComparator
 
compareSerialized(DataInputView, DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.StringValueComparator
 
compareSerialized(DataInputView, DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.TypeComparator
Compares two records in serialized form.
compareSerialized(DataInputView, DataInputView) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.CopyableValueComparator
 
compareSerialized(DataInputView, DataInputView) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.GenericTypeComparator
 
compareSerialized(DataInputView, DataInputView) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.NullAwareComparator
 
compareSerialized(DataInputView, DataInputView) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.PojoComparator
 
compareSerialized(DataInputView, DataInputView) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.RowComparator
 
compareSerialized(DataInputView, DataInputView) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
 
compareSerialized(DataInputView, DataInputView) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.ValueComparator
 
compareSerializedDate(DataInputView, DataInputView, boolean) - 类 中的静态方法org.apache.flink.api.common.typeutils.base.DateComparator
 
compareSerializedLocalDate(DataInputView, DataInputView, boolean) - 类 中的静态方法org.apache.flink.api.common.typeutils.base.LocalDateComparator
 
compareSerializedLocalTime(DataInputView, DataInputView, boolean) - 类 中的静态方法org.apache.flink.api.common.typeutils.base.LocalTimeComparator
 
compareTo(Resource) - 类 中的方法org.apache.flink.api.common.resources.Resource
 
compareTo(MemorySize) - 类 中的方法org.apache.flink.configuration.MemorySize
 
compareTo(BlockLocation) - 类 中的方法org.apache.flink.core.fs.local.LocalBlockLocation
 
compareTo(Object) - 类 中的方法org.apache.flink.core.fs.Path
 
compareTo(BooleanValue) - 类 中的方法org.apache.flink.types.BooleanValue
 
compareTo(ByteValue) - 类 中的方法org.apache.flink.types.ByteValue
 
compareTo(CharValue) - 类 中的方法org.apache.flink.types.CharValue
 
compareTo(DoubleValue) - 类 中的方法org.apache.flink.types.DoubleValue
 
compareTo(FloatValue) - 类 中的方法org.apache.flink.types.FloatValue
 
compareTo(IntValue) - 类 中的方法org.apache.flink.types.IntValue
 
compareTo(LongValue) - 类 中的方法org.apache.flink.types.LongValue
 
compareTo(NullValue) - 类 中的方法org.apache.flink.types.NullValue
 
compareTo(ShortValue) - 类 中的方法org.apache.flink.types.ShortValue
 
compareTo(StringValue) - 类 中的方法org.apache.flink.types.StringValue
 
compareTo(AbstractID) - 类 中的方法org.apache.flink.util.AbstractID
 
compareTo(Delayed) - 类 中的方法org.apache.flink.util.concurrent.NeverCompleteFuture
 
compareToReference(TypeComparator<T>) - 类 中的方法org.apache.flink.api.common.typeutils.base.array.PrimitiveArrayComparator
 
compareToReference(TypeComparator<T>) - 类 中的方法org.apache.flink.api.common.typeutils.base.BasicTypeComparator
 
compareToReference(TypeComparator<BooleanValue>) - 类 中的方法org.apache.flink.api.common.typeutils.base.BooleanValueComparator
 
compareToReference(TypeComparator<ByteValue>) - 类 中的方法org.apache.flink.api.common.typeutils.base.ByteValueComparator
 
compareToReference(TypeComparator<CharValue>) - 类 中的方法org.apache.flink.api.common.typeutils.base.CharValueComparator
 
compareToReference(TypeComparator<DoubleValue>) - 类 中的方法org.apache.flink.api.common.typeutils.base.DoubleValueComparator
 
compareToReference(TypeComparator<FloatValue>) - 类 中的方法org.apache.flink.api.common.typeutils.base.FloatValueComparator
 
compareToReference(TypeComparator<IntValue>) - 类 中的方法org.apache.flink.api.common.typeutils.base.IntValueComparator
 
compareToReference(TypeComparator<LocalDate>) - 类 中的方法org.apache.flink.api.common.typeutils.base.LocalDateComparator
 
compareToReference(TypeComparator<LocalDateTime>) - 类 中的方法org.apache.flink.api.common.typeutils.base.LocalDateTimeComparator
 
compareToReference(TypeComparator<LongValue>) - 类 中的方法org.apache.flink.api.common.typeutils.base.LongValueComparator
 
compareToReference(TypeComparator<NullValue>) - 类 中的方法org.apache.flink.api.common.typeutils.base.NullValueComparator
 
compareToReference(TypeComparator<ShortValue>) - 类 中的方法org.apache.flink.api.common.typeutils.base.ShortValueComparator
 
compareToReference(TypeComparator<StringValue>) - 类 中的方法org.apache.flink.api.common.typeutils.base.StringValueComparator
 
compareToReference(T2) - 类 中的方法org.apache.flink.api.common.typeutils.GenericPairComparator
 
compareToReference(T) - 类 中的方法org.apache.flink.api.common.typeutils.SameTypePairComparator
 
compareToReference(TypeComparator<T>) - 类 中的方法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) - 类 中的方法org.apache.flink.api.common.typeutils.TypePairComparator
 
compareToReference(TypeComparator<T>) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.CopyableValueComparator
 
compareToReference(TypeComparator<T>) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.GenericTypeComparator
 
compareToReference(TypeComparator<T>) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.NullAwareComparator
 
compareToReference(TypeComparator<T>) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.PojoComparator
 
compareToReference(TypeComparator<Row>) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.RowComparator
 
compareToReference(TypeComparator<T>) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
 
compareToReference(TypeComparator<T>) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.ValueComparator
 
compatibleAfterMigration() - 类 中的静态方法org.apache.flink.api.common.typeutils.TypeSerializerSchemaCompatibility
Returns a result that indicates that the new serializer can be used after migrating the written bytes, i.e. reading it with the old serializer and then writing it again with the new serializer.
compatibleAsIs() - 类 中的静态方法org.apache.flink.api.common.typeutils.TypeSerializerSchemaCompatibility
Returns a result that indicates that the new serializer is compatible and no migration is required.
compatibleWithReconfiguredSerializer(TypeSerializer<T>) - 类 中的静态方法org.apache.flink.api.common.typeutils.TypeSerializerSchemaCompatibility
Returns a result that indicates a reconfigured version of the new serializer is compatible, and should be used instead of the original new serializer.
CompilerHints - org.apache.flink.api.common.operators中的类
A class encapsulating compiler hints describing the behavior of the user function.
CompilerHints() - 类 的构造器org.apache.flink.api.common.operators.CompilerHints
 
compilerHints - 类 中的变量org.apache.flink.api.common.operators.Operator
 
complementBlockInfo(BlockInfo) - 类 中的方法org.apache.flink.api.common.io.BinaryOutputFormat
 
completeAll(Collection<? extends CompletableFuture<?>>) - 类 中的静态方法org.apache.flink.util.concurrent.FutureUtils
Creates a FutureUtils.ConjunctFuture which is only completed after all given futures have completed.
completeDelayed(CompletableFuture<T>, T, Duration) - 类 中的静态方法org.apache.flink.util.concurrent.FutureUtils
Asynchronously completes the future after a certain delay.
completedExceptionally(Throwable) - 类 中的静态方法org.apache.flink.util.concurrent.FutureUtils
Returns an exceptionally completed CompletableFuture.
completedVoidFuture() - 类 中的静态方法org.apache.flink.util.concurrent.FutureUtils
Returns a completed future of type Void.
completeFromCallable(CompletableFuture<T>, Callable<T>) - 类 中的静态方法org.apache.flink.util.concurrent.FutureUtils
Fakes asynchronous execution by immediately executing the operation and completing the supplied future either normally or exceptionally.
ComponentClassLoader - org.apache.flink.core.classloading中的类
A URLClassLoader that restricts which classes can be loaded to those contained within the given classpath, except classes from a given set of packages that are either loaded owner or component-first.
ComponentClassLoader(URL[], ClassLoader, String[], String[]) - 类 的构造器org.apache.flink.core.classloading.ComponentClassLoader
 
composeAfterwards(CompletableFuture<?>, Supplier<CompletableFuture<?>>) - 类 中的静态方法org.apache.flink.util.concurrent.FutureUtils
Run the given asynchronous action after the completion of the given future.
CompositeSerializer<T> - org.apache.flink.api.common.typeutils中的类
Base class for composite serializers.
CompositeSerializer(boolean, TypeSerializer<?>...) - 类 的构造器org.apache.flink.api.common.typeutils.CompositeSerializer
Can be used for user facing constructor.
CompositeSerializer(CompositeSerializer.PrecomputedParameters, TypeSerializer<?>...) - 类 的构造器org.apache.flink.api.common.typeutils.CompositeSerializer
Can be used in createSerializerInstance for internal operations.
CompositeSerializer.ConfigSnapshot - org.apache.flink.api.common.typeutils中的类
已过时。
this snapshot class is no longer in use by any serializers, and is only kept around for backwards compatibility. All subclass serializers should have their own serializer snapshot classes.
CompositeSerializer.PrecomputedParameters - org.apache.flink.api.common.typeutils中的类
This class holds composite serializer parameters which can be precomputed in advanced for better performance.
CompositeType<T> - 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>) - 类 的构造器org.apache.flink.api.common.typeutils.CompositeType
 
CompositeType.FlatFieldDescriptor - org.apache.flink.api.common.typeutils中的类
 
CompositeType.InvalidFieldReferenceException - org.apache.flink.api.common.typeutils中的异常错误
 
CompositeType.TypeComparatorBuilder<T> - org.apache.flink.api.common.typeutils中的接口
 
CompositeTypeComparator<T> - org.apache.flink.api.common.typeutils中的类
 
CompositeTypeComparator() - 类 的构造器org.apache.flink.api.common.typeutils.CompositeTypeComparator
 
CompositeTypeSerializerConfigSnapshot<T> - org.apache.flink.api.common.typeutils中的类
A TypeSerializerConfigSnapshot for serializers that has multiple nested serializers.
CompositeTypeSerializerConfigSnapshot() - 类 的构造器org.apache.flink.api.common.typeutils.CompositeTypeSerializerConfigSnapshot
This empty nullary constructor is required for deserializing the configuration.
CompositeTypeSerializerConfigSnapshot(TypeSerializer<?>...) - 类 的构造器org.apache.flink.api.common.typeutils.CompositeTypeSerializerConfigSnapshot
 
CompositeTypeSerializerSnapshot<T,S extends TypeSerializer<T>> - org.apache.flink.api.common.typeutils中的类
A CompositeTypeSerializerSnapshot is a convenient serializer snapshot class that can be used by simple serializers which 1) delegates its serialization to multiple nested serializers, and 2) may contain some extra static information that needs to be persisted as part of its snapshot.
CompositeTypeSerializerSnapshot(Class<? extends TypeSerializer>) - 类 的构造器org.apache.flink.api.common.typeutils.CompositeTypeSerializerSnapshot
Constructor to be used for read instantiation.
CompositeTypeSerializerSnapshot(S) - 类 的构造器org.apache.flink.api.common.typeutils.CompositeTypeSerializerSnapshot
Constructor to be used for writing the snapshot.
CompositeTypeSerializerSnapshot.OuterSchemaCompatibility - org.apache.flink.api.common.typeutils中的枚举
Indicates schema compatibility of the serializer configuration persisted as the outer snapshot.
CompositeTypeSerializerUtil - org.apache.flink.api.common.typeutils中的类
CompositeTypeSerializerUtil() - 类 的构造器org.apache.flink.api.common.typeutils.CompositeTypeSerializerUtil
 
CompositeTypeSerializerUtil.IntermediateCompatibilityResult<T> - org.apache.flink.api.common.typeutils中的类
 
compressDirectory(Path, Path) - 类 中的静态方法org.apache.flink.util.FileUtils
 
CompressedSerializedValue<T> - org.apache.flink.util中的类
An extension of SerializedValue that compresses the value after the serialization.
computeLogicalKeyPositions() - 类 中的方法org.apache.flink.api.common.operators.Keys
 
computeLogicalKeyPositions() - 类 中的方法org.apache.flink.api.common.operators.Keys.ExpressionKeys
 
computeLogicalKeyPositions() - 类 中的方法org.apache.flink.api.common.operators.Keys.SelectorFunctionKeys
 
concat(String[], String[]) - 类 中的静态方法org.apache.flink.util.ArrayUtils
 
concatenate(Record) - 类 中的方法org.apache.flink.types.Record
 
concatenateWithAnd(String, String) - 类 中的静态方法org.apache.flink.util.StringUtils
If both string arguments are non-null, this method concatenates them with ' and '.
CONF_DIR - 类 中的静态变量org.apache.flink.configuration.DeploymentOptionsInternal
 
confData - 类 中的变量org.apache.flink.configuration.Configuration
Stores the concrete key/value pairs of this configuration object.
ConfigConstants - org.apache.flink.configuration中的类
This class contains all constants for the configuration.
ConfigOption<T> - org.apache.flink.configuration中的类
A ConfigOption describes a configuration parameter.
ConfigOptions - org.apache.flink.configuration中的类
ConfigOptions are used to build a ConfigOption.
ConfigOptions.ListConfigOptionBuilder<E> - org.apache.flink.configuration中的类
Builder for ConfigOption of list of type E.
ConfigOptions.OptionBuilder - org.apache.flink.configuration中的类
The option builder is used to create a ConfigOption.
ConfigOptions.TypedConfigOptionBuilder<T> - org.apache.flink.configuration中的类
Builder for ConfigOption with a defined atomic type.
ConfigSnapshot() - 类 的构造器org.apache.flink.api.common.typeutils.CompositeSerializer.ConfigSnapshot
已过时。
This empty nullary constructor is required for deserializing the configuration.
Configuration - org.apache.flink.configuration中的类
Lightweight configuration object which stores key/value pairs.
Configuration() - 类 的构造器org.apache.flink.configuration.Configuration
Creates a new empty configuration.
Configuration(Configuration) - 类 的构造器org.apache.flink.configuration.Configuration
Creates a new configuration with the copy of the given configuration.
ConfigurationException - org.apache.flink.util中的异常错误
Exception which occurs when creating a configuration object fails.
ConfigurationException(String) - 异常错误 的构造器org.apache.flink.util.ConfigurationException
 
ConfigurationException(String, Throwable) - 异常错误 的构造器org.apache.flink.util.ConfigurationException
 
ConfigurationException(Throwable) - 异常错误 的构造器org.apache.flink.util.ConfigurationException
 
ConfigurationUtils - org.apache.flink.configuration中的类
Utility class for Configuration related helper functions.
configure(ReadableConfig, ClassLoader) - 类 中的方法org.apache.flink.api.common.ExecutionConfig
Sets all relevant options contained in the ReadableConfig such as e.g.
configure(Configuration) - 类 中的方法org.apache.flink.api.common.io.BinaryInputFormat
 
configure(Configuration) - 类 中的方法org.apache.flink.api.common.io.BinaryOutputFormat
 
configure(Configuration) - 类 中的方法org.apache.flink.api.common.io.DelimitedInputFormat
Configures this input format by reading the path to the file from the configuration and the string that defines the record delimiter.
configure(Configuration) - 类 中的方法org.apache.flink.api.common.io.FileInputFormat
Configures the file input format by reading the file path from the configuration.
configure(Configuration) - 类 中的方法org.apache.flink.api.common.io.FileOutputFormat
 
configure(Configuration) - 类 中的方法org.apache.flink.api.common.io.GenericInputFormat
 
configure(Configuration) - 接口 中的方法org.apache.flink.api.common.io.InputFormat
Configures this input format.
configure(Configuration) - 接口 中的方法org.apache.flink.api.common.io.OutputFormat
Configures this output format.
configure(Configuration) - 类 中的方法org.apache.flink.api.common.io.ReplicatingInputFormat
 
configure(Configuration) - 类 中的方法org.apache.flink.core.fs.ConnectionLimitingFactory
 
configure(Configuration) - 类 中的方法org.apache.flink.core.fs.PluginFileSystemFactory
 
configure(Configuration) - 接口 中的方法org.apache.flink.core.plugin.Plugin
Optional method for plugins to pick up settings from the configuration.
ConfigUtils - org.apache.flink.configuration中的类
General utilities for parsing values to configuration options.
ConjunctFuture() - 类 的构造器org.apache.flink.util.concurrent.FutureUtils.ConjunctFuture
 
CONNECT_BACKLOG - 类 中的静态变量org.apache.flink.configuration.NettyShuffleEnvironmentOptions
 
CONNECT_TIMEOUT - 类 中的静态变量org.apache.flink.configuration.BlobServerOptions
The connection timeout in milliseconds for the blob client.
CONNECTION_TIMEOUT - 类 中的静态变量org.apache.flink.configuration.RestOptions
The maximum time in ms for the client to establish a TCP connection.
ConnectionLimitingFactory - org.apache.flink.core.fs中的类
A wrapping factory that adds a LimitedConnectionsFileSystem to a file system.
ConnectionLimitingSettings(int, int, int, long, long) - 类 的构造器org.apache.flink.core.fs.LimitedConnectionsFileSystem.ConnectionLimitingSettings
Creates a new ConnectionLimitingSettings with the given parameters.
constructIntermediateCompatibilityResult(TypeSerializer<?>[], TypeSerializerSnapshot<?>[]) - 类 中的静态方法org.apache.flink.api.common.typeutils.CompositeTypeSerializerUtil
Constructs an CompositeTypeSerializerUtil.IntermediateCompatibilityResult with the given array of nested serializers and their corresponding serializer snapshots.
CONTAINERIZED_HEAP_CUTOFF_MIN - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
Not used anymore, but remain here until Flink 2.0
CONTAINERIZED_HEAP_CUTOFF_RATIO - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
Not used anymore, but remain here until Flink 2.0
CONTAINERIZED_MASTER_ENV_PREFIX - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
CONTAINERIZED_MASTER_ENV_PREFIX - 类 中的静态变量org.apache.flink.configuration.ResourceManagerOptions
Prefix for passing custom environment variables to Flink's master process.
CONTAINERIZED_TASK_MANAGER_ENV_PREFIX - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
CONTAINERIZED_TASK_MANAGER_ENV_PREFIX - 类 中的静态变量org.apache.flink.configuration.ResourceManagerOptions
Similar to the CONTAINERIZED_MASTER_ENV_PREFIX, this configuration prefix allows setting custom environment variables for the workers (TaskManagers).
containingIteration - 类 中的变量org.apache.flink.api.common.operators.base.DeltaIterationBase.SolutionSetPlaceHolder
 
contains(Integer) - 类 中的方法org.apache.flink.api.common.operators.util.FieldSet
 
contains(UK) - 接口 中的方法org.apache.flink.api.common.state.MapState
Returns whether there exists the given mapping.
contains(K) - 接口 中的方法org.apache.flink.api.common.state.ReadOnlyBroadcastState
Returns whether there exists the given mapping.
contains(ConfigOption<?>) - 类 中的方法org.apache.flink.configuration.Configuration
Checks whether there is an entry for the given config option.
contains(ConfigOption<?>) - 类 中的方法org.apache.flink.configuration.DelegatingConfiguration
 
contains(Object) - 类 中的方法org.apache.flink.types.ListValue
 
containsAll(Collection<?>) - 类 中的方法org.apache.flink.types.ListValue
 
containsKey(String) - 类 中的方法org.apache.flink.configuration.Configuration
Checks whether there is an entry with the specified key.
containsKey(String) - 类 中的方法org.apache.flink.configuration.DelegatingConfiguration
 
containsKey(Object) - 类 中的方法org.apache.flink.types.MapValue
 
containsValue(Object) - 类 中的方法org.apache.flink.types.MapValue
 
ConvergenceCriterion<T extends Value> - org.apache.flink.api.common.aggregators中的接口
Used to check for convergence.
convertBoxedJavaType(Object) - 类 中的静态方法org.apache.flink.types.JavaToValueConverter
 
convertValue(Object, Class<?>) - 类 中的静态方法org.apache.flink.configuration.ConfigurationUtils
Tries to convert the raw value into the provided type.
convertValueType(Value) - 类 中的静态方法org.apache.flink.types.JavaToValueConverter
 
copy(Map<String, Accumulator<?, ?>>) - 类 中的静态方法org.apache.flink.api.common.accumulators.AccumulatorHelper
 
copy(boolean[]) - 类 中的方法org.apache.flink.api.common.typeutils.base.array.BooleanPrimitiveArraySerializer
 
copy(boolean[], boolean[]) - 类 中的方法org.apache.flink.api.common.typeutils.base.array.BooleanPrimitiveArraySerializer
 
copy(DataInputView, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.array.BooleanPrimitiveArraySerializer
 
copy(byte[]) - 类 中的方法org.apache.flink.api.common.typeutils.base.array.BytePrimitiveArraySerializer
 
copy(byte[], byte[]) - 类 中的方法org.apache.flink.api.common.typeutils.base.array.BytePrimitiveArraySerializer
 
copy(DataInputView, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.array.BytePrimitiveArraySerializer
 
copy(char[]) - 类 中的方法org.apache.flink.api.common.typeutils.base.array.CharPrimitiveArraySerializer
 
copy(char[], char[]) - 类 中的方法org.apache.flink.api.common.typeutils.base.array.CharPrimitiveArraySerializer
 
copy(DataInputView, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.array.CharPrimitiveArraySerializer
 
copy(double[]) - 类 中的方法org.apache.flink.api.common.typeutils.base.array.DoublePrimitiveArraySerializer
 
copy(double[], double[]) - 类 中的方法org.apache.flink.api.common.typeutils.base.array.DoublePrimitiveArraySerializer
 
copy(DataInputView, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.array.DoublePrimitiveArraySerializer
 
copy(float[]) - 类 中的方法org.apache.flink.api.common.typeutils.base.array.FloatPrimitiveArraySerializer
 
copy(float[], float[]) - 类 中的方法org.apache.flink.api.common.typeutils.base.array.FloatPrimitiveArraySerializer
 
copy(DataInputView, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.array.FloatPrimitiveArraySerializer
 
copy(int[]) - 类 中的方法org.apache.flink.api.common.typeutils.base.array.IntPrimitiveArraySerializer
 
copy(int[], int[]) - 类 中的方法org.apache.flink.api.common.typeutils.base.array.IntPrimitiveArraySerializer
 
copy(DataInputView, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.array.IntPrimitiveArraySerializer
 
copy(long[]) - 类 中的方法org.apache.flink.api.common.typeutils.base.array.LongPrimitiveArraySerializer
 
copy(long[], long[]) - 类 中的方法org.apache.flink.api.common.typeutils.base.array.LongPrimitiveArraySerializer
 
copy(DataInputView, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.array.LongPrimitiveArraySerializer
 
copy(short[]) - 类 中的方法org.apache.flink.api.common.typeutils.base.array.ShortPrimitiveArraySerializer
 
copy(short[], short[]) - 类 中的方法org.apache.flink.api.common.typeutils.base.array.ShortPrimitiveArraySerializer
 
copy(DataInputView, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.array.ShortPrimitiveArraySerializer
 
copy(String[]) - 类 中的方法org.apache.flink.api.common.typeutils.base.array.StringArraySerializer
 
copy(String[], String[]) - 类 中的方法org.apache.flink.api.common.typeutils.base.array.StringArraySerializer
 
copy(DataInputView, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.array.StringArraySerializer
 
copy(BigDecimal) - 类 中的方法org.apache.flink.api.common.typeutils.base.BigDecSerializer
 
copy(BigDecimal, BigDecimal) - 类 中的方法org.apache.flink.api.common.typeutils.base.BigDecSerializer
 
copy(DataInputView, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.BigDecSerializer
 
copy(BigInteger) - 类 中的方法org.apache.flink.api.common.typeutils.base.BigIntSerializer
 
copy(BigInteger, BigInteger) - 类 中的方法org.apache.flink.api.common.typeutils.base.BigIntSerializer
 
copy(DataInputView, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.BigIntSerializer
 
copy(Boolean) - 类 中的方法org.apache.flink.api.common.typeutils.base.BooleanSerializer
 
copy(Boolean, Boolean) - 类 中的方法org.apache.flink.api.common.typeutils.base.BooleanSerializer
 
copy(DataInputView, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.BooleanSerializer
 
copy(BooleanValue) - 类 中的方法org.apache.flink.api.common.typeutils.base.BooleanValueSerializer
 
copy(BooleanValue, BooleanValue) - 类 中的方法org.apache.flink.api.common.typeutils.base.BooleanValueSerializer
 
copy(DataInputView, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.BooleanValueSerializer
 
copy(Byte) - 类 中的方法org.apache.flink.api.common.typeutils.base.ByteSerializer
 
copy(Byte, Byte) - 类 中的方法org.apache.flink.api.common.typeutils.base.ByteSerializer
 
copy(DataInputView, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.ByteSerializer
 
copy(ByteValue) - 类 中的方法org.apache.flink.api.common.typeutils.base.ByteValueSerializer
 
copy(ByteValue, ByteValue) - 类 中的方法org.apache.flink.api.common.typeutils.base.ByteValueSerializer
 
copy(DataInputView, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.ByteValueSerializer
 
copy(Character) - 类 中的方法org.apache.flink.api.common.typeutils.base.CharSerializer
 
copy(Character, Character) - 类 中的方法org.apache.flink.api.common.typeutils.base.CharSerializer
 
copy(DataInputView, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.CharSerializer
 
copy(CharValue) - 类 中的方法org.apache.flink.api.common.typeutils.base.CharValueSerializer
 
copy(CharValue, CharValue) - 类 中的方法org.apache.flink.api.common.typeutils.base.CharValueSerializer
 
copy(DataInputView, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.CharValueSerializer
 
copy(Date) - 类 中的方法org.apache.flink.api.common.typeutils.base.DateSerializer
 
copy(Date, Date) - 类 中的方法org.apache.flink.api.common.typeutils.base.DateSerializer
 
copy(DataInputView, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.DateSerializer
 
copy(Double) - 类 中的方法org.apache.flink.api.common.typeutils.base.DoubleSerializer
 
copy(Double, Double) - 类 中的方法org.apache.flink.api.common.typeutils.base.DoubleSerializer
 
copy(DataInputView, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.DoubleSerializer
 
copy(DoubleValue) - 类 中的方法org.apache.flink.api.common.typeutils.base.DoubleValueSerializer
 
copy(DoubleValue, DoubleValue) - 类 中的方法org.apache.flink.api.common.typeutils.base.DoubleValueSerializer
 
copy(DataInputView, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.DoubleValueSerializer
 
copy(T) - 类 中的方法org.apache.flink.api.common.typeutils.base.EnumSerializer
 
copy(T, T) - 类 中的方法org.apache.flink.api.common.typeutils.base.EnumSerializer
 
copy(DataInputView, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.EnumSerializer
 
copy(Float) - 类 中的方法org.apache.flink.api.common.typeutils.base.FloatSerializer
 
copy(Float, Float) - 类 中的方法org.apache.flink.api.common.typeutils.base.FloatSerializer
 
copy(DataInputView, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.FloatSerializer
 
copy(FloatValue) - 类 中的方法org.apache.flink.api.common.typeutils.base.FloatValueSerializer
 
copy(FloatValue, FloatValue) - 类 中的方法org.apache.flink.api.common.typeutils.base.FloatValueSerializer
 
copy(DataInputView, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.FloatValueSerializer
 
copy(C[]) - 类 中的方法org.apache.flink.api.common.typeutils.base.GenericArraySerializer
 
copy(C[], C[]) - 类 中的方法org.apache.flink.api.common.typeutils.base.GenericArraySerializer
 
copy(DataInputView, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.GenericArraySerializer
 
copy(Instant) - 类 中的方法org.apache.flink.api.common.typeutils.base.InstantSerializer
 
copy(Instant, Instant) - 类 中的方法org.apache.flink.api.common.typeutils.base.InstantSerializer
 
copy(DataInputView, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.InstantSerializer
 
copy(Integer) - 类 中的方法org.apache.flink.api.common.typeutils.base.IntSerializer
 
copy(Integer, Integer) - 类 中的方法org.apache.flink.api.common.typeutils.base.IntSerializer
 
copy(DataInputView, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.IntSerializer
 
copy(IntValue) - 类 中的方法org.apache.flink.api.common.typeutils.base.IntValueSerializer
 
copy(IntValue, IntValue) - 类 中的方法org.apache.flink.api.common.typeutils.base.IntValueSerializer
 
copy(DataInputView, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.IntValueSerializer
 
copy(List<T>) - 类 中的方法org.apache.flink.api.common.typeutils.base.ListSerializer
 
copy(List<T>, List<T>) - 类 中的方法org.apache.flink.api.common.typeutils.base.ListSerializer
 
copy(DataInputView, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.ListSerializer
 
copy(LocalDate) - 类 中的方法org.apache.flink.api.common.typeutils.base.LocalDateSerializer
 
copy(LocalDate, LocalDate) - 类 中的方法org.apache.flink.api.common.typeutils.base.LocalDateSerializer
 
copy(DataInputView, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.LocalDateSerializer
 
copy(LocalDateTime) - 类 中的方法org.apache.flink.api.common.typeutils.base.LocalDateTimeSerializer
 
copy(LocalDateTime, LocalDateTime) - 类 中的方法org.apache.flink.api.common.typeutils.base.LocalDateTimeSerializer
 
copy(DataInputView, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.LocalDateTimeSerializer
 
copy(LocalTime) - 类 中的方法org.apache.flink.api.common.typeutils.base.LocalTimeSerializer
 
copy(LocalTime, LocalTime) - 类 中的方法org.apache.flink.api.common.typeutils.base.LocalTimeSerializer
 
copy(DataInputView, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.LocalTimeSerializer
 
copy(Long) - 类 中的方法org.apache.flink.api.common.typeutils.base.LongSerializer
 
copy(Long, Long) - 类 中的方法org.apache.flink.api.common.typeutils.base.LongSerializer
 
copy(DataInputView, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.LongSerializer
 
copy(LongValue) - 类 中的方法org.apache.flink.api.common.typeutils.base.LongValueSerializer
 
copy(LongValue, LongValue) - 类 中的方法org.apache.flink.api.common.typeutils.base.LongValueSerializer
 
copy(DataInputView, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.LongValueSerializer
 
copy(Map<K, V>) - 类 中的方法org.apache.flink.api.common.typeutils.base.MapSerializer
 
copy(Map<K, V>, Map<K, V>) - 类 中的方法org.apache.flink.api.common.typeutils.base.MapSerializer
 
copy(DataInputView, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.MapSerializer
 
copy(NullValue) - 类 中的方法org.apache.flink.api.common.typeutils.base.NullValueSerializer
 
copy(NullValue, NullValue) - 类 中的方法org.apache.flink.api.common.typeutils.base.NullValueSerializer
 
copy(DataInputView, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.NullValueSerializer
 
copy(Short) - 类 中的方法org.apache.flink.api.common.typeutils.base.ShortSerializer
 
copy(Short, Short) - 类 中的方法org.apache.flink.api.common.typeutils.base.ShortSerializer
 
copy(DataInputView, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.ShortSerializer
 
copy(ShortValue) - 类 中的方法org.apache.flink.api.common.typeutils.base.ShortValueSerializer
 
copy(ShortValue, ShortValue) - 类 中的方法org.apache.flink.api.common.typeutils.base.ShortValueSerializer
 
copy(DataInputView, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.ShortValueSerializer
 
copy(Date) - 类 中的方法org.apache.flink.api.common.typeutils.base.SqlDateSerializer
 
copy(Date, Date) - 类 中的方法org.apache.flink.api.common.typeutils.base.SqlDateSerializer
 
copy(DataInputView, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.SqlDateSerializer
 
copy(Time) - 类 中的方法org.apache.flink.api.common.typeutils.base.SqlTimeSerializer
 
copy(Time, Time) - 类 中的方法org.apache.flink.api.common.typeutils.base.SqlTimeSerializer
 
copy(DataInputView, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.SqlTimeSerializer
 
copy(Timestamp) - 类 中的方法org.apache.flink.api.common.typeutils.base.SqlTimestampSerializer
 
copy(Timestamp, Timestamp) - 类 中的方法org.apache.flink.api.common.typeutils.base.SqlTimestampSerializer
 
copy(DataInputView, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.SqlTimestampSerializer
 
copy(String) - 类 中的方法org.apache.flink.api.common.typeutils.base.StringSerializer
 
copy(String, String) - 类 中的方法org.apache.flink.api.common.typeutils.base.StringSerializer
 
copy(DataInputView, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.StringSerializer
 
copy(StringValue) - 类 中的方法org.apache.flink.api.common.typeutils.base.StringValueSerializer
 
copy(StringValue, StringValue) - 类 中的方法org.apache.flink.api.common.typeutils.base.StringValueSerializer
 
copy(DataInputView, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.StringValueSerializer
 
copy(Void) - 类 中的方法org.apache.flink.api.common.typeutils.base.VoidSerializer
 
copy(Void, Void) - 类 中的方法org.apache.flink.api.common.typeutils.base.VoidSerializer
 
copy(DataInputView, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.VoidSerializer
 
copy(T) - 类 中的方法org.apache.flink.api.common.typeutils.CompositeSerializer
 
copy(T, T) - 类 中的方法org.apache.flink.api.common.typeutils.CompositeSerializer
 
copy(DataInputView, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.CompositeSerializer
 
copy(T) - 类 中的方法org.apache.flink.api.common.typeutils.SingleThreadAccessCheckingTypeSerializer
 
copy(T, T) - 类 中的方法org.apache.flink.api.common.typeutils.SingleThreadAccessCheckingTypeSerializer
 
copy(DataInputView, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.SingleThreadAccessCheckingTypeSerializer
 
copy(T) - 类 中的方法org.apache.flink.api.common.typeutils.TypeSerializer
Creates a deep copy of the given element in a new element.
copy(T, T) - 类 中的方法org.apache.flink.api.common.typeutils.TypeSerializer
Creates a copy from the given element.
copy(DataInputView, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.TypeSerializer
Copies exactly one record from the source input view to the target output view.
copy(T) - 类 中的方法org.apache.flink.api.common.typeutils.UnloadableDummyTypeSerializer
 
copy(T, T) - 类 中的方法org.apache.flink.api.common.typeutils.UnloadableDummyTypeSerializer
 
copy(DataInputView, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.UnloadableDummyTypeSerializer
 
copy() - 类 中的方法org.apache.flink.api.java.tuple.Tuple
Shallow tuple copy.
copy() - 类 中的方法org.apache.flink.api.java.tuple.Tuple0
Shallow tuple copy.
copy() - 类 中的方法org.apache.flink.api.java.tuple.Tuple1
Shallow tuple copy.
copy() - 类 中的方法org.apache.flink.api.java.tuple.Tuple10
Shallow tuple copy.
copy() - 类 中的方法org.apache.flink.api.java.tuple.Tuple11
Shallow tuple copy.
copy() - 类 中的方法org.apache.flink.api.java.tuple.Tuple12
Shallow tuple copy.
copy() - 类 中的方法org.apache.flink.api.java.tuple.Tuple13
Shallow tuple copy.
copy() - 类 中的方法org.apache.flink.api.java.tuple.Tuple14
Shallow tuple copy.
copy() - 类 中的方法org.apache.flink.api.java.tuple.Tuple15
Shallow tuple copy.
copy() - 类 中的方法org.apache.flink.api.java.tuple.Tuple16
Shallow tuple copy.
copy() - 类 中的方法org.apache.flink.api.java.tuple.Tuple17
Shallow tuple copy.
copy() - 类 中的方法org.apache.flink.api.java.tuple.Tuple18
Shallow tuple copy.
copy() - 类 中的方法org.apache.flink.api.java.tuple.Tuple19
Shallow tuple copy.
copy() - 类 中的方法org.apache.flink.api.java.tuple.Tuple2
Shallow tuple copy.
copy() - 类 中的方法org.apache.flink.api.java.tuple.Tuple20
Shallow tuple copy.
copy() - 类 中的方法org.apache.flink.api.java.tuple.Tuple21
Shallow tuple copy.
copy() - 类 中的方法org.apache.flink.api.java.tuple.Tuple22
Shallow tuple copy.
copy() - 类 中的方法org.apache.flink.api.java.tuple.Tuple23
Shallow tuple copy.
copy() - 类 中的方法org.apache.flink.api.java.tuple.Tuple24
Shallow tuple copy.
copy() - 类 中的方法org.apache.flink.api.java.tuple.Tuple25
Shallow tuple copy.
copy() - 类 中的方法org.apache.flink.api.java.tuple.Tuple3
Shallow tuple copy.
copy() - 类 中的方法org.apache.flink.api.java.tuple.Tuple4
Shallow tuple copy.
copy() - 类 中的方法org.apache.flink.api.java.tuple.Tuple5
Shallow tuple copy.
copy() - 类 中的方法org.apache.flink.api.java.tuple.Tuple6
Shallow tuple copy.
copy() - 类 中的方法org.apache.flink.api.java.tuple.Tuple7
Shallow tuple copy.
copy() - 类 中的方法org.apache.flink.api.java.tuple.Tuple8
Shallow tuple copy.
copy() - 类 中的方法org.apache.flink.api.java.tuple.Tuple9
Shallow tuple copy.
copy(T) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer
 
copy(T, T) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer
 
copy(DataInputView, DataOutputView) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer
 
copy(Either<L, R>) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.EitherSerializer
 
copy(Either<L, R>, Either<L, R>) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.EitherSerializer
 
copy(DataInputView, DataOutputView) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.EitherSerializer
 
copy(T) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer
 
copy(T, T) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer
 
copy(DataInputView, DataOutputView) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer
 
copy(T, Kryo, TypeSerializer<T>) - 类 中的静态方法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>) - 类 中的静态方法org.apache.flink.api.java.typeutils.runtime.KryoUtils
Tries to copy the given record from using the provided Kryo instance.
copy(T) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.NullableSerializer
 
copy(T, T) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.NullableSerializer
 
copy(DataInputView, DataOutputView) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.NullableSerializer
 
copy(T) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.PojoSerializer
 
copy(T, T) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.PojoSerializer
 
copy(DataInputView, DataOutputView) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.PojoSerializer
 
copy(Row) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.RowSerializer
 
copy(Row, Row) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.RowSerializer
 
copy(DataInputView, DataOutputView) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.RowSerializer
 
copy(Tuple0) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.Tuple0Serializer
 
copy(Tuple0, Tuple0) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.Tuple0Serializer
 
copy(DataInputView, DataOutputView) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.Tuple0Serializer
 
copy(T) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.TupleSerializer
 
copy(T, T) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.TupleSerializer
 
copy(DataInputView, DataOutputView) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.TupleSerializerBase
 
copy(T) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.ValueSerializer
 
copy(T, T) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.ValueSerializer
 
copy(DataInputView, DataOutputView) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.ValueSerializer
 
copy(T) - 类 中的方法org.apache.flink.core.io.SimpleVersionedSerializerTypeSerializerProxy
 
copy(T, T) - 类 中的方法org.apache.flink.core.io.SimpleVersionedSerializerTypeSerializerProxy
 
copy(DataInputView, DataOutputView) - 类 中的方法org.apache.flink.core.io.SimpleVersionedSerializerTypeSerializerProxy
 
copy() - 类 中的方法org.apache.flink.types.BooleanValue
 
copy(DataInputView, DataOutputView) - 类 中的方法org.apache.flink.types.BooleanValue
 
copy() - 类 中的方法org.apache.flink.types.ByteValue
 
copy(DataInputView, DataOutputView) - 类 中的方法org.apache.flink.types.ByteValue
 
copy() - 类 中的方法org.apache.flink.types.CharValue
 
copy(DataInputView, DataOutputView) - 类 中的方法org.apache.flink.types.CharValue
 
copy() - 接口 中的方法org.apache.flink.types.CopyableValue
Performs a deep copy of this object into a new instance.
copy(DataInputView, DataOutputView) - 接口 中的方法org.apache.flink.types.CopyableValue
Copies the next serialized instance from source to target.
copy() - 类 中的方法org.apache.flink.types.DoubleValue
 
copy(DataInputView, DataOutputView) - 类 中的方法org.apache.flink.types.DoubleValue
 
copy() - 类 中的方法org.apache.flink.types.FloatValue
 
copy(DataInputView, DataOutputView) - 类 中的方法org.apache.flink.types.FloatValue
 
copy() - 类 中的方法org.apache.flink.types.IntValue
 
copy(DataInputView, DataOutputView) - 类 中的方法org.apache.flink.types.IntValue
 
copy() - 类 中的方法org.apache.flink.types.LongValue
 
copy(DataInputView, DataOutputView) - 类 中的方法org.apache.flink.types.LongValue
 
copy() - 类 中的方法org.apache.flink.types.NullValue
 
copy(DataInputView, DataOutputView) - 类 中的方法org.apache.flink.types.NullValue
 
copy() - 类 中的方法org.apache.flink.types.Record
 
copy(DataInputView, DataOutputView) - 类 中的方法org.apache.flink.types.Record
 
copy(Row) - 类 中的静态方法org.apache.flink.types.Row
Creates a new row which is copied from another row (including its RowKind).
copy() - 类 中的方法org.apache.flink.types.ShortValue
 
copy(DataInputView, DataOutputView) - 类 中的方法org.apache.flink.types.ShortValue
 
copy() - 类 中的方法org.apache.flink.types.StringValue
 
copy(DataInputView, DataOutputView) - 类 中的方法org.apache.flink.types.StringValue
 
copy(Path, Path, boolean) - 类 中的静态方法org.apache.flink.util.FileUtils
Copies all files from source to target and sets executable flag.
CopyableValue<T> - org.apache.flink.types中的接口
Interface to be implemented by basic types that support to be copied efficiently.
CopyableValueComparator<T extends CopyableValue<T> & Comparable<T>> - org.apache.flink.api.java.typeutils.runtime中的类
Comparator for all Value types that extend Key
CopyableValueComparator(boolean, Class<T>) - 类 的构造器org.apache.flink.api.java.typeutils.runtime.CopyableValueComparator
 
CopyableValueSerializer<T extends CopyableValue<T>> - org.apache.flink.api.java.typeutils.runtime中的类
 
CopyableValueSerializer(Class<T>) - 类 的构造器org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer
 
CopyableValueSerializer.CopyableValueSerializerConfigSnapshot<T extends CopyableValue<T>> - org.apache.flink.api.java.typeutils.runtime中的类
已过时。
CopyableValueSerializer.CopyableValueSerializerSnapshot<T extends CopyableValue<T>> - org.apache.flink.api.java.typeutils.runtime中的类
TypeSerializerSnapshot for the CopyableValueSerializer.
CopyableValueSerializerConfigSnapshot() - 类 的构造器org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer.CopyableValueSerializerConfigSnapshot
已过时。
This empty nullary constructor is required for deserializing the configuration.
CopyableValueSerializerConfigSnapshot(Class<T>) - 类 的构造器org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer.CopyableValueSerializerConfigSnapshot
已过时。
 
CopyableValueSerializerSnapshot() - 类 的构造器org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer.CopyableValueSerializerSnapshot
Used for reflective instantiation.
copyBigInteger(DataInputView, DataOutputView) - 类 中的静态方法org.apache.flink.api.common.typeutils.base.BigIntSerializer
 
copyBytes(InputStream, OutputStream, int, boolean) - 类 中的静态方法org.apache.flink.util.IOUtils
Copies from one stream to another.
copyBytes(InputStream, OutputStream) - 类 中的静态方法org.apache.flink.util.IOUtils
Copies from one stream to another.
copyBytes(InputStream, OutputStream, boolean) - 类 中的静态方法org.apache.flink.util.IOUtils
Copies from one stream to another.
copyFrom(CompilerHints) - 类 中的方法org.apache.flink.api.common.operators.CompilerHints
 
copyFrom(Record, int[], int[]) - 类 中的方法org.apache.flink.types.Record
Bin-copies fields from a source record to this record.
copyFromUnsafe(int, Object, int, int) - 类 中的方法org.apache.flink.core.memory.MemorySegment
Bulk copy method.
CopyingIterator<E> - org.apache.flink.api.common.functions.util中的类
Wraps an iterator to return deep copies of the original iterator's elements.
CopyingIterator(Iterator<E>, TypeSerializer<E>) - 类 的构造器org.apache.flink.api.common.functions.util.CopyingIterator
 
CopyingListCollector<T> - org.apache.flink.api.common.functions.util中的类
A Collector that collects deep copies of its elements in a list.
CopyingListCollector(List<T>, TypeSerializer<T>) - 类 的构造器org.apache.flink.api.common.functions.util.CopyingListCollector
 
copyNormalizedKey(MemorySegment, int, int) - 类 中的方法org.apache.flink.types.BooleanValue
 
copyNormalizedKey(MemorySegment, int, int) - 类 中的方法org.apache.flink.types.ByteValue
 
copyNormalizedKey(MemorySegment, int, int) - 类 中的方法org.apache.flink.types.CharValue
 
copyNormalizedKey(MemorySegment, int, int) - 类 中的方法org.apache.flink.types.IntValue
 
copyNormalizedKey(MemorySegment, int, int) - 类 中的方法org.apache.flink.types.LongValue
 
copyNormalizedKey(MemorySegment, int, int) - 接口 中的方法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) - 类 中的方法org.apache.flink.types.NullValue
 
copyNormalizedKey(MemorySegment, int, int) - 类 中的方法org.apache.flink.types.ShortValue
 
copyNormalizedKey(MemorySegment, int, int) - 类 中的方法org.apache.flink.types.StringValue
 
copyString(DataInput, DataOutput) - 类 中的静态方法org.apache.flink.types.StringValue
 
copyTo(int, MemorySegment, int, int) - 类 中的方法org.apache.flink.core.memory.MemorySegment
Bulk copy method.
copyTo(BooleanValue) - 类 中的方法org.apache.flink.types.BooleanValue
 
copyTo(ByteValue) - 类 中的方法org.apache.flink.types.ByteValue
 
copyTo(CharValue) - 类 中的方法org.apache.flink.types.CharValue
 
copyTo(T) - 接口 中的方法org.apache.flink.types.CopyableValue
Performs a deep copy of this object into the target instance.
copyTo(DoubleValue) - 类 中的方法org.apache.flink.types.DoubleValue
 
copyTo(FloatValue) - 类 中的方法org.apache.flink.types.FloatValue
 
copyTo(IntValue) - 类 中的方法org.apache.flink.types.IntValue
 
copyTo(LongValue) - 类 中的方法org.apache.flink.types.LongValue
 
copyTo(NullValue) - 类 中的方法org.apache.flink.types.NullValue
 
copyTo(Record) - 类 中的方法org.apache.flink.types.Record
 
copyTo(ShortValue) - 类 中的方法org.apache.flink.types.ShortValue
 
copyTo(StringValue) - 类 中的方法org.apache.flink.types.StringValue
 
copyToUnsafe(int, Object, int, int) - 类 中的方法org.apache.flink.core.memory.MemorySegment
Bulk copy method.
CoreOptions - org.apache.flink.configuration中的类
The set of configuration options for core parameters.
CoreOptions() - 类 的构造器org.apache.flink.configuration.CoreOptions
 
count - 类 中的变量org.apache.flink.core.memory.ByteArrayOutputStreamWithPos
 
CPU_CORES - 类 中的静态变量org.apache.flink.configuration.TaskManagerOptions
This config option describes number of cpu cores of task executors.
CPUResource - org.apache.flink.api.common.resources中的类
Represents CPU resource.
CPUResource(double) - 类 的构造器org.apache.flink.api.common.resources.CPUResource
 
create(InputStream) - 类 中的方法org.apache.flink.api.common.io.compression.Bzip2InputStreamFactory
 
create(InputStream) - 类 中的方法org.apache.flink.api.common.io.compression.DeflateInflaterInputStreamFactory
 
create(InputStream) - 类 中的方法org.apache.flink.api.common.io.compression.GzipInflaterInputStreamFactory
 
create(InputStream) - 接口 中的方法org.apache.flink.api.common.io.compression.InflaterInputStreamFactory
Creates a InflaterInputStream that wraps the given input stream.
create(InputStream) - 类 中的方法org.apache.flink.api.common.io.compression.XZInputStreamFactory
 
create(InputStream) - 类 中的方法org.apache.flink.api.common.io.compression.ZStandardInputStreamFactory
 
create(BigDecimal) - 类 中的方法org.apache.flink.api.common.resources.CPUResource
 
create(BigDecimal) - 类 中的方法org.apache.flink.api.common.resources.ExternalResource
 
create(BigDecimal) - 类 中的方法org.apache.flink.api.common.resources.Resource
Create a new instance of the sub resource.
create(FSDataOutputStream) - 接口 中的方法org.apache.flink.api.common.serialization.BulkWriter.Factory
Creates a writer that writes to the given stream.
create(Kryo, Input, Class<Collection>) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.kryo.Serializers.SpecificInstanceCollectionSerializer
 
create(URI) - 类 中的方法org.apache.flink.core.fs.ConnectionLimitingFactory
 
create(Path, boolean, int, short, long) - 类 中的方法org.apache.flink.core.fs.FileSystem
已过时。
Deprecated because not well supported across types of file systems. Control the behavior of specific file systems via configurations instead.
create(Path, boolean) - 类 中的方法org.apache.flink.core.fs.FileSystem
已过时。
create(Path, FileSystem.WriteMode) - 类 中的方法org.apache.flink.core.fs.FileSystem
Opens an FSDataOutputStream to a new file at the given path.
create(URI) - 接口 中的方法org.apache.flink.core.fs.FileSystemFactory
Creates a new file system for the given file system URI.
create(Path, FileSystem.WriteMode) - 类 中的方法org.apache.flink.core.fs.LimitedConnectionsFileSystem
 
create(Path, boolean, int, short, long) - 类 中的方法org.apache.flink.core.fs.LimitedConnectionsFileSystem
已过时。
create(Path, FileSystem.WriteMode) - 类 中的方法org.apache.flink.core.fs.local.LocalFileSystem
 
create(URI) - 类 中的方法org.apache.flink.core.fs.local.LocalFileSystemFactory
 
create(URI) - 类 中的方法org.apache.flink.core.fs.PluginFileSystemFactory
 
create(Path, boolean, int, short, long) - 类 中的方法org.apache.flink.core.fs.SafetyNetWrapperFileSystem
 
create(Path, FileSystem.WriteMode) - 类 中的方法org.apache.flink.core.fs.SafetyNetWrapperFileSystem
 
create(PluginDescriptor, ClassLoader, String[]) - 类 中的静态方法org.apache.flink.core.plugin.PluginLoader
 
create(ClassLoader) - 类 中的静态方法org.apache.flink.util.SimpleUserCodeClassLoader
 
createAccumulator() - 接口 中的方法org.apache.flink.api.common.functions.AggregateFunction
Creates a new accumulator, starting a new aggregate.
createAccumulator() - 类 中的方法org.apache.flink.api.common.functions.RichAggregateFunction
 
createAvroSerializer(Class<T>) - 类 中的方法org.apache.flink.api.java.typeutils.AvroUtils
Creates an AvroSerializer if flink-avro is present, otherwise throws an exception.
createAvroTypeInfo(Class<T>) - 类 中的方法org.apache.flink.api.java.typeutils.AvroUtils
Creates an AvroTypeInfo if flink-avro is present, otherwise throws an exception.
createBlockInfo() - 类 中的方法org.apache.flink.api.common.io.BinaryInputFormat
 
createBlockInfo() - 类 中的方法org.apache.flink.api.common.io.BinaryOutputFormat
 
createCommitter() - 接口 中的方法org.apache.flink.api.connector.sink.Sink
Creates a Committer which is part of a 2-phase-commit protocol.
createComparator(boolean, ExecutionConfig) - 接口 中的方法org.apache.flink.api.common.typeinfo.AtomicType
Creates a comparator for this type.
createComparator(boolean, ExecutionConfig) - 类 中的方法org.apache.flink.api.common.typeinfo.BasicTypeInfo
 
createComparator(boolean, ExecutionConfig) - 类 中的方法org.apache.flink.api.common.typeinfo.LocalTimeTypeInfo
 
createComparator(boolean, ExecutionConfig) - 类 中的方法org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
 
createComparator(boolean, ExecutionConfig) - 类 中的方法org.apache.flink.api.common.typeinfo.SqlTimeTypeInfo
 
createComparator(int[], boolean[], int, ExecutionConfig) - 类 中的方法org.apache.flink.api.common.typeutils.CompositeType
Generic implementation of the comparator creation.
createComparator() - 接口 中的方法org.apache.flink.api.common.typeutils.TypeComparatorFactory
 
createComparator(boolean, ExecutionConfig) - 类 中的方法org.apache.flink.api.java.typeutils.EnumTypeInfo
 
createComparator(boolean, ExecutionConfig) - 类 中的方法org.apache.flink.api.java.typeutils.GenericTypeInfo
 
createComparator(int[], boolean[], int, ExecutionConfig) - 类 中的方法org.apache.flink.api.java.typeutils.RowTypeInfo
 
createComparator() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.RuntimeComparatorFactory
 
createComparator(boolean, ExecutionConfig) - 类 中的方法org.apache.flink.api.java.typeutils.ValueTypeInfo
 
createComparator12(TypeComparator<T1>, TypeComparator<T2>) - 接口 中的方法org.apache.flink.api.common.typeutils.TypePairComparatorFactory
 
createComparator12(TypeComparator<T1>, TypeComparator<T2>) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.RuntimePairComparatorFactory
 
createComparator21(TypeComparator<T1>, TypeComparator<T2>) - 接口 中的方法org.apache.flink.api.common.typeutils.TypePairComparatorFactory
 
createComparator21(TypeComparator<T1>, TypeComparator<T2>) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.RuntimePairComparatorFactory
 
createConfiguration(Properties) - 类 中的静态方法org.apache.flink.configuration.ConfigurationUtils
Creates a new Configuration from the given Properties.
createCopy(Kryo, Collection) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.kryo.Serializers.SpecificInstanceCollectionSerializer
 
createCopy() - 类 中的方法org.apache.flink.types.Record
Creates an exact copy of this record.
createCopyWritable(T) - 类 中的静态方法org.apache.flink.util.InstantiationUtil
Clones the given writable using the serialization.
createDefaultFilter() - 类 中的静态方法org.apache.flink.api.common.io.FilePathFilter
Returns the default filter, which excludes the following files: Files starting with "_" Files starting with ".
createEntropyAware(FileSystem, Path, FileSystem.WriteMode) - 类 中的静态方法org.apache.flink.core.fs.EntropyInjector
Handles entropy injection across regular and entropy-aware file systems.
createEnumerator(SplitEnumeratorContext<NumberSequenceSource.NumberSequenceSplit>) - 类 中的方法org.apache.flink.api.connector.source.lib.NumberSequenceSource
 
createEnumerator(SplitEnumeratorContext<SplitT>) - 接口 中的方法org.apache.flink.api.connector.source.Source
Creates a new SplitEnumerator for this source, starting a new input.
createExternalResourceDriver(Configuration) - 接口 中的方法org.apache.flink.api.common.externalresource.ExternalResourceDriverFactory
Construct the ExternalResourceDriver from configuration.
createFrom(CheckedSupplier<T>) - 类 中的静态方法org.apache.flink.util.OptionalFailure
 
createGlobalCommitter() - 接口 中的方法org.apache.flink.api.connector.sink.Sink
Creates a GlobalCommitter which is part of a 2-phase-commit protocol.
createHadoopWritableTypeInfo(Class<T>) - 类 中的静态方法org.apache.flink.api.java.typeutils.TypeExtractor
 
createInputSplits(int) - 类 中的方法org.apache.flink.api.common.io.BinaryInputFormat
 
createInputSplits(int) - 类 中的方法org.apache.flink.api.common.io.FileInputFormat
Computes the input splits for the file.
createInputSplits(int) - 类 中的方法org.apache.flink.api.common.io.GenericInputFormat
 
createInputSplits(int) - 接口 中的方法org.apache.flink.api.common.io.InputFormat
 
createInputSplits(int) - 类 中的方法org.apache.flink.api.common.io.ReplicatingInputFormat
 
createInputSplits(int) - 接口 中的方法org.apache.flink.core.io.InputSplitSource
Computes the input splits.
createInstance() - 类 中的方法org.apache.flink.api.common.typeutils.base.array.BooleanPrimitiveArraySerializer
 
createInstance() - 类 中的方法org.apache.flink.api.common.typeutils.base.array.BytePrimitiveArraySerializer
 
createInstance() - 类 中的方法org.apache.flink.api.common.typeutils.base.array.CharPrimitiveArraySerializer
 
createInstance() - 类 中的方法org.apache.flink.api.common.typeutils.base.array.DoublePrimitiveArraySerializer
 
createInstance() - 类 中的方法org.apache.flink.api.common.typeutils.base.array.FloatPrimitiveArraySerializer
 
createInstance() - 类 中的方法org.apache.flink.api.common.typeutils.base.array.IntPrimitiveArraySerializer
 
createInstance() - 类 中的方法org.apache.flink.api.common.typeutils.base.array.LongPrimitiveArraySerializer
 
createInstance() - 类 中的方法org.apache.flink.api.common.typeutils.base.array.ShortPrimitiveArraySerializer
 
createInstance() - 类 中的方法org.apache.flink.api.common.typeutils.base.array.StringArraySerializer
 
createInstance() - 类 中的方法org.apache.flink.api.common.typeutils.base.BigDecSerializer
 
createInstance() - 类 中的方法org.apache.flink.api.common.typeutils.base.BigIntSerializer
 
createInstance() - 类 中的方法org.apache.flink.api.common.typeutils.base.BooleanSerializer
 
createInstance() - 类 中的方法org.apache.flink.api.common.typeutils.base.BooleanValueSerializer
 
createInstance() - 类 中的方法org.apache.flink.api.common.typeutils.base.ByteSerializer
 
createInstance() - 类 中的方法org.apache.flink.api.common.typeutils.base.ByteValueSerializer
 
createInstance() - 类 中的方法org.apache.flink.api.common.typeutils.base.CharSerializer
 
createInstance() - 类 中的方法org.apache.flink.api.common.typeutils.base.CharValueSerializer
 
createInstance() - 类 中的方法org.apache.flink.api.common.typeutils.base.DateSerializer
 
createInstance() - 类 中的方法org.apache.flink.api.common.typeutils.base.DoubleSerializer
 
createInstance() - 类 中的方法org.apache.flink.api.common.typeutils.base.DoubleValueSerializer
 
createInstance() - 类 中的方法org.apache.flink.api.common.typeutils.base.EnumSerializer
 
createInstance() - 类 中的方法org.apache.flink.api.common.typeutils.base.FloatSerializer
 
createInstance() - 类 中的方法org.apache.flink.api.common.typeutils.base.FloatValueSerializer
 
createInstance() - 类 中的方法org.apache.flink.api.common.typeutils.base.GenericArraySerializer
 
createInstance() - 类 中的方法org.apache.flink.api.common.typeutils.base.InstantSerializer
 
createInstance() - 类 中的方法org.apache.flink.api.common.typeutils.base.IntSerializer
 
createInstance() - 类 中的方法org.apache.flink.api.common.typeutils.base.IntValueSerializer
 
createInstance() - 类 中的方法org.apache.flink.api.common.typeutils.base.ListSerializer
 
createInstance() - 类 中的方法org.apache.flink.api.common.typeutils.base.LocalDateSerializer
 
createInstance() - 类 中的方法org.apache.flink.api.common.typeutils.base.LocalDateTimeSerializer
 
createInstance() - 类 中的方法org.apache.flink.api.common.typeutils.base.LocalTimeSerializer
 
createInstance() - 类 中的方法org.apache.flink.api.common.typeutils.base.LongSerializer
 
createInstance() - 类 中的方法org.apache.flink.api.common.typeutils.base.LongValueSerializer
 
createInstance() - 类 中的方法org.apache.flink.api.common.typeutils.base.MapSerializer
 
createInstance() - 类 中的方法org.apache.flink.api.common.typeutils.base.NullValueSerializer
 
createInstance() - 类 中的方法org.apache.flink.api.common.typeutils.base.ShortSerializer
 
createInstance() - 类 中的方法org.apache.flink.api.common.typeutils.base.ShortValueSerializer
 
createInstance() - 类 中的方法org.apache.flink.api.common.typeutils.base.SqlDateSerializer
 
createInstance() - 类 中的方法org.apache.flink.api.common.typeutils.base.SqlTimeSerializer
 
createInstance() - 类 中的方法org.apache.flink.api.common.typeutils.base.SqlTimestampSerializer
 
createInstance() - 类 中的方法org.apache.flink.api.common.typeutils.base.StringSerializer
 
createInstance() - 类 中的方法org.apache.flink.api.common.typeutils.base.StringValueSerializer
 
createInstance() - 类 中的方法org.apache.flink.api.common.typeutils.base.VoidSerializer
 
createInstance(Object...) - 类 中的方法org.apache.flink.api.common.typeutils.CompositeSerializer
Create new instance from its fields.
createInstance() - 类 中的方法org.apache.flink.api.common.typeutils.CompositeSerializer
 
createInstance() - 类 中的方法org.apache.flink.api.common.typeutils.SingleThreadAccessCheckingTypeSerializer
 
createInstance() - 类 中的方法org.apache.flink.api.common.typeutils.TypeSerializer
Creates a new instance of the data type.
createInstance() - 类 中的方法org.apache.flink.api.common.typeutils.UnloadableDummyTypeSerializer
 
createInstance() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer
 
createInstance() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.EitherSerializer
 
createInstance() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer
 
createInstance() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.NullableSerializer
 
createInstance() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.PojoSerializer
 
createInstance() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.RowSerializer
 
createInstance() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.Tuple0Serializer
 
createInstance(Object[]) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.Tuple0Serializer
 
createInstance() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.TupleSerializer
 
createInstance(Object[]) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.TupleSerializer
 
createInstance(Object[]) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.TupleSerializerBase
 
createInstance() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.ValueSerializer
 
createInstance() - 类 中的方法org.apache.flink.core.io.SimpleVersionedSerializerTypeSerializerProxy
 
createLegacySerializer(ExecutionConfig) - 类 中的方法org.apache.flink.api.java.typeutils.RowTypeInfo
已过时。
createNewOrderingUpToIndex(int) - 类 中的方法org.apache.flink.api.common.operators.Ordering
Creates a new ordering the represents an ordering on a prefix of the fields.
createOrReuseInstance(Object[], T) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.TupleSerializer
 
createOrReuseInstance(Object[], T) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.TupleSerializerBase
 
createOuterSerializerWithNestedSerializers(TypeSerializer<?>[]) - 类 中的方法org.apache.flink.api.common.typeutils.base.GenericArraySerializerSnapshot
 
createOuterSerializerWithNestedSerializers(TypeSerializer<?>[]) - 类 中的方法org.apache.flink.api.common.typeutils.base.ListSerializerSnapshot
 
createOuterSerializerWithNestedSerializers(TypeSerializer<?>[]) - 类 中的方法org.apache.flink.api.common.typeutils.base.MapSerializerSnapshot
 
createOuterSerializerWithNestedSerializers(TypeSerializer<?>[]) - 类 中的方法org.apache.flink.api.common.typeutils.CompositeTypeSerializerSnapshot
Creates an instance of the outer serializer with a given array of its nested serializers.
createOuterSerializerWithNestedSerializers(TypeSerializer<?>[]) - 类 中的方法org.apache.flink.api.common.typeutils.SingleThreadAccessCheckingTypeSerializer.SingleThreadAccessCheckingTypeSerializerSnapshot
 
createOuterSerializerWithNestedSerializers(TypeSerializer<?>[]) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.JavaEitherSerializerSnapshot
 
createOuterSerializerWithNestedSerializers(TypeSerializer<?>[]) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.NullableSerializer.NullableSerializerSnapshot
 
createOuterSerializerWithNestedSerializers(TypeSerializer<?>[]) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.RowSerializer.RowSerializerSnapshot
 
createOuterSerializerWithNestedSerializers(TypeSerializer<?>[]) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.TupleSerializerSnapshot
 
createOutputForSplit(String) - 接口 中的方法org.apache.flink.api.connector.source.ReaderOutput
Creates a SourceOutput for a specific Source Split.
createPluginClassLoader(PluginDescriptor, ClassLoader, String[]) - 类 中的静态方法org.apache.flink.core.plugin.PluginLoader
 
createPluginManagerFromRootFolder(Configuration) - 类 中的静态方法org.apache.flink.core.plugin.PluginUtils
 
createPojoSerializer(ExecutionConfig) - 类 中的方法org.apache.flink.api.java.typeutils.PojoTypeInfo
 
createProber(TypeComparator<PT>, TypePairComparator<PT, BT>) - 类 中的方法org.apache.flink.api.common.operators.util.JoinHashMap
 
createReader(SourceReaderContext) - 类 中的方法org.apache.flink.api.connector.source.lib.NumberSequenceSource
 
createReader(SourceReaderContext) - 接口 中的方法org.apache.flink.api.connector.source.Source
Creates a new reader to read data from the splits it gets assigned.
createRecoverableWriter() - 类 中的方法org.apache.flink.core.fs.FileSystem
Creates a new RecoverableWriter.
createRecoverableWriter() - 类 中的方法org.apache.flink.core.fs.local.LocalFileSystem
 
createRecoverableWriter() - 类 中的方法org.apache.flink.core.fs.SafetyNetWrapperFileSystem
 
createRowWithNamedPositions(RowKind, Object[], LinkedHashMap<String, Integer>) - 类 中的静态方法org.apache.flink.types.RowUtils
Internal utility for creating a row in static named-position field mode.
createSerializer(ExecutionConfig) - 类 中的方法org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
 
createSerializer(ExecutionConfig) - 类 中的方法org.apache.flink.api.common.typeinfo.BasicTypeInfo
 
createSerializer(ExecutionConfig) - 类 中的方法org.apache.flink.api.common.typeinfo.LocalTimeTypeInfo
 
createSerializer(ExecutionConfig) - 类 中的方法org.apache.flink.api.common.typeinfo.NothingTypeInfo
 
createSerializer(ExecutionConfig) - 类 中的方法org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
 
createSerializer(ExecutionConfig) - 类 中的方法org.apache.flink.api.common.typeinfo.SqlTimeTypeInfo
 
createSerializer(ExecutionConfig) - 类 中的方法org.apache.flink.api.common.typeinfo.TypeInformation
Creates a serializer for the type.
createSerializer(Class<T>) - 类 中的方法org.apache.flink.api.common.typeutils.GenericTypeSerializerSnapshot
Create a serializer that is able to serialize the generic type typeClass.
createSerializer(ExecutionConfig) - 类 中的方法org.apache.flink.api.java.typeutils.EitherTypeInfo
 
createSerializer(ExecutionConfig) - 类 中的方法org.apache.flink.api.java.typeutils.EnumTypeInfo
 
createSerializer(ExecutionConfig) - 类 中的方法org.apache.flink.api.java.typeutils.GenericTypeInfo
 
createSerializer(ExecutionConfig) - 类 中的方法org.apache.flink.api.java.typeutils.ListTypeInfo
 
createSerializer(ExecutionConfig) - 类 中的方法org.apache.flink.api.java.typeutils.MapTypeInfo
 
createSerializer(ExecutionConfig) - 类 中的方法org.apache.flink.api.java.typeutils.MissingTypeInfo
 
createSerializer(ExecutionConfig) - 类 中的方法org.apache.flink.api.java.typeutils.ObjectArrayTypeInfo
 
createSerializer(ExecutionConfig) - 类 中的方法org.apache.flink.api.java.typeutils.PojoTypeInfo
 
createSerializer(ExecutionConfig) - 类 中的方法org.apache.flink.api.java.typeutils.RowTypeInfo
 
createSerializer(Class<T>) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer.CopyableValueSerializerSnapshot
 
createSerializer(Class<T>) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.ValueSerializer.ValueSerializerSnapshot
 
createSerializer(ExecutionConfig) - 类 中的方法org.apache.flink.api.java.typeutils.TupleTypeInfo
 
createSerializer(ExecutionConfig) - 类 中的方法org.apache.flink.api.java.typeutils.ValueTypeInfo
 
createSerializerInstance(CompositeSerializer.PrecomputedParameters, TypeSerializer<?>...) - 类 中的方法org.apache.flink.api.common.typeutils.CompositeSerializer
Factory for concrete serializer.
createSocket(int) - 接口 中的方法org.apache.flink.util.NetUtils.SocketFactory
 
createSocketFromPorts(Iterator<Integer>, NetUtils.SocketFactory) - 类 中的静态方法org.apache.flink.util.NetUtils
Tries to allocate a socket from the given sets of ports.
createStatistics(List<FileStatus>, FileInputFormat.FileBaseStatistics) - 类 中的方法org.apache.flink.api.common.io.BinaryInputFormat
Fill in the statistics.
createTimestampAssigner(TimestampAssignerSupplier.Context) - 接口 中的方法org.apache.flink.api.common.eventtime.TimestampAssignerSupplier
Instantiates a TimestampAssigner.
createTimestampAssigner(TimestampAssignerSupplier.Context) - 类 中的方法org.apache.flink.api.common.eventtime.TimestampAssignerSupplier.SupplierFromSerializableTimestampAssigner
 
createTimestampAssigner(TimestampAssignerSupplier.Context) - 接口 中的方法org.apache.flink.api.common.eventtime.WatermarkStrategy
Instantiates a TimestampAssigner for assigning timestamps according to this strategy.
createTypeComparator(ExecutionConfig) - 接口 中的方法org.apache.flink.api.common.typeutils.CompositeType.TypeComparatorBuilder
 
createTypeComparatorBuilder() - 类 中的方法org.apache.flink.api.common.typeutils.CompositeType
 
createTypeComparatorBuilder() - 类 中的方法org.apache.flink.api.java.typeutils.PojoTypeInfo
 
createTypeComparatorBuilder() - 类 中的方法org.apache.flink.api.java.typeutils.RowTypeInfo
 
createTypeComparatorBuilder() - 类 中的方法org.apache.flink.api.java.typeutils.TupleTypeInfo
 
createTypeInfo(Type, Map<String, TypeInformation<?>>) - 类 中的方法org.apache.flink.api.common.typeinfo.TypeInfoFactory
Creates type information for the type the factory is targeted for.
createTypeInfo(Type, Map<String, TypeInformation<?>>) - 类 中的方法org.apache.flink.api.java.typeutils.EitherTypeInfoFactory
 
createTypeInfo(Class<T>) - 类 中的静态方法org.apache.flink.api.java.typeutils.TypeExtractor
 
createTypeInfo(Type) - 类 中的静态方法org.apache.flink.api.java.typeutils.TypeExtractor
 
createTypeInfo(Object, Class<?>, Class<?>, int) - 类 中的静态方法org.apache.flink.api.java.typeutils.TypeExtractor
Creates a TypeInformation from the given parameters.
createTypeInfo(Class<?>, Class<?>, int, TypeInformation<IN1>, TypeInformation<IN2>) - 类 中的静态方法org.apache.flink.api.java.typeutils.TypeExtractor
 
createUnionCascade(List<? extends Operator<T>>) - 类 中的静态方法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>...) - 类 中的静态方法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>...) - 类 中的静态方法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() - 类 中的方法org.apache.flink.types.parser.BigDecParser
 
createValue() - 类 中的方法org.apache.flink.types.parser.BigIntParser
 
createValue() - 类 中的方法org.apache.flink.types.parser.BooleanParser
 
createValue() - 类 中的方法org.apache.flink.types.parser.BooleanValueParser
 
createValue() - 类 中的方法org.apache.flink.types.parser.ByteParser
 
createValue() - 类 中的方法org.apache.flink.types.parser.ByteValueParser
 
createValue() - 类 中的方法org.apache.flink.types.parser.DoubleParser
 
createValue() - 类 中的方法org.apache.flink.types.parser.DoubleValueParser
 
createValue() - 类 中的方法org.apache.flink.types.parser.FieldParser
Returns an instance of the parsed value type.
createValue() - 类 中的方法org.apache.flink.types.parser.FloatParser
 
createValue() - 类 中的方法org.apache.flink.types.parser.FloatValueParser
 
createValue() - 类 中的方法org.apache.flink.types.parser.IntParser
 
createValue() - 类 中的方法org.apache.flink.types.parser.IntValueParser
 
createValue() - 类 中的方法org.apache.flink.types.parser.LongParser
 
createValue() - 类 中的方法org.apache.flink.types.parser.LongValueParser
 
createValue() - 类 中的方法org.apache.flink.types.parser.ShortParser
 
createValue() - 类 中的方法org.apache.flink.types.parser.ShortValueParser
 
createValue() - 类 中的方法org.apache.flink.types.parser.SqlDateParser
 
createValue() - 类 中的方法org.apache.flink.types.parser.SqlTimeParser
 
createValue() - 类 中的方法org.apache.flink.types.parser.SqlTimestampParser
 
createValue() - 类 中的方法org.apache.flink.types.parser.StringParser
 
createValue() - 类 中的方法org.apache.flink.types.parser.StringValueParser
 
createWatermarkGenerator(WatermarkGeneratorSupplier.Context) - 接口 中的方法org.apache.flink.api.common.eventtime.WatermarkGeneratorSupplier
Instantiates a WatermarkGenerator.
createWatermarkGenerator(WatermarkGeneratorSupplier.Context) - 接口 中的方法org.apache.flink.api.common.eventtime.WatermarkStrategy
Instantiates a WatermarkGenerator that generates watermarks according to this strategy.
createWriter(Sink.InitContext, List<WriterStateT>) - 接口 中的方法org.apache.flink.api.connector.sink.Sink
Create a SinkWriter.
cross(IN1, IN2) - 接口 中的方法org.apache.flink.api.common.functions.CrossFunction
Cross UDF method.
cross(IN1, IN2) - 类 中的方法org.apache.flink.api.common.functions.RichCrossFunction
 
CrossFunction<IN1,IN2,OUT> - org.apache.flink.api.common.functions中的接口
Interface for Cross functions.
CrossOperatorBase<IN1,IN2,OUT,FT extends CrossFunction<IN1,IN2,OUT>> - org.apache.flink.api.common.operators.base中的类
 
CrossOperatorBase(UserCodeWrapper<FT>, BinaryOperatorInformation<IN1, IN2, OUT>, String) - 类 的构造器org.apache.flink.api.common.operators.base.CrossOperatorBase
 
CrossOperatorBase(FT, BinaryOperatorInformation<IN1, IN2, OUT>, String) - 类 的构造器org.apache.flink.api.common.operators.base.CrossOperatorBase
 
CrossOperatorBase(Class<? extends FT>, BinaryOperatorInformation<IN1, IN2, OUT>, String) - 类 的构造器org.apache.flink.api.common.operators.base.CrossOperatorBase
 
CrossOperatorBase.CrossHint - org.apache.flink.api.common.operators.base中的枚举
The cross hint tells the system which sizes to expect from the data sets
CrossOperatorBase.CrossWithLarge - org.apache.flink.api.common.operators.base中的接口
Marker interface to declare the second input as the larger one.
CrossOperatorBase.CrossWithSmall - org.apache.flink.api.common.operators.base中的接口
Marker interface to declare the second input as the smaller one.
CUR_DIR - 类 中的静态变量org.apache.flink.core.fs.Path
Character denoting the current directory.
currBuffer - 类 中的变量org.apache.flink.api.common.io.DelimitedInputFormat
 
currentParallelism() - 接口 中的方法org.apache.flink.api.connector.source.SplitEnumeratorContext
Get the current parallelism of this Source.
currentSplit - 类 中的变量org.apache.flink.api.common.io.FileInputFormat
The current split that this parallel instance must consume.
currentWatermark() - 接口 中的方法org.apache.flink.api.connector.sink.SinkWriter.Context
Returns the current event-time watermark.
currLen - 类 中的变量org.apache.flink.api.common.io.DelimitedInputFormat
 
currOffset - 类 中的变量org.apache.flink.api.common.io.DelimitedInputFormat
 

D

DATA_BIND_PORT - 类 中的静态变量org.apache.flink.configuration.NettyShuffleEnvironmentOptions
The local network port that the task manager listen at for data exchange.
DATA_PORT - 类 中的静态变量org.apache.flink.configuration.NettyShuffleEnvironmentOptions
The default network port the task manager expects to receive transfer envelopes on.
DATA_SSL_ENABLED - 类 中的静态变量org.apache.flink.configuration.NettyShuffleEnvironmentOptions
Config parameter to override SSL support for taskmanager's data transport.
DataDistribution - org.apache.flink.api.common.distributions中的接口
 
DataInputDeserializer - org.apache.flink.core.memory中的类
A simple and efficient deserializer for the DataInput interface.
DataInputDeserializer() - 类 的构造器org.apache.flink.core.memory.DataInputDeserializer
 
DataInputDeserializer(byte[]) - 类 的构造器org.apache.flink.core.memory.DataInputDeserializer
 
DataInputDeserializer(byte[], int, int) - 类 的构造器org.apache.flink.core.memory.DataInputDeserializer
 
DataInputDeserializer(ByteBuffer) - 类 的构造器org.apache.flink.core.memory.DataInputDeserializer
 
DataInputView - 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 - org.apache.flink.api.java.typeutils.runtime中的类
An input stream that draws its data from a DataInputView.
DataInputViewStream(DataInputView) - 类 的构造器org.apache.flink.api.java.typeutils.runtime.DataInputViewStream
 
DataInputViewStreamWrapper - org.apache.flink.core.memory中的类
Utility class that turns an InputStream into a DataInputView.
DataInputViewStreamWrapper(InputStream) - 类 的构造器org.apache.flink.core.memory.DataInputViewStreamWrapper
 
DataOutputSerializer - org.apache.flink.core.memory中的类
A simple and efficient serializer for the DataOutput interface.
DataOutputSerializer(int) - 类 的构造器org.apache.flink.core.memory.DataOutputSerializer
 
DataOutputView - 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 - org.apache.flink.api.java.typeutils.runtime中的类
 
DataOutputViewStream(DataOutputView) - 类 的构造器org.apache.flink.api.java.typeutils.runtime.DataOutputViewStream
 
DataOutputViewStreamWrapper - org.apache.flink.core.memory中的类
Utility class that turns an OutputStream into a DataOutputView.
DataOutputViewStreamWrapper(OutputStream) - 类 的构造器org.apache.flink.core.memory.DataOutputViewStreamWrapper
 
DATE - 类 中的静态变量org.apache.flink.api.common.typeinfo.SqlTimeTypeInfo
 
DATE_TYPE_INFO - 类 中的静态变量org.apache.flink.api.common.typeinfo.BasicTypeInfo
 
DateComparator - org.apache.flink.api.common.typeutils.base中的类
 
DateComparator(boolean) - 类 的构造器org.apache.flink.api.common.typeutils.base.DateComparator
 
dateComparator - 类 中的变量org.apache.flink.api.common.typeutils.base.LocalDateTimeComparator
 
DateSerializer - org.apache.flink.api.common.typeutils.base中的类
 
DateSerializer() - 类 的构造器org.apache.flink.api.common.typeutils.base.DateSerializer
 
DateSerializer.DateSerializerSnapshot - org.apache.flink.api.common.typeutils.base中的类
Serializer configuration snapshot for compatibility and format evolution.
DateSerializerSnapshot() - 类 的构造器org.apache.flink.api.common.typeutils.base.DateSerializer.DateSerializerSnapshot
 
days(long) - 类 中的静态方法org.apache.flink.api.common.time.Time
Creates a new Time that represents the given number of days.
Deadline - org.apache.flink.api.common.time中的类
This class stores a deadline, as obtained via Deadline.now() or from Deadline.plus(Duration).
DEBUG_MEMORY_LOG - 类 中的静态变量org.apache.flink.configuration.TaskManagerOptions
 
DEBUG_MEMORY_USAGE_LOG_INTERVAL_MS - 类 中的静态变量org.apache.flink.configuration.TaskManagerOptions
 
declareManagedMemoryUseCaseAtOperatorScope(ManagedMemoryUseCase, int) - 类 中的方法org.apache.flink.api.dag.Transformation
Declares that this transformation contains certain operator scope managed memory use case.
declareManagedMemoryUseCaseAtSlotScope(ManagedMemoryUseCase) - 类 中的方法org.apache.flink.api.dag.Transformation
Declares that this transformation contains certain slot scope managed memory use case.
decodeListFromConfig(ReadableConfig, ConfigOption<List<IN>>, FunctionWithException<IN, OUT, E>) - 类 中的静态方法org.apache.flink.configuration.ConfigUtils
Gets a List of values of type IN from a ReadableConfig and transforms it to a List of type OUT based on the provided mapper function.
decompressAndDeserializeObject(byte[], ClassLoader) - 类 中的静态方法org.apache.flink.util.InstantiationUtil
 
decorateIfLimited(FileSystemFactory, String, Configuration) - 类 中的静态方法org.apache.flink.core.fs.ConnectionLimitingFactory
Decorates the given factory for a ConnectionLimitingFactory, if the given configuration configured connection limiting for the given file system scheme.
decorateInputStream(FSDataInputStream, FileInputSplit) - 类 中的方法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 - 类 中的静态变量org.apache.flink.api.common.operators.ResourceSpec
The default ResourceSpec used for operators and transformation functions.
DEFAULT_AKKA_ASK_TIMEOUT - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
DEFAULT_AKKA_CLIENT_TIMEOUT - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
Use ClientOptions#CLIENT_TIMEOUT instead.
DEFAULT_AKKA_DISPATCHER_THROUGHPUT - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
DEFAULT_AKKA_FRAMESIZE - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
DEFAULT_AKKA_LOG_LIFECYCLE_EVENTS - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
DEFAULT_AKKA_LOOKUP_TIMEOUT - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
DEFAULT_AKKA_SSL_ENABLED - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
DEFAULT_AKKA_TRANSPORT_HEARTBEAT_INTERVAL - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
Use AkkaOptions#TRANSPORT_HEARTBEAT_INTERVAL instead.
DEFAULT_AKKA_TRANSPORT_HEARTBEAT_PAUSE - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
Use AkkaOptions#TRANSPORT_HEARTBEAT_PAUSE instead.
DEFAULT_AKKA_TRANSPORT_THRESHOLD - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
Use AkkaOptions#TRANSPORT_THRESHOLD instead.
DEFAULT_AKKA_WATCH_THRESHOLD - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
This default value is no longer used and has no effect on Flink.
DEFAULT_BLOB_FETCH_BACKLOG - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
DEFAULT_BLOB_FETCH_CONCURRENT - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
DEFAULT_BLOB_FETCH_RETRIES - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
DEFAULT_BLOB_SERVER_PORT - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
DEFAULT_BLOB_SERVICE_SSL_ENABLED - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
DEFAULT_CHARSET - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
 
DEFAULT_DELIMITED_FORMAT_MAX_LINE_SAMPLES - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
DEFAULT_DELIMITED_FORMAT_MAX_SAMPLE_LEN - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
DEFAULT_DELIMITED_FORMAT_MIN_LINE_SAMPLES - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
DEFAULT_EXECUTION_RETRIES - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
The default number of execution retries.
DEFAULT_FILESYSTEM_ALWAYS_CREATE_DIRECTORY - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
DEFAULT_FILESYSTEM_OVERWRITE - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
The default behavior with respect to overwriting existing files (= not overwrite).
DEFAULT_FILESYSTEM_SCHEME - 类 中的静态变量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_FILESYSTEM_SCHEME - 类 中的静态变量org.apache.flink.configuration.CoreOptions
The default filesystem scheme, used for paths that do not declare a scheme explicitly.
DEFAULT_FLINK_PLUGINS_DIRS - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
The default Flink plugins directory if none has been specified via ConfigConstants.ENV_FLINK_PLUGINS_DIR.
DEFAULT_FLINK_USR_LIB_DIR - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
The user lib directory name.
DEFAULT_FS_STREAM_OPENING_TIMEOUT - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
The default timeout for filesystem stream opening: infinite (means max long milliseconds).
DEFAULT_HA_JOB_MANAGER_PORT - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
No longer used.
DEFAULT_HA_MODE - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
Deprecated in favour of HighAvailabilityOptions.HA_MODE
DEFAULT_HA_ZOOKEEPER_CLIENT_ACL - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
DEFAULT_JOB_MANAGER_IPC_PORT - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
DEFAULT_JOB_MANAGER_WEB_ARCHIVE_COUNT - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
DEFAULT_JOB_MANAGER_WEB_BACK_PRESSURE_CLEAN_UP_INTERVAL - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
DEFAULT_JOB_MANAGER_WEB_BACK_PRESSURE_DELAY - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
DEFAULT_JOB_MANAGER_WEB_BACK_PRESSURE_NUM_SAMPLES - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
DEFAULT_JOB_MANAGER_WEB_BACK_PRESSURE_REFRESH_INTERVAL - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
DEFAULT_JOB_MANAGER_WEB_CHECKPOINTS_DISABLE - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
Config key has been deprecated. Therefore, no default value required.
DEFAULT_JOB_MANAGER_WEB_CHECKPOINTS_HISTORY_SIZE - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
DEFAULT_JOB_MANAGER_WEB_FRONTEND_ADDRESS - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
use WebOptions.ADDRESS instead
DEFAULT_JOB_MANAGER_WEB_FRONTEND_PORT - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
use WebOptions.PORT instead
DEFAULT_JOB_MANAGER_WEB_SSL_ENABLED - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
DEFAULT_JOB_MANAGER_WEB_SUBMIT_ENABLED - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
DEFAULT_LIBRARY_CACHE_MANAGER_CLEANUP_INTERVAL - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
DEFAULT_LOCAL_NUMBER_JOB_MANAGER - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
 
DEFAULT_LOCAL_NUMBER_RESOURCE_MANAGER - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
DEFAULT_LOCAL_NUMBER_TASK_MANAGER - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
 
DEFAULT_MEMORY_MANAGER_MEMORY_FRACTION - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
has no effect
DEFAULT_MESOS_ARTIFACT_SERVER_PORT - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
has no effect
DEFAULT_MESOS_ARTIFACT_SERVER_SSL_ENABLED - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
has no effect
DEFAULT_MESOS_FAILOVER_TIMEOUT_SECS - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
has no effect
DEFAULT_MESOS_RESOURCEMANAGER_FRAMEWORK_NAME - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
has no effect
DEFAULT_MESOS_RESOURCEMANAGER_FRAMEWORK_ROLE - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
has no effect
DEFAULT_MESOS_RESOURCEMANAGER_FRAMEWORK_USER - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
has no effect
DEFAULT_METRICS_LATENCY_HISTORY_SIZE - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
DEFAULT_PARALLELISM - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
DEFAULT_PARALLELISM - 类 中的静态变量org.apache.flink.configuration.CoreOptions
 
DEFAULT_PARALLELISM_KEY - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
DEFAULT_RECOVERY_JOB_MANAGER_PORT - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
DEFAULT_RECOVERY_MODE - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
Deprecated in favour of ConfigConstants.DEFAULT_HA_MODE
DEFAULT_RESOURCE_MANAGER_IPC_PORT - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
DEFAULT_RUNTIME_HASH_JOIN_BLOOM_FILTERS - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
DEFAULT_SECURITY_SSL_ALGORITHMS - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
DEFAULT_SECURITY_SSL_ENABLED - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
DEFAULT_SECURITY_SSL_PROTOCOL - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
DEFAULT_SECURITY_SSL_VERIFY_HOSTNAME - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
DEFAULT_SORT_SPILLING_THRESHOLD - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
DEFAULT_SORT_SPILLING_THRESHOLD_KEY - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
DEFAULT_SPILLING_MAX_FAN - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
DEFAULT_SPILLING_MAX_FAN_KEY - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
DEFAULT_STATE_BACKEND - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
 
DEFAULT_TASK_CANCELLATION_INTERVAL_MILLIS - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
DEFAULT_TASK_MANAGER_DATA_PORT - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
DEFAULT_TASK_MANAGER_DATA_SSL_ENABLED - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
DEFAULT_TASK_MANAGER_DEBUG_MEMORY_USAGE_LOG_INTERVAL_MS - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
DEFAULT_TASK_MANAGER_DEBUG_MEMORY_USAGE_START_LOG_THREAD - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
DEFAULT_TASK_MANAGER_INITIAL_REGISTRATION_PAUSE - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
DEFAULT_TASK_MANAGER_IPC_PORT - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
DEFAULT_TASK_MANAGER_MAX_REGISTRATION_DURATION - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
DEFAULT_TASK_MANAGER_MAX_REGISTRATION_PAUSE - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
DEFAULT_TASK_MANAGER_MEMORY_PRE_ALLOCATE - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
has no effect
DEFAULT_TASK_MANAGER_MEMORY_SEGMENT_SIZE - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
TaskManagerOptions.MEMORY_SEGMENT_SIZE provides the default value now
DEFAULT_TASK_MANAGER_NETWORK_DEFAULT_IO_MODE - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
Not used anymore
DEFAULT_TASK_MANAGER_NETWORK_NUM_BUFFERS - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
DEFAULT_TASK_MANAGER_REFUSED_REGISTRATION_PAUSE - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
DEFAULT_TASK_MANAGER_TMP_PATH - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
CoreOptions.TMP_DIRS provides the default value now
DEFAULT_USE_LARGE_RECORD_HANDLER - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
DEFAULT_YARN_APPLICATION_MASTER_PORT - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
Not used anymore, but remain here until Flink 2.0
DEFAULT_YARN_CONTAINER_START_COMMAND_TEMPLATE - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
Start command template for Flink on YARN containers.
DEFAULT_YARN_HEAP_CUTOFF - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
Not used anymore, but remain here until Flink 2.0
DEFAULT_YARN_HEAP_CUTOFF_RATIO - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
Not used anymore, but remain here until Flink 2.0
DEFAULT_YARN_JOB_MANAGER_PORT - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
in favor of YarnConfigOptions#APPLICATION_MASTER_PORT.
DEFAULT_YARN_MIN_HEAP_CUTOFF - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
Not used anymore, but remain here until Flink 2.0
DEFAULT_ZOOKEEPER_CHECKPOINT_COUNTER_PATH - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
no longer used.
DEFAULT_ZOOKEEPER_CHECKPOINTS_PATH - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
no longer used.
DEFAULT_ZOOKEEPER_CLIENT_PORT - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
in favor of FlinkZookeeperQuorumPeer#DEFAULT_ZOOKEEPER_CLIENT_PORT.
DEFAULT_ZOOKEEPER_CONNECTION_TIMEOUT - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
DEFAULT_ZOOKEEPER_DIR_KEY - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
DEFAULT_ZOOKEEPER_INIT_LIMIT - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
in favor of FlinkZookeeperQuorumPeer#DEFAULT_ZOOKEEPER_INIT_LIMIT.
DEFAULT_ZOOKEEPER_JOBGRAPHS_PATH - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
DEFAULT_ZOOKEEPER_LATCH_PATH - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
no longer used.
DEFAULT_ZOOKEEPER_LEADER_PATH - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
no longer used.
DEFAULT_ZOOKEEPER_LEADER_PORT - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
in favor of FlinkZookeeperQuorumPeer#DEFAULT_ZOOKEEPER_LEADER_PORT.
DEFAULT_ZOOKEEPER_MAX_RETRY_ATTEMPTS - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
DEFAULT_ZOOKEEPER_MESOS_WORKERS_PATH - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
has no effect
DEFAULT_ZOOKEEPER_NAMESPACE_KEY - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
DEFAULT_ZOOKEEPER_PEER_PORT - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
in favor of FlinkZookeeperQuorumPeer#DEFAULT_ZOOKEEPER_PEER_PORT.
DEFAULT_ZOOKEEPER_RETRY_WAIT - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
DEFAULT_ZOOKEEPER_SASL_DISABLE - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
DEFAULT_ZOOKEEPER_SESSION_TIMEOUT - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
DEFAULT_ZOOKEEPER_SYNC_LIMIT - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
in favor of FlinkZookeeperQuorumPeer#DEFAULT_ZOOKEEPER_SYNC_LIMIT.
DefaultExecutorServiceLoader - org.apache.flink.core.execution中的类
The default implementation of the PipelineExecutorServiceLoader.
DefaultExecutorServiceLoader() - 类 的构造器org.apache.flink.core.execution.DefaultExecutorServiceLoader
 
DefaultInputSplitAssigner - org.apache.flink.api.common.io中的类
This is the default implementation of the InputSplitAssigner interface.
DefaultInputSplitAssigner(InputSplit[]) - 类 的构造器org.apache.flink.api.common.io.DefaultInputSplitAssigner
 
DefaultInputSplitAssigner(Collection<? extends InputSplit>) - 类 的构造器org.apache.flink.api.common.io.DefaultInputSplitAssigner
 
defaultParallelism - 类 中的变量org.apache.flink.api.common.Plan
The default parallelism to use for nodes that have no explicitly specified parallelism.
DefaultPluginManager - org.apache.flink.core.plugin中的类
Default implementation of PluginManager.
DefaultPluginManager(Collection<PluginDescriptor>, String[]) - 类 的构造器org.apache.flink.core.plugin.DefaultPluginManager
 
DefaultPluginManager(Collection<PluginDescriptor>, ClassLoader, String[]) - 类 的构造器org.apache.flink.core.plugin.DefaultPluginManager
 
defaultValue - 类 中的变量org.apache.flink.api.common.state.StateDescriptor
已过时。
To make the semantics more clear, user should manually manage the default value if the contents of the state is null
defaultValue() - 类 中的方法org.apache.flink.configuration.ConfigOption
Returns the default value, or null, if there is no default value.
defaultValue(T) - 类 中的方法org.apache.flink.configuration.ConfigOptions.OptionBuilder
已过时。
define the type explicitly first with one of the intType(), stringType(), etc.
defaultValue(T) - 类 中的方法org.apache.flink.configuration.ConfigOptions.TypedConfigOptionBuilder
Creates a ConfigOption with the given default value.
defaultValues(E...) - 类 中的方法org.apache.flink.configuration.ConfigOptions.ListConfigOptionBuilder
Creates a ConfigOption with the given default value.
DeflateInflaterInputStreamFactory - org.apache.flink.api.common.io.compression中的类
Factory for input streams that decompress the "deflate" compression format.
DeflateInflaterInputStreamFactory() - 类 的构造器org.apache.flink.api.common.io.compression.DeflateInflaterInputStreamFactory
 
delegateCompatibilityCheckToNewSnapshot(TypeSerializer<T>, CompositeTypeSerializerSnapshot<T, ? extends TypeSerializer>, TypeSerializerSnapshot<?>...) - 类 中的静态方法org.apache.flink.api.common.typeutils.CompositeTypeSerializerUtil
Delegates compatibility checks to a CompositeTypeSerializerSnapshot instance.
DelegatingConfiguration - org.apache.flink.configuration中的类
A configuration that manages a subset of keys with a common prefix from a given configuration.
DelegatingConfiguration() - 类 的构造器org.apache.flink.configuration.DelegatingConfiguration
Default constructor for serialization.
DelegatingConfiguration(Configuration, String) - 类 的构造器org.apache.flink.configuration.DelegatingConfiguration
Creates a new delegating configuration which stores its key/value pairs in the given configuration using the specifies key prefix.
delete(Path, boolean) - 类 中的方法org.apache.flink.core.fs.FileSystem
Delete a file.
delete(Path, boolean) - 类 中的方法org.apache.flink.core.fs.LimitedConnectionsFileSystem
 
delete(Path, boolean) - 类 中的方法org.apache.flink.core.fs.local.LocalFileSystem
 
delete(Path, boolean) - 类 中的方法org.apache.flink.core.fs.SafetyNetWrapperFileSystem
 
deleteDirectory(File) - 类 中的静态方法org.apache.flink.util.FileUtils
Deletes the given directory recursively.
deleteDirectoryQuietly(File) - 类 中的静态方法org.apache.flink.util.FileUtils
Deletes the given directory recursively, not reporting any I/O exceptions that occur.
deleteFileOrDirectory(File) - 类 中的静态方法org.apache.flink.util.FileUtils
Removes the given file or directory recursively.
deleteFileQuietly(Path) - 类 中的静态方法org.apache.flink.util.IOUtils
Deletes the given file.
deletePathIfEmpty(FileSystem, Path) - 类 中的静态方法org.apache.flink.util.FileUtils
Deletes the path if it is empty.
DELIMITED_FORMAT_MAX_LINE_SAMPLES - 类 中的静态变量org.apache.flink.configuration.OptimizerOptions
The maximum number of line samples taken by the compiler for delimited inputs.
DELIMITED_FORMAT_MAX_LINE_SAMPLES_KEY - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
DELIMITED_FORMAT_MAX_SAMPLE_LEN - 类 中的静态变量org.apache.flink.configuration.OptimizerOptions
The maximal length of a line sample that the compiler takes for delimited inputs.
DELIMITED_FORMAT_MAX_SAMPLE_LENGTH_KEY - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
DELIMITED_FORMAT_MIN_LINE_SAMPLES - 类 中的静态变量org.apache.flink.configuration.OptimizerOptions
The minimum number of line samples taken by the compiler for delimited inputs.
DELIMITED_FORMAT_MIN_LINE_SAMPLES_KEY - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
DelimitedInputFormat<OT> - org.apache.flink.api.common.io中的类
Base implementation for input formats that split the input at a delimiter into records.
DelimitedInputFormat() - 类 的构造器org.apache.flink.api.common.io.DelimitedInputFormat
 
DelimitedInputFormat(Path, Configuration) - 类 的构造器org.apache.flink.api.common.io.DelimitedInputFormat
 
delimiterNext(byte[], int, byte[]) - 类 中的静态方法org.apache.flink.types.parser.FieldParser
Checks if the delimiter starts at the given start position of the byte array.
DeltaIterationBase<ST,WT> - 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) - 类 的构造器org.apache.flink.api.common.operators.base.DeltaIterationBase
 
DeltaIterationBase(BinaryOperatorInformation<ST, WT, ST>, int[]) - 类 的构造器org.apache.flink.api.common.operators.base.DeltaIterationBase
 
DeltaIterationBase(BinaryOperatorInformation<ST, WT, ST>, int, String) - 类 的构造器org.apache.flink.api.common.operators.base.DeltaIterationBase
 
DeltaIterationBase(BinaryOperatorInformation<ST, WT, ST>, int[], String) - 类 的构造器org.apache.flink.api.common.operators.base.DeltaIterationBase
 
DeltaIterationBase.SolutionSetPlaceHolder<ST> - 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> - 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.
DeploymentOptions - org.apache.flink.configuration中的类
The configuration options relevant for all Executors.
DeploymentOptions() - 类 的构造器org.apache.flink.configuration.DeploymentOptions
 
DeploymentOptionsInternal - org.apache.flink.configuration中的类
Internal options used during deployment.
DeploymentOptionsInternal() - 类 的构造器org.apache.flink.configuration.DeploymentOptionsInternal
 
deprecatedKeys() - 类 中的方法org.apache.flink.configuration.ConfigOption
已过时。
depth() - 类 中的方法org.apache.flink.core.fs.Path
Returns the number of elements in this path.
DescribedEnum - org.apache.flink.configuration中的接口
Describe enum constants used in ConfigOptions.
description() - 类 中的方法org.apache.flink.configuration.ConfigOption
Returns the description of this option.
Description - org.apache.flink.configuration.description中的类
Description for ConfigOption.
Description.DescriptionBuilder - org.apache.flink.configuration.description中的类
Builder for Description.
DescriptionBuilder() - 类 的构造器org.apache.flink.configuration.description.Description.DescriptionBuilder
 
deserializationAdapter(RuntimeContext) - 类 中的静态方法org.apache.flink.api.common.serialization.RuntimeContextInitializationContextAdapters
 
deserializationAdapter(RuntimeContext, Function<MetricGroup, MetricGroup>) - 类 中的静态方法org.apache.flink.api.common.serialization.RuntimeContextInitializationContextAdapters
 
DeserializationException - org.apache.flink.types中的异常错误
An exception specifying that the deserialization caused an error.
DeserializationException() - 异常错误 的构造器org.apache.flink.types.DeserializationException
Constructs an DeserializationException with null as its error detail message.
DeserializationException(String, Throwable) - 异常错误 的构造器org.apache.flink.types.DeserializationException
Constructs an DeserializationException with the specified detail message and cause.
DeserializationException(String) - 异常错误 的构造器org.apache.flink.types.DeserializationException
Constructs an DeserializationException with the specified detail message.
DeserializationException(Throwable) - 异常错误 的构造器org.apache.flink.types.DeserializationException
Constructs an DeserializationException with the specified cause.
DeserializationSchema<T> - org.apache.flink.api.common.serialization中的接口
The deserialization schema describes how to turn the byte messages delivered by certain data sources (for example Apache Kafka) into data types (Java/Scala objects) that are processed by Flink.
DeserializationSchema.InitializationContext - org.apache.flink.api.common.serialization中的接口
A contextual information provided for DeserializationSchema.open(InitializationContext) method.
deserialize(T, DataInputView) - 类 中的方法org.apache.flink.api.common.io.BinaryInputFormat
 
deserialize(T, DataInputView) - 类 中的方法org.apache.flink.api.common.io.SerializedInputFormat
 
deserialize(byte[]) - 类 中的方法org.apache.flink.api.common.serialization.AbstractDeserializationSchema
De-serializes the byte message.
deserialize(byte[]) - 接口 中的方法org.apache.flink.api.common.serialization.DeserializationSchema
Deserializes the byte message.
deserialize(byte[], Collector<T>) - 接口 中的方法org.apache.flink.api.common.serialization.DeserializationSchema
Deserializes the byte message.
deserialize(byte[]) - 类 中的方法org.apache.flink.api.common.serialization.SimpleStringSchema
 
deserialize(byte[]) - 类 中的方法org.apache.flink.api.common.serialization.TypeInformationSerializationSchema
 
deserialize(DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.array.BooleanPrimitiveArraySerializer
 
deserialize(boolean[], DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.array.BooleanPrimitiveArraySerializer
 
deserialize(DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.array.BytePrimitiveArraySerializer
 
deserialize(byte[], DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.array.BytePrimitiveArraySerializer
 
deserialize(DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.array.CharPrimitiveArraySerializer
 
deserialize(char[], DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.array.CharPrimitiveArraySerializer
 
deserialize(DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.array.DoublePrimitiveArraySerializer
 
deserialize(double[], DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.array.DoublePrimitiveArraySerializer
 
deserialize(DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.array.FloatPrimitiveArraySerializer
 
deserialize(float[], DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.array.FloatPrimitiveArraySerializer
 
deserialize(DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.array.IntPrimitiveArraySerializer
 
deserialize(int[], DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.array.IntPrimitiveArraySerializer
 
deserialize(DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.array.LongPrimitiveArraySerializer
 
deserialize(long[], DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.array.LongPrimitiveArraySerializer
 
deserialize(DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.array.ShortPrimitiveArraySerializer
 
deserialize(short[], DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.array.ShortPrimitiveArraySerializer
 
deserialize(DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.array.StringArraySerializer
 
deserialize(String[], DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.array.StringArraySerializer
 
deserialize(DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.BigDecSerializer
 
deserialize(BigDecimal, DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.BigDecSerializer
 
deserialize(DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.BigIntSerializer
 
deserialize(BigInteger, DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.BigIntSerializer
 
deserialize(DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.BooleanSerializer
 
deserialize(Boolean, DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.BooleanSerializer
 
deserialize(DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.BooleanValueSerializer
 
deserialize(BooleanValue, DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.BooleanValueSerializer
 
deserialize(DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.ByteSerializer
 
deserialize(Byte, DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.ByteSerializer
 
deserialize(DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.ByteValueSerializer
 
deserialize(ByteValue, DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.ByteValueSerializer
 
deserialize(DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.CharSerializer
 
deserialize(Character, DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.CharSerializer
 
deserialize(DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.CharValueSerializer
 
deserialize(CharValue, DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.CharValueSerializer
 
deserialize(DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.DateSerializer
 
deserialize(Date, DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.DateSerializer
 
deserialize(DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.DoubleSerializer
 
deserialize(Double, DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.DoubleSerializer
 
deserialize(DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.DoubleValueSerializer
 
deserialize(DoubleValue, DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.DoubleValueSerializer
 
deserialize(DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.EnumSerializer
 
deserialize(T, DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.EnumSerializer
 
deserialize(DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.FloatSerializer
 
deserialize(Float, DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.FloatSerializer
 
deserialize(DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.FloatValueSerializer
 
deserialize(FloatValue, DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.FloatValueSerializer
 
deserialize(DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.GenericArraySerializer
 
deserialize(C[], DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.GenericArraySerializer
 
deserialize(DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.InstantSerializer
 
deserialize(Instant, DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.InstantSerializer
 
deserialize(DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.IntSerializer
 
deserialize(Integer, DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.IntSerializer
 
deserialize(DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.IntValueSerializer
 
deserialize(IntValue, DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.IntValueSerializer
 
deserialize(DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.ListSerializer
 
deserialize(List<T>, DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.ListSerializer
 
deserialize(DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.LocalDateSerializer
 
deserialize(LocalDate, DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.LocalDateSerializer
 
deserialize(DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.LocalDateTimeSerializer
 
deserialize(LocalDateTime, DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.LocalDateTimeSerializer
 
deserialize(DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.LocalTimeSerializer
 
deserialize(LocalTime, DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.LocalTimeSerializer
 
deserialize(DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.LongSerializer
 
deserialize(Long, DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.LongSerializer
 
deserialize(DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.LongValueSerializer
 
deserialize(LongValue, DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.LongValueSerializer
 
deserialize(DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.MapSerializer
 
deserialize(Map<K, V>, DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.MapSerializer
 
deserialize(DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.NullValueSerializer
 
deserialize(NullValue, DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.NullValueSerializer
 
deserialize(DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.ShortSerializer
 
deserialize(Short, DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.ShortSerializer
 
deserialize(DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.ShortValueSerializer
 
deserialize(ShortValue, DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.ShortValueSerializer
 
deserialize(DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.SqlDateSerializer
 
deserialize(Date, DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.SqlDateSerializer
 
deserialize(DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.SqlTimeSerializer
 
deserialize(Time, DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.SqlTimeSerializer
 
deserialize(DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.SqlTimestampSerializer
 
deserialize(Timestamp, DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.SqlTimestampSerializer
 
deserialize(DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.StringSerializer
 
deserialize(String, DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.StringSerializer
 
deserialize(DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.StringValueSerializer
 
deserialize(StringValue, DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.StringValueSerializer
 
deserialize(DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.VoidSerializer
 
deserialize(Void, DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.VoidSerializer
 
deserialize(DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.CompositeSerializer
 
deserialize(T, DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.CompositeSerializer
 
deserialize(DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.SingleThreadAccessCheckingTypeSerializer
 
deserialize(T, DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.SingleThreadAccessCheckingTypeSerializer
 
deserialize(DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.TypeSerializer
De-serializes a record from the given source input view.
deserialize(T, DataInputView) - 类 中的方法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) - 类 中的方法org.apache.flink.api.common.typeutils.UnloadableDummyTypeSerializer
 
deserialize(T, DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.UnloadableDummyTypeSerializer
 
deserialize(DataInputView) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer
 
deserialize(T, DataInputView) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer
 
deserialize(DataInputView) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.EitherSerializer
 
deserialize(Either<L, R>, DataInputView) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.EitherSerializer
 
deserialize(DataInputView) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer
 
deserialize(T, DataInputView) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer
 
deserialize(DataInputView) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.NullableSerializer
 
deserialize(T, DataInputView) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.NullableSerializer
 
deserialize(DataInputView) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.PojoSerializer
 
deserialize(T, DataInputView) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.PojoSerializer
 
deserialize(DataInputView) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.RowSerializer
 
deserialize(Row, DataInputView) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.RowSerializer
 
deserialize(DataInputView) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.Tuple0Serializer
 
deserialize(Tuple0, DataInputView) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.Tuple0Serializer
 
deserialize(DataInputView) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.TupleSerializer
 
deserialize(T, DataInputView) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.TupleSerializer
 
deserialize(DataInputView) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.ValueSerializer
 
deserialize(T, DataInputView) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.ValueSerializer
 
deserialize(int, byte[]) - 接口 中的方法org.apache.flink.core.io.SimpleVersionedSerializer
De-serializes the given data (bytes) which was serialized with the scheme of the indicated version.
deserialize(DataInputView) - 类 中的方法org.apache.flink.core.io.SimpleVersionedSerializerTypeSerializerProxy
 
deserialize(T, DataInputView) - 类 中的方法org.apache.flink.core.io.SimpleVersionedSerializerTypeSerializerProxy
 
deserialize(DataInputView) - 类 中的方法org.apache.flink.types.Record
 
deserializeAccumulators(Map<String, SerializedValue<OptionalFailure<Object>>>, ClassLoader) - 类 中的静态方法org.apache.flink.api.common.accumulators.AccumulatorHelper
Takes the serialized accumulator results and tries to deserialize them using the provided class loader.
deserializeAndUnwrapAccumulators(Map<String, SerializedValue<OptionalFailure<Object>>>, ClassLoader) - 类 中的静态方法org.apache.flink.api.common.accumulators.AccumulatorHelper
Takes the serialized accumulator results and tries to deserialize them using the provided class loader, and then try to unwrap the value unchecked.
deserializedFields1 - 类 中的变量org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
 
deserializedFields2 - 类 中的变量org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
 
deserializeError(ClassLoader) - 异常错误 中的方法org.apache.flink.util.SerializedThrowable
 
deserializeField(ObjectInputStream) - 类 中的静态方法org.apache.flink.api.java.typeutils.runtime.FieldSerializer
 
deserializeFromByteArray(TypeSerializer<T>, byte[]) - 类 中的静态方法org.apache.flink.util.InstantiationUtil
 
deserializeFromByteArray(TypeSerializer<T>, T, byte[]) - 类 中的静态方法org.apache.flink.util.InstantiationUtil
 
deserializeList(ArrayList<byte[]>, TypeSerializer<T>) - 类 中的静态方法org.apache.flink.api.common.accumulators.SerializedListAccumulator
 
deserializeObject(byte[], ClassLoader) - 类 中的静态方法org.apache.flink.util.InstantiationUtil
 
deserializeObject(InputStream, ClassLoader) - 类 中的静态方法org.apache.flink.util.InstantiationUtil
 
deserializeObject(byte[], ClassLoader, boolean) - 类 中的静态方法org.apache.flink.util.InstantiationUtil
 
deserializeObject(InputStream, ClassLoader, boolean) - 类 中的静态方法org.apache.flink.util.InstantiationUtil
 
deserializeValue(ClassLoader) - 类 中的方法org.apache.flink.util.CompressedSerializedValue
Decompress and deserialize the data to get the original object.
deserializeValue(ClassLoader) - 类 中的方法org.apache.flink.util.SerializedValue
 
DETACHED_MESSAGE - 类 中的静态变量org.apache.flink.core.execution.DetachedJobExecutionResult
 
DetachedJobExecutionResult - org.apache.flink.core.execution中的类
The JobExecutionResult returned by a context environment when executing a job in detached mode.
DetachedJobExecutionResult(JobID) - 类 的构造器org.apache.flink.core.execution.DetachedJobExecutionResult
 
directExecutor() - 类 中的静态方法org.apache.flink.util.concurrent.Executors
Return a direct executor.
DirectoryBasedPluginFinder - org.apache.flink.core.plugin中的类
This class is used to create a collection of PluginDescriptor based on directory structure for a given plugin root folder.
DirectoryBasedPluginFinder(Path) - 类 的构造器org.apache.flink.core.plugin.DirectoryBasedPluginFinder
 
disableAutoGeneratedUIDs() - 类 中的方法org.apache.flink.api.common.ExecutionConfig
Disables auto-generated UIDs.
disableAutoTypeRegistration() - 类 中的方法org.apache.flink.api.common.ExecutionConfig
Control whether Flink is automatically registering all types in the user programs with Kryo.
disableCleanupInBackground() - 类 中的方法org.apache.flink.api.common.state.StateTtlConfig.Builder
Disable default cleanup of expired state in background (enabled by default).
disableClosureCleaner() - 类 中的方法org.apache.flink.api.common.ExecutionConfig
Disables the ClosureCleaner.
DISABLED - 类 中的静态变量org.apache.flink.api.common.state.StateTtlConfig
 
DISABLED_NETWORK_BUFFER_TIMEOUT - 类 中的静态变量org.apache.flink.configuration.ExecutionOptions
A special marker value for disabling buffer timeout.
disableForceAvro() - 类 中的方法org.apache.flink.api.common.ExecutionConfig
Disables the Apache Avro serializer as the forced serializer for POJOs.
disableForceKryo() - 类 中的方法org.apache.flink.api.common.ExecutionConfig
Disable use of Kryo serializer for all POJOs.
disableGenericTypes() - 类 中的方法org.apache.flink.api.common.ExecutionConfig
Disables the use of generic types (types that would be serialized via Kryo).
disableObjectReuse() - 类 中的方法org.apache.flink.api.common.ExecutionConfig
Disables reusing objects that Flink internally uses for deserialization and passing data to user-code functions.
DISPATCHER_THROUGHPUT - 类 中的静态变量org.apache.flink.configuration.AkkaOptions
Maximum number of messages until another actor is executed by the same thread.
Disposable - org.apache.flink.util中的接口
Interface for classes that can be disposed, i.e. that have a dedicated lifecycle step to "destroy" the object.
dispose() - 接口 中的方法org.apache.flink.util.Disposable
Disposes the object and releases all resources.
DistributedCache - 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>>) - 类 的构造器org.apache.flink.api.common.cache.DistributedCache
 
DistributedCache.DistributedCacheEntry - org.apache.flink.api.common.cache中的类
Meta info about an entry in DistributedCache.
DistributedCacheEntry(String, Boolean) - 类 的构造器org.apache.flink.api.common.cache.DistributedCache.DistributedCacheEntry
Client-side constructor used by the API for initial registration.
DistributedCacheEntry(String, boolean, boolean) - 类 的构造器org.apache.flink.api.common.cache.DistributedCache.DistributedCacheEntry
Client-side constructor used during job-submission for zipped directory.
DistributedCacheEntry(String, Boolean, byte[], boolean) - 类 的构造器org.apache.flink.api.common.cache.DistributedCache.DistributedCacheEntry
Server-side constructor used during job-submission for zipped directories.
DistributedCacheEntry(String, Boolean, byte[]) - 类 的构造器org.apache.flink.api.common.cache.DistributedCache.DistributedCacheEntry
Server-side constructor used during job-submission for files.
divide(BigDecimal) - 类 中的方法org.apache.flink.api.common.resources.Resource
 
divide(int) - 类 中的方法org.apache.flink.api.common.resources.Resource
 
divide(long) - 类 中的方法org.apache.flink.configuration.MemorySize
 
divideRoundUp(int, int) - 类 中的静态方法org.apache.flink.util.MathUtils
Divide and rounding up to integer.
doForward(T, Throwable, CompletableFuture<T>) - 类 中的静态方法org.apache.flink.util.concurrent.FutureUtils
Completes the given future with either the given value or throwable, depending on which parameter is not null.
doRegister(Closeable, Map<Closeable, Object>) - 类 中的方法org.apache.flink.core.fs.CloseableRegistry
 
doRegister(WrappingProxyCloseable<? extends Closeable>, Map<Closeable, SafetyNetCloseableRegistry.PhantomDelegatingCloseableRef>) - 类 中的方法org.apache.flink.core.fs.SafetyNetCloseableRegistry
 
doRegister(C, Map<Closeable, T>) - 类 中的方法org.apache.flink.util.AbstractCloseableRegistry
Does the actual registration of the closeable with the registry map.
DOUBLE - 类 中的静态变量org.apache.flink.api.common.typeinfo.Types
Returns type information for both a primitive double and Double.
DOUBLE_ARRAY_TYPE_INFO - 类 中的静态变量org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
 
DOUBLE_PRIMITIVE_ARRAY_TYPE_INFO - 类 中的静态变量org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
 
DOUBLE_TYPE_INFO - 类 中的静态变量org.apache.flink.api.common.typeinfo.BasicTypeInfo
 
DOUBLE_VALUE_TYPE_INFO - 类 中的静态变量org.apache.flink.api.java.typeutils.ValueTypeInfo
 
DoubleComparator - org.apache.flink.api.common.typeutils.base中的类
 
DoubleComparator(boolean) - 类 的构造器org.apache.flink.api.common.typeutils.base.DoubleComparator
 
DoubleCounter - org.apache.flink.api.common.accumulators中的类
An accumulator that sums up double values.
DoubleCounter() - 类 的构造器org.apache.flink.api.common.accumulators.DoubleCounter
 
DoubleCounter(double) - 类 的构造器org.apache.flink.api.common.accumulators.DoubleCounter
 
DoubleMaximum - org.apache.flink.api.common.accumulators中的类
An accumulator that finds the maximum double value.
DoubleMaximum() - 类 的构造器org.apache.flink.api.common.accumulators.DoubleMaximum
 
DoubleMaximum(double) - 类 的构造器org.apache.flink.api.common.accumulators.DoubleMaximum
 
DoubleMinimum - org.apache.flink.api.common.accumulators中的类
An accumulator that finds the minimum double value.
DoubleMinimum() - 类 的构造器org.apache.flink.api.common.accumulators.DoubleMinimum
 
DoubleMinimum(double) - 类 的构造器org.apache.flink.api.common.accumulators.DoubleMinimum
 
DoubleParser - org.apache.flink.types.parser中的类
Parses a text field into a Double.
DoubleParser() - 类 的构造器org.apache.flink.types.parser.DoubleParser
 
DoublePrimitiveArrayComparator - org.apache.flink.api.common.typeutils.base.array中的类
 
DoublePrimitiveArrayComparator(boolean) - 类 的构造器org.apache.flink.api.common.typeutils.base.array.DoublePrimitiveArrayComparator
 
DoublePrimitiveArraySerializer - org.apache.flink.api.common.typeutils.base.array中的类
A serializer for double arrays.
DoublePrimitiveArraySerializer() - 类 的构造器org.apache.flink.api.common.typeutils.base.array.DoublePrimitiveArraySerializer
 
DoublePrimitiveArraySerializer.DoublePrimitiveArraySerializerSnapshot - org.apache.flink.api.common.typeutils.base.array中的类
Serializer configuration snapshot for compatibility and format evolution.
DoublePrimitiveArraySerializerSnapshot() - 类 的构造器org.apache.flink.api.common.typeutils.base.array.DoublePrimitiveArraySerializer.DoublePrimitiveArraySerializerSnapshot
 
DoubleSerializer - org.apache.flink.api.common.typeutils.base中的类
Type serializer for Double.
DoubleSerializer() - 类 的构造器org.apache.flink.api.common.typeutils.base.DoubleSerializer
 
DoubleSerializer.DoubleSerializerSnapshot - org.apache.flink.api.common.typeutils.base中的类
Serializer configuration snapshot for compatibility and format evolution.
DoubleSerializerSnapshot() - 类 的构造器org.apache.flink.api.common.typeutils.base.DoubleSerializer.DoubleSerializerSnapshot
 
DoubleSumAggregator - org.apache.flink.api.common.aggregators中的类
An Aggregator that sums up DoubleValue values.
DoubleSumAggregator() - 类 的构造器org.apache.flink.api.common.aggregators.DoubleSumAggregator
 
doubleType() - 类 中的方法org.apache.flink.configuration.ConfigOptions.OptionBuilder
Defines that the value of the option should be of Double type.
DoubleValue - org.apache.flink.types中的类
Boxed serializable and comparable double precision floating point type, representing the primitive type double.
DoubleValue() - 类 的构造器org.apache.flink.types.DoubleValue
Initializes the encapsulated double with 0.0.
DoubleValue(double) - 类 的构造器org.apache.flink.types.DoubleValue
Initializes the encapsulated double with the provided value.
DoubleValueComparator - org.apache.flink.api.common.typeutils.base中的类
Specialized comparator for DoubleValue based on CopyableValueComparator.
DoubleValueComparator(boolean) - 类 的构造器org.apache.flink.api.common.typeutils.base.DoubleValueComparator
 
DoubleValueParser - org.apache.flink.types.parser中的类
Parses a text field into a DoubleValue.
DoubleValueParser() - 类 的构造器org.apache.flink.types.parser.DoubleValueParser
 
DoubleValueSerializer - org.apache.flink.api.common.typeutils.base中的类
 
DoubleValueSerializer() - 类 的构造器org.apache.flink.api.common.typeutils.base.DoubleValueSerializer
 
DoubleValueSerializer.DoubleValueSerializerSnapshot - org.apache.flink.api.common.typeutils.base中的类
Serializer configuration snapshot for compatibility and format evolution.
DoubleValueSerializerSnapshot() - 类 的构造器org.apache.flink.api.common.typeutils.base.DoubleValueSerializer.DoubleValueSerializerSnapshot
 
DoubleZeroConvergence - org.apache.flink.api.common.aggregators中的类
A ConvergenceCriterion over an Aggregator that defines convergence as reached once the aggregator holds the value zero.
DoubleZeroConvergence() - 类 的构造器org.apache.flink.api.common.aggregators.DoubleZeroConvergence
 
doUnRegister(Closeable, Map<Closeable, Object>) - 类 中的方法org.apache.flink.core.fs.CloseableRegistry
 
doUnRegister(WrappingProxyCloseable<? extends Closeable>, Map<Closeable, SafetyNetCloseableRegistry.PhantomDelegatingCloseableRef>) - 类 中的方法org.apache.flink.core.fs.SafetyNetCloseableRegistry
 
doUnRegister(C, Map<Closeable, T>) - 类 中的方法org.apache.flink.util.AbstractCloseableRegistry
Does the actual un-registration of the closeable from the registry map.
DualInputOperator<IN1,IN2,OUT,FT extends Function> - org.apache.flink.api.common.operators中的类
Abstract operator superclass for all operators that have two inputs, like "Join", "CoGroup", or "Cross".
DualInputOperator(UserCodeWrapper<FT>, BinaryOperatorInformation<IN1, IN2, OUT>, String) - 类 的构造器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) - 类 的构造器org.apache.flink.api.common.operators.DualInputOperator
Creates a new abstract dual-input operator with the given name wrapping the given user function.
DualInputSemanticProperties - org.apache.flink.api.common.operators中的类
Container for the semantic properties associated to a dual input operator.
DualInputSemanticProperties() - 类 的构造器org.apache.flink.api.common.operators.DualInputSemanticProperties
 
DummyAvroKryoSerializerClass() - 类 的构造器org.apache.flink.api.java.typeutils.runtime.kryo.Serializers.DummyAvroKryoSerializerClass
 
DummyAvroRegisteredClass() - 类 的构造器org.apache.flink.api.java.typeutils.runtime.kryo.Serializers.DummyAvroRegisteredClass
 
DummyKryoSerializerClass() - 类 的构造器org.apache.flink.api.java.typeutils.runtime.KryoRegistrationSerializerConfigSnapshot.DummyKryoSerializerClass
 
DummyRegisteredClass() - 类 的构造器org.apache.flink.api.java.typeutils.runtime.KryoRegistrationSerializerConfigSnapshot.DummyRegisteredClass
 
duplicate() - 类 中的方法org.apache.flink.api.common.typeutils.base.array.BooleanPrimitiveArrayComparator
 
duplicate() - 类 中的方法org.apache.flink.api.common.typeutils.base.array.BytePrimitiveArrayComparator
 
duplicate() - 类 中的方法org.apache.flink.api.common.typeutils.base.array.CharPrimitiveArrayComparator
 
duplicate() - 类 中的方法org.apache.flink.api.common.typeutils.base.array.DoublePrimitiveArrayComparator
 
duplicate() - 类 中的方法org.apache.flink.api.common.typeutils.base.array.FloatPrimitiveArrayComparator
 
duplicate() - 类 中的方法org.apache.flink.api.common.typeutils.base.array.IntPrimitiveArrayComparator
 
duplicate() - 类 中的方法org.apache.flink.api.common.typeutils.base.array.LongPrimitiveArrayComparator
 
duplicate() - 类 中的方法org.apache.flink.api.common.typeutils.base.array.ShortPrimitiveArrayComparator
 
duplicate() - 类 中的方法org.apache.flink.api.common.typeutils.base.BigDecComparator
 
duplicate() - 类 中的方法org.apache.flink.api.common.typeutils.base.BigIntComparator
 
duplicate() - 类 中的方法org.apache.flink.api.common.typeutils.base.BooleanComparator
 
duplicate() - 类 中的方法org.apache.flink.api.common.typeutils.base.BooleanValueComparator
 
duplicate() - 类 中的方法org.apache.flink.api.common.typeutils.base.ByteComparator
 
duplicate() - 类 中的方法org.apache.flink.api.common.typeutils.base.ByteValueComparator
 
duplicate() - 类 中的方法org.apache.flink.api.common.typeutils.base.CharComparator
 
duplicate() - 类 中的方法org.apache.flink.api.common.typeutils.base.CharValueComparator
 
duplicate() - 类 中的方法org.apache.flink.api.common.typeutils.base.DateComparator
 
duplicate() - 类 中的方法org.apache.flink.api.common.typeutils.base.DoubleComparator
 
duplicate() - 类 中的方法org.apache.flink.api.common.typeutils.base.DoubleValueComparator
 
duplicate() - 类 中的方法org.apache.flink.api.common.typeutils.base.EnumComparator
 
duplicate() - 类 中的方法org.apache.flink.api.common.typeutils.base.EnumSerializer
 
duplicate() - 类 中的方法org.apache.flink.api.common.typeutils.base.FloatComparator
 
duplicate() - 类 中的方法org.apache.flink.api.common.typeutils.base.FloatValueComparator
 
duplicate() - 类 中的方法org.apache.flink.api.common.typeutils.base.GenericArraySerializer
 
duplicate() - 类 中的方法org.apache.flink.api.common.typeutils.base.InstantComparator
 
duplicate() - 类 中的方法org.apache.flink.api.common.typeutils.base.IntComparator
 
duplicate() - 类 中的方法org.apache.flink.api.common.typeutils.base.IntValueComparator
 
duplicate() - 类 中的方法org.apache.flink.api.common.typeutils.base.ListSerializer
 
duplicate() - 类 中的方法org.apache.flink.api.common.typeutils.base.LocalDateComparator
 
duplicate() - 类 中的方法org.apache.flink.api.common.typeutils.base.LocalDateTimeComparator
 
duplicate() - 类 中的方法org.apache.flink.api.common.typeutils.base.LocalTimeComparator
 
duplicate() - 类 中的方法org.apache.flink.api.common.typeutils.base.LongComparator
 
duplicate() - 类 中的方法org.apache.flink.api.common.typeutils.base.LongValueComparator
 
duplicate() - 类 中的方法org.apache.flink.api.common.typeutils.base.MapSerializer
 
duplicate() - 类 中的方法org.apache.flink.api.common.typeutils.base.NullValueComparator
 
duplicate() - 类 中的方法org.apache.flink.api.common.typeutils.base.ShortComparator
 
duplicate() - 类 中的方法org.apache.flink.api.common.typeutils.base.ShortValueComparator
 
duplicate() - 类 中的方法org.apache.flink.api.common.typeutils.base.SqlTimestampComparator
 
duplicate() - 类 中的方法org.apache.flink.api.common.typeutils.base.StringComparator
 
duplicate() - 类 中的方法org.apache.flink.api.common.typeutils.base.StringValueComparator
 
duplicate() - 类 中的方法org.apache.flink.api.common.typeutils.base.TypeSerializerSingleton
 
duplicate() - 类 中的方法org.apache.flink.api.common.typeutils.CompositeSerializer
 
duplicate() - 类 中的方法org.apache.flink.api.common.typeutils.SingleThreadAccessCheckingTypeSerializer
 
duplicate() - 类 中的方法org.apache.flink.api.common.typeutils.TypeComparator
Creates a copy of this class.
duplicate() - 类 中的方法org.apache.flink.api.common.typeutils.TypeSerializer
Creates a deep copy of this serializer if it is necessary, i.e. if it is stateful.
duplicate() - 类 中的方法org.apache.flink.api.common.typeutils.UnloadableDummyTypeSerializer
 
duplicate() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.CopyableValueComparator
 
duplicate() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer
 
duplicate() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.EitherSerializer
 
duplicate() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.GenericTypeComparator
 
duplicate() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer
 
duplicate() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.NullableSerializer
 
duplicate() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.NullAwareComparator
 
duplicate() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.PojoComparator
 
duplicate() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.PojoSerializer
 
duplicate() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.RowComparator
 
duplicate() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.RowSerializer
 
duplicate() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.Tuple0Serializer
 
duplicate() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.TupleComparator
 
duplicate() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.TupleSerializer
 
duplicate() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.ValueComparator
 
duplicate() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.ValueSerializer
 
duplicate() - 类 中的方法org.apache.flink.core.io.SimpleVersionedSerializerTypeSerializerProxy
 
durationType() - 类 中的方法org.apache.flink.configuration.ConfigOptions.OptionBuilder
Defines that the value of the option should be of Duration type.
DynamicCodeLoadingException - org.apache.flink.util中的异常错误
An exception that is thrown if the dynamic instantiation of code fails.
DynamicCodeLoadingException(Throwable) - 异常错误 的构造器org.apache.flink.util.DynamicCodeLoadingException
Creates a new exception with the given cause.
DynamicCodeLoadingException(String, Throwable) - 异常错误 的构造器org.apache.flink.util.DynamicCodeLoadingException
Creates a new exception with the given message and cause.

E

EAGER_FUNCTION_MESSAGE - 类 中的静态变量org.apache.flink.core.execution.DetachedJobExecutionResult
 
EITHER(TypeInformation<L>, TypeInformation<R>) - 类 中的静态方法org.apache.flink.api.common.typeinfo.Types
Returns type information for Flink's Either type.
Either<L,R> - org.apache.flink.types中的类
This type represents a value of one two possible types, Left or Right (a disjoint union), inspired by Scala's Either type.
Either() - 类 的构造器org.apache.flink.types.Either
 
Either.Left<L,R> - org.apache.flink.types中的类
A left value of Either
Either.Right<L,R> - org.apache.flink.types中的类
A right value of Either
EitherSerializer<L,R> - org.apache.flink.api.java.typeutils.runtime中的类
A TypeSerializer for the Either type of the Java class.
EitherSerializer(TypeSerializer<L>, TypeSerializer<R>) - 类 的构造器org.apache.flink.api.java.typeutils.runtime.EitherSerializer
 
EitherSerializerConfigSnapshot<L,R> - org.apache.flink.api.java.typeutils.runtime中的类
已过时。
EitherSerializerConfigSnapshot() - 类 的构造器org.apache.flink.api.java.typeutils.runtime.EitherSerializerConfigSnapshot
已过时。
This empty nullary constructor is required for deserializing the configuration.
EitherSerializerSnapshot<L,R> - org.apache.flink.api.java.typeutils.runtime中的类
已过时。
this snapshot class is no longer used by any serializers. Instead, JavaEitherSerializerSnapshot is used.
EitherSerializerSnapshot() - 类 的构造器org.apache.flink.api.java.typeutils.runtime.EitherSerializerSnapshot
已过时。
Constructor for read instantiation.
EitherSerializerSnapshot(TypeSerializer<L>, TypeSerializer<R>) - 类 的构造器org.apache.flink.api.java.typeutils.runtime.EitherSerializerSnapshot
已过时。
Constructor to create the snapshot for writing.
EitherTypeInfo<L,R> - org.apache.flink.api.java.typeutils中的类
A TypeInformation for the Either type of the Java API.
EitherTypeInfo(TypeInformation<L>, TypeInformation<R>) - 类 的构造器org.apache.flink.api.java.typeutils.EitherTypeInfo
 
EitherTypeInfoFactory<L,R> - org.apache.flink.api.java.typeutils中的类
 
EitherTypeInfoFactory() - 类 的构造器org.apache.flink.api.java.typeutils.EitherTypeInfoFactory
 
emitWatermark(Watermark) - 接口 中的方法org.apache.flink.api.common.eventtime.WatermarkOutput
Emits the given watermark.
emitWatermark(Watermark) - 接口 中的方法org.apache.flink.api.connector.source.ReaderOutput
Emits the given watermark.
empty() - 类 中的静态方法org.apache.flink.types.SerializableOptional
 
empty() - 接口 中的静态方法org.apache.flink.util.CloseableIterable
Returns an empty iterator.
empty() - 接口 中的静态方法org.apache.flink.util.CloseableIterator
 
EMPTY_ARGS - 接口 中的静态变量org.apache.flink.api.common.operators.MailboxExecutor
A constant for empty args to save on object allocation.
EMPTY_INSTANCE - 接口 中的静态变量org.apache.flink.util.CloseableIterator
 
EMPTY_LIST - 类 中的静态变量org.apache.flink.api.common.operators.util.FieldList
 
EMPTY_SET - 类 中的静态变量org.apache.flink.api.common.operators.util.FieldSet
 
EMPTY_STRING_ARRAY - 类 中的静态变量org.apache.flink.util.StringUtils
An empty string array.
emptyClassArray() - 类 中的静态方法org.apache.flink.api.common.operators.AbstractUdfOperator
Generic utility function that returns an empty class array.
EmptySemanticProperties() - 类 的构造器org.apache.flink.api.common.operators.SemanticProperties.EmptySemanticProperties
 
ENABLE_FINE_GRAINED_RESOURCE_MANAGEMENT - 类 中的静态变量org.apache.flink.configuration.ClusterOptions
 
ENABLE_FLAMEGRAPH - 类 中的静态变量org.apache.flink.configuration.RestOptions
Enables the experimental flame graph feature.
ENABLE_QUERYABLE_STATE_PROXY_SERVER - 类 中的静态变量org.apache.flink.configuration.QueryableStateOptions
Option whether the queryable state proxy and server should be enabled where possible and configurable.
ENABLE_STATE_CHANGE_LOG - 类 中的静态变量org.apache.flink.configuration.CheckpointingOptions
Whether to enable state change log.
enableAutoGeneratedUIDs() - 类 中的方法org.apache.flink.api.common.ExecutionConfig
Enables the Flink runtime to auto-generate UID's for operators.
enableClosureCleaner() - 类 中的方法org.apache.flink.api.common.ExecutionConfig
Enables the ClosureCleaner.
enableForceAvro() - 类 中的方法org.apache.flink.api.common.ExecutionConfig
Forces Flink to use the Apache Avro serializer for POJOs.
enableForceKryo() - 类 中的方法org.apache.flink.api.common.ExecutionConfig
Force TypeExtractor to use Kryo serializer for POJOS even though we could analyze as POJO.
enableGenericTypes() - 类 中的方法org.apache.flink.api.common.ExecutionConfig
Enables the use generic types which are serialized via Kryo.
enableObjectReuse() - 类 中的方法org.apache.flink.api.common.ExecutionConfig
Enables reusing objects that Flink internally uses for deserialization and passing data to user-code functions.
enableQuotedStringParsing(char) - 类 中的方法org.apache.flink.api.common.io.GenericCsvInputFormat
 
enableQuotedStringParsing(byte) - 类 中的方法org.apache.flink.types.parser.StringParser
 
enableQuotedStringParsing(byte) - 类 中的方法org.apache.flink.types.parser.StringValueParser
 
enableTimeToLive(StateTtlConfig) - 类 中的方法org.apache.flink.api.common.state.StateDescriptor
Configures optional activation of state time-to-live (TTL).
encode(IN, OutputStream) - 接口 中的方法org.apache.flink.api.common.serialization.Encoder
Writes one element to the bucket file.
encode(IN, OutputStream) - 类 中的方法org.apache.flink.api.common.serialization.SimpleStringEncoder
 
encodeArrayToConfig(WritableConfig, ConfigOption<List<OUT>>, IN[], Function<IN, OUT>) - 类 中的静态方法org.apache.flink.configuration.ConfigUtils
Puts an array of values of type IN in a WritableConfig as a ConfigOption of type List of type OUT.
encodeCollectionToConfig(WritableConfig, ConfigOption<List<OUT>>, Collection<IN>, Function<IN, OUT>) - 类 中的静态方法org.apache.flink.configuration.ConfigUtils
Puts a Collection of values of type IN in a WritableConfig as a ConfigOption of type List of type OUT.
Encoder<IN> - org.apache.flink.api.common.serialization中的接口
A Encoder is used by the streaming file sink to perform the actual writing of the incoming elements to the files in a bucket.
endOfInput() - 接口 中的方法org.apache.flink.api.connector.sink.GlobalCommitter
Signals that there is no committable any more.
endsWithDelimiter(byte[], int, byte[]) - 类 中的静态方法org.apache.flink.types.parser.FieldParser
Checks if the given bytes ends with the delimiter at the given end position.
ensureSerializable(Object) - 类 中的静态方法org.apache.flink.api.java.ClosureCleaner
 
entries() - 接口 中的方法org.apache.flink.api.common.state.BroadcastState
Returns all the mappings in the state.
entries() - 接口 中的方法org.apache.flink.api.common.state.MapState
Returns all the mappings in the state.
EntropyInjectingFileSystem - org.apache.flink.core.fs中的接口
An interface to be implemented by a FileSystem that is aware of entropy injection.
EntropyInjector - org.apache.flink.core.fs中的类
This class offers utilities for entropy injection for FileSystems that implement EntropyInjectingFileSystem.
entrySet() - 类 中的方法org.apache.flink.types.MapValue
 
ENUM(Class<E>) - 类 中的静态方法org.apache.flink.api.common.typeinfo.Types
Returns type information for Java enumerations.
EnumComparator<T extends Enum<T>> - org.apache.flink.api.common.typeutils.base中的类
 
EnumComparator(boolean) - 类 的构造器org.apache.flink.api.common.typeutils.base.EnumComparator
 
ENUMERATE_NESTED_FILES_FLAG - 类 中的静态变量org.apache.flink.api.common.io.FileInputFormat
The config parameter which defines whether input directories are recursively traversed.
enumerateNestedFiles - 类 中的变量org.apache.flink.api.common.io.FileInputFormat
The flag to specify whether recursive traversal of the input directory structure is enabled.
EnumSerializer<T extends Enum<T>> - org.apache.flink.api.common.typeutils.base中的类
TypeSerializer for Java enums.
EnumSerializer(Class<T>) - 类 的构造器org.apache.flink.api.common.typeutils.base.EnumSerializer
 
EnumSerializer.EnumSerializerConfigSnapshot<T extends Enum<T>> - org.apache.flink.api.common.typeutils.base中的类
已过时。
EnumSerializer.EnumSerializerSnapshot<T extends Enum<T>> - org.apache.flink.api.common.typeutils.base中的类
EnumSerializerConfigSnapshot() - 类 的构造器org.apache.flink.api.common.typeutils.base.EnumSerializer.EnumSerializerConfigSnapshot
已过时。
This empty nullary constructor is required for deserializing the configuration.
EnumSerializerSnapshot() - 类 的构造器org.apache.flink.api.common.typeutils.base.EnumSerializer.EnumSerializerSnapshot
 
enumType(Class<T>) - 类 中的方法org.apache.flink.configuration.ConfigOptions.OptionBuilder
Defines that the value of the option should be of Enum type.
EnumTypeInfo<T extends Enum<T>> - org.apache.flink.api.java.typeutils中的类
A TypeInformation for java enumeration types.
EnumTypeInfo(Class<T>) - 类 的构造器org.apache.flink.api.java.typeutils.EnumTypeInfo
 
ENV_FLINK_BIN_DIR - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
The environment variable name which contains the location of the bin directory.
ENV_FLINK_CONF_DIR - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
The environment variable name which contains the location of the configuration directory.
ENV_FLINK_HOME_DIR - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
The environment variable name which contains the Flink installation root directory.
ENV_FLINK_LIB_DIR - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
The environment variable name which contains the location of the lib folder.
ENV_FLINK_OPT_DIR - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
The environment variable name which contains the location of the opt directory.
ENV_FLINK_PLUGINS_DIR - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
The environment variable name which contains the location of the plugins folder.
eof() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.NoFetchingInput
 
equals(Object) - 类 中的方法org.apache.flink.api.common.cache.DistributedCache.DistributedCacheEntry
 
equals(Object) - 类 中的方法org.apache.flink.api.common.eventtime.Watermark
 
equals(Object) - 类 中的方法org.apache.flink.api.common.ExecutionConfig
 
equals(Object) - 类 中的方法org.apache.flink.api.common.ExecutionConfig.GlobalJobParameters
 
equals(Object) - 类 中的方法org.apache.flink.api.common.operators.Ordering
 
equals(Object) - 类 中的方法org.apache.flink.api.common.operators.ResourceSpec
 
equals(Object) - 类 中的方法org.apache.flink.api.common.operators.SlotSharingGroup
 
equals(Object) - 类 中的方法org.apache.flink.api.common.operators.util.FieldSet
 
equals(Object) - 类 中的方法org.apache.flink.api.common.operators.util.TypeComparable
 
equals(Object) - 类 中的方法org.apache.flink.api.common.resources.Resource
 
equals(Object) - 类 中的方法org.apache.flink.api.common.restartstrategy.RestartStrategies.ExponentialDelayRestartStrategyConfiguration
 
equals(Object) - 类 中的方法org.apache.flink.api.common.restartstrategy.RestartStrategies.FailureRateRestartStrategyConfiguration
 
equals(Object) - 类 中的方法org.apache.flink.api.common.restartstrategy.RestartStrategies.FallbackRestartStrategyConfiguration
 
equals(Object) - 类 中的方法org.apache.flink.api.common.restartstrategy.RestartStrategies.FixedDelayRestartStrategyConfiguration
 
equals(Object) - 类 中的方法org.apache.flink.api.common.restartstrategy.RestartStrategies.NoRestartStrategyConfiguration
 
equals(Object) - 类 中的方法org.apache.flink.api.common.state.StateDescriptor
 
equals(Object) - 类 中的方法org.apache.flink.api.common.time.Time
 
equals(Object) - 类 中的方法org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
 
equals(Object) - 类 中的方法org.apache.flink.api.common.typeinfo.BasicTypeInfo
 
equals(Object) - 类 中的方法org.apache.flink.api.common.typeinfo.LocalTimeTypeInfo
 
equals(Object) - 类 中的方法org.apache.flink.api.common.typeinfo.NothingTypeInfo
 
equals(Object) - 类 中的方法org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
 
equals(Object) - 类 中的方法org.apache.flink.api.common.typeinfo.SqlTimeTypeInfo
 
equals(Object) - 类 中的方法org.apache.flink.api.common.typeinfo.TypeHint
 
equals(Object) - 类 中的方法org.apache.flink.api.common.typeinfo.TypeInformation
 
equals(Object) - 类 中的方法org.apache.flink.api.common.typeutils.BackwardsCompatibleSerializerSnapshot
 
equals(Object) - 类 中的方法org.apache.flink.api.common.typeutils.base.EnumSerializer.EnumSerializerConfigSnapshot
已过时。
 
equals(Object) - 类 中的方法org.apache.flink.api.common.typeutils.base.EnumSerializer
 
equals(Object) - 类 中的方法org.apache.flink.api.common.typeutils.base.GenericArraySerializer
 
equals(Object) - 类 中的方法org.apache.flink.api.common.typeutils.base.ListSerializer
 
equals(Object) - 类 中的方法org.apache.flink.api.common.typeutils.base.MapSerializer
 
equals(Object) - 类 中的方法org.apache.flink.api.common.typeutils.base.TypeSerializerSingleton
 
equals(Object) - 类 中的方法org.apache.flink.api.common.typeutils.CompositeSerializer
 
equals(Object) - 类 中的方法org.apache.flink.api.common.typeutils.CompositeType
 
equals(Object) - 类 中的方法org.apache.flink.api.common.typeutils.CompositeTypeSerializerConfigSnapshot
 
equals(Object) - 类 中的方法org.apache.flink.api.common.typeutils.GenericTypeSerializerConfigSnapshot
 
equals(Object) - 类 中的方法org.apache.flink.api.common.typeutils.ParameterlessTypeSerializerConfig
已过时。
 
equals(Object) - 类 中的方法org.apache.flink.api.common.typeutils.SimpleTypeSerializerSnapshot
 
equals(Object) - 类 中的方法org.apache.flink.api.common.typeutils.SingleThreadAccessCheckingTypeSerializer
 
equals(Object) - 类 中的方法org.apache.flink.api.common.typeutils.TypeSerializer
 
equals(Object) - 类 中的方法org.apache.flink.api.common.typeutils.UnloadableDummyTypeSerializer
 
equals(Object) - 类 中的方法org.apache.flink.api.connector.source.ReaderInfo
 
equals(Object) - 类 中的方法org.apache.flink.api.dag.Transformation
 
equals(Object) - 类 中的方法org.apache.flink.api.java.tuple.Tuple0
Deep equality for tuples by calling equals() on the tuple members.
equals(Object) - 类 中的方法org.apache.flink.api.java.tuple.Tuple1
Deep equality for tuples by calling equals() on the tuple members.
equals(Object) - 类 中的方法org.apache.flink.api.java.tuple.Tuple10
Deep equality for tuples by calling equals() on the tuple members.
equals(Object) - 类 中的方法org.apache.flink.api.java.tuple.Tuple11
Deep equality for tuples by calling equals() on the tuple members.
equals(Object) - 类 中的方法org.apache.flink.api.java.tuple.Tuple12
Deep equality for tuples by calling equals() on the tuple members.
equals(Object) - 类 中的方法org.apache.flink.api.java.tuple.Tuple13
Deep equality for tuples by calling equals() on the tuple members.
equals(Object) - 类 中的方法org.apache.flink.api.java.tuple.Tuple14
Deep equality for tuples by calling equals() on the tuple members.
equals(Object) - 类 中的方法org.apache.flink.api.java.tuple.Tuple15
Deep equality for tuples by calling equals() on the tuple members.
equals(Object) - 类 中的方法org.apache.flink.api.java.tuple.Tuple16
Deep equality for tuples by calling equals() on the tuple members.
equals(Object) - 类 中的方法org.apache.flink.api.java.tuple.Tuple17
Deep equality for tuples by calling equals() on the tuple members.
equals(Object) - 类 中的方法org.apache.flink.api.java.tuple.Tuple18
Deep equality for tuples by calling equals() on the tuple members.
equals(Object) - 类 中的方法org.apache.flink.api.java.tuple.Tuple19
Deep equality for tuples by calling equals() on the tuple members.
equals(Object) - 类 中的方法org.apache.flink.api.java.tuple.Tuple2
Deep equality for tuples by calling equals() on the tuple members.
equals(Object) - 类 中的方法org.apache.flink.api.java.tuple.Tuple20
Deep equality for tuples by calling equals() on the tuple members.
equals(Object) - 类 中的方法org.apache.flink.api.java.tuple.Tuple21
Deep equality for tuples by calling equals() on the tuple members.
equals(Object) - 类 中的方法org.apache.flink.api.java.tuple.Tuple22
Deep equality for tuples by calling equals() on the tuple members.
equals(Object) - 类 中的方法org.apache.flink.api.java.tuple.Tuple23
Deep equality for tuples by calling equals() on the tuple members.
equals(Object) - 类 中的方法org.apache.flink.api.java.tuple.Tuple24
Deep equality for tuples by calling equals() on the tuple members.
equals(Object) - 类 中的方法org.apache.flink.api.java.tuple.Tuple25
Deep equality for tuples by calling equals() on the tuple members.
equals(Object) - 类 中的方法org.apache.flink.api.java.tuple.Tuple3
Deep equality for tuples by calling equals() on the tuple members.
equals(Object) - 类 中的方法org.apache.flink.api.java.tuple.Tuple4
Deep equality for tuples by calling equals() on the tuple members.
equals(Object) - 类 中的方法org.apache.flink.api.java.tuple.Tuple5
Deep equality for tuples by calling equals() on the tuple members.
equals(Object) - 类 中的方法org.apache.flink.api.java.tuple.Tuple6
Deep equality for tuples by calling equals() on the tuple members.
equals(Object) - 类 中的方法org.apache.flink.api.java.tuple.Tuple7
Deep equality for tuples by calling equals() on the tuple members.
equals(Object) - 类 中的方法org.apache.flink.api.java.tuple.Tuple8
Deep equality for tuples by calling equals() on the tuple members.
equals(Object) - 类 中的方法org.apache.flink.api.java.tuple.Tuple9
Deep equality for tuples by calling equals() on the tuple members.
equals(Object) - 类 中的方法org.apache.flink.api.java.typeutils.EitherTypeInfo
 
equals(Object) - 类 中的方法org.apache.flink.api.java.typeutils.EnumTypeInfo
 
equals(Object) - 类 中的方法org.apache.flink.api.java.typeutils.GenericTypeInfo
 
equals(Object) - 类 中的方法org.apache.flink.api.java.typeutils.ListTypeInfo
 
equals(Object) - 类 中的方法org.apache.flink.api.java.typeutils.MapTypeInfo
 
equals(Object) - 类 中的方法org.apache.flink.api.java.typeutils.MissingTypeInfo
 
equals(Object) - 类 中的方法org.apache.flink.api.java.typeutils.MultisetTypeInfo
 
equals(Object) - 类 中的方法org.apache.flink.api.java.typeutils.ObjectArrayTypeInfo
 
equals(Object) - 类 中的方法org.apache.flink.api.java.typeutils.PojoField
 
equals(Object) - 类 中的方法org.apache.flink.api.java.typeutils.PojoTypeInfo
 
equals(Object) - 类 中的方法org.apache.flink.api.java.typeutils.RowTypeInfo
The equals method does only check for field types.
equals(Object) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer
 
equals(Object) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.EitherSerializer
 
equals(Object) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer
 
equals(Object) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.KryoRegistration
 
equals(Object) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.KryoRegistrationSerializerConfigSnapshot
 
equals(Object) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.NullableSerializer
 
equals(Object) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.PojoSerializer
 
equals(Object) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.PojoSerializer.PojoSerializerConfigSnapshot
已过时。
 
equals(Object) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.RowSerializer
 
equals(Object) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.RuntimeSerializerFactory
 
equals(Object) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.Tuple0Serializer
 
equals(Object) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.TupleSerializerBase
 
equals(Object) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.TupleSerializerConfigSnapshot
 
equals(Object) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.ValueSerializer
 
equals(Object) - 类 中的方法org.apache.flink.api.java.typeutils.TupleTypeInfo
 
equals(Object) - 类 中的方法org.apache.flink.api.java.typeutils.TupleTypeInfoBase
 
equals(Object) - 类 中的方法org.apache.flink.api.java.typeutils.ValueTypeInfo
 
equals(Object) - 类 中的方法org.apache.flink.configuration.ConfigOption
 
equals(Object) - 类 中的方法org.apache.flink.configuration.Configuration
 
equals(Object) - 类 中的方法org.apache.flink.configuration.DelegatingConfiguration
 
equals(Object) - 类 中的方法org.apache.flink.configuration.FallbackKey
 
equals(Object) - 类 中的方法org.apache.flink.configuration.MemorySize
 
equals(Object) - 类 中的方法org.apache.flink.core.fs.ClosingFSDataInputStream
 
equals(Object) - 类 中的方法org.apache.flink.core.fs.ClosingFSDataOutputStream
 
equals(Object) - 类 中的方法org.apache.flink.core.fs.FileInputSplit
 
equals(Object) - 类 中的方法org.apache.flink.core.fs.Path
 
equals(Object) - 类 中的方法org.apache.flink.core.io.GenericInputSplit
 
equals(Object) - 类 中的方法org.apache.flink.core.io.LocatableInputSplit
 
equals(Object) - 类 中的方法org.apache.flink.core.io.SimpleVersionedSerializerTypeSerializerProxy
 
equals(Object) - 类 中的方法org.apache.flink.types.BooleanValue
 
equals(Object) - 类 中的方法org.apache.flink.types.ByteValue
 
equals(Object) - 类 中的方法org.apache.flink.types.CharValue
 
equals(Object) - 类 中的方法org.apache.flink.types.DoubleValue
 
equals(Object) - 类 中的方法org.apache.flink.types.Either.Left
 
equals(Object) - 类 中的方法org.apache.flink.types.Either.Right
 
equals(Object) - 类 中的方法org.apache.flink.types.FloatValue
 
equals(Object) - 类 中的方法org.apache.flink.types.IntValue
 
equals(Object) - 接口 中的方法org.apache.flink.types.Key
已过时。
Compares the object on equality with another object.
equals(Object) - 类 中的方法org.apache.flink.types.ListValue
 
equals(Object) - 类 中的方法org.apache.flink.types.LongValue
 
equals(Object) - 类 中的方法org.apache.flink.types.MapValue
 
equals(Object) - 类 中的方法org.apache.flink.types.NullValue
 
equals(Object) - 类 中的方法org.apache.flink.types.Row
 
equals(Object) - 类 中的方法org.apache.flink.types.ShortValue
 
equals(Object) - 类 中的方法org.apache.flink.types.StringValue
 
equals(Object) - 类 中的方法org.apache.flink.util.AbstractID
 
equals(Object) - 类 中的方法org.apache.flink.util.OptionalFailure
 
equals(Object) - 类 中的方法org.apache.flink.util.OutputTag
 
equals(Object) - 类 中的方法org.apache.flink.util.ReflectionUtil.FullTypeInfo
 
equals(Object) - 类 中的方法org.apache.flink.util.SerializedValue
 
equals(Object) - 类 中的方法org.apache.flink.util.StringBasedID
 
equalsFields(int[], Value[], Value[]) - 类 中的方法org.apache.flink.types.Record
Checks the values of this record and a given list of values at specified positions for equality.
equalTo(MemorySegment, int, int, int) - 类 中的方法org.apache.flink.core.memory.MemorySegment
Equals two memory segment regions.
equalToReference(T) - 类 中的方法org.apache.flink.api.common.typeutils.base.array.PrimitiveArrayComparator
 
equalToReference(T) - 类 中的方法org.apache.flink.api.common.typeutils.base.BasicTypeComparator
 
equalToReference(BooleanValue) - 类 中的方法org.apache.flink.api.common.typeutils.base.BooleanValueComparator
 
equalToReference(ByteValue) - 类 中的方法org.apache.flink.api.common.typeutils.base.ByteValueComparator
 
equalToReference(CharValue) - 类 中的方法org.apache.flink.api.common.typeutils.base.CharValueComparator
 
equalToReference(DoubleValue) - 类 中的方法org.apache.flink.api.common.typeutils.base.DoubleValueComparator
 
equalToReference(FloatValue) - 类 中的方法org.apache.flink.api.common.typeutils.base.FloatValueComparator
 
equalToReference(IntValue) - 类 中的方法org.apache.flink.api.common.typeutils.base.IntValueComparator
 
equalToReference(LocalDate) - 类 中的方法org.apache.flink.api.common.typeutils.base.LocalDateComparator
 
equalToReference(LocalDateTime) - 类 中的方法org.apache.flink.api.common.typeutils.base.LocalDateTimeComparator
 
equalToReference(LongValue) - 类 中的方法org.apache.flink.api.common.typeutils.base.LongValueComparator
 
equalToReference(NullValue) - 类 中的方法org.apache.flink.api.common.typeutils.base.NullValueComparator
 
equalToReference(ShortValue) - 类 中的方法org.apache.flink.api.common.typeutils.base.ShortValueComparator
 
equalToReference(StringValue) - 类 中的方法org.apache.flink.api.common.typeutils.base.StringValueComparator
 
equalToReference(T2) - 类 中的方法org.apache.flink.api.common.typeutils.GenericPairComparator
 
equalToReference(T) - 类 中的方法org.apache.flink.api.common.typeutils.SameTypePairComparator
 
equalToReference(T) - 类 中的方法org.apache.flink.api.common.typeutils.TypeComparator
Checks, whether the given element is equal to the element that has been set as the comparison reference in this comparator instance.
equalToReference(T2) - 类 中的方法org.apache.flink.api.common.typeutils.TypePairComparator
Checks, whether the given candidate instance is equal to the reference instance, with respect to this comparator's equality definition.
equalToReference(T) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.CopyableValueComparator
 
equalToReference(T) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.GenericTypeComparator
 
equalToReference(T) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.NullAwareComparator
 
equalToReference(T) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.PojoComparator
 
equalToReference(Row) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.RowComparator
 
equalToReference(T) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.TupleComparator
 
equalToReference(T) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.ValueComparator
 
ERROR_REGISTRATION_DELAY - 类 中的静态变量org.apache.flink.configuration.ClusterOptions
 
EVENLY_SPREAD_OUT_SLOTS_STRATEGY - 类 中的静态变量org.apache.flink.configuration.ClusterOptions
 
ExceptionUtils - org.apache.flink.util中的类
A collection of utility functions for dealing with exceptions and exception workflows.
executablesEquals(Method) - 类 中的方法org.apache.flink.api.java.typeutils.TypeExtractionUtils.LambdaExecutable
 
executablesEquals(Constructor<?>) - 类 中的方法org.apache.flink.api.java.typeutils.TypeExtractionUtils.LambdaExecutable
 
execute(Plan) - 类 中的方法org.apache.flink.api.common.operators.CollectionExecutor
 
execute(ThrowingRunnable<? extends Exception>, String) - 接口 中的方法org.apache.flink.api.common.operators.MailboxExecutor
Executes the given command at some time in the future in the mailbox thread.
execute(ThrowingRunnable<? extends Exception>, String, Object...) - 接口 中的方法org.apache.flink.api.common.operators.MailboxExecutor
Executes the given command at some time in the future in the mailbox thread.
execute(Pipeline, Configuration, ClassLoader) - 接口 中的方法org.apache.flink.core.execution.PipelineExecutor
Executes a Pipeline based on the provided configuration and returns a JobClient which allows to interact with the job being executed, e.g. cancel it or take a savepoint.
execute(Runnable) - 类 中的方法org.apache.flink.util.concurrent.ScheduledExecutorServiceAdapter
 
execute(Runnable) - 类 中的方法org.apache.flink.util.concurrent.SeparateThreadExecutor
 
executeOnCollections(List<T>, RuntimeContext, ExecutionConfig) - 类 中的方法org.apache.flink.api.common.operators.base.BulkIterationBase
 
executeOnCollections(List<IN1>, List<IN2>, RuntimeContext, ExecutionConfig) - 类 中的方法org.apache.flink.api.common.operators.base.CoGroupOperatorBase
 
executeOnCollections(List<IN1>, List<IN2>, RuntimeContext, ExecutionConfig) - 类 中的方法org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase
 
executeOnCollections(List<IN1>, List<IN2>, RuntimeContext, ExecutionConfig) - 类 中的方法org.apache.flink.api.common.operators.base.CrossOperatorBase
 
executeOnCollections(List<ST>, List<WT>, RuntimeContext, ExecutionConfig) - 类 中的方法org.apache.flink.api.common.operators.base.DeltaIterationBase
 
executeOnCollections(List<T>, RuntimeContext, ExecutionConfig) - 类 中的方法org.apache.flink.api.common.operators.base.FilterOperatorBase
 
executeOnCollections(List<IN>, RuntimeContext, ExecutionConfig) - 类 中的方法org.apache.flink.api.common.operators.base.FlatMapOperatorBase
 
executeOnCollections(List<IN>, RuntimeContext, ExecutionConfig) - 类 中的方法org.apache.flink.api.common.operators.base.GroupCombineOperatorBase
 
executeOnCollections(List<IN>, RuntimeContext, ExecutionConfig) - 类 中的方法org.apache.flink.api.common.operators.base.GroupReduceOperatorBase
 
executeOnCollections(List<IN1>, List<IN2>, RuntimeContext, ExecutionConfig) - 类 中的方法org.apache.flink.api.common.operators.base.InnerJoinOperatorBase
 
executeOnCollections(List<IN>, RuntimeContext, ExecutionConfig) - 类 中的方法org.apache.flink.api.common.operators.base.MapOperatorBase
 
executeOnCollections(List<IN>, RuntimeContext, ExecutionConfig) - 类 中的方法org.apache.flink.api.common.operators.base.MapPartitionOperatorBase
 
executeOnCollections(List<IN1>, List<IN2>, RuntimeContext, ExecutionConfig) - 类 中的方法org.apache.flink.api.common.operators.base.OuterJoinOperatorBase
 
executeOnCollections(List<IN>, RuntimeContext, ExecutionConfig) - 类 中的方法org.apache.flink.api.common.operators.base.PartitionOperatorBase
 
executeOnCollections(List<T>, RuntimeContext, ExecutionConfig) - 类 中的方法org.apache.flink.api.common.operators.base.ReduceOperatorBase
 
executeOnCollections(List<IN>, RuntimeContext, ExecutionConfig) - 类 中的方法org.apache.flink.api.common.operators.base.SortPartitionOperatorBase
 
executeOnCollections(List<IN1>, List<IN2>, RuntimeContext, ExecutionConfig) - 类 中的方法org.apache.flink.api.common.operators.DualInputOperator
 
executeOnCollections(List<IN>, RuntimeContext, ExecutionConfig) - 类 中的方法org.apache.flink.api.common.operators.GenericDataSinkBase
 
executeOnCollections(RuntimeContext, ExecutionConfig) - 类 中的方法org.apache.flink.api.common.operators.GenericDataSourceBase
 
executeOnCollections(List<IN>, RuntimeContext, ExecutionConfig) - 类 中的方法org.apache.flink.api.common.operators.SingleInputOperator
 
executeOnCollections(List<T>, List<T>, RuntimeContext, ExecutionConfig) - 类 中的方法org.apache.flink.api.common.operators.Union
 
EXECUTION_FAILOVER_STRATEGY - 类 中的静态变量org.apache.flink.configuration.JobManagerOptions
This option specifies the failover strategy, i.e. how the job computation recovers from task failures.
EXECUTION_RETRIES_KEY - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
The configuration value will be replaced by ConfigConstants.RESTART_STRATEGY_FIXED_DELAY_ATTEMPTS and the corresponding FixedDelayRestartStrategy.
EXECUTION_RETRY_DELAY_KEY - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
The configuration value will be replaced by ConfigConstants.RESTART_STRATEGY_FIXED_DELAY_DELAY and the corresponding FixedDelayRestartStrategy.
ExecutionConfig - org.apache.flink.api.common中的类
A config to define the behavior of the program execution.
ExecutionConfig() - 类 的构造器org.apache.flink.api.common.ExecutionConfig
 
executionConfig - 类 中的变量org.apache.flink.api.common.Plan
Config object for runtime execution parameters.
ExecutionConfig.ClosureCleanerLevel - org.apache.flink.api.common中的枚举
Configuration settings for the closure cleaner.
ExecutionConfig.GlobalJobParameters - org.apache.flink.api.common中的类
Abstract class for a custom user configuration object registered at the execution config.
ExecutionConfig.SerializableSerializer<T extends com.esotericsoftware.kryo.Serializer<?> & Serializable> - org.apache.flink.api.common中的类
 
ExecutionMode - org.apache.flink.api.common中的枚举
The execution mode specifies how a batch program is executed in terms of data exchange: pipelining or batched.
ExecutionOptions - org.apache.flink.configuration中的类
ConfigOptions specific for a single execution of a user program.
ExecutionOptions() - 类 的构造器org.apache.flink.configuration.ExecutionOptions
 
Executors - org.apache.flink.util.concurrent中的类
Collection of Executor and ExecutorService implementations.
Executors() - 类 的构造器org.apache.flink.util.concurrent.Executors
 
ExecutorThreadFactory - org.apache.flink.util.concurrent中的类
A thread factory intended for use by critical thread pools.
ExecutorThreadFactory() - 类 的构造器org.apache.flink.util.concurrent.ExecutorThreadFactory
Creates a new thread factory using the default thread pool name ('flink-executor-pool') and the default uncaught exception handler (log exception and kill process).
ExecutorThreadFactory(String) - 类 的构造器org.apache.flink.util.concurrent.ExecutorThreadFactory
Creates a new thread factory using the given thread pool name and the default uncaught exception handler (log exception and kill process).
ExecutorThreadFactory(String, Thread.UncaughtExceptionHandler) - 类 的构造器org.apache.flink.util.concurrent.ExecutorThreadFactory
Creates a new thread factory using the given thread pool name and the given uncaught exception handler.
ExecutorThreadFactory.Builder - org.apache.flink.util.concurrent中的类
ExecutorUtils - org.apache.flink.util中的类
Utilities for Executors.
ExecutorUtils() - 类 的构造器org.apache.flink.util.ExecutorUtils
 
exists(Path) - 类 中的方法org.apache.flink.core.fs.FileSystem
Check if exists.
exists(Path) - 类 中的方法org.apache.flink.core.fs.LimitedConnectionsFileSystem
 
exists(Path) - 类 中的方法org.apache.flink.core.fs.local.LocalFileSystem
 
exists(Path) - 类 中的方法org.apache.flink.core.fs.SafetyNetWrapperFileSystem
 
EXIT_CODE - 类 中的静态变量org.apache.flink.util.FatalExitExceptionHandler
 
EXIT_ON_FATAL_AKKA_ERROR - 类 中的静态变量org.apache.flink.configuration.TaskManagerOptions
已过时。
expandDirectory(Path, Path) - 类 中的静态方法org.apache.flink.util.FileUtils
 
ExponentialBackoffRetryStrategy - org.apache.flink.util.concurrent中的类
An implementation of RetryStrategy that retries that has an exponential backoff with a cap.
ExponentialBackoffRetryStrategy(int, Duration, Duration) - 类 的构造器org.apache.flink.util.concurrent.ExponentialBackoffRetryStrategy
 
exponentialDelayRestart(Time, Time, double, Time, double) - 类 中的静态方法org.apache.flink.api.common.restartstrategy.RestartStrategies
Generates a ExponentialDelayRestartStrategyConfiguration.
ExponentialDelayRestartStrategyConfiguration(Time, Time, double, Time, double) - 类 的构造器org.apache.flink.api.common.restartstrategy.RestartStrategies.ExponentialDelayRestartStrategyConfiguration
 
ExpressionKeys(TypeInformation<T>) - 类 的构造器org.apache.flink.api.common.operators.Keys.ExpressionKeys
ExpressionKeys that is defined by the full data type.
ExpressionKeys(int, TypeInformation<T>) - 类 的构造器org.apache.flink.api.common.operators.Keys.ExpressionKeys
Create int-based (non-nested) field position keys on a tuple type.
ExpressionKeys(int[], TypeInformation<T>) - 类 的构造器org.apache.flink.api.common.operators.Keys.ExpressionKeys
Create int-based (non-nested) field position keys on a tuple type.
ExpressionKeys(int[], TypeInformation<T>, boolean) - 类 的构造器org.apache.flink.api.common.operators.Keys.ExpressionKeys
Create int-based (non-nested) field position keys on a tuple type.
ExpressionKeys(String, TypeInformation<T>) - 类 的构造器org.apache.flink.api.common.operators.Keys.ExpressionKeys
Create String-based (nested) field expression keys on a composite type.
ExpressionKeys(String[], TypeInformation<T>) - 类 的构造器org.apache.flink.api.common.operators.Keys.ExpressionKeys
Create String-based (nested) field expression keys on a composite type.
EXTERNAL_RESOURCE_AMOUNT - 类 中的静态变量org.apache.flink.configuration.ExternalResourceOptions
The amount for the external resource specified by >resource_name< per TaskExecutor.
EXTERNAL_RESOURCE_AMOUNT_SUFFIX - 类 中的静态变量org.apache.flink.configuration.ExternalResourceOptions
The amount of the external resource per task executor.
EXTERNAL_RESOURCE_DRIVER_FACTORY_CLASS - 类 中的静态变量org.apache.flink.configuration.ExternalResourceOptions
Defines the factory class name for the external resource identified by >resource_name<.
EXTERNAL_RESOURCE_DRIVER_FACTORY_SUFFIX - 类 中的静态变量org.apache.flink.configuration.ExternalResourceOptions
The driver factory class of the external resource to use.
EXTERNAL_RESOURCE_DRIVER_PARAM - 类 中的静态变量org.apache.flink.configuration.ExternalResourceOptions
The naming pattern of custom config options for the external resource specified by >resource_name<.
EXTERNAL_RESOURCE_DRIVER_PARAM_SUFFIX - 类 中的静态变量org.apache.flink.configuration.ExternalResourceOptions
The suffix of custom config options' prefix for the external resource.
EXTERNAL_RESOURCE_LIST - 类 中的静态变量org.apache.flink.configuration.ExternalResourceOptions
List of the resource_name of all external resources with delimiter ";", e.g.
ExternallyInducedSourceReader<T,SplitT extends SourceSplit> - org.apache.flink.api.connector.source中的接口
Sources that implement this interface do not trigger checkpoints when receiving a trigger message from the checkpoint coordinator, but when their input data/events indicate that a checkpoint should be triggered.
ExternalResource - org.apache.flink.api.common.resources中的类
An external resource.
ExternalResource(String, double) - 类 的构造器org.apache.flink.api.common.resources.ExternalResource
 
ExternalResourceDriver - org.apache.flink.api.common.externalresource中的接口
Driver which takes the responsibility to manage and provide the information of external resource.
ExternalResourceDriverFactory - org.apache.flink.api.common.externalresource中的接口
ExternalResourceInfo - org.apache.flink.api.common.externalresource中的接口
Contains the information of an external resource.
ExternalResourceOptions - org.apache.flink.configuration中的类
Configuration options for external resources and external resource drivers.
ExternalResourceOptions() - 类 的构造器org.apache.flink.configuration.ExternalResourceOptions
 
extractFileExtension(String) - 类 中的静态方法org.apache.flink.api.common.io.FileInputFormat
Returns the extension of a file name (!
extractKeys(Object, Object[], int) - 类 中的方法org.apache.flink.api.common.typeutils.base.array.PrimitiveArrayComparator
 
extractKeys(Object, Object[], int) - 类 中的方法org.apache.flink.api.common.typeutils.base.BasicTypeComparator
 
extractKeys(Object, Object[], int) - 类 中的方法org.apache.flink.api.common.typeutils.base.BooleanValueComparator
 
extractKeys(Object, Object[], int) - 类 中的方法org.apache.flink.api.common.typeutils.base.ByteValueComparator
 
extractKeys(Object, Object[], int) - 类 中的方法org.apache.flink.api.common.typeutils.base.CharValueComparator
 
extractKeys(Object, Object[], int) - 类 中的方法org.apache.flink.api.common.typeutils.base.DoubleValueComparator
 
extractKeys(Object, Object[], int) - 类 中的方法org.apache.flink.api.common.typeutils.base.FloatValueComparator
 
extractKeys(Object, Object[], int) - 类 中的方法org.apache.flink.api.common.typeutils.base.IntValueComparator
 
extractKeys(Object, Object[], int) - 类 中的方法org.apache.flink.api.common.typeutils.base.LocalDateComparator
 
extractKeys(Object, Object[], int) - 类 中的方法org.apache.flink.api.common.typeutils.base.LocalDateTimeComparator
 
extractKeys(Object, Object[], int) - 类 中的方法org.apache.flink.api.common.typeutils.base.LongValueComparator
 
extractKeys(Object, Object[], int) - 类 中的方法org.apache.flink.api.common.typeutils.base.NullValueComparator
 
extractKeys(Object, Object[], int) - 类 中的方法org.apache.flink.api.common.typeutils.base.ShortValueComparator
 
extractKeys(Object, Object[], int) - 类 中的方法org.apache.flink.api.common.typeutils.base.StringValueComparator
 
extractKeys(Object, Object[], int) - 类 中的方法org.apache.flink.api.common.typeutils.TypeComparator
Extracts the key fields from a record.
extractKeys(Object, Object[], int) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.CopyableValueComparator
 
extractKeys(Object, Object[], int) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.GenericTypeComparator
 
extractKeys(Object, Object[], int) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.NullAwareComparator
 
extractKeys(Object, Object[], int) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.PojoComparator
 
extractKeys(Object, Object[], int) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.RowComparator
 
extractKeys(Object, Object[], int) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.TupleComparator
 
extractKeys(Object, Object[], int) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.ValueComparator
 
extractResourceSpec(SlotSharingGroup) - 类 中的静态方法org.apache.flink.api.common.operators.util.SlotSharingGroupUtils
 
extractTimestamp(T, long) - 类 中的方法org.apache.flink.api.common.eventtime.IngestionTimeAssigner
 
extractTimestamp(E, long) - 类 中的方法org.apache.flink.api.common.eventtime.RecordTimestampAssigner
 
extractTimestamp(T, long) - 接口 中的方法org.apache.flink.api.common.eventtime.TimestampAssigner
Assigns a timestamp to an element, in milliseconds since the Epoch.
extractTypeArgument(Type, int) - 类 中的静态方法org.apache.flink.api.java.typeutils.TypeExtractionUtils
This method extracts the n-th type argument from the given type.
extractTypeFromLambda(Class<?>, TypeExtractionUtils.LambdaExecutable, int[], int, int) - 类 中的静态方法org.apache.flink.api.java.typeutils.TypeExtractionUtils
Extracts type from given index from lambda.

F

f0 - 类 中的变量org.apache.flink.api.java.tuple.Tuple1
Field 0 of the tuple.
f0 - 类 中的变量org.apache.flink.api.java.tuple.Tuple10
Field 0 of the tuple.
f0 - 类 中的变量org.apache.flink.api.java.tuple.Tuple11
Field 0 of the tuple.
f0 - 类 中的变量org.apache.flink.api.java.tuple.Tuple12
Field 0 of the tuple.
f0 - 类 中的变量org.apache.flink.api.java.tuple.Tuple13
Field 0 of the tuple.
f0 - 类 中的变量org.apache.flink.api.java.tuple.Tuple14
Field 0 of the tuple.
f0 - 类 中的变量org.apache.flink.api.java.tuple.Tuple15
Field 0 of the tuple.
f0 - 类 中的变量org.apache.flink.api.java.tuple.Tuple16
Field 0 of the tuple.
f0 - 类 中的变量org.apache.flink.api.java.tuple.Tuple17
Field 0 of the tuple.
f0 - 类 中的变量org.apache.flink.api.java.tuple.Tuple18
Field 0 of the tuple.
f0 - 类 中的变量org.apache.flink.api.java.tuple.Tuple19
Field 0 of the tuple.
f0 - 类 中的变量org.apache.flink.api.java.tuple.Tuple2
Field 0 of the tuple.
f0 - 类 中的变量org.apache.flink.api.java.tuple.Tuple20
Field 0 of the tuple.
f0 - 类 中的变量org.apache.flink.api.java.tuple.Tuple21
Field 0 of the tuple.
f0 - 类 中的变量org.apache.flink.api.java.tuple.Tuple22
Field 0 of the tuple.
f0 - 类 中的变量org.apache.flink.api.java.tuple.Tuple23
Field 0 of the tuple.
f0 - 类 中的变量org.apache.flink.api.java.tuple.Tuple24
Field 0 of the tuple.
f0 - 类 中的变量org.apache.flink.api.java.tuple.Tuple25
Field 0 of the tuple.
f0 - 类 中的变量org.apache.flink.api.java.tuple.Tuple3
Field 0 of the tuple.
f0 - 类 中的变量org.apache.flink.api.java.tuple.Tuple4
Field 0 of the tuple.
f0 - 类 中的变量org.apache.flink.api.java.tuple.Tuple5
Field 0 of the tuple.
f0 - 类 中的变量org.apache.flink.api.java.tuple.Tuple6
Field 0 of the tuple.
f0 - 类 中的变量org.apache.flink.api.java.tuple.Tuple7
Field 0 of the tuple.
f0 - 类 中的变量org.apache.flink.api.java.tuple.Tuple8
Field 0 of the tuple.
f0 - 类 中的变量org.apache.flink.api.java.tuple.Tuple9
Field 0 of the tuple.
f1 - 类 中的变量org.apache.flink.api.java.tuple.Tuple10
Field 1 of the tuple.
f1 - 类 中的变量org.apache.flink.api.java.tuple.Tuple11
Field 1 of the tuple.
f1 - 类 中的变量org.apache.flink.api.java.tuple.Tuple12
Field 1 of the tuple.
f1 - 类 中的变量org.apache.flink.api.java.tuple.Tuple13
Field 1 of the tuple.
f1 - 类 中的变量org.apache.flink.api.java.tuple.Tuple14
Field 1 of the tuple.
f1 - 类 中的变量org.apache.flink.api.java.tuple.Tuple15
Field 1 of the tuple.
f1 - 类 中的变量org.apache.flink.api.java.tuple.Tuple16
Field 1 of the tuple.
f1 - 类 中的变量org.apache.flink.api.java.tuple.Tuple17
Field 1 of the tuple.
f1 - 类 中的变量org.apache.flink.api.java.tuple.Tuple18
Field 1 of the tuple.
f1 - 类 中的变量org.apache.flink.api.java.tuple.Tuple19
Field 1 of the tuple.
f1 - 类 中的变量org.apache.flink.api.java.tuple.Tuple2
Field 1 of the tuple.
f1 - 类 中的变量org.apache.flink.api.java.tuple.Tuple20
Field 1 of the tuple.
f1 - 类 中的变量org.apache.flink.api.java.tuple.Tuple21
Field 1 of the tuple.
f1 - 类 中的变量org.apache.flink.api.java.tuple.Tuple22
Field 1 of the tuple.
f1 - 类 中的变量org.apache.flink.api.java.tuple.Tuple23
Field 1 of the tuple.
f1 - 类 中的变量org.apache.flink.api.java.tuple.Tuple24
Field 1 of the tuple.
f1 - 类 中的变量org.apache.flink.api.java.tuple.Tuple25
Field 1 of the tuple.
f1 - 类 中的变量org.apache.flink.api.java.tuple.Tuple3
Field 1 of the tuple.
f1 - 类 中的变量org.apache.flink.api.java.tuple.Tuple4
Field 1 of the tuple.
f1 - 类 中的变量org.apache.flink.api.java.tuple.Tuple5
Field 1 of the tuple.
f1 - 类 中的变量org.apache.flink.api.java.tuple.Tuple6
Field 1 of the tuple.
f1 - 类 中的变量org.apache.flink.api.java.tuple.Tuple7
Field 1 of the tuple.
f1 - 类 中的变量org.apache.flink.api.java.tuple.Tuple8
Field 1 of the tuple.
f1 - 类 中的变量org.apache.flink.api.java.tuple.Tuple9
Field 1 of the tuple.
f10 - 类 中的变量org.apache.flink.api.java.tuple.Tuple11
Field 10 of the tuple.
f10 - 类 中的变量org.apache.flink.api.java.tuple.Tuple12
Field 10 of the tuple.
f10 - 类 中的变量org.apache.flink.api.java.tuple.Tuple13
Field 10 of the tuple.
f10 - 类 中的变量org.apache.flink.api.java.tuple.Tuple14
Field 10 of the tuple.
f10 - 类 中的变量org.apache.flink.api.java.tuple.Tuple15
Field 10 of the tuple.
f10 - 类 中的变量org.apache.flink.api.java.tuple.Tuple16
Field 10 of the tuple.
f10 - 类 中的变量org.apache.flink.api.java.tuple.Tuple17
Field 10 of the tuple.
f10 - 类 中的变量org.apache.flink.api.java.tuple.Tuple18
Field 10 of the tuple.
f10 - 类 中的变量org.apache.flink.api.java.tuple.Tuple19
Field 10 of the tuple.
f10 - 类 中的变量org.apache.flink.api.java.tuple.Tuple20
Field 10 of the tuple.
f10 - 类 中的变量org.apache.flink.api.java.tuple.Tuple21
Field 10 of the tuple.
f10 - 类 中的变量org.apache.flink.api.java.tuple.Tuple22
Field 10 of the tuple.
f10 - 类 中的变量org.apache.flink.api.java.tuple.Tuple23
Field 10 of the tuple.
f10 - 类 中的变量org.apache.flink.api.java.tuple.Tuple24
Field 10 of the tuple.
f10 - 类 中的变量org.apache.flink.api.java.tuple.Tuple25
Field 10 of the tuple.
f11 - 类 中的变量org.apache.flink.api.java.tuple.Tuple12
Field 11 of the tuple.
f11 - 类 中的变量org.apache.flink.api.java.tuple.Tuple13
Field 11 of the tuple.
f11 - 类 中的变量org.apache.flink.api.java.tuple.Tuple14
Field 11 of the tuple.
f11 - 类 中的变量org.apache.flink.api.java.tuple.Tuple15
Field 11 of the tuple.
f11 - 类 中的变量org.apache.flink.api.java.tuple.Tuple16
Field 11 of the tuple.
f11 - 类 中的变量org.apache.flink.api.java.tuple.Tuple17
Field 11 of the tuple.
f11 - 类 中的变量org.apache.flink.api.java.tuple.Tuple18
Field 11 of the tuple.
f11 - 类 中的变量org.apache.flink.api.java.tuple.Tuple19
Field 11 of the tuple.
f11 - 类 中的变量org.apache.flink.api.java.tuple.Tuple20
Field 11 of the tuple.
f11 - 类 中的变量org.apache.flink.api.java.tuple.Tuple21
Field 11 of the tuple.
f11 - 类 中的变量org.apache.flink.api.java.tuple.Tuple22
Field 11 of the tuple.
f11 - 类 中的变量org.apache.flink.api.java.tuple.Tuple23
Field 11 of the tuple.
f11 - 类 中的变量org.apache.flink.api.java.tuple.Tuple24
Field 11 of the tuple.
f11 - 类 中的变量org.apache.flink.api.java.tuple.Tuple25
Field 11 of the tuple.
f12 - 类 中的变量org.apache.flink.api.java.tuple.Tuple13
Field 12 of the tuple.
f12 - 类 中的变量org.apache.flink.api.java.tuple.Tuple14
Field 12 of the tuple.
f12 - 类 中的变量org.apache.flink.api.java.tuple.Tuple15
Field 12 of the tuple.
f12 - 类 中的变量org.apache.flink.api.java.tuple.Tuple16
Field 12 of the tuple.
f12 - 类 中的变量org.apache.flink.api.java.tuple.Tuple17
Field 12 of the tuple.
f12 - 类 中的变量org.apache.flink.api.java.tuple.Tuple18
Field 12 of the tuple.
f12 - 类 中的变量org.apache.flink.api.java.tuple.Tuple19
Field 12 of the tuple.
f12 - 类 中的变量org.apache.flink.api.java.tuple.Tuple20
Field 12 of the tuple.
f12 - 类 中的变量org.apache.flink.api.java.tuple.Tuple21
Field 12 of the tuple.
f12 - 类 中的变量org.apache.flink.api.java.tuple.Tuple22
Field 12 of the tuple.
f12 - 类 中的变量org.apache.flink.api.java.tuple.Tuple23
Field 12 of the tuple.
f12 - 类 中的变量org.apache.flink.api.java.tuple.Tuple24
Field 12 of the tuple.
f12 - 类 中的变量org.apache.flink.api.java.tuple.Tuple25
Field 12 of the tuple.
f13 - 类 中的变量org.apache.flink.api.java.tuple.Tuple14
Field 13 of the tuple.
f13 - 类 中的变量org.apache.flink.api.java.tuple.Tuple15
Field 13 of the tuple.
f13 - 类 中的变量org.apache.flink.api.java.tuple.Tuple16
Field 13 of the tuple.
f13 - 类 中的变量org.apache.flink.api.java.tuple.Tuple17
Field 13 of the tuple.
f13 - 类 中的变量org.apache.flink.api.java.tuple.Tuple18
Field 13 of the tuple.
f13 - 类 中的变量org.apache.flink.api.java.tuple.Tuple19
Field 13 of the tuple.
f13 - 类 中的变量org.apache.flink.api.java.tuple.Tuple20
Field 13 of the tuple.
f13 - 类 中的变量org.apache.flink.api.java.tuple.Tuple21
Field 13 of the tuple.
f13 - 类 中的变量org.apache.flink.api.java.tuple.Tuple22
Field 13 of the tuple.
f13 - 类 中的变量org.apache.flink.api.java.tuple.Tuple23
Field 13 of the tuple.
f13 - 类 中的变量org.apache.flink.api.java.tuple.Tuple24
Field 13 of the tuple.
f13 - 类 中的变量org.apache.flink.api.java.tuple.Tuple25
Field 13 of the tuple.
f14 - 类 中的变量org.apache.flink.api.java.tuple.Tuple15
Field 14 of the tuple.
f14 - 类 中的变量org.apache.flink.api.java.tuple.Tuple16
Field 14 of the tuple.
f14 - 类 中的变量org.apache.flink.api.java.tuple.Tuple17
Field 14 of the tuple.
f14 - 类 中的变量org.apache.flink.api.java.tuple.Tuple18
Field 14 of the tuple.
f14 - 类 中的变量org.apache.flink.api.java.tuple.Tuple19
Field 14 of the tuple.
f14 - 类 中的变量org.apache.flink.api.java.tuple.Tuple20
Field 14 of the tuple.
f14 - 类 中的变量org.apache.flink.api.java.tuple.Tuple21
Field 14 of the tuple.
f14 - 类 中的变量org.apache.flink.api.java.tuple.Tuple22
Field 14 of the tuple.
f14 - 类 中的变量org.apache.flink.api.java.tuple.Tuple23
Field 14 of the tuple.
f14 - 类 中的变量org.apache.flink.api.java.tuple.Tuple24
Field 14 of the tuple.
f14 - 类 中的变量org.apache.flink.api.java.tuple.Tuple25
Field 14 of the tuple.
f15 - 类 中的变量org.apache.flink.api.java.tuple.Tuple16
Field 15 of the tuple.
f15 - 类 中的变量org.apache.flink.api.java.tuple.Tuple17
Field 15 of the tuple.
f15 - 类 中的变量org.apache.flink.api.java.tuple.Tuple18
Field 15 of the tuple.
f15 - 类 中的变量org.apache.flink.api.java.tuple.Tuple19
Field 15 of the tuple.
f15 - 类 中的变量org.apache.flink.api.java.tuple.Tuple20
Field 15 of the tuple.
f15 - 类 中的变量org.apache.flink.api.java.tuple.Tuple21
Field 15 of the tuple.
f15 - 类 中的变量org.apache.flink.api.java.tuple.Tuple22
Field 15 of the tuple.
f15 - 类 中的变量org.apache.flink.api.java.tuple.Tuple23
Field 15 of the tuple.
f15 - 类 中的变量org.apache.flink.api.java.tuple.Tuple24
Field 15 of the tuple.
f15 - 类 中的变量org.apache.flink.api.java.tuple.Tuple25
Field 15 of the tuple.
f16 - 类 中的变量org.apache.flink.api.java.tuple.Tuple17
Field 16 of the tuple.
f16 - 类 中的变量org.apache.flink.api.java.tuple.Tuple18
Field 16 of the tuple.
f16 - 类 中的变量org.apache.flink.api.java.tuple.Tuple19
Field 16 of the tuple.
f16 - 类 中的变量org.apache.flink.api.java.tuple.Tuple20
Field 16 of the tuple.
f16 - 类 中的变量org.apache.flink.api.java.tuple.Tuple21
Field 16 of the tuple.
f16 - 类 中的变量org.apache.flink.api.java.tuple.Tuple22
Field 16 of the tuple.
f16 - 类 中的变量org.apache.flink.api.java.tuple.Tuple23
Field 16 of the tuple.
f16 - 类 中的变量org.apache.flink.api.java.tuple.Tuple24
Field 16 of the tuple.
f16 - 类 中的变量org.apache.flink.api.java.tuple.Tuple25
Field 16 of the tuple.
f17 - 类 中的变量org.apache.flink.api.java.tuple.Tuple18
Field 17 of the tuple.
f17 - 类 中的变量org.apache.flink.api.java.tuple.Tuple19
Field 17 of the tuple.
f17 - 类 中的变量org.apache.flink.api.java.tuple.Tuple20
Field 17 of the tuple.
f17 - 类 中的变量org.apache.flink.api.java.tuple.Tuple21
Field 17 of the tuple.
f17 - 类 中的变量org.apache.flink.api.java.tuple.Tuple22
Field 17 of the tuple.
f17 - 类 中的变量org.apache.flink.api.java.tuple.Tuple23
Field 17 of the tuple.
f17 - 类 中的变量org.apache.flink.api.java.tuple.Tuple24
Field 17 of the tuple.
f17 - 类 中的变量org.apache.flink.api.java.tuple.Tuple25
Field 17 of the tuple.
f18 - 类 中的变量org.apache.flink.api.java.tuple.Tuple19
Field 18 of the tuple.
f18 - 类 中的变量org.apache.flink.api.java.tuple.Tuple20
Field 18 of the tuple.
f18 - 类 中的变量org.apache.flink.api.java.tuple.Tuple21
Field 18 of the tuple.
f18 - 类 中的变量org.apache.flink.api.java.tuple.Tuple22
Field 18 of the tuple.
f18 - 类 中的变量org.apache.flink.api.java.tuple.Tuple23
Field 18 of the tuple.
f18 - 类 中的变量org.apache.flink.api.java.tuple.Tuple24
Field 18 of the tuple.
f18 - 类 中的变量org.apache.flink.api.java.tuple.Tuple25
Field 18 of the tuple.
f19 - 类 中的变量org.apache.flink.api.java.tuple.Tuple20
Field 19 of the tuple.
f19 - 类 中的变量org.apache.flink.api.java.tuple.Tuple21
Field 19 of the tuple.
f19 - 类 中的变量org.apache.flink.api.java.tuple.Tuple22
Field 19 of the tuple.
f19 - 类 中的变量org.apache.flink.api.java.tuple.Tuple23
Field 19 of the tuple.
f19 - 类 中的变量org.apache.flink.api.java.tuple.Tuple24
Field 19 of the tuple.
f19 - 类 中的变量org.apache.flink.api.java.tuple.Tuple25
Field 19 of the tuple.
f2 - 类 中的变量org.apache.flink.api.java.tuple.Tuple10
Field 2 of the tuple.
f2 - 类 中的变量org.apache.flink.api.java.tuple.Tuple11
Field 2 of the tuple.
f2 - 类 中的变量org.apache.flink.api.java.tuple.Tuple12
Field 2 of the tuple.
f2 - 类 中的变量org.apache.flink.api.java.tuple.Tuple13
Field 2 of the tuple.
f2 - 类 中的变量org.apache.flink.api.java.tuple.Tuple14
Field 2 of the tuple.
f2 - 类 中的变量org.apache.flink.api.java.tuple.Tuple15
Field 2 of the tuple.
f2 - 类 中的变量org.apache.flink.api.java.tuple.Tuple16
Field 2 of the tuple.
f2 - 类 中的变量org.apache.flink.api.java.tuple.Tuple17
Field 2 of the tuple.
f2 - 类 中的变量org.apache.flink.api.java.tuple.Tuple18
Field 2 of the tuple.
f2 - 类 中的变量org.apache.flink.api.java.tuple.Tuple19
Field 2 of the tuple.
f2 - 类 中的变量org.apache.flink.api.java.tuple.Tuple20
Field 2 of the tuple.
f2 - 类 中的变量org.apache.flink.api.java.tuple.Tuple21
Field 2 of the tuple.
f2 - 类 中的变量org.apache.flink.api.java.tuple.Tuple22
Field 2 of the tuple.
f2 - 类 中的变量org.apache.flink.api.java.tuple.Tuple23
Field 2 of the tuple.
f2 - 类 中的变量org.apache.flink.api.java.tuple.Tuple24
Field 2 of the tuple.
f2 - 类 中的变量org.apache.flink.api.java.tuple.Tuple25
Field 2 of the tuple.
f2 - 类 中的变量org.apache.flink.api.java.tuple.Tuple3
Field 2 of the tuple.
f2 - 类 中的变量org.apache.flink.api.java.tuple.Tuple4
Field 2 of the tuple.
f2 - 类 中的变量org.apache.flink.api.java.tuple.Tuple5
Field 2 of the tuple.
f2 - 类 中的变量org.apache.flink.api.java.tuple.Tuple6
Field 2 of the tuple.
f2 - 类 中的变量org.apache.flink.api.java.tuple.Tuple7
Field 2 of the tuple.
f2 - 类 中的变量org.apache.flink.api.java.tuple.Tuple8
Field 2 of the tuple.
f2 - 类 中的变量org.apache.flink.api.java.tuple.Tuple9
Field 2 of the tuple.
f20 - 类 中的变量org.apache.flink.api.java.tuple.Tuple21
Field 20 of the tuple.
f20 - 类 中的变量org.apache.flink.api.java.tuple.Tuple22
Field 20 of the tuple.
f20 - 类 中的变量org.apache.flink.api.java.tuple.Tuple23
Field 20 of the tuple.
f20 - 类 中的变量org.apache.flink.api.java.tuple.Tuple24
Field 20 of the tuple.
f20 - 类 中的变量org.apache.flink.api.java.tuple.Tuple25
Field 20 of the tuple.
f21 - 类 中的变量org.apache.flink.api.java.tuple.Tuple22
Field 21 of the tuple.
f21 - 类 中的变量org.apache.flink.api.java.tuple.Tuple23
Field 21 of the tuple.
f21 - 类 中的变量org.apache.flink.api.java.tuple.Tuple24
Field 21 of the tuple.
f21 - 类 中的变量org.apache.flink.api.java.tuple.Tuple25
Field 21 of the tuple.
f22 - 类 中的变量org.apache.flink.api.java.tuple.Tuple23
Field 22 of the tuple.
f22 - 类 中的变量org.apache.flink.api.java.tuple.Tuple24
Field 22 of the tuple.
f22 - 类 中的变量org.apache.flink.api.java.tuple.Tuple25
Field 22 of the tuple.
f23 - 类 中的变量org.apache.flink.api.java.tuple.Tuple24
Field 23 of the tuple.
f23 - 类 中的变量org.apache.flink.api.java.tuple.Tuple25
Field 23 of the tuple.
f24 - 类 中的变量org.apache.flink.api.java.tuple.Tuple25
Field 24 of the tuple.
f3 - 类 中的变量org.apache.flink.api.java.tuple.Tuple10
Field 3 of the tuple.
f3 - 类 中的变量org.apache.flink.api.java.tuple.Tuple11
Field 3 of the tuple.
f3 - 类 中的变量org.apache.flink.api.java.tuple.Tuple12
Field 3 of the tuple.
f3 - 类 中的变量org.apache.flink.api.java.tuple.Tuple13
Field 3 of the tuple.
f3 - 类 中的变量org.apache.flink.api.java.tuple.Tuple14
Field 3 of the tuple.
f3 - 类 中的变量org.apache.flink.api.java.tuple.Tuple15
Field 3 of the tuple.
f3 - 类 中的变量org.apache.flink.api.java.tuple.Tuple16
Field 3 of the tuple.
f3 - 类 中的变量org.apache.flink.api.java.tuple.Tuple17
Field 3 of the tuple.
f3 - 类 中的变量org.apache.flink.api.java.tuple.Tuple18
Field 3 of the tuple.
f3 - 类 中的变量org.apache.flink.api.java.tuple.Tuple19
Field 3 of the tuple.
f3 - 类 中的变量org.apache.flink.api.java.tuple.Tuple20
Field 3 of the tuple.
f3 - 类 中的变量org.apache.flink.api.java.tuple.Tuple21
Field 3 of the tuple.
f3 - 类 中的变量org.apache.flink.api.java.tuple.Tuple22
Field 3 of the tuple.
f3 - 类 中的变量org.apache.flink.api.java.tuple.Tuple23
Field 3 of the tuple.
f3 - 类 中的变量org.apache.flink.api.java.tuple.Tuple24
Field 3 of the tuple.
f3 - 类 中的变量org.apache.flink.api.java.tuple.Tuple25
Field 3 of the tuple.
f3 - 类 中的变量org.apache.flink.api.java.tuple.Tuple4
Field 3 of the tuple.
f3 - 类 中的变量org.apache.flink.api.java.tuple.Tuple5
Field 3 of the tuple.
f3 - 类 中的变量org.apache.flink.api.java.tuple.Tuple6
Field 3 of the tuple.
f3 - 类 中的变量org.apache.flink.api.java.tuple.Tuple7
Field 3 of the tuple.
f3 - 类 中的变量org.apache.flink.api.java.tuple.Tuple8
Field 3 of the tuple.
f3 - 类 中的变量org.apache.flink.api.java.tuple.Tuple9
Field 3 of the tuple.
f4 - 类 中的变量org.apache.flink.api.java.tuple.Tuple10
Field 4 of the tuple.
f4 - 类 中的变量org.apache.flink.api.java.tuple.Tuple11
Field 4 of the tuple.
f4 - 类 中的变量org.apache.flink.api.java.tuple.Tuple12
Field 4 of the tuple.
f4 - 类 中的变量org.apache.flink.api.java.tuple.Tuple13
Field 4 of the tuple.
f4 - 类 中的变量org.apache.flink.api.java.tuple.Tuple14
Field 4 of the tuple.
f4 - 类 中的变量org.apache.flink.api.java.tuple.Tuple15
Field 4 of the tuple.
f4 - 类 中的变量org.apache.flink.api.java.tuple.Tuple16
Field 4 of the tuple.
f4 - 类 中的变量org.apache.flink.api.java.tuple.Tuple17
Field 4 of the tuple.
f4 - 类 中的变量org.apache.flink.api.java.tuple.Tuple18
Field 4 of the tuple.
f4 - 类 中的变量org.apache.flink.api.java.tuple.Tuple19
Field 4 of the tuple.
f4 - 类 中的变量org.apache.flink.api.java.tuple.Tuple20
Field 4 of the tuple.
f4 - 类 中的变量org.apache.flink.api.java.tuple.Tuple21
Field 4 of the tuple.
f4 - 类 中的变量org.apache.flink.api.java.tuple.Tuple22
Field 4 of the tuple.
f4 - 类 中的变量org.apache.flink.api.java.tuple.Tuple23
Field 4 of the tuple.
f4 - 类 中的变量org.apache.flink.api.java.tuple.Tuple24
Field 4 of the tuple.
f4 - 类 中的变量org.apache.flink.api.java.tuple.Tuple25
Field 4 of the tuple.
f4 - 类 中的变量org.apache.flink.api.java.tuple.Tuple5
Field 4 of the tuple.
f4 - 类 中的变量org.apache.flink.api.java.tuple.Tuple6
Field 4 of the tuple.
f4 - 类 中的变量org.apache.flink.api.java.tuple.Tuple7
Field 4 of the tuple.
f4 - 类 中的变量org.apache.flink.api.java.tuple.Tuple8
Field 4 of the tuple.
f4 - 类 中的变量org.apache.flink.api.java.tuple.Tuple9
Field 4 of the tuple.
f5 - 类 中的变量org.apache.flink.api.java.tuple.Tuple10
Field 5 of the tuple.
f5 - 类 中的变量org.apache.flink.api.java.tuple.Tuple11
Field 5 of the tuple.
f5 - 类 中的变量org.apache.flink.api.java.tuple.Tuple12
Field 5 of the tuple.
f5 - 类 中的变量org.apache.flink.api.java.tuple.Tuple13
Field 5 of the tuple.
f5 - 类 中的变量org.apache.flink.api.java.tuple.Tuple14
Field 5 of the tuple.
f5 - 类 中的变量org.apache.flink.api.java.tuple.Tuple15
Field 5 of the tuple.
f5 - 类 中的变量org.apache.flink.api.java.tuple.Tuple16
Field 5 of the tuple.
f5 - 类 中的变量org.apache.flink.api.java.tuple.Tuple17
Field 5 of the tuple.
f5 - 类 中的变量org.apache.flink.api.java.tuple.Tuple18
Field 5 of the tuple.
f5 - 类 中的变量org.apache.flink.api.java.tuple.Tuple19
Field 5 of the tuple.
f5 - 类 中的变量org.apache.flink.api.java.tuple.Tuple20
Field 5 of the tuple.
f5 - 类 中的变量org.apache.flink.api.java.tuple.Tuple21
Field 5 of the tuple.
f5 - 类 中的变量org.apache.flink.api.java.tuple.Tuple22
Field 5 of the tuple.
f5 - 类 中的变量org.apache.flink.api.java.tuple.Tuple23
Field 5 of the tuple.
f5 - 类 中的变量org.apache.flink.api.java.tuple.Tuple24
Field 5 of the tuple.
f5 - 类 中的变量org.apache.flink.api.java.tuple.Tuple25
Field 5 of the tuple.
f5 - 类 中的变量org.apache.flink.api.java.tuple.Tuple6
Field 5 of the tuple.
f5 - 类 中的变量org.apache.flink.api.java.tuple.Tuple7
Field 5 of the tuple.
f5 - 类 中的变量org.apache.flink.api.java.tuple.Tuple8
Field 5 of the tuple.
f5 - 类 中的变量org.apache.flink.api.java.tuple.Tuple9
Field 5 of the tuple.
f6 - 类 中的变量org.apache.flink.api.java.tuple.Tuple10
Field 6 of the tuple.
f6 - 类 中的变量org.apache.flink.api.java.tuple.Tuple11
Field 6 of the tuple.
f6 - 类 中的变量org.apache.flink.api.java.tuple.Tuple12
Field 6 of the tuple.
f6 - 类 中的变量org.apache.flink.api.java.tuple.Tuple13
Field 6 of the tuple.
f6 - 类 中的变量org.apache.flink.api.java.tuple.Tuple14
Field 6 of the tuple.
f6 - 类 中的变量org.apache.flink.api.java.tuple.Tuple15
Field 6 of the tuple.
f6 - 类 中的变量org.apache.flink.api.java.tuple.Tuple16
Field 6 of the tuple.
f6 - 类 中的变量org.apache.flink.api.java.tuple.Tuple17
Field 6 of the tuple.
f6 - 类 中的变量org.apache.flink.api.java.tuple.Tuple18
Field 6 of the tuple.
f6 - 类 中的变量org.apache.flink.api.java.tuple.Tuple19
Field 6 of the tuple.
f6 - 类 中的变量org.apache.flink.api.java.tuple.Tuple20
Field 6 of the tuple.
f6 - 类 中的变量org.apache.flink.api.java.tuple.Tuple21
Field 6 of the tuple.
f6 - 类 中的变量org.apache.flink.api.java.tuple.Tuple22
Field 6 of the tuple.
f6 - 类 中的变量org.apache.flink.api.java.tuple.Tuple23
Field 6 of the tuple.
f6 - 类 中的变量org.apache.flink.api.java.tuple.Tuple24
Field 6 of the tuple.
f6 - 类 中的变量org.apache.flink.api.java.tuple.Tuple25
Field 6 of the tuple.
f6 - 类 中的变量org.apache.flink.api.java.tuple.Tuple7
Field 6 of the tuple.
f6 - 类 中的变量org.apache.flink.api.java.tuple.Tuple8
Field 6 of the tuple.
f6 - 类 中的变量org.apache.flink.api.java.tuple.Tuple9
Field 6 of the tuple.
f7 - 类 中的变量org.apache.flink.api.java.tuple.Tuple10
Field 7 of the tuple.
f7 - 类 中的变量org.apache.flink.api.java.tuple.Tuple11
Field 7 of the tuple.
f7 - 类 中的变量org.apache.flink.api.java.tuple.Tuple12
Field 7 of the tuple.
f7 - 类 中的变量org.apache.flink.api.java.tuple.Tuple13
Field 7 of the tuple.
f7 - 类 中的变量org.apache.flink.api.java.tuple.Tuple14
Field 7 of the tuple.
f7 - 类 中的变量org.apache.flink.api.java.tuple.Tuple15
Field 7 of the tuple.
f7 - 类 中的变量org.apache.flink.api.java.tuple.Tuple16
Field 7 of the tuple.
f7 - 类 中的变量org.apache.flink.api.java.tuple.Tuple17
Field 7 of the tuple.
f7 - 类 中的变量org.apache.flink.api.java.tuple.Tuple18
Field 7 of the tuple.
f7 - 类 中的变量org.apache.flink.api.java.tuple.Tuple19
Field 7 of the tuple.
f7 - 类 中的变量org.apache.flink.api.java.tuple.Tuple20
Field 7 of the tuple.
f7 - 类 中的变量org.apache.flink.api.java.tuple.Tuple21
Field 7 of the tuple.
f7 - 类 中的变量org.apache.flink.api.java.tuple.Tuple22
Field 7 of the tuple.
f7 - 类 中的变量org.apache.flink.api.java.tuple.Tuple23
Field 7 of the tuple.
f7 - 类 中的变量org.apache.flink.api.java.tuple.Tuple24
Field 7 of the tuple.
f7 - 类 中的变量org.apache.flink.api.java.tuple.Tuple25
Field 7 of the tuple.
f7 - 类 中的变量org.apache.flink.api.java.tuple.Tuple8
Field 7 of the tuple.
f7 - 类 中的变量org.apache.flink.api.java.tuple.Tuple9
Field 7 of the tuple.
f8 - 类 中的变量org.apache.flink.api.java.tuple.Tuple10
Field 8 of the tuple.
f8 - 类 中的变量org.apache.flink.api.java.tuple.Tuple11
Field 8 of the tuple.
f8 - 类 中的变量org.apache.flink.api.java.tuple.Tuple12
Field 8 of the tuple.
f8 - 类 中的变量org.apache.flink.api.java.tuple.Tuple13
Field 8 of the tuple.
f8 - 类 中的变量org.apache.flink.api.java.tuple.Tuple14
Field 8 of the tuple.
f8 - 类 中的变量org.apache.flink.api.java.tuple.Tuple15
Field 8 of the tuple.
f8 - 类 中的变量org.apache.flink.api.java.tuple.Tuple16
Field 8 of the tuple.
f8 - 类 中的变量org.apache.flink.api.java.tuple.Tuple17
Field 8 of the tuple.
f8 - 类 中的变量org.apache.flink.api.java.tuple.Tuple18
Field 8 of the tuple.
f8 - 类 中的变量org.apache.flink.api.java.tuple.Tuple19
Field 8 of the tuple.
f8 - 类 中的变量org.apache.flink.api.java.tuple.Tuple20
Field 8 of the tuple.
f8 - 类 中的变量org.apache.flink.api.java.tuple.Tuple21
Field 8 of the tuple.
f8 - 类 中的变量org.apache.flink.api.java.tuple.Tuple22
Field 8 of the tuple.
f8 - 类 中的变量org.apache.flink.api.java.tuple.Tuple23
Field 8 of the tuple.
f8 - 类 中的变量org.apache.flink.api.java.tuple.Tuple24
Field 8 of the tuple.
f8 - 类 中的变量org.apache.flink.api.java.tuple.Tuple25
Field 8 of the tuple.
f8 - 类 中的变量org.apache.flink.api.java.tuple.Tuple9
Field 8 of the tuple.
f9 - 类 中的变量org.apache.flink.api.java.tuple.Tuple10
Field 9 of the tuple.
f9 - 类 中的变量org.apache.flink.api.java.tuple.Tuple11
Field 9 of the tuple.
f9 - 类 中的变量org.apache.flink.api.java.tuple.Tuple12
Field 9 of the tuple.
f9 - 类 中的变量org.apache.flink.api.java.tuple.Tuple13
Field 9 of the tuple.
f9 - 类 中的变量org.apache.flink.api.java.tuple.Tuple14
Field 9 of the tuple.
f9 - 类 中的变量org.apache.flink.api.java.tuple.Tuple15
Field 9 of the tuple.
f9 - 类 中的变量org.apache.flink.api.java.tuple.Tuple16
Field 9 of the tuple.
f9 - 类 中的变量org.apache.flink.api.java.tuple.Tuple17
Field 9 of the tuple.
f9 - 类 中的变量org.apache.flink.api.java.tuple.Tuple18
Field 9 of the tuple.
f9 - 类 中的变量org.apache.flink.api.java.tuple.Tuple19
Field 9 of the tuple.
f9 - 类 中的变量org.apache.flink.api.java.tuple.Tuple20
Field 9 of the tuple.
f9 - 类 中的变量org.apache.flink.api.java.tuple.Tuple21
Field 9 of the tuple.
f9 - 类 中的变量org.apache.flink.api.java.tuple.Tuple22
Field 9 of the tuple.
f9 - 类 中的变量org.apache.flink.api.java.tuple.Tuple23
Field 9 of the tuple.
f9 - 类 中的变量org.apache.flink.api.java.tuple.Tuple24
Field 9 of the tuple.
f9 - 类 中的变量org.apache.flink.api.java.tuple.Tuple25
Field 9 of the tuple.
FAIL_ON_USER_CLASS_LOADING_METASPACE_OOM - 类 中的静态变量org.apache.flink.configuration.CoreOptions
 
failureRateRestart(int, Time, Time) - 类 中的静态方法org.apache.flink.api.common.restartstrategy.RestartStrategies
Generates a FailureRateRestartStrategyConfiguration.
FailureRateRestartStrategyConfiguration(int, Time, Time) - 类 的构造器org.apache.flink.api.common.restartstrategy.RestartStrategies.FailureRateRestartStrategyConfiguration
 
FailureTolerantObjectInputStream(InputStream, ClassLoader) - 类 的构造器org.apache.flink.util.InstantiationUtil.FailureTolerantObjectInputStream
 
FallbackKey - org.apache.flink.configuration中的类
A key with FallbackKeys will fall back to the FallbackKeys if it itself is not configured.
fallbackKeys() - 类 中的方法org.apache.flink.configuration.ConfigOption
Gets the fallback keys, in the order to be checked.
fallBackRestart() - 类 中的静态方法org.apache.flink.api.common.restartstrategy.RestartStrategies
 
FallbackRestartStrategyConfiguration() - 类 的构造器org.apache.flink.api.common.restartstrategy.RestartStrategies.FallbackRestartStrategyConfiguration
 
FALSE - 类 中的静态变量org.apache.flink.types.BooleanValue
 
FatalExitExceptionHandler - org.apache.flink.util中的类
Handler for uncaught exceptions that will log the exception and kill the process afterwards.
FatalExitExceptionHandler() - 类 的构造器org.apache.flink.util.FatalExitExceptionHandler
 
FETCH_BACKLOG - 类 中的静态变量org.apache.flink.configuration.BlobServerOptions
The config parameter defining the backlog of BLOB fetches on the JobManager.
FETCH_CONCURRENT - 类 中的静态变量org.apache.flink.configuration.BlobServerOptions
The config parameter defining the maximum number of concurrent BLOB fetches that the JobManager serves.
FETCH_RETRIES - 类 中的静态变量org.apache.flink.configuration.BlobServerOptions
The config parameter defining number of retires for failed BLOB fetches.
fieldIncluded - 类 中的变量org.apache.flink.api.common.io.GenericCsvInputFormat
 
FieldList - org.apache.flink.api.common.operators.util中的类
Immutable ordered list of fields IDs.
FieldList() - 类 的构造器org.apache.flink.api.common.operators.util.FieldList
 
FieldList(int) - 类 的构造器org.apache.flink.api.common.operators.util.FieldList
 
FieldList(Integer) - 类 的构造器org.apache.flink.api.common.operators.util.FieldList
 
FieldList(int...) - 类 的构造器org.apache.flink.api.common.operators.util.FieldList
 
fieldNames - 类 中的变量org.apache.flink.api.java.typeutils.RowTypeInfo
 
fieldNames - 类 中的变量org.apache.flink.api.java.typeutils.TupleTypeInfo
 
FieldParser<T> - org.apache.flink.types.parser中的类
A FieldParser is used parse a field from a sequence of bytes.
FieldParser() - 类 的构造器org.apache.flink.types.parser.FieldParser
 
FieldParser.ParseErrorState - org.apache.flink.types.parser中的枚举
An enumeration of different types of errors that may occur.
FieldSerializer - org.apache.flink.api.java.typeutils.runtime中的类
This class is for the serialization of java.lang.reflect.Field, which doesn't implement Serializable, therefore readObject/writeObject need to be implemented in classes where there is a field of type java.lang.reflect.Field.
FieldSerializer() - 类 的构造器org.apache.flink.api.java.typeutils.runtime.FieldSerializer
 
fieldSerializers - 类 中的变量org.apache.flink.api.common.typeutils.CompositeSerializer
Serializers for fields which constitute T.
fieldSerializers - 类 中的变量org.apache.flink.api.java.typeutils.runtime.TupleSerializerBase
 
FieldSet - org.apache.flink.api.common.operators.util中的类
Immutable unordered collection of fields IDs.
FieldSet() - 类 的构造器org.apache.flink.api.common.operators.util.FieldSet
Creates a new empty set of fields.
FieldSet(Integer) - 类 的构造器org.apache.flink.api.common.operators.util.FieldSet
Creates a set with one field.
FieldSet(int...) - 类 的构造器org.apache.flink.api.common.operators.util.FieldSet
Creates a set with the given fields.
FieldSet(int[], boolean) - 类 的构造器org.apache.flink.api.common.operators.util.FieldSet
Creates a set with the given fields.
FieldSet(Collection<Integer>) - 类 的构造器org.apache.flink.api.common.operators.util.FieldSet
 
FILE_PARAMETER_KEY - 类 中的静态变量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) - 类 的构造器org.apache.flink.api.common.io.FileInputFormat.FileBaseStatistics
Creates a new statistics object.
FileInputFormat<OT> - org.apache.flink.api.common.io中的类
The base class for RichInputFormats that read from files.
FileInputFormat() - 类 的构造器org.apache.flink.api.common.io.FileInputFormat
 
FileInputFormat(Path) - 类 的构造器org.apache.flink.api.common.io.FileInputFormat
 
FileInputFormat.FileBaseStatistics - org.apache.flink.api.common.io中的类
Encapsulation of the basic statistics the optimizer obtains about a file.
FileInputFormat.InputSplitOpenThread - org.apache.flink.api.common.io中的类
Obtains a DataInputStream in an thread that is not interrupted.
FileInputSplit - 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[]) - 类 的构造器org.apache.flink.core.fs.FileInputSplit
Constructs a split with host information.
fileModTime - 类 中的变量org.apache.flink.api.common.io.FileInputFormat.FileBaseStatistics
 
FileOutputFormat<IT> - org.apache.flink.api.common.io中的类
The abstract base class for all Rich output formats that are file based.
FileOutputFormat() - 类 的构造器org.apache.flink.api.common.io.FileOutputFormat
 
FileOutputFormat(Path) - 类 的构造器org.apache.flink.api.common.io.FileOutputFormat
 
FileOutputFormat.OutputDirectoryMode - org.apache.flink.api.common.io中的枚举
Behavior for creating output directories.
filePath - 类 中的变量org.apache.flink.api.common.cache.DistributedCache.DistributedCacheEntry
 
filePath - 类 中的变量org.apache.flink.api.common.io.FileInputFormat
FilePathFilter - org.apache.flink.api.common.io中的类
The FilePathFilter.filterPath(Path) method is responsible for deciding if a path is eligible for further processing or not.
FilePathFilter() - 类 的构造器org.apache.flink.api.common.io.FilePathFilter
 
FilePathFilter.DefaultFilter - org.apache.flink.api.common.io中的类
The default file path filtering method and is used if no other such function is provided.
fileSize - 类 中的变量org.apache.flink.api.common.io.FileInputFormat.FileBaseStatistics
 
FileStatus - org.apache.flink.core.fs中的接口
Interface that represents the client side information for a file independent of the file system.
FileSystem - org.apache.flink.core.fs中的类
Abstract base class of all file systems used by Flink.
FileSystem() - 类 的构造器org.apache.flink.core.fs.FileSystem
 
FileSystem.WriteMode - org.apache.flink.core.fs中的枚举
The possible write modes.
FILESYSTEM_DEFAULT_OVERWRITE_KEY - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
FILESYSTEM_OUTPUT_ALWAYS_CREATE_DIRECTORY - 类 中的静态变量org.apache.flink.configuration.CoreOptions
Specifies whether the file systems should always create a directory for the output, even with a parallelism of one.
FILESYSTEM_OUTPUT_ALWAYS_CREATE_DIRECTORY_KEY - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
FILESYSTEM_SCHEME - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
fileSystemConnectionLimit(String) - 类 中的静态方法org.apache.flink.configuration.CoreOptions
The total number of input plus output connections that a file system for the given scheme may open.
fileSystemConnectionLimitIn(String) - 类 中的静态方法org.apache.flink.configuration.CoreOptions
The total number of input connections that a file system for the given scheme may open.
fileSystemConnectionLimitOut(String) - 类 中的静态方法org.apache.flink.configuration.CoreOptions
The total number of output connections that a file system for the given scheme may open.
fileSystemConnectionLimitStreamInactivityTimeout(String) - 类 中的静态方法org.apache.flink.configuration.CoreOptions
If any connection limit is configured, this option can be optionally set to define after which time (in milliseconds) inactive streams are reclaimed.
fileSystemConnectionLimitTimeout(String) - 类 中的静态方法org.apache.flink.configuration.CoreOptions
If any connection limit is configured, this option can be optionally set to define after which time (in milliseconds) stream opening fails with a timeout exception, if no stream connection becomes available.
FileSystemFactory - org.apache.flink.core.fs中的接口
A factory to create file systems.
FileSystemKind - org.apache.flink.core.fs中的枚举
An enumeration defining the kind and characteristics of a FileSystem.
FileSystemSafetyNet - org.apache.flink.core.fs中的类
The FileSystemSafetyNet can be used to guard a thread against FileSystem stream resource leaks.
FileSystemSafetyNet() - 类 的构造器org.apache.flink.core.fs.FileSystemSafetyNet
 
FILESYTEM_DEFAULT_OVERRIDE - 类 中的静态变量org.apache.flink.configuration.CoreOptions
Specifies whether file output writers should overwrite existing files by default.
FileUtils - org.apache.flink.util中的类
This is a utility class to deal files and directories.
filter(T) - 接口 中的方法org.apache.flink.api.common.functions.FilterFunction
The filter function that evaluates the predicate.
filter(T) - 类 中的方法org.apache.flink.api.common.functions.RichFilterFunction
 
FilterFunction<T> - org.apache.flink.api.common.functions中的接口
A filter function is a predicate applied individually to each record.
FilterOperatorBase<T,FT extends FlatMapFunction<T,T>> - org.apache.flink.api.common.operators.base中的类
 
FilterOperatorBase(UserCodeWrapper<FT>, UnaryOperatorInformation<T, T>, String) - 类 的构造器org.apache.flink.api.common.operators.base.FilterOperatorBase
 
FilterOperatorBase(FT, UnaryOperatorInformation<T, T>, String) - 类 的构造器org.apache.flink.api.common.operators.base.FilterOperatorBase
 
FilterOperatorBase(Class<? extends FT>, UnaryOperatorInformation<T, T>, String) - 类 的构造器org.apache.flink.api.common.operators.base.FilterOperatorBase
 
filterPath(Path) - 类 中的方法org.apache.flink.api.common.io.FilePathFilter.DefaultFilter
 
filterPath(Path) - 类 中的方法org.apache.flink.api.common.io.FilePathFilter
Returns true if the filePath given is to be ignored when processing a directory, e.g.
filterPath(Path) - 类 中的方法org.apache.flink.api.common.io.GlobFilePathFilter
 
filterPrefixMapKey(String, String) - 类 中的静态方法org.apache.flink.configuration.ConfigurationUtils
Filter condition for prefix map keys.
filterRecoveredCommittables(List<GlobalCommT>) - 接口 中的方法org.apache.flink.api.connector.sink.GlobalCommitter
Find out which global committables need to be retried when recovering from the failure.
finalizeGlobal(int) - 接口 中的方法org.apache.flink.api.common.io.FinalizeOnMaster
The method is invoked on the master (JobManager) after all (parallel) instances of an OutputFormat finished.
FinalizeOnMaster - org.apache.flink.api.common.io中的接口
This interface may be implemented by OutputFormats to have the master finalize them globally.
find(CharSequence) - 类 中的方法org.apache.flink.types.StringValue
Finds any occurrence of the str character sequence in this StringValue.
find(CharSequence, int) - 类 中的方法org.apache.flink.types.StringValue
Finds any occurrence of the str character sequence in this StringValue.
findPlugins() - 类 中的方法org.apache.flink.core.plugin.DirectoryBasedPluginFinder
 
findPlugins() - 接口 中的方法org.apache.flink.core.plugin.PluginFinder
Find plugins and return a corresponding collection of PluginDescriptor instances.
findSerializedThrowable(Throwable, Class<T>, ClassLoader) - 类 中的静态方法org.apache.flink.util.ExceptionUtils
Checks whether a throwable chain contains a specific type of exception and returns it.
findThrowable(Throwable, Class<T>) - 类 中的静态方法org.apache.flink.util.ExceptionUtils
Checks whether a throwable chain contains a specific type of exception and returns it.
findThrowable(Throwable, Predicate<Throwable>) - 类 中的静态方法org.apache.flink.util.ExceptionUtils
Checks whether a throwable chain contains an exception matching a predicate and returns it.
findThrowableSerializedAware(Throwable, Class<T>, ClassLoader) - 类 中的静态方法org.apache.flink.util.ExceptionUtils
Checks whether a throwable chain contains a specific type of exception and returns it.
findThrowableWithMessage(Throwable, String) - 类 中的静态方法org.apache.flink.util.ExceptionUtils
Checks whether a throwable chain contains a specific error message and returns the corresponding throwable.
FINE_GRAINED_SHUFFLE_MODE_ALL_BLOCKING - 类 中的静态变量org.apache.flink.configuration.ClusterOptions
 
finish() - 接口 中的方法org.apache.flink.api.common.serialization.BulkWriter
Finishes the writing.
firstOrSuppressed(T, T) - 类 中的静态方法org.apache.flink.util.ExceptionUtils
Adds a new exception as a suppressed exception to a prior exception, or returns the new exception, if no prior exception exists.
fixedDelayRestart(int, long) - 类 中的静态方法org.apache.flink.api.common.restartstrategy.RestartStrategies
Generates a FixedDelayRestartStrategyConfiguration.
fixedDelayRestart(int, Time) - 类 中的静态方法org.apache.flink.api.common.restartstrategy.RestartStrategies
Generates a FixedDelayRestartStrategyConfiguration.
FixedRetryStrategy - org.apache.flink.util.concurrent中的类
An implementation of RetryStrategy that retries at a fixed delay.
FixedRetryStrategy(int, Duration) - 类 的构造器org.apache.flink.util.concurrent.FixedRetryStrategy
 
FLAMEGRAPH_CLEANUP_INTERVAL - 类 中的静态变量org.apache.flink.configuration.RestOptions
"Time after which cached stats are cleaned up if not accessed.
FLAMEGRAPH_DELAY - 类 中的静态变量org.apache.flink.configuration.RestOptions
Delay between individual stack trace samples taken for building a FlameGraph.
FLAMEGRAPH_NUM_SAMPLES - 类 中的静态变量org.apache.flink.configuration.RestOptions
Number of samples to take to build a FlameGraph.
FLAMEGRAPH_REFRESH_INTERVAL - 类 中的静态变量org.apache.flink.configuration.RestOptions
Time after which available stats are deprecated and need to be refreshed (by resampling).
FLAMEGRAPH_STACK_TRACE_DEPTH - 类 中的静态变量org.apache.flink.configuration.RestOptions
Maximum depth of stack traces used to create FlameGraphs.
FlatFieldDescriptor(int, TypeInformation<?>) - 类 的构造器org.apache.flink.api.common.typeutils.CompositeType.FlatFieldDescriptor
 
FlatJoinFunction<IN1,IN2,OUT> - org.apache.flink.api.common.functions中的接口
Interface for Join functions.
flatMap(T, Collector<O>) - 接口 中的方法org.apache.flink.api.common.functions.FlatMapFunction
The core method of the FlatMapFunction.
flatMap(IN, Collector<OUT>) - 类 中的方法org.apache.flink.api.common.functions.RichFlatMapFunction
 
flatMap(X, Collector<X>) - 类 中的方法org.apache.flink.api.common.operators.base.BulkIterationBase.TerminationCriterionMapper
 
flatMap(Iterable<G>, Function<K, V>) - 类 中的静态方法org.apache.flink.util.IterableUtils
Flatmap the two-dimensional Iterable into an one-dimensional Iterable and convert the keys into items.
FlatMapFunction<T,O> - org.apache.flink.api.common.functions中的接口
Base interface for flatMap functions.
FlatMapOperatorBase<IN,OUT,FT extends FlatMapFunction<IN,OUT>> - org.apache.flink.api.common.operators.base中的类
 
FlatMapOperatorBase(UserCodeWrapper<FT>, UnaryOperatorInformation<IN, OUT>, String) - 类 的构造器org.apache.flink.api.common.operators.base.FlatMapOperatorBase
 
FlatMapOperatorBase(FT, UnaryOperatorInformation<IN, OUT>, String) - 类 的构造器org.apache.flink.api.common.operators.base.FlatMapOperatorBase
 
FlatMapOperatorBase(Class<? extends FT>, UnaryOperatorInformation<IN, OUT>, String) - 类 的构造器org.apache.flink.api.common.operators.base.FlatMapOperatorBase
 
flatten(CloseableIterator<T>...) - 接口 中的静态方法org.apache.flink.util.CloseableIterator
 
flatten(Properties) - 类 中的静态方法org.apache.flink.util.PropertiesUtil
Flatten a recursive Properties to a first level property map.
FLINK_BASE_DIR_PATH_KEY - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
This parameter should not be used any more. A running Flink cluster should make no assumption about its location.
FLINK_CLI_JVM_OPTIONS - 类 中的静态变量org.apache.flink.configuration.CoreOptions
 
FLINK_CONF_FILENAME - 类 中的静态变量org.apache.flink.configuration.GlobalConfiguration
 
FLINK_HADOOP_CONF_DIR - 类 中的静态变量org.apache.flink.configuration.CoreOptions
This options is here only for documentation generation, it is only evaluated in the shell scripts.
FLINK_HBASE_CONF_DIR - 类 中的静态变量org.apache.flink.configuration.CoreOptions
This options is here only for documentation generation, it is only evaluated in the shell scripts.
FLINK_HS_JVM_OPTIONS - 类 中的静态变量org.apache.flink.configuration.CoreOptions
 
FLINK_JM_JVM_OPTIONS - 类 中的静态变量org.apache.flink.configuration.CoreOptions
 
FLINK_JVM_OPTIONS - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
FLINK_JVM_OPTIONS - 类 中的静态变量org.apache.flink.configuration.CoreOptions
 
FLINK_LOG_DIR - 类 中的静态变量org.apache.flink.configuration.CoreOptions
This options is here only for documentation generation, it is only evaluated in the shell scripts.
FLINK_LOG_MAX - 类 中的静态变量org.apache.flink.configuration.CoreOptions
This options is here only for documentation generation, it is only evaluated in the shell scripts.
FLINK_PID_DIR - 类 中的静态变量org.apache.flink.configuration.CoreOptions
The config parameter defining the directory for Flink PID file. see: bin/config.sh#KEY_ENV_PID_DIR and bin/config.sh#DEFAULT_ENV_PID_DIR
FLINK_SSH_OPTIONS - 类 中的静态变量org.apache.flink.configuration.CoreOptions
This options is here only for documentation generation, it is only evaluated in the shell scripts.
FLINK_TM_JVM_OPTIONS - 类 中的静态变量org.apache.flink.configuration.CoreOptions
 
FLINK_YARN_CONF_DIR - 类 中的静态变量org.apache.flink.configuration.CoreOptions
This options is here only for documentation generation, it is only evaluated in the shell scripts.
FlinkConnectorRateLimiter - org.apache.flink.api.common.io.ratelimiting中的接口
An interface to create a ratelimiter The ratelimiter is configured via FlinkConnectorRateLimiter.setRate(long) and created via FlinkConnectorRateLimiter.open(RuntimeContext).
FlinkException - org.apache.flink.util中的异常错误
Base class of all Flink-specific checked exceptions.
FlinkException(String) - 异常错误 的构造器org.apache.flink.util.FlinkException
Creates a new Exception with the given message and null as the cause.
FlinkException(Throwable) - 异常错误 的构造器org.apache.flink.util.FlinkException
Creates a new exception with a null message and the given cause.
FlinkException(String, Throwable) - 异常错误 的构造器org.apache.flink.util.FlinkException
Creates a new exception with the given message and cause.
FlinkRuntimeException - org.apache.flink.util中的异常错误
Base class of all Flink-specific unchecked exceptions.
FlinkRuntimeException(String) - 异常错误 的构造器org.apache.flink.util.FlinkRuntimeException
Creates a new Exception with the given message and null as the cause.
FlinkRuntimeException(Throwable) - 异常错误 的构造器org.apache.flink.util.FlinkRuntimeException
Creates a new exception with a null message and the given cause.
FlinkRuntimeException(String, Throwable) - 异常错误 的构造器org.apache.flink.util.FlinkRuntimeException
Creates a new exception with the given message and cause.
FlinkSecurityManager - org.apache.flink.core.security中的类
FlinkSecurityManager to control certain behaviors that can be captured by Java system security manager.
FlinkUserCodeClassLoader - org.apache.flink.util中的类
This class loader accepts a custom handler if an exception occurs in FlinkUserCodeClassLoader.loadClass(String, boolean).
FlinkUserCodeClassLoader(URL[], ClassLoader) - 类 的构造器org.apache.flink.util.FlinkUserCodeClassLoader
 
FlinkUserCodeClassLoader(URL[], ClassLoader, Consumer<Throwable>) - 类 的构造器org.apache.flink.util.FlinkUserCodeClassLoader
 
flipSignBit(long) - 类 中的静态方法org.apache.flink.util.MathUtils
Flips the sign bit (most-significant-bit) of the input.
FLOAT - 类 中的静态变量org.apache.flink.api.common.typeinfo.Types
Returns type information for both a primitive float and Float.
FLOAT_ARRAY_TYPE_INFO - 类 中的静态变量org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
 
FLOAT_PRIMITIVE_ARRAY_TYPE_INFO - 类 中的静态变量org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
 
FLOAT_TYPE_INFO - 类 中的静态变量org.apache.flink.api.common.typeinfo.BasicTypeInfo
 
FLOAT_VALUE_TYPE_INFO - 类 中的静态变量org.apache.flink.api.java.typeutils.ValueTypeInfo
 
FloatComparator - org.apache.flink.api.common.typeutils.base中的类
 
FloatComparator(boolean) - 类 的构造器org.apache.flink.api.common.typeutils.base.FloatComparator
 
FloatParser - org.apache.flink.types.parser中的类
Parses a text field into a Float.
FloatParser() - 类 的构造器org.apache.flink.types.parser.FloatParser
 
FloatPrimitiveArrayComparator - org.apache.flink.api.common.typeutils.base.array中的类
 
FloatPrimitiveArrayComparator(boolean) - 类 的构造器org.apache.flink.api.common.typeutils.base.array.FloatPrimitiveArrayComparator
 
FloatPrimitiveArraySerializer - org.apache.flink.api.common.typeutils.base.array中的类
A serializer for float arrays.
FloatPrimitiveArraySerializer() - 类 的构造器org.apache.flink.api.common.typeutils.base.array.FloatPrimitiveArraySerializer
 
FloatPrimitiveArraySerializer.FloatPrimitiveArraySerializerSnapshot - org.apache.flink.api.common.typeutils.base.array中的类
Serializer configuration snapshot for compatibility and format evolution.
FloatPrimitiveArraySerializerSnapshot() - 类 的构造器org.apache.flink.api.common.typeutils.base.array.FloatPrimitiveArraySerializer.FloatPrimitiveArraySerializerSnapshot
 
FloatSerializer - org.apache.flink.api.common.typeutils.base中的类
Type serializer for Float.
FloatSerializer() - 类 的构造器org.apache.flink.api.common.typeutils.base.FloatSerializer
 
FloatSerializer.FloatSerializerSnapshot - org.apache.flink.api.common.typeutils.base中的类
Serializer configuration snapshot for compatibility and format evolution.
FloatSerializerSnapshot() - 类 的构造器org.apache.flink.api.common.typeutils.base.FloatSerializer.FloatSerializerSnapshot
 
floatType() - 类 中的方法org.apache.flink.configuration.ConfigOptions.OptionBuilder
Defines that the value of the option should be of Float type.
FloatValue - org.apache.flink.types中的类
Boxed serializable and comparable single precision floating point type, representing the primitive type float.
FloatValue() - 类 的构造器org.apache.flink.types.FloatValue
Initializes the encapsulated float with 0.0.
FloatValue(float) - 类 的构造器org.apache.flink.types.FloatValue
Initializes the encapsulated float with the provided value.
FloatValueComparator - org.apache.flink.api.common.typeutils.base中的类
Specialized comparator for FloatValue based on CopyableValueComparator.
FloatValueComparator(boolean) - 类 的构造器org.apache.flink.api.common.typeutils.base.FloatValueComparator
 
FloatValueParser - org.apache.flink.types.parser中的类
Parses a text field into a FloatValue
FloatValueParser() - 类 的构造器org.apache.flink.types.parser.FloatValueParser
 
FloatValueSerializer - org.apache.flink.api.common.typeutils.base中的类
 
FloatValueSerializer() - 类 的构造器org.apache.flink.api.common.typeutils.base.FloatValueSerializer
 
FloatValueSerializer.FloatValueSerializerSnapshot - org.apache.flink.api.common.typeutils.base中的类
Serializer configuration snapshot for compatibility and format evolution.
FloatValueSerializerSnapshot() - 类 的构造器org.apache.flink.api.common.typeutils.base.FloatValueSerializer.FloatValueSerializerSnapshot
 
flush() - 接口 中的方法org.apache.flink.api.common.serialization.BulkWriter
Flushes all intermediate buffered data to the output stream.
flush() - 类 中的方法org.apache.flink.core.fs.FSDataOutputStream
Flushes the stream, writing any data currently buffered in stream implementation to the proper output stream.
flush() - 类 中的方法org.apache.flink.core.fs.FSDataOutputStreamWrapper
 
flush() - 类 中的方法org.apache.flink.core.fs.local.LocalDataOutputStream
 
FLUSH_AFTER_EVERY_RECORD - 类 中的静态变量org.apache.flink.configuration.ExecutionOptions
A special marker value for flushing network buffers after each record.
forBoundedOutOfOrderness(Duration) - 接口 中的静态方法org.apache.flink.api.common.eventtime.WatermarkStrategy
Creates a watermark strategy for situations where records are out of order, but you can place an upper bound on how far the events are out of order.
FORCE_AVRO - 类 中的静态变量org.apache.flink.configuration.PipelineOptions
 
FORCE_KRYO - 类 中的静态变量org.apache.flink.configuration.PipelineOptions
 
forceProcessExit(int) - 类 中的静态方法org.apache.flink.core.security.FlinkSecurityManager
Use this method to circumvent the configured FlinkSecurityManager behavior, ensuring that the current JVM process will always stop via System.exit() or Runtime.getRuntime().halt().
forEach(LinkedOptionalMap.ConsumerWithException<K, V, E>) - 类 中的方法org.apache.flink.util.LinkedOptionalMap
 
forEachRemaining(Consumer<? super E>) - 类 中的方法org.apache.flink.util.CloseableIterator.IteratorAdapter
 
forGenerator(WatermarkGeneratorSupplier<T>) - 接口 中的静态方法org.apache.flink.api.common.eventtime.WatermarkStrategy
Creates a watermark strategy based on an existing WatermarkGeneratorSupplier.
forInputsCount(int) - 类 中的静态方法org.apache.flink.api.common.eventtime.IndexedCombinedWatermarkStatus
 
FORK_JOIN_EXECUTOR_PARALLELISM_FACTOR - 类 中的静态变量org.apache.flink.configuration.AkkaOptions
 
FORK_JOIN_EXECUTOR_PARALLELISM_MAX - 类 中的静态变量org.apache.flink.configuration.AkkaOptions
 
FORK_JOIN_EXECUTOR_PARALLELISM_MIN - 类 中的静态变量org.apache.flink.configuration.AkkaOptions
 
format(Description) - 类 中的方法org.apache.flink.configuration.description.Formatter
Formats the description into a String using format specific tags.
format(LinkElement) - 类 中的方法org.apache.flink.configuration.description.Formatter
 
format(TextElement) - 类 中的方法org.apache.flink.configuration.description.Formatter
 
format(LineBreakElement) - 类 中的方法org.apache.flink.configuration.description.Formatter
 
format(ListElement) - 类 中的方法org.apache.flink.configuration.description.Formatter
 
format(Formatter) - 类 中的方法org.apache.flink.configuration.description.LineBreakElement
 
format(Formatter) - 类 中的方法org.apache.flink.configuration.description.LinkElement
 
format(Formatter) - 类 中的方法org.apache.flink.configuration.description.ListElement
 
format(Formatter) - 类 中的方法org.apache.flink.configuration.description.TextElement
 
formatLineBreak(StringBuilder) - 类 中的方法org.apache.flink.configuration.description.Formatter
 
formatLineBreak(StringBuilder) - 类 中的方法org.apache.flink.configuration.description.HtmlFormatter
 
formatLink(StringBuilder, String, String) - 类 中的方法org.apache.flink.configuration.description.Formatter
 
formatLink(StringBuilder, String, String) - 类 中的方法org.apache.flink.configuration.description.HtmlFormatter
 
formatList(StringBuilder, String[]) - 类 中的方法org.apache.flink.configuration.description.Formatter
 
formatList(StringBuilder, String[]) - 类 中的方法org.apache.flink.configuration.description.HtmlFormatter
 
Formatter - org.apache.flink.configuration.description中的类
Allows providing multiple formatters for the description.
Formatter() - 类 的构造器org.apache.flink.configuration.description.Formatter
 
formatText(StringBuilder, String, String[], EnumSet<TextElement.TextStyle>) - 类 中的方法org.apache.flink.configuration.description.Formatter
 
formatText(StringBuilder, String, String[], EnumSet<TextElement.TextStyle>) - 类 中的方法org.apache.flink.configuration.description.HtmlFormatter
 
formatWithHighestUnit(Duration) - 类 中的静态方法org.apache.flink.util.TimeUtils
Pretty prints the duration as a lowest granularity unit that does not lose precision.
formatWrapper - 类 中的变量org.apache.flink.api.common.operators.GenericDataSinkBase
 
formatWrapper - 类 中的变量org.apache.flink.api.common.operators.GenericDataSourceBase
 
forMonotonousTimestamps() - 接口 中的静态方法org.apache.flink.api.common.eventtime.WatermarkStrategy
Creates a watermark strategy for situations with monotonously ascending timestamps.
forward(CompletableFuture<T>, CompletableFuture<T>) - 类 中的静态方法org.apache.flink.util.concurrent.FutureUtils
Forwards the value from the source future to the target future.
forwardAsync(CompletableFuture<T>, CompletableFuture<T>, Executor) - 类 中的静态方法org.apache.flink.util.concurrent.FutureUtils
Forwards the value from the source future to the target future using the provided executor.
FractionalTypeInfo<T> - 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>>) - 类 的构造器org.apache.flink.api.common.typeinfo.FractionalTypeInfo
 
FRAMESIZE - 类 中的静态变量org.apache.flink.configuration.AkkaOptions
Maximum framesize of akka messages.
FRAMEWORK_HEAP_MEMORY - 类 中的静态变量org.apache.flink.configuration.TaskManagerOptions
Framework Heap Memory size for TaskExecutors.
FRAMEWORK_OFF_HEAP_MEMORY - 类 中的静态变量org.apache.flink.configuration.TaskManagerOptions
Framework Off-Heap Memory size for TaskExecutors.
free() - 类 中的方法org.apache.flink.core.memory.MemorySegment
Frees this memory segment.
from() - 类 中的方法org.apache.flink.api.connector.source.lib.NumberSequenceSource.NumberSequenceSplit
 
fromBoolean(boolean) - 枚举 中的静态方法org.apache.flink.util.TernaryBoolean
Converts the given boolean to a TernaryBoolean, TernaryBoolean.TRUE or TernaryBoolean.FALSE respectively.
fromBoxedBoolean(Boolean) - 枚举 中的静态方法org.apache.flink.util.TernaryBoolean
Converts the given boxed Boolean to a TernaryBoolean.
fromByteArray(byte[]) - 类 中的静态方法org.apache.flink.api.common.JobID
Creates a new JobID from the given byte sequence.
fromByteBuffer(ByteBuffer) - 类 中的静态方法org.apache.flink.api.common.JobID
 
fromBytes(byte[]) - 类 中的静态方法org.apache.flink.util.CompressedSerializedValue
Construct a compressed serialized value with a serialized byte array.
fromBytes(byte[]) - 类 中的静态方法org.apache.flink.util.SerializedValue
Constructs serialized value from serialized data.
fromByteValue(byte) - 枚举 中的静态方法org.apache.flink.types.RowKind
Creates a RowKind from the given byte value.
fromConfig(Configuration, String) - 类 中的静态方法org.apache.flink.core.fs.LimitedConnectionsFileSystem.ConnectionLimitingSettings
Parses and returns the settings for connection limiting, for the file system with the given file system scheme.
fromConfiguration(ReadableConfig) - 类 中的静态方法org.apache.flink.api.common.restartstrategy.RestartStrategies
fromConfiguration(Configuration) - 类 中的静态方法org.apache.flink.core.plugin.PluginConfig
 
fromDuration(Duration) - 类 中的静态方法org.apache.flink.api.common.time.Time
Creates a new Time that represents the number of milliseconds in the given duration.
fromHexString(String) - 类 中的静态方法org.apache.flink.api.common.JobID
Parses a JobID from the given string.
fromJobSubmissionResult(JobSubmissionResult) - 类 中的静态方法org.apache.flink.api.common.JobExecutionResult
已过时。
Will be removed in future versions.
fromList(List<T>, Consumer<T>) - 接口 中的静态方法org.apache.flink.util.CloseableIterator
 
fromLocalFile(File) - 类 中的静态方法org.apache.flink.core.fs.Path
Creates a path for the given local file.
fromMap(Map<String, String>) - 类 中的静态方法org.apache.flink.configuration.Configuration
Creates a new configuration that is initialized with the options of the given map.
fromNow(Duration) - 类 中的静态方法org.apache.flink.api.common.time.Deadline
Constructs a Deadline that is a given duration after now.
fromNowWithClock(Duration, Clock) - 类 中的静态方法org.apache.flink.api.common.time.Deadline
Constructs a Deadline that is a given duration after now, where now and all other times from this deadline are defined by the given Clock.
fromObject(T) - 类 中的静态方法org.apache.flink.util.CompressedSerializedValue
Constructs a compressed serialized value for the given object.
FS_SMALL_FILE_THRESHOLD - 类 中的静态变量org.apache.flink.configuration.CheckpointingOptions
The minimum size of state data files.
FS_STREAM_OPENING_TIMEOUT_KEY - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
The config parameter defining the timeout for filesystem stream opening.
FS_WRITE_BUFFER_SIZE - 类 中的静态变量org.apache.flink.configuration.CheckpointingOptions
The default size of the write buffer for the checkpoint streams that write to file systems.
FSDataInputStream - org.apache.flink.core.fs中的类
Interface for a data input stream to a file on a FileSystem.
FSDataInputStream() - 类 的构造器org.apache.flink.core.fs.FSDataInputStream
 
FSDataInputStreamWrapper - org.apache.flink.core.fs中的类
Simple forwarding wrapper around FSDataInputStream.
FSDataInputStreamWrapper(FSDataInputStream) - 类 的构造器org.apache.flink.core.fs.FSDataInputStreamWrapper
 
FSDataOutputStream - org.apache.flink.core.fs中的类
An output stream to a file that is created via a FileSystem.
FSDataOutputStream() - 类 的构造器org.apache.flink.core.fs.FSDataOutputStream
 
FSDataOutputStreamWrapper - org.apache.flink.core.fs中的类
Simple forwarding wrapper around FSDataInputStream.
FSDataOutputStreamWrapper(FSDataOutputStream) - 类 的构造器org.apache.flink.core.fs.FSDataOutputStreamWrapper
 
FullTypeInfo(Class<?>, ReflectionUtil.FullTypeInfo[]) - 类 的构造器org.apache.flink.util.ReflectionUtil.FullTypeInfo
 
Function - org.apache.flink.api.common.functions中的接口
The base interface for all user-defined functions.
FunctionUtils - org.apache.flink.api.common.functions.util中的类
Utility class that contains helper methods to work with Flink Function class.
FunctionUtils - org.apache.flink.util.function中的类
Utility class for Flink's functions.
FunctionWithException<T,R,E extends Throwable> - org.apache.flink.util.function中的接口
A functional interface for a Function that may throw exceptions.
FutureConsumerWithException<T,E extends Throwable> - org.apache.flink.util.concurrent中的接口
A checked extension of the Consumer interface which rethrows exceptions wrapped in a CompletionException.
FutureTaskWithException<V> - org.apache.flink.util.function中的类
FutureTask that also implements RunnableWithException.
FutureTaskWithException(Callable<V>) - 类 的构造器org.apache.flink.util.function.FutureTaskWithException
 
FutureTaskWithException(RunnableWithException) - 类 的构造器org.apache.flink.util.function.FutureTaskWithException
 
FutureUtils - org.apache.flink.util.concurrent中的类
A collection of utilities that expand the usage of CompletableFuture.
FutureUtils() - 类 的构造器org.apache.flink.util.concurrent.FutureUtils
 
FutureUtils.ConjunctFuture<T> - org.apache.flink.util.concurrent中的类
A future that is complete once multiple other futures completed.
FutureUtils.RetryException - org.apache.flink.util.concurrent中的异常错误
Exception with which the returned future is completed if the FutureUtils.retry(Supplier, int, Executor) operation fails.

G

generate() - 类 中的静态方法org.apache.flink.api.common.JobID
Creates a new (statistically) random JobID.
generateEntropy() - 接口 中的方法org.apache.flink.core.fs.EntropyInjectingFileSystem
Creates a string with random entropy to be injected into a path.
generateRandomAlphanumericString(Random, int) - 类 中的静态方法org.apache.flink.util.StringUtils
Creates a random alphanumeric string of given length.
GENERIC(Class<T>) - 类 中的静态方法org.apache.flink.api.common.typeinfo.Types
Returns generic type information for any Java object.
GENERIC_TYPES - 类 中的静态变量org.apache.flink.configuration.PipelineOptions
 
GenericArraySerializer<C> - org.apache.flink.api.common.typeutils.base中的类
A serializer for arrays of objects.
GenericArraySerializer(Class<C>, TypeSerializer<C>) - 类 的构造器org.apache.flink.api.common.typeutils.base.GenericArraySerializer
 
GenericArraySerializerConfigSnapshot<C> - org.apache.flink.api.common.typeutils.base中的类
已过时。
this is deprecated and no longer used by the GenericArraySerializer. It has been replaced by GenericArraySerializerSnapshot.
GenericArraySerializerConfigSnapshot() - 类 的构造器org.apache.flink.api.common.typeutils.base.GenericArraySerializerConfigSnapshot
已过时。
Constructor for read instantiation.
GenericArraySerializerConfigSnapshot(GenericArraySerializer<C>) - 类 的构造器org.apache.flink.api.common.typeutils.base.GenericArraySerializerConfigSnapshot
已过时。
Constructor to create the snapshot for writing.
GenericArraySerializerSnapshot<C> - org.apache.flink.api.common.typeutils.base中的类
Point-in-time configuration of a GenericArraySerializer.
GenericArraySerializerSnapshot() - 类 的构造器org.apache.flink.api.common.typeutils.base.GenericArraySerializerSnapshot
Constructor to be used for read instantiation.
GenericArraySerializerSnapshot(GenericArraySerializer<C>) - 类 的构造器org.apache.flink.api.common.typeutils.base.GenericArraySerializerSnapshot
Constructor to be used for writing the snapshot.
GenericCsvInputFormat<OT> - org.apache.flink.api.common.io中的类
 
GenericCsvInputFormat() - 类 的构造器org.apache.flink.api.common.io.GenericCsvInputFormat
 
GenericCsvInputFormat(Path) - 类 的构造器org.apache.flink.api.common.io.GenericCsvInputFormat
 
GenericDataSinkBase<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) - 类 的构造器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) - 类 的构造器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,?>> - org.apache.flink.api.common.operators中的类
Abstract superclass for data sources in a Pact plan.
GenericDataSourceBase(T, OperatorInformation<OUT>, String) - 类 的构造器org.apache.flink.api.common.operators.GenericDataSourceBase
Creates a new instance for the given file using the given input format.
GenericDataSourceBase(T, OperatorInformation<OUT>) - 类 的构造器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) - 类 的构造器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>) - 类 的构造器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> - org.apache.flink.api.common.operators中的接口
 
GenericInputFormat<OT> - org.apache.flink.api.common.io中的类
Generic base class for all Rich inputs that are not based on files.
GenericInputFormat() - 类 的构造器org.apache.flink.api.common.io.GenericInputFormat
 
GenericInputSplit - org.apache.flink.core.io中的类
A generic input split that has only a partition number.
GenericInputSplit(int, int) - 类 的构造器org.apache.flink.core.io.GenericInputSplit
Creates a generic input split with the given split number.
genericKeyWithSuffix(String) - 类 中的静态方法org.apache.flink.configuration.ExternalResourceOptions
 
GenericPairComparator<T1,T2> - org.apache.flink.api.common.typeutils中的类
 
GenericPairComparator(TypeComparator<T1>, TypeComparator<T2>) - 类 的构造器org.apache.flink.api.common.typeutils.GenericPairComparator
 
GenericTypeComparator<T extends Comparable<T>> - org.apache.flink.api.java.typeutils.runtime中的类
TypeComparator for all types that extend Comparable.
GenericTypeComparator(boolean, TypeSerializer<T>, Class<T>) - 类 的构造器org.apache.flink.api.java.typeutils.runtime.GenericTypeComparator
 
GenericTypeInfo<T> - org.apache.flink.api.java.typeutils中的类
 
GenericTypeInfo(Class<T>) - 类 的构造器org.apache.flink.api.java.typeutils.GenericTypeInfo
 
GenericTypeSerializerConfigSnapshot<T> - org.apache.flink.api.common.typeutils中的类
Configuration snapshot for serializers for generic types.
GenericTypeSerializerConfigSnapshot() - 类 的构造器org.apache.flink.api.common.typeutils.GenericTypeSerializerConfigSnapshot
This empty nullary constructor is required for deserializing the configuration.
GenericTypeSerializerConfigSnapshot(Class<T>) - 类 的构造器org.apache.flink.api.common.typeutils.GenericTypeSerializerConfigSnapshot
 
GenericTypeSerializerSnapshot<T,S extends TypeSerializer> - org.apache.flink.api.common.typeutils中的类
Base TypeSerializerSnapshot for serializers for generic types.
GenericTypeSerializerSnapshot() - 类 的构造器org.apache.flink.api.common.typeutils.GenericTypeSerializerSnapshot
 
GenericTypeSerializerSnapshot(Class<T>) - 类 的构造器org.apache.flink.api.common.typeutils.GenericTypeSerializerSnapshot
 
get(int) - 类 中的方法org.apache.flink.api.common.operators.util.FieldList
 
get() - 接口 中的方法org.apache.flink.api.common.state.AppendingState
Returns the current value for the state.
get(UK) - 接口 中的方法org.apache.flink.api.common.state.MapState
Returns the current value associated with the given key.
get(K) - 接口 中的方法org.apache.flink.api.common.state.ReadOnlyBroadcastState
Returns the current value associated with the given key.
get(ConfigOption<T>) - 类 中的方法org.apache.flink.configuration.Configuration
 
get(ConfigOption<T>) - 类 中的方法org.apache.flink.configuration.DelegatingConfiguration
 
get(ConfigOption<T>) - 接口 中的方法org.apache.flink.configuration.ReadableConfig
Reads a value using the metadata included in ConfigOption.
get(URI) - 类 中的静态方法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) - 类 中的方法org.apache.flink.core.memory.MemorySegment
Reads the byte at the given position.
get(int, byte[]) - 类 中的方法org.apache.flink.core.memory.MemorySegment
Bulk get method.
get(int, byte[], int, int) - 类 中的方法org.apache.flink.core.memory.MemorySegment
Bulk get method.
get(DataOutput, int, int) - 类 中的方法org.apache.flink.core.memory.MemorySegment
 
get(int, ByteBuffer, int) - 类 中的方法org.apache.flink.core.memory.MemorySegment
Bulk get method.
get() - 类 中的方法org.apache.flink.types.BooleanValue
 
get(int) - 类 中的方法org.apache.flink.types.ListValue
 
get(Object) - 类 中的方法org.apache.flink.types.MapValue
 
get() - 类 中的方法org.apache.flink.types.SerializableOptional
 
get() - 类 中的方法org.apache.flink.util.concurrent.NeverCompleteFuture
 
get(long, TimeUnit) - 类 中的方法org.apache.flink.util.concurrent.NeverCompleteFuture
 
get() - 接口 中的方法org.apache.flink.util.function.SupplierWithException
Gets the result of this supplier.
get() - 类 中的方法org.apache.flink.util.OptionalFailure
 
get(Throwable, ClassLoader) - 异常错误 中的静态方法org.apache.flink.util.SerializedThrowable
 
getAccessTime() - 接口 中的方法org.apache.flink.core.fs.FileStatus
Get the access time of the file.
getAccessTime() - 类 中的方法org.apache.flink.core.fs.local.LocalFileStatus
 
getAccumulatedRecordCount() - 类 中的方法org.apache.flink.api.common.io.BlockInfo
Returns the accumulated record count.
getAccumulator(String) - 接口 中的方法org.apache.flink.api.common.functions.RuntimeContext
Get an existing accumulator object.
getAccumulator(String) - 类 中的方法org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
 
getAccumulatorResult(String) - 类 中的方法org.apache.flink.api.common.JobExecutionResult
Gets the accumulator with the given name.
getAccumulatorResult(String) - 类 中的方法org.apache.flink.core.execution.DetachedJobExecutionResult
 
getAccumulators() - 接口 中的方法org.apache.flink.core.execution.JobClient
Requests the accumulators of the associated job.
getActualBytes() - 类 中的方法org.apache.flink.api.common.typeutils.UnloadableDummyTypeSerializer
 
getAddress() - 类 中的方法org.apache.flink.core.memory.MemorySegment
Returns the memory address of off-heap memory segments.
getAddressSize() - 枚举 中的方法org.apache.flink.util.ProcessorArchitecture
Gets the address size of the memory (32 bit, 64 bit).
getAggregate() - 接口 中的方法org.apache.flink.api.common.aggregators.Aggregator
Gets the aggregator's current aggregate.
getAggregate() - 类 中的方法org.apache.flink.api.common.aggregators.DoubleSumAggregator
 
getAggregate() - 类 中的方法org.apache.flink.api.common.aggregators.LongSumAggregator
 
getAggregate() - 类 中的方法org.apache.flink.api.common.operators.base.BulkIterationBase.TerminationCriterionAggregator
 
getAggregateFunction() - 类 中的方法org.apache.flink.api.common.state.AggregatingStateDescriptor
Returns the aggregate function to be used for the state.
getAggregateFunctionAccumulatorType(AggregateFunction<IN, ACC, ?>, TypeInformation<IN>, String, boolean) - 类 中的静态方法org.apache.flink.api.java.typeutils.TypeExtractor
 
getAggregateFunctionReturnType(AggregateFunction<IN, ?, OUT>, TypeInformation<IN>, String, boolean) - 类 中的静态方法org.apache.flink.api.java.typeutils.TypeExtractor
 
getAggregatingState(AggregatingStateDescriptor<IN, ACC, OUT>) - 接口 中的方法org.apache.flink.api.common.functions.RuntimeContext
Gets a handle to the system's key/value aggregating state.
getAggregatingState(AggregatingStateDescriptor<IN, ACC, OUT>) - 类 中的方法org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
 
getAggregatingState(AggregatingStateDescriptor<IN, ACC, OUT>) - 接口 中的方法org.apache.flink.api.common.state.KeyedStateStore
Gets a handle to the system's key/value folding state.
getAggregator() - 类 中的方法org.apache.flink.api.common.aggregators.AggregatorWithName
Gets the aggregator.
getAggregators() - 类 中的方法org.apache.flink.api.common.operators.base.BulkIterationBase
 
getAggregators() - 类 中的方法org.apache.flink.api.common.operators.base.DeltaIterationBase
 
getAggregators() - 接口 中的方法org.apache.flink.api.common.operators.IterationOperator
 
getAllAccumulatorResults() - 类 中的方法org.apache.flink.api.common.JobExecutionResult
Gets all accumulators produced by the job.
getAllAccumulatorResults() - 类 中的方法org.apache.flink.core.execution.DetachedJobExecutionResult
 
getAllDeclaredFields(Class<?>, boolean) - 类 中的静态方法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.
getAllDeclaredMethods(Class<?>) - 类 中的静态方法org.apache.flink.api.java.typeutils.TypeExtractionUtils
Returns all declared methods of a class including methods of superclasses.
getAllocationIDAsString() - 类 中的方法org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
 
getAllocationIDAsString() - 类 中的方法org.apache.flink.api.common.TaskInfo
Returns the allocation id for where this task is executed.
getAllRegisteredAggregators() - 类 中的方法org.apache.flink.api.common.aggregators.AggregatorRegistry
 
getAllUnits() - 枚举 中的静态方法org.apache.flink.configuration.MemorySize.MemoryUnit
 
getAlternativeNames() - 枚举 中的方法org.apache.flink.util.ProcessorArchitecture
Gets the alternative names for the processor architecture.
getAlwaysParentFirstPatterns() - 类 中的方法org.apache.flink.core.plugin.PluginConfig
 
getAmountConfigOptionForResource(String) - 类 中的静态方法org.apache.flink.configuration.ExternalResourceOptions
Generate the config option key for the amount of external resource with resource_name.
getArchitectureName() - 枚举 中的方法org.apache.flink.util.ProcessorArchitecture
Gets the primary name of the processor architecture.
getArity() - 类 中的方法org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
 
getArity() - 类 中的方法org.apache.flink.api.common.typeinfo.BasicTypeInfo
 
getArity() - 类 中的方法org.apache.flink.api.common.typeinfo.LocalTimeTypeInfo
 
getArity() - 类 中的方法org.apache.flink.api.common.typeinfo.NothingTypeInfo
 
getArity() - 类 中的方法org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
 
getArity() - 类 中的方法org.apache.flink.api.common.typeinfo.SqlTimeTypeInfo
 
getArity() - 类 中的方法org.apache.flink.api.common.typeinfo.TypeInformation
Gets the arity of this type - the number of fields without nesting.
getArity() - 类 中的方法org.apache.flink.api.java.tuple.Tuple
Gets the number of field in the tuple (the tuple arity).
getArity() - 类 中的方法org.apache.flink.api.java.tuple.Tuple0
 
getArity() - 类 中的方法org.apache.flink.api.java.tuple.Tuple1
 
getArity() - 类 中的方法org.apache.flink.api.java.tuple.Tuple10
 
getArity() - 类 中的方法org.apache.flink.api.java.tuple.Tuple11
 
getArity() - 类 中的方法org.apache.flink.api.java.tuple.Tuple12
 
getArity() - 类 中的方法org.apache.flink.api.java.tuple.Tuple13
 
getArity() - 类 中的方法org.apache.flink.api.java.tuple.Tuple14
 
getArity() - 类 中的方法org.apache.flink.api.java.tuple.Tuple15
 
getArity() - 类 中的方法org.apache.flink.api.java.tuple.Tuple16
 
getArity() - 类 中的方法org.apache.flink.api.java.tuple.Tuple17
 
getArity() - 类 中的方法org.apache.flink.api.java.tuple.Tuple18
 
getArity() - 类 中的方法org.apache.flink.api.java.tuple.Tuple19
 
getArity() - 类 中的方法org.apache.flink.api.java.tuple.Tuple2
 
getArity() - 类 中的方法org.apache.flink.api.java.tuple.Tuple20
 
getArity() - 类 中的方法org.apache.flink.api.java.tuple.Tuple21
 
getArity() - 类 中的方法org.apache.flink.api.java.tuple.Tuple22
 
getArity() - 类 中的方法org.apache.flink.api.java.tuple.Tuple23
 
getArity() - 类 中的方法org.apache.flink.api.java.tuple.Tuple24
 
getArity() - 类 中的方法org.apache.flink.api.java.tuple.Tuple25
 
getArity() - 类 中的方法org.apache.flink.api.java.tuple.Tuple3
 
getArity() - 类 中的方法org.apache.flink.api.java.tuple.Tuple4
 
getArity() - 类 中的方法org.apache.flink.api.java.tuple.Tuple5
 
getArity() - 类 中的方法org.apache.flink.api.java.tuple.Tuple6
 
getArity() - 类 中的方法org.apache.flink.api.java.tuple.Tuple7
 
getArity() - 类 中的方法org.apache.flink.api.java.tuple.Tuple8
 
getArity() - 类 中的方法org.apache.flink.api.java.tuple.Tuple9
 
getArity() - 类 中的方法org.apache.flink.api.java.typeutils.EitherTypeInfo
 
getArity() - 类 中的方法org.apache.flink.api.java.typeutils.EnumTypeInfo
 
getArity() - 类 中的方法org.apache.flink.api.java.typeutils.GenericTypeInfo
 
getArity() - 类 中的方法org.apache.flink.api.java.typeutils.ListTypeInfo
 
getArity() - 类 中的方法org.apache.flink.api.java.typeutils.MapTypeInfo
 
getArity() - 类 中的方法org.apache.flink.api.java.typeutils.MissingTypeInfo
 
getArity() - 类 中的方法org.apache.flink.api.java.typeutils.ObjectArrayTypeInfo
 
getArity() - 类 中的方法org.apache.flink.api.java.typeutils.PojoTypeInfo
 
getArity() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.RowSerializer
 
getArity() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.TupleSerializerBase
 
getArity() - 类 中的方法org.apache.flink.api.java.typeutils.TupleTypeInfoBase
 
getArity() - 类 中的方法org.apache.flink.api.java.typeutils.ValueTypeInfo
 
getArity() - 类 中的方法org.apache.flink.types.Row
Returns the number of fields in the row.
getArray() - 类 中的方法org.apache.flink.core.memory.MemorySegment
Returns the byte array of on-heap memory segments.
getAsBoolean() - 枚举 中的方法org.apache.flink.util.TernaryBoolean
Gets this ternary boolean as a boxed boolean.
getAttemptNumber() - 接口 中的方法org.apache.flink.api.common.functions.RuntimeContext
Gets the attempt number of this parallel subtask.
getAttemptNumber() - 类 中的方法org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
 
getAttemptNumber() - 类 中的方法org.apache.flink.api.common.TaskInfo
Gets the attempt number of this parallel subtask.
getAutoWatermarkInterval() - 类 中的方法org.apache.flink.api.common.ExecutionConfig
Returns the interval of the automatic watermark emission.
getAvailablePort() - 类 中的静态方法org.apache.flink.util.NetUtils
Find a non-occupied port.
getAverageRecordWidth() - 类 中的方法org.apache.flink.api.common.io.FileInputFormat.FileBaseStatistics
Gets the estimated average number of bytes per record.
getAverageRecordWidth() - 接口 中的方法org.apache.flink.api.common.io.statistics.BaseStatistics
Gets the average width of a record, in bytes.
getAvgOutputRecordSize() - 类 中的方法org.apache.flink.api.common.operators.CompilerHints
 
getAvroUtils() - 类 中的静态方法org.apache.flink.api.java.typeutils.AvroUtils
Returns either the default AvroUtils which throw an exception in cases where Avro would be needed or loads the specific utils for Avro from flink-avro.
getBackoffMultiplier() - 类 中的方法org.apache.flink.api.common.restartstrategy.RestartStrategies.ExponentialDelayRestartStrategyConfiguration
 
getBasicAndBasicValueTupleTypeInfo(Class<?>...) - 类 中的静态方法org.apache.flink.api.java.typeutils.TupleTypeInfo
 
getBasicTupleTypeInfo(Class<?>...) - 类 中的静态方法org.apache.flink.api.java.typeutils.TupleTypeInfo
 
getBinaryLength() - 类 中的方法org.apache.flink.types.BooleanValue
 
getBinaryLength() - 类 中的方法org.apache.flink.types.ByteValue
 
getBinaryLength() - 类 中的方法org.apache.flink.types.CharValue
 
getBinaryLength() - 接口 中的方法org.apache.flink.types.CopyableValue
Gets the length of the data type when it is serialized, in bytes.
getBinaryLength() - 类 中的方法org.apache.flink.types.DoubleValue
 
getBinaryLength() - 类 中的方法org.apache.flink.types.FloatValue
 
getBinaryLength() - 类 中的方法org.apache.flink.types.IntValue
 
getBinaryLength() - 类 中的方法org.apache.flink.types.LongValue
 
getBinaryLength() - 类 中的方法org.apache.flink.types.NullValue
 
getBinaryLength() - 类 中的方法org.apache.flink.types.Record
 
getBinaryLength() - 类 中的方法org.apache.flink.types.ShortValue
 
getBinaryLength() - 类 中的方法org.apache.flink.types.StringValue
 
getBinaryOperatorReturnType(Function, Class<?>, int, int, int, int[], TypeInformation<IN1>, TypeInformation<IN2>, String, boolean) - 类 中的静态方法org.apache.flink.api.java.typeutils.TypeExtractor
Returns the binary operator's return type.
getBlockLocations() - 类 中的方法org.apache.flink.core.fs.local.LocalFileStatus
 
getBlockLocations() - 接口 中的方法org.apache.flink.core.fs.LocatedFileStatus
Gets the location information for the file.
getBlocks() - 类 中的方法org.apache.flink.configuration.description.Description
 
getBlockSize() - 类 中的方法org.apache.flink.api.common.io.BinaryInputFormat
 
getBlockSize() - 接口 中的方法org.apache.flink.core.fs.FileStatus
Get the block size of the file.
getBlockSize() - 类 中的方法org.apache.flink.core.fs.local.LocalFileStatus
 
getBoolean(String, boolean) - 类 中的方法org.apache.flink.configuration.Configuration
getBoolean(ConfigOption<Boolean>) - 类 中的方法org.apache.flink.configuration.Configuration
Returns the value associated with the given config option as a boolean.
getBoolean(ConfigOption<Boolean>, boolean) - 类 中的方法org.apache.flink.configuration.Configuration
Returns the value associated with the given config option as a boolean.
getBoolean(String, boolean) - 类 中的方法org.apache.flink.configuration.DelegatingConfiguration
 
getBoolean(ConfigOption<Boolean>) - 类 中的方法org.apache.flink.configuration.DelegatingConfiguration
 
getBoolean(ConfigOption<Boolean>, boolean) - 类 中的方法org.apache.flink.configuration.DelegatingConfiguration
 
getBoolean(int) - 类 中的方法org.apache.flink.core.memory.MemorySegment
Reads one byte at the given position and returns its boolean representation.
getBoolean(Properties, String, boolean) - 类 中的静态方法org.apache.flink.util.PropertiesUtil
Get boolean from properties.
getBoundedness() - 类 中的方法org.apache.flink.api.connector.source.lib.NumberSequenceSource
 
getBoundedness() - 接口 中的方法org.apache.flink.api.connector.source.Source
Get the boundedness of this source.
getBroadcastInputs() - 类 中的方法org.apache.flink.api.common.operators.AbstractUdfOperator
Returns the input, or null, if none is set.
getBroadcastInputs() - 类 中的方法org.apache.flink.api.common.operators.base.BulkIterationBase
The BulkIteration meta operator cannot have broadcast inputs.
getBroadcastInputs() - 类 中的方法org.apache.flink.api.common.operators.base.DeltaIterationBase
DeltaIteration meta operator cannot have broadcast inputs.
getBroadcastState(MapStateDescriptor<K, V>) - 接口 中的方法org.apache.flink.api.common.state.OperatorStateStore
Creates (or restores) a broadcast state.
getBroadcastVariable(String) - 接口 中的方法org.apache.flink.api.common.functions.RuntimeContext
Returns the result bound to the broadcast variable identified by the given name.
getBroadcastVariable(String) - 类 中的方法org.apache.flink.api.common.functions.util.RuntimeUDFContext
 
getBroadcastVariableWithInitializer(String, BroadcastVariableInitializer<T, C>) - 接口 中的方法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>) - 类 中的方法org.apache.flink.api.common.functions.util.RuntimeUDFContext
 
getBucketBoundary(int, int) - 接口 中的方法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.
getBuf() - 类 中的方法org.apache.flink.core.memory.ByteArrayOutputStreamWithPos
 
getBufferSize() - 类 中的方法org.apache.flink.api.common.io.DelimitedInputFormat
 
getBufferTimeout() - 类 中的方法org.apache.flink.api.dag.Transformation
Returns the buffer timeout of this Transformation.
getBuildComparator() - 类 中的方法org.apache.flink.api.common.operators.util.JoinHashMap
 
getBuildSerializer() - 类 中的方法org.apache.flink.api.common.operators.util.JoinHashMap
 
getByteArray() - 类 中的方法org.apache.flink.core.memory.DataOutputSerializer
已过时。
Replaced by DataOutputSerializer.getSharedBuffer() for a better, safer name.
getByteArray() - 类 中的方法org.apache.flink.util.SerializedValue
Returns byte array for serialized data.
getBytes(String, byte[]) - 类 中的方法org.apache.flink.configuration.Configuration
Returns the value associated with the given key as a byte array.
getBytes(String, byte[]) - 类 中的方法org.apache.flink.configuration.DelegatingConfiguration
 
getBytes() - 类 中的方法org.apache.flink.configuration.MemorySize
Gets the memory size in bytes.
getBytes() - 类 中的方法org.apache.flink.util.AbstractID
Gets the bytes underlying this ID.
getCachedFiles() - 类 中的方法org.apache.flink.api.common.Plan
Return the registered cached files.
getChar(int) - 类 中的方法org.apache.flink.core.memory.MemorySegment
Reads a char value from the given position, in the system's native byte order.
getCharArray() - 类 中的方法org.apache.flink.types.StringValue
Returns this StringValue's internal character data.
getCharBigEndian(int) - 类 中的方法org.apache.flink.core.memory.MemorySegment
Reads a character value (16 bit, 2 bytes) from the given position, in big-endian byte order.
getCharLittleEndian(int) - 类 中的方法org.apache.flink.core.memory.MemorySegment
Reads a character value (16 bit, 2 bytes) from the given position, in little-endian byte order.
getCharset() - 类 中的方法org.apache.flink.api.common.io.DelimitedInputFormat
Get the character set used for the row delimiter.
getCharset() - 类 中的方法org.apache.flink.api.common.serialization.SimpleStringSchema
Gets the charset used by this schema for serialization.
getCharset() - 类 中的方法org.apache.flink.types.parser.FieldParser
Gets the character set used for this parser.
getClass(String, Class<? extends T>, ClassLoader) - 类 中的方法org.apache.flink.configuration.Configuration
Returns the class associated with the given key as a string.
getClass(String, Class<? extends T>, ClassLoader) - 类 中的方法org.apache.flink.configuration.DelegatingConfiguration
 
getClassLoader() - 类 中的方法org.apache.flink.core.fs.ConnectionLimitingFactory
 
getClassLoader() - 类 中的方法org.apache.flink.core.fs.PluginFileSystemFactory
 
getClassLoader() - 接口 中的方法org.apache.flink.core.plugin.Plugin
Helper method to get the class loader used to load the plugin.
getClazz() - 类 中的方法org.apache.flink.util.ReflectionUtil.FullTypeInfo
 
getClazzIterator() - 类 中的方法org.apache.flink.util.ReflectionUtil.FullTypeInfo
 
getCleanupSize() - 类 中的方法org.apache.flink.api.common.state.StateTtlConfig.IncrementalCleanupStrategy
 
getCleanupStrategies() - 类 中的方法org.apache.flink.api.common.state.StateTtlConfig
 
getClosureCleanerLevel() - 类 中的方法org.apache.flink.api.common.ExecutionConfig
Returns the configured ExecutionConfig.ClosureCleanerLevel.
getCoGroupReturnTypes(CoGroupFunction<IN1, IN2, OUT>, TypeInformation<IN1>, TypeInformation<IN2>) - 类 中的静态方法org.apache.flink.api.java.typeutils.TypeExtractor
 
getCoGroupReturnTypes(CoGroupFunction<IN1, IN2, OUT>, TypeInformation<IN1>, TypeInformation<IN2>, String, boolean) - 类 中的静态方法org.apache.flink.api.java.typeutils.TypeExtractor
 
getCoLocationGroupKey() - 类 中的方法org.apache.flink.api.dag.Transformation
NOTE: This is an internal undocumented feature for now.
getCombinedWatermark() - 类 中的方法org.apache.flink.api.common.eventtime.IndexedCombinedWatermarkStatus
 
getCombineHint() - 类 中的方法org.apache.flink.api.common.operators.base.ReduceOperatorBase
 
getCommentPrefix() - 类 中的方法org.apache.flink.api.common.io.GenericCsvInputFormat
 
getCommitRecoverableSerializer() - 类 中的方法org.apache.flink.core.fs.local.LocalRecoverableWriter
 
getCommitRecoverableSerializer() - 接口 中的方法org.apache.flink.core.fs.RecoverableWriter
The serializer for the CommitRecoverable types created in this writer.
getCommittableSerializer() - 接口 中的方法org.apache.flink.api.connector.sink.Sink
Returns the serializer of the committable type.
getCommonFileExtensions() - 类 中的方法org.apache.flink.api.common.io.compression.Bzip2InputStreamFactory
 
getCommonFileExtensions() - 类 中的方法org.apache.flink.api.common.io.compression.DeflateInflaterInputStreamFactory
 
getCommonFileExtensions() - 类 中的方法org.apache.flink.api.common.io.compression.GzipInflaterInputStreamFactory
 
getCommonFileExtensions() - 接口 中的方法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.
getCommonFileExtensions() - 类 中的方法org.apache.flink.api.common.io.compression.XZInputStreamFactory
 
getCommonFileExtensions() - 类 中的方法org.apache.flink.api.common.io.compression.ZStandardInputStreamFactory
 
getCompatibleStateNames() - 接口 中的方法org.apache.flink.api.connector.sink.Sink
A list of state names of sinks from which the state can be restored.
getCompatibleVersions() - 类 中的方法org.apache.flink.api.common.typeutils.base.EnumSerializer.EnumSerializerConfigSnapshot
已过时。
 
getCompatibleVersions() - 类 中的方法org.apache.flink.core.io.VersionedIOReadableWritable
Returns the compatible version values.
getCompilerHints() - 类 中的方法org.apache.flink.api.common.operators.Operator
Gets the compiler hints for this contract instance.
getComponentClass() - 类 中的方法org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
Gets the class that represents the component type.
getComponentClass() - 类 中的方法org.apache.flink.api.common.typeutils.base.GenericArraySerializer
 
getComponentInfo() - 类 中的方法org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
 
getComponentInfo() - 类 中的方法org.apache.flink.api.java.typeutils.ObjectArrayTypeInfo
 
getComponentSerializer() - 类 中的方法org.apache.flink.api.common.typeutils.base.GenericArraySerializer
 
getComponentType() - 类 中的方法org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
Gets the type information of the component type.
getComponentTypeClass() - 类 中的方法org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
 
getConfiguration() - 接口 中的方法org.apache.flink.api.connector.source.SourceReaderContext
Gets the configuration with which Flink was started.
getContainingBulkIteration() - 类 中的方法org.apache.flink.api.common.operators.base.BulkIterationBase.PartialSolutionPlaceHolder
 
getContainingWorksetIteration() - 类 中的方法org.apache.flink.api.common.operators.base.DeltaIterationBase.SolutionSetPlaceHolder
 
getContainingWorksetIteration() - 类 中的方法org.apache.flink.api.common.operators.base.DeltaIterationBase.WorksetPlaceHolder
 
getConvergenceCriterion() - 类 中的方法org.apache.flink.api.common.aggregators.AggregatorRegistry
 
getConvergenceCriterionAggregatorName() - 类 中的方法org.apache.flink.api.common.aggregators.AggregatorRegistry
 
getCopyOfBuffer() - 类 中的方法org.apache.flink.core.memory.DataOutputSerializer
Gets a copy of the buffer that has the right length for the data serialized so far.
getCorrectHostnamePort(String) - 类 中的静态方法org.apache.flink.util.NetUtils
Converts a string of the form "host:port" into an URL.
getCpuCores() - 类 中的方法org.apache.flink.api.common.operators.ResourceSpec
 
getCpuCores() - 类 中的方法org.apache.flink.api.common.operators.SlotSharingGroup
 
getCrossHint() - 类 中的方法org.apache.flink.api.common.operators.base.CrossOperatorBase
 
getCrossReturnTypes(CrossFunction<IN1, IN2, OUT>, TypeInformation<IN1>, TypeInformation<IN2>) - 类 中的静态方法org.apache.flink.api.java.typeutils.TypeExtractor
 
getCrossReturnTypes(CrossFunction<IN1, IN2, OUT>, TypeInformation<IN1>, TypeInformation<IN2>, String, boolean) - 类 中的静态方法org.apache.flink.api.java.typeutils.TypeExtractor
 
getCurrent() - 类 中的方法org.apache.flink.api.common.operators.util.ListKeyGroupedIterator.ValuesIterator
 
getCurrent() - 类 中的方法org.apache.flink.util.LongValueSequenceIterator
 
getCurrent() - 类 中的方法org.apache.flink.util.NumberSequenceIterator
 
getCurrentOperatingSystem() - 枚举 中的静态方法org.apache.flink.util.OperatingSystem
Gets the operating system that the JVM runs on from the java system properties. this method returns UNKNOWN, if the operating system was not successfully determined.
getCurrentOuterSnapshotVersion() - 类 中的方法org.apache.flink.api.common.typeutils.base.GenericArraySerializerSnapshot
 
getCurrentOuterSnapshotVersion() - 类 中的方法org.apache.flink.api.common.typeutils.base.ListSerializerSnapshot
 
getCurrentOuterSnapshotVersion() - 类 中的方法org.apache.flink.api.common.typeutils.base.MapSerializerSnapshot
 
getCurrentOuterSnapshotVersion() - 类 中的方法org.apache.flink.api.common.typeutils.CompositeTypeSerializerSnapshot
Returns the version of the current outer snapshot's written binary format.
getCurrentOuterSnapshotVersion() - 类 中的方法org.apache.flink.api.common.typeutils.SingleThreadAccessCheckingTypeSerializer.SingleThreadAccessCheckingTypeSerializerSnapshot
 
getCurrentOuterSnapshotVersion() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.JavaEitherSerializerSnapshot
 
getCurrentOuterSnapshotVersion() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.NullableSerializer.NullableSerializerSnapshot
 
getCurrentOuterSnapshotVersion() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.RowSerializer.RowSerializerSnapshot
 
getCurrentOuterSnapshotVersion() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.TupleSerializerSnapshot
 
getCurrentProcessingTime() - 接口 中的方法org.apache.flink.api.connector.sink.Sink.ProcessingTimeService
Returns the current processing time.
getCurrentState() - 类 中的方法org.apache.flink.api.common.io.BinaryInputFormat
 
getCurrentState() - 接口 中的方法org.apache.flink.api.common.io.CheckpointableInputFormat
Returns the split currently being read, along with its current state.
getCurrentState() - 类 中的方法org.apache.flink.api.common.io.DelimitedInputFormat
 
getCurrentVersion() - 类 中的方法org.apache.flink.api.common.typeutils.BackwardsCompatibleSerializerSnapshot
 
getCurrentVersion() - 类 中的方法org.apache.flink.api.common.typeutils.base.EnumSerializer.EnumSerializerSnapshot
 
getCurrentVersion() - 类 中的方法org.apache.flink.api.common.typeutils.base.GenericArraySerializerConfigSnapshot
已过时。
 
getCurrentVersion() - 类 中的方法org.apache.flink.api.common.typeutils.CompositeTypeSerializerSnapshot
 
getCurrentVersion() - 类 中的方法org.apache.flink.api.common.typeutils.GenericTypeSerializerSnapshot
 
getCurrentVersion() - 类 中的方法org.apache.flink.api.common.typeutils.SimpleTypeSerializerSnapshot
 
getCurrentVersion() - 类 中的方法org.apache.flink.api.common.typeutils.TypeSerializerConfigSnapshot
已过时。
 
getCurrentVersion() - 接口 中的方法org.apache.flink.api.common.typeutils.TypeSerializerSnapshot
Returns the version of the current snapshot's written binary format.
getCurrentVersion() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.EitherSerializerSnapshot
已过时。
 
getCurrentVersion() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializerSnapshot
 
getCurrentVersion() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.PojoSerializerSnapshot
 
getCurrentWorkingDirectory() - 类 中的静态方法org.apache.flink.util.FileUtils
Returns the current working directory as specified by the user.dir system property.
getCustomPartitioner() - 类 中的方法org.apache.flink.api.common.operators.base.CoGroupOperatorBase
 
getCustomPartitioner() - 类 中的方法org.apache.flink.api.common.operators.base.GroupReduceOperatorBase
 
getCustomPartitioner() - 类 中的方法org.apache.flink.api.common.operators.base.JoinOperatorBase
 
getCustomPartitioner() - 类 中的方法org.apache.flink.api.common.operators.base.PartitionOperatorBase
 
getCustomPartitioner() - 类 中的方法org.apache.flink.api.common.operators.base.ReduceOperatorBase
 
getDataSinks() - 类 中的方法org.apache.flink.api.common.Plan
Gets all the data sinks of this job.
getDataType() - 接口 中的方法org.apache.flink.api.common.typeutils.TypeSerializerFactory
 
getDataType() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.RuntimeSerializerFactory
 
getDeclaredField(Class<?>, String) - 类 中的静态方法org.apache.flink.api.java.typeutils.TypeExtractor
 
getDefaultBlockSize() - 类 中的方法org.apache.flink.core.fs.FileSystem
已过时。
This value is no longer used and is meaningless.
getDefaultBlockSize() - 类 中的方法org.apache.flink.core.fs.LimitedConnectionsFileSystem
已过时。
getDefaultBlockSize() - 类 中的方法org.apache.flink.core.fs.SafetyNetWrapperFileSystem
 
getDefaultFsUri() - 类 中的静态方法org.apache.flink.core.fs.FileSystem
Gets the default file system URI that is used for paths and file systems that do not specify and explicit scheme.
getDefaultInputDependencyConstraint() - 类 中的方法org.apache.flink.api.common.ExecutionConfig
已过时。
due to the deprecation of InputDependencyConstraint.
getDefaultKryoSerializerClasses() - 类 中的方法org.apache.flink.api.common.ExecutionConfig
Returns the registered default Kryo Serializer classes.
getDefaultKryoSerializers() - 类 中的方法org.apache.flink.api.common.ExecutionConfig
Returns the registered default Kryo Serializers.
getDefaultParallelism() - 类 中的方法org.apache.flink.api.common.Plan
Gets the default parallelism for this job.
getDefaultValue() - 类 中的方法org.apache.flink.api.common.state.StateDescriptor
Returns the default value.
getDeferredOutput(String) - 类 中的方法org.apache.flink.api.common.eventtime.WatermarkOutputMultiplexer
Returns a deferred WatermarkOutput for the given output ID.
getDelay(TimeUnit) - 类 中的方法org.apache.flink.util.concurrent.NeverCompleteFuture
 
getDelayBetweenAttemptsInterval() - 类 中的方法org.apache.flink.api.common.restartstrategy.RestartStrategies.FailureRateRestartStrategyConfiguration
 
getDelayBetweenAttemptsInterval() - 类 中的方法org.apache.flink.api.common.restartstrategy.RestartStrategies.FixedDelayRestartStrategyConfiguration
 
getDelimiter() - 类 中的方法org.apache.flink.api.common.io.DelimitedInputFormat
 
getDescription() - 枚举 中的方法org.apache.flink.api.common.BatchShuffleMode
 
getDescription() - 枚举 中的方法org.apache.flink.api.common.ExecutionConfig.ClosureCleanerLevel
 
getDescription() - 接口 中的方法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() - 类 中的方法org.apache.flink.api.common.restartstrategy.RestartStrategies.ExponentialDelayRestartStrategyConfiguration
 
getDescription() - 类 中的方法org.apache.flink.api.common.restartstrategy.RestartStrategies.FailureRateRestartStrategyConfiguration
 
getDescription() - 类 中的方法org.apache.flink.api.common.restartstrategy.RestartStrategies.FallbackRestartStrategyConfiguration
 
getDescription() - 类 中的方法org.apache.flink.api.common.restartstrategy.RestartStrategies.FixedDelayRestartStrategyConfiguration
 
getDescription() - 类 中的方法org.apache.flink.api.common.restartstrategy.RestartStrategies.NoRestartStrategyConfiguration
 
getDescription() - 类 中的方法org.apache.flink.api.common.restartstrategy.RestartStrategies.RestartStrategyConfiguration
Returns a description which is shown in the web interface.
getDescription() - 枚举 中的方法org.apache.flink.configuration.ClusterOptions.UserSystemExitMode
 
getDescription() - 接口 中的方法org.apache.flink.configuration.DescribedEnum
Returns the description for the enum constant.
getDescriptionPrefix() - 类 中的方法org.apache.flink.api.common.operators.util.FieldList
 
getDescriptionPrefix() - 类 中的方法org.apache.flink.api.common.operators.util.FieldSet
 
getDescriptionSuffix() - 类 中的方法org.apache.flink.api.common.operators.util.FieldList
 
getDescriptionSuffix() - 类 中的方法org.apache.flink.api.common.operators.util.FieldSet
 
getDirectoryFileName(int) - 类 中的方法org.apache.flink.api.common.io.FileOutputFormat
 
getDistributedCache() - 接口 中的方法org.apache.flink.api.common.functions.RuntimeContext
Returns the DistributedCache to get the local temporary file copies of files otherwise not locally accessible.
getDistributedCache() - 类 中的方法org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
 
getDistribution() - 类 中的方法org.apache.flink.api.common.operators.base.PartitionOperatorBase
 
getDouble(String, double) - 类 中的方法org.apache.flink.configuration.Configuration
getDouble(ConfigOption<Double>) - 类 中的方法org.apache.flink.configuration.Configuration
Returns the value associated with the given config option as a double.
getDouble(ConfigOption<Double>, double) - 类 中的方法org.apache.flink.configuration.Configuration
Returns the value associated with the given config option as a double.
getDouble(String, double) - 类 中的方法org.apache.flink.configuration.DelegatingConfiguration
 
getDouble(ConfigOption<Double>) - 类 中的方法org.apache.flink.configuration.DelegatingConfiguration
 
getDouble(ConfigOption<Double>, double) - 类 中的方法org.apache.flink.configuration.DelegatingConfiguration
 
getDouble(int) - 类 中的方法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) - 类 中的方法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) - 接口 中的方法org.apache.flink.api.common.functions.RuntimeContext
Convenience function to create a counter object for doubles.
getDoubleCounter(String) - 类 中的方法org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
 
getDoubleLittleEndian(int) - 类 中的方法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.
getElements() - 类 中的方法org.apache.flink.configuration.description.TextElement
 
getElementSerializer() - 类 中的方法org.apache.flink.api.common.state.ListStateDescriptor
Gets the serializer for the elements contained in the list.
getElementSerializer() - 类 中的方法org.apache.flink.api.common.typeutils.base.ListSerializer
Gets the serializer for the elements of the list.
getElementTypeInfo() - 类 中的方法org.apache.flink.api.java.typeutils.ListTypeInfo
Gets the type information for the elements contained in the list
getElementTypeInfo() - 类 中的方法org.apache.flink.api.java.typeutils.MultisetTypeInfo
Gets the type information for the elements contained in the Multiset
getEntries() - 类 中的方法org.apache.flink.configuration.description.ListElement
 
getEntropyInjectionKey() - 接口 中的方法org.apache.flink.core.fs.EntropyInjectingFileSystem
Gets the marker string that represents the substring of a path to be replaced by the entropy characters.
getEnum(Class<T>, ConfigOption<String>) - 类 中的方法org.apache.flink.configuration.Configuration
Returns the value associated with the given config option as an enum.
getEnum(Class<T>, ConfigOption<String>) - 类 中的方法org.apache.flink.configuration.DelegatingConfiguration
 
getEnumeratorCheckpointSerializer() - 类 中的方法org.apache.flink.api.connector.source.lib.NumberSequenceSource
 
getEnumeratorCheckpointSerializer() - 接口 中的方法org.apache.flink.api.connector.source.Source
Creates the serializer for the SplitEnumerator checkpoint.
getErrorState() - 类 中的方法org.apache.flink.types.parser.FieldParser
Gets the error state of the parser, as a value of the enumeration FieldParser.ParseErrorState.
getExecutionConfig() - 接口 中的方法org.apache.flink.api.common.functions.RuntimeContext
Returns the ExecutionConfig for the currently executing job.
getExecutionConfig() - 类 中的方法org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
 
getExecutionConfig() - 类 中的方法org.apache.flink.api.common.Plan
Gets the execution config object.
getExecutionMode() - 类 中的方法org.apache.flink.api.common.ArchivedExecutionConfig
 
getExecutionMode() - 类 中的方法org.apache.flink.api.common.ExecutionConfig
Gets the execution mode used to execute the program.
getExecutionRetryDelay() - 类 中的方法org.apache.flink.api.common.ExecutionConfig
已过时。
Should no longer be used because it is subsumed by RestartStrategyConfiguration
getExecutor(Configuration) - 接口 中的方法org.apache.flink.core.execution.PipelineExecutorFactory
Instantiates an PipelineExecutor compatible with the provided configuration.
getExecutorFactory(Configuration) - 类 中的方法org.apache.flink.core.execution.DefaultExecutorServiceLoader
 
getExecutorFactory(Configuration) - 接口 中的方法org.apache.flink.core.execution.PipelineExecutorServiceLoader
Loads the PipelineExecutorFactory which is compatible with the provided configuration.
getExecutorNames() - 类 中的方法org.apache.flink.core.execution.DefaultExecutorServiceLoader
 
getExecutorNames() - 接口 中的方法org.apache.flink.core.execution.PipelineExecutorServiceLoader
Loads and returns a stream of the names of all available executors.
getExtendedResource(String) - 类 中的方法org.apache.flink.api.common.operators.ResourceSpec
 
getExtendedResources() - 类 中的方法org.apache.flink.api.common.operators.ResourceSpec
 
getExternalResourceDriverFactoryConfigOptionForResource(String) - 类 中的静态方法org.apache.flink.configuration.ExternalResourceOptions
Generate the config option key for the factory class name of ExternalResourceDriver.
getExternalResourceInfos(String) - 接口 中的方法org.apache.flink.api.common.functions.RuntimeContext
Get the specific external resource information by the resourceName.
getExternalResourceInfos(String) - 类 中的方法org.apache.flink.api.common.functions.util.RuntimeUDFContext
 
getExternalResourceParamConfigPrefixForResource(String) - 类 中的静态方法org.apache.flink.configuration.ExternalResourceOptions
Generate the suffix option key prefix for the user-defined params for external resources.
getExternalResources() - 类 中的方法org.apache.flink.api.common.operators.SlotSharingGroup
 
getFailureCause() - 类 中的方法org.apache.flink.util.OptionalFailure
 
getFailureInterval() - 类 中的方法org.apache.flink.api.common.restartstrategy.RestartStrategies.FailureRateRestartStrategyConfiguration
 
getField(T, int) - 类 中的方法org.apache.flink.api.common.typeutils.CompositeSerializer
Get field of existing instance.
getField(int) - 类 中的方法org.apache.flink.api.java.tuple.Tuple
Gets the field at the specified position.
getField(int) - 类 中的方法org.apache.flink.api.java.tuple.Tuple0
 
getField(int) - 类 中的方法org.apache.flink.api.java.tuple.Tuple1
 
getField(int) - 类 中的方法org.apache.flink.api.java.tuple.Tuple10
 
getField(int) - 类 中的方法org.apache.flink.api.java.tuple.Tuple11
 
getField(int) - 类 中的方法org.apache.flink.api.java.tuple.Tuple12
 
getField(int) - 类 中的方法org.apache.flink.api.java.tuple.Tuple13
 
getField(int) - 类 中的方法org.apache.flink.api.java.tuple.Tuple14
 
getField(int) - 类 中的方法org.apache.flink.api.java.tuple.Tuple15
 
getField(int) - 类 中的方法org.apache.flink.api.java.tuple.Tuple16
 
getField(int) - 类 中的方法org.apache.flink.api.java.tuple.Tuple17
 
getField(int) - 类 中的方法org.apache.flink.api.java.tuple.Tuple18
 
getField(int) - 类 中的方法org.apache.flink.api.java.tuple.Tuple19
 
getField(int) - 类 中的方法org.apache.flink.api.java.tuple.Tuple2
 
getField(int) - 类 中的方法org.apache.flink.api.java.tuple.Tuple20
 
getField(int) - 类 中的方法org.apache.flink.api.java.tuple.Tuple21
 
getField(int) - 类 中的方法org.apache.flink.api.java.tuple.Tuple22
 
getField(int) - 类 中的方法org.apache.flink.api.java.tuple.Tuple23
 
getField(int) - 类 中的方法org.apache.flink.api.java.tuple.Tuple24
 
getField(int) - 类 中的方法org.apache.flink.api.java.tuple.Tuple25
 
getField(int) - 类 中的方法org.apache.flink.api.java.tuple.Tuple3
 
getField(int) - 类 中的方法org.apache.flink.api.java.tuple.Tuple4
 
getField(int) - 类 中的方法org.apache.flink.api.java.tuple.Tuple5
 
getField(int) - 类 中的方法org.apache.flink.api.java.tuple.Tuple6
 
getField(int) - 类 中的方法org.apache.flink.api.java.tuple.Tuple7
 
getField(int) - 类 中的方法org.apache.flink.api.java.tuple.Tuple8
 
getField(int) - 类 中的方法org.apache.flink.api.java.tuple.Tuple9
 
getField() - 类 中的方法org.apache.flink.api.java.typeutils.PojoField
 
getField(int, Class<T>) - 类 中的方法org.apache.flink.types.Record
Gets the field at the given position from the record.
getField(int, T) - 类 中的方法org.apache.flink.types.Record
Gets the field at the given position.
getField(int) - 类 中的方法org.apache.flink.types.Row
Returns the field's content at the specified field position.
getField(String) - 类 中的方法org.apache.flink.types.Row
Returns the field's content using the specified field name.
getFieldAs(int) - 类 中的方法org.apache.flink.types.Row
Returns the field's content at the specified field position.
getFieldAs(String) - 类 中的方法org.apache.flink.types.Row
Returns the field's content using the specified field name.
getFieldDelimiter() - 类 中的方法org.apache.flink.api.common.io.GenericCsvInputFormat
 
getFieldIndex(String) - 类 中的方法org.apache.flink.api.common.typeutils.CompositeType
Returns the field index of the composite field of the given name.
getFieldIndex(String) - 类 中的方法org.apache.flink.api.java.typeutils.PojoTypeInfo
 
getFieldIndex(String) - 类 中的方法org.apache.flink.api.java.typeutils.RowTypeInfo
 
getFieldIndex(String) - 类 中的方法org.apache.flink.api.java.typeutils.TupleTypeInfo
 
getFieldInto(int, Value) - 类 中的方法org.apache.flink.types.Record
Gets the field at the given position.
getFieldName() - 类 中的方法org.apache.flink.api.java.typeutils.PojoTypeInfo.NamedFlatFieldDescriptor
 
getFieldNames() - 类 中的方法org.apache.flink.api.common.typeutils.CompositeType
Returns the names of the composite fields of this type.
getFieldNames() - 类 中的方法org.apache.flink.api.java.typeutils.PojoTypeInfo
 
getFieldNames() - 类 中的方法org.apache.flink.api.java.typeutils.RowTypeInfo
 
getFieldNames() - 类 中的方法org.apache.flink.api.java.typeutils.TupleTypeInfo
 
getFieldNames(boolean) - 类 中的方法org.apache.flink.types.Row
Returns the set of field names if this row operates in name-based field mode, otherwise null.
getFieldNotNull(int) - 类 中的方法org.apache.flink.api.java.tuple.Tuple
Gets the field at the specified position, throws NullFieldException if the field is null.
getFieldNumber(int) - 类 中的方法org.apache.flink.api.common.operators.Ordering
 
getFieldNumber() - 异常错误 中的方法org.apache.flink.types.KeyFieldOutOfBoundsException
Gets the field number that was attempted to access.
getFieldNumber() - 异常错误 中的方法org.apache.flink.types.NullKeyFieldException
Gets the field number that was attempted to access.
getFieldOrders() - 类 中的方法org.apache.flink.api.common.operators.Ordering
 
getFieldParsers() - 类 中的方法org.apache.flink.api.common.io.GenericCsvInputFormat
 
getFieldPos() - 异常错误 中的方法org.apache.flink.types.NullFieldException
Gets the field number that was attempted to access.
getFieldPositions() - 类 中的方法org.apache.flink.api.common.operators.Ordering
 
getFieldSerializers() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.TupleSerializerBase
 
getFieldsInto(int[], Value[]) - 类 中的方法org.apache.flink.types.Record
Gets the fields at the given positions into an array.
getFieldsIntoCheckingNull(int[], Value[]) - 类 中的方法org.apache.flink.types.Record
Gets the fields at the given positions into an array.
getFieldSortDirections() - 类 中的方法org.apache.flink.api.common.operators.Ordering
 
getFieldToSerializerConfigSnapshot() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.PojoSerializer.PojoSerializerConfigSnapshot
已过时。
 
getFieldTypes() - 类 中的方法org.apache.flink.api.java.typeutils.TupleTypeInfoBase
Returns the field types.
getFile(String) - 类 中的方法org.apache.flink.api.common.cache.DistributedCache
 
getFile() - 类 中的方法org.apache.flink.core.fs.local.LocalFileStatus
 
getFile() - 类 中的方法org.apache.flink.core.fs.RefCountedFile
 
getFileBlockLocations(FileStatus, long, long) - 类 中的方法org.apache.flink.core.fs.FileSystem
Return an array containing hostnames, offset and size of portions of the given file.
getFileBlockLocations(FileStatus, long, long) - 类 中的方法org.apache.flink.core.fs.LimitedConnectionsFileSystem
 
getFileBlockLocations(FileStatus, long, long) - 类 中的方法org.apache.flink.core.fs.local.LocalFileSystem
 
getFileBlockLocations(FileStatus, long, long) - 类 中的方法org.apache.flink.core.fs.SafetyNetWrapperFileSystem
 
getFilePath() - 类 中的方法org.apache.flink.api.common.io.FileInputFormat
已过时。
Please use getFilePaths() instead.
getFilePaths() - 类 中的方法org.apache.flink.api.common.io.FileInputFormat
Returns the paths of all files to be read by the FileInputFormat.
getFiles() - 类 中的方法org.apache.flink.api.common.io.BinaryInputFormat
 
getFileStats(FileInputFormat.FileBaseStatistics, Path[], ArrayList<FileStatus>) - 类 中的方法org.apache.flink.api.common.io.FileInputFormat
 
getFileStats(FileInputFormat.FileBaseStatistics, Path, FileSystem, ArrayList<FileStatus>) - 类 中的方法org.apache.flink.api.common.io.FileInputFormat
 
getFileStatus(Path) - 类 中的方法org.apache.flink.core.fs.FileSystem
Return a file status object that represents the path.
getFileStatus(Path) - 类 中的方法org.apache.flink.core.fs.LimitedConnectionsFileSystem
 
getFileStatus(Path) - 类 中的方法org.apache.flink.core.fs.local.LocalFileSystem
 
getFileStatus(Path) - 类 中的方法org.apache.flink.core.fs.SafetyNetWrapperFileSystem
 
getFileSystem() - 类 中的方法org.apache.flink.core.fs.Path
Returns the FileSystem that owns this Path.
getFilterFactor() - 类 中的方法org.apache.flink.api.common.operators.CompilerHints
 
getFinalResult() - 类 中的方法org.apache.flink.api.common.typeutils.CompositeTypeSerializerUtil.IntermediateCompatibilityResult
 
getFirstInput() - 类 中的方法org.apache.flink.api.common.operators.DualInputOperator
Returns the first input, or null, if none is set.
getFirstInputType() - 类 中的方法org.apache.flink.api.common.operators.BinaryOperatorInformation
 
getFirstRecordStart() - 类 中的方法org.apache.flink.api.common.io.BlockInfo
Returns the firstRecordStart.
getFlatComparator(List<TypeComparator>) - 类 中的方法org.apache.flink.api.common.typeutils.CompositeTypeComparator
 
getFlatComparator(List<TypeComparator>) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.PojoComparator
 
getFlatComparator(List<TypeComparator>) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.RowComparator
 
getFlatComparator(List<TypeComparator>) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
 
getFlatComparators() - 类 中的方法org.apache.flink.api.common.typeutils.base.array.PrimitiveArrayComparator
 
getFlatComparators() - 类 中的方法org.apache.flink.api.common.typeutils.base.BasicTypeComparator
 
getFlatComparators() - 类 中的方法org.apache.flink.api.common.typeutils.base.BooleanValueComparator
 
getFlatComparators() - 类 中的方法org.apache.flink.api.common.typeutils.base.ByteValueComparator
 
getFlatComparators() - 类 中的方法org.apache.flink.api.common.typeutils.base.CharValueComparator
 
getFlatComparators() - 类 中的方法org.apache.flink.api.common.typeutils.base.DoubleValueComparator
 
getFlatComparators() - 类 中的方法org.apache.flink.api.common.typeutils.base.FloatValueComparator
 
getFlatComparators() - 类 中的方法org.apache.flink.api.common.typeutils.base.IntValueComparator
 
getFlatComparators() - 类 中的方法org.apache.flink.api.common.typeutils.base.LocalDateComparator
 
getFlatComparators() - 类 中的方法org.apache.flink.api.common.typeutils.base.LocalDateTimeComparator
 
getFlatComparators() - 类 中的方法org.apache.flink.api.common.typeutils.base.LongValueComparator
 
getFlatComparators() - 类 中的方法org.apache.flink.api.common.typeutils.base.NullValueComparator
 
getFlatComparators() - 类 中的方法org.apache.flink.api.common.typeutils.base.ShortValueComparator
 
getFlatComparators() - 类 中的方法org.apache.flink.api.common.typeutils.base.StringValueComparator
 
getFlatComparators() - 类 中的方法org.apache.flink.api.common.typeutils.CompositeTypeComparator
 
getFlatComparators() - 类 中的方法org.apache.flink.api.common.typeutils.TypeComparator
Get the field comparators.
getFlatComparators() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.CopyableValueComparator
 
getFlatComparators() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.GenericTypeComparator
 
getFlatComparators() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.NullAwareComparator
 
getFlatComparators() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.ValueComparator
 
getFlatFields(String) - 类 中的方法org.apache.flink.api.common.typeutils.CompositeType
Returns the flat field descriptors for the given field expression.
getFlatFields(String, int, List<CompositeType.FlatFieldDescriptor>) - 类 中的方法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>) - 类 中的方法org.apache.flink.api.java.typeutils.PojoTypeInfo
 
getFlatFields(String, int, List<CompositeType.FlatFieldDescriptor>) - 类 中的方法org.apache.flink.api.java.typeutils.RowTypeInfo
 
getFlatFields(String, int, List<CompositeType.FlatFieldDescriptor>) - 类 中的方法org.apache.flink.api.java.typeutils.TupleTypeInfoBase
 
getFlatJoinReturnTypes(FlatJoinFunction<IN1, IN2, OUT>, TypeInformation<IN1>, TypeInformation<IN2>) - 类 中的静态方法org.apache.flink.api.java.typeutils.TypeExtractor
 
getFlatJoinReturnTypes(FlatJoinFunction<IN1, IN2, OUT>, TypeInformation<IN1>, TypeInformation<IN2>, String, boolean) - 类 中的静态方法org.apache.flink.api.java.typeutils.TypeExtractor
 
getFlatMapReturnTypes(FlatMapFunction<IN, OUT>, TypeInformation<IN>) - 类 中的静态方法org.apache.flink.api.java.typeutils.TypeExtractor
 
getFlatMapReturnTypes(FlatMapFunction<IN, OUT>, TypeInformation<IN>, String, boolean) - 类 中的静态方法org.apache.flink.api.java.typeutils.TypeExtractor
 
getFloat(String, float) - 类 中的方法org.apache.flink.configuration.Configuration
getFloat(ConfigOption<Float>) - 类 中的方法org.apache.flink.configuration.Configuration
Returns the value associated with the given config option as a float.
getFloat(ConfigOption<Float>, float) - 类 中的方法org.apache.flink.configuration.Configuration
Returns the value associated with the given config option as a float.
getFloat(String, float) - 类 中的方法org.apache.flink.configuration.DelegatingConfiguration
 
getFloat(ConfigOption<Float>) - 类 中的方法org.apache.flink.configuration.DelegatingConfiguration
 
getFloat(ConfigOption<Float>, float) - 类 中的方法org.apache.flink.configuration.DelegatingConfiguration
 
getFloat(int) - 类 中的方法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) - 类 中的方法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) - 类 中的方法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.
getForClass(Class<X>) - 类 中的静态方法org.apache.flink.api.java.typeutils.TypeExtractor
Creates type information from a given Class such as Integer, String[] or POJOs.
getFormat() - 类 中的方法org.apache.flink.configuration.description.TextElement
 
getFormattedTimestamp() - 类 中的方法org.apache.flink.api.common.eventtime.Watermark
Formats the timestamp of this watermark, assuming it is a millisecond timestamp.
getFormatWrapper() - 类 中的方法org.apache.flink.api.common.operators.GenericDataSinkBase
Gets the class describing this sinks output format.
getFormatWrapper() - 类 中的方法org.apache.flink.api.common.operators.GenericDataSourceBase
Gets the class describing the input format.
getForObject(X) - 类 中的静态方法org.apache.flink.api.java.typeutils.TypeExtractor
 
getForwardingSourceField(int, int) - 类 中的方法org.apache.flink.api.common.operators.DualInputSemanticProperties
 
getForwardingSourceField(int, int) - 类 中的方法org.apache.flink.api.common.operators.SemanticProperties.EmptySemanticProperties
 
getForwardingSourceField(int, int) - 接口 中的方法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) - 类 中的方法org.apache.flink.api.common.operators.SingleInputSemanticProperties.AllFieldsForwardedProperties
 
getForwardingSourceField(int, int) - 类 中的方法org.apache.flink.api.common.operators.SingleInputSemanticProperties
 
getForwardingTargetFields(int, int) - 类 中的方法org.apache.flink.api.common.operators.DualInputSemanticProperties
 
getForwardingTargetFields(int, int) - 类 中的方法org.apache.flink.api.common.operators.SemanticProperties.EmptySemanticProperties
 
getForwardingTargetFields(int, int) - 接口 中的方法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) - 类 中的方法org.apache.flink.api.common.operators.SingleInputSemanticProperties.AllFieldsForwardedProperties
 
getForwardingTargetFields(int, int) - 类 中的方法org.apache.flink.api.common.operators.SingleInputSemanticProperties
 
getFrom() - 类 中的方法org.apache.flink.api.connector.source.lib.NumberSequenceSource
 
getFullStringifiedStackTrace() - 异常错误 中的方法org.apache.flink.util.SerializedThrowable
 
getFullTemplateType(Type, int) - 类 中的静态方法org.apache.flink.util.ReflectionUtil
Extract the full template type information from the given type's template parameter at the given position.
getFullTemplateType(Type) - 类 中的静态方法org.apache.flink.util.ReflectionUtil
Extract the full type information from the given type.
getFunctionName() - 类 中的方法org.apache.flink.api.java.typeutils.MissingTypeInfo
 
getFunctionRuntimeContext(Function, RuntimeContext) - 类 中的静态方法org.apache.flink.api.common.functions.util.FunctionUtils
 
getGenericFieldTypes() - 类 中的方法org.apache.flink.api.common.io.GenericCsvInputFormat
 
getGenericParameters() - 类 中的方法org.apache.flink.api.common.typeinfo.TypeInformation
Optional method for giving Flink's type extraction system information about the mapping of a generic type parameter to the type information of a subtype.
getGenericParameters() - 类 中的方法org.apache.flink.api.java.typeutils.EitherTypeInfo
 
getGenericParameters() - 类 中的方法org.apache.flink.api.java.typeutils.TupleTypeInfo
 
getGibiBytes() - 类 中的方法org.apache.flink.configuration.MemorySize
Gets the memory size in Gibibytes (= 1024 Mebibytes).
getGlobalCommittableSerializer() - 接口 中的方法org.apache.flink.api.connector.sink.Sink
Returns the serializer of the aggregated committable type.
getGlobalJobParameters() - 类 中的方法org.apache.flink.api.common.ArchivedExecutionConfig
 
getGlobalJobParameters() - 类 中的方法org.apache.flink.api.common.ExecutionConfig
 
getGroupCombineReturnTypes(GroupCombineFunction<IN, OUT>, TypeInformation<IN>) - 类 中的静态方法org.apache.flink.api.java.typeutils.TypeExtractor
 
getGroupCombineReturnTypes(GroupCombineFunction<IN, OUT>, TypeInformation<IN>, String, boolean) - 类 中的静态方法org.apache.flink.api.java.typeutils.TypeExtractor
 
getGroupOrder(int) - 类 中的方法org.apache.flink.api.common.operators.base.CoGroupOperatorBase
Gets the value order for an input, i.e. the order of elements within a group.
getGroupOrder(int) - 类 中的方法org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase
Gets the value order for an input, i.e. the order of elements within a group.
getGroupOrder() - 类 中的方法org.apache.flink.api.common.operators.base.GroupCombineOperatorBase
Gets the order of elements within a reduce group.
getGroupOrder() - 类 中的方法org.apache.flink.api.common.operators.base.GroupReduceOperatorBase
Gets the order of elements within a reduce group.
getGroupOrderForInputOne() - 类 中的方法org.apache.flink.api.common.operators.base.CoGroupOperatorBase
Gets the order of elements within a group for the first input.
getGroupOrderForInputOne() - 类 中的方法org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase
Gets the order of elements within a group for the first input.
getGroupOrderForInputTwo() - 类 中的方法org.apache.flink.api.common.operators.base.CoGroupOperatorBase
Gets the order of elements within a group for the second input.
getGroupOrderForInputTwo() - 类 中的方法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>) - 类 中的静态方法org.apache.flink.api.java.typeutils.TypeExtractor
 
getGroupReduceReturnTypes(GroupReduceFunction<IN, OUT>, TypeInformation<IN>, String, boolean) - 类 中的静态方法org.apache.flink.api.java.typeutils.TypeExtractor
 
getHeapMemory() - 类 中的方法org.apache.flink.core.memory.MemorySegment
Get the heap byte array object.
getHistogram(String) - 接口 中的方法org.apache.flink.api.common.functions.RuntimeContext
Convenience function to create a counter object for histograms.
getHistogram(String) - 类 中的方法org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
 
getHomeDirectory() - 类 中的方法org.apache.flink.core.fs.FileSystem
Returns the path of the user's home directory in this file system.
getHomeDirectory() - 类 中的方法org.apache.flink.core.fs.LimitedConnectionsFileSystem
 
getHomeDirectory() - 类 中的方法org.apache.flink.core.fs.local.LocalFileSystem
 
getHomeDirectory() - 类 中的方法org.apache.flink.core.fs.SafetyNetWrapperFileSystem
 
getHostnameFromFQDN(String) - 类 中的静态方法org.apache.flink.util.NetUtils
Turn a fully qualified domain name (fqdn) into a hostname.
getHostnames() - 类 中的方法org.apache.flink.core.io.LocatableInputSplit
Returns the names of the hosts storing the data this input split refers to
getHosts() - 接口 中的方法org.apache.flink.core.fs.BlockLocation
Get the list of hosts (hostname) hosting this block.
getHosts() - 类 中的方法org.apache.flink.core.fs.local.LocalBlockLocation
 
getId() - 类 中的方法org.apache.flink.api.dag.Transformation
Returns the unique ID of this Transformation.
getId() - 类 中的方法org.apache.flink.util.OutputTag
 
getImmediateOutput(String) - 类 中的方法org.apache.flink.api.common.eventtime.WatermarkOutputMultiplexer
Returns an immediate WatermarkOutput for the given output ID.
getIncrementalCleanupStrategy() - 类 中的方法org.apache.flink.api.common.state.StateTtlConfig.CleanupStrategies
 
getIndexOfSubtask() - 接口 中的方法org.apache.flink.api.connector.source.SourceReaderContext
 
getIndexOfThisSubtask() - 接口 中的方法org.apache.flink.api.common.functions.RuntimeContext
Gets the number of this parallel subtask.
getIndexOfThisSubtask() - 类 中的方法org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
 
getIndexOfThisSubtask() - 类 中的方法org.apache.flink.api.common.TaskInfo
Gets the number of this parallel subtask.
getInflaterInputStreamFactory(String) - 类 中的静态方法org.apache.flink.api.common.io.FileInputFormat
 
getInfoFor(Class<X>) - 类 中的静态方法org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
 
getInfoFor(Class<X>) - 类 中的静态方法org.apache.flink.api.common.typeinfo.BasicTypeInfo
 
getInfoFor(Class) - 类 中的静态方法org.apache.flink.api.common.typeinfo.LocalTimeTypeInfo
 
getInfoFor(Class<X>) - 类 中的静态方法org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
Tries to get the PrimitiveArrayTypeInfo for an array.
getInfoFor(Class<X>) - 类 中的静态方法org.apache.flink.api.common.typeinfo.SqlTimeTypeInfo
 
getInfoFor(TypeInformation<C>) - 类 中的静态方法org.apache.flink.api.java.typeutils.MultisetTypeInfo
 
getInfoFor(Class<T>, TypeInformation<C>) - 类 中的静态方法org.apache.flink.api.java.typeutils.ObjectArrayTypeInfo
 
getInfoFor(TypeInformation<C>) - 类 中的静态方法org.apache.flink.api.java.typeutils.ObjectArrayTypeInfo
Creates a new ObjectArrayTypeInfo from a TypeInformation for the component type.
getInfoSize() - 类 中的方法org.apache.flink.api.common.io.BlockInfo
 
getInitialBackoff() - 类 中的方法org.apache.flink.api.common.restartstrategy.RestartStrategies.ExponentialDelayRestartStrategyConfiguration
 
getInitialSolutionSet() - 类 中的方法org.apache.flink.api.common.operators.base.DeltaIterationBase
Returns the initial solution set input, or null, if none is set.
getInitialWorkset() - 类 中的方法org.apache.flink.api.common.operators.base.DeltaIterationBase
Returns the initial workset input, or null, if none is set.
getInput() - 类 中的方法org.apache.flink.api.common.operators.GenericDataSinkBase
Returns this operator's input operator.
getInput() - 类 中的方法org.apache.flink.api.common.operators.SingleInputOperator
Returns the input operator or data source, or null, if none is set.
getInputFormatTypes(InputFormat<IN, ?>) - 类 中的静态方法org.apache.flink.api.java.typeutils.TypeExtractor
 
getInputs() - 类 中的方法org.apache.flink.api.dag.Transformation
Returns the transformations that are the immediate predecessors of the current transformation in the transformation graph.
getInputSplitAssigner(FileInputSplit[]) - 类 中的方法org.apache.flink.api.common.io.FileInputFormat
 
getInputSplitAssigner(GenericInputSplit[]) - 类 中的方法org.apache.flink.api.common.io.GenericInputFormat
 
getInputSplitAssigner(T[]) - 接口 中的方法org.apache.flink.api.common.io.InputFormat
 
getInputSplitAssigner(S[]) - 类 中的方法org.apache.flink.api.common.io.ReplicatingInputFormat
 
getInputSplitAssigner(T[]) - 接口 中的方法org.apache.flink.core.io.InputSplitSource
Returns the assigner for the input splits.
getInputSplits() - 类 中的方法org.apache.flink.api.common.io.BinaryInputFormat
 
getInputType() - 类 中的方法org.apache.flink.api.common.operators.Keys.SelectorFunctionKeys
 
getInputType() - 类 中的方法org.apache.flink.api.common.operators.UnaryOperatorInformation
 
getInputView() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.DataInputViewStream
 
getInstance() - 类 中的静态方法org.apache.flink.api.common.io.compression.Bzip2InputStreamFactory
 
getInstance() - 类 中的静态方法org.apache.flink.api.common.io.compression.DeflateInflaterInputStreamFactory
 
getInstance() - 类 中的静态方法org.apache.flink.api.common.io.compression.GzipInflaterInputStreamFactory
 
getInstance() - 类 中的静态方法org.apache.flink.api.common.io.compression.XZInputStreamFactory
 
getInstance() - 类 中的静态方法org.apache.flink.api.common.io.compression.ZStandardInputStreamFactory
 
getInstance() - 类 中的静态方法org.apache.flink.api.common.typeutils.base.NullValueComparator
 
getInstance() - 类 中的静态方法org.apache.flink.management.jmx.JMXService
Acquire the global singleton JMXServer instance.
getInstance() - 类 中的静态方法org.apache.flink.types.NullValue
Returns the NullValue singleton instance.
getInstance() - 类 中的静态方法org.apache.flink.util.clock.SystemClock
 
getInt(int) - 类 中的方法org.apache.flink.core.memory.MemorySegment
Reads an int value (32bit, 4 bytes) from the given position, in the system's native byte order.
getInt(Properties, String, int) - 类 中的静态方法org.apache.flink.util.PropertiesUtil
Get integer from properties.
getIntBigEndian(int) - 类 中的方法org.apache.flink.core.memory.MemorySegment
Reads an int value (32bit, 4 bytes) from the given position, in big-endian byte order.
getIntCounter(String) - 接口 中的方法org.apache.flink.api.common.functions.RuntimeContext
Convenience function to create a counter object for integers.
getIntCounter(String) - 类 中的方法org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
 
getIntCounterResult(String) - 类 中的方法org.apache.flink.api.common.JobExecutionResult
已过时。
Will be removed in future versions. Use JobExecutionResult.getAccumulatorResult(java.lang.String) instead.
getIntCounterResult(String) - 类 中的方法org.apache.flink.core.execution.DetachedJobExecutionResult
 
getInteger(String, int) - 类 中的方法org.apache.flink.configuration.Configuration
getInteger(ConfigOption<Integer>) - 类 中的方法org.apache.flink.configuration.Configuration
Returns the value associated with the given config option as an integer.
getInteger(ConfigOption<Integer>, int) - 类 中的方法org.apache.flink.configuration.Configuration
Returns the value associated with the given config option as an integer.
getInteger(String, int) - 类 中的方法org.apache.flink.configuration.DelegatingConfiguration
 
getInteger(ConfigOption<Integer>) - 类 中的方法org.apache.flink.configuration.DelegatingConfiguration
 
getInteger(ConfigOption<Integer>, int) - 类 中的方法org.apache.flink.configuration.DelegatingConfiguration
 
getIntLittleEndian(int) - 类 中的方法org.apache.flink.core.memory.MemorySegment
Reads an int value (32bit, 4 bytes) from the given position, in little-endian byte order.
getInvolvedIndexes() - 类 中的方法org.apache.flink.api.common.operators.Ordering
 
getIterationAggregator(String) - 接口 中的方法org.apache.flink.api.common.functions.IterationRuntimeContext
 
getIterationRuntimeContext() - 类 中的方法org.apache.flink.api.common.functions.AbstractRichFunction
 
getIterationRuntimeContext() - 接口 中的方法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.
getIterator() - 类 中的方法org.apache.flink.api.connector.source.lib.NumberSequenceSource.NumberSequenceSplit
 
getIterator() - 接口 中的方法org.apache.flink.api.connector.source.lib.util.IteratorSourceSplit
Gets the iterator over the elements of this split.
getJarFiles(String[]) - 类 中的静态方法org.apache.flink.util.JarUtils
 
getJitterFactor() - 类 中的方法org.apache.flink.api.common.restartstrategy.RestartStrategies.ExponentialDelayRestartStrategyConfiguration
 
getJobExecutionResult() - 类 中的方法org.apache.flink.api.common.JobExecutionResult
 
getJobExecutionResult() - 类 中的方法org.apache.flink.api.common.JobSubmissionResult
Returns the JobExecutionResult if available.
getJobExecutionResult() - 类 中的方法org.apache.flink.core.execution.DetachedJobExecutionResult
 
getJobExecutionResult() - 接口 中的方法org.apache.flink.core.execution.JobClient
Returns the result of the job execution of the submitted job.
getJobId() - 接口 中的方法org.apache.flink.api.common.functions.RuntimeContext
The ID of the current job.
getJobId() - 类 中的方法org.apache.flink.api.common.functions.util.RuntimeUDFContext
 
getJobID() - 类 中的方法org.apache.flink.api.common.JobSubmissionResult
Returns the JobID assigned to the job by the Flink runtime.
getJobId() - 类 中的方法org.apache.flink.api.common.Plan
Gets the ID of the job that the dataflow plan belongs to.
getJobID() - 类 中的方法org.apache.flink.core.execution.DetachedJobExecutionResult
 
getJobID() - 接口 中的方法org.apache.flink.core.execution.JobClient
Returns the JobID that uniquely identifies the job this client is scoped to.
getJobName() - 类 中的方法org.apache.flink.api.common.Plan
Gets the name of this job.
getJobStatus() - 接口 中的方法org.apache.flink.core.execution.JobClient
Requests the JobStatus of the associated job.
getJoinHint() - 类 中的方法org.apache.flink.api.common.operators.base.JoinOperatorBase
 
getJoinReturnTypes(JoinFunction<IN1, IN2, OUT>, TypeInformation<IN1>, TypeInformation<IN2>) - 类 中的静态方法org.apache.flink.api.java.typeutils.TypeExtractor
 
getJoinReturnTypes(JoinFunction<IN1, IN2, OUT>, TypeInformation<IN1>, TypeInformation<IN2>, String, boolean) - 类 中的静态方法org.apache.flink.api.java.typeutils.TypeExtractor
 
getKey(IN) - 接口 中的方法org.apache.flink.api.java.functions.KeySelector
User-defined function that deterministically extracts the key from an object.
getKey(T) - 类 中的方法org.apache.flink.api.java.functions.NullByteKeySelector
 
getKey() - 类 中的方法org.apache.flink.configuration.FallbackKey
 
getKey() - 类 中的方法org.apache.flink.util.LinkedOptionalMap.KeyValue
 
getKeyColumns(int) - 类 中的方法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) - 类 中的方法org.apache.flink.api.common.operators.DualInputOperator
 
getKeyColumns(int) - 类 中的方法org.apache.flink.api.common.operators.SingleInputOperator
 
getKeyExtractor() - 类 中的方法org.apache.flink.api.common.operators.Keys.SelectorFunctionKeys
 
getKeyFields() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.PojoComparator
 
getKeyFieldTypes() - 类 中的方法org.apache.flink.api.common.operators.Keys.ExpressionKeys
 
getKeyFieldTypes() - 类 中的方法org.apache.flink.api.common.operators.Keys
 
getKeyFieldTypes() - 类 中的方法org.apache.flink.api.common.operators.Keys.SelectorFunctionKeys
 
getKeyPositions() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
 
getKeys() - 接口 中的方法org.apache.flink.api.common.externalresource.ExternalResourceInfo
Get all property keys.
getKeySelectorTypes(KeySelector<IN, OUT>, TypeInformation<IN>) - 类 中的静态方法org.apache.flink.api.java.typeutils.TypeExtractor
 
getKeySelectorTypes(KeySelector<IN, OUT>, TypeInformation<IN>, String, boolean) - 类 中的静态方法org.apache.flink.api.java.typeutils.TypeExtractor
 
getKeySerializer() - 类 中的方法org.apache.flink.api.common.state.MapStateDescriptor
Gets the serializer for the keys in the state.
getKeySerializer() - 类 中的方法org.apache.flink.api.common.typeutils.base.MapSerializer
 
getKeySerializerSnapshot() - 类 中的方法org.apache.flink.api.common.typeutils.base.MapSerializerSnapshot
 
getKeyString() - 类 中的方法org.apache.flink.util.StringBasedID
 
getKeyType() - 类 中的方法org.apache.flink.api.common.operators.Keys.SelectorFunctionKeys
 
getKeyTypeInfo() - 类 中的方法org.apache.flink.api.java.typeutils.MapTypeInfo
Gets the type information for the keys in the map
getKeyTypes() - 接口 中的方法org.apache.flink.api.common.distributions.DataDistribution
Gets the type of the key by which the dataSet is partitioned.
getKibiBytes() - 类 中的方法org.apache.flink.configuration.MemorySize
Gets the memory size in Kibibytes (= 1024 bytes).
getKind() - 类 中的方法org.apache.flink.core.fs.FileSystem
已过时。
this method is not used anymore.
getKind() - 类 中的方法org.apache.flink.core.fs.LimitedConnectionsFileSystem
 
getKind() - 类 中的方法org.apache.flink.core.fs.local.LocalFileSystem
 
getKind() - 类 中的方法org.apache.flink.core.fs.SafetyNetWrapperFileSystem
 
getKind() - 类 中的方法org.apache.flink.types.Row
Returns the kind of change that this row describes in a changelog.
getKryo() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer
 
getKryoRegistrations() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.KryoRegistrationSerializerConfigSnapshot
 
getLastModificationTime() - 类 中的方法org.apache.flink.api.common.io.FileInputFormat.FileBaseStatistics
Gets the timestamp of the last modification.
getLastResult() - 类 中的方法org.apache.flink.types.parser.BigDecParser
 
getLastResult() - 类 中的方法org.apache.flink.types.parser.BigIntParser
 
getLastResult() - 类 中的方法org.apache.flink.types.parser.BooleanParser
 
getLastResult() - 类 中的方法org.apache.flink.types.parser.BooleanValueParser
 
getLastResult() - 类 中的方法org.apache.flink.types.parser.ByteParser
 
getLastResult() - 类 中的方法org.apache.flink.types.parser.ByteValueParser
 
getLastResult() - 类 中的方法org.apache.flink.types.parser.DoubleParser
 
getLastResult() - 类 中的方法org.apache.flink.types.parser.DoubleValueParser
 
getLastResult() - 类 中的方法org.apache.flink.types.parser.FieldParser
Gets the parsed field.
getLastResult() - 类 中的方法org.apache.flink.types.parser.FloatParser
 
getLastResult() - 类 中的方法org.apache.flink.types.parser.FloatValueParser
 
getLastResult() - 类 中的方法org.apache.flink.types.parser.IntParser
 
getLastResult() - 类 中的方法org.apache.flink.types.parser.IntValueParser
 
getLastResult() - 类 中的方法org.apache.flink.types.parser.LongParser
 
getLastResult() - 类 中的方法org.apache.flink.types.parser.LongValueParser
 
getLastResult() - 类 中的方法org.apache.flink.types.parser.ShortParser
 
getLastResult() - 类 中的方法org.apache.flink.types.parser.ShortValueParser
 
getLastResult() - 类 中的方法org.apache.flink.types.parser.SqlDateParser
 
getLastResult() - 类 中的方法org.apache.flink.types.parser.SqlTimeParser
 
getLastResult() - 类 中的方法org.apache.flink.types.parser.SqlTimestampParser
 
getLastResult() - 类 中的方法org.apache.flink.types.parser.StringParser
 
getLastResult() - 类 中的方法org.apache.flink.types.parser.StringValueParser
 
getLatencyTrackingInterval() - 类 中的方法org.apache.flink.api.common.ExecutionConfig
Returns the latency tracking interval.
getLeaseCount() - 类 中的方法org.apache.flink.util.ResourceGuard
Returns the current count of open leases.
getLeftSerializer() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.EitherSerializer
 
getLeftType() - 类 中的方法org.apache.flink.api.java.typeutils.EitherTypeInfo
 
getLen() - 接口 中的方法org.apache.flink.core.fs.FileStatus
Return the length of this file.
getLen() - 类 中的方法org.apache.flink.core.fs.local.LocalFileStatus
 
getLength() - 类 中的方法org.apache.flink.api.common.typeutils.base.array.BooleanPrimitiveArraySerializer
 
getLength() - 类 中的方法org.apache.flink.api.common.typeutils.base.array.BytePrimitiveArraySerializer
 
getLength() - 类 中的方法org.apache.flink.api.common.typeutils.base.array.CharPrimitiveArraySerializer
 
getLength() - 类 中的方法org.apache.flink.api.common.typeutils.base.array.DoublePrimitiveArraySerializer
 
getLength() - 类 中的方法org.apache.flink.api.common.typeutils.base.array.FloatPrimitiveArraySerializer
 
getLength() - 类 中的方法org.apache.flink.api.common.typeutils.base.array.IntPrimitiveArraySerializer
 
getLength() - 类 中的方法org.apache.flink.api.common.typeutils.base.array.LongPrimitiveArraySerializer
 
getLength() - 类 中的方法org.apache.flink.api.common.typeutils.base.array.ShortPrimitiveArraySerializer
 
getLength() - 类 中的方法org.apache.flink.api.common.typeutils.base.array.StringArraySerializer
 
getLength() - 类 中的方法org.apache.flink.api.common.typeutils.base.BigDecSerializer
 
getLength() - 类 中的方法org.apache.flink.api.common.typeutils.base.BigIntSerializer
 
getLength() - 类 中的方法org.apache.flink.api.common.typeutils.base.BooleanSerializer
 
getLength() - 类 中的方法org.apache.flink.api.common.typeutils.base.BooleanValueSerializer
 
getLength() - 类 中的方法org.apache.flink.api.common.typeutils.base.ByteSerializer
 
getLength() - 类 中的方法org.apache.flink.api.common.typeutils.base.ByteValueSerializer
 
getLength() - 类 中的方法org.apache.flink.api.common.typeutils.base.CharSerializer
 
getLength() - 类 中的方法org.apache.flink.api.common.typeutils.base.CharValueSerializer
 
getLength() - 类 中的方法org.apache.flink.api.common.typeutils.base.DateSerializer
 
getLength() - 类 中的方法org.apache.flink.api.common.typeutils.base.DoubleSerializer
 
getLength() - 类 中的方法org.apache.flink.api.common.typeutils.base.DoubleValueSerializer
 
getLength() - 类 中的方法org.apache.flink.api.common.typeutils.base.EnumSerializer
 
getLength() - 类 中的方法org.apache.flink.api.common.typeutils.base.FloatSerializer
 
getLength() - 类 中的方法org.apache.flink.api.common.typeutils.base.FloatValueSerializer
 
getLength() - 类 中的方法org.apache.flink.api.common.typeutils.base.GenericArraySerializer
 
getLength() - 类 中的方法org.apache.flink.api.common.typeutils.base.InstantSerializer
 
getLength() - 类 中的方法org.apache.flink.api.common.typeutils.base.IntSerializer
 
getLength() - 类 中的方法org.apache.flink.api.common.typeutils.base.IntValueSerializer
 
getLength() - 类 中的方法org.apache.flink.api.common.typeutils.base.ListSerializer
 
getLength() - 类 中的方法org.apache.flink.api.common.typeutils.base.LocalDateSerializer
 
getLength() - 类 中的方法org.apache.flink.api.common.typeutils.base.LocalDateTimeSerializer
 
getLength() - 类 中的方法org.apache.flink.api.common.typeutils.base.LocalTimeSerializer
 
getLength() - 类 中的方法org.apache.flink.api.common.typeutils.base.LongSerializer
 
getLength() - 类 中的方法org.apache.flink.api.common.typeutils.base.LongValueSerializer
 
getLength() - 类 中的方法org.apache.flink.api.common.typeutils.base.MapSerializer
 
getLength() - 类 中的方法org.apache.flink.api.common.typeutils.base.NullValueSerializer
 
getLength() - 类 中的方法org.apache.flink.api.common.typeutils.base.ShortSerializer
 
getLength() - 类 中的方法org.apache.flink.api.common.typeutils.base.ShortValueSerializer
 
getLength() - 类 中的方法org.apache.flink.api.common.typeutils.base.SqlDateSerializer
 
getLength() - 类 中的方法org.apache.flink.api.common.typeutils.base.SqlTimeSerializer
 
getLength() - 类 中的方法org.apache.flink.api.common.typeutils.base.SqlTimestampSerializer
 
getLength() - 类 中的方法org.apache.flink.api.common.typeutils.base.StringSerializer
 
getLength() - 类 中的方法org.apache.flink.api.common.typeutils.base.StringValueSerializer
 
getLength() - 类 中的方法org.apache.flink.api.common.typeutils.base.VoidSerializer
 
getLength() - 类 中的方法org.apache.flink.api.common.typeutils.CompositeSerializer
 
getLength() - 类 中的方法org.apache.flink.api.common.typeutils.SingleThreadAccessCheckingTypeSerializer
 
getLength() - 类 中的方法org.apache.flink.api.common.typeutils.TypeSerializer
Gets the length of the data type, if it is a fix length data type.
getLength() - 类 中的方法org.apache.flink.api.common.typeutils.UnloadableDummyTypeSerializer
 
getLength() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer
 
getLength() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.EitherSerializer
 
getLength() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer
 
getLength() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.NullableSerializer
 
getLength() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.PojoSerializer
 
getLength() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.RowSerializer
 
getLength() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.Tuple0Serializer
 
getLength() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.TupleSerializerBase
 
getLength() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.ValueSerializer
 
getLength() - 接口 中的方法org.apache.flink.core.fs.BlockLocation
Get the length of the block.
getLength() - 类 中的方法org.apache.flink.core.fs.FileInputSplit
Returns the number of bytes in the file to process.
getLength() - 类 中的方法org.apache.flink.core.fs.local.LocalBlockLocation
 
getLength() - 类 中的方法org.apache.flink.core.io.SimpleVersionedSerializerTypeSerializerProxy
 
getLineLengthLimit() - 类 中的方法org.apache.flink.api.common.io.DelimitedInputFormat
 
getLink() - 类 中的方法org.apache.flink.configuration.description.LinkElement
 
getListState(ListStateDescriptor<T>) - 接口 中的方法org.apache.flink.api.common.functions.RuntimeContext
Gets a handle to the system's key/value list state.
getListState(ListStateDescriptor<T>) - 类 中的方法org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
 
getListState(ListStateDescriptor<T>) - 接口 中的方法org.apache.flink.api.common.state.KeyedStateStore
Gets a handle to the system's key/value list state.
getListState(ListStateDescriptor<S>) - 接口 中的方法org.apache.flink.api.common.state.OperatorStateStore
Creates (or restores) a list state.
getLoaderExcludePatterns() - 类 中的方法org.apache.flink.core.plugin.PluginDescriptor
 
getLocalFileSystem() - 类 中的静态方法org.apache.flink.core.fs.FileSystem
Returns a reference to the FileSystem instance for accessing the local file system.
getLocalFsURI() - 类 中的静态方法org.apache.flink.core.fs.local.LocalFileSystem
Gets the URI that represents the local file system.
getLocalHostName() - 接口 中的方法org.apache.flink.api.connector.source.SourceReaderContext
Gets the hostname of the machine where this reader is executed.
getLocalOrder() - 类 中的方法org.apache.flink.api.common.operators.GenericDataSinkBase
Gets the order, in which the data sink writes its data locally.
getLocalValue() - 接口 中的方法org.apache.flink.api.common.accumulators.Accumulator
 
getLocalValue() - 类 中的方法org.apache.flink.api.common.accumulators.AverageAccumulator
 
getLocalValue() - 类 中的方法org.apache.flink.api.common.accumulators.DoubleCounter
 
getLocalValue() - 类 中的方法org.apache.flink.api.common.accumulators.DoubleMaximum
 
getLocalValue() - 类 中的方法org.apache.flink.api.common.accumulators.DoubleMinimum
 
getLocalValue() - 类 中的方法org.apache.flink.api.common.accumulators.Histogram
 
getLocalValue() - 类 中的方法org.apache.flink.api.common.accumulators.IntCounter
 
getLocalValue() - 类 中的方法org.apache.flink.api.common.accumulators.IntMaximum
 
getLocalValue() - 类 中的方法org.apache.flink.api.common.accumulators.IntMinimum
 
getLocalValue() - 类 中的方法org.apache.flink.api.common.accumulators.ListAccumulator
 
getLocalValue() - 类 中的方法org.apache.flink.api.common.accumulators.LongCounter
 
getLocalValue() - 类 中的方法org.apache.flink.api.common.accumulators.LongMaximum
 
getLocalValue() - 类 中的方法org.apache.flink.api.common.accumulators.LongMinimum
 
getLocalValue() - 类 中的方法org.apache.flink.api.common.accumulators.SerializedListAccumulator
 
getLocalValuePrimitive() - 类 中的方法org.apache.flink.api.common.accumulators.DoubleCounter
 
getLocalValuePrimitive() - 类 中的方法org.apache.flink.api.common.accumulators.DoubleMaximum
 
getLocalValuePrimitive() - 类 中的方法org.apache.flink.api.common.accumulators.DoubleMinimum
 
getLocalValuePrimitive() - 类 中的方法org.apache.flink.api.common.accumulators.IntCounter
 
getLocalValuePrimitive() - 类 中的方法org.apache.flink.api.common.accumulators.IntMaximum
 
getLocalValuePrimitive() - 类 中的方法org.apache.flink.api.common.accumulators.IntMinimum
 
getLocalValuePrimitive() - 类 中的方法org.apache.flink.api.common.accumulators.LongCounter
 
getLocalValuePrimitive() - 类 中的方法org.apache.flink.api.common.accumulators.LongMaximum
 
getLocalValuePrimitive() - 类 中的方法org.apache.flink.api.common.accumulators.LongMinimum
 
getLocation() - 类 中的方法org.apache.flink.api.connector.source.ReaderInfo
 
getLong(String, long) - 类 中的方法org.apache.flink.configuration.Configuration
getLong(ConfigOption<Long>) - 类 中的方法org.apache.flink.configuration.Configuration
Returns the value associated with the given config option as a long integer.
getLong(ConfigOption<Long>, long) - 类 中的方法org.apache.flink.configuration.Configuration
Returns the value associated with the given config option as a long integer.
getLong(String, long) - 类 中的方法org.apache.flink.configuration.DelegatingConfiguration
 
getLong(ConfigOption<Long>) - 类 中的方法org.apache.flink.configuration.DelegatingConfiguration
 
getLong(ConfigOption<Long>, long) - 类 中的方法org.apache.flink.configuration.DelegatingConfiguration
 
getLong(int) - 类 中的方法org.apache.flink.core.memory.MemorySegment
Reads a long value (64bit, 8 bytes) from the given position, in the system's native byte order.
getLong(Properties, String, long) - 类 中的静态方法org.apache.flink.util.PropertiesUtil
Get long from properties.
getLong(Properties, String, long, Logger) - 类 中的静态方法org.apache.flink.util.PropertiesUtil
Get long from properties.
getLongBigEndian(int) - 类 中的方法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) - 接口 中的方法org.apache.flink.api.common.functions.RuntimeContext
Convenience function to create a counter object for longs.
getLongCounter(String) - 类 中的方法org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
 
getLongLittleEndian(int) - 类 中的方法org.apache.flink.core.memory.MemorySegment
Reads a long integer value (64bit, 8 bytes) from the given position, in little endian byte order.
getLowerPart() - 类 中的方法org.apache.flink.util.AbstractID
Gets the lower 64 bits of the ID.
getMailboxExecutor() - 接口 中的方法org.apache.flink.api.connector.sink.Sink.InitContext
Returns the mailbox executor that allows to execute Runnables inside the task thread in between record processing.
getManagedMemory() - 类 中的方法org.apache.flink.api.common.operators.ResourceSpec
 
getManagedMemory() - 类 中的方法org.apache.flink.api.common.operators.SlotSharingGroup
 
getManagedMemoryOperatorScopeUseCaseWeights() - 类 中的方法org.apache.flink.api.dag.Transformation
Get operator scope use cases that this transformation needs managed memory for, and the use-case-specific weights for this transformation.
getManagedMemorySlotScopeUseCases() - 类 中的方法org.apache.flink.api.dag.Transformation
Get slot scope use cases that this transformation needs managed memory for.
getMapPartitionReturnTypes(MapPartitionFunction<IN, OUT>, TypeInformation<IN>) - 类 中的静态方法org.apache.flink.api.java.typeutils.TypeExtractor
 
getMapPartitionReturnTypes(MapPartitionFunction<IN, OUT>, TypeInformation<IN>, String, boolean) - 类 中的静态方法org.apache.flink.api.java.typeutils.TypeExtractor
 
getMapReturnTypes(MapFunction<IN, OUT>, TypeInformation<IN>) - 类 中的静态方法org.apache.flink.api.java.typeutils.TypeExtractor
 
getMapReturnTypes(MapFunction<IN, OUT>, TypeInformation<IN>, String, boolean) - 类 中的静态方法org.apache.flink.api.java.typeutils.TypeExtractor
 
getMapState(MapStateDescriptor<UK, UV>) - 接口 中的方法org.apache.flink.api.common.functions.RuntimeContext
Gets a handle to the system's key/value map state.
getMapState(MapStateDescriptor<UK, UV>) - 类 中的方法org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
 
getMapState(MapStateDescriptor<UK, UV>) - 接口 中的方法org.apache.flink.api.common.state.KeyedStateStore
Gets a handle to the system's key/value map state.
getMaxBackoff() - 类 中的方法org.apache.flink.api.common.restartstrategy.RestartStrategies.ExponentialDelayRestartStrategyConfiguration
 
getMaxFailureRate() - 类 中的方法org.apache.flink.api.common.restartstrategy.RestartStrategies.FailureRateRestartStrategyConfiguration
 
getMaximumNumberOfIterations() - 类 中的方法org.apache.flink.api.common.operators.base.BulkIterationBase
 
getMaximumNumberOfIterations() - 类 中的方法org.apache.flink.api.common.operators.base.DeltaIterationBase
 
getMaximumNumberOfSplits() - 类 中的方法org.apache.flink.util.LongValueSequenceIterator
 
getMaximumNumberOfSplits() - 类 中的方法org.apache.flink.util.NumberSequenceIterator
 
getMaximumNumberOfSplits() - 类 中的方法org.apache.flink.util.SplittableIterator
The maximum number of splits into which this iterator can be split up.
getMaximumParallelism() - 类 中的方法org.apache.flink.api.common.Plan
 
getMaxNormalizedKeyLen() - 类 中的方法org.apache.flink.types.BooleanValue
 
getMaxNormalizedKeyLen() - 类 中的方法org.apache.flink.types.ByteValue
 
getMaxNormalizedKeyLen() - 类 中的方法org.apache.flink.types.CharValue
 
getMaxNormalizedKeyLen() - 类 中的方法org.apache.flink.types.IntValue
 
getMaxNormalizedKeyLen() - 类 中的方法org.apache.flink.types.LongValue
 
getMaxNormalizedKeyLen() - 接口 中的方法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() - 类 中的方法org.apache.flink.types.NullValue
 
getMaxNormalizedKeyLen() - 类 中的方法org.apache.flink.types.ShortValue
 
getMaxNormalizedKeyLen() - 类 中的方法org.apache.flink.types.StringValue
 
getMaxNumberOfParallelSubtasks() - 接口 中的方法org.apache.flink.api.common.functions.RuntimeContext
Gets the number of max-parallelism with which the parallel task runs.
getMaxNumberOfParallelSubtasks() - 类 中的方法org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
 
getMaxNumberOfParallelSubtasks() - 类 中的方法org.apache.flink.api.common.TaskInfo
Gets the max parallelism aka the max number of subtasks.
getMaxNumOpenInputStreams() - 类 中的方法org.apache.flink.core.fs.LimitedConnectionsFileSystem
Gets the maximum number of concurrently open input streams.
getMaxNumOpenOutputStreams() - 类 中的方法org.apache.flink.core.fs.LimitedConnectionsFileSystem
Gets the maximum number of concurrently open output streams.
getMaxNumOpenStreamsTotal() - 类 中的方法org.apache.flink.core.fs.LimitedConnectionsFileSystem
Gets the maximum number of concurrently open streams (input + output).
getMaxParallelism() - 类 中的方法org.apache.flink.api.common.ArchivedExecutionConfig
 
getMaxParallelism() - 类 中的方法org.apache.flink.api.common.ExecutionConfig
Gets the maximum degree of parallelism defined for the program.
getMaxParallelism() - 类 中的方法org.apache.flink.api.dag.Transformation
Gets the maximum parallelism for this stream transformation.
getMebiBytes() - 类 中的方法org.apache.flink.configuration.MemorySize
Gets the memory size in Mebibytes (= 1024 Kibibytes).
getMemoryAddressSize() - 枚举 中的静态方法org.apache.flink.util.ProcessorArchitecture
Gets the MemorySize of the ProcessorArchitecture of this process.
getMerged() - 类 中的方法org.apache.flink.util.LinkedOptionalMap.MergeResult
 
getMetricGroup() - 接口 中的方法org.apache.flink.api.common.eventtime.TimestampAssignerSupplier.Context
Returns the metric group for the context in which the created TimestampAssigner is used.
getMetricGroup() - 接口 中的方法org.apache.flink.api.common.eventtime.WatermarkGeneratorSupplier.Context
Returns the metric group for the context in which the created WatermarkGenerator is used.
getMetricGroup() - 接口 中的方法org.apache.flink.api.common.functions.RuntimeContext
Returns the metric group for this parallel subtask.
getMetricGroup() - 类 中的方法org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
 
getMetricGroup() - 接口 中的方法org.apache.flink.api.common.serialization.DeserializationSchema.InitializationContext
Returns the metric group for the parallel subtask of the source that runs this DeserializationSchema.
getMetricGroup() - 接口 中的方法org.apache.flink.api.common.serialization.SerializationSchema.InitializationContext
Returns the metric group for the parallel subtask of the source that runs this SerializationSchema.
getMetricGroup() - 类 中的方法org.apache.flink.api.connector.sink.InitContextInitializationContextAdapter
 
getMinResources() - 类 中的方法org.apache.flink.api.common.operators.Operator
Gets the minimum resources for this operator.
getMinResources() - 类 中的方法org.apache.flink.api.dag.Transformation
Gets the minimum resource of this stream transformation.
getMinSplitSize() - 类 中的方法org.apache.flink.api.common.io.FileInputFormat
 
getModificationTime() - 接口 中的方法org.apache.flink.core.fs.FileStatus
Get the modification time of the file.
getModificationTime() - 类 中的方法org.apache.flink.core.fs.local.LocalFileStatus
 
getMultiplier() - 枚举 中的方法org.apache.flink.configuration.MemorySize.MemoryUnit
 
getName() - 类 中的方法org.apache.flink.api.common.aggregators.AggregatorWithName
Gets the name that the aggregator is registered under.
getName() - 类 中的方法org.apache.flink.api.common.operators.Operator
Gets the name of the contract instance.
getName() - 类 中的方法org.apache.flink.api.common.operators.SlotSharingGroup
 
getName() - 类 中的方法org.apache.flink.api.common.resources.Resource
 
getName() - 类 中的方法org.apache.flink.api.common.state.StateDescriptor
Returns the name of this StateDescriptor.
getName() - 类 中的方法org.apache.flink.api.dag.Transformation
Returns the name of this Transformation.
getName() - 类 中的方法org.apache.flink.api.java.typeutils.TypeExtractionUtils.LambdaExecutable
 
getName() - 接口 中的方法org.apache.flink.core.execution.PipelineExecutorFactory
Returns the name of the executor that this factory creates.
getName() - 类 中的方法org.apache.flink.core.fs.Path
Returns the final component of this path, i.e., everything that follows the last separator.
getNestedFileEnumeration() - 类 中的方法org.apache.flink.api.common.io.FileInputFormat
 
getNestedSerializers(GenericArraySerializer<C>) - 类 中的方法org.apache.flink.api.common.typeutils.base.GenericArraySerializerSnapshot
 
getNestedSerializers(ListSerializer<T>) - 类 中的方法org.apache.flink.api.common.typeutils.base.ListSerializerSnapshot
 
getNestedSerializers(MapSerializer<K, V>) - 类 中的方法org.apache.flink.api.common.typeutils.base.MapSerializerSnapshot
 
getNestedSerializers(S) - 类 中的方法org.apache.flink.api.common.typeutils.CompositeTypeSerializerSnapshot
Gets the nested serializers from the outer serializer.
getNestedSerializers() - 类 中的方法org.apache.flink.api.common.typeutils.CompositeTypeSerializerUtil.IntermediateCompatibilityResult
 
getNestedSerializers(SingleThreadAccessCheckingTypeSerializer<T>) - 类 中的方法org.apache.flink.api.common.typeutils.SingleThreadAccessCheckingTypeSerializer.SingleThreadAccessCheckingTypeSerializerSnapshot
 
getNestedSerializers(EitherSerializer<L, R>) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.JavaEitherSerializerSnapshot
 
getNestedSerializers(NullableSerializer<T>) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.NullableSerializer.NullableSerializerSnapshot
 
getNestedSerializers(RowSerializer) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.RowSerializer.RowSerializerSnapshot
 
getNestedSerializers(TupleSerializer<T>) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.TupleSerializerSnapshot
 
getNestedSerializersAndConfigs() - 类 中的方法org.apache.flink.api.common.typeutils.CompositeTypeSerializerConfigSnapshot
 
getNestedSerializerSnapshots() - 类 中的方法org.apache.flink.api.common.typeutils.CompositeTypeSerializerConfigSnapshot
 
getNestedSerializerSnapshots() - 类 中的方法org.apache.flink.api.common.typeutils.CompositeTypeSerializerSnapshot
 
getNestedSerializerSnapshots() - 类 中的方法org.apache.flink.api.common.typeutils.NestedSerializersSnapshotDelegate
Returns the snapshots of the nested serializers.
getNetRuntime() - 类 中的方法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) - 类 中的方法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.
getNetRuntime() - 类 中的方法org.apache.flink.core.execution.DetachedJobExecutionResult
 
getNewNodeId() - 类 中的静态方法org.apache.flink.api.dag.Transformation
 
getNextInputSplit(String, int) - 类 中的方法org.apache.flink.api.common.io.DefaultInputSplitAssigner
 
getNextInputSplit(String, int) - 类 中的方法org.apache.flink.api.common.io.LocatableInputSplitAssigner
 
getNextInputSplit(String, int) - 类 中的方法org.apache.flink.api.common.io.ReplicatingInputSplitAssigner
 
getNextInputSplit(String, int) - 接口 中的方法org.apache.flink.core.io.InputSplitAssigner
Returns the next input split that shall be consumed.
getNextPartialSolution() - 类 中的方法org.apache.flink.api.common.operators.base.BulkIterationBase
 
getNextRetryStrategy() - 类 中的方法org.apache.flink.util.concurrent.ExponentialBackoffRetryStrategy
 
getNextRetryStrategy() - 类 中的方法org.apache.flink.util.concurrent.FixedRetryStrategy
 
getNextRetryStrategy() - 接口 中的方法org.apache.flink.util.concurrent.RetryStrategy
 
getNextWorkset() - 类 中的方法org.apache.flink.api.common.operators.base.DeltaIterationBase
Gets the contract that has been set as the next workset.
getNonRegisteredSubclassesToSerializerConfigSnapshots() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.PojoSerializer.PojoSerializerConfigSnapshot
已过时。
 
getNormalizeKeyLen() - 类 中的方法org.apache.flink.api.common.typeutils.base.array.PrimitiveArrayComparator
 
getNormalizeKeyLen() - 类 中的方法org.apache.flink.api.common.typeutils.base.BigDecComparator
 
getNormalizeKeyLen() - 类 中的方法org.apache.flink.api.common.typeutils.base.BigIntComparator
 
getNormalizeKeyLen() - 类 中的方法org.apache.flink.api.common.typeutils.base.BooleanComparator
 
getNormalizeKeyLen() - 类 中的方法org.apache.flink.api.common.typeutils.base.BooleanValueComparator
 
getNormalizeKeyLen() - 类 中的方法org.apache.flink.api.common.typeutils.base.ByteComparator
 
getNormalizeKeyLen() - 类 中的方法org.apache.flink.api.common.typeutils.base.ByteValueComparator
 
getNormalizeKeyLen() - 类 中的方法org.apache.flink.api.common.typeutils.base.CharComparator
 
getNormalizeKeyLen() - 类 中的方法org.apache.flink.api.common.typeutils.base.CharValueComparator
 
getNormalizeKeyLen() - 类 中的方法org.apache.flink.api.common.typeutils.base.DateComparator
 
getNormalizeKeyLen() - 类 中的方法org.apache.flink.api.common.typeutils.base.DoubleComparator
 
getNormalizeKeyLen() - 类 中的方法org.apache.flink.api.common.typeutils.base.DoubleValueComparator
 
getNormalizeKeyLen() - 类 中的方法org.apache.flink.api.common.typeutils.base.EnumComparator
 
getNormalizeKeyLen() - 类 中的方法org.apache.flink.api.common.typeutils.base.FloatComparator
 
getNormalizeKeyLen() - 类 中的方法org.apache.flink.api.common.typeutils.base.FloatValueComparator
 
getNormalizeKeyLen() - 类 中的方法org.apache.flink.api.common.typeutils.base.InstantComparator
 
getNormalizeKeyLen() - 类 中的方法org.apache.flink.api.common.typeutils.base.IntComparator
 
getNormalizeKeyLen() - 类 中的方法org.apache.flink.api.common.typeutils.base.IntValueComparator
 
getNormalizeKeyLen() - 类 中的方法org.apache.flink.api.common.typeutils.base.LocalDateComparator
 
getNormalizeKeyLen() - 类 中的方法org.apache.flink.api.common.typeutils.base.LocalDateTimeComparator
 
getNormalizeKeyLen() - 类 中的方法org.apache.flink.api.common.typeutils.base.LocalTimeComparator
 
getNormalizeKeyLen() - 类 中的方法org.apache.flink.api.common.typeutils.base.LongComparator
 
getNormalizeKeyLen() - 类 中的方法org.apache.flink.api.common.typeutils.base.LongValueComparator
 
getNormalizeKeyLen() - 类 中的方法org.apache.flink.api.common.typeutils.base.NullValueComparator
 
getNormalizeKeyLen() - 类 中的方法org.apache.flink.api.common.typeutils.base.ShortComparator
 
getNormalizeKeyLen() - 类 中的方法org.apache.flink.api.common.typeutils.base.ShortValueComparator
 
getNormalizeKeyLen() - 类 中的方法org.apache.flink.api.common.typeutils.base.SqlTimestampComparator
 
getNormalizeKeyLen() - 类 中的方法org.apache.flink.api.common.typeutils.base.StringComparator
 
getNormalizeKeyLen() - 类 中的方法org.apache.flink.api.common.typeutils.base.StringValueComparator
 
getNormalizeKeyLen() - 类 中的方法org.apache.flink.api.common.typeutils.TypeComparator
Gets the number of bytes that the normalized key would maximally take.
getNormalizeKeyLen() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.CopyableValueComparator
 
getNormalizeKeyLen() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.GenericTypeComparator
 
getNormalizeKeyLen() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.NullAwareComparator
 
getNormalizeKeyLen() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.PojoComparator
 
getNormalizeKeyLen() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.RowComparator
 
getNormalizeKeyLen() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
 
getNormalizeKeyLen() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.ValueComparator
 
getNumberOfExecutionRetries() - 类 中的方法org.apache.flink.api.common.ExecutionConfig
已过时。
Should no longer be used because it is subsumed by RestartStrategyConfiguration
getNumberOfFields() - 接口 中的方法org.apache.flink.api.common.distributions.DataDistribution
The number of fields in the (composite) key.
getNumberOfFields() - 类 中的方法org.apache.flink.api.common.operators.Ordering
 
getNumberOfFieldsTotal() - 类 中的方法org.apache.flink.api.common.io.GenericCsvInputFormat
 
getNumberOfInputs() - 类 中的方法org.apache.flink.api.common.operators.AbstractUdfOperator
Gets the number of inputs for this operator.
getNumberOfInputs() - 类 中的方法org.apache.flink.api.common.operators.DualInputOperator
 
getNumberOfInputs() - 类 中的方法org.apache.flink.api.common.operators.SingleInputOperator
 
getNumberOfKeyFields() - 类 中的方法org.apache.flink.api.common.operators.Keys.ExpressionKeys
 
getNumberOfKeyFields() - 类 中的方法org.apache.flink.api.common.operators.Keys
 
getNumberOfKeyFields() - 类 中的方法org.apache.flink.api.common.operators.Keys.SelectorFunctionKeys
 
getNumberOfLocalAssignments() - 类 中的方法org.apache.flink.api.common.io.LocatableInputSplitAssigner
 
getNumberOfNonNullFields() - 类 中的方法org.apache.flink.api.common.io.GenericCsvInputFormat
 
getNumberOfOpenInputStreams() - 类 中的方法org.apache.flink.core.fs.LimitedConnectionsFileSystem
Gets the number of currently open input streams.
getNumberOfOpenOutputStreams() - 类 中的方法org.apache.flink.core.fs.LimitedConnectionsFileSystem
Gets the number of currently open output streams.
getNumberOfParallelSubtasks() - 接口 中的方法org.apache.flink.api.common.functions.RuntimeContext
Gets the parallelism with which the parallel task runs.
getNumberOfParallelSubtasks() - 类 中的方法org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
 
getNumberOfParallelSubtasks() - 类 中的方法org.apache.flink.api.common.TaskInfo
Gets the parallelism with which the parallel task runs.
getNumberOfParallelSubtasks() - 接口 中的方法org.apache.flink.api.connector.sink.Sink.InitContext
 
getNumberOfRecords() - 类 中的方法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() - 接口 中的方法org.apache.flink.api.common.io.statistics.BaseStatistics
Gets the number of records in the input (= base cardinality).
getNumberOfRegisteredCloseables() - 类 中的方法org.apache.flink.util.AbstractCloseableRegistry
 
getNumberOfRemoteAssignments() - 类 中的方法org.apache.flink.api.common.io.LocatableInputSplitAssigner
 
getNumFields() - 类 中的方法org.apache.flink.types.Record
Gets the number of fields currently in the record.
getNumFuturesCompleted() - 类 中的方法org.apache.flink.util.concurrent.FutureUtils.ConjunctFuture
Gets the number of Futures in the conjunction that are already complete.
getNumFuturesTotal() - 类 中的方法org.apache.flink.util.concurrent.FutureUtils.ConjunctFuture
Gets the total number of Futures in the conjunction.
getNumLineSamples() - 类 中的方法org.apache.flink.api.common.io.DelimitedInputFormat
 
getNumRemainingRetries() - 类 中的方法org.apache.flink.util.concurrent.ExponentialBackoffRetryStrategy
 
getNumRemainingRetries() - 类 中的方法org.apache.flink.util.concurrent.FixedRetryStrategy
 
getNumRemainingRetries() - 接口 中的方法org.apache.flink.util.concurrent.RetryStrategy
 
getNumSplits() - 类 中的方法org.apache.flink.api.common.io.FileInputFormat
 
getObjectReuseEnabled() - 类 中的方法org.apache.flink.api.common.ArchivedExecutionConfig
 
getOffset() - 接口 中的方法org.apache.flink.core.fs.BlockLocation
Get the start offset of the file associated with this block.
getOffset() - 类 中的方法org.apache.flink.core.fs.local.LocalBlockLocation
 
getOpenTimeout() - 类 中的方法org.apache.flink.api.common.io.FileInputFormat
 
getOperatorInfo() - 类 中的方法org.apache.flink.api.common.operators.DualInputOperator
Gets the information about the operators input/output types.
getOperatorInfo() - 类 中的方法org.apache.flink.api.common.operators.Operator
Gets the information about the operators input/output types.
getOperatorInfo() - 类 中的方法org.apache.flink.api.common.operators.SingleInputOperator
Gets the information about the operators input/output types.
getOptional(ConfigOption<T>) - 类 中的方法org.apache.flink.configuration.Configuration
 
getOptional(ConfigOption<T>) - 类 中的方法org.apache.flink.configuration.DelegatingConfiguration
 
getOptional(ConfigOption<T>) - 接口 中的方法org.apache.flink.configuration.ReadableConfig
Reads a value using the metadata included in ConfigOption.
getOrDefault(CompletableFuture<T>, T) - 类 中的静态方法org.apache.flink.util.concurrent.FutureUtils
 
getOrDefault(boolean) - 枚举 中的方法org.apache.flink.util.TernaryBoolean
Gets the boolean value corresponding to this value.
getOrder(int) - 类 中的方法org.apache.flink.api.common.operators.Ordering
 
getOrdering() - 类 中的方法org.apache.flink.api.common.operators.base.PartitionOperatorBase
 
getOriginalError() - 类 中的方法org.apache.flink.api.common.typeutils.UnloadableDummyTypeSerializer
 
getOriginalErrorClassName() - 异常错误 中的方法org.apache.flink.util.SerializedThrowable
 
getOriginalKeyFieldTypes() - 类 中的方法org.apache.flink.api.common.operators.Keys.ExpressionKeys
 
getOriginalKeyFieldTypes() - 类 中的方法org.apache.flink.api.common.operators.Keys
 
getOriginalKeyFieldTypes() - 类 中的方法org.apache.flink.api.common.operators.Keys.SelectorFunctionKeys
 
getOuterJoinType() - 类 中的方法org.apache.flink.api.common.operators.base.OuterJoinOperatorBase
 
getOutputCardinality() - 类 中的方法org.apache.flink.api.common.operators.CompilerHints
 
getOutputDirectoryMode() - 类 中的方法org.apache.flink.api.common.io.FileOutputFormat
 
getOutputFilePath() - 类 中的方法org.apache.flink.api.common.io.FileOutputFormat
 
getOutputSize() - 类 中的方法org.apache.flink.api.common.operators.CompilerHints
 
getOutputType() - 类 中的方法org.apache.flink.api.common.operators.OperatorInformation
Gets the return type of the user code function.
getOutputType() - 类 中的方法org.apache.flink.api.dag.Transformation
Returns the output type of this Transformation as a TypeInformation.
getOwner() - 类 中的方法org.apache.flink.core.memory.MemorySegment
Gets the owner of this memory segment.
getParallelism() - 类 中的方法org.apache.flink.api.common.ArchivedExecutionConfig
 
getParallelism() - 类 中的方法org.apache.flink.api.common.ExecutionConfig
Gets the parallelism with which operation are executed by default.
getParallelism() - 类 中的方法org.apache.flink.api.common.operators.Operator
Gets the parallelism for this contract instance.
getParallelism() - 类 中的方法org.apache.flink.api.dag.Transformation
Returns the parallelism of this Transformation.
getParameters() - 类 中的方法org.apache.flink.api.common.operators.Operator
Gets the stub parameters of this contract.
getParameterType(Class<?>, Class<?>, int) - 类 中的静态方法org.apache.flink.api.java.typeutils.TypeExtractor
 
getParameterTypes() - 类 中的方法org.apache.flink.api.java.typeutils.TypeExtractionUtils.LambdaExecutable
 
getParent() - 类 中的方法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.
getParentFirstLoaderPatterns(Configuration) - 类 中的静态方法org.apache.flink.configuration.CoreOptions
 
getParserForType(Class<T>) - 类 中的静态方法org.apache.flink.types.parser.FieldParser
Gets the parser for the type specified by the given class.
getPartialSolution() - 类 中的方法org.apache.flink.api.common.operators.base.BulkIterationBase
 
getPartitionerTypes(Partitioner<T>) - 类 中的静态方法org.apache.flink.api.java.typeutils.TypeExtractor
 
getPartitionerTypes(Partitioner<T>, String, boolean) - 类 中的静态方法org.apache.flink.api.java.typeutils.TypeExtractor
 
getPartitionMethod() - 类 中的方法org.apache.flink.api.common.operators.base.PartitionOperatorBase
 
getPartitionOrdering() - 类 中的方法org.apache.flink.api.common.operators.base.SortPartitionOperatorBase
 
getPath() - 类 中的方法org.apache.flink.core.fs.FileInputSplit
Returns the path of the file containing this split's data.
getPath() - 接口 中的方法org.apache.flink.core.fs.FileStatus
Returns the corresponding Path to the FileStatus.
getPath() - 类 中的方法org.apache.flink.core.fs.local.LocalFileStatus
 
getPath() - 类 中的方法org.apache.flink.core.fs.Path
Return full path.
getPluginId() - 类 中的方法org.apache.flink.core.plugin.PluginDescriptor
 
getPluginParentFirstLoaderPatterns(Configuration) - 类 中的静态方法org.apache.flink.configuration.CoreOptions
 
getPluginResourceURLs() - 类 中的方法org.apache.flink.core.plugin.PluginDescriptor
 
getPluginsDir() - 类 中的静态方法org.apache.flink.core.plugin.PluginConfig
 
getPluginsPath() - 类 中的方法org.apache.flink.core.plugin.PluginConfig
 
getPojoFieldAt(int) - 类 中的方法org.apache.flink.api.java.typeutils.PojoTypeInfo
 
getPort() - 类 中的静态方法org.apache.flink.management.jmx.JMXService
 
getPortRangeFromString(String) - 类 中的静态方法org.apache.flink.util.NetUtils
Returns an iterator over available ports defined by the range definition.
getPos() - 类 中的方法org.apache.flink.api.common.io.InputStreamFSInputWrapper
 
getPos() - 类 中的方法org.apache.flink.core.fs.FSDataInputStream
Gets the current position in the input stream.
getPos() - 类 中的方法org.apache.flink.core.fs.FSDataInputStreamWrapper
 
getPos() - 类 中的方法org.apache.flink.core.fs.FSDataOutputStream
Gets the position of the stream (non-negative), defined as the number of bytes from the beginning of the file to the current writing position.
getPos() - 类 中的方法org.apache.flink.core.fs.FSDataOutputStreamWrapper
 
getPos() - 类 中的方法org.apache.flink.core.fs.local.LocalDataInputStream
 
getPos() - 类 中的方法org.apache.flink.core.fs.local.LocalDataOutputStream
 
getPosition() - 类 中的方法org.apache.flink.api.common.typeutils.CompositeType.FlatFieldDescriptor
 
getPosition() - 类 中的方法org.apache.flink.core.memory.ByteArrayOutputStreamWithPos
 
getPosition() - 类 中的方法org.apache.flink.core.memory.DataInputDeserializer
 
getPosition() - 类 中的方法org.apache.flink.core.memory.MemorySegmentInputStreamWithPos
 
getPostPassClassName() - 类 中的方法org.apache.flink.api.common.Plan
Gets the optimizer post-pass class for this job.
getPreferredResources() - 类 中的方法org.apache.flink.api.common.operators.Operator
Gets the preferred resources for this contract instance.
getPreferredResources() - 类 中的方法org.apache.flink.api.dag.Transformation
Gets the preferred resource of this stream transformation.
getPrefixedKeyValuePairs(String, Configuration) - 类 中的静态方法org.apache.flink.configuration.ConfigurationUtils
Extract and parse Flink configuration properties with a given name prefix and return the result as a Map.
getPresentEntries() - 类 中的方法org.apache.flink.util.LinkedOptionalMap
 
getPreviousIterationAggregate(String) - 接口 中的方法org.apache.flink.api.common.functions.IterationRuntimeContext
 
getProcessingTimeService() - 接口 中的方法org.apache.flink.api.connector.sink.Sink.InitContext
Returns a Sink.ProcessingTimeService that can be used to get the current time and register timers.
getProcessorArchitecture() - 枚举 中的静态方法org.apache.flink.util.ProcessorArchitecture
Gets the ProcessorArchitecture of the system running this process.
getProducedType() - 类 中的方法org.apache.flink.api.common.serialization.AbstractDeserializationSchema
Gets the type produced by this deserializer.
getProducedType() - 类 中的方法org.apache.flink.api.common.serialization.SimpleStringSchema
 
getProducedType() - 类 中的方法org.apache.flink.api.common.serialization.TypeInformationSerializationSchema
 
getProducedType() - 类 中的方法org.apache.flink.api.connector.source.lib.NumberSequenceSource
 
getProducedType() - 接口 中的方法org.apache.flink.api.java.typeutils.ResultTypeQueryable
Gets the data type (as a TypeInformation) produced by this function or input format.
getProperty(String) - 接口 中的方法org.apache.flink.api.common.externalresource.ExternalResourceInfo
Get the property indicated by the specified key.
getQueryableStateName() - 类 中的方法org.apache.flink.api.common.state.StateDescriptor
Returns the queryable state name.
getQueryTimeAfterNumEntries() - 类 中的方法org.apache.flink.api.common.state.StateTtlConfig.RocksdbCompactFilterCleanupStrategy
 
getRandomFilename(String) - 类 中的静态方法org.apache.flink.util.FileUtils
Constructs a random filename with the given prefix and a random part generated from hex characters.
getRandomString(Random, int, int) - 类 中的静态方法org.apache.flink.util.StringUtils
Creates a random string with a length within the given interval.
getRandomString(Random, int, int, char, char) - 类 中的静态方法org.apache.flink.util.StringUtils
Creates a random string with a length within the given interval.
getRangeIndex(T) - 类 中的方法org.apache.flink.api.common.distributions.CommonRangeBoundaries
 
getRangeIndex(T) - 接口 中的方法org.apache.flink.api.common.distributions.RangeBoundaries
Get the range index of record.
getRate() - 接口 中的方法org.apache.flink.api.common.io.ratelimiting.FlinkConnectorRateLimiter
 
getRate() - 类 中的方法org.apache.flink.api.common.io.ratelimiting.GuavaFlinkConnectorRateLimiter
 
getRawClass(Type) - 类 中的静态方法org.apache.flink.api.java.typeutils.TypeExtractionUtils
Returns the raw class of both parameterized types and generic arrays.
getReadFields(int) - 类 中的方法org.apache.flink.api.common.operators.DualInputSemanticProperties
 
getReadFields(int) - 类 中的方法org.apache.flink.api.common.operators.SemanticProperties.EmptySemanticProperties
 
getReadFields(int) - 接口 中的方法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) - 类 中的方法org.apache.flink.api.common.operators.SingleInputSemanticProperties
 
getReadVersion() - 类 中的方法org.apache.flink.core.io.VersionedIOReadableWritable
Returns the found serialization version.
getReconfiguredSerializer() - 类 中的方法org.apache.flink.api.common.typeutils.TypeSerializerSchemaCompatibility
Gets the reconfigured serializer.
getRecordCount() - 类 中的方法org.apache.flink.api.common.io.BlockInfo
Returns the recordCount.
getRecoverable() - 接口 中的方法org.apache.flink.core.fs.RecoverableFsDataOutputStream.Committer
Gets a recoverable object to recover the committer.
getReduceFunction() - 类 中的方法org.apache.flink.api.common.state.ReducingStateDescriptor
Returns the reduce function to be used for the reducing state.
getReducingState(ReducingStateDescriptor<T>) - 接口 中的方法org.apache.flink.api.common.functions.RuntimeContext
Gets a handle to the system's key/value reducing state.
getReducingState(ReducingStateDescriptor<T>) - 类 中的方法org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
 
getReducingState(ReducingStateDescriptor<T>) - 接口 中的方法org.apache.flink.api.common.state.KeyedStateStore
Gets a handle to the system's key/value reducing state.
getReferenceCounter() - 类 中的方法org.apache.flink.core.fs.RefCountedFile
 
getReferencesToClose() - 类 中的方法org.apache.flink.core.fs.CloseableRegistry
 
getReferencesToClose() - 类 中的方法org.apache.flink.util.AbstractCloseableRegistry
 
getRegisteredBroadcastStateNames() - 接口 中的方法org.apache.flink.api.common.state.OperatorStateStore
Returns a set with the names of all currently registered broadcast states.
getRegisteredClass() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.KryoRegistration
 
getRegisteredKryoTypes() - 类 中的方法org.apache.flink.api.common.ExecutionConfig
Returns the registered Kryo types.
getRegisteredPojoTypes() - 类 中的方法org.apache.flink.api.common.ExecutionConfig
Returns the registered POJO types.
getRegisteredStateNames() - 接口 中的方法org.apache.flink.api.common.state.OperatorStateStore
Returns a set with the names of all currently registered states.
getRegisteredSubclassesToSerializerConfigSnapshots() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.PojoSerializer.PojoSerializerConfigSnapshot
已过时。
 
getRegisteredTypesWithKryoSerializerClasses() - 类 中的方法org.apache.flink.api.common.ExecutionConfig
Returns the registered types with their Kryo Serializer classes.
getRegisteredTypesWithKryoSerializers() - 类 中的方法org.apache.flink.api.common.ExecutionConfig
Returns the registered types with Kryo Serializers.
getReplicatedInputFormat() - 类 中的方法org.apache.flink.api.common.io.ReplicatingInputFormat
 
getReplication() - 接口 中的方法org.apache.flink.core.fs.FileStatus
Get the replication factor of a file.
getReplication() - 类 中的方法org.apache.flink.core.fs.local.LocalFileStatus
 
getResetBackoffThreshold() - 类 中的方法org.apache.flink.api.common.restartstrategy.RestartStrategies.ExponentialDelayRestartStrategyConfiguration
 
getResource(String) - 类 中的方法org.apache.flink.core.classloading.ComponentClassLoader
 
getResource(String) - 类 中的方法org.apache.flink.util.ChildFirstClassLoader
 
getResources(String) - 类 中的方法org.apache.flink.core.classloading.ComponentClassLoader
 
getResources(String) - 类 中的方法org.apache.flink.util.ChildFirstClassLoader
 
getRestartAttempts() - 类 中的方法org.apache.flink.api.common.restartstrategy.RestartStrategies.FixedDelayRestartStrategyConfiguration
 
getRestartStrategy() - 类 中的方法org.apache.flink.api.common.ExecutionConfig
Returns the restart strategy which has been set for the current job.
getRestartStrategyDescription() - 类 中的方法org.apache.flink.api.common.ArchivedExecutionConfig
 
getRestoredCheckpointId() - 接口 中的方法org.apache.flink.api.connector.sink.Sink.InitContext
Returns id of the restored checkpoint, if state was restored from the snapshot of a previous execution.
getRestoredNestedSerializer(int) - 类 中的方法org.apache.flink.api.common.typeutils.NestedSerializersSnapshotDelegate
Creates the restore serializer from the pos-th config snapshot.
getRestoredNestedSerializers() - 类 中的方法org.apache.flink.api.common.typeutils.NestedSerializersSnapshotDelegate
Produces a restore serializer from each contained serializer configuration snapshot.
getResult(ACC) - 接口 中的方法org.apache.flink.api.common.functions.AggregateFunction
Gets the result of the aggregation from the accumulator.
getResult(ACC) - 类 中的方法org.apache.flink.api.common.functions.RichAggregateFunction
 
getResultsFormatted(Map<String, Object>) - 类 中的静态方法org.apache.flink.api.common.accumulators.AccumulatorHelper
 
getResumeRecoverableSerializer() - 类 中的方法org.apache.flink.core.fs.local.LocalRecoverableWriter
 
getResumeRecoverableSerializer() - 接口 中的方法org.apache.flink.core.fs.RecoverableWriter
The serializer for the ResumeRecoverable types created in this writer.
getRetryDelay() - 类 中的方法org.apache.flink.util.concurrent.ExponentialBackoffRetryStrategy
 
getRetryDelay() - 类 中的方法org.apache.flink.util.concurrent.FixedRetryStrategy
 
getRetryDelay() - 接口 中的方法org.apache.flink.util.concurrent.RetryStrategy
 
getReturnType() - 类 中的方法org.apache.flink.api.java.typeutils.TypeExtractionUtils.LambdaExecutable
 
getRightSerializer() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.EitherSerializer
 
getRightType() - 类 中的方法org.apache.flink.api.java.typeutils.EitherTypeInfo
 
getRocksdbCompactFilterCleanupStrategy() - 类 中的方法org.apache.flink.api.common.state.StateTtlConfig.CleanupStrategies
 
getRuntimeContext() - 类 中的方法org.apache.flink.api.common.functions.AbstractRichFunction
 
getRuntimeContext() - 接口 中的方法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 task that executes the function.
getRuntimeContext() - 类 中的方法org.apache.flink.api.common.io.ReplicatingInputFormat
 
getRuntimeContext() - 类 中的方法org.apache.flink.api.common.io.RichInputFormat
 
getRuntimeContext() - 类 中的方法org.apache.flink.api.common.io.RichOutputFormat
 
getSchedulerType(Configuration) - 类 中的静态方法org.apache.flink.configuration.ClusterOptions
 
getScheme() - 类 中的方法org.apache.flink.core.fs.ConnectionLimitingFactory
 
getScheme() - 接口 中的方法org.apache.flink.core.fs.FileSystemFactory
Gets the scheme of the file system created by this factory.
getScheme() - 类 中的方法org.apache.flink.core.fs.local.LocalFileSystemFactory
 
getScheme() - 类 中的方法org.apache.flink.core.fs.PluginFileSystemFactory
 
getSecondInput() - 类 中的方法org.apache.flink.api.common.operators.DualInputOperator
Returns the second input, or null, if none is set.
getSecondInputType() - 类 中的方法org.apache.flink.api.common.operators.BinaryOperatorInformation
 
getSemanticProperties() - 类 中的方法org.apache.flink.api.common.operators.base.PartitionOperatorBase
 
getSemanticProperties() - 类 中的方法org.apache.flink.api.common.operators.base.SortPartitionOperatorBase
 
getSemanticProperties() - 类 中的方法org.apache.flink.api.common.operators.DualInputOperator
 
getSemanticProperties() - 类 中的方法org.apache.flink.api.common.operators.SingleInputOperator
 
getSerializableSerializerInstance() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.KryoRegistration
 
getSerializationFormatIdentifier() - 类 中的方法org.apache.flink.api.common.typeutils.ParameterlessTypeSerializerConfig
已过时。
 
getSerializedException() - 异常错误 中的方法org.apache.flink.util.SerializedThrowable
 
getSerializer() - 类 中的方法org.apache.flink.api.common.ExecutionConfig.SerializableSerializer
 
getSerializer() - 类 中的方法org.apache.flink.api.common.state.StateDescriptor
Returns the TypeSerializer that can be used to serialize the value in the state.
getSerializer() - 接口 中的方法org.apache.flink.api.common.typeutils.TypeSerializerFactory
 
getSerializer(Kryo) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.KryoRegistration
 
getSerializer() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.RuntimeSerializerFactory
 
getSerializerClass() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.KryoRegistration
 
getSerializerDefinitionType() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.KryoRegistration
 
getSharedBuffer() - 类 中的方法org.apache.flink.core.memory.DataOutputSerializer
Gets a reference to the internal byte buffer.
getSharedInstance() - 类 中的静态方法org.apache.flink.core.fs.local.LocalFileSystem
Gets the shared instance of this file system.
getShort(int) - 类 中的方法org.apache.flink.core.memory.MemorySegment
Reads a short integer value (16 bit, 2 bytes) from the given position, composing them into a short value according to the current byte order.
getShortBigEndian(int) - 类 中的方法org.apache.flink.core.memory.MemorySegment
Reads a short integer value (16 bit, 2 bytes) from the given position, in big-endian byte order.
getShortLittleEndian(int) - 类 中的方法org.apache.flink.core.memory.MemorySegment
Reads a short integer value (16 bit, 2 bytes) from the given position, in little-endian byte order.
getShortName() - 枚举 中的方法org.apache.flink.api.common.operators.Order
 
getSingleAbstractMethod(Class<?>) - 类 中的静态方法org.apache.flink.api.java.typeutils.TypeExtractionUtils
Extracts a Single Abstract Method (SAM) as defined in Java Specification (4.3.2.
getSingleNestedSerializerAndConfig() - 类 中的方法org.apache.flink.api.common.typeutils.CompositeTypeSerializerConfigSnapshot
 
getSize() - 类 中的方法org.apache.flink.api.common.time.Time
Gets the length of this policy's time interval.
getSize() - 类 中的方法org.apache.flink.util.CompressedSerializedValue
Returns the size of the compressed serialized data.
getSlotSharingGroup() - 类 中的方法org.apache.flink.api.dag.Transformation
Returns the slot sharing group of this transformation if present.
getSolutionSet() - 类 中的方法org.apache.flink.api.common.operators.base.DeltaIterationBase
Gets the contract that represents the solution set for the step function.
getSolutionSetDelta() - 类 中的方法org.apache.flink.api.common.operators.base.DeltaIterationBase
Gets the contract that has been set as the solution set delta.
getSolutionSetKeyFields() - 类 中的方法org.apache.flink.api.common.operators.base.DeltaIterationBase
 
getSplit(int, int) - 类 中的方法org.apache.flink.util.SplittableIterator
Splits this iterator into n partitions and returns the i-th partition out of those.
getSplitDataProperties() - 类 中的方法org.apache.flink.api.common.operators.GenericDataSourceBase
Returns the data properties of this data source's splits.
getSplitGroupKeys() - 接口 中的方法org.apache.flink.api.common.operators.GenericDataSourceBase.SplitDataProperties
 
getSplitLength() - 类 中的方法org.apache.flink.api.common.io.FileInputFormat
Gets the length or remaining length of the current split.
getSplitNumber() - 类 中的方法org.apache.flink.core.io.GenericInputSplit
 
getSplitNumber() - 接口 中的方法org.apache.flink.core.io.InputSplit
Returns the number of this input split.
getSplitNumber() - 类 中的方法org.apache.flink.core.io.LocatableInputSplit
 
getSplitOrder() - 接口 中的方法org.apache.flink.api.common.operators.GenericDataSourceBase.SplitDataProperties
 
getSplitPartitioner() - 接口 中的方法org.apache.flink.api.common.operators.GenericDataSourceBase.SplitDataProperties
 
getSplitPartitionKeys() - 接口 中的方法org.apache.flink.api.common.operators.GenericDataSourceBase.SplitDataProperties
 
getSplitSerializer() - 类 中的方法org.apache.flink.api.connector.source.lib.NumberSequenceSource
 
getSplitSerializer() - 接口 中的方法org.apache.flink.api.connector.source.Source
Creates a serializer for the source splits.
getSplitStart() - 类 中的方法org.apache.flink.api.common.io.FileInputFormat
Gets the start of the current split.
getStandaloneClusterStartupPeriodTime(Configuration) - 类 中的静态方法org.apache.flink.configuration.ConfigurationUtils
 
getStart() - 类 中的方法org.apache.flink.core.fs.FileInputSplit
Returns the position of the first byte in the file to process.
getState(ValueStateDescriptor<T>) - 接口 中的方法org.apache.flink.api.common.functions.RuntimeContext
Gets a handle to the system's key/value state.
getState(ValueStateDescriptor<T>) - 类 中的方法org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
 
getState(ValueStateDescriptor<T>) - 接口 中的方法org.apache.flink.api.common.state.KeyedStateStore
Gets a handle to the system's key/value state.
getStateVisibility() - 类 中的方法org.apache.flink.api.common.state.StateTtlConfig
 
getStatistics(BaseStatistics) - 类 中的方法org.apache.flink.api.common.io.BinaryInputFormat
 
getStatistics(BaseStatistics) - 类 中的方法org.apache.flink.api.common.io.DelimitedInputFormat
 
getStatistics(BaseStatistics) - 类 中的方法org.apache.flink.api.common.io.FileInputFormat
Obtains basic file statistics containing only file size.
getStatistics(BaseStatistics) - 类 中的方法org.apache.flink.api.common.io.GenericInputFormat
 
getStatistics(BaseStatistics) - 接口 中的方法org.apache.flink.api.common.io.InputFormat
Gets the basic statistics from the input described by this format.
getStatistics(BaseStatistics) - 类 中的方法org.apache.flink.api.common.io.ReplicatingInputFormat
 
getStatisticsKey() - 类 中的方法org.apache.flink.api.common.operators.GenericDataSourceBase
Gets the key under which statistics about this data source may be obtained from the statistics cache.
getStreamInactivityTimeout() - 类 中的方法org.apache.flink.core.fs.LimitedConnectionsFileSystem
Gets the milliseconds that a stream may spend not writing any bytes before it is closed as inactive.
getStreamOpenTimeout() - 类 中的方法org.apache.flink.core.fs.LimitedConnectionsFileSystem
Gets the number of milliseconds that a opening a stream may wait for availability in the connection pool.
getString(String, String) - 类 中的方法org.apache.flink.configuration.Configuration
getString(ConfigOption<String>) - 类 中的方法org.apache.flink.configuration.Configuration
Returns the value associated with the given config option as a string.
getString(ConfigOption<String>, String) - 类 中的方法org.apache.flink.configuration.Configuration
Returns the value associated with the given config option as a string.
getString(String, String) - 类 中的方法org.apache.flink.configuration.DelegatingConfiguration
 
getString(ConfigOption<String>) - 类 中的方法org.apache.flink.configuration.DelegatingConfiguration
 
getString(ConfigOption<String>, String) - 类 中的方法org.apache.flink.configuration.DelegatingConfiguration
 
getStringInMillis(Duration) - 类 中的静态方法org.apache.flink.util.TimeUtils
 
getStyles() - 类 中的方法org.apache.flink.configuration.description.TextElement
 
getSubtaskId() - 接口 中的方法org.apache.flink.api.connector.sink.Sink.InitContext
 
getSubtaskId() - 类 中的方法org.apache.flink.api.connector.source.ReaderInfo
 
getSuperstepNumber() - 接口 中的方法org.apache.flink.api.common.functions.IterationRuntimeContext
Gets the number of the current superstep.
getSuperTemplateTypes(Class<?>) - 类 中的静态方法org.apache.flink.util.ReflectionUtil
 
getSuperTemplateTypes(Class<?>, Class<?>) - 类 中的静态方法org.apache.flink.util.ReflectionUtil
 
getSynchronizationLock() - 类 中的方法org.apache.flink.util.AbstractCloseableRegistry
Returns the lock on which manipulations to members closeableToRef and closeable must be synchronized.
getSystemConfigKeyConfigOptionForResource(String, String) - 类 中的静态方法org.apache.flink.configuration.ExternalResourceOptions
Generate the config option key for the configuration key of external resource in the deploying system.
getSystemResourceMetricsProbingInterval(Configuration) - 类 中的静态方法org.apache.flink.configuration.ConfigurationUtils
 
getTaskCancellationInterval() - 类 中的方法org.apache.flink.api.common.ExecutionConfig
Gets the interval (in milliseconds) between consecutive attempts to cancel a running task.
getTaskCancellationTimeout() - 类 中的方法org.apache.flink.api.common.ExecutionConfig
Returns the timeout (in milliseconds) after which an ongoing task cancellation leads to a fatal TaskManager error.
getTaskHeapMemory() - 类 中的方法org.apache.flink.api.common.operators.ResourceSpec
 
getTaskHeapMemory() - 类 中的方法org.apache.flink.api.common.operators.SlotSharingGroup
 
getTaskName() - 接口 中的方法org.apache.flink.api.common.functions.RuntimeContext
Returns the name of the task in which the UDF runs, as assigned during plan construction.
getTaskName() - 类 中的方法org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
 
getTaskName() - 类 中的方法org.apache.flink.api.common.TaskInfo
Returns the name of the task
getTaskNameWithSubtasks() - 接口 中的方法org.apache.flink.api.common.functions.RuntimeContext
Returns the name of the task, appended with the subtask indicator, such as "MyTask (3/6)#1", where 3 would be (RuntimeContext.getIndexOfThisSubtask() + 1), and 6 would be RuntimeContext.getNumberOfParallelSubtasks(), and 1 would be RuntimeContext.getAttemptNumber().
getTaskNameWithSubtasks() - 类 中的方法org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
 
getTaskNameWithSubtasks() - 类 中的方法org.apache.flink.api.common.TaskInfo
Returns the name of the task, appended with the subtask indicator, such as "MyTask (3/6)#1", where 3 would be (TaskInfo.getIndexOfThisSubtask() + 1), and 6 would be TaskInfo.getNumberOfParallelSubtasks(), and 1 would be TaskInfo.getAttemptNumber().
getTaskOffHeapMemory() - 类 中的方法org.apache.flink.api.common.operators.ResourceSpec
 
getTaskOffHeapMemory() - 类 中的方法org.apache.flink.api.common.operators.SlotSharingGroup
 
getTebiBytes() - 类 中的方法org.apache.flink.configuration.MemorySize
Gets the memory size in Tebibytes (= 1024 Gibibytes).
getTemplateType(Class<?>, int) - 类 中的静态方法org.apache.flink.util.ReflectionUtil
 
getTemplateType(Class<?>, Class<?>, int) - 类 中的静态方法org.apache.flink.util.ReflectionUtil
 
getTemplateType1(Class<?>) - 类 中的静态方法org.apache.flink.util.ReflectionUtil
 
getTemplateType1(Type) - 类 中的静态方法org.apache.flink.util.ReflectionUtil
 
getTemplateType2(Class<?>) - 类 中的静态方法org.apache.flink.util.ReflectionUtil
 
getTemplateType3(Class<?>) - 类 中的静态方法org.apache.flink.util.ReflectionUtil
 
getTemplateType4(Class<?>) - 类 中的静态方法org.apache.flink.util.ReflectionUtil
 
getTemplateType5(Class<?>) - 类 中的静态方法org.apache.flink.util.ReflectionUtil
 
getTemplateType6(Class<?>) - 类 中的静态方法org.apache.flink.util.ReflectionUtil
 
getTemplateType7(Class<?>) - 类 中的静态方法org.apache.flink.util.ReflectionUtil
 
getTemplateType8(Class<?>) - 类 中的静态方法org.apache.flink.util.ReflectionUtil
 
getTemplateTypeInfos() - 类 中的方法org.apache.flink.util.ReflectionUtil.FullTypeInfo
 
getTemplateTypes(ParameterizedType) - 类 中的静态方法org.apache.flink.util.ReflectionUtil
 
getTemplateTypes(Class<?>) - 类 中的静态方法org.apache.flink.util.ReflectionUtil
 
getTerminationCriterion() - 类 中的方法org.apache.flink.api.common.operators.base.BulkIterationBase
 
getText() - 类 中的方法org.apache.flink.configuration.description.LinkElement
 
getTimestamp() - 类 中的方法org.apache.flink.api.common.eventtime.Watermark
Returns the timestamp associated with this Watermark.
getTo() - 类 中的方法org.apache.flink.api.connector.source.lib.NumberSequenceSource
 
getTo() - 类 中的方法org.apache.flink.util.LongValueSequenceIterator
 
getTo() - 类 中的方法org.apache.flink.util.NumberSequenceIterator
 
getTotalFields() - 类 中的方法org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
 
getTotalFields() - 类 中的方法org.apache.flink.api.common.typeinfo.BasicTypeInfo
 
getTotalFields() - 类 中的方法org.apache.flink.api.common.typeinfo.LocalTimeTypeInfo
 
getTotalFields() - 类 中的方法org.apache.flink.api.common.typeinfo.NothingTypeInfo
 
getTotalFields() - 类 中的方法org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
 
getTotalFields() - 类 中的方法org.apache.flink.api.common.typeinfo.SqlTimeTypeInfo
 
getTotalFields() - 类 中的方法org.apache.flink.api.common.typeinfo.TypeInformation
Gets the number of logical fields in this type.
getTotalFields() - 类 中的方法org.apache.flink.api.java.typeutils.EitherTypeInfo
 
getTotalFields() - 类 中的方法org.apache.flink.api.java.typeutils.EnumTypeInfo
 
getTotalFields() - 类 中的方法org.apache.flink.api.java.typeutils.GenericTypeInfo
 
getTotalFields() - 类 中的方法org.apache.flink.api.java.typeutils.ListTypeInfo
 
getTotalFields() - 类 中的方法org.apache.flink.api.java.typeutils.MapTypeInfo
 
getTotalFields() - 类 中的方法org.apache.flink.api.java.typeutils.MissingTypeInfo
 
getTotalFields() - 类 中的方法org.apache.flink.api.java.typeutils.ObjectArrayTypeInfo
 
getTotalFields() - 类 中的方法org.apache.flink.api.java.typeutils.PojoTypeInfo
 
getTotalFields() - 类 中的方法org.apache.flink.api.java.typeutils.TupleTypeInfoBase
 
getTotalFields() - 类 中的方法org.apache.flink.api.java.typeutils.ValueTypeInfo
 
getTotalInputSize() - 类 中的方法org.apache.flink.api.common.io.FileInputFormat.FileBaseStatistics
Gets the file size.
getTotalInputSize() - 接口 中的方法org.apache.flink.api.common.io.statistics.BaseStatistics
Gets the total size of the input.
getTotalNumberOfOpenStreams() - 类 中的方法org.apache.flink.core.fs.LimitedConnectionsFileSystem
Gets the total number of open streams (input plus output).
getTotalNumberOfSplits() - 类 中的方法org.apache.flink.core.io.GenericInputSplit
 
getTransitivePredecessors() - 类 中的方法org.apache.flink.api.dag.Transformation
Returns all transitive predecessor Transformations of this Transformation.
getTtl() - 类 中的方法org.apache.flink.api.common.state.StateTtlConfig
 
getTtlConfig() - 类 中的方法org.apache.flink.api.common.state.StateDescriptor
 
getTtlTimeCharacteristic() - 类 中的方法org.apache.flink.api.common.state.StateTtlConfig
 
getTupleClass(int) - 类 中的静态方法org.apache.flink.api.java.tuple.Tuple
Gets the class corresponding to the tuple of the given arity (dimensions).
getTupleClass() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.TupleSerializerBase
 
getTupleClass() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.TupleSerializerConfigSnapshot
 
getType(int) - 类 中的方法org.apache.flink.api.common.operators.Ordering
 
getType() - 类 中的方法org.apache.flink.api.common.state.AggregatingStateDescriptor
 
getType() - 类 中的方法org.apache.flink.api.common.state.ListStateDescriptor
 
getType() - 类 中的方法org.apache.flink.api.common.state.MapStateDescriptor
 
getType() - 类 中的方法org.apache.flink.api.common.state.ReducingStateDescriptor
 
getType() - 类 中的方法org.apache.flink.api.common.state.StateDescriptor
 
getType() - 类 中的方法org.apache.flink.api.common.state.ValueStateDescriptor
 
getType() - 类 中的方法org.apache.flink.api.common.typeutils.CompositeType.FlatFieldDescriptor
 
getTypeAt(String) - 类 中的方法org.apache.flink.api.common.typeutils.CompositeType
Returns the type of the (nested) field at the given field expression position.
getTypeAt(int) - 类 中的方法org.apache.flink.api.common.typeutils.CompositeType
Returns the type of the (unnested) field at the given field position.
getTypeAt(String) - 类 中的方法org.apache.flink.api.java.typeutils.PojoTypeInfo
 
getTypeAt(int) - 类 中的方法org.apache.flink.api.java.typeutils.PojoTypeInfo
 
getTypeAt(String) - 类 中的方法org.apache.flink.api.java.typeutils.RowTypeInfo
 
getTypeAt(String) - 类 中的方法org.apache.flink.api.java.typeutils.TupleTypeInfoBase
 
getTypeAt(int) - 类 中的方法org.apache.flink.api.java.typeutils.TupleTypeInfoBase
 
getTypeClass() - 类 中的方法org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
 
getTypeClass() - 类 中的方法org.apache.flink.api.common.typeinfo.BasicTypeInfo
 
getTypeClass() - 类 中的方法org.apache.flink.api.common.typeinfo.LocalTimeTypeInfo
 
getTypeClass() - 类 中的方法org.apache.flink.api.common.typeinfo.NothingTypeInfo
 
getTypeClass() - 类 中的方法org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
 
getTypeClass() - 类 中的方法org.apache.flink.api.common.typeinfo.SqlTimeTypeInfo
 
getTypeClass() - 类 中的方法org.apache.flink.api.common.typeinfo.TypeInformation
Gets the class of the type represented by this type information.
getTypeClass() - 类 中的方法org.apache.flink.api.common.typeutils.CompositeType
Returns the type class of the composite type
getTypeClass() - 类 中的方法org.apache.flink.api.common.typeutils.GenericTypeSerializerConfigSnapshot
 
getTypeClass(S) - 类 中的方法org.apache.flink.api.common.typeutils.GenericTypeSerializerSnapshot
Gets the type class from the corresponding serializer.
getTypeClass() - 类 中的方法org.apache.flink.api.java.typeutils.EitherTypeInfo
 
getTypeClass() - 类 中的方法org.apache.flink.api.java.typeutils.EnumTypeInfo
 
getTypeClass() - 类 中的方法org.apache.flink.api.java.typeutils.GenericTypeInfo
 
getTypeClass() - 类 中的方法org.apache.flink.api.java.typeutils.ListTypeInfo
 
getTypeClass() - 类 中的方法org.apache.flink.api.java.typeutils.MapTypeInfo
 
getTypeClass() - 类 中的方法org.apache.flink.api.java.typeutils.MissingTypeInfo
 
getTypeClass() - 类 中的方法org.apache.flink.api.java.typeutils.ObjectArrayTypeInfo
 
getTypeClass(CopyableValueSerializer) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer.CopyableValueSerializerSnapshot
 
getTypeClass(ValueSerializer) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.ValueSerializer.ValueSerializerSnapshot
 
getTypeClass() - 类 中的方法org.apache.flink.api.java.typeutils.ValueTypeInfo
 
getTypeException() - 类 中的方法org.apache.flink.api.java.typeutils.MissingTypeInfo
 
getTypeHierarchy(List<Type>, Type, Class<?>) - 类 中的静态方法org.apache.flink.api.java.typeutils.TypeExtractionUtils
Traverses the type hierarchy of a type up until a certain stop class is found.
getTypeInfo() - 类 中的方法org.apache.flink.api.common.typeinfo.TypeHint
Gets the type information described by this TypeHint.
getTypeInfo() - 类 中的方法org.apache.flink.util.OutputTag
 
getTypeInfoFactory(Type) - 类 中的静态方法org.apache.flink.api.java.typeutils.TypeExtractor
Returns the type information factory for a type using the factory registry or annotations.
getTypeInfoFactory(Field) - 类 中的静态方法org.apache.flink.api.java.typeutils.TypeExtractor
Returns the type information factory for an annotated field.
getTypeInformation() - 类 中的方法org.apache.flink.api.java.typeutils.PojoField
 
getTypes() - 类 中的方法org.apache.flink.api.common.operators.Ordering
 
getTypeSerializer() - 类 中的方法org.apache.flink.api.common.typeutils.TypeSerializerSerializationUtil.TypeSerializerSerializationProxy
已过时。
 
getUid() - 类 中的方法org.apache.flink.api.dag.Transformation
Returns the user-specified ID of this transformation.
getUnaryOperatorReturnType(Function, Class<?>, int, int, int[], TypeInformation<IN>, String, boolean) - 类 中的静态方法org.apache.flink.api.java.typeutils.TypeExtractor
Returns the unary operator's return type.
getUnchecked() - 类 中的方法org.apache.flink.util.OptionalFailure
 
getUnguardedFileSystem(URI) - 类 中的静态方法org.apache.flink.core.fs.FileSystem
 
getUnionListState(ListStateDescriptor<S>) - 接口 中的方法org.apache.flink.api.common.state.OperatorStateStore
Creates (or restores) a list state.
getUniqueFields() - 类 中的方法org.apache.flink.api.common.operators.CompilerHints
Gets the FieldSets that are unique
getUnit() - 类 中的方法org.apache.flink.api.common.time.Time
Gets the time unit for this policy's time interval.
getUnits() - 枚举 中的方法org.apache.flink.configuration.MemorySize.MemoryUnit
 
getUpdatedSplitForIterator(NumberSequenceIterator) - 类 中的方法org.apache.flink.api.connector.source.lib.NumberSequenceSource.NumberSequenceSplit
 
getUpdatedSplitForIterator(IterT) - 接口 中的方法org.apache.flink.api.connector.source.lib.util.IteratorSourceSplit
Converts an iterator (that may have returned some elements already) back into a source split.
getUpdateType() - 类 中的方法org.apache.flink.api.common.state.StateTtlConfig
 
getUpperPart() - 类 中的方法org.apache.flink.util.AbstractID
Gets the upper 64 bits of the ID.
getUri() - 类 中的方法org.apache.flink.core.fs.FileSystem
Returns a URI whose scheme and authority identify this file system.
getUri() - 类 中的方法org.apache.flink.core.fs.LimitedConnectionsFileSystem
 
getUri() - 类 中的方法org.apache.flink.core.fs.local.LocalFileSystem
 
getUri() - 类 中的方法org.apache.flink.core.fs.SafetyNetWrapperFileSystem
 
getUserCodeAnnotation(Class<A>) - 类 中的方法org.apache.flink.api.common.operators.util.UserCodeClassWrapper
 
getUserCodeAnnotation(Class<A>) - 类 中的方法org.apache.flink.api.common.operators.util.UserCodeObjectWrapper
 
getUserCodeAnnotation(Class<A>) - 接口 中的方法org.apache.flink.api.common.operators.util.UserCodeWrapper
Gets an annotation that pertains to the user code class.
getUserCodeClass() - 类 中的方法org.apache.flink.api.common.operators.util.UserCodeClassWrapper
 
getUserCodeClass() - 类 中的方法org.apache.flink.api.common.operators.util.UserCodeObjectWrapper
 
getUserCodeClass() - 接口 中的方法org.apache.flink.api.common.operators.util.UserCodeWrapper
Gets the class of the user code.
getUserCodeClassLoader() - 接口 中的方法org.apache.flink.api.common.functions.RuntimeContext
Gets the ClassLoader to load classes that are not in system's classpath, but are part of the jar file of a user job.
getUserCodeClassLoader() - 类 中的方法org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
 
getUserCodeClassLoader() - 接口 中的方法org.apache.flink.api.common.serialization.DeserializationSchema.InitializationContext
Gets the UserCodeClassLoader to load classes that are not in system's classpath, but are part of the jar file of a user job.
getUserCodeClassLoader() - 接口 中的方法org.apache.flink.api.common.serialization.SerializationSchema.InitializationContext
Gets the UserCodeClassLoader to load classes that are not in system's classpath, but are part of the jar file of a user job.
getUserCodeClassLoader() - 类 中的方法org.apache.flink.api.common.typeutils.TypeSerializerConfigSnapshot
已过时。
Returns the user code class loader.
getUserCodeClassLoader() - 类 中的方法org.apache.flink.api.connector.sink.InitContextInitializationContextAdapter
 
getUserCodeClassLoader() - 接口 中的方法org.apache.flink.api.connector.sink.Sink.InitContext
Gets the UserCodeClassLoader to load classes that are not in system's classpath, but are part of the jar file of a user job.
getUserCodeClassLoader() - 接口 中的方法org.apache.flink.api.connector.source.SourceReaderContext
Gets the UserCodeClassLoader to load classes that are not in system's classpath, but are part of the jar file of a user job.
getUserCodeObject(Class<? super T>, ClassLoader) - 类 中的方法org.apache.flink.api.common.operators.util.UserCodeClassWrapper
 
getUserCodeObject() - 类 中的方法org.apache.flink.api.common.operators.util.UserCodeClassWrapper
 
getUserCodeObject(Class<? super T>, ClassLoader) - 类 中的方法org.apache.flink.api.common.operators.util.UserCodeObjectWrapper
 
getUserCodeObject() - 类 中的方法org.apache.flink.api.common.operators.util.UserCodeObjectWrapper
 
getUserCodeObject(Class<? super T>, ClassLoader) - 接口 中的方法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() - 接口 中的方法org.apache.flink.api.common.operators.util.UserCodeWrapper
Gets the user code object.
getUserCodeWrapper() - 类 中的方法org.apache.flink.api.common.operators.AbstractUdfOperator
Gets the function that is held by this operator.
getUserCodeWrapper() - 类 中的方法org.apache.flink.api.common.operators.base.BulkIterationBase.PartialSolutionPlaceHolder
 
getUserCodeWrapper() - 类 中的方法org.apache.flink.api.common.operators.base.DeltaIterationBase.SolutionSetPlaceHolder
 
getUserCodeWrapper() - 类 中的方法org.apache.flink.api.common.operators.base.DeltaIterationBase.WorksetPlaceHolder
 
getUserCodeWrapper() - 类 中的方法org.apache.flink.api.common.operators.GenericDataSinkBase
Gets the class describing the output format.
getUserCodeWrapper() - 类 中的方法org.apache.flink.api.common.operators.GenericDataSourceBase
Gets the class describing the input format.
getUserCodeWrapper() - 类 中的方法org.apache.flink.api.common.operators.Operator
Gets the user code wrapper.
getUserProvidedNodeHash() - 类 中的方法org.apache.flink.api.dag.Transformation
Gets the user provided hash.
getValue() - 类 中的方法org.apache.flink.api.common.resources.Resource
 
getValue(ConfigOption<?>) - 类 中的方法org.apache.flink.configuration.Configuration
Returns the value associated with the given config option as a string.
getValue(ConfigOption<?>) - 类 中的方法org.apache.flink.configuration.DelegatingConfiguration
 
getValue() - 类 中的方法org.apache.flink.types.BooleanValue
 
getValue() - 类 中的方法org.apache.flink.types.ByteValue
Returns the value of the encapsulated byte.
getValue() - 类 中的方法org.apache.flink.types.CharValue
Returns the value of the encapsulated char.
getValue() - 类 中的方法org.apache.flink.types.DoubleValue
Returns the value of the encapsulated primitive double.
getValue() - 类 中的方法org.apache.flink.types.FloatValue
Returns the value of the encapsulated primitive float.
getValue() - 类 中的方法org.apache.flink.types.IntValue
Returns the value of the encapsulated int.
getValue() - 类 中的方法org.apache.flink.types.LongValue
Returns the value of the encapsulated long.
getValue() - 类 中的方法org.apache.flink.types.ShortValue
Returns the value of the encapsulated short.
getValue() - 类 中的方法org.apache.flink.types.StringValue
Gets this StringValue as a String.
getValue() - 类 中的方法org.apache.flink.util.LinkedOptionalMap.KeyValue
 
getValues() - 类 中的方法org.apache.flink.api.common.operators.util.ListKeyGroupedIterator
Returns an iterator over all values that belong to the current key.
getValueSerializer() - 类 中的方法org.apache.flink.api.common.state.MapStateDescriptor
Gets the serializer for the values in the state.
getValueSerializer() - 类 中的方法org.apache.flink.api.common.typeutils.base.MapSerializer
 
getValueTypeInfo() - 类 中的方法org.apache.flink.api.java.typeutils.MapTypeInfo
Gets the type information for the values in the map
getVersion() - 类 中的方法org.apache.flink.api.common.typeutils.base.CollectionSerializerConfigSnapshot
已过时。
 
getVersion() - 类 中的方法org.apache.flink.api.common.typeutils.base.EnumSerializer.EnumSerializerConfigSnapshot
已过时。
 
getVersion() - 类 中的方法org.apache.flink.api.common.typeutils.base.MapSerializerConfigSnapshot
已过时。
 
getVersion() - 类 中的方法org.apache.flink.api.common.typeutils.CompositeSerializer.ConfigSnapshot
已过时。
 
getVersion() - 类 中的方法org.apache.flink.api.common.typeutils.ParameterlessTypeSerializerConfig
已过时。
 
getVersion() - 类 中的方法org.apache.flink.api.common.typeutils.TypeSerializerSerializationUtil.TypeSerializerSerializationProxy
已过时。
 
getVersion() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer.CopyableValueSerializerConfigSnapshot
已过时。
 
getVersion() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.EitherSerializerConfigSnapshot
已过时。
 
getVersion() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer.KryoSerializerConfigSnapshot
已过时。
 
getVersion() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.NullableSerializer.NullableSerializerConfigSnapshot
已过时。
 
getVersion() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.PojoSerializer.PojoSerializerConfigSnapshot
已过时。
 
getVersion() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.RowSerializer.RowSerializerConfigSnapshot
已过时。
 
getVersion() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.TupleSerializerConfigSnapshot
 
getVersion() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.ValueSerializer.ValueSerializerConfigSnapshot
已过时。
 
getVersion() - 接口 中的方法org.apache.flink.core.io.SimpleVersionedSerializer
Gets the version with which this serializer serializes.
getVersion() - 接口 中的方法org.apache.flink.core.io.Versioned
Returns the version number of the object.
getWildcardIPAddress() - 类 中的静态方法org.apache.flink.util.NetUtils
Returns the wildcard address to listen on all interfaces.
getWithoutException(CompletableFuture<T>) - 类 中的静态方法org.apache.flink.util.concurrent.FutureUtils
Gets the result of a completable future without any exception thrown.
getWorkingDirectory() - 类 中的方法org.apache.flink.core.fs.FileSystem
Returns the path of the file system's current working directory.
getWorkingDirectory() - 类 中的方法org.apache.flink.core.fs.LimitedConnectionsFileSystem
 
getWorkingDirectory() - 类 中的方法org.apache.flink.core.fs.local.LocalFileSystem
 
getWorkingDirectory() - 类 中的方法org.apache.flink.core.fs.SafetyNetWrapperFileSystem
 
getWorkset() - 类 中的方法org.apache.flink.api.common.operators.base.DeltaIterationBase
Gets the contract that represents the workset for the step function.
getWrappedDelegate() - 类 中的方法org.apache.flink.core.fs.FSDataInputStreamWrapper
 
getWrappedDelegate() - 类 中的方法org.apache.flink.core.fs.FSDataOutputStreamWrapper
 
getWrappedDelegate() - 类 中的方法org.apache.flink.core.fs.SafetyNetWrapperFileSystem
 
getWrappedDelegate() - 接口 中的方法org.apache.flink.util.WrappingProxy
 
getWriteMode() - 类 中的方法org.apache.flink.api.common.io.FileOutputFormat
 
getWriterStateSerializer() - 接口 中的方法org.apache.flink.api.connector.sink.Sink
Any stateful sink needs to provide this state serializer and implement SinkWriter.snapshotState(long) properly.
GLOBAL_JOB_PARAMETERS - 类 中的静态变量org.apache.flink.configuration.PipelineOptions
 
GlobalCommitter<CommT,GlobalCommT> - org.apache.flink.api.connector.sink中的接口
The GlobalCommitter is responsible for creating and committing an aggregated committable, which we call global committable (see combine(java.util.List<CommT>)).
GlobalConfiguration - org.apache.flink.configuration中的类
Global configuration object for Flink.
GlobalJobParameters() - 类 的构造器org.apache.flink.api.common.ExecutionConfig.GlobalJobParameters
 
GlobFilePathFilter - org.apache.flink.api.common.io中的类
Class for determining if a particular file should be included or excluded based on a set of include and exclude glob filters.
GlobFilePathFilter() - 类 的构造器org.apache.flink.api.common.io.GlobFilePathFilter
Constructor for GlobFilePathFilter that will match all files
GlobFilePathFilter(List<String>, List<String>) - 类 的构造器org.apache.flink.api.common.io.GlobFilePathFilter
Constructor for GlobFilePathFilter
gracefulShutdown(long, TimeUnit, ExecutorService...) - 类 中的静态方法org.apache.flink.util.ExecutorUtils
Gracefully shutdown the given ExecutorService.
GroupCombineFunction<IN,OUT> - org.apache.flink.api.common.functions中的接口
Generic interface used for combine functions ("combiners").
GroupCombineOperatorBase<IN,OUT,FT extends GroupCombineFunction<IN,OUT>> - org.apache.flink.api.common.operators.base中的类
Base operator for the combineGroup transformation.
GroupCombineOperatorBase(FT, UnaryOperatorInformation<IN, OUT>, int[], String) - 类 的构造器org.apache.flink.api.common.operators.base.GroupCombineOperatorBase
 
GroupReduceFunction<T,O> - org.apache.flink.api.common.functions中的接口
The interface for group reduce functions.
GroupReduceOperatorBase<IN,OUT,FT extends GroupReduceFunction<IN,OUT>> - org.apache.flink.api.common.operators.base中的类
 
GroupReduceOperatorBase(UserCodeWrapper<FT>, UnaryOperatorInformation<IN, OUT>, int[], String) - 类 的构造器org.apache.flink.api.common.operators.base.GroupReduceOperatorBase
 
GroupReduceOperatorBase(FT, UnaryOperatorInformation<IN, OUT>, int[], String) - 类 的构造器org.apache.flink.api.common.operators.base.GroupReduceOperatorBase
 
GroupReduceOperatorBase(Class<? extends FT>, UnaryOperatorInformation<IN, OUT>, int[], String) - 类 的构造器org.apache.flink.api.common.operators.base.GroupReduceOperatorBase
 
GroupReduceOperatorBase(UserCodeWrapper<FT>, UnaryOperatorInformation<IN, OUT>, String) - 类 的构造器org.apache.flink.api.common.operators.base.GroupReduceOperatorBase
 
GroupReduceOperatorBase(FT, UnaryOperatorInformation<IN, OUT>, String) - 类 的构造器org.apache.flink.api.common.operators.base.GroupReduceOperatorBase
 
GroupReduceOperatorBase(Class<? extends FT>, UnaryOperatorInformation<IN, OUT>, String) - 类 的构造器org.apache.flink.api.common.operators.base.GroupReduceOperatorBase
 
groupsFields(FieldSet) - 类 中的方法org.apache.flink.api.common.operators.Ordering
 
GuavaFlinkConnectorRateLimiter - org.apache.flink.api.common.io.ratelimiting中的类
An implementation of FlinkConnectorRateLimiter that uses Guava's RateLimiter for rate limiting.
GuavaFlinkConnectorRateLimiter() - 类 的构造器org.apache.flink.api.common.io.ratelimiting.GuavaFlinkConnectorRateLimiter
 
GzipInflaterInputStreamFactory - org.apache.flink.api.common.io.compression中的类
Factory for input streams that decompress the GZIP compression format.
GzipInflaterInputStreamFactory() - 类 的构造器org.apache.flink.api.common.io.compression.GzipInflaterInputStreamFactory
 

H

HA_CLUSTER_ID - 类 中的静态变量org.apache.flink.configuration.HighAvailabilityOptions
The ID of the Flink cluster, used to separate multiple Flink clusters Needs to be set for standalone clusters, is automatically inferred in YARN.
HA_JOB_DELAY - 类 中的静态变量org.apache.flink.configuration.HighAvailabilityOptions
已过时。
Don't use this option anymore. It has no effect on Flink.
HA_JOB_MANAGER_PORT - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
Ports used by the job manager if not in 'none' recovery mode.
HA_JOB_MANAGER_PORT_RANGE - 类 中的静态变量org.apache.flink.configuration.HighAvailabilityOptions
Optional port (range) used by the job manager in high-availability mode.
HA_MODE - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
Deprecated in favour of HighAvailabilityOptions.HA_MODE
HA_MODE - 类 中的静态变量org.apache.flink.configuration.HighAvailabilityOptions
Defines high-availability mode used for the cluster execution.
HA_STORAGE_PATH - 类 中的静态变量org.apache.flink.configuration.HighAvailabilityOptions
File system path (URI) where Flink persists metadata in high-availability setups.
HA_ZOOKEEPER_CHECKPOINT_COUNTER_PATH - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
no longer used.
HA_ZOOKEEPER_CHECKPOINTS_PATH - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
no longer used.
HA_ZOOKEEPER_CLIENT_ACL - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
HA_ZOOKEEPER_CONNECTION_TIMEOUT - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
HA_ZOOKEEPER_DIR_KEY - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
HA_ZOOKEEPER_JOBGRAPHS_PATH - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
HA_ZOOKEEPER_JOBGRAPHS_PATH - 类 中的静态变量org.apache.flink.configuration.HighAvailabilityOptions
ZooKeeper root path (ZNode) for job graphs.
HA_ZOOKEEPER_LATCH_PATH - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
no longer used.
HA_ZOOKEEPER_LEADER_PATH - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
no longer used.
HA_ZOOKEEPER_MAX_RETRY_ATTEMPTS - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
HA_ZOOKEEPER_MESOS_WORKERS_PATH - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
has no effect
HA_ZOOKEEPER_NAMESPACE_KEY - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
HA_ZOOKEEPER_QUORUM - 类 中的静态变量org.apache.flink.configuration.HighAvailabilityOptions
The ZooKeeper quorum to use, when running Flink in a high-availability mode with ZooKeeper.
HA_ZOOKEEPER_QUORUM_KEY - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
HA_ZOOKEEPER_RETRY_WAIT - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
HA_ZOOKEEPER_ROOT - 类 中的静态变量org.apache.flink.configuration.HighAvailabilityOptions
The root path under which Flink stores its entries in ZooKeeper.
HA_ZOOKEEPER_SESSION_TIMEOUT - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
HA_ZOOKEEPER_STORAGE_PATH - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
HADOOP_COPYING - 类 中的静态变量org.apache.flink.api.common.io.FilePathFilter
Name of an unfinished Hadoop file
HALT_ON_FATAL_ERROR - 类 中的静态变量org.apache.flink.configuration.ClusterOptions
 
handleAsyncIfNotDone(CompletableFuture<IN>, Executor, BiFunction<? super IN, Throwable, ? extends OUT>) - 类 中的静态方法org.apache.flink.util.concurrent.FutureUtils
This function takes a CompletableFuture and a handler function for the result of this future.
handleException(CompletableFuture<? extends T>, Class<E>, Function<? super E, ? extends T>) - 类 中的静态方法org.apache.flink.util.concurrent.FutureUtils
Checks that the given CompletableFuture is not completed exceptionally with the specified class.
handleSourceEvent(int, SourceEvent) - 接口 中的方法org.apache.flink.api.connector.source.SplitEnumerator
Handles a custom source event from the source reader.
handleSourceEvents(SourceEvent) - 接口 中的方法org.apache.flink.api.connector.source.SourceReader
Handle a custom source event sent by the SplitEnumerator.
handleSplitRequest(int, String) - 类 中的方法org.apache.flink.api.connector.source.lib.util.IteratorSourceEnumerator
 
handleSplitRequest(int, String) - 接口 中的方法org.apache.flink.api.connector.source.SplitEnumerator
Handles the request for a split.
handleUncaughtException(CompletableFuture<?>, Thread.UncaughtExceptionHandler) - 类 中的静态方法org.apache.flink.util.concurrent.FutureUtils
Checks that the given CompletableFuture is not completed exceptionally.
hasAbsentKeysOrValues() - 类 中的方法org.apache.flink.util.LinkedOptionalMap
Checks whether there are entries with absent keys or values.
hasAutoGeneratedUIDsEnabled() - 类 中的方法org.apache.flink.api.common.ExecutionConfig
Checks whether auto generated UIDs are supported.
hasBroadcastVariable(String) - 接口 中的方法org.apache.flink.api.common.functions.RuntimeContext
Tests for the existence of the broadcast variable identified by the given name.
hasBroadcastVariable(String) - 类 中的方法org.apache.flink.api.common.functions.util.RuntimeUDFContext
 
hasDefaultValue() - 类 中的方法org.apache.flink.configuration.ConfigOption
Checks if this option has a default value.
hasDeprecatedKeys() - 类 中的方法org.apache.flink.configuration.ConfigOption
已过时。
hasDeterministicFieldOrder() - 类 中的方法org.apache.flink.api.common.typeutils.CompositeType
True if this type has an inherent ordering of the fields, such that a user can always be sure in which order the fields will be in.
hasDeterministicFieldOrder() - 类 中的方法org.apache.flink.api.java.typeutils.TupleTypeInfoBase
 
hasFallbackKeys() - 类 中的方法org.apache.flink.configuration.ConfigOption
Checks whether this option has fallback keys.
hasField(String) - 类 中的方法org.apache.flink.api.common.typeutils.CompositeType
Returns true when this type has a composite field with the given name.
hasGenericTypesDisabled() - 类 中的方法org.apache.flink.api.common.ExecutionConfig
Checks whether generic types are supported.
hash(boolean[]) - 类 中的方法org.apache.flink.api.common.typeutils.base.array.BooleanPrimitiveArrayComparator
 
hash(byte[]) - 类 中的方法org.apache.flink.api.common.typeutils.base.array.BytePrimitiveArrayComparator
 
hash(char[]) - 类 中的方法org.apache.flink.api.common.typeutils.base.array.CharPrimitiveArrayComparator
 
hash(double[]) - 类 中的方法org.apache.flink.api.common.typeutils.base.array.DoublePrimitiveArrayComparator
 
hash(float[]) - 类 中的方法org.apache.flink.api.common.typeutils.base.array.FloatPrimitiveArrayComparator
 
hash(int[]) - 类 中的方法org.apache.flink.api.common.typeutils.base.array.IntPrimitiveArrayComparator
 
hash(long[]) - 类 中的方法org.apache.flink.api.common.typeutils.base.array.LongPrimitiveArrayComparator
 
hash(short[]) - 类 中的方法org.apache.flink.api.common.typeutils.base.array.ShortPrimitiveArrayComparator
 
hash(T) - 类 中的方法org.apache.flink.api.common.typeutils.base.BasicTypeComparator
 
hash(BooleanValue) - 类 中的方法org.apache.flink.api.common.typeutils.base.BooleanValueComparator
 
hash(ByteValue) - 类 中的方法org.apache.flink.api.common.typeutils.base.ByteValueComparator
 
hash(CharValue) - 类 中的方法org.apache.flink.api.common.typeutils.base.CharValueComparator
 
hash(DoubleValue) - 类 中的方法org.apache.flink.api.common.typeutils.base.DoubleValueComparator
 
hash(FloatValue) - 类 中的方法org.apache.flink.api.common.typeutils.base.FloatValueComparator
 
hash(IntValue) - 类 中的方法org.apache.flink.api.common.typeutils.base.IntValueComparator
 
hash(LocalDate) - 类 中的方法org.apache.flink.api.common.typeutils.base.LocalDateComparator
 
hash(LocalDateTime) - 类 中的方法org.apache.flink.api.common.typeutils.base.LocalDateTimeComparator
 
hash(LongValue) - 类 中的方法org.apache.flink.api.common.typeutils.base.LongValueComparator
 
hash(NullValue) - 类 中的方法org.apache.flink.api.common.typeutils.base.NullValueComparator
 
hash(ShortValue) - 类 中的方法org.apache.flink.api.common.typeutils.base.ShortValueComparator
 
hash(StringValue) - 类 中的方法org.apache.flink.api.common.typeutils.base.StringValueComparator
 
hash(T) - 类 中的方法org.apache.flink.api.common.typeutils.TypeComparator
Computes a hash value for the given record.
hash(T) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.CopyableValueComparator
 
hash(T) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.GenericTypeComparator
 
hash(T) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.NullAwareComparator
 
hash(T) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.PojoComparator
 
hash(Row) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.RowComparator
 
hash(T) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.TupleComparator
 
hash(T) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.ValueComparator
 
HASH_JOIN_BLOOM_FILTERS - 类 中的静态变量org.apache.flink.configuration.AlgorithmOptions
 
HASH_SALT - 类 中的静态变量org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
A sequence of prime numbers to be used for salting the computed hash values.
hashCode() - 类 中的方法org.apache.flink.api.common.cache.DistributedCache.DistributedCacheEntry
 
hashCode() - 类 中的方法org.apache.flink.api.common.eventtime.Watermark
 
hashCode() - 类 中的方法org.apache.flink.api.common.ExecutionConfig.GlobalJobParameters
 
hashCode() - 类 中的方法org.apache.flink.api.common.ExecutionConfig
 
hashCode() - 类 中的方法org.apache.flink.api.common.operators.Ordering
 
hashCode() - 类 中的方法org.apache.flink.api.common.operators.ResourceSpec
 
hashCode() - 类 中的方法org.apache.flink.api.common.operators.SlotSharingGroup
 
hashCode() - 类 中的方法org.apache.flink.api.common.operators.util.FieldSet
 
hashCode() - 类 中的方法org.apache.flink.api.common.operators.util.TypeComparable
 
hashCode() - 类 中的方法org.apache.flink.api.common.resources.Resource
 
hashCode() - 类 中的方法org.apache.flink.api.common.restartstrategy.RestartStrategies.ExponentialDelayRestartStrategyConfiguration
 
hashCode() - 类 中的方法org.apache.flink.api.common.restartstrategy.RestartStrategies.FailureRateRestartStrategyConfiguration
 
hashCode() - 类 中的方法org.apache.flink.api.common.restartstrategy.RestartStrategies.FallbackRestartStrategyConfiguration
 
hashCode() - 类 中的方法org.apache.flink.api.common.restartstrategy.RestartStrategies.FixedDelayRestartStrategyConfiguration
 
hashCode() - 类 中的方法org.apache.flink.api.common.restartstrategy.RestartStrategies.NoRestartStrategyConfiguration
 
hashCode() - 类 中的方法org.apache.flink.api.common.state.StateDescriptor
 
hashCode() - 类 中的方法org.apache.flink.api.common.time.Time
 
hashCode() - 类 中的方法org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
 
hashCode() - 类 中的方法org.apache.flink.api.common.typeinfo.BasicTypeInfo
 
hashCode() - 类 中的方法org.apache.flink.api.common.typeinfo.LocalTimeTypeInfo
 
hashCode() - 类 中的方法org.apache.flink.api.common.typeinfo.NothingTypeInfo
 
hashCode() - 类 中的方法org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
 
hashCode() - 类 中的方法org.apache.flink.api.common.typeinfo.SqlTimeTypeInfo
 
hashCode() - 类 中的方法org.apache.flink.api.common.typeinfo.TypeHint
 
hashCode() - 类 中的方法org.apache.flink.api.common.typeinfo.TypeInformation
 
hashCode() - 类 中的方法org.apache.flink.api.common.typeutils.BackwardsCompatibleSerializerSnapshot
 
hashCode() - 类 中的方法org.apache.flink.api.common.typeutils.base.EnumSerializer.EnumSerializerConfigSnapshot
已过时。
 
hashCode() - 类 中的方法org.apache.flink.api.common.typeutils.base.EnumSerializer
 
hashCode() - 类 中的方法org.apache.flink.api.common.typeutils.base.GenericArraySerializer
 
hashCode() - 类 中的方法org.apache.flink.api.common.typeutils.base.ListSerializer
 
hashCode() - 类 中的方法org.apache.flink.api.common.typeutils.base.MapSerializer
 
hashCode() - 类 中的方法org.apache.flink.api.common.typeutils.base.TypeSerializerSingleton
 
hashCode() - 类 中的方法org.apache.flink.api.common.typeutils.CompositeSerializer
 
hashCode() - 类 中的方法org.apache.flink.api.common.typeutils.CompositeType
 
hashCode() - 类 中的方法org.apache.flink.api.common.typeutils.CompositeTypeSerializerConfigSnapshot
 
hashCode() - 类 中的方法org.apache.flink.api.common.typeutils.GenericTypeSerializerConfigSnapshot
 
hashCode() - 类 中的方法org.apache.flink.api.common.typeutils.ParameterlessTypeSerializerConfig
已过时。
 
hashCode() - 类 中的方法org.apache.flink.api.common.typeutils.SimpleTypeSerializerSnapshot
 
hashCode() - 类 中的方法org.apache.flink.api.common.typeutils.SingleThreadAccessCheckingTypeSerializer
 
hashCode() - 类 中的方法org.apache.flink.api.common.typeutils.TypeSerializer
 
hashCode() - 类 中的方法org.apache.flink.api.common.typeutils.UnloadableDummyTypeSerializer
 
hashCode() - 类 中的方法org.apache.flink.api.connector.source.ReaderInfo
 
hashCode() - 类 中的方法org.apache.flink.api.dag.Transformation
 
hashCode() - 类 中的方法org.apache.flink.api.java.tuple.Tuple0
 
hashCode() - 类 中的方法org.apache.flink.api.java.tuple.Tuple1
 
hashCode() - 类 中的方法org.apache.flink.api.java.tuple.Tuple10
 
hashCode() - 类 中的方法org.apache.flink.api.java.tuple.Tuple11
 
hashCode() - 类 中的方法org.apache.flink.api.java.tuple.Tuple12
 
hashCode() - 类 中的方法org.apache.flink.api.java.tuple.Tuple13
 
hashCode() - 类 中的方法org.apache.flink.api.java.tuple.Tuple14
 
hashCode() - 类 中的方法org.apache.flink.api.java.tuple.Tuple15
 
hashCode() - 类 中的方法org.apache.flink.api.java.tuple.Tuple16
 
hashCode() - 类 中的方法org.apache.flink.api.java.tuple.Tuple17
 
hashCode() - 类 中的方法org.apache.flink.api.java.tuple.Tuple18
 
hashCode() - 类 中的方法org.apache.flink.api.java.tuple.Tuple19
 
hashCode() - 类 中的方法org.apache.flink.api.java.tuple.Tuple2
 
hashCode() - 类 中的方法org.apache.flink.api.java.tuple.Tuple20
 
hashCode() - 类 中的方法org.apache.flink.api.java.tuple.Tuple21
 
hashCode() - 类 中的方法org.apache.flink.api.java.tuple.Tuple22
 
hashCode() - 类 中的方法org.apache.flink.api.java.tuple.Tuple23
 
hashCode() - 类 中的方法org.apache.flink.api.java.tuple.Tuple24
 
hashCode() - 类 中的方法org.apache.flink.api.java.tuple.Tuple25
 
hashCode() - 类 中的方法org.apache.flink.api.java.tuple.Tuple3
 
hashCode() - 类 中的方法org.apache.flink.api.java.tuple.Tuple4
 
hashCode() - 类 中的方法org.apache.flink.api.java.tuple.Tuple5
 
hashCode() - 类 中的方法org.apache.flink.api.java.tuple.Tuple6
 
hashCode() - 类 中的方法org.apache.flink.api.java.tuple.Tuple7
 
hashCode() - 类 中的方法org.apache.flink.api.java.tuple.Tuple8
 
hashCode() - 类 中的方法org.apache.flink.api.java.tuple.Tuple9
 
hashCode() - 类 中的方法org.apache.flink.api.java.typeutils.EitherTypeInfo
 
hashCode() - 类 中的方法org.apache.flink.api.java.typeutils.EnumTypeInfo
 
hashCode() - 类 中的方法org.apache.flink.api.java.typeutils.GenericTypeInfo
 
hashCode() - 类 中的方法org.apache.flink.api.java.typeutils.ListTypeInfo
 
hashCode() - 类 中的方法org.apache.flink.api.java.typeutils.MapTypeInfo
 
hashCode() - 类 中的方法org.apache.flink.api.java.typeutils.MissingTypeInfo
 
hashCode() - 类 中的方法org.apache.flink.api.java.typeutils.MultisetTypeInfo
 
hashCode() - 类 中的方法org.apache.flink.api.java.typeutils.ObjectArrayTypeInfo
 
hashCode() - 类 中的方法org.apache.flink.api.java.typeutils.PojoField
 
hashCode() - 类 中的方法org.apache.flink.api.java.typeutils.PojoTypeInfo
 
hashCode() - 类 中的方法org.apache.flink.api.java.typeutils.RowTypeInfo
 
hashCode() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer
 
hashCode() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.EitherSerializer
 
hashCode() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer
 
hashCode() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.KryoRegistration
 
hashCode() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.KryoRegistrationSerializerConfigSnapshot
 
hashCode() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.NullableSerializer
 
hashCode() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.PojoSerializer
 
hashCode() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.PojoSerializer.PojoSerializerConfigSnapshot
已过时。
 
hashCode() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.RowSerializer
 
hashCode() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.RuntimeSerializerFactory
 
hashCode() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.Tuple0Serializer
 
hashCode() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.TupleSerializerBase
 
hashCode() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.TupleSerializerConfigSnapshot
 
hashCode() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.ValueSerializer
 
hashCode() - 类 中的方法org.apache.flink.api.java.typeutils.TupleTypeInfo
 
hashCode() - 类 中的方法org.apache.flink.api.java.typeutils.TupleTypeInfoBase
 
hashCode() - 类 中的方法org.apache.flink.api.java.typeutils.ValueTypeInfo
 
hashCode() - 类 中的方法org.apache.flink.configuration.ConfigOption
 
hashCode() - 类 中的方法org.apache.flink.configuration.Configuration
 
hashCode() - 类 中的方法org.apache.flink.configuration.DelegatingConfiguration
 
hashCode() - 类 中的方法org.apache.flink.configuration.FallbackKey
 
hashCode() - 类 中的方法org.apache.flink.configuration.MemorySize
 
hashCode() - 类 中的方法org.apache.flink.core.fs.ClosingFSDataInputStream
 
hashCode() - 类 中的方法org.apache.flink.core.fs.ClosingFSDataOutputStream
 
hashCode() - 类 中的方法org.apache.flink.core.fs.FileInputSplit
 
hashCode() - 类 中的方法org.apache.flink.core.fs.Path
 
hashCode() - 类 中的方法org.apache.flink.core.io.GenericInputSplit
 
hashCode() - 类 中的方法org.apache.flink.core.io.LocatableInputSplit
 
hashCode() - 类 中的方法org.apache.flink.core.io.SimpleVersionedSerializerTypeSerializerProxy
 
hashCode() - 类 中的方法org.apache.flink.types.BooleanValue
 
hashCode() - 类 中的方法org.apache.flink.types.ByteValue
 
hashCode() - 类 中的方法org.apache.flink.types.CharValue
 
hashCode() - 类 中的方法org.apache.flink.types.DoubleValue
 
hashCode() - 类 中的方法org.apache.flink.types.Either.Left
 
hashCode() - 类 中的方法org.apache.flink.types.Either.Right
 
hashCode() - 类 中的方法org.apache.flink.types.FloatValue
 
hashCode() - 类 中的方法org.apache.flink.types.IntValue
 
hashCode() - 接口 中的方法org.apache.flink.types.Key
已过时。
All keys must override the hash-code function to generate proper deterministic hash codes, based on their contents.
hashCode() - 类 中的方法org.apache.flink.types.ListValue
 
hashCode() - 类 中的方法org.apache.flink.types.LongValue
 
hashCode() - 类 中的方法org.apache.flink.types.MapValue
 
hashCode() - 类 中的方法org.apache.flink.types.NullValue
 
hashCode() - 类 中的方法org.apache.flink.types.Row
 
hashCode() - 类 中的方法org.apache.flink.types.ShortValue
 
hashCode() - 类 中的方法org.apache.flink.types.StringValue
 
hashCode() - 类 中的方法org.apache.flink.util.AbstractID
 
hashCode() - 类 中的方法org.apache.flink.util.OptionalFailure
 
hashCode() - 类 中的方法org.apache.flink.util.OutputTag
 
hashCode() - 类 中的方法org.apache.flink.util.SerializedValue
 
hashCode() - 类 中的方法org.apache.flink.util.StringBasedID
 
hasMissingKeys() - 类 中的方法org.apache.flink.util.LinkedOptionalMap.MergeResult
 
hasNext() - 类 中的方法org.apache.flink.api.common.functions.util.CopyingIterator
 
hasNext() - 类 中的方法org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase.SimpleListIterable.SimpleListIterator
 
hasNext() - 类 中的方法org.apache.flink.api.common.operators.util.ListKeyGroupedIterator.ValuesIterator
 
hasNext() - 类 中的方法org.apache.flink.util.CloseableIterator.IteratorAdapter
 
hasNext() - 类 中的方法org.apache.flink.util.LongValueSequenceIterator
 
hasNext() - 类 中的方法org.apache.flink.util.NumberSequenceIterator
 
hasNext() - 类 中的方法org.apache.flink.util.UnionIterator
 
hasObject() - 类 中的方法org.apache.flink.api.common.operators.util.UserCodeClassWrapper
 
hasObject() - 类 中的方法org.apache.flink.api.common.operators.util.UserCodeObjectWrapper
 
hasObject() - 接口 中的方法org.apache.flink.api.common.operators.util.UserCodeWrapper
Checks whether the wrapper already has an object, or whether it needs to instantiate it.
hasPublicNullaryConstructor(Class<?>) - 类 中的静态方法org.apache.flink.util.InstantiationUtil
Checks, whether the given class has a public nullary constructor.
hasSuperclass(Class<?>, String) - 类 中的静态方法org.apache.flink.api.java.typeutils.TypeExtractionUtils
Returns true if the given class has a superclass of given name.
hasTimeLeft() - 类 中的方法org.apache.flink.api.common.time.Deadline
Returns whether there is any time left between the deadline and now.
hasUnit(String) - 枚举 中的静态方法org.apache.flink.configuration.MemorySize.MemoryUnit
 
hasWindowsDrive() - 类 中的方法org.apache.flink.core.fs.Path
Checks if the provided path string contains a windows drive letter.
HDFS_DEFAULT_CONFIG - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
Use environment variable HADOOP_CONF_DIR instead.
HDFS_SITE_CONFIG - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
Use environment variable HADOOP_CONF_DIR instead.
HEARTBEAT_INTERVAL - 类 中的静态变量org.apache.flink.configuration.HeartbeatManagerOptions
Time interval for requesting heartbeat from sender side.
HEARTBEAT_RPC_FAILURE_THRESHOLD - 类 中的静态变量org.apache.flink.configuration.HeartbeatManagerOptions
 
HEARTBEAT_TIMEOUT - 类 中的静态变量org.apache.flink.configuration.HeartbeatManagerOptions
Timeout for requesting and receiving heartbeat for both sender and receiver sides.
HeartbeatManagerOptions - org.apache.flink.configuration中的类
The set of configuration options relating to heartbeat manager settings.
hexStringToByte(String) - 类 中的静态方法org.apache.flink.util.StringUtils
Given a hex string this will return the byte array corresponding to the string .
HIDDEN_CONTENT - 类 中的静态变量org.apache.flink.configuration.GlobalConfiguration
 
hideSensitiveValues(Map<String, String>) - 类 中的静态方法org.apache.flink.configuration.ConfigurationUtils
Replaces values whose keys are sensitive according to GlobalConfiguration.isSensitive(String) with GlobalConfiguration.HIDDEN_CONTENT.
HighAvailabilityOptions - org.apache.flink.configuration中的类
The set of configuration options relating to high-availability settings.
Histogram - org.apache.flink.api.common.accumulators中的类
Histogram accumulator, which builds a histogram in a distributed manner.
Histogram() - 类 的构造器org.apache.flink.api.common.accumulators.Histogram
 
HISTORY_SERVER_ARCHIVE_DIRS - 类 中的静态变量org.apache.flink.configuration.HistoryServerOptions
Comma-separated list of directories which the HistoryServer polls for new archives.
HISTORY_SERVER_ARCHIVE_REFRESH_INTERVAL - 类 中的静态变量org.apache.flink.configuration.HistoryServerOptions
The interval at which the HistoryServer polls HistoryServerOptions.HISTORY_SERVER_ARCHIVE_DIRS for new archives.
HISTORY_SERVER_CLEANUP_EXPIRED_JOBS - 类 中的静态变量org.apache.flink.configuration.HistoryServerOptions
If this option is enabled then deleted job archives are also deleted from HistoryServer.
HISTORY_SERVER_RETAINED_JOBS - 类 中的静态变量org.apache.flink.configuration.HistoryServerOptions
 
HISTORY_SERVER_WEB_ADDRESS - 类 中的静态变量org.apache.flink.configuration.HistoryServerOptions
The address under which the HistoryServer web-frontend is accessible.
HISTORY_SERVER_WEB_DIR - 类 中的静态变量org.apache.flink.configuration.HistoryServerOptions
The local directory used by the HistoryServer web-frontend.
HISTORY_SERVER_WEB_PORT - 类 中的静态变量org.apache.flink.configuration.HistoryServerOptions
The port under which the HistoryServer web-frontend is accessible.
HISTORY_SERVER_WEB_REFRESH_INTERVAL - 类 中的静态变量org.apache.flink.configuration.HistoryServerOptions
The refresh interval for the HistoryServer web-frontend in milliseconds.
HISTORY_SERVER_WEB_SSL_ENABLED - 类 中的静态变量org.apache.flink.configuration.HistoryServerOptions
Enables/Disables SSL support for the HistoryServer web-frontend.
HistoryServerOptions - org.apache.flink.configuration中的类
The set of configuration options relating to the HistoryServer.
HOST - 类 中的静态变量org.apache.flink.configuration.TaskManagerOptions
The external address of the network interface where the TaskManager is exposed.
HOST_BIND_POLICY - 类 中的静态变量org.apache.flink.configuration.TaskManagerOptions
The config parameter for automatically defining the TaskManager's binding address, if TaskManagerOptions.HOST configuration option is not set.
hostAndPortToUrlString(String, int) - 类 中的静态方法org.apache.flink.util.NetUtils
Normalizes and encodes a hostname and port to be included in URL.
hours(long) - 类 中的静态方法org.apache.flink.api.common.time.Time
Creates a new Time that represents the given number of hours.
HtmlFormatter - org.apache.flink.configuration.description中的类
Formatter that transforms Description into Html representation.
HtmlFormatter() - 类 的构造器org.apache.flink.configuration.description.HtmlFormatter
 

I

id - 类 中的变量org.apache.flink.api.dag.Transformation
 
idCounter - 类 中的静态变量org.apache.flink.api.dag.Transformation
 
IDLENESS_TIMEOUT - 类 中的静态变量org.apache.flink.configuration.RestOptions
The maximum time in ms for a connection to stay idle before failing.
ifNotPresent(ThrowingRunnable<E>) - 类 中的方法org.apache.flink.util.OptionalConsumer
 
ifPresent(Consumer<? super T>) - 类 中的方法org.apache.flink.types.SerializableOptional
 
ifPresent(Consumer<T>) - 类 中的方法org.apache.flink.util.OptionalConsumer
 
ignoreFn() - 类 中的静态方法org.apache.flink.util.function.FunctionUtils
Consumer which ignores the input.
IllegalConfigurationException - org.apache.flink.configuration中的异常错误
An IllegalConfigurationException is thrown when the values in a given Configuration are not valid.
IllegalConfigurationException(String) - 异常错误 的构造器org.apache.flink.configuration.IllegalConfigurationException
Constructs an new IllegalConfigurationException with the given error message.
IllegalConfigurationException(String, Object...) - 异常错误 的构造器org.apache.flink.configuration.IllegalConfigurationException
Constructs an new IllegalConfigurationException with the given error message format and arguments.
IllegalConfigurationException(String, Throwable) - 异常错误 的构造器org.apache.flink.configuration.IllegalConfigurationException
Constructs an new IllegalConfigurationException with the given error message and a given cause.
immutableEntries() - 接口 中的方法org.apache.flink.api.common.state.ReadOnlyBroadcastState
Returns an immutable Iterable over the entries in the state.
incompatible() - 类 中的静态方法org.apache.flink.api.common.typeutils.TypeSerializerSchemaCompatibility
Returns a result that indicates there is no possible way for the new serializer to be use-able.
IncompatibleKeysException(String) - 异常错误 的构造器org.apache.flink.api.common.operators.Keys.IncompatibleKeysException
 
IncompatibleKeysException(TypeInformation<?>, TypeInformation<?>) - 异常错误 的构造器org.apache.flink.api.common.operators.Keys.IncompatibleKeysException
 
INCREMENTAL_CHECKPOINTS - 类 中的静态变量org.apache.flink.configuration.CheckpointingOptions
Option whether the state backend should create incremental checkpoints, if possible.
IndexedCombinedWatermarkStatus - org.apache.flink.api.common.eventtime中的类
Represents combined value and status of a watermark for a set number of input partial watermarks.
indexes - 类 中的变量org.apache.flink.api.common.operators.Ordering
 
indexOf(Object) - 类 中的方法org.apache.flink.types.ListValue
 
INFLATER_INPUT_STREAM_FACTORIES - 类 中的静态变量org.apache.flink.api.common.io.FileInputFormat
A mapping of file extensions to decompression algorithms based on DEFLATE.
InflaterInputStreamFactory<T extends InputStream> - org.apache.flink.api.common.io.compression中的接口
Creates a new instance of a certain subclass of InflaterInputStream.
inFullSnapshot() - 类 中的方法org.apache.flink.api.common.state.StateTtlConfig.CleanupStrategies
 
IngestionTimeAssigner<T> - org.apache.flink.api.common.eventtime中的类
A timestamp assigner that assigns timestamps based on the machine's wall clock.
IngestionTimeAssigner() - 类 的构造器org.apache.flink.api.common.eventtime.IngestionTimeAssigner
 
InitContextInitializationContextAdapter - org.apache.flink.api.connector.sink中的类
Adapter between Sink.InitContext and SerializationSchema.InitializationContext.
InitContextInitializationContextAdapter(UserCodeClassLoader, Supplier<MetricGroup>) - 类 的构造器org.apache.flink.api.connector.sink.InitContextInitializationContextAdapter
 
initDefaultsFromConfiguration(Configuration) - 类 中的静态方法org.apache.flink.api.common.io.FileOutputFormat
Initialize defaults for output format.
INITIAL_REGISTRATION_BACKOFF - 类 中的静态变量org.apache.flink.configuration.TaskManagerOptions
INITIAL_REGISTRATION_TIMEOUT - 类 中的静态变量org.apache.flink.configuration.ClusterOptions
 
initialize(Configuration) - 类 中的静态方法org.apache.flink.core.fs.FileSystem
initialize(Configuration, PluginManager) - 类 中的静态方法org.apache.flink.core.fs.FileSystem
Initializes the shared file system settings.
initializeBroadcastVariable(Iterable<T>) - 接口 中的方法org.apache.flink.api.common.functions.BroadcastVariableInitializer
The method that reads the data elements from the broadcast variable and creates the transformed data structure.
initializeFields(T) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.PojoSerializer
 
initializeGlobal(int) - 类 中的方法org.apache.flink.api.common.io.FileOutputFormat
Initialization of the distributed file system if it is used.
initializeGlobal(int) - 接口 中的方法org.apache.flink.api.common.io.InitializeOnMaster
The method is invoked on the master (JobManager) before the distributed program execution starts.
InitializeOnMaster - org.apache.flink.api.common.io中的接口
This interface may be implemented by OutputFormats to have the master initialize them globally.
initializeSafetyNetForThread() - 类 中的静态方法org.apache.flink.core.fs.FileSystemSafetyNet
Activates the safety net for a thread.
initializeSerializerUnlessSet(ExecutionConfig) - 类 中的方法org.apache.flink.api.common.state.StateDescriptor
Initializes the serializer, unless it has been initialized before.
initializeSplit(FileInputSplit, Long) - 类 中的方法org.apache.flink.api.common.io.DelimitedInputFormat
Initialization method that is called after opening or reopening an input split.
initializeSplit(FileInputSplit, Long) - 类 中的方法org.apache.flink.api.common.io.GenericCsvInputFormat
 
initializeTypeComparatorBuilder(int) - 接口 中的方法org.apache.flink.api.common.typeutils.CompositeType.TypeComparatorBuilder
 
initOutPathDistFS(Path, FileSystem.WriteMode, boolean) - 类 中的方法org.apache.flink.core.fs.FileSystem
Initializes output directories on distributed file systems according to the given write mode.
initOutPathDistFS(Path, FileSystem.WriteMode, boolean) - 类 中的方法org.apache.flink.core.fs.SafetyNetWrapperFileSystem
 
initOutPathLocalFS(Path, FileSystem.WriteMode, boolean) - 类 中的方法org.apache.flink.core.fs.FileSystem
Initializes output directories on local file systems according to the given write mode.
initOutPathLocalFS(Path, FileSystem.WriteMode, boolean) - 类 中的方法org.apache.flink.core.fs.SafetyNetWrapperFileSystem
 
InlineElement - org.apache.flink.configuration.description中的接口
Part of description that represents an element inside a block e.g. a link.
InnerJoinOperatorBase<IN1,IN2,OUT,FT extends FlatJoinFunction<IN1,IN2,OUT>> - org.apache.flink.api.common.operators.base中的类
 
InnerJoinOperatorBase(UserCodeWrapper<FT>, BinaryOperatorInformation<IN1, IN2, OUT>, int[], int[], String) - 类 的构造器org.apache.flink.api.common.operators.base.InnerJoinOperatorBase
 
InnerJoinOperatorBase(FT, BinaryOperatorInformation<IN1, IN2, OUT>, int[], int[], String) - 类 的构造器org.apache.flink.api.common.operators.base.InnerJoinOperatorBase
 
InnerJoinOperatorBase(Class<? extends FT>, BinaryOperatorInformation<IN1, IN2, OUT>, int[], int[], String) - 类 的构造器org.apache.flink.api.common.operators.base.InnerJoinOperatorBase
 
input - 类 中的变量org.apache.flink.api.common.operators.GenericDataSinkBase
 
input - 类 中的变量org.apache.flink.api.common.operators.SingleInputOperator
The input which produces the data consumed by this operator.
input1 - 类 中的变量org.apache.flink.api.common.operators.DualInputOperator
The operator producing the first input.
input2 - 类 中的变量org.apache.flink.api.common.operators.DualInputOperator
The operator producing the second input.
InputDependencyConstraint - org.apache.flink.api.common中的枚举
已过时。
InputDependencyConstraint is not used anymore and will be deleted in one of the future versions. It was previously used in the scheduler implementations that were removed as part of FLINK-20589.
InputFormat<OT,T extends InputSplit> - org.apache.flink.api.common.io中的接口
The base interface for data sources that produces records.
InputSplit - org.apache.flink.core.io中的接口
This interface must be implemented by all kind of input splits that can be assigned to input formats.
InputSplitAssigner - org.apache.flink.core.io中的接口
An input split assigner distributes the InputSplits among the instances on which a data source exists.
InputSplitOpenThread(FileInputSplit, long) - 类 的构造器org.apache.flink.api.common.io.FileInputFormat.InputSplitOpenThread
 
InputSplitSource<T extends InputSplit> - org.apache.flink.core.io中的接口
InputSplitSources create InputSplits that define portions of data to be produced by InputFormats.
InputStatus - org.apache.flink.core.io中的枚举
An InputStatus indicates the availability of data from an asynchronous input.
inputStream - 类 中的变量org.apache.flink.core.fs.FSDataInputStreamWrapper
 
InputStreamFSInputWrapper - org.apache.flink.api.common.io中的类
This class wraps an InputStream and exposes it as FSDataInputStream.
InputStreamFSInputWrapper(InputStream) - 类 的构造器org.apache.flink.api.common.io.InputStreamFSInputWrapper
 
inputType - 类 中的变量org.apache.flink.api.common.operators.UnaryOperatorInformation
Input Type of the operator
inputType1 - 类 中的变量org.apache.flink.api.common.operators.BinaryOperatorInformation
Input type of the first input
inputType2 - 类 中的变量org.apache.flink.api.common.operators.BinaryOperatorInformation
Input type of the second input
InputTypeConfigurable - org.apache.flink.api.java.typeutils中的接口
OutputFormats can implement this interface to be configured with the data type they will operate on.
inputView - 类 中的变量org.apache.flink.api.java.typeutils.runtime.DataInputViewStream
 
inRocksdbCompactFilter() - 类 中的方法org.apache.flink.api.common.state.StateTtlConfig.CleanupStrategies
 
insertOrReplace(BT) - 类 中的方法org.apache.flink.api.common.operators.util.JoinHashMap
 
INSTANCE - 类 中的静态变量org.apache.flink.api.common.typeutils.base.array.BooleanPrimitiveArraySerializer
 
INSTANCE - 类 中的静态变量org.apache.flink.api.common.typeutils.base.array.BytePrimitiveArraySerializer
 
INSTANCE - 类 中的静态变量org.apache.flink.api.common.typeutils.base.array.CharPrimitiveArraySerializer
 
INSTANCE - 类 中的静态变量org.apache.flink.api.common.typeutils.base.array.DoublePrimitiveArraySerializer
 
INSTANCE - 类 中的静态变量org.apache.flink.api.common.typeutils.base.array.FloatPrimitiveArraySerializer
 
INSTANCE - 类 中的静态变量org.apache.flink.api.common.typeutils.base.array.IntPrimitiveArraySerializer
 
INSTANCE - 类 中的静态变量org.apache.flink.api.common.typeutils.base.array.LongPrimitiveArraySerializer
 
INSTANCE - 类 中的静态变量org.apache.flink.api.common.typeutils.base.array.ShortPrimitiveArraySerializer
 
INSTANCE - 类 中的静态变量org.apache.flink.api.common.typeutils.base.array.StringArraySerializer
 
INSTANCE - 类 中的静态变量org.apache.flink.api.common.typeutils.base.BigDecSerializer
 
INSTANCE - 类 中的静态变量org.apache.flink.api.common.typeutils.base.BigIntSerializer
 
INSTANCE - 类 中的静态变量org.apache.flink.api.common.typeutils.base.BooleanSerializer
Sharable instance of the BooleanSerializer.
INSTANCE - 类 中的静态变量org.apache.flink.api.common.typeutils.base.BooleanValueSerializer
 
INSTANCE - 类 中的静态变量org.apache.flink.api.common.typeutils.base.ByteSerializer
Sharable instance of the ByteSerializer.
INSTANCE - 类 中的静态变量org.apache.flink.api.common.typeutils.base.ByteValueSerializer
 
INSTANCE - 类 中的静态变量org.apache.flink.api.common.typeutils.base.CharSerializer
Sharable instance of the CharSerializer.
INSTANCE - 类 中的静态变量org.apache.flink.api.common.typeutils.base.CharValueSerializer
 
INSTANCE - 类 中的静态变量org.apache.flink.api.common.typeutils.base.DateSerializer
 
INSTANCE - 类 中的静态变量org.apache.flink.api.common.typeutils.base.DoubleSerializer
Sharable instance of the DoubleSerializer.
INSTANCE - 类 中的静态变量org.apache.flink.api.common.typeutils.base.DoubleValueSerializer
 
INSTANCE - 类 中的静态变量org.apache.flink.api.common.typeutils.base.FloatSerializer
Sharable instance of the FloatSerializer.
INSTANCE - 类 中的静态变量org.apache.flink.api.common.typeutils.base.FloatValueSerializer
 
INSTANCE - 类 中的静态变量org.apache.flink.api.common.typeutils.base.InstantSerializer
 
INSTANCE - 类 中的静态变量org.apache.flink.api.common.typeutils.base.IntSerializer
Sharable instance of the IntSerializer.
INSTANCE - 类 中的静态变量org.apache.flink.api.common.typeutils.base.IntValueSerializer
 
INSTANCE - 类 中的静态变量org.apache.flink.api.common.typeutils.base.LocalDateSerializer
 
INSTANCE - 类 中的静态变量org.apache.flink.api.common.typeutils.base.LocalDateTimeSerializer
 
INSTANCE - 类 中的静态变量org.apache.flink.api.common.typeutils.base.LocalTimeSerializer
 
INSTANCE - 类 中的静态变量org.apache.flink.api.common.typeutils.base.LongSerializer
Sharable instance of the LongSerializer.
INSTANCE - 类 中的静态变量org.apache.flink.api.common.typeutils.base.LongValueSerializer
 
INSTANCE - 类 中的静态变量org.apache.flink.api.common.typeutils.base.NullValueSerializer
 
INSTANCE - 类 中的静态变量org.apache.flink.api.common.typeutils.base.ShortSerializer
Sharable instance of the ShortSerializer.
INSTANCE - 类 中的静态变量org.apache.flink.api.common.typeutils.base.ShortValueSerializer
 
INSTANCE - 类 中的静态变量org.apache.flink.api.common.typeutils.base.SqlDateSerializer
 
INSTANCE - 类 中的静态变量org.apache.flink.api.common.typeutils.base.SqlTimeSerializer
 
INSTANCE - 类 中的静态变量org.apache.flink.api.common.typeutils.base.SqlTimestampSerializer
 
INSTANCE - 类 中的静态变量org.apache.flink.api.common.typeutils.base.StringSerializer
Sharable instance of the StringSerializer.
INSTANCE - 类 中的静态变量org.apache.flink.api.common.typeutils.base.StringValueSerializer
 
INSTANCE - 类 中的静态变量org.apache.flink.api.common.typeutils.base.VoidSerializer
Sharable instance of the VoidSerializer.
INSTANCE - 类 中的静态变量org.apache.flink.api.java.tuple.Tuple0
 
INSTANCE - 类 中的静态变量org.apache.flink.api.java.typeutils.runtime.Tuple0Serializer
 
INSTANCE - 类 中的静态变量org.apache.flink.util.FatalExitExceptionHandler
 
INSTANT - 类 中的静态变量org.apache.flink.api.common.typeinfo.Types
Returns type information for Instant.
INSTANT_TYPE_INFO - 类 中的静态变量org.apache.flink.api.common.typeinfo.BasicTypeInfo
 
InstantComparator - org.apache.flink.api.common.typeutils.base中的类
Comparator for comparing Java Instant.
InstantComparator(boolean) - 类 的构造器org.apache.flink.api.common.typeutils.base.InstantComparator
 
instantiate(String, Class<T>, ClassLoader) - 类 中的静态方法org.apache.flink.util.InstantiationUtil
Creates a new instance of the given class name and type using the provided ClassLoader.
instantiate(Class<T>, Class<? super T>) - 类 中的静态方法org.apache.flink.util.InstantiationUtil
Creates a new instance of the given class.
instantiate(Class<T>) - 类 中的静态方法org.apache.flink.util.InstantiationUtil
Creates a new instance of the given class.
instantiateDeserializationUtils() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
 
InstantiationUtil - org.apache.flink.util中的类
Utility class to create instances from class objects and checking failure reasons.
InstantiationUtil.ClassLoaderObjectInputStream - org.apache.flink.util中的类
A custom ObjectInputStream that can load classes using a specific ClassLoader.
InstantiationUtil.FailureTolerantObjectInputStream - org.apache.flink.util中的类
An ObjectInputStream that ignores serialVersionUID mismatches when deserializing objects of anonymous classes or our Scala serializer classes and also replaces occurences of GenericData.Array (from Avro) by a dummy class so that the KryoSerializer can still be deserialized without Avro being on the classpath.
InstantSerializer - org.apache.flink.api.common.typeutils.base中的类
Serializer for serializing/deserializing Instant values including null values.
InstantSerializer() - 类 的构造器org.apache.flink.api.common.typeutils.base.InstantSerializer
 
InstantSerializer.InstantSerializerSnapshot - org.apache.flink.api.common.typeutils.base中的类
Serializer configuration snapshot for compatibility and format evolution.
InstantSerializerSnapshot() - 类 的构造器org.apache.flink.api.common.typeutils.base.InstantSerializer.InstantSerializerSnapshot
 
INT - 类 中的静态变量org.apache.flink.api.common.typeinfo.Types
Returns type information for both a primitive int and Integer.
INT_ARRAY_TYPE_INFO - 类 中的静态变量org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
 
INT_PRIMITIVE_ARRAY_TYPE_INFO - 类 中的静态变量org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
 
INT_TYPE_INFO - 类 中的静态变量org.apache.flink.api.common.typeinfo.BasicTypeInfo
 
INT_VALUE_TYPE_INFO - 类 中的静态变量org.apache.flink.api.java.typeutils.ValueTypeInfo
 
IntComparator - org.apache.flink.api.common.typeutils.base中的类
 
IntComparator(boolean) - 类 的构造器org.apache.flink.api.common.typeutils.base.IntComparator
 
IntCounter - org.apache.flink.api.common.accumulators中的类
An accumulator that sums up Integer values.
IntCounter() - 类 的构造器org.apache.flink.api.common.accumulators.IntCounter
 
IntCounter(int) - 类 的构造器org.apache.flink.api.common.accumulators.IntCounter
 
IntegerTypeInfo<T> - 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>>) - 类 的构造器org.apache.flink.api.common.typeinfo.IntegerTypeInfo
 
INTERCEPT_USER_SYSTEM_EXIT - 类 中的静态变量org.apache.flink.configuration.ClusterOptions
 
IntMaximum - org.apache.flink.api.common.accumulators中的类
An accumulator that finds the maximum integer value.
IntMaximum() - 类 的构造器org.apache.flink.api.common.accumulators.IntMaximum
 
IntMaximum(int) - 类 的构造器org.apache.flink.api.common.accumulators.IntMaximum
 
IntMinimum - org.apache.flink.api.common.accumulators中的类
An accumulator that finds the minimum integer value.
IntMinimum() - 类 的构造器org.apache.flink.api.common.accumulators.IntMinimum
 
IntMinimum(int) - 类 的构造器org.apache.flink.api.common.accumulators.IntMinimum
 
IntParser - org.apache.flink.types.parser中的类
Parses a decimal text field into a IntValue.
IntParser() - 类 的构造器org.apache.flink.types.parser.IntParser
 
IntPrimitiveArrayComparator - org.apache.flink.api.common.typeutils.base.array中的类
 
IntPrimitiveArrayComparator(boolean) - 类 的构造器org.apache.flink.api.common.typeutils.base.array.IntPrimitiveArrayComparator
 
IntPrimitiveArraySerializer - org.apache.flink.api.common.typeutils.base.array中的类
A serializer for int arrays.
IntPrimitiveArraySerializer() - 类 的构造器org.apache.flink.api.common.typeutils.base.array.IntPrimitiveArraySerializer
 
IntPrimitiveArraySerializer.IntPrimitiveArraySerializerSnapshot - org.apache.flink.api.common.typeutils.base.array中的类
Serializer configuration snapshot for compatibility and format evolution.
IntPrimitiveArraySerializerSnapshot() - 类 的构造器org.apache.flink.api.common.typeutils.base.array.IntPrimitiveArraySerializer.IntPrimitiveArraySerializerSnapshot
 
IntSerializer - org.apache.flink.api.common.typeutils.base中的类
Type serializer for Integer (and int, via auto-boxing).
IntSerializer() - 类 的构造器org.apache.flink.api.common.typeutils.base.IntSerializer
 
IntSerializer.IntSerializerSnapshot - org.apache.flink.api.common.typeutils.base中的类
Serializer configuration snapshot for compatibility and format evolution.
IntSerializerSnapshot() - 类 的构造器org.apache.flink.api.common.typeutils.base.IntSerializer.IntSerializerSnapshot
 
intType() - 类 中的方法org.apache.flink.configuration.ConfigOptions.OptionBuilder
Defines that the value of the option should be of Integer type.
IntValue - org.apache.flink.types中的类
Boxed serializable and comparable integer type, representing the primitive type int.
IntValue() - 类 的构造器org.apache.flink.types.IntValue
Initializes the encapsulated int with 0.
IntValue(int) - 类 的构造器org.apache.flink.types.IntValue
Initializes the encapsulated int with the provided value.
IntValueComparator - org.apache.flink.api.common.typeutils.base中的类
Specialized comparator for IntValue based on CopyableValueComparator.
IntValueComparator(boolean) - 类 的构造器org.apache.flink.api.common.typeutils.base.IntValueComparator
 
IntValueParser - org.apache.flink.types.parser中的类
Parses a decimal text field into a IntValue.
IntValueParser() - 类 的构造器org.apache.flink.types.parser.IntValueParser
 
IntValueSerializer - org.apache.flink.api.common.typeutils.base中的类
 
IntValueSerializer() - 类 的构造器org.apache.flink.api.common.typeutils.base.IntValueSerializer
 
IntValueSerializer.IntValueSerializerSnapshot - org.apache.flink.api.common.typeutils.base中的类
Serializer configuration snapshot for compatibility and format evolution.
IntValueSerializerSnapshot() - 类 的构造器org.apache.flink.api.common.typeutils.base.IntValueSerializer.IntValueSerializerSnapshot
 
InvalidFieldReferenceException(String) - 异常错误 的构造器org.apache.flink.api.common.typeutils.CompositeType.InvalidFieldReferenceException
 
invalidLineCount - 类 中的变量org.apache.flink.api.common.io.GenericCsvInputFormat
 
InvalidProgramException - org.apache.flink.api.common中的异常错误
An exception thrown to indicate that the composed program is invalid.
InvalidProgramException() - 异常错误 的构造器org.apache.flink.api.common.InvalidProgramException
Creates a new exception with no message.
InvalidProgramException(String) - 异常错误 的构造器org.apache.flink.api.common.InvalidProgramException
Creates a new exception with the given message.
InvalidProgramException(String, Throwable) - 异常错误 的构造器org.apache.flink.api.common.InvalidProgramException
Creates a new exception with the given message and cause.
InvalidSemanticAnnotationException(String) - 异常错误 的构造器org.apache.flink.api.common.operators.SemanticProperties.InvalidSemanticAnnotationException
 
InvalidSemanticAnnotationException(String, Throwable) - 异常错误 的构造器org.apache.flink.api.common.operators.SemanticProperties.InvalidSemanticAnnotationException
 
InvalidTypesException - 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() - 异常错误 的构造器org.apache.flink.api.common.functions.InvalidTypesException
Creates a new exception with no message.
InvalidTypesException(String) - 异常错误 的构造器org.apache.flink.api.common.functions.InvalidTypesException
Creates a new exception with the given message.
InvalidTypesException(String, Throwable) - 异常错误 的构造器org.apache.flink.api.common.functions.InvalidTypesException
 
invertNormalizedKey() - 类 中的方法org.apache.flink.api.common.typeutils.base.array.PrimitiveArrayComparator
 
invertNormalizedKey() - 类 中的方法org.apache.flink.api.common.typeutils.base.BasicTypeComparator
 
invertNormalizedKey() - 类 中的方法org.apache.flink.api.common.typeutils.base.BooleanValueComparator
 
invertNormalizedKey() - 类 中的方法org.apache.flink.api.common.typeutils.base.ByteValueComparator
 
invertNormalizedKey() - 类 中的方法org.apache.flink.api.common.typeutils.base.CharValueComparator
 
invertNormalizedKey() - 类 中的方法org.apache.flink.api.common.typeutils.base.DoubleValueComparator
 
invertNormalizedKey() - 类 中的方法org.apache.flink.api.common.typeutils.base.FloatValueComparator
 
invertNormalizedKey() - 类 中的方法org.apache.flink.api.common.typeutils.base.IntValueComparator
 
invertNormalizedKey() - 类 中的方法org.apache.flink.api.common.typeutils.base.LocalDateComparator
 
invertNormalizedKey() - 类 中的方法org.apache.flink.api.common.typeutils.base.LocalDateTimeComparator
 
invertNormalizedKey() - 类 中的方法org.apache.flink.api.common.typeutils.base.LongValueComparator
 
invertNormalizedKey() - 类 中的方法org.apache.flink.api.common.typeutils.base.NullValueComparator
 
invertNormalizedKey() - 类 中的方法org.apache.flink.api.common.typeutils.base.ShortValueComparator
 
invertNormalizedKey() - 类 中的方法org.apache.flink.api.common.typeutils.base.StringValueComparator
 
invertNormalizedKey() - 类 中的方法org.apache.flink.api.common.typeutils.TypeComparator
Flag whether normalized key comparisons should be inverted key should be interpreted inverted, i.e. descending.
invertNormalizedKey() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.CopyableValueComparator
 
invertNormalizedKey() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.GenericTypeComparator
 
invertNormalizedKey() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.NullAwareComparator
 
invertNormalizedKey() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.PojoComparator
 
invertNormalizedKey() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.RowComparator
 
invertNormalizedKey() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
 
invertNormalizedKey() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.ValueComparator
 
invertNormKey - 类 中的变量org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
 
IOReadableWritable - 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.
IOUtils - org.apache.flink.util中的类
An utility class for I/O related functionality.
ipAddressAndPortToUrlString(InetAddress, int) - 类 中的静态方法org.apache.flink.util.NetUtils
Encodes an IP address and port to be included in URL. in particular, this method makes sure that IPv6 addresses have the proper formatting to be included in URLs.
ipAddressToUrlString(InetAddress) - 类 中的静态方法org.apache.flink.util.NetUtils
Encodes an IP address properly as a URL string.
IPC_PORT - 类 中的静态变量org.apache.flink.configuration.ResourceManagerOptions
Defines the network port to connect to for communication with the resource manager.
isAbsolute() - 类 中的方法org.apache.flink.core.fs.Path
Checks if the directory of this path is absolute.
isAdaptiveSchedulerEnabled(Configuration) - 类 中的静态方法org.apache.flink.configuration.ClusterOptions
 
isAutoTypeRegistrationDisabled() - 类 中的方法org.apache.flink.api.common.ExecutionConfig
 
isAvailable() - 类 中的方法org.apache.flink.api.connector.source.lib.util.IteratorSourceReader
 
isAvailable() - 接口 中的方法org.apache.flink.api.connector.source.SourceReader
Returns a future that signals that data is available from the reader.
isBasicType() - 类 中的方法org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
 
isBasicType() - 类 中的方法org.apache.flink.api.common.typeinfo.BasicTypeInfo
 
isBasicType() - 类 中的方法org.apache.flink.api.common.typeinfo.LocalTimeTypeInfo
 
isBasicType() - 类 中的方法org.apache.flink.api.common.typeinfo.NothingTypeInfo
 
isBasicType() - 类 中的方法org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
 
isBasicType() - 类 中的方法org.apache.flink.api.common.typeinfo.SqlTimeTypeInfo
 
isBasicType() - 类 中的方法org.apache.flink.api.common.typeinfo.TypeInformation
Checks if this type information represents a basic type.
isBasicType() - 类 中的方法org.apache.flink.api.java.typeutils.EitherTypeInfo
 
isBasicType() - 类 中的方法org.apache.flink.api.java.typeutils.EnumTypeInfo
 
isBasicType() - 类 中的方法org.apache.flink.api.java.typeutils.GenericTypeInfo
 
isBasicType() - 类 中的方法org.apache.flink.api.java.typeutils.ListTypeInfo
 
isBasicType() - 类 中的方法org.apache.flink.api.java.typeutils.MapTypeInfo
 
isBasicType() - 类 中的方法org.apache.flink.api.java.typeutils.MissingTypeInfo
 
isBasicType() - 类 中的方法org.apache.flink.api.java.typeutils.ObjectArrayTypeInfo
 
isBasicType() - 类 中的方法org.apache.flink.api.java.typeutils.PojoTypeInfo
 
isBasicType() - 类 中的方法org.apache.flink.api.java.typeutils.TupleTypeInfoBase
 
isBasicType() - 类 中的方法org.apache.flink.api.java.typeutils.ValueTypeInfo
 
isBasicValueType() - 类 中的方法org.apache.flink.api.java.typeutils.ValueTypeInfo
 
isCancelled() - 类 中的方法org.apache.flink.util.concurrent.NeverCompleteFuture
 
isCaseClass() - 类 中的方法org.apache.flink.api.java.typeutils.TupleTypeInfoBase
 
isClassType(Type) - 类 中的静态方法org.apache.flink.api.java.typeutils.TypeExtractionUtils
Checks if a type can be converted to a Class.
isCleanupInBackground() - 类 中的方法org.apache.flink.api.common.state.StateTtlConfig.CleanupStrategies
 
isCloseableRegistered(Closeable) - 类 中的方法org.apache.flink.util.AbstractCloseableRegistry
 
isClosed() - 类 中的方法org.apache.flink.core.fs.ClosingFSDataInputStream
 
isClosed() - 类 中的方法org.apache.flink.core.fs.ClosingFSDataOutputStream
 
isClosed() - 类 中的方法org.apache.flink.util.AbstractCloseableRegistry
 
isClosed() - 类 中的方法org.apache.flink.util.ResourceGuard
Returns true if the resource guard is closed, i.e. after ResourceGuard.close() was called.
isClosureCleanerEnabled() - 类 中的方法org.apache.flink.api.common.ExecutionConfig
Returns whether the ClosureCleaner is enabled.
isCombinable() - 类 中的方法org.apache.flink.api.common.operators.base.GroupReduceOperatorBase
Checks whether the operation is combinable.
isCombinableFirst() - 类 中的方法org.apache.flink.api.common.operators.base.CoGroupOperatorBase
 
isCombinableFirst() - 类 中的方法org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase
 
isCombinableSecond() - 类 中的方法org.apache.flink.api.common.operators.base.CoGroupOperatorBase
 
isCombinableSecond() - 类 中的方法org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase
 
isCompatibleAfterMigration() - 类 中的方法org.apache.flink.api.common.typeutils.CompositeTypeSerializerUtil.IntermediateCompatibilityResult
 
isCompatibleAfterMigration() - 类 中的方法org.apache.flink.api.common.typeutils.TypeSerializerSchemaCompatibility
Returns whether or not the type of the compatibility is Type#COMPATIBLE_AFTER_MIGRATION.
isCompatibleAsIs() - 类 中的方法org.apache.flink.api.common.typeutils.CompositeTypeSerializerUtil.IntermediateCompatibilityResult
 
isCompatibleAsIs() - 类 中的方法org.apache.flink.api.common.typeutils.TypeSerializerSchemaCompatibility
Returns whether or not the type of the compatibility is Type#COMPATIBLE_AS_IS.
isCompatibleWith(Configuration) - 接口 中的方法org.apache.flink.core.execution.PipelineExecutorFactory
Returns true if this factory is compatible with the options in the provided configuration, false otherwise.
isCompatibleWithReconfiguredSerializer() - 类 中的方法org.apache.flink.api.common.typeutils.CompositeTypeSerializerUtil.IntermediateCompatibilityResult
 
isCompatibleWithReconfiguredSerializer() - 类 中的方法org.apache.flink.api.common.typeutils.TypeSerializerSchemaCompatibility
Returns whether or not the type of the compatibility is Type#COMPATIBLE_WITH_RECONFIGURED_SERIALIZER.
isCompletedNormally(CompletableFuture<?>) - 类 中的静态方法org.apache.flink.util.concurrent.FutureUtils
 
isConverged(int, T) - 接口 中的方法org.apache.flink.api.common.aggregators.ConvergenceCriterion
Decide whether the iterative algorithm has converged
isConverged(int, DoubleValue) - 类 中的方法org.apache.flink.api.common.aggregators.DoubleZeroConvergence
Returns true, if the aggregator value is zero, false otherwise.
isConverged(int, LongValue) - 类 中的方法org.apache.flink.api.common.aggregators.LongZeroConvergence
Returns true, if the aggregator value is zero, false otherwise.
isConverged(int, LongValue) - 类 中的方法org.apache.flink.api.common.operators.base.BulkIterationBase.TerminationCriterionAggregationConvergence
 
isDeprecated() - 类 中的方法org.apache.flink.configuration.FallbackKey
 
isDir() - 接口 中的方法org.apache.flink.core.fs.FileStatus
Checks if this object represents a directory.
isDir() - 类 中的方法org.apache.flink.core.fs.local.LocalFileStatus
 
isDirectOutOfMemoryError(Throwable) - 类 中的静态方法org.apache.flink.util.ExceptionUtils
Checks whether the given exception indicates a JVM direct out-of-memory error.
isDistributedFS() - 类 中的方法org.apache.flink.core.fs.FileSystem
Returns true if this is a distributed file system.
isDistributedFS() - 类 中的方法org.apache.flink.core.fs.LimitedConnectionsFileSystem
 
isDistributedFS() - 类 中的方法org.apache.flink.core.fs.local.LocalFileSystem
 
isDistributedFS() - 类 中的方法org.apache.flink.core.fs.SafetyNetWrapperFileSystem
 
isDone() - 类 中的方法org.apache.flink.util.concurrent.NeverCompleteFuture
 
isDummy() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.KryoRegistration
 
isEmpty() - 类 中的方法org.apache.flink.api.common.operators.Keys
 
isEmpty() - 接口 中的方法org.apache.flink.api.common.state.MapState
Returns true if this state contains no key-value mappings, otherwise false.
isEmpty() - 类 中的方法org.apache.flink.types.ListValue
 
isEmpty() - 类 中的方法org.apache.flink.types.MapValue
 
isEnabled() - 类 中的方法org.apache.flink.api.common.state.StateTtlConfig
 
isEndOfStream(T) - 类 中的方法org.apache.flink.api.common.serialization.AbstractDeserializationSchema
Method to decide whether the element signals the end of the stream.
isEndOfStream(T) - 接口 中的方法org.apache.flink.api.common.serialization.DeserializationSchema
Method to decide whether the element signals the end of the stream.
isEndOfStream(String) - 类 中的方法org.apache.flink.api.common.serialization.SimpleStringSchema
 
isEndOfStream(T) - 类 中的方法org.apache.flink.api.common.serialization.TypeInformationSerializationSchema
This schema never considers an element to signal end-of-stream, so this method returns always false.
isEntropyInjecting(FileSystem) - 类 中的静态方法org.apache.flink.core.fs.EntropyInjector
 
isExactMatch(FieldList) - 类 中的方法org.apache.flink.api.common.operators.util.FieldList
 
isExecutable - 类 中的变量org.apache.flink.api.common.cache.DistributedCache.DistributedCacheEntry
 
isFailure() - 类 中的方法org.apache.flink.util.OptionalFailure
 
isFineGrainedResourceManagementEnabled(Configuration) - 类 中的静态方法org.apache.flink.configuration.ClusterOptions
 
isForceAvroEnabled() - 类 中的方法org.apache.flink.api.common.ExecutionConfig
Returns whether the Apache Avro is the default serializer for POJOs.
isForceKryoEnabled() - 类 中的方法org.apache.flink.api.common.ExecutionConfig
 
isFreeBSD() - 枚举 中的静态方法org.apache.flink.util.OperatingSystem
Checks whether the operating system this JVM runs on is FreeBSD.
isFreed() - 类 中的方法org.apache.flink.core.memory.MemorySegment
Checks whether the memory segment was freed.
isGloballyTerminalState() - 枚举 中的方法org.apache.flink.api.common.JobStatus
Checks whether this state is globally terminal.
isHeapSpaceOutOfMemoryError(Throwable) - 类 中的静态方法org.apache.flink.util.ExceptionUtils
 
isIdle() - 类 中的方法org.apache.flink.api.common.eventtime.IndexedCombinedWatermarkStatus
 
isImmutableType() - 类 中的方法org.apache.flink.api.common.typeutils.base.array.BooleanPrimitiveArraySerializer
 
isImmutableType() - 类 中的方法org.apache.flink.api.common.typeutils.base.array.BytePrimitiveArraySerializer
 
isImmutableType() - 类 中的方法org.apache.flink.api.common.typeutils.base.array.CharPrimitiveArraySerializer
 
isImmutableType() - 类 中的方法org.apache.flink.api.common.typeutils.base.array.DoublePrimitiveArraySerializer
 
isImmutableType() - 类 中的方法org.apache.flink.api.common.typeutils.base.array.FloatPrimitiveArraySerializer
 
isImmutableType() - 类 中的方法org.apache.flink.api.common.typeutils.base.array.IntPrimitiveArraySerializer
 
isImmutableType() - 类 中的方法org.apache.flink.api.common.typeutils.base.array.LongPrimitiveArraySerializer
 
isImmutableType() - 类 中的方法org.apache.flink.api.common.typeutils.base.array.ShortPrimitiveArraySerializer
 
isImmutableType() - 类 中的方法org.apache.flink.api.common.typeutils.base.array.StringArraySerializer
 
isImmutableType() - 类 中的方法org.apache.flink.api.common.typeutils.base.BigDecSerializer
 
isImmutableType() - 类 中的方法org.apache.flink.api.common.typeutils.base.BigIntSerializer
 
isImmutableType() - 类 中的方法org.apache.flink.api.common.typeutils.base.BooleanSerializer
 
isImmutableType() - 类 中的方法org.apache.flink.api.common.typeutils.base.BooleanValueSerializer
 
isImmutableType() - 类 中的方法org.apache.flink.api.common.typeutils.base.ByteSerializer
 
isImmutableType() - 类 中的方法org.apache.flink.api.common.typeutils.base.ByteValueSerializer
 
isImmutableType() - 类 中的方法org.apache.flink.api.common.typeutils.base.CharSerializer
 
isImmutableType() - 类 中的方法org.apache.flink.api.common.typeutils.base.CharValueSerializer
 
isImmutableType() - 类 中的方法org.apache.flink.api.common.typeutils.base.DateSerializer
 
isImmutableType() - 类 中的方法org.apache.flink.api.common.typeutils.base.DoubleSerializer
 
isImmutableType() - 类 中的方法org.apache.flink.api.common.typeutils.base.DoubleValueSerializer
 
isImmutableType() - 类 中的方法org.apache.flink.api.common.typeutils.base.EnumSerializer
 
isImmutableType() - 类 中的方法org.apache.flink.api.common.typeutils.base.FloatSerializer
 
isImmutableType() - 类 中的方法org.apache.flink.api.common.typeutils.base.FloatValueSerializer
 
isImmutableType() - 类 中的方法org.apache.flink.api.common.typeutils.base.GenericArraySerializer
 
isImmutableType() - 类 中的方法org.apache.flink.api.common.typeutils.base.InstantSerializer
 
isImmutableType() - 类 中的方法org.apache.flink.api.common.typeutils.base.IntSerializer
 
isImmutableType() - 类 中的方法org.apache.flink.api.common.typeutils.base.IntValueSerializer
 
isImmutableType() - 类 中的方法org.apache.flink.api.common.typeutils.base.ListSerializer
 
isImmutableType() - 类 中的方法org.apache.flink.api.common.typeutils.base.LocalDateSerializer
 
isImmutableType() - 类 中的方法org.apache.flink.api.common.typeutils.base.LocalDateTimeSerializer
 
isImmutableType() - 类 中的方法org.apache.flink.api.common.typeutils.base.LocalTimeSerializer
 
isImmutableType() - 类 中的方法org.apache.flink.api.common.typeutils.base.LongSerializer
 
isImmutableType() - 类 中的方法org.apache.flink.api.common.typeutils.base.LongValueSerializer
 
isImmutableType() - 类 中的方法org.apache.flink.api.common.typeutils.base.MapSerializer
 
isImmutableType() - 类 中的方法org.apache.flink.api.common.typeutils.base.NullValueSerializer
 
isImmutableType() - 类 中的方法org.apache.flink.api.common.typeutils.base.ShortSerializer
 
isImmutableType() - 类 中的方法org.apache.flink.api.common.typeutils.base.ShortValueSerializer
 
isImmutableType() - 类 中的方法org.apache.flink.api.common.typeutils.base.SqlDateSerializer
 
isImmutableType() - 类 中的方法org.apache.flink.api.common.typeutils.base.SqlTimeSerializer
 
isImmutableType() - 类 中的方法org.apache.flink.api.common.typeutils.base.SqlTimestampSerializer
 
isImmutableType() - 类 中的方法org.apache.flink.api.common.typeutils.base.StringSerializer
 
isImmutableType() - 类 中的方法org.apache.flink.api.common.typeutils.base.StringValueSerializer
 
isImmutableType() - 类 中的方法org.apache.flink.api.common.typeutils.base.VoidSerializer
 
isImmutableType() - 类 中的方法org.apache.flink.api.common.typeutils.CompositeSerializer
 
isImmutableType() - 类 中的方法org.apache.flink.api.common.typeutils.SingleThreadAccessCheckingTypeSerializer
 
isImmutableType() - 类 中的方法org.apache.flink.api.common.typeutils.TypeSerializer
Gets whether the type is an immutable type.
isImmutableType() - 类 中的方法org.apache.flink.api.common.typeutils.UnloadableDummyTypeSerializer
 
isImmutableType() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer
 
isImmutableType() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.EitherSerializer
 
isImmutableType() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer
 
isImmutableType() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.NullableSerializer
 
isImmutableType() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.PojoSerializer
 
isImmutableType() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.RowSerializer
 
isImmutableType() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.TupleSerializerBase
 
isImmutableType() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.ValueSerializer
 
isImmutableType() - 类 中的方法org.apache.flink.core.io.SimpleVersionedSerializerTypeSerializerProxy
 
isIncompatible() - 类 中的方法org.apache.flink.api.common.typeutils.CompositeTypeSerializerUtil.IntermediateCompatibilityResult
 
isIncompatible() - 类 中的方法org.apache.flink.api.common.typeutils.TypeSerializerSchemaCompatibility
Returns whether or not the type of the compatibility is Type#INCOMPATIBLE.
isInternalSSLEnabled(Configuration) - 类 中的静态方法org.apache.flink.configuration.SecurityOptions
Checks whether SSL for internal communication (rpc, data transport, blob server) is enabled.
isJarFile(Path) - 类 中的静态方法org.apache.flink.util.FileUtils
Checks whether the given file has a jar extension.
isJobExecutionResult() - 类 中的方法org.apache.flink.api.common.JobExecutionResult
 
isJobExecutionResult() - 类 中的方法org.apache.flink.api.common.JobSubmissionResult
Checks if this JobSubmissionResult is also a JobExecutionResult.
isJobExecutionResult() - 类 中的方法org.apache.flink.core.execution.DetachedJobExecutionResult
 
isJvmFatalError(Throwable) - 类 中的静态方法org.apache.flink.util.ExceptionUtils
Checks whether the given exception indicates a situation that may leave the JVM in a corrupted state, meaning a state where continued normal operation can only be guaranteed via clean process restart.
isJvmFatalOrOutOfMemoryError(Throwable) - 类 中的静态方法org.apache.flink.util.ExceptionUtils
Checks whether the given exception indicates a situation that may leave the JVM in a corrupted state, or an out-of-memory error.
isKeyType() - 类 中的方法org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
 
isKeyType() - 类 中的方法org.apache.flink.api.common.typeinfo.BasicTypeInfo
 
isKeyType() - 类 中的方法org.apache.flink.api.common.typeinfo.LocalTimeTypeInfo
 
isKeyType() - 类 中的方法org.apache.flink.api.common.typeinfo.NothingTypeInfo
 
isKeyType() - 类 中的方法org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
 
isKeyType() - 类 中的方法org.apache.flink.api.common.typeinfo.SqlTimeTypeInfo
 
isKeyType() - 类 中的方法org.apache.flink.api.common.typeinfo.TypeInformation
Checks whether this type can be used as a key.
isKeyType() - 类 中的方法org.apache.flink.api.common.typeutils.CompositeType
 
isKeyType() - 类 中的方法org.apache.flink.api.java.typeutils.EitherTypeInfo
 
isKeyType() - 类 中的方法org.apache.flink.api.java.typeutils.EnumTypeInfo
 
isKeyType() - 类 中的方法org.apache.flink.api.java.typeutils.GenericTypeInfo
 
isKeyType() - 类 中的方法org.apache.flink.api.java.typeutils.ListTypeInfo
 
isKeyType() - 类 中的方法org.apache.flink.api.java.typeutils.MapTypeInfo
 
isKeyType() - 类 中的方法org.apache.flink.api.java.typeutils.MissingTypeInfo
 
isKeyType() - 类 中的方法org.apache.flink.api.java.typeutils.ObjectArrayTypeInfo
 
isKeyType() - 类 中的方法org.apache.flink.api.java.typeutils.ValueTypeInfo
 
isLatencyTrackingConfigured() - 类 中的方法org.apache.flink.api.common.ExecutionConfig
 
isLeft() - 类 中的方法org.apache.flink.types.Either
 
isLenient() - 类 中的方法org.apache.flink.api.common.io.GenericCsvInputFormat
 
isLinux() - 枚举 中的静态方法org.apache.flink.util.OperatingSystem
Checks whether the operating system this JVM runs on is Linux.
isMac() - 枚举 中的静态方法org.apache.flink.util.OperatingSystem
Checks whether the operating system this JVM runs on is Windows.
isMetaspaceOutOfMemoryError(Throwable) - 类 中的静态方法org.apache.flink.util.ExceptionUtils
Checks whether the given exception indicates a JVM metaspace out-of-memory error.
isMetBy(Ordering) - 类 中的方法org.apache.flink.api.common.operators.Ordering
 
isNonStaticInnerClass(Class<?>) - 类 中的静态方法org.apache.flink.util.InstantiationUtil
Checks, whether the class is an inner class that is not statically accessible.
isNormalizedKeyPrefixOnly(int) - 类 中的方法org.apache.flink.api.common.typeutils.base.array.PrimitiveArrayComparator
 
isNormalizedKeyPrefixOnly(int) - 类 中的方法org.apache.flink.api.common.typeutils.base.BigDecComparator
 
isNormalizedKeyPrefixOnly(int) - 类 中的方法org.apache.flink.api.common.typeutils.base.BigIntComparator
 
isNormalizedKeyPrefixOnly(int) - 类 中的方法org.apache.flink.api.common.typeutils.base.BooleanComparator
 
isNormalizedKeyPrefixOnly(int) - 类 中的方法org.apache.flink.api.common.typeutils.base.BooleanValueComparator
 
isNormalizedKeyPrefixOnly(int) - 类 中的方法org.apache.flink.api.common.typeutils.base.ByteComparator
 
isNormalizedKeyPrefixOnly(int) - 类 中的方法org.apache.flink.api.common.typeutils.base.ByteValueComparator
 
isNormalizedKeyPrefixOnly(int) - 类 中的方法org.apache.flink.api.common.typeutils.base.CharComparator
 
isNormalizedKeyPrefixOnly(int) - 类 中的方法org.apache.flink.api.common.typeutils.base.CharValueComparator
 
isNormalizedKeyPrefixOnly(int) - 类 中的方法org.apache.flink.api.common.typeutils.base.DateComparator
 
isNormalizedKeyPrefixOnly(int) - 类 中的方法org.apache.flink.api.common.typeutils.base.DoubleComparator
 
isNormalizedKeyPrefixOnly(int) - 类 中的方法org.apache.flink.api.common.typeutils.base.DoubleValueComparator
 
isNormalizedKeyPrefixOnly(int) - 类 中的方法org.apache.flink.api.common.typeutils.base.EnumComparator
 
isNormalizedKeyPrefixOnly(int) - 类 中的方法org.apache.flink.api.common.typeutils.base.FloatComparator
 
isNormalizedKeyPrefixOnly(int) - 类 中的方法org.apache.flink.api.common.typeutils.base.FloatValueComparator
 
isNormalizedKeyPrefixOnly(int) - 类 中的方法org.apache.flink.api.common.typeutils.base.InstantComparator
 
isNormalizedKeyPrefixOnly(int) - 类 中的方法org.apache.flink.api.common.typeutils.base.IntComparator
 
isNormalizedKeyPrefixOnly(int) - 类 中的方法org.apache.flink.api.common.typeutils.base.IntValueComparator
 
isNormalizedKeyPrefixOnly(int) - 类 中的方法org.apache.flink.api.common.typeutils.base.LocalDateComparator
 
isNormalizedKeyPrefixOnly(int) - 类 中的方法org.apache.flink.api.common.typeutils.base.LocalDateTimeComparator
 
isNormalizedKeyPrefixOnly(int) - 类 中的方法org.apache.flink.api.common.typeutils.base.LocalTimeComparator
 
isNormalizedKeyPrefixOnly(int) - 类 中的方法org.apache.flink.api.common.typeutils.base.LongComparator
 
isNormalizedKeyPrefixOnly(int) - 类 中的方法org.apache.flink.api.common.typeutils.base.LongValueComparator
 
isNormalizedKeyPrefixOnly(int) - 类 中的方法org.apache.flink.api.common.typeutils.base.NullValueComparator
 
isNormalizedKeyPrefixOnly(int) - 类 中的方法org.apache.flink.api.common.typeutils.base.ShortComparator
 
isNormalizedKeyPrefixOnly(int) - 类 中的方法org.apache.flink.api.common.typeutils.base.ShortValueComparator
 
isNormalizedKeyPrefixOnly(int) - 类 中的方法org.apache.flink.api.common.typeutils.base.SqlTimestampComparator
 
isNormalizedKeyPrefixOnly(int) - 类 中的方法org.apache.flink.api.common.typeutils.base.StringComparator
 
isNormalizedKeyPrefixOnly(int) - 类 中的方法org.apache.flink.api.common.typeutils.base.StringValueComparator
 
isNormalizedKeyPrefixOnly(int) - 类 中的方法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) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.CopyableValueComparator
 
isNormalizedKeyPrefixOnly(int) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.GenericTypeComparator
 
isNormalizedKeyPrefixOnly(int) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.NullAwareComparator
 
isNormalizedKeyPrefixOnly(int) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.PojoComparator
 
isNormalizedKeyPrefixOnly(int) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.RowComparator
 
isNormalizedKeyPrefixOnly(int) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
 
isNormalizedKeyPrefixOnly(int) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.ValueComparator
 
isNull(int) - 类 中的方法org.apache.flink.types.Record
 
isNullOrEmpty(Collection<?>) - 类 中的静态方法org.apache.flink.util.CollectionUtil
 
isNullOrEmpty(Map<?, ?>) - 类 中的静态方法org.apache.flink.util.CollectionUtil
 
isNullOrWhitespaceOnly(String) - 类 中的静态方法org.apache.flink.util.StringUtils
Checks if the string is null, empty, or contains only whitespace characters.
isObjectReuseEnabled() - 类 中的方法org.apache.flink.api.common.ExecutionConfig
Returns whether object reuse has been enabled or disabled.
isOffHeap() - 类 中的方法org.apache.flink.core.memory.MemorySegment
Checks whether this memory segment is backed by off-heap memory.
isOrdered() - 枚举 中的方法org.apache.flink.api.common.operators.Order
Checks, if this enum constant represents in fact an order.
isOrderedSubset() - 类 中的方法org.apache.flink.util.LinkedOptionalMap.MergeResult
Returns true if keyNames present at @left, appearing in prefix order at @right.
isOrderEqualOnFirstNFields(Ordering, int) - 类 中的方法org.apache.flink.api.common.operators.Ordering
 
isOuterSnapshotCompatible(S) - 类 中的方法org.apache.flink.api.common.typeutils.CompositeTypeSerializerSnapshot
已过时。
this method is deprecated, and will be removed in the future. Please implement CompositeTypeSerializerSnapshot.resolveOuterSchemaCompatibility(TypeSerializer) instead.
isOverdue() - 类 中的方法org.apache.flink.api.common.time.Deadline
Determines whether the deadline is in the past, i.e. whether the time left is zero or negative.
isPowerOf2(long) - 类 中的静态方法org.apache.flink.util.MathUtils
Checks whether the given value is a power of two.
isPresent() - 类 中的方法org.apache.flink.types.SerializableOptional
 
isProperClass(Class<?>) - 类 中的静态方法org.apache.flink.util.InstantiationUtil
Checks, whether the class is a proper class, i.e. not abstract or an interface, and not a primitive type.
isPublic(Class<?>) - 类 中的静态方法org.apache.flink.util.InstantiationUtil
Checks, whether the given class is public.
isQueryable() - 类 中的方法org.apache.flink.api.common.state.StateDescriptor
Returns whether the state created from this descriptor is queryable.
isResponsibleFor(OutputTag<?>, OutputTag<?>) - 类 中的静态方法org.apache.flink.util.OutputTag
 
isRestSSLAuthenticationEnabled(Configuration) - 类 中的静态方法org.apache.flink.configuration.SecurityOptions
Checks whether mutual SSL authentication for the external REST endpoint is enabled.
isRestSSLEnabled(Configuration) - 类 中的静态方法org.apache.flink.configuration.SecurityOptions
Checks whether SSL for the external REST endpoint is enabled.
isRight() - 类 中的方法org.apache.flink.types.Either
 
isSensitive(String) - 类 中的静态方法org.apache.flink.configuration.GlobalConfiguration
Check whether the key is a hidden key.
isSerializable(Object) - 类 中的静态方法org.apache.flink.util.InstantiationUtil
 
isSerializerInitialized() - 类 中的方法org.apache.flink.api.common.state.StateDescriptor
Checks whether the serializer has been initialized.
isSkippingFirstLineAsHeader() - 类 中的方法org.apache.flink.api.common.io.GenericCsvInputFormat
 
isSolaris() - 枚举 中的静态方法org.apache.flink.util.OperatingSystem
Checks whether the operating system this JVM runs on is Solaris.
isSolutionSetUnManaged() - 类 中的方法org.apache.flink.api.common.operators.base.DeltaIterationBase
gets whether the solution set is in managed or unmanaged memory.
isSortKey(int, TypeInformation<?>) - 类 中的静态方法org.apache.flink.api.common.operators.Keys.ExpressionKeys
 
isSortKey(String, TypeInformation<?>) - 类 中的静态方法org.apache.flink.api.common.operators.Keys.ExpressionKeys
 
isSortKeyType() - 类 中的方法org.apache.flink.api.common.typeinfo.TypeInformation
Checks whether this type can be used as a key for sorting.
isSortKeyType() - 类 中的方法org.apache.flink.api.common.typeutils.CompositeType
 
isSortKeyType() - 类 中的方法org.apache.flink.api.java.typeutils.PojoTypeInfo
 
isTerminalState() - 枚举 中的方法org.apache.flink.api.common.JobStatus
Checks whether this state is locally terminal.
isTupleType() - 类 中的方法org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
 
isTupleType() - 类 中的方法org.apache.flink.api.common.typeinfo.BasicTypeInfo
 
isTupleType() - 类 中的方法org.apache.flink.api.common.typeinfo.LocalTimeTypeInfo
 
isTupleType() - 类 中的方法org.apache.flink.api.common.typeinfo.NothingTypeInfo
 
isTupleType() - 类 中的方法org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
 
isTupleType() - 类 中的方法org.apache.flink.api.common.typeinfo.SqlTimeTypeInfo
 
isTupleType() - 类 中的方法org.apache.flink.api.common.typeinfo.TypeInformation
Checks if this type information represents a Tuple type.
isTupleType() - 类 中的方法org.apache.flink.api.java.typeutils.EitherTypeInfo
 
isTupleType() - 类 中的方法org.apache.flink.api.java.typeutils.EnumTypeInfo
 
isTupleType() - 类 中的方法org.apache.flink.api.java.typeutils.GenericTypeInfo
 
isTupleType() - 类 中的方法org.apache.flink.api.java.typeutils.ListTypeInfo
 
isTupleType() - 类 中的方法org.apache.flink.api.java.typeutils.MapTypeInfo
 
isTupleType() - 类 中的方法org.apache.flink.api.java.typeutils.MissingTypeInfo
 
isTupleType() - 类 中的方法org.apache.flink.api.java.typeutils.ObjectArrayTypeInfo
 
isTupleType() - 类 中的方法org.apache.flink.api.java.typeutils.PojoTypeInfo
 
isTupleType() - 类 中的方法org.apache.flink.api.java.typeutils.TupleTypeInfoBase
 
isTupleType() - 类 中的方法org.apache.flink.api.java.typeutils.ValueTypeInfo
 
isUseSnapshotCompression() - 类 中的方法org.apache.flink.api.common.ExecutionConfig
 
isValidClientPort(int) - 类 中的静态方法org.apache.flink.util.NetUtils
Check whether the given port is in right range when connecting to somewhere.
isValidHostPort(int) - 类 中的静态方法org.apache.flink.util.NetUtils
check whether the given port is in right range when getting port from local system.
isValidSubset(FieldSet) - 类 中的方法org.apache.flink.api.common.operators.util.FieldList
 
isValidSubset(FieldList) - 类 中的方法org.apache.flink.api.common.operators.util.FieldList
 
isValidSubset(FieldSet) - 类 中的方法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) - 类 中的方法org.apache.flink.api.common.operators.util.FieldList
 
isWindows() - 枚举 中的静态方法org.apache.flink.util.OperatingSystem
Checks whether the operating system this JVM runs on is Windows.
isZero() - 类 中的方法org.apache.flink.api.common.resources.Resource
 
isZipped - 类 中的变量org.apache.flink.api.common.cache.DistributedCache.DistributedCacheEntry
 
IterableIterator<E> - org.apache.flink.util中的接口
An Iterator that is also Iterable (often by returning itself).
iterableToList(Iterable<E>) - 类 中的静态方法org.apache.flink.util.CollectionUtil
Collects the elements in the Iterable in a List.
IterableUtils - org.apache.flink.util中的类
A collection of utilities that expand the usage of Iterable.
IterationOperator - org.apache.flink.api.common.operators中的接口
 
IterationRuntimeContext - org.apache.flink.api.common.functions中的接口
A specialization of the RuntimeContext available in iterative computations of the DataSet API.
iterator() - 类 中的方法org.apache.flink.api.common.functions.util.CopyingIterator
 
iterator() - 类 中的方法org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase.SimpleListIterable
 
iterator() - 类 中的方法org.apache.flink.api.common.operators.util.FieldSet
 
iterator() - 类 中的方法org.apache.flink.api.common.operators.util.ListKeyGroupedIterator.ValuesIterator
 
iterator() - 接口 中的方法org.apache.flink.api.common.state.BroadcastState
Iterates over all the mappings in the state.
iterator() - 接口 中的方法org.apache.flink.api.common.state.MapState
Iterates over all the mappings in the state.
iterator() - 类 中的方法org.apache.flink.types.ListValue
 
iterator() - 类 中的方法org.apache.flink.util.CloseableIterable.Empty
 
iterator() - 类 中的方法org.apache.flink.util.UnionIterator
 
IteratorSourceEnumerator<SplitT extends IteratorSourceSplit<?,?>> - org.apache.flink.api.connector.source.lib.util中的类
A SplitEnumerator for iterator sources.
IteratorSourceEnumerator(SplitEnumeratorContext<SplitT>, Collection<SplitT>) - 类 的构造器org.apache.flink.api.connector.source.lib.util.IteratorSourceEnumerator
 
IteratorSourceReader<E,IterT extends Iterator<E>,SplitT extends IteratorSourceSplit<E,IterT>> - org.apache.flink.api.connector.source.lib.util中的类
A SourceReader that returns the values of an iterator, supplied via an IteratorSourceSplit.
IteratorSourceReader(SourceReaderContext) - 类 的构造器org.apache.flink.api.connector.source.lib.util.IteratorSourceReader
 
IteratorSourceSplit<E,IterT extends Iterator<E>> - org.apache.flink.api.connector.source.lib.util中的接口
A SourceSplit that represents a sequence of elements captured in an iterator.
iteratorToList(Iterator<E>) - 类 中的静态方法org.apache.flink.util.CollectionUtil
Collects the elements in the Iterator in a List.

J

JARS - 类 中的静态变量org.apache.flink.configuration.PipelineOptions
A list of jar files that contain the user-defined function (UDF) classes and all classes used from within the UDFs.
JarUtils - org.apache.flink.util中的类
Utility functions for jar files.
JarUtils() - 类 的构造器org.apache.flink.util.JarUtils
 
JavaEitherSerializerSnapshot<L,R> - org.apache.flink.api.java.typeutils.runtime中的类
Snapshot class for the EitherSerializer.
JavaEitherSerializerSnapshot() - 类 的构造器org.apache.flink.api.java.typeutils.runtime.JavaEitherSerializerSnapshot
Constructor for read instantiation.
JavaEitherSerializerSnapshot(EitherSerializer<L, R>) - 类 的构造器org.apache.flink.api.java.typeutils.runtime.JavaEitherSerializerSnapshot
Constructor to create the snapshot for writing.
JavaSerializer<T> - org.apache.flink.api.java.typeutils.runtime.kryo中的类
This is a reimplementation of Kryo's JavaSerializer, that additionally makes sure the ObjectInputStream used for deserialization specifically uses Kryo's registered classloader.
JavaSerializer() - 类 的构造器org.apache.flink.api.java.typeutils.runtime.kryo.JavaSerializer
 
JavaToValueConverter - org.apache.flink.types中的类
 
JavaToValueConverter() - 类 的构造器org.apache.flink.types.JavaToValueConverter
 
jenkinsHash(int) - 类 中的静态方法org.apache.flink.util.MathUtils
This function hashes an integer value.
JMX_SERVER_PORT - 类 中的静态变量org.apache.flink.configuration.JMXServerOptions
Port configured to enable JMX server for metrics and debugging.
JMXServerOptions - org.apache.flink.configuration中的类
The set of configuration options relating to JMX server.
JMXService - org.apache.flink.management.jmx中的类
Provide a JVM-wide singleton JMX Service.
JMXService() - 类 的构造器org.apache.flink.management.jmx.JMXService
 
JOB_LISTENERS - 类 中的静态变量org.apache.flink.configuration.DeploymentOptions
 
JOB_MANAGER_FUTURE_POOL_SIZE - 类 中的静态变量org.apache.flink.configuration.JobManagerOptions
 
JOB_MANAGER_HEAP_MEMORY - 类 中的静态变量org.apache.flink.configuration.JobManagerOptions
已过时。
use JobManagerOptions.TOTAL_FLINK_MEMORY for standalone setups and JobManagerOptions.TOTAL_PROCESS_MEMORY for containerized setups.
JOB_MANAGER_HEAP_MEMORY_MB - 类 中的静态变量org.apache.flink.configuration.JobManagerOptions
已过时。
use JobManagerOptions.TOTAL_FLINK_MEMORY for standalone setups and JobManagerOptions.TOTAL_PROCESS_MEMORY for containerized setups.
JOB_MANAGER_IO_POOL_SIZE - 类 中的静态变量org.apache.flink.configuration.JobManagerOptions
 
JOB_MANAGER_IPC_ADDRESS_KEY - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
JOB_MANAGER_IPC_PORT_KEY - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
JOB_MANAGER_WEB_ARCHIVE_COUNT - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
JOB_MANAGER_WEB_BACK_PRESSURE_CLEAN_UP_INTERVAL - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
- no longer used.
JOB_MANAGER_WEB_BACK_PRESSURE_DELAY - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
- no longer used.
JOB_MANAGER_WEB_BACK_PRESSURE_NUM_SAMPLES - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
- no longer used.
JOB_MANAGER_WEB_BACK_PRESSURE_REFRESH_INTERVAL - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
- no longer used.
JOB_MANAGER_WEB_CHECKPOINTS_DISABLE - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
Not possible to disable any longer. Use history size of 0.
JOB_MANAGER_WEB_CHECKPOINTS_HISTORY_SIZE - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
JOB_MANAGER_WEB_LOG_PATH_KEY - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
Use WebOptions.LOG_PATH instead.
JOB_MANAGER_WEB_PORT_KEY - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
Use WebOptions.PORT instead.
JOB_MANAGER_WEB_SSL_ENABLED - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
JOB_MANAGER_WEB_SUBMIT_ENABLED_KEY - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
JOB_MANAGER_WEB_TMPDIR_KEY - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
Use WebOptions.TMP_DIR instead.
JOB_MANAGER_WEB_UPLOAD_DIR_KEY - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
JOB_RESULT_MESSAGE - 类 中的静态变量org.apache.flink.core.execution.DetachedJobExecutionResult
 
JOB_STORE_CACHE_SIZE - 类 中的静态变量org.apache.flink.configuration.JobManagerOptions
The job store cache size in bytes which is used to keep completed jobs in memory.
JOB_STORE_EXPIRATION_TIME - 类 中的静态变量org.apache.flink.configuration.JobManagerOptions
The time in seconds after which a completed job expires and is purged from the job store.
JOB_STORE_MAX_CAPACITY - 类 中的静态变量org.apache.flink.configuration.JobManagerOptions
The max number of completed jobs that can be kept in the job store.
JOB_TIMEOUT - 类 中的静态变量org.apache.flink.configuration.ResourceManagerOptions
Timeout for jobs which don't have a job manager as leader assigned.
JobClient - org.apache.flink.core.execution中的接口
A client that is scoped to a specific job.
JobExecutionResult - org.apache.flink.api.common中的类
The result of a job execution.
JobExecutionResult(JobID, long, Map<String, OptionalFailure<Object>>) - 类 的构造器org.apache.flink.api.common.JobExecutionResult
Creates a new JobExecutionResult.
JobID - org.apache.flink.api.common中的类
Unique (at least statistically unique) identifier for a Flink Job.
JobID() - 类 的构造器org.apache.flink.api.common.JobID
Creates a new (statistically) random JobID.
JobID(long, long) - 类 的构造器org.apache.flink.api.common.JobID
Creates a new JobID, using the given lower and upper parts.
JobID(byte[]) - 类 的构造器org.apache.flink.api.common.JobID
Creates a new JobID from the given byte sequence.
JobListener - org.apache.flink.core.execution中的接口
A listener that is notified on specific job status changed, which should be firstly registered by #registerJobListener of execution environments.
JobManagerOptions - org.apache.flink.configuration中的类
Configuration options for the JobManager.
JobManagerOptions.SchedulerType - org.apache.flink.configuration中的枚举
Type of scheduler implementation.
jobName - 类 中的变量org.apache.flink.api.common.Plan
The name of the job.
JobStatus - org.apache.flink.api.common中的枚举
Possible states of a job once it has been accepted by the dispatcher.
JobSubmissionResult - org.apache.flink.api.common中的类
The result of submitting a job to a JobManager.
JobSubmissionResult(JobID) - 类 的构造器org.apache.flink.api.common.JobSubmissionResult
 
join(IN1, IN2, Collector<OUT>) - 接口 中的方法org.apache.flink.api.common.functions.FlatJoinFunction
The join method, called once per joined pair of elements.
join(IN1, IN2) - 接口 中的方法org.apache.flink.api.common.functions.JoinFunction
The join method, called once per joined pair of elements.
join(IN1, IN2, Collector<OUT>) - 类 中的方法org.apache.flink.api.common.functions.RichFlatJoinFunction
 
join(IN1, IN2) - 类 中的方法org.apache.flink.api.common.functions.RichJoinFunction
 
join(Row, Row...) - 类 中的静态方法org.apache.flink.types.Row
Creates a new row with fields that are copied from the other rows and appended to the resulting row in the given order.
JoinFunction<IN1,IN2,OUT> - org.apache.flink.api.common.functions中的接口
Interface for Join functions.
JoinHashMap<BT> - org.apache.flink.api.common.operators.util中的类
 
JoinHashMap(TypeSerializer<BT>, TypeComparator<BT>) - 类 的构造器org.apache.flink.api.common.operators.util.JoinHashMap
 
JoinHashMap.Prober<PT> - org.apache.flink.api.common.operators.util中的类
 
JoinOperatorBase<IN1,IN2,OUT,FT extends FlatJoinFunction<IN1,IN2,OUT>> - org.apache.flink.api.common.operators.base中的类
 
JoinOperatorBase(UserCodeWrapper<FT>, BinaryOperatorInformation<IN1, IN2, OUT>, int[], int[], String) - 类 的构造器org.apache.flink.api.common.operators.base.JoinOperatorBase
 
JoinOperatorBase(FT, BinaryOperatorInformation<IN1, IN2, OUT>, int[], int[], String) - 类 的构造器org.apache.flink.api.common.operators.base.JoinOperatorBase
 
JoinOperatorBase(Class<? extends FT>, BinaryOperatorInformation<IN1, IN2, OUT>, int[], int[], String) - 类 的构造器org.apache.flink.api.common.operators.base.JoinOperatorBase
 
JoinOperatorBase.JoinHint - org.apache.flink.api.common.operators.base中的枚举
An enumeration of hints, optionally usable to tell the system how exactly execute the join.
JVM_DIRECT_MEMORY_LIMIT_ENABLED - 类 中的静态变量org.apache.flink.configuration.JobManagerOptions
Off-heap Memory size for the JobManager.
JVM_EXIT_ON_FATAL_ERROR - 类 中的静态变量org.apache.flink.configuration.AkkaOptions
Exit JVM on fatal Akka errors.
JVM_HEAP_MEMORY - 类 中的静态变量org.apache.flink.configuration.JobManagerOptions
JVM Heap Memory size for the JobManager.
JVM_METASPACE - 类 中的静态变量org.apache.flink.configuration.JobManagerOptions
JVM Metaspace Size for the JobManager.
JVM_METASPACE - 类 中的静态变量org.apache.flink.configuration.TaskManagerOptions
JVM Metaspace Size for the TaskExecutors.
JVM_OVERHEAD_FRACTION - 类 中的静态变量org.apache.flink.configuration.JobManagerOptions
Fraction of Total Process Memory to be reserved for JVM Overhead.
JVM_OVERHEAD_FRACTION - 类 中的静态变量org.apache.flink.configuration.TaskManagerOptions
Fraction of Total Process Memory to be reserved for JVM Overhead.
JVM_OVERHEAD_MAX - 类 中的静态变量org.apache.flink.configuration.JobManagerOptions
Max JVM Overhead size for the TaskExecutors.
JVM_OVERHEAD_MAX - 类 中的静态变量org.apache.flink.configuration.TaskManagerOptions
Max JVM Overhead size for the TaskExecutors.
JVM_OVERHEAD_MIN - 类 中的静态变量org.apache.flink.configuration.JobManagerOptions
Min JVM Overhead size for the JobManager.
JVM_OVERHEAD_MIN - 类 中的静态变量org.apache.flink.configuration.TaskManagerOptions
Min JVM Overhead size for the TaskExecutors.

K

KERBEROS_FETCH_DELEGATION_TOKEN - 类 中的静态变量org.apache.flink.configuration.SecurityOptions
 
KERBEROS_KRB5_PATH - 类 中的静态变量org.apache.flink.configuration.SecurityOptions
 
KERBEROS_LOGIN_CONTEXTS - 类 中的静态变量org.apache.flink.configuration.SecurityOptions
 
KERBEROS_LOGIN_KEYTAB - 类 中的静态变量org.apache.flink.configuration.SecurityOptions
 
KERBEROS_LOGIN_PRINCIPAL - 类 中的静态变量org.apache.flink.configuration.SecurityOptions
 
KERBEROS_LOGIN_USETICKETCACHE - 类 中的静态变量org.apache.flink.configuration.SecurityOptions
 
key() - 类 中的方法org.apache.flink.configuration.ConfigOption
Gets the configuration key.
key(String) - 类 中的静态方法org.apache.flink.configuration.ConfigOptions
Starts building a new ConfigOption.
Key<T> - org.apache.flink.types中的接口
已过时。
The Key type is a relict of a deprecated and removed API and will be removed in future (2.0) versions as well.
KeyedStateStore - org.apache.flink.api.common.state中的接口
This interface contains methods for registering keyed state with a managed store.
KeyFieldOutOfBoundsException - org.apache.flink.types中的异常错误
An exception specifying that a required key field was not set in a record, i.e. was null .
KeyFieldOutOfBoundsException() - 异常错误 的构造器org.apache.flink.types.KeyFieldOutOfBoundsException
Constructs an KeyFieldOutOfBoundsException with null as its error detail message.
KeyFieldOutOfBoundsException(String) - 异常错误 的构造器org.apache.flink.types.KeyFieldOutOfBoundsException
Constructs an KeyFieldOutOfBoundsException with the specified detail message.
KeyFieldOutOfBoundsException(int) - 异常错误 的构造器org.apache.flink.types.KeyFieldOutOfBoundsException
Constructs an KeyFieldOutOfBoundsException with a default message, referring to given field number as the null key field.
KeyFieldOutOfBoundsException(int, Throwable) - 异常错误 的构造器org.apache.flink.types.KeyFieldOutOfBoundsException
 
keyNames() - 类 中的方法org.apache.flink.util.LinkedOptionalMap
Returns the key names added to this map.
keyPositions - 类 中的变量org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
key positions describe which fields are keys in what order
Keys<T> - org.apache.flink.api.common.operators中的类
 
Keys() - 类 的构造器org.apache.flink.api.common.operators.Keys
 
keys() - 接口 中的方法org.apache.flink.api.common.state.MapState
Returns all the keys in the state.
Keys.ExpressionKeys<T> - org.apache.flink.api.common.operators中的类
Represents (nested) field access through string and integer-based keys
Keys.IncompatibleKeysException - org.apache.flink.api.common.operators中的异常错误
 
Keys.SelectorFunctionKeys<T,K> - org.apache.flink.api.common.operators中的类
 
KeySelector<IN,KEY> - org.apache.flink.api.java.functions中的接口
The KeySelector allows to use deterministic objects for operations such as reduce, reduceGroup, join, coGroup, etc.
keySet() - 类 中的方法org.apache.flink.configuration.Configuration
Returns the keys of all key/value pairs stored inside this configuration object.
keySet() - 类 中的方法org.apache.flink.configuration.DelegatingConfiguration
 
keySet() - 类 中的方法org.apache.flink.types.MapValue
 
KILL_ON_OUT_OF_MEMORY - 类 中的静态变量org.apache.flink.configuration.TaskManagerOptions
Whether to kill the TaskManager when the task thread throws an OutOfMemoryError.
KRYO_DEFAULT_SERIALIZERS - 类 中的静态变量org.apache.flink.configuration.PipelineOptions
 
KRYO_REGISTERED_CLASSES - 类 中的静态变量org.apache.flink.configuration.PipelineOptions
 
KryoRegistration - org.apache.flink.api.java.typeutils.runtime中的类
A KryoRegistration resembles a registered class and its serializer in Kryo.
KryoRegistration(Class<?>) - 类 的构造器org.apache.flink.api.java.typeutils.runtime.KryoRegistration
 
KryoRegistration(Class<?>, Class<? extends Serializer<?>>) - 类 的构造器org.apache.flink.api.java.typeutils.runtime.KryoRegistration
 
KryoRegistration(Class<?>, ExecutionConfig.SerializableSerializer<? extends Serializer<?>>) - 类 的构造器org.apache.flink.api.java.typeutils.runtime.KryoRegistration
 
KryoRegistration.SerializerDefinitionType - org.apache.flink.api.java.typeutils.runtime中的枚举
IMPORTANT: the order of the enumerations must not change, since their ordinals are used for serialization.
KryoRegistrationSerializerConfigSnapshot<T> - org.apache.flink.api.java.typeutils.runtime中的类
Configuration snapshot base class for serializers that use Kryo for serialization.
KryoRegistrationSerializerConfigSnapshot() - 类 的构造器org.apache.flink.api.java.typeutils.runtime.KryoRegistrationSerializerConfigSnapshot
This empty nullary constructor is required for deserializing the configuration.
KryoRegistrationSerializerConfigSnapshot(Class<T>, LinkedHashMap<String, KryoRegistration>) - 类 的构造器org.apache.flink.api.java.typeutils.runtime.KryoRegistrationSerializerConfigSnapshot
 
KryoRegistrationSerializerConfigSnapshot.DummyKryoSerializerClass<RC> - org.apache.flink.api.java.typeutils.runtime中的类
Placeholder dummy for a previously registered Kryo serializer that is no longer valid or in classpath on restore.
KryoRegistrationSerializerConfigSnapshot.DummyRegisteredClass - org.apache.flink.api.java.typeutils.runtime中的类
Placeholder dummy for a previously registered class that can no longer be found in classpath on restore.
KryoSerializer<T> - org.apache.flink.api.java.typeutils.runtime.kryo中的类
A type serializer that serializes its type using the Kryo serialization framework (https://github.com/EsotericSoftware/kryo).
KryoSerializer(Class<T>, ExecutionConfig) - 类 的构造器org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer
 
KryoSerializer(KryoSerializer<T>) - 类 的构造器org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer
Copy-constructor that does not copy transient fields.
KryoSerializer.KryoSerializerConfigSnapshot<T> - org.apache.flink.api.java.typeutils.runtime.kryo中的类
已过时。
KryoSerializerConfigSnapshot() - 类 的构造器org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer.KryoSerializerConfigSnapshot
已过时。
This empty nullary constructor is required for deserializing the configuration.
KryoSerializerConfigSnapshot(Class<T>, LinkedHashMap<String, KryoRegistration>) - 类 的构造器org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer.KryoSerializerConfigSnapshot
已过时。
 
KryoSerializerSnapshot<T> - org.apache.flink.api.java.typeutils.runtime.kryo中的类
KryoSerializerSnapshot() - 类 的构造器org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializerSnapshot
 
KryoUtils - org.apache.flink.api.java.typeutils.runtime中的类
Convenience methods for Kryo
KryoUtils() - 类 的构造器org.apache.flink.api.java.typeutils.runtime.KryoUtils
 

L

LambdaExecutable(Constructor<?>) - 类 的构造器org.apache.flink.api.java.typeutils.TypeExtractionUtils.LambdaExecutable
 
LambdaExecutable(Method) - 类 的构造器org.apache.flink.api.java.typeutils.TypeExtractionUtils.LambdaExecutable
 
LambdaUtil - org.apache.flink.util中的类
This class offers utility functions for Java's lambda features.
lastIndexOf(Object) - 类 中的方法org.apache.flink.types.ListValue
 
LATENCY_HISTORY_SIZE - 类 中的静态变量org.apache.flink.configuration.MetricOptions
The number of measured latencies to maintain at each operator.
LATENCY_INTERVAL - 类 中的静态变量org.apache.flink.configuration.MetricOptions
 
LATENCY_SOURCE_GRANULARITY - 类 中的静态变量org.apache.flink.configuration.MetricOptions
 
LATENCY_TRACK_ENABLED - 类 中的静态变量org.apache.flink.configuration.StateBackendOptions
 
LATENCY_TRACK_HISTORY_SIZE - 类 中的静态变量org.apache.flink.configuration.StateBackendOptions
 
LATENCY_TRACK_SAMPLE_INTERVAL - 类 中的静态变量org.apache.flink.configuration.StateBackendOptions
 
LATENCY_TRACK_STATE_NAME_AS_VARIABLE - 类 中的静态变量org.apache.flink.configuration.StateBackendOptions
 
Left(L) - 类 中的静态方法org.apache.flink.types.Either
Create a Left value of Either
left() - 类 中的方法org.apache.flink.types.Either
Retrieve the Left value of Either.
Left(L) - 类 的构造器org.apache.flink.types.Either.Left
 
left() - 类 中的方法org.apache.flink.types.Either.Left
 
left() - 类 中的方法org.apache.flink.types.Either.Right
 
legacyReadNestedSerializerSnapshots(DataInputView, ClassLoader) - 类 中的静态方法org.apache.flink.api.common.typeutils.NestedSerializersSnapshotDelegate
Reads the composite snapshot of all the contained serializers in a way that is compatible with Version 1 of the deprecated CompositeTypeSerializerConfigSnapshot.
LegacySerializerSnapshotTransformer<T> - org.apache.flink.api.common.typeutils中的接口
This interface provides a way for TypeSerializers to transform a legacy TypeSerializerSnapshot used in versions before Flink 1.7 during deserialization.
length() - 类 中的方法org.apache.flink.core.memory.DataOutputSerializer
 
length() - 类 中的方法org.apache.flink.types.StringValue
 
lessThanOrEqual(ResourceSpec) - 类 中的方法org.apache.flink.api.common.operators.ResourceSpec
Checks the current resource less than or equal with the other resource by comparing all the fields in the resource.
LIBRARY_CACHE_MANAGER_CLEANUP_INTERVAL - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
LimitedConnectionsFileSystem - org.apache.flink.core.fs中的类
A file system that limits the number of concurrently open input streams, output streams, and total streams for a target file system.
LimitedConnectionsFileSystem(FileSystem, int) - 类 的构造器org.apache.flink.core.fs.LimitedConnectionsFileSystem
Creates a new output connection limiting file system.
LimitedConnectionsFileSystem(FileSystem, int, long, long) - 类 的构造器org.apache.flink.core.fs.LimitedConnectionsFileSystem
Creates a new output connection limiting file system.
LimitedConnectionsFileSystem(FileSystem, int, int, int, long, long) - 类 的构造器org.apache.flink.core.fs.LimitedConnectionsFileSystem
Creates a new output connection limiting file system, limiting input and output streams with potentially different quotas.
LimitedConnectionsFileSystem.ConnectionLimitingSettings - org.apache.flink.core.fs中的类
A simple configuration data object capturing the settings for limited connections.
LimitedConnectionsFileSystem.StreamTimeoutException - org.apache.flink.core.fs中的异常错误
A special IOException, indicating a timeout in the data output stream.
limitInput - 类 中的变量org.apache.flink.core.fs.LimitedConnectionsFileSystem.ConnectionLimitingSettings
The limit for the number of input stream connections, or 0, if no limit.
limitOutput - 类 中的变量org.apache.flink.core.fs.LimitedConnectionsFileSystem.ConnectionLimitingSettings
The limit for the number of output stream connections, or 0, if no limit.
limitTotal - 类 中的变量org.apache.flink.core.fs.LimitedConnectionsFileSystem.ConnectionLimitingSettings
The limit for the total number of connections, or 0, if no limit.
linebreak() - 类 中的方法org.apache.flink.configuration.description.Description.DescriptionBuilder
Creates a line break in the description.
linebreak() - 类 中的静态方法org.apache.flink.configuration.description.LineBreakElement
Creates a line break in the description.
LineBreakElement - org.apache.flink.configuration.description中的类
Represents a line break in the Description.
lineDelimiterIsLinebreak - 类 中的变量org.apache.flink.api.common.io.GenericCsvInputFormat
 
link(String, String) - 类 中的静态方法org.apache.flink.configuration.description.LinkElement
Creates a link with a given url and description.
link(String) - 类 中的静态方法org.apache.flink.configuration.description.LinkElement
Creates a link with a given url.
LinkedOptionalMap<K,V> - org.apache.flink.util中的类
A LinkedOptionalMap is an order preserving map (like LinkedHashMap) where keys have a unique string name, but are optionally present, and the values are optional.
LinkedOptionalMap() - 类 的构造器org.apache.flink.util.LinkedOptionalMap
 
LinkedOptionalMap(int) - 类 的构造器org.apache.flink.util.LinkedOptionalMap
 
LinkedOptionalMap.ConsumerWithException<K,V,E extends Throwable> - org.apache.flink.util中的接口
A Consumer that throws exceptions.
LinkedOptionalMap.KeyValue<K,V> - org.apache.flink.util中的类
Key-value pairs stored by the underlying map.
LinkedOptionalMap.MergeResult<K,V> - org.apache.flink.util中的类
LinkedOptionalMapSerializer - org.apache.flink.util中的类
LinkedOptionalMapSerializer - A serializer of LinkedOptionalMap.
LinkElement - org.apache.flink.configuration.description中的类
Element that represents a link in the Description.
LIST(TypeInformation<E>) - 类 中的静态方法org.apache.flink.api.common.typeinfo.Types
Returns type information for a Java List.
list(InlineElement...) - 类 中的方法org.apache.flink.configuration.description.Description.DescriptionBuilder
Adds a bulleted list to the description.
list(InlineElement...) - 类 中的静态方法org.apache.flink.configuration.description.ListElement
Creates a list with blocks of text.
ListAccumulator<T> - org.apache.flink.api.common.accumulators中的类
This accumulator stores a collection of objects.
ListAccumulator() - 类 的构造器org.apache.flink.api.common.accumulators.ListAccumulator
 
ListCollector<T> - org.apache.flink.api.common.functions.util中的类
A Collector that puts the collected elements into a given list.
ListCollector(List<T>) - 类 的构造器org.apache.flink.api.common.functions.util.ListCollector
 
listDirectory(Path) - 类 中的静态方法org.apache.flink.util.FileUtils
Lists the given directory in a resource-leak-safe way.
ListElement - org.apache.flink.configuration.description中的类
Represents a list in the Description.
listFilesInDirectory(Path, Predicate<Path>) - 类 中的静态方法org.apache.flink.util.FileUtils
List the directory recursively and return the files that satisfy the fileFilter.
listIterator() - 类 中的方法org.apache.flink.types.ListValue
 
listIterator(int) - 类 中的方法org.apache.flink.types.ListValue
 
ListKeyGroupedIterator<E> - org.apache.flink.api.common.operators.util中的类
The KeyValueIterator returns a key and all values that belong to the key (share the same key).
ListKeyGroupedIterator(List<E>, TypeSerializer<E>, TypeComparator<E>) - 类 的构造器org.apache.flink.api.common.operators.util.ListKeyGroupedIterator
Initializes the ListKeyGroupedIterator..
ListKeyGroupedIterator.ValuesIterator - org.apache.flink.api.common.operators.util中的类
 
ListSerializer<T> - org.apache.flink.api.common.typeutils.base中的类
A serializer for Lists.
ListSerializer(TypeSerializer<T>) - 类 的构造器org.apache.flink.api.common.typeutils.base.ListSerializer
Creates a list serializer that uses the given serializer to serialize the list's elements.
ListSerializerSnapshot<T> - org.apache.flink.api.common.typeutils.base中的类
Snapshot class for the ListSerializer.
ListSerializerSnapshot() - 类 的构造器org.apache.flink.api.common.typeutils.base.ListSerializerSnapshot
Constructor for read instantiation.
ListSerializerSnapshot(ListSerializer<T>) - 类 的构造器org.apache.flink.api.common.typeutils.base.ListSerializerSnapshot
Constructor to create the snapshot for writing.
ListState<T> - org.apache.flink.api.common.state中的接口
State interface for partitioned list state in Operations.
ListStateDescriptor<T> - org.apache.flink.api.common.state中的类
ListStateDescriptor(String, Class<T>) - 类 的构造器org.apache.flink.api.common.state.ListStateDescriptor
Creates a new ListStateDescriptor with the given name and list element type.
ListStateDescriptor(String, TypeInformation<T>) - 类 的构造器org.apache.flink.api.common.state.ListStateDescriptor
Creates a new ListStateDescriptor with the given name and list element type.
ListStateDescriptor(String, TypeSerializer<T>) - 类 的构造器org.apache.flink.api.common.state.ListStateDescriptor
Creates a new ListStateDescriptor with the given name and list element type.
listStatus(Path) - 类 中的方法org.apache.flink.core.fs.FileSystem
List the statuses of the files/directories in the given path if the path is a directory.
listStatus(Path) - 类 中的方法org.apache.flink.core.fs.LimitedConnectionsFileSystem
 
listStatus(Path) - 类 中的方法org.apache.flink.core.fs.local.LocalFileSystem
 
listStatus(Path) - 类 中的方法org.apache.flink.core.fs.SafetyNetWrapperFileSystem
 
ListTypeInfo<T> - org.apache.flink.api.java.typeutils中的类
A TypeInformation for the list types of the Java API.
ListTypeInfo(Class<T>) - 类 的构造器org.apache.flink.api.java.typeutils.ListTypeInfo
 
ListTypeInfo(TypeInformation<T>) - 类 的构造器org.apache.flink.api.java.typeutils.ListTypeInfo
 
ListValue<V extends Value> - org.apache.flink.types中的类
Generic list base type for PACT programs that implements the Value and List interfaces.
ListValue() - 类 的构造器org.apache.flink.types.ListValue
Initializes the encapsulated list with an empty ArrayList.
ListValue(Collection<V>) - 类 的构造器org.apache.flink.types.ListValue
Initializes the encapsulated list with an ArrayList filled with all object contained in the specified Collection object.
load(Class<P>) - 类 中的方法org.apache.flink.core.plugin.DefaultPluginManager
 
load(Class<P>) - 类 中的方法org.apache.flink.core.plugin.PluginLoader
Returns in iterator over all available implementations of the given service interface (SPI) for the plugin.
load(Class<P>) - 接口 中的方法org.apache.flink.core.plugin.PluginManager
Returns in iterator over all available implementations of the given service interface (SPI) in all the plugins known to this plugin manager instance.
loadClass(String, boolean) - 类 中的方法org.apache.flink.core.classloading.ComponentClassLoader
 
loadClass(String, boolean) - 类 中的方法org.apache.flink.util.FlinkUserCodeClassLoader
 
loadClassWithoutExceptionHandling(String, boolean) - 类 中的方法org.apache.flink.util.ChildFirstClassLoader
 
loadClassWithoutExceptionHandling(String, boolean) - 类 中的方法org.apache.flink.util.FlinkUserCodeClassLoader
Same as FlinkUserCodeClassLoader.loadClass(String, boolean) but without exception handling.
loadConfigParameters(Configuration) - 类 中的静态方法org.apache.flink.api.common.io.DelimitedInputFormat
 
loadConfiguration() - 类 中的静态方法org.apache.flink.configuration.GlobalConfiguration
Loads the global configuration from the environment.
loadConfiguration(Configuration) - 类 中的静态方法org.apache.flink.configuration.GlobalConfiguration
Loads the global configuration and adds the given dynamic properties configuration.
loadConfiguration(String) - 类 中的静态方法org.apache.flink.configuration.GlobalConfiguration
Loads the configuration files from the specified directory.
loadConfiguration(String, Configuration) - 类 中的静态方法org.apache.flink.configuration.GlobalConfiguration
Loads the configuration files from the specified directory.
loadGlobalConfigParams() - 类 中的静态方法org.apache.flink.api.common.io.DelimitedInputFormat
已过时。
Please use loadConfigParameters(Configuration config
LOCAL_DATE - 类 中的静态变量org.apache.flink.api.common.typeinfo.LocalTimeTypeInfo
 
LOCAL_DATE - 类 中的静态变量org.apache.flink.api.common.typeinfo.Types
Returns type information for LocalDate.
LOCAL_DATE_TIME - 类 中的静态变量org.apache.flink.api.common.typeinfo.LocalTimeTypeInfo
 
LOCAL_DATE_TIME - 类 中的静态变量org.apache.flink.api.common.typeinfo.Types
Returns type information for LocalDateTime.
LOCAL_NUMBER_JOB_MANAGER - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
 
LOCAL_NUMBER_RESOURCE_MANAGER - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
LOCAL_NUMBER_RESOURCE_MANAGER - 类 中的静态变量org.apache.flink.configuration.ResourceManagerOptions
已过时。
LOCAL_NUMBER_TASK_MANAGER - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
Sets the number of local task managers.
LOCAL_RECOVERY - 类 中的静态变量org.apache.flink.configuration.CheckpointingOptions
This option configures local recovery for this state backend.
LOCAL_RECOVERY_TASK_MANAGER_STATE_ROOT_DIRS - 类 中的静态变量org.apache.flink.configuration.CheckpointingOptions
The config parameter defining the root directories for storing file-based state for local recovery.
LOCAL_START_WEBSERVER - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
Has no effect; the web-server is always started. Will be removed in 2.0.
LOCAL_TIME - 类 中的静态变量org.apache.flink.api.common.typeinfo.LocalTimeTypeInfo
 
LOCAL_TIME - 类 中的静态变量org.apache.flink.api.common.typeinfo.Types
Returns type information for LocalTime.
LocalBlockLocation - org.apache.flink.core.fs.local中的类
Implementation of the BlockLocation interface for a local file system.
LocalBlockLocation(long) - 类 的构造器org.apache.flink.core.fs.local.LocalBlockLocation
 
LocalDataInputStream - org.apache.flink.core.fs.local中的类
The LocalDataInputStream class is a wrapper class for a data input stream to the local file system.
LocalDataInputStream(File) - 类 的构造器org.apache.flink.core.fs.local.LocalDataInputStream
Constructs a new LocalDataInputStream object from a given File object.
LocalDataOutputStream - org.apache.flink.core.fs.local中的类
The LocalDataOutputStream class is a wrapper class for a data output stream to the local file system.
LocalDataOutputStream(File) - 类 的构造器org.apache.flink.core.fs.local.LocalDataOutputStream
Constructs a new LocalDataOutputStream object from a given File object.
LocalDateComparator - org.apache.flink.api.common.typeutils.base中的类
This class can not extend BasicTypeComparator, because LocalDate is a Comparable of ChronoLocalDate instead of Comparable of LocalDate.
LocalDateComparator(boolean) - 类 的构造器org.apache.flink.api.common.typeutils.base.LocalDateComparator
 
LocalDateSerializer - org.apache.flink.api.common.typeutils.base中的类
 
LocalDateSerializer() - 类 的构造器org.apache.flink.api.common.typeutils.base.LocalDateSerializer
 
LocalDateSerializer.LocalDateSerializerSnapshot - org.apache.flink.api.common.typeutils.base中的类
Serializer configuration snapshot for compatibility and format evolution.
LocalDateSerializerSnapshot() - 类 的构造器org.apache.flink.api.common.typeutils.base.LocalDateSerializer.LocalDateSerializerSnapshot
 
LocalDateTimeComparator - org.apache.flink.api.common.typeutils.base中的类
This class can not extend BasicTypeComparator, because LocalDateTime is a Comparable of ChronoLocalDateTime instead of Comparable of LocalDateTime.
LocalDateTimeComparator(boolean) - 类 的构造器org.apache.flink.api.common.typeutils.base.LocalDateTimeComparator
 
LocalDateTimeSerializer - org.apache.flink.api.common.typeutils.base中的类
 
LocalDateTimeSerializer() - 类 的构造器org.apache.flink.api.common.typeutils.base.LocalDateTimeSerializer
 
LocalDateTimeSerializer.LocalDateTimeSerializerSnapshot - org.apache.flink.api.common.typeutils.base中的类
Serializer configuration snapshot for compatibility and format evolution.
LocalDateTimeSerializerSnapshot() - 类 的构造器org.apache.flink.api.common.typeutils.base.LocalDateTimeSerializer.LocalDateTimeSerializerSnapshot
 
LocalFileStatus - org.apache.flink.core.fs.local中的类
The class LocalFileStatus provides an implementation of the FileStatus interface for the local file system.
LocalFileStatus(File, FileSystem) - 类 的构造器org.apache.flink.core.fs.local.LocalFileStatus
Creates a LocalFileStatus object from a given File object.
LocalFileSystem - org.apache.flink.core.fs.local中的类
The class LocalFileSystem is an implementation of the FileSystem interface for the local file system of the machine where the JVM runs.
LocalFileSystem() - 类 的构造器org.apache.flink.core.fs.local.LocalFileSystem
Constructs a new LocalFileSystem object.
LocalFileSystemFactory - org.apache.flink.core.fs.local中的类
A factory for the LocalFileSystem.
LocalFileSystemFactory() - 类 的构造器org.apache.flink.core.fs.local.LocalFileSystemFactory
 
LocalRecoverableWriter - org.apache.flink.core.fs.local中的类
LocalRecoverableWriter(LocalFileSystem) - 类 的构造器org.apache.flink.core.fs.local.LocalRecoverableWriter
 
LocalTimeComparator - org.apache.flink.api.common.typeutils.base中的类
 
LocalTimeComparator(boolean) - 类 的构造器org.apache.flink.api.common.typeutils.base.LocalTimeComparator
 
LocalTimeSerializer - org.apache.flink.api.common.typeutils.base中的类
 
LocalTimeSerializer() - 类 的构造器org.apache.flink.api.common.typeutils.base.LocalTimeSerializer
 
LocalTimeSerializer.LocalTimeSerializerSnapshot - org.apache.flink.api.common.typeutils.base中的类
Serializer configuration snapshot for compatibility and format evolution.
LocalTimeSerializerSnapshot() - 类 的构造器org.apache.flink.api.common.typeutils.base.LocalTimeSerializer.LocalTimeSerializerSnapshot
 
LocalTimeTypeInfo<T extends java.time.temporal.Temporal> - org.apache.flink.api.common.typeinfo中的类
Type information for Java LocalDate/LocalTime/LocalDateTime.
LocalTimeTypeInfo(Class<T>, TypeSerializer<T>, Class<? extends TypeComparator<T>>) - 类 的构造器org.apache.flink.api.common.typeinfo.LocalTimeTypeInfo
 
LocatableInputSplit - org.apache.flink.core.io中的类
A locatable input split is an input split referring to input data which is located on one or more hosts.
LocatableInputSplit(int, String[]) - 类 的构造器org.apache.flink.core.io.LocatableInputSplit
Creates a new locatable input split that refers to a multiple host as its data location.
LocatableInputSplit(int, String) - 类 的构造器org.apache.flink.core.io.LocatableInputSplit
Creates a new locatable input split that refers to a single host as its data location.
LocatableInputSplitAssigner - org.apache.flink.api.common.io中的类
The locatable input split assigner assigns to each host splits that are local, before assigning splits that are not local.
LocatableInputSplitAssigner(Collection<LocatableInputSplit>) - 类 的构造器org.apache.flink.api.common.io.LocatableInputSplitAssigner
 
LocatableInputSplitAssigner(LocatableInputSplit[]) - 类 的构造器org.apache.flink.api.common.io.LocatableInputSplitAssigner
 
LocatedFileStatus - org.apache.flink.core.fs中的接口
A LocatedFileStatus is a FileStatus that contains additionally the location information of the file directly.
log2floor(int) - 类 中的静态方法org.apache.flink.util.MathUtils
Computes the logarithm of the given value to the base of 2, rounded down.
log2strict(int) - 类 中的静态方法org.apache.flink.util.MathUtils
Computes the logarithm of the given value to the base of 2.
LOG_LIFECYCLE_EVENTS - 类 中的静态变量org.apache.flink.configuration.AkkaOptions
Log lifecycle events.
LOG_PATH - 类 中的静态变量org.apache.flink.configuration.WebOptions
The log file location (may be in /log for standalone but under log directory when using YARN).
LONG - 类 中的静态变量org.apache.flink.api.common.typeinfo.Types
Returns type information for both a primitive long and Long.
LONG_ARRAY_TYPE_INFO - 类 中的静态变量org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
 
LONG_PRIMITIVE_ARRAY_TYPE_INFO - 类 中的静态变量org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
 
LONG_TYPE_INFO - 类 中的静态变量org.apache.flink.api.common.typeinfo.BasicTypeInfo
 
LONG_VALUE_TYPE_INFO - 类 中的静态变量org.apache.flink.api.java.typeutils.ValueTypeInfo
 
LongComparator - org.apache.flink.api.common.typeutils.base中的类
 
LongComparator(boolean) - 类 的构造器org.apache.flink.api.common.typeutils.base.LongComparator
 
LongCounter - org.apache.flink.api.common.accumulators中的类
An accumulator that sums up long values.
LongCounter() - 类 的构造器org.apache.flink.api.common.accumulators.LongCounter
 
LongCounter(long) - 类 的构造器org.apache.flink.api.common.accumulators.LongCounter
 
LongFunctionWithException<R,E extends Throwable> - org.apache.flink.util.function中的接口
Similar to LongFunction but can throw Exception.
LongMaximum - org.apache.flink.api.common.accumulators中的类
An accumulator that finds the maximum long value.
LongMaximum() - 类 的构造器org.apache.flink.api.common.accumulators.LongMaximum
 
LongMaximum(long) - 类 的构造器org.apache.flink.api.common.accumulators.LongMaximum
 
LongMinimum - org.apache.flink.api.common.accumulators中的类
An accumulator that finds the minimum long value.
LongMinimum() - 类 的构造器org.apache.flink.api.common.accumulators.LongMinimum
 
LongMinimum(long) - 类 的构造器org.apache.flink.api.common.accumulators.LongMinimum
 
LongParser - org.apache.flink.types.parser中的类
Parses a decimal text field into a LongValue.
LongParser() - 类 的构造器org.apache.flink.types.parser.LongParser
 
LongPrimitiveArrayComparator - org.apache.flink.api.common.typeutils.base.array中的类
 
LongPrimitiveArrayComparator(boolean) - 类 的构造器org.apache.flink.api.common.typeutils.base.array.LongPrimitiveArrayComparator
 
LongPrimitiveArraySerializer - org.apache.flink.api.common.typeutils.base.array中的类
A serializer for long arrays.
LongPrimitiveArraySerializer() - 类 的构造器org.apache.flink.api.common.typeutils.base.array.LongPrimitiveArraySerializer
 
LongPrimitiveArraySerializer.LongPrimitiveArraySerializerSnapshot - org.apache.flink.api.common.typeutils.base.array中的类
Serializer configuration snapshot for compatibility and format evolution.
LongPrimitiveArraySerializerSnapshot() - 类 的构造器org.apache.flink.api.common.typeutils.base.array.LongPrimitiveArraySerializer.LongPrimitiveArraySerializerSnapshot
 
LongSerializer - org.apache.flink.api.common.typeutils.base中的类
Type serializer for Long.
LongSerializer() - 类 的构造器org.apache.flink.api.common.typeutils.base.LongSerializer
 
LongSerializer.LongSerializerSnapshot - org.apache.flink.api.common.typeutils.base中的类
Serializer configuration snapshot for compatibility and format evolution.
LongSerializerSnapshot() - 类 的构造器org.apache.flink.api.common.typeutils.base.LongSerializer.LongSerializerSnapshot
 
LongSumAggregator - org.apache.flink.api.common.aggregators中的类
An Aggregator that sums up long values.
LongSumAggregator() - 类 的构造器org.apache.flink.api.common.aggregators.LongSumAggregator
 
longToIntWithBitMixing(long) - 类 中的静态方法org.apache.flink.util.MathUtils
Pseudo-randomly maps a long (64-bit) to an integer (32-bit) using some bit-mixing for better distribution.
longType() - 类 中的方法org.apache.flink.configuration.ConfigOptions.OptionBuilder
Defines that the value of the option should be of Long type.
LongValue - org.apache.flink.types中的类
Boxed serializable and comparable long integer type, representing the primitive type long.
LongValue() - 类 的构造器org.apache.flink.types.LongValue
Initializes the encapsulated long with 0.
LongValue(long) - 类 的构造器org.apache.flink.types.LongValue
Initializes the encapsulated long with the specified value.
LongValueComparator - org.apache.flink.api.common.typeutils.base中的类
Specialized comparator for LongValue based on CopyableValueComparator.
LongValueComparator(boolean) - 类 的构造器org.apache.flink.api.common.typeutils.base.LongValueComparator
 
LongValueParser - org.apache.flink.types.parser中的类
Parses a decimal text field into a LongValue.
LongValueParser() - 类 的构造器org.apache.flink.types.parser.LongValueParser
 
LongValueSequenceIterator - org.apache.flink.util中的类
The LongValueSequenceIterator is an iterator that returns a sequence of numbers (as LongValue)s.
LongValueSequenceIterator(long, long) - 类 的构造器org.apache.flink.util.LongValueSequenceIterator
Creates a new splittable iterator, returning the range [from, to].
LongValueSerializer - org.apache.flink.api.common.typeutils.base中的类
 
LongValueSerializer() - 类 的构造器org.apache.flink.api.common.typeutils.base.LongValueSerializer
 
LongValueSerializer.LongValueSerializerSnapshot - org.apache.flink.api.common.typeutils.base中的类
Serializer configuration snapshot for compatibility and format evolution.
LongValueSerializerSnapshot() - 类 的构造器org.apache.flink.api.common.typeutils.base.LongValueSerializer.LongValueSerializerSnapshot
 
LongZeroConvergence - org.apache.flink.api.common.aggregators中的类
A ConvergenceCriterion over an Aggregator that defines convergence as reached once the aggregator holds the value zero.
LongZeroConvergence() - 类 的构造器org.apache.flink.api.common.aggregators.LongZeroConvergence
 
LOOKUP_TIMEOUT - 类 中的静态变量org.apache.flink.configuration.AkkaOptions
LOOKUP_TIMEOUT_DURATION - 类 中的静态变量org.apache.flink.configuration.AkkaOptions
Timeout for all blocking calls that look up remote actors.
lookupMatch(PT) - 类 中的方法org.apache.flink.api.common.operators.util.JoinHashMap.Prober
 
lowerPart - 类 中的变量org.apache.flink.util.AbstractID
The lower part of the actual ID.

M

MailboxExecutor - org.apache.flink.api.common.operators中的接口
Executor like interface for an build around a mailbox-based execution model.
makeQualified(FileSystem) - 类 中的方法org.apache.flink.core.fs.Path
Returns a qualified path object.
makeSpace(int) - 类 中的方法org.apache.flink.types.Record
Reserves space for at least the given number of fields in the internal arrays.
MANAGED_MEMORY_CONSUMER_NAME_DATAPROC - 类 中的静态变量org.apache.flink.configuration.TaskManagerOptions
MANAGED_MEMORY_CONSUMER_NAME_OPERATOR - 类 中的静态变量org.apache.flink.configuration.TaskManagerOptions
 
MANAGED_MEMORY_CONSUMER_NAME_PYTHON - 类 中的静态变量org.apache.flink.configuration.TaskManagerOptions
 
MANAGED_MEMORY_CONSUMER_NAME_STATE_BACKEND - 类 中的静态变量org.apache.flink.configuration.TaskManagerOptions
 
MANAGED_MEMORY_CONSUMER_WEIGHTS - 类 中的静态变量org.apache.flink.configuration.TaskManagerOptions
Weights of managed memory consumers.
MANAGED_MEMORY_FRACTION - 类 中的静态变量org.apache.flink.configuration.TaskManagerOptions
Fraction of Total Flink Memory to be used as Managed Memory, if TaskManagerOptions.MANAGED_MEMORY_SIZE is not specified.
MANAGED_MEMORY_SIZE - 类 中的静态变量org.apache.flink.configuration.TaskManagerOptions
Managed Memory size for TaskExecutors.
ManagedMemoryUseCase - org.apache.flink.core.memory中的枚举
Use cases of managed memory.
ManagedMemoryUseCase.Scope - org.apache.flink.core.memory中的枚举
Scope at which memory is managed for a use case.
ManualClock - org.apache.flink.util.clock中的类
A Clock implementation which allows to advance time manually.
ManualClock() - 类 的构造器org.apache.flink.util.clock.ManualClock
 
ManualClock(long) - 类 的构造器org.apache.flink.util.clock.ManualClock
 
map(T) - 接口 中的方法org.apache.flink.api.common.functions.MapFunction
The mapping method.
map(IN) - 类 中的方法org.apache.flink.api.common.functions.RichMapFunction
 
MAP(TypeInformation<K>, TypeInformation<V>) - 类 中的静态方法org.apache.flink.api.common.typeinfo.Types
Returns type information for a Java Map.
map(Function<? super T, ? extends R>) - 类 中的方法org.apache.flink.types.SerializableOptional
 
MapFunction<T,O> - org.apache.flink.api.common.functions中的接口
Base interface for Map functions.
MapOperatorBase<IN,OUT,FT extends MapFunction<IN,OUT>> - org.apache.flink.api.common.operators.base中的类
 
MapOperatorBase(UserCodeWrapper<FT>, UnaryOperatorInformation<IN, OUT>, String) - 类 的构造器org.apache.flink.api.common.operators.base.MapOperatorBase
 
MapOperatorBase(FT, UnaryOperatorInformation<IN, OUT>, String) - 类 的构造器org.apache.flink.api.common.operators.base.MapOperatorBase
 
MapOperatorBase(Class<? extends FT>, UnaryOperatorInformation<IN, OUT>, String) - 类 的构造器org.apache.flink.api.common.operators.base.MapOperatorBase
 
mapPartition(Iterable<T>, Collector<O>) - 接口 中的方法org.apache.flink.api.common.functions.MapPartitionFunction
A user-implemented function that modifies or transforms an incoming object.
mapPartition(Iterable<I>, Collector<O>) - 类 中的方法org.apache.flink.api.common.functions.RichMapPartitionFunction
 
MapPartitionFunction<T,O> - org.apache.flink.api.common.functions中的接口
Interface for "mapPartition" functions.
MapPartitionOperatorBase<IN,OUT,FT extends MapPartitionFunction<IN,OUT>> - org.apache.flink.api.common.operators.base中的类
 
MapPartitionOperatorBase(UserCodeWrapper<FT>, UnaryOperatorInformation<IN, OUT>, String) - 类 的构造器org.apache.flink.api.common.operators.base.MapPartitionOperatorBase
 
MapPartitionOperatorBase(FT, UnaryOperatorInformation<IN, OUT>, String) - 类 的构造器org.apache.flink.api.common.operators.base.MapPartitionOperatorBase
 
MapPartitionOperatorBase(Class<? extends FT>, UnaryOperatorInformation<IN, OUT>, String) - 类 的构造器org.apache.flink.api.common.operators.base.MapPartitionOperatorBase
 
MapSerializer<K,V> - org.apache.flink.api.common.typeutils.base中的类
A serializer for Map.
MapSerializer(TypeSerializer<K>, TypeSerializer<V>) - 类 的构造器org.apache.flink.api.common.typeutils.base.MapSerializer
Creates a map serializer that uses the given serializers to serialize the key-value pairs in the map.
MapSerializerConfigSnapshot<K,V> - org.apache.flink.api.common.typeutils.base中的类
已过时。
this snapshot class should not be used by any serializer anymore.
MapSerializerConfigSnapshot() - 类 的构造器org.apache.flink.api.common.typeutils.base.MapSerializerConfigSnapshot
已过时。
This empty nullary constructor is required for deserializing the configuration.
MapSerializerConfigSnapshot(TypeSerializer<K>, TypeSerializer<V>) - 类 的构造器org.apache.flink.api.common.typeutils.base.MapSerializerConfigSnapshot
已过时。
 
MapSerializerSnapshot<K,V> - org.apache.flink.api.common.typeutils.base中的类
Snapshot class for the MapSerializer.
MapSerializerSnapshot() - 类 的构造器org.apache.flink.api.common.typeutils.base.MapSerializerSnapshot
Constructor for read instantiation.
MapSerializerSnapshot(MapSerializer<K, V>) - 类 的构造器org.apache.flink.api.common.typeutils.base.MapSerializerSnapshot
Constructor to create the snapshot for writing.
MapState<UK,UV> - org.apache.flink.api.common.state中的接口
State interface for partitioned key-value state.
MapStateDescriptor<UK,UV> - org.apache.flink.api.common.state中的类
MapStateDescriptor(String, TypeSerializer<UK>, TypeSerializer<UV>) - 类 的构造器org.apache.flink.api.common.state.MapStateDescriptor
Create a new MapStateDescriptor with the given name and the given type serializers.
MapStateDescriptor(String, TypeInformation<UK>, TypeInformation<UV>) - 类 的构造器org.apache.flink.api.common.state.MapStateDescriptor
Create a new MapStateDescriptor with the given name and the given type information.
MapStateDescriptor(String, Class<UK>, Class<UV>) - 类 的构造器org.apache.flink.api.common.state.MapStateDescriptor
Create a new MapStateDescriptor with the given name and the given type information.
mapType() - 类 中的方法org.apache.flink.configuration.ConfigOptions.OptionBuilder
Defines that the value of the option should be a set of properties, which can be represented as Map<String, String>.
MapTypeInfo<K,V> - org.apache.flink.api.java.typeutils中的类
Special TypeInformation used by MapStateDescriptor.
MapTypeInfo(TypeInformation<K>, TypeInformation<V>) - 类 的构造器org.apache.flink.api.java.typeutils.MapTypeInfo
 
MapTypeInfo(Class<K>, Class<V>) - 类 的构造器org.apache.flink.api.java.typeutils.MapTypeInfo
 
MapValue<K extends Value,V extends Value> - org.apache.flink.types中的类
Generic map base type for PACT programs that implements the Value and Map interfaces.
MapValue() - 类 的构造器org.apache.flink.types.MapValue
Initializes the encapsulated map with an empty HashMap.
MapValue(Map<K, V>) - 类 的构造器org.apache.flink.types.MapValue
Initializes the encapsulated map with a HashMap filled with all entries of the provided map.
mapWithIndex(Collection<T>, BiFunction<T, Integer, R>) - 类 中的静态方法org.apache.flink.util.CollectionUtil
 
mark(int) - 类 中的方法org.apache.flink.core.fs.FSDataInputStreamWrapper
 
mark(int) - 类 中的方法org.apache.flink.core.memory.MemorySegmentInputStreamWithPos
 
markActive() - 接口 中的方法org.apache.flink.api.common.eventtime.WatermarkOutput
Marks this output as active, meaning that downstream operations should wait for watermarks from this output.
markIdle() - 接口 中的方法org.apache.flink.api.common.eventtime.WatermarkOutput
Marks this output as idle, meaning that downstream operations do not wait for watermarks from this output.
markIdle() - 接口 中的方法org.apache.flink.api.connector.source.ReaderOutput
Marks this output as idle, meaning that downstream operations do not wait for watermarks from this output.
markSupported() - 类 中的方法org.apache.flink.core.fs.FSDataInputStreamWrapper
 
markSupported() - 类 中的方法org.apache.flink.core.memory.MemorySegmentInputStreamWithPos
 
MaskUtils - org.apache.flink.api.java.typeutils.runtime中的类
Utilities for reading and writing binary masks.
MaskUtils() - 类 的构造器org.apache.flink.api.java.typeutils.runtime.MaskUtils
 
MathUtils - org.apache.flink.util中的类
Collection of simple mathematical routines.
MAX_ARITY - 类 中的静态变量org.apache.flink.api.java.tuple.Tuple
 
MAX_ARRAY_SIZE - 类 中的静态变量org.apache.flink.util.CollectionUtil
A safe maximum size for arrays in the JVM.
MAX_ATTEMPTS_HISTORY_SIZE - 类 中的静态变量org.apache.flink.configuration.JobManagerOptions
The maximum number of prior execution attempts kept in history.
MAX_EXCEPTION_HISTORY_SIZE - 类 中的静态变量org.apache.flink.configuration.WebOptions
The maximum number of failures kept in the exception history.
MAX_PARALLELISM - 类 中的静态变量org.apache.flink.configuration.PipelineOptions
 
MAX_REGISTRATION_TIMEOUT - 类 中的静态变量org.apache.flink.configuration.ClusterOptions
 
MAX_RETAINED_CHECKPOINTS - 类 中的静态变量org.apache.flink.configuration.CheckpointingOptions
The maximum number of completed checkpoints to retain.
MAX_SLOT_NUM - 类 中的静态变量org.apache.flink.configuration.ResourceManagerOptions
 
MAX_TOTAL_CPU - 类 中的静态变量org.apache.flink.configuration.ResourceManagerOptions
 
MAX_TOTAL_MEM - 类 中的静态变量org.apache.flink.configuration.ResourceManagerOptions
 
MAX_VALUE - 类 中的静态变量org.apache.flink.configuration.MemorySize
 
MAX_WATERMARK - 类 中的静态变量org.apache.flink.api.common.eventtime.Watermark
The watermark that signifies end-of-event-time.
MEMORY_SEGMENT_SIZE - 类 中的静态变量org.apache.flink.configuration.TaskManagerOptions
Size of memory buffers used by the network stack and the memory manager.
MemorySegment - org.apache.flink.core.memory中的类
This class represents a piece of memory managed by Flink.
MemorySegmentFactory - org.apache.flink.core.memory中的类
A factory for memory segments (MemorySegment).
MemorySegmentFactory() - 类 的构造器org.apache.flink.core.memory.MemorySegmentFactory
 
MemorySegmentInputStreamWithPos - org.apache.flink.core.memory中的类
Un-synchronized input stream using the given memory segment.
MemorySegmentInputStreamWithPos(MemorySegment, int, int) - 类 的构造器org.apache.flink.core.memory.MemorySegmentInputStreamWithPos
 
MemorySegmentProvider - org.apache.flink.core.memory中的接口
The provider used for requesting and releasing batch of memory segments.
MemorySegmentSource - org.apache.flink.core.memory中的接口
Interface describing entities that can provide memory segments.
MemorySegmentWritable - org.apache.flink.core.memory中的接口
Provides the interface for write(Segment).
MemorySize - org.apache.flink.configuration中的类
MemorySize is a representation of a number of bytes, viewable in different units.
MemorySize(long) - 类 的构造器org.apache.flink.configuration.MemorySize
Constructs a new MemorySize.
MemorySize.MemoryUnit - org.apache.flink.configuration中的枚举
Enum which defines memory unit, mostly used to parse value from configuration file.
memoryType() - 类 中的方法org.apache.flink.configuration.ConfigOptions.OptionBuilder
Defines that the value of the option should be of MemorySize type.
MemoryUtils - org.apache.flink.core.memory中的类
Utility class for memory operations.
merge(Accumulator<V, R>) - 接口 中的方法org.apache.flink.api.common.accumulators.Accumulator
Used by system internally to merge the collected parts of an accumulator at the end of the job.
merge(Accumulator<Double, Double>) - 类 中的方法org.apache.flink.api.common.accumulators.AverageAccumulator
 
merge(Accumulator<Double, Double>) - 类 中的方法org.apache.flink.api.common.accumulators.DoubleCounter
 
merge(Accumulator<Double, Double>) - 类 中的方法org.apache.flink.api.common.accumulators.DoubleMaximum
 
merge(Accumulator<Double, Double>) - 类 中的方法org.apache.flink.api.common.accumulators.DoubleMinimum
 
merge(Accumulator<Integer, TreeMap<Integer, Integer>>) - 类 中的方法org.apache.flink.api.common.accumulators.Histogram
 
merge(Accumulator<Integer, Integer>) - 类 中的方法org.apache.flink.api.common.accumulators.IntCounter
 
merge(Accumulator<Integer, Integer>) - 类 中的方法org.apache.flink.api.common.accumulators.IntMaximum
 
merge(Accumulator<Integer, Integer>) - 类 中的方法org.apache.flink.api.common.accumulators.IntMinimum
 
merge(Accumulator<T, ArrayList<T>>) - 类 中的方法org.apache.flink.api.common.accumulators.ListAccumulator
 
merge(Accumulator<Long, Long>) - 类 中的方法org.apache.flink.api.common.accumulators.LongCounter
 
merge(Accumulator<Long, Long>) - 类 中的方法org.apache.flink.api.common.accumulators.LongMaximum
 
merge(Accumulator<Long, Long>) - 类 中的方法org.apache.flink.api.common.accumulators.LongMinimum
 
merge(Accumulator<T, ArrayList<byte[]>>) - 类 中的方法org.apache.flink.api.common.accumulators.SerializedListAccumulator
 
merge(ACC, ACC) - 接口 中的方法org.apache.flink.api.common.functions.AggregateFunction
Merges two accumulators, returning an accumulator with the merged state.
merge(ACC, ACC) - 类 中的方法org.apache.flink.api.common.functions.RichAggregateFunction
 
merge(ResourceSpec) - 类 中的方法org.apache.flink.api.common.operators.ResourceSpec
Used by system internally to merge the other resources of chained operators when generating the job graph.
merge(T) - 类 中的方法org.apache.flink.api.common.resources.Resource
 
mergeInto(Map<String, OptionalFailure<Accumulator<?, ?>>>, Map<String, Accumulator<?, ?>>) - 类 中的静态方法org.apache.flink.api.common.accumulators.AccumulatorHelper
Merge two collections of accumulators.
mergeRightIntoLeft(LinkedOptionalMap<K, V>, LinkedOptionalMap<K, V>) - 类 中的静态方法org.apache.flink.util.LinkedOptionalMap
Tries to merges the keys and the values of @right into @left.
MergingState<IN,OUT> - org.apache.flink.api.common.state中的接口
Extension of AppendingState that allows merging of state.
MESOS_ARTIFACT_SERVER_PORT_KEY - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
has no effect
MESOS_ARTIFACT_SERVER_SSL_ENABLED - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
has no effect
MESOS_FAILOVER_TIMEOUT_SECONDS - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
has no effect
MESOS_INITIAL_TASKS - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
has no effect
MESOS_MASTER_URL - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
has no effect
MESOS_MAX_FAILED_TASKS - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
has no effect
MESOS_RESOURCEMANAGER_FRAMEWORK_NAME - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
has no effect
MESOS_RESOURCEMANAGER_FRAMEWORK_PRINCIPAL - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
has no effect
MESOS_RESOURCEMANAGER_FRAMEWORK_ROLE - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
has no effect
MESOS_RESOURCEMANAGER_FRAMEWORK_SECRET - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
has no effect
MESOS_RESOURCEMANAGER_FRAMEWORK_USER - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
has no effect
METRIC_FETCHER_UPDATE_INTERVAL - 类 中的静态变量org.apache.flink.configuration.MetricOptions
The config parameter defining the update interval for the metric fetcher used by the web UI in milliseconds.
metricGroup() - 接口 中的方法org.apache.flink.api.connector.sink.Sink.InitContext
 
metricGroup() - 接口 中的方法org.apache.flink.api.connector.source.SourceReaderContext
 
metricGroup() - 接口 中的方法org.apache.flink.api.connector.source.SplitEnumeratorContext
 
MetricOptions - org.apache.flink.configuration中的类
Configuration options for metrics and metric reporters.
METRICS_LATENCY_HISTORY_SIZE - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
METRICS_REPORTER_CLASS_SUFFIX - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
The class of the reporter to use.
METRICS_REPORTER_EXCLUDED_VARIABLES - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
The set of variables that should be excluded.
METRICS_REPORTER_FACTORY_CLASS_SUFFIX - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
The class of the reporter factory to use.
METRICS_REPORTER_INTERVAL_SUFFIX - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
The interval between reports.
METRICS_REPORTER_PREFIX - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
The prefix for per-reporter configs.
METRICS_REPORTER_SCOPE_DELIMITER - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
The delimiter used to assemble the metric identifier.
METRICS_REPORTERS_LIST - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
METRICS_SCOPE_DELIMITER - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
METRICS_SCOPE_NAMING_JM - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
METRICS_SCOPE_NAMING_JM_JOB - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
METRICS_SCOPE_NAMING_OPERATOR - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
METRICS_SCOPE_NAMING_TASK - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
METRICS_SCOPE_NAMING_TM - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
METRICS_SCOPE_NAMING_TM_JOB - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
MIGRATION_NOT_SUPPORTED_MSG - 异常错误 中的静态变量org.apache.flink.util.StateMigrationException
 
milliseconds(long) - 类 中的静态方法org.apache.flink.api.common.time.Time
Creates a new Time that represents the given number of milliseconds.
MIN_JVM_HEAP_SIZE - 类 中的静态变量org.apache.flink.configuration.JobManagerOptions
 
MIN_MEMORY_SEGMENT_SIZE - 类 中的静态变量org.apache.flink.configuration.TaskManagerOptions
Minimum possible size of memory buffers used by the network stack and the memory manager.
MIN_PARALLELISM_INCREASE - 类 中的静态变量org.apache.flink.configuration.JobManagerOptions
 
minSplitSize - 类 中的变量org.apache.flink.api.common.io.FileInputFormat
The minimal split size, set by the configure() method.
minutes(long) - 类 中的静态方法org.apache.flink.api.common.time.Time
Creates a new Time that represents the given number of minutes.
missingKeys() - 类 中的方法org.apache.flink.util.LinkedOptionalMap.MergeResult
 
MissingTypeInfo - org.apache.flink.api.java.typeutils中的类
A special type information signifying that the type extraction failed.
MissingTypeInfo(String) - 类 的构造器org.apache.flink.api.java.typeutils.MissingTypeInfo
 
MissingTypeInfo(String, InvalidTypesException) - 类 的构造器org.apache.flink.api.java.typeutils.MissingTypeInfo
 
mkdirs(Path) - 类 中的方法org.apache.flink.core.fs.FileSystem
Make the given file and all non-existent parents into directories.
mkdirs(Path) - 类 中的方法org.apache.flink.core.fs.LimitedConnectionsFileSystem
 
mkdirs(Path) - 类 中的方法org.apache.flink.core.fs.local.LocalFileSystem
Recursively creates the directory specified by the provided path.
mkdirs(Path) - 类 中的方法org.apache.flink.core.fs.SafetyNetWrapperFileSystem
 
monitorUserSystemExitForCurrentThread() - 类 中的静态方法org.apache.flink.core.security.FlinkSecurityManager
 
multiply(BigDecimal) - 类 中的方法org.apache.flink.api.common.resources.Resource
 
multiply(int) - 类 中的方法org.apache.flink.api.common.resources.Resource
 
multiply(double) - 类 中的方法org.apache.flink.configuration.MemorySize
 
MultisetTypeInfo<T> - org.apache.flink.api.java.typeutils中的类
A TypeInformation for the Multiset types of the Java API.
MultisetTypeInfo(Class<T>) - 类 的构造器org.apache.flink.api.java.typeutils.MultisetTypeInfo
 
MultisetTypeInfo(TypeInformation<T>) - 类 的构造器org.apache.flink.api.java.typeutils.MultisetTypeInfo
 
murmurHash(int) - 类 中的静态方法org.apache.flink.util.MathUtils
This function hashes an integer value.
MutableObjectIterator<E> - org.apache.flink.util中的接口
A simple iterator interface.

N

name - 类 中的变量org.apache.flink.api.common.operators.Operator
 
NAME - 类 中的静态变量org.apache.flink.api.common.resources.CPUResource
 
name - 类 中的变量org.apache.flink.api.common.state.StateDescriptor
Name that uniquely identifies state created from this StateDescriptor.
name - 类 中的变量org.apache.flink.api.dag.Transformation
 
NAME - 类 中的静态变量org.apache.flink.configuration.PipelineOptions
The job name used for printing and logging.
NamedFlatFieldDescriptor(String, int, TypeInformation<?>) - 类 的构造器org.apache.flink.api.java.typeutils.PojoTypeInfo.NamedFlatFieldDescriptor
 
NATIVE_BLOCK_SIZE - 类 中的静态变量org.apache.flink.api.common.io.BinaryInputFormat
 
NATIVE_BLOCK_SIZE - 类 中的静态变量org.apache.flink.api.common.io.BinaryOutputFormat
 
NATIVE_BYTE_ORDER - 类 中的静态变量org.apache.flink.core.memory.MemoryUtils
The native byte order of the platform on which the system currently runs.
NestedSerializersSnapshotDelegate - org.apache.flink.api.common.typeutils中的类
A NestedSerializersSnapshotDelegate represents the snapshots of multiple serializers that are used by an outer serializer.
NestedSerializersSnapshotDelegate(TypeSerializer<?>...) - 类 的构造器org.apache.flink.api.common.typeutils.NestedSerializersSnapshotDelegate
Constructor to create a snapshot for writing.
NettyShuffleEnvironmentOptions - org.apache.flink.configuration中的类
The set of configuration options relating to network stack.
NetUtils - org.apache.flink.util中的类
Utility for various network related tasks (such as finding free ports).
NetUtils() - 类 的构造器org.apache.flink.util.NetUtils
 
NetUtils.SocketFactory - org.apache.flink.util中的接口
A factory for a local socket from port number.
NETWORK_BATCH_SHUFFLE_READ_MEMORY - 类 中的静态变量org.apache.flink.configuration.TaskManagerOptions
Size of direct memory used by blocking shuffle for shuffle data read (currently only used by sort-merge shuffle).
NETWORK_BLOCKING_SHUFFLE_TYPE - 类 中的静态变量org.apache.flink.configuration.NettyShuffleEnvironmentOptions
 
NETWORK_BUFFERS_MEMORY_FRACTION - 类 中的静态变量org.apache.flink.configuration.NettyShuffleEnvironmentOptions
NETWORK_BUFFERS_MEMORY_MAX - 类 中的静态变量org.apache.flink.configuration.NettyShuffleEnvironmentOptions
已过时。
NETWORK_BUFFERS_MEMORY_MIN - 类 中的静态变量org.apache.flink.configuration.NettyShuffleEnvironmentOptions
已过时。
NETWORK_BUFFERS_PER_CHANNEL - 类 中的静态变量org.apache.flink.configuration.NettyShuffleEnvironmentOptions
Number of network buffers to use for each outgoing/incoming channel (subpartition/input channel).
NETWORK_DETAILED_METRICS - 类 中的静态变量org.apache.flink.configuration.NettyShuffleEnvironmentOptions
Boolean flag to enable/disable more detailed metrics about inbound/outbound network queue lengths.
NETWORK_EXCLUSIVE_BUFFERS_REQUEST_TIMEOUT_MILLISECONDS - 类 中的静态变量org.apache.flink.configuration.NettyShuffleEnvironmentOptions
The timeout for requesting exclusive buffers for each channel.
NETWORK_EXTRA_BUFFERS_PER_GATE - 类 中的静态变量org.apache.flink.configuration.NettyShuffleEnvironmentOptions
Number of extra network buffers to use for each outgoing/incoming gate (result partition/input gate).
NETWORK_MAX_BUFFERS_PER_CHANNEL - 类 中的静态变量org.apache.flink.configuration.NettyShuffleEnvironmentOptions
Number of max buffers can be used for each output subparition.
NETWORK_MEMORY_FRACTION - 类 中的静态变量org.apache.flink.configuration.TaskManagerOptions
Fraction of Total Flink Memory to be used as Network Memory.
NETWORK_MEMORY_MAX - 类 中的静态变量org.apache.flink.configuration.TaskManagerOptions
Max Network Memory size for TaskExecutors.
NETWORK_MEMORY_MIN - 类 中的静态变量org.apache.flink.configuration.TaskManagerOptions
Min Network Memory size for TaskExecutors.
NETWORK_NUM_BUFFERS - 类 中的静态变量org.apache.flink.configuration.NettyShuffleEnvironmentOptions
NETWORK_REQUEST_BACKOFF_INITIAL - 类 中的静态变量org.apache.flink.configuration.NettyShuffleEnvironmentOptions
Minimum backoff for partition requests of input channels.
NETWORK_REQUEST_BACKOFF_MAX - 类 中的静态变量org.apache.flink.configuration.NettyShuffleEnvironmentOptions
Maximum backoff for partition requests of input channels.
NETWORK_RETRIES - 类 中的静态变量org.apache.flink.configuration.NettyShuffleEnvironmentOptions
 
NETWORK_SORT_SHUFFLE_MIN_BUFFERS - 类 中的静态变量org.apache.flink.configuration.NettyShuffleEnvironmentOptions
Minimum number of network buffers required per sort-merge blocking result partition.
NETWORK_SORT_SHUFFLE_MIN_PARALLELISM - 类 中的静态变量org.apache.flink.configuration.NettyShuffleEnvironmentOptions
Parallelism threshold to switch between sort-merge based blocking shuffle and the default hash-based blocking shuffle.
NeverCompleteFuture - org.apache.flink.util.concurrent中的类
A future that never completes.
NeverCompleteFuture(long) - 类 的构造器org.apache.flink.util.concurrent.NeverCompleteFuture
 
neverReturnExpired() - 类 中的方法org.apache.flink.api.common.state.StateTtlConfig.Builder
 
newBuilder(double, int) - 类 中的静态方法org.apache.flink.api.common.operators.ResourceSpec
 
newBuilder(double, MemorySize) - 类 中的静态方法org.apache.flink.api.common.operators.ResourceSpec
 
newBuilder(String) - 类 中的静态方法org.apache.flink.api.common.operators.SlotSharingGroup
 
newBuilder(Time) - 类 中的静态方法org.apache.flink.api.common.state.StateTtlConfig
 
newDirectExecutorService() - 类 中的静态方法org.apache.flink.util.concurrent.Executors
Return a new direct executor service.
newInstance(int) - 类 中的静态方法org.apache.flink.api.java.tuple.Tuple
 
newInstance() - 类 中的方法org.apache.flink.configuration.description.Formatter
 
newInstance() - 类 中的方法org.apache.flink.configuration.description.HtmlFormatter
 
newInstance(Class<T>) - 类 中的静态方法org.apache.flink.util.ReflectionUtil
 
newThread(Runnable) - 类 中的方法org.apache.flink.util.concurrent.ExecutorThreadFactory
 
next() - 类 中的方法org.apache.flink.api.common.functions.util.CopyingIterator
 
next() - 类 中的方法org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase.SimpleListIterable.SimpleListIterator
 
next() - 类 中的方法org.apache.flink.api.common.operators.util.ListKeyGroupedIterator.ValuesIterator
 
next() - 类 中的方法org.apache.flink.util.CloseableIterator.IteratorAdapter
 
next() - 类 中的方法org.apache.flink.util.LongValueSequenceIterator
 
next(E) - 接口 中的方法org.apache.flink.util.MutableObjectIterator
Gets the next element from the collection.
next() - 接口 中的方法org.apache.flink.util.MutableObjectIterator
Gets the next element from the collection.
next() - 类 中的方法org.apache.flink.util.NumberSequenceIterator
 
next(StringValue) - 类 中的方法org.apache.flink.util.StringValueUtils.WhitespaceTokenizer
Gets the next token from the string.
next() - 类 中的方法org.apache.flink.util.UnionIterator
 
next(int) - 类 中的方法org.apache.flink.util.XORShiftRandom
All other methods like nextInt()/nextDouble()... depends on this, so we just need to overwrite this.
nextKey() - 类 中的方法org.apache.flink.api.common.operators.util.ListKeyGroupedIterator
Moves the iterator to the next key.
nextRecord(T) - 类 中的方法org.apache.flink.api.common.io.BinaryInputFormat
 
nextRecord(OT) - 类 中的方法org.apache.flink.api.common.io.DelimitedInputFormat
 
nextRecord(OT) - 接口 中的方法org.apache.flink.api.common.io.InputFormat
Reads the next record from the input.
nextRecord(OT) - 类 中的方法org.apache.flink.api.common.io.ReplicatingInputFormat
 
nextSegment() - 接口 中的方法org.apache.flink.core.memory.MemorySegmentSource
Gets the next memory segment.
nextStringEndPos(byte[], int, int, byte[]) - 类 中的方法org.apache.flink.types.parser.FieldParser
Returns the end position of a string.
nextStringLength(byte[], int, int, char) - 类 中的静态方法org.apache.flink.types.parser.FieldParser
Returns the length of a string.
NO_INDEX - 类 中的静态变量org.apache.flink.api.java.typeutils.TypeExtractor
 
NO_TIMESTAMP - 接口 中的静态变量org.apache.flink.api.common.eventtime.TimestampAssigner
The value that is passed to TimestampAssigner.extractTimestamp(T, long) when there is no previous timestamp attached to the record.
noDefaultValue() - 类 中的方法org.apache.flink.configuration.ConfigOptions.ListConfigOptionBuilder
Creates a ConfigOption without a default value.
noDefaultValue() - 类 中的方法org.apache.flink.configuration.ConfigOptions.OptionBuilder
已过时。
define the type explicitly first with one of the intType(), stringType(), etc.
noDefaultValue() - 类 中的方法org.apache.flink.configuration.ConfigOptions.TypedConfigOptionBuilder
Creates a ConfigOption without a default value.
NoFetchingInput - org.apache.flink.api.java.typeutils.runtime中的类
 
NoFetchingInput(InputStream) - 类 的构造器org.apache.flink.api.java.typeutils.runtime.NoFetchingInput
 
nonBlockingShutdown(long, TimeUnit, ExecutorService...) - 类 中的静态方法org.apache.flink.util.ExecutorUtils
Shuts the given ExecutorService down in a non-blocking fashion.
NONE - 类 中的静态变量org.apache.flink.configuration.ExternalResourceOptions
Indicate an empty external resources list.
NonParallelInput - org.apache.flink.api.common.io中的接口
This interface acts as a marker for input formats for inputs which cannot be split.
NonSerializableUserCodeException - org.apache.flink.api.common中的异常错误
An special case of the InvalidProgramException, indicating that a part of the program that needs to be serializable (for shipping) is not serializable.
NonSerializableUserCodeException() - 异常错误 的构造器org.apache.flink.api.common.NonSerializableUserCodeException
Creates a new exception with no message.
NonSerializableUserCodeException(String) - 异常错误 的构造器org.apache.flink.api.common.NonSerializableUserCodeException
Creates a new exception with the given message.
NOOP_EXCEPTION_HANDLER - 类 中的静态变量org.apache.flink.util.FlinkUserCodeClassLoader
 
NoOpFunction - org.apache.flink.api.common.functions.util中的类
An AbstractRichFunction that does nothing.
NoOpFunction() - 类 的构造器org.apache.flink.api.common.functions.util.NoOpFunction
 
noRestart() - 类 中的静态方法org.apache.flink.api.common.restartstrategy.RestartStrategies
Generates NoRestartStrategyConfiguration.
NoRestartStrategyConfiguration() - 类 的构造器org.apache.flink.api.common.restartstrategy.RestartStrategies.NoRestartStrategyConfiguration
 
NormalizableKey<T> - org.apache.flink.types中的接口
The base interface for normalizable keys.
normalizableKeyPrefixLen - 类 中的变量org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
 
normalizedKeyLengths - 类 中的变量org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
 
NormalizedKeyUtil - org.apache.flink.api.common.typeutils.base中的类
Utilities related to TypeComparator.
NormalizedKeyUtil() - 类 的构造器org.apache.flink.api.common.typeutils.base.NormalizedKeyUtil
 
Nothing - org.apache.flink.types中的类
A type for (synthetic) operators that do not output data.
NothingTypeInfo - org.apache.flink.api.common.typeinfo中的类
Placeholder type information for the Nothing type.
NothingTypeInfo() - 类 的构造器org.apache.flink.api.common.typeinfo.NothingTypeInfo
 
notifyCheckpointAborted(long) - 接口 中的方法org.apache.flink.api.common.state.CheckpointListener
This method is called as a notification once a distributed checkpoint has been aborted.
notifyCheckpointComplete(long) - 接口 中的方法org.apache.flink.api.common.state.CheckpointListener
Notifies the listener that the checkpoint with the given checkpointId completed and was committed.
notifyCheckpointComplete(long) - 接口 中的方法org.apache.flink.api.connector.source.SourceReader
We have an empty default implementation here because most source readers do not have to implement the method.
notifyCheckpointComplete(long) - 接口 中的方法org.apache.flink.api.connector.source.SplitEnumerator
We have an empty default implementation here because most source readers do not have to implement the method.
notifyNoMoreSplits() - 类 中的方法org.apache.flink.api.connector.source.lib.util.IteratorSourceReader
 
notifyNoMoreSplits() - 接口 中的方法org.apache.flink.api.connector.source.SourceReader
This method is called when the reader is notified that it will not receive any further splits.
notSupported() - 异常错误 中的静态方法org.apache.flink.util.StateMigrationException
 
now() - 类 中的静态方法org.apache.flink.api.common.time.Deadline
Constructs a Deadline that has now as the deadline.
noWatermarks() - 接口 中的静态方法org.apache.flink.api.common.eventtime.WatermarkStrategy
Creates a watermark strategy that generates no watermarks at all.
NoWatermarksGenerator<E> - org.apache.flink.api.common.eventtime中的类
An implementation of a WatermarkGenerator that generates no Watermarks.
NoWatermarksGenerator() - 类 的构造器org.apache.flink.api.common.eventtime.NoWatermarksGenerator
 
NULL_VALUE_TYPE_INFO - 类 中的静态变量org.apache.flink.api.java.typeutils.ValueTypeInfo
 
NullableSerializer<T> - org.apache.flink.api.java.typeutils.runtime中的类
Serializer wrapper to add support of null value serialization.
NullableSerializer.NullableSerializerConfigSnapshot<T> - org.apache.flink.api.java.typeutils.runtime中的类
已过时。
this snapshot class is no longer in use, and is maintained only for backwards compatibility purposes. It is fully replaced by NullableSerializer.NullableSerializerSnapshot.
NullableSerializer.NullableSerializerSnapshot<T> - org.apache.flink.api.java.typeutils.runtime中的类
Snapshot for serializers of nullable types, containing the snapshot of its original serializer.
NullableSerializerConfigSnapshot() - 类 的构造器org.apache.flink.api.java.typeutils.runtime.NullableSerializer.NullableSerializerConfigSnapshot
已过时。
This empty nullary constructor is required for deserializing the configuration.
NullableSerializerSnapshot() - 类 的构造器org.apache.flink.api.java.typeutils.runtime.NullableSerializer.NullableSerializerSnapshot
 
NullableSerializerSnapshot(NullableSerializer<T>) - 类 的构造器org.apache.flink.api.java.typeutils.runtime.NullableSerializer.NullableSerializerSnapshot
 
NullAwareComparator<T> - org.apache.flink.api.java.typeutils.runtime中的类
Null-aware comparator that wraps a comparator which does not support null references.
NullAwareComparator(TypeComparator<T>, boolean) - 类 的构造器org.apache.flink.api.java.typeutils.runtime.NullAwareComparator
 
NullByteKeySelector<T> - org.apache.flink.api.java.functions中的类
Used as a dummy KeySelector to allow using keyed operators for non-keyed use cases.
NullByteKeySelector() - 类 的构造器org.apache.flink.api.java.functions.NullByteKeySelector
 
NullFieldException - org.apache.flink.types中的异常错误
An exception specifying that a required field was not set in a record, i.e. was null .
NullFieldException() - 异常错误 的构造器org.apache.flink.types.NullFieldException
Constructs an NullFieldException with null as its error detail message.
NullFieldException(String) - 异常错误 的构造器org.apache.flink.types.NullFieldException
Constructs an NullFieldException with the specified detail message.
NullFieldException(int) - 异常错误 的构造器org.apache.flink.types.NullFieldException
Constructs an NullFieldException with a default message, referring to given field number as the null field.
NullFieldException(int, Throwable) - 异常错误 的构造器org.apache.flink.types.NullFieldException
Constructs an NullFieldException with a default message, referring to given field number as the null field and a cause (Throwable)
nullFn() - 类 中的静态方法org.apache.flink.util.function.FunctionUtils
Function which returns null (type: Void).
NullKeyFieldException - org.apache.flink.types中的异常错误
An exception specifying that a required key field was not set in a record, i.e. was null .
NullKeyFieldException() - 异常错误 的构造器org.apache.flink.types.NullKeyFieldException
Constructs an NullKeyFieldException with null as its error detail message.
NullKeyFieldException(NullFieldException) - 异常错误 的构造器org.apache.flink.types.NullKeyFieldException
Constructs an NullKeyFieldException with a default message, referring to the field number given in the NullFieldException.
NullKeyFieldException(String) - 异常错误 的构造器org.apache.flink.types.NullKeyFieldException
Constructs an NullKeyFieldException with the specified detail message.
NullKeyFieldException(int) - 异常错误 的构造器org.apache.flink.types.NullKeyFieldException
Constructs an NullKeyFieldException with a default message, referring to given field number as the null key field.
NullValue - org.apache.flink.types中的类
Null base type for programs that implements the Key interface.
NullValue() - 类 的构造器org.apache.flink.types.NullValue
Creates a NullValue object.
NullValueComparator - org.apache.flink.api.common.typeutils.base中的类
Specialized comparator for NullValue based on CopyableValueComparator.
NullValueSerializer - org.apache.flink.api.common.typeutils.base中的类
 
NullValueSerializer() - 类 的构造器org.apache.flink.api.common.typeutils.base.NullValueSerializer
 
NullValueSerializer.NullValueSerializerSnapshot - org.apache.flink.api.common.typeutils.base中的类
Serializer configuration snapshot for compatibility and format evolution.
NullValueSerializerSnapshot() - 类 的构造器org.apache.flink.api.common.typeutils.base.NullValueSerializer.NullValueSerializerSnapshot
 
NUM_ARENAS - 类 中的静态变量org.apache.flink.configuration.NettyShuffleEnvironmentOptions
 
NUM_RECORDS_UNKNOWN - 接口 中的静态变量org.apache.flink.api.common.io.statistics.BaseStatistics
Constant indicating that the number of records is unknown;
NUM_TASK_SLOTS - 类 中的静态变量org.apache.flink.configuration.TaskManagerOptions
The config parameter defining the number of task slots of a task manager.
NUM_THREADS_CLIENT - 类 中的静态变量org.apache.flink.configuration.NettyShuffleEnvironmentOptions
 
NUM_THREADS_SERVER - 类 中的静态变量org.apache.flink.configuration.NettyShuffleEnvironmentOptions
 
NumberSequenceIterator - org.apache.flink.util中的类
The NumberSequenceIterator is an iterator that returns a sequence of numbers (as Long)s.
NumberSequenceIterator(long, long) - 类 的构造器org.apache.flink.util.NumberSequenceIterator
Creates a new splittable iterator, returning the range [from, to].
NumberSequenceSource - org.apache.flink.api.connector.source.lib中的类
A data source that produces a sequence of numbers (longs).
NumberSequenceSource(long, long) - 类 的构造器org.apache.flink.api.connector.source.lib.NumberSequenceSource
Creates a new NumberSequenceSource that produces parallel sequences covering the range from to to (both boundaries are inclusive).
NumberSequenceSource.NumberSequenceSplit - org.apache.flink.api.connector.source.lib中的类
A split of the source, representing a number sub-sequence.
NumberSequenceSplit(String, long, long) - 类 的构造器org.apache.flink.api.connector.source.lib.NumberSequenceSource.NumberSequenceSplit
 
NumericTypeInfo<T> - org.apache.flink.api.common.typeinfo中的类
Type information for numeric primitive types: int, long, double, byte, short, float, char.
NumericTypeInfo(Class<T>, Class<?>[], TypeSerializer<T>, Class<? extends TypeComparator<T>>) - 类 的构造器org.apache.flink.api.common.typeinfo.NumericTypeInfo
 
numLeadingNormalizableKeys - 类 中的变量org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
 
numSplits - 类 中的变量org.apache.flink.api.common.io.FileInputFormat
The desired number of splits, as set by the configure() method.

O

OBJECT_ARRAY(TypeInformation<E>) - 类 中的静态方法org.apache.flink.api.common.typeinfo.Types
Returns type information for Java arrays of object types (such as String[], Integer[]).
OBJECT_REUSE - 类 中的静态变量org.apache.flink.configuration.PipelineOptions
 
ObjectArrayTypeInfo<T,C> - org.apache.flink.api.java.typeutils中的类
 
obtainLeft(Either<L, R>, TypeSerializer<L>) - 类 中的静态方法org.apache.flink.types.Either
Utility function for EitherSerializer to support object reuse.
obtainRight(Either<L, R>, TypeSerializer<R>) - 类 中的静态方法org.apache.flink.types.Either
Utility function for EitherSerializer to support object reuse.
of(SerializableTimestampAssigner<T>) - 接口 中的静态方法org.apache.flink.api.common.eventtime.TimestampAssignerSupplier
 
of(long, TimeUnit) - 类 中的静态方法org.apache.flink.api.common.time.Time
Creates a new Time of the given duration and TimeUnit.
of(Class<T>) - 类 中的静态方法org.apache.flink.api.common.typeinfo.TypeInformation
Creates a TypeInformation for the type described by the given class.
of(TypeHint<T>) - 类 中的静态方法org.apache.flink.api.common.typeinfo.TypeInformation
Creates a TypeInformation for a generic type via a utility "type hint".
of(T0) - 类 中的静态方法org.apache.flink.api.java.tuple.Tuple1
Creates a new tuple and assigns the given values to the tuple's fields.
of(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9) - 类 中的静态方法org.apache.flink.api.java.tuple.Tuple10
Creates a new tuple and assigns the given values to the tuple's fields.
of(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10) - 类 中的静态方法org.apache.flink.api.java.tuple.Tuple11
Creates a new tuple and assigns the given values to the tuple's fields.
of(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11) - 类 中的静态方法org.apache.flink.api.java.tuple.Tuple12
Creates a new tuple and assigns the given values to the tuple's fields.
of(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12) - 类 中的静态方法org.apache.flink.api.java.tuple.Tuple13
Creates a new tuple and assigns the given values to the tuple's fields.
of(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13) - 类 中的静态方法org.apache.flink.api.java.tuple.Tuple14
Creates a new tuple and assigns the given values to the tuple's fields.
of(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14) - 类 中的静态方法org.apache.flink.api.java.tuple.Tuple15
Creates a new tuple and assigns the given values to the tuple's fields.
of(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15) - 类 中的静态方法org.apache.flink.api.java.tuple.Tuple16
Creates a new tuple and assigns the given values to the tuple's fields.
of(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16) - 类 中的静态方法org.apache.flink.api.java.tuple.Tuple17
Creates a new tuple and assigns the given values to the tuple's fields.
of(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17) - 类 中的静态方法org.apache.flink.api.java.tuple.Tuple18
Creates a new tuple and assigns the given values to the tuple's fields.
of(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18) - 类 中的静态方法org.apache.flink.api.java.tuple.Tuple19
Creates a new tuple and assigns the given values to the tuple's fields.
of(T0, T1) - 类 中的静态方法org.apache.flink.api.java.tuple.Tuple2
Creates a new tuple and assigns the given values to the tuple's fields.
of(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19) - 类 中的静态方法org.apache.flink.api.java.tuple.Tuple20
Creates a new tuple and assigns the given values to the tuple's fields.
of(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20) - 类 中的静态方法org.apache.flink.api.java.tuple.Tuple21
Creates a new tuple and assigns the given values to the tuple's fields.
of(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, T21) - 类 中的静态方法org.apache.flink.api.java.tuple.Tuple22
Creates a new tuple and assigns the given values to the tuple's fields.
of(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, T21, T22) - 类 中的静态方法org.apache.flink.api.java.tuple.Tuple23
Creates a new tuple and assigns the given values to the tuple's fields.
of(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, T21, T22, T23) - 类 中的静态方法org.apache.flink.api.java.tuple.Tuple24
Creates a new tuple and assigns the given values to the tuple's fields.
of(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) - 类 中的静态方法org.apache.flink.api.java.tuple.Tuple25
Creates a new tuple and assigns the given values to the tuple's fields.
of(T0, T1, T2) - 类 中的静态方法org.apache.flink.api.java.tuple.Tuple3
Creates a new tuple and assigns the given values to the tuple's fields.
of(T0, T1, T2, T3) - 类 中的静态方法org.apache.flink.api.java.tuple.Tuple4
Creates a new tuple and assigns the given values to the tuple's fields.
of(T0, T1, T2, T3, T4) - 类 中的静态方法org.apache.flink.api.java.tuple.Tuple5
Creates a new tuple and assigns the given values to the tuple's fields.
of(T0, T1, T2, T3, T4, T5) - 类 中的静态方法org.apache.flink.api.java.tuple.Tuple6
Creates a new tuple and assigns the given values to the tuple's fields.
of(T0, T1, T2, T3, T4, T5, T6) - 类 中的静态方法org.apache.flink.api.java.tuple.Tuple7
Creates a new tuple and assigns the given values to the tuple's fields.
of(T0, T1, T2, T3, T4, T5, T6, T7) - 类 中的静态方法org.apache.flink.api.java.tuple.Tuple8
Creates a new tuple and assigns the given values to the tuple's fields.
of(T0, T1, T2, T3, T4, T5, T6, T7, T8) - 类 中的静态方法org.apache.flink.api.java.tuple.Tuple9
Creates a new tuple and assigns the given values to the tuple's fields.
of(FileSystemFactory) - 类 中的静态方法org.apache.flink.core.fs.PluginFileSystemFactory
 
of(L) - 类 中的静态方法org.apache.flink.types.Either.Left
Creates a left value of Either
of(R) - 类 中的静态方法org.apache.flink.types.Either.Right
Creates a right value of Either
of(Object...) - 类 中的静态方法org.apache.flink.types.Row
Creates a fixed-length row in position-based field mode and assigns the given values to the row's fields.
of(T) - 类 中的静态方法org.apache.flink.types.SerializableOptional
 
of(Optional<T>) - 类 中的静态方法org.apache.flink.util.OptionalConsumer
 
of(T) - 类 中的静态方法org.apache.flink.util.OptionalFailure
 
of(ClassLoader) - 类 中的静态方法org.apache.flink.util.TemporaryClassLoaderContext
Sets the context class loader to the given ClassLoader and returns a resource that sets it back to the current context ClassLoader when the resource is closed.
ofElement(E, Consumer<E>) - 接口 中的静态方法org.apache.flink.util.CloseableIterator
 
ofElements(Consumer<T>, T...) - 接口 中的静态方法org.apache.flink.util.CloseableIterator
 
OFF_HEAP_MEMORY - 类 中的静态变量org.apache.flink.configuration.JobManagerOptions
Off-heap Memory size for the JobManager.
ofFailure(Throwable) - 类 中的静态方法org.apache.flink.util.OptionalFailure
 
OFFLOAD_MINSIZE - 类 中的静态变量org.apache.flink.configuration.BlobServerOptions
The minimum size for messages to be offloaded to the BlobServer.
ofKind(RowKind, Object...) - 类 中的静态方法org.apache.flink.types.Row
Creates a fixed-length row in position-based field mode with given kind and assigns the given values to the row's fields.
ofMebiBytes(long) - 类 中的静态方法org.apache.flink.configuration.MemorySize
 
ofNullable(T) - 类 中的静态方法org.apache.flink.types.SerializableOptional
 
onEvent(T, long, WatermarkOutput) - 类 中的方法org.apache.flink.api.common.eventtime.BoundedOutOfOrdernessWatermarks
 
onEvent(E, long, WatermarkOutput) - 类 中的方法org.apache.flink.api.common.eventtime.NoWatermarksGenerator
 
onEvent(T, long, WatermarkOutput) - 接口 中的方法org.apache.flink.api.common.eventtime.WatermarkGenerator
Called for every event, allows the watermark generator to examine and remember the event timestamps, or to emit a watermark based on the event itself.
onEvent(T, long, WatermarkOutput) - 类 中的方法org.apache.flink.api.common.eventtime.WatermarksWithIdleness
 
onJobExecuted(JobExecutionResult, Throwable) - 接口 中的方法org.apache.flink.core.execution.JobListener
Callback on job execution finished, successfully or unsuccessfully.
onJobSubmitted(JobClient, Throwable) - 接口 中的方法org.apache.flink.core.execution.JobListener
Callback on job submission.
onPeriodicEmit(WatermarkOutput) - 类 中的方法org.apache.flink.api.common.eventtime.BoundedOutOfOrdernessWatermarks
 
onPeriodicEmit(WatermarkOutput) - 类 中的方法org.apache.flink.api.common.eventtime.NoWatermarksGenerator
 
onPeriodicEmit(WatermarkOutput) - 接口 中的方法org.apache.flink.api.common.eventtime.WatermarkGenerator
Called periodically, and might emit a new watermark, or not.
onPeriodicEmit() - 类 中的方法org.apache.flink.api.common.eventtime.WatermarkOutputMultiplexer
Tells the WatermarkOutputMultiplexer to combine all outstanding deferred watermark updates and possibly emit a new update to the underlying WatermarkOutput.
onPeriodicEmit(WatermarkOutput) - 类 中的方法org.apache.flink.api.common.eventtime.WatermarksWithIdleness
 
onProcessingTime(long) - 接口 中的方法org.apache.flink.api.connector.sink.Sink.ProcessingTimeService.ProcessingTimeCallback
This method is invoked with the time which the callback register for.
open(Configuration) - 类 中的方法org.apache.flink.api.common.functions.AbstractRichFunction
 
open(Configuration) - 接口 中的方法org.apache.flink.api.common.functions.RichFunction
Initialization method for the function.
open(int, int) - 类 中的方法org.apache.flink.api.common.functions.util.PrintSinkOutputWriter
 
open(FileInputSplit) - 类 中的方法org.apache.flink.api.common.io.BinaryInputFormat
 
open(int, int) - 类 中的方法org.apache.flink.api.common.io.BinaryOutputFormat
 
open(FileInputSplit) - 类 中的方法org.apache.flink.api.common.io.DelimitedInputFormat
Opens the given input split.
open(FileInputSplit) - 类 中的方法org.apache.flink.api.common.io.FileInputFormat
Opens an input stream to the file defined in the input format.
open(int, int) - 类 中的方法org.apache.flink.api.common.io.FileOutputFormat
 
open(GenericInputSplit) - 类 中的方法org.apache.flink.api.common.io.GenericInputFormat
 
open(T) - 接口 中的方法org.apache.flink.api.common.io.InputFormat
Opens a parallel instance of the input format to work on a split.
open(int, int) - 接口 中的方法org.apache.flink.api.common.io.OutputFormat
Opens a parallel instance of the output format to store the result of its parallel instance.
open(RuntimeContext) - 接口 中的方法org.apache.flink.api.common.io.ratelimiting.FlinkConnectorRateLimiter
A method that can be used to create and configure a ratelimiter based on the runtimeContext.
open(RuntimeContext) - 类 中的方法org.apache.flink.api.common.io.ratelimiting.GuavaFlinkConnectorRateLimiter
Creates a rate limiter with the runtime context provided.
open(S) - 类 中的方法org.apache.flink.api.common.io.ReplicatingInputFormat
 
open(Configuration) - 类 中的方法org.apache.flink.api.common.operators.base.BulkIterationBase.TerminationCriterionMapper
 
open(DeserializationSchema.InitializationContext) - 接口 中的方法org.apache.flink.api.common.serialization.DeserializationSchema
Initialization method for the schema.
open(SerializationSchema.InitializationContext) - 接口 中的方法org.apache.flink.api.common.serialization.SerializationSchema
Initialization method for the schema.
open(Path, int) - 类 中的方法org.apache.flink.core.fs.FileSystem
Opens an FSDataInputStream at the indicated Path.
open(Path) - 类 中的方法org.apache.flink.core.fs.FileSystem
Opens an FSDataInputStream at the indicated Path.
open(Path, int) - 类 中的方法org.apache.flink.core.fs.LimitedConnectionsFileSystem
 
open(Path) - 类 中的方法org.apache.flink.core.fs.LimitedConnectionsFileSystem
 
open(Path, int) - 类 中的方法org.apache.flink.core.fs.local.LocalFileSystem
 
open(Path) - 类 中的方法org.apache.flink.core.fs.local.LocalFileSystem
 
open(Path) - 类 中的方法org.apache.flink.core.fs.local.LocalRecoverableWriter
 
open(Path) - 接口 中的方法org.apache.flink.core.fs.RecoverableWriter
Opens a new recoverable stream to write to the given path.
open(Path, int) - 类 中的方法org.apache.flink.core.fs.SafetyNetWrapperFileSystem
 
open(Path) - 类 中的方法org.apache.flink.core.fs.SafetyNetWrapperFileSystem
 
openFunction(Function, Configuration) - 类 中的静态方法org.apache.flink.api.common.functions.util.FunctionUtils
 
openInputFormat() - 类 中的方法org.apache.flink.api.common.io.ReplicatingInputFormat
 
openInputFormat() - 类 中的方法org.apache.flink.api.common.io.RichInputFormat
Opens this InputFormat instance.
openTimeout - 类 中的变量org.apache.flink.api.common.io.FileInputFormat
Stream opening timeout.
OperatingSystem - org.apache.flink.util中的枚举
An enumeration indicating the operating system that the JVM runs on.
Operator<OUT> - org.apache.flink.api.common.operators中的类
Abstract base class for all operators.
Operator(OperatorInformation<OUT>, String) - 类 的构造器org.apache.flink.api.common.operators.Operator
Creates a new contract with the given name.
OPERATOR_CHAINING - 类 中的静态变量org.apache.flink.configuration.PipelineOptions
 
operatorInfo - 类 中的变量org.apache.flink.api.common.operators.Operator
The return type of the user function.
OperatorInformation<OUT> - org.apache.flink.api.common.operators中的类
A class for holding information about an operator, such as input/output TypeInformation.
OperatorInformation(TypeInformation<OUT>) - 类 的构造器org.apache.flink.api.common.operators.OperatorInformation
 
OperatorStateStore - org.apache.flink.api.common.state中的接口
This interface contains methods for registering operator state with a managed store.
OperatorValidationUtils - org.apache.flink.api.common.operators.util中的类
Utils for checking operators' resource and parallelism settings.
OptimizerOptions - org.apache.flink.configuration中的类
Configuration options for the optimizer.
OptimizerOptions() - 类 的构造器org.apache.flink.configuration.OptimizerOptions
 
OptionalConsumer<T> - org.apache.flink.util中的类
Utility class which allows to run code depending on whether the optional has a value or is empty.
OptionalFailure<T> - org.apache.flink.util中的类
Wrapper around an object representing either a success (with a given value) or a failure cause.
optionalMapOf(Map<K, V>, Function<K, String>) - 类 中的静态方法org.apache.flink.util.LinkedOptionalMap
Creates an LinkedOptionalMap from the provided map.
Order - org.apache.flink.api.common.operators中的枚举
Enumeration representing order.
Ordering - org.apache.flink.api.common.operators中的类
This class represents an ordering on a set of fields.
Ordering() - 类 的构造器org.apache.flink.api.common.operators.Ordering
Creates an empty ordering.
Ordering(int, Class<? extends Comparable<?>>, Order) - 类 的构造器org.apache.flink.api.common.operators.Ordering
 
orders - 类 中的变量org.apache.flink.api.common.operators.Ordering
 
org.apache.flink.api.common - 程序包 org.apache.flink.api.common
 
org.apache.flink.api.common.accumulators - 程序包 org.apache.flink.api.common.accumulators
 
org.apache.flink.api.common.aggregators - 程序包 org.apache.flink.api.common.aggregators
 
org.apache.flink.api.common.cache - 程序包 org.apache.flink.api.common.cache
 
org.apache.flink.api.common.distributions - 程序包 org.apache.flink.api.common.distributions
 
org.apache.flink.api.common.eventtime - 程序包 org.apache.flink.api.common.eventtime
 
org.apache.flink.api.common.externalresource - 程序包 org.apache.flink.api.common.externalresource
 
org.apache.flink.api.common.functions - 程序包 org.apache.flink.api.common.functions
 
org.apache.flink.api.common.functions.util - 程序包 org.apache.flink.api.common.functions.util
 
org.apache.flink.api.common.io - 程序包 org.apache.flink.api.common.io
 
org.apache.flink.api.common.io.compression - 程序包 org.apache.flink.api.common.io.compression
 
org.apache.flink.api.common.io.ratelimiting - 程序包 org.apache.flink.api.common.io.ratelimiting
 
org.apache.flink.api.common.io.statistics - 程序包 org.apache.flink.api.common.io.statistics
 
org.apache.flink.api.common.operators - 程序包 org.apache.flink.api.common.operators
 
org.apache.flink.api.common.operators.base - 程序包 org.apache.flink.api.common.operators.base
 
org.apache.flink.api.common.operators.util - 程序包 org.apache.flink.api.common.operators.util
 
org.apache.flink.api.common.resources - 程序包 org.apache.flink.api.common.resources
 
org.apache.flink.api.common.restartstrategy - 程序包 org.apache.flink.api.common.restartstrategy
 
org.apache.flink.api.common.serialization - 程序包 org.apache.flink.api.common.serialization
 
org.apache.flink.api.common.state - 程序包 org.apache.flink.api.common.state
 
org.apache.flink.api.common.time - 程序包 org.apache.flink.api.common.time
 
org.apache.flink.api.common.typeinfo - 程序包 org.apache.flink.api.common.typeinfo
 
org.apache.flink.api.common.typeutils - 程序包 org.apache.flink.api.common.typeutils
 
org.apache.flink.api.common.typeutils.base - 程序包 org.apache.flink.api.common.typeutils.base
 
org.apache.flink.api.common.typeutils.base.array - 程序包 org.apache.flink.api.common.typeutils.base.array
 
org.apache.flink.api.connector.sink - 程序包 org.apache.flink.api.connector.sink
 
org.apache.flink.api.connector.source - 程序包 org.apache.flink.api.connector.source
 
org.apache.flink.api.connector.source.lib - 程序包 org.apache.flink.api.connector.source.lib
 
org.apache.flink.api.connector.source.lib.util - 程序包 org.apache.flink.api.connector.source.lib.util
 
org.apache.flink.api.dag - 程序包 org.apache.flink.api.dag
 
org.apache.flink.api.java - 程序包 org.apache.flink.api.java
 
org.apache.flink.api.java.functions - 程序包 org.apache.flink.api.java.functions
 
org.apache.flink.api.java.tuple - 程序包 org.apache.flink.api.java.tuple
 
org.apache.flink.api.java.tuple.builder - 程序包 org.apache.flink.api.java.tuple.builder
 
org.apache.flink.api.java.typeutils - 程序包 org.apache.flink.api.java.typeutils
 
org.apache.flink.api.java.typeutils.runtime - 程序包 org.apache.flink.api.java.typeutils.runtime
 
org.apache.flink.api.java.typeutils.runtime.kryo - 程序包 org.apache.flink.api.java.typeutils.runtime.kryo
 
org.apache.flink.configuration - 程序包 org.apache.flink.configuration
 
org.apache.flink.configuration.description - 程序包 org.apache.flink.configuration.description
 
org.apache.flink.core.classloading - 程序包 org.apache.flink.core.classloading
 
org.apache.flink.core.execution - 程序包 org.apache.flink.core.execution
 
org.apache.flink.core.fs - 程序包 org.apache.flink.core.fs
 
org.apache.flink.core.fs.local - 程序包 org.apache.flink.core.fs.local
 
org.apache.flink.core.io - 程序包 org.apache.flink.core.io
 
org.apache.flink.core.memory - 程序包 org.apache.flink.core.memory
 
org.apache.flink.core.plugin - 程序包 org.apache.flink.core.plugin
 
org.apache.flink.core.security - 程序包 org.apache.flink.core.security
 
org.apache.flink.management.jmx - 程序包 org.apache.flink.management.jmx
 
org.apache.flink.types - 程序包 org.apache.flink.types
 
org.apache.flink.types.parser - 程序包 org.apache.flink.types.parser
 
org.apache.flink.util - 程序包 org.apache.flink.util
 
org.apache.flink.util.clock - 程序包 org.apache.flink.util.clock
 
org.apache.flink.util.concurrent - 程序包 org.apache.flink.util.concurrent
 
org.apache.flink.util.function - 程序包 org.apache.flink.util.function
 
orTimeout(CompletableFuture<T>, long, TimeUnit) - 类 中的静态方法org.apache.flink.util.concurrent.FutureUtils
Times the given future out after the timeout.
orTimeout(CompletableFuture<T>, long, TimeUnit, String) - 类 中的静态方法org.apache.flink.util.concurrent.FutureUtils
Times the given future out after the timeout.
orTimeout(CompletableFuture<T>, long, TimeUnit, Executor) - 类 中的静态方法org.apache.flink.util.concurrent.FutureUtils
Times the given future out after the timeout.
orTimeout(CompletableFuture<T>, long, TimeUnit, Executor, String) - 类 中的静态方法org.apache.flink.util.concurrent.FutureUtils
Times the given future out after the timeout.
OuterJoinOperatorBase<IN1,IN2,OUT,FT extends FlatJoinFunction<IN1,IN2,OUT>> - org.apache.flink.api.common.operators.base中的类
 
OuterJoinOperatorBase(UserCodeWrapper<FT>, BinaryOperatorInformation<IN1, IN2, OUT>, int[], int[], String, OuterJoinOperatorBase.OuterJoinType) - 类 的构造器org.apache.flink.api.common.operators.base.OuterJoinOperatorBase
 
OuterJoinOperatorBase(FT, BinaryOperatorInformation<IN1, IN2, OUT>, int[], int[], String, OuterJoinOperatorBase.OuterJoinType) - 类 的构造器org.apache.flink.api.common.operators.base.OuterJoinOperatorBase
 
OuterJoinOperatorBase(Class<? extends FT>, BinaryOperatorInformation<IN1, IN2, OUT>, int[], int[], String, OuterJoinOperatorBase.OuterJoinType) - 类 的构造器org.apache.flink.api.common.operators.base.OuterJoinOperatorBase
 
OuterJoinOperatorBase.OuterJoinType - org.apache.flink.api.common.operators.base中的枚举
 
outputFilePath - 类 中的变量org.apache.flink.api.common.io.FileOutputFormat
The path of the file to be written.
OutputFormat<IT> - org.apache.flink.api.common.io中的接口
The base interface for outputs that consumes records.
outputStream - 类 中的变量org.apache.flink.core.fs.FSDataOutputStreamWrapper
 
OutputStreamAndPath - org.apache.flink.core.fs中的类
An output stream and a path.
OutputStreamAndPath(FSDataOutputStream, Path) - 类 的构造器org.apache.flink.core.fs.OutputStreamAndPath
Creates a OutputStreamAndPath.
OutputTag<T> - org.apache.flink.util中的类
An OutputTag is a typed and named tag to use for tagging side outputs of an operator.
OutputTag(String) - 类 的构造器org.apache.flink.util.OutputTag
Creates a new named OutputTag with the given id.
OutputTag(String, TypeInformation<T>) - 类 的构造器org.apache.flink.util.OutputTag
Creates a new named OutputTag with the given id and output TypeInformation.
outputType - 类 中的变量org.apache.flink.api.common.operators.OperatorInformation
Output type of the operator
outputType - 类 中的变量org.apache.flink.api.dag.Transformation
 
outputView - 类 中的变量org.apache.flink.api.java.typeutils.runtime.DataOutputViewStream
 

P

PACKAGE_SEPARATOR - 类 中的静态变量org.apache.flink.util.FileUtils
 
PARALLELISM_AUTO_MAX - 类 中的静态变量org.apache.flink.api.common.ExecutionConfig
已过时。
PARALLELISM_DEFAULT - 类 中的静态变量org.apache.flink.api.common.ExecutionConfig
The flag value indicating use of the default parallelism.
PARALLELISM_UNKNOWN - 类 中的静态变量org.apache.flink.api.common.ExecutionConfig
The flag value indicating an unknown or unset parallelism.
ParameterlessTypeSerializerConfig<T> - org.apache.flink.api.common.typeutils中的类
已过时。
this snapshot class is no longer used by any serializers, and is maintained only for backward compatibility reasons. It is fully replaced by SimpleTypeSerializerSnapshot.
ParameterlessTypeSerializerConfig() - 类 的构造器org.apache.flink.api.common.typeutils.ParameterlessTypeSerializerConfig
已过时。
This empty nullary constructor is required for deserializing the configuration.
ParameterlessTypeSerializerConfig(String) - 类 的构造器org.apache.flink.api.common.typeutils.ParameterlessTypeSerializerConfig
已过时。
 
parameters - 类 中的变量org.apache.flink.api.common.operators.Operator
 
PARENT_FIRST_LOGGING_PATTERNS - 类 中的静态变量org.apache.flink.configuration.CoreOptions
 
parse(String) - 类 中的静态方法org.apache.flink.configuration.MemorySize
Parses the given string as as MemorySize.
parse(String, MemorySize.MemoryUnit) - 类 中的静态方法org.apache.flink.configuration.MemorySize
Parses the given string with a default unit.
parseBytes(String) - 类 中的静态方法org.apache.flink.configuration.MemorySize
Parses the given string as bytes.
parseCachedFilesFromString(List<String>) - 类 中的静态方法org.apache.flink.api.common.cache.DistributedCache
Parses a list of distributed cache entries encoded in a string.
parseDuration(String) - 类 中的静态方法org.apache.flink.util.TimeUtils
Parse the given string to a java Duration.
ParseException - 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() - 异常错误 的构造器org.apache.flink.api.common.io.ParseException
 
ParseException(String) - 异常错误 的构造器org.apache.flink.api.common.io.ParseException
 
ParseException(Throwable) - 异常错误 的构造器org.apache.flink.api.common.io.ParseException
 
ParseException(String, Throwable) - 异常错误 的构造器org.apache.flink.api.common.io.ParseException
 
parseField(byte[], int, int, byte[], BigDecimal) - 类 中的方法org.apache.flink.types.parser.BigDecParser
 
parseField(byte[], int, int) - 类 中的静态方法org.apache.flink.types.parser.BigDecParser
Static utility to parse a field of type BigDecimal from a byte sequence that represents text characters (such as when read from a file stream).
parseField(byte[], int, int, char) - 类 中的静态方法org.apache.flink.types.parser.BigDecParser
Static utility to parse a field of type BigDecimal from a byte sequence that represents text characters (such as when read from a file stream).
parseField(byte[], int, int, byte[], BigInteger) - 类 中的方法org.apache.flink.types.parser.BigIntParser
 
parseField(byte[], int, int) - 类 中的静态方法org.apache.flink.types.parser.BigIntParser
Static utility to parse a field of type BigInteger from a byte sequence that represents text characters (such as when read from a file stream).
parseField(byte[], int, int, char) - 类 中的静态方法org.apache.flink.types.parser.BigIntParser
Static utility to parse a field of type BigInteger from a byte sequence that represents text characters (such as when read from a file stream).
parseField(byte[], int, int, byte[], Boolean) - 类 中的方法org.apache.flink.types.parser.BooleanParser
 
parseField(byte[], int, int, byte[], BooleanValue) - 类 中的方法org.apache.flink.types.parser.BooleanValueParser
 
parseField(byte[], int, int, byte[], Byte) - 类 中的方法org.apache.flink.types.parser.ByteParser
 
parseField(byte[], int, int) - 类 中的静态方法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) - 类 中的静态方法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) - 类 中的方法org.apache.flink.types.parser.ByteValueParser
 
parseField(byte[], int, int, byte[], Double) - 类 中的方法org.apache.flink.types.parser.DoubleParser
 
parseField(byte[], int, int) - 类 中的静态方法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) - 类 中的静态方法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) - 类 中的方法org.apache.flink.types.parser.DoubleValueParser
 
parseField(byte[], int, int, byte[], T) - 类 中的方法org.apache.flink.types.parser.FieldParser
Each parser's logic should be implemented inside this method
parseField(byte[], int, int, byte[], Float) - 类 中的方法org.apache.flink.types.parser.FloatParser
 
parseField(byte[], int, int) - 类 中的静态方法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) - 类 中的静态方法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) - 类 中的方法org.apache.flink.types.parser.FloatValueParser
 
parseField(byte[], int, int, byte[], Integer) - 类 中的方法org.apache.flink.types.parser.IntParser
 
parseField(byte[], int, int) - 类 中的静态方法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) - 类 中的静态方法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) - 类 中的方法org.apache.flink.types.parser.IntValueParser
 
parseField(byte[], int, int, byte[], Long) - 类 中的方法org.apache.flink.types.parser.LongParser
 
parseField(byte[], int, int) - 类 中的静态方法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) - 类 中的静态方法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) - 类 中的方法org.apache.flink.types.parser.LongValueParser
 
parseField(byte[], int, int, byte[], Short) - 类 中的方法org.apache.flink.types.parser.ShortParser
 
parseField(byte[], int, int) - 类 中的静态方法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) - 类 中的静态方法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) - 类 中的方法org.apache.flink.types.parser.ShortValueParser
 
parseField(byte[], int, int, byte[], Date) - 类 中的方法org.apache.flink.types.parser.SqlDateParser
 
parseField(byte[], int, int) - 类 中的静态方法org.apache.flink.types.parser.SqlDateParser
Static utility to parse a field of type Date from a byte sequence that represents text characters (such as when read from a file stream).
parseField(byte[], int, int, char) - 类 中的静态方法org.apache.flink.types.parser.SqlDateParser
Static utility to parse a field of type Date from a byte sequence that represents text characters (such as when read from a file stream).
parseField(byte[], int, int, byte[], Time) - 类 中的方法org.apache.flink.types.parser.SqlTimeParser
 
parseField(byte[], int, int) - 类 中的静态方法org.apache.flink.types.parser.SqlTimeParser
Static utility to parse a field of type Time from a byte sequence that represents text characters (such as when read from a file stream).
parseField(byte[], int, int, char) - 类 中的静态方法org.apache.flink.types.parser.SqlTimeParser
Static utility to parse a field of type Time from a byte sequence that represents text characters (such as when read from a file stream).
parseField(byte[], int, int, byte[], Timestamp) - 类 中的方法org.apache.flink.types.parser.SqlTimestampParser
 
parseField(byte[], int, int) - 类 中的静态方法org.apache.flink.types.parser.SqlTimestampParser
Static utility to parse a field of type Timestamp from a byte sequence that represents text characters (such as when read from a file stream).
parseField(byte[], int, int, char) - 类 中的静态方法org.apache.flink.types.parser.SqlTimestampParser
Static utility to parse a field of type Timestamp from a byte sequence that represents text characters (such as when read from a file stream).
parseField(byte[], int, int, byte[], String) - 类 中的方法org.apache.flink.types.parser.StringParser
 
parseField(byte[], int, int, byte[], StringValue) - 类 中的方法org.apache.flink.types.parser.StringValueParser
 
parseHostPortAddress(String) - 类 中的静态方法org.apache.flink.util.NetUtils
Converts a string of the form "host:port" into an InetSocketAddress.
parseJvmArgString(String) - 类 中的静态方法org.apache.flink.configuration.ConfigurationUtils
 
parseLocalStateDirectories(Configuration) - 类 中的静态方法org.apache.flink.configuration.ConfigurationUtils
Extracts the local state directories as defined by CheckpointingOptions.LOCAL_RECOVERY_TASK_MANAGER_STATE_ROOT_DIRS.
parseMap(String) - 类 中的静态方法org.apache.flink.configuration.ConfigurationUtils
Parses a string as a map of strings.
parseParentFirstLoaderPatterns(String, String) - 类 中的静态方法org.apache.flink.configuration.CoreOptions
 
parseRecord(Object[], byte[], int, int) - 类 中的方法org.apache.flink.api.common.io.GenericCsvInputFormat
 
parseTempDirectories(Configuration) - 类 中的静态方法org.apache.flink.configuration.ConfigurationUtils
Extracts the task manager directories for temporary files as defined by CoreOptions.TMP_DIRS.
parseTmResourceDynamicConfigs(String) - 类 中的静态方法org.apache.flink.configuration.ConfigurationUtils
 
PartialSolutionPlaceHolder(BulkIterationBase<OT>, OperatorInformation<OT>) - 类 的构造器org.apache.flink.api.common.operators.base.BulkIterationBase.PartialSolutionPlaceHolder
 
partition(K, int) - 接口 中的方法org.apache.flink.api.common.functions.Partitioner
Computes the partition for the given key.
partition(Collection<T>, int) - 类 中的静态方法org.apache.flink.util.CollectionUtil
Partition a collection into approximately n buckets.
PARTITION_RELEASE_DURING_JOB_EXECUTION - 类 中的静态变量org.apache.flink.configuration.JobManagerOptions
Config parameter controlling whether partitions should already be released during the job execution.
Partitioner<K> - org.apache.flink.api.common.functions中的接口
Function to implement a custom partition assignment for keys.
partitionNumber - 类 中的变量org.apache.flink.api.common.io.GenericInputFormat
The partition of this split.
PartitionOperatorBase<IN> - org.apache.flink.api.common.operators.base中的类
 
PartitionOperatorBase(UnaryOperatorInformation<IN, IN>, PartitionOperatorBase.PartitionMethod, int[], String) - 类 的构造器org.apache.flink.api.common.operators.base.PartitionOperatorBase
 
PartitionOperatorBase(UnaryOperatorInformation<IN, IN>, PartitionOperatorBase.PartitionMethod, String) - 类 的构造器org.apache.flink.api.common.operators.base.PartitionOperatorBase
 
PartitionOperatorBase.PartitionMethod - org.apache.flink.api.common.operators.base中的枚举
 
path() - 类 中的方法org.apache.flink.core.fs.OutputStreamAndPath
 
Path - org.apache.flink.core.fs中的类
Names a file or directory in a FileSystem.
Path() - 类 的构造器org.apache.flink.core.fs.Path
Constructs a new (empty) path object (used to reconstruct path object after RPC call).
Path(URI) - 类 的构造器org.apache.flink.core.fs.Path
Constructs a path object from a given URI.
Path(String, String) - 类 的构造器org.apache.flink.core.fs.Path
Resolve a child path against a parent path.
Path(Path, String) - 类 的构造器org.apache.flink.core.fs.Path
Resolve a child path against a parent path.
Path(String, Path) - 类 的构造器org.apache.flink.core.fs.Path
Resolve a child path against a parent path.
Path(Path, Path) - 类 的构造器org.apache.flink.core.fs.Path
Resolve a child path against a parent path.
Path(String) - 类 的构造器org.apache.flink.core.fs.Path
Construct a path from a String.
Path(String, String, String) - 类 的构造器org.apache.flink.core.fs.Path
Construct a Path from a scheme, an authority and a path string.
PATH_HADOOP_CONFIG - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
Use environment variable HADOOP_CONF_DIR instead.
pathToFile(Path) - 类 中的方法org.apache.flink.core.fs.local.LocalFileSystem
Converts the given Path to a File for this file system.
persist() - 类 中的方法org.apache.flink.core.fs.RecoverableFsDataOutputStream
Ensures all data so far is persistent (similar to FSDataOutputStream.sync()) and returns a handle to recover the stream at the current position.
Pipeline - org.apache.flink.api.dag中的接口
Common interface for Flink pipelines.
PIPELINE_FIXED_JOB_ID - 类 中的静态变量org.apache.flink.configuration.PipelineOptionsInternal
 
PipelineExecutor - org.apache.flink.core.execution中的接口
The entity responsible for executing a Pipeline, i.e. a user job.
PipelineExecutorFactory - org.apache.flink.core.execution中的接口
A factory for selecting and instantiating the adequate PipelineExecutor based on a provided Configuration.
PipelineExecutorServiceLoader - org.apache.flink.core.execution中的接口
An interface to be implemented by the entity responsible for finding the correct PipelineExecutor to execute a given Pipeline.
PipelineOptions - org.apache.flink.configuration中的类
The configuration options for job execution.
PipelineOptions() - 类 的构造器org.apache.flink.configuration.PipelineOptions
 
PipelineOptionsInternal - org.apache.flink.configuration中的类
Pipeline options that are not meant to be used by the user.
PipelineOptionsInternal() - 类 的构造器org.apache.flink.configuration.PipelineOptionsInternal
 
Plan - org.apache.flink.api.common中的类
This class represents Flink programs, in the form of dataflow plans.
Plan(Collection<? extends GenericDataSinkBase<?>>, String) - 类 的构造器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) - 类 的构造器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) - 类 的构造器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) - 类 的构造器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<?>>) - 类 的构造器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) - 类 的构造器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<?>) - 类 的构造器org.apache.flink.api.common.Plan
Creates a new program plan with single data sink.
Plan(GenericDataSinkBase<?>, int) - 类 的构造器org.apache.flink.api.common.Plan
Creates a new program plan with single data sink and the given default parallelism.
Plugin - org.apache.flink.core.plugin中的接口
Interface for plugins.
PLUGIN_ALWAYS_PARENT_FIRST_LOADER_PATTERNS - 类 中的静态变量org.apache.flink.configuration.CoreOptions
PLUGIN_ALWAYS_PARENT_FIRST_LOADER_PATTERNS_ADDITIONAL - 类 中的静态变量org.apache.flink.configuration.CoreOptions
 
PluginConfig - org.apache.flink.core.plugin中的类
Stores the configuration for plugins mechanism.
PluginDescriptor - org.apache.flink.core.plugin中的类
Descriptive meta information for a plugin.
PluginDescriptor(String, URL[], String[]) - 类 的构造器org.apache.flink.core.plugin.PluginDescriptor
 
PluginFileSystemFactory - org.apache.flink.core.fs中的类
A wrapper around FileSystemFactory that ensures the plugin classloader is used for all FileSystem operations.
PluginFinder - org.apache.flink.core.plugin中的接口
Implementations of this interface provide mechanisms to locate plugins and create corresponding PluginDescriptor objects.
PluginLoader - org.apache.flink.core.plugin中的类
A PluginLoader is used by the PluginManager to load a single plugin.
PluginLoader(String, URLClassLoader) - 类 的构造器org.apache.flink.core.plugin.PluginLoader
 
PluginManager - org.apache.flink.core.plugin中的接口
PluginManager is responsible for managing cluster plugins which are loaded using separate class loaders so that their dependencies don't interfere with Flink's dependencies.
PluginUtils - org.apache.flink.core.plugin中的类
Utility functions for the plugin mechanism.
plus(Duration) - 类 中的方法org.apache.flink.api.common.time.Deadline
 
POJO(Class<T>) - 类 中的静态方法org.apache.flink.api.common.typeinfo.Types
Returns type information for a POJO (Plain Old Java Object).
POJO(Class<T>, Map<String, TypeInformation<?>>) - 类 中的静态方法org.apache.flink.api.common.typeinfo.Types
Returns type information for a POJO (Plain Old Java Object) and allows to specify all fields manually.
POJO_REGISTERED_CLASSES - 类 中的静态变量org.apache.flink.configuration.PipelineOptions
 
PojoComparator<T> - org.apache.flink.api.java.typeutils.runtime中的类
 
PojoComparator(Field[], TypeComparator<?>[], TypeSerializer<T>, Class<T>) - 类 的构造器org.apache.flink.api.java.typeutils.runtime.PojoComparator
 
PojoField - org.apache.flink.api.java.typeutils中的类
Represent a field definition for PojoTypeInfo type of objects.
PojoField(Field, TypeInformation<?>) - 类 的构造器org.apache.flink.api.java.typeutils.PojoField
 
PojoSerializer<T> - org.apache.flink.api.java.typeutils.runtime中的类
 
PojoSerializer(Class<T>, TypeSerializer<?>[], Field[], ExecutionConfig) - 类 的构造器org.apache.flink.api.java.typeutils.runtime.PojoSerializer
Constructor to create a new PojoSerializer.
PojoSerializer.PojoSerializerConfigSnapshot<T> - org.apache.flink.api.java.typeutils.runtime中的类
已过时。
This snapshot class is no longer being used. It has been fully replaced by PojoSerializerSnapshot.
PojoSerializerConfigSnapshot() - 类 的构造器org.apache.flink.api.java.typeutils.runtime.PojoSerializer.PojoSerializerConfigSnapshot
已过时。
This empty nullary constructor is required for deserializing the configuration.
PojoSerializerConfigSnapshot(Class<T>, LinkedHashMap<String, Tuple2<TypeSerializer<?>, TypeSerializerSnapshot<?>>>, LinkedHashMap<Class<?>, Tuple2<TypeSerializer<?>, TypeSerializerSnapshot<?>>>, HashMap<Class<?>, Tuple2<TypeSerializer<?>, TypeSerializerSnapshot<?>>>) - 类 的构造器org.apache.flink.api.java.typeutils.runtime.PojoSerializer.PojoSerializerConfigSnapshot
已过时。
 
PojoSerializerConfigSnapshot(Class<T>, LinkedHashMap<String, Tuple2<TypeSerializer<?>, TypeSerializerSnapshot<?>>>, LinkedHashMap<Class<?>, Tuple2<TypeSerializer<?>, TypeSerializerSnapshot<?>>>, HashMap<Class<?>, Tuple2<TypeSerializer<?>, TypeSerializerSnapshot<?>>>, boolean) - 类 的构造器org.apache.flink.api.java.typeutils.runtime.PojoSerializer.PojoSerializerConfigSnapshot
已过时。
 
PojoSerializerSnapshot<T> - org.apache.flink.api.java.typeutils.runtime中的类
Snapshot class for the PojoSerializer.
PojoSerializerSnapshot() - 类 的构造器org.apache.flink.api.java.typeutils.runtime.PojoSerializerSnapshot
Constructor for reading the snapshot.
PojoTypeInfo<T> - org.apache.flink.api.java.typeutils中的类
TypeInformation for "Java Beans"-style types.
PojoTypeInfo(Class<T>, List<PojoField>) - 类 的构造器org.apache.flink.api.java.typeutils.PojoTypeInfo
 
PojoTypeInfo.NamedFlatFieldDescriptor - org.apache.flink.api.java.typeutils中的类
 
pollNext(ReaderOutput<E>) - 类 中的方法org.apache.flink.api.connector.source.lib.util.IteratorSourceReader
 
pollNext(ReaderOutput<T>) - 接口 中的方法org.apache.flink.api.connector.source.SourceReader
Poll the next available record into the SourceOutput.
PORT - 类 中的静态变量org.apache.flink.configuration.BlobServerOptions
The config parameter defining the server port of the blob service.
PORT - 类 中的静态变量org.apache.flink.configuration.JobManagerOptions
The config parameter defining the network port to connect to for communication with the job manager.
PORT - 类 中的静态变量org.apache.flink.configuration.RestOptions
The port that the REST client connects to and the REST server binds to if RestOptions.BIND_PORT has not been specified.
PORT - 类 中的静态变量org.apache.flink.configuration.WebOptions
已过时。
Use RestOptions.PORT instead
PostVersionedIOReadableWritable - org.apache.flink.core.io中的类
A VersionedIOReadableWritable which allows to differentiate whether the previous data was versioned with a VersionedIOReadableWritable.
PostVersionedIOReadableWritable() - 类 的构造器org.apache.flink.core.io.PostVersionedIOReadableWritable
 
postVisit(T) - 接口 中的方法org.apache.flink.util.Visitor
Method that is invoked after all child nodes or descendant nodes were visited.
Preconditions - org.apache.flink.util中的类
A collection of static utility methods to validate input.
prepareCommit(boolean) - 接口 中的方法org.apache.flink.api.connector.sink.SinkWriter
Prepare for a commit.
preVisit(T) - 接口 中的方法org.apache.flink.util.Visitor
Method that is invoked on the visit before visiting and child nodes or descendant nodes.
PRIMITIVE_ARRAY(TypeInformation<?>) - 类 中的静态方法org.apache.flink.api.common.typeinfo.Types
Returns type information for Java arrays of primitive type (such as byte[]).
PrimitiveArrayComparator<T,C extends BasicTypeComparator> - org.apache.flink.api.common.typeutils.base.array中的类
 
PrimitiveArrayComparator(boolean, C) - 类 的构造器org.apache.flink.api.common.typeutils.base.array.PrimitiveArrayComparator
 
PrimitiveArrayTypeInfo<T> - org.apache.flink.api.common.typeinfo中的类
A TypeInformation for arrays of primitive types (int, long, double, ...).
PrintSinkOutputWriter<IN> - org.apache.flink.api.common.functions.util中的类
Print sink output writer for DataStream and DataSet print API.
PrintSinkOutputWriter() - 类 的构造器org.apache.flink.api.common.functions.util.PrintSinkOutputWriter
 
PrintSinkOutputWriter(boolean) - 类 的构造器org.apache.flink.api.common.functions.util.PrintSinkOutputWriter
 
PrintSinkOutputWriter(String, boolean) - 类 的构造器org.apache.flink.api.common.functions.util.PrintSinkOutputWriter
 
printStackTrace(PrintStream) - 异常错误 中的方法org.apache.flink.util.SerializedThrowable
 
printStackTrace(PrintWriter) - 异常错误 中的方法org.apache.flink.util.SerializedThrowable
 
privateDuplicate(TupleComparatorBase<T>) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
 
Prober(TypeComparator<PT>, TypePairComparator<PT, BT>) - 类 的构造器org.apache.flink.api.common.operators.util.JoinHashMap.Prober
 
processAsByteBuffer(Function<ByteBuffer, T>) - 类 中的方法org.apache.flink.core.memory.MemorySegment
Applies the given process function on a ByteBuffer that represents this entire segment.
processAsByteBuffer(Consumer<ByteBuffer>) - 类 中的方法org.apache.flink.core.memory.MemorySegment
Supplies a ByteBuffer that represents this entire segment to the given process consumer.
ProcessorArchitecture - org.apache.flink.util中的枚举
The processor architecture of the this system.
ProcessorArchitecture.MemoryAddressSize - org.apache.flink.util中的枚举
The memory address size of the processor.
ProgramDescription - 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.
project(Row, int[]) - 类 中的静态方法org.apache.flink.types.Row
Creates a new row with projected fields and identical RowKind from another row.
project(Row, String[]) - 类 中的静态方法org.apache.flink.types.Row
Creates a new row with projected fields and identical RowKind from another row.
project(Collection<I>, Function<I, O>) - 类 中的静态方法org.apache.flink.util.CollectionUtil
 
projectFields(RowTypeInfo, int[]) - 类 中的静态方法org.apache.flink.api.java.typeutils.RowTypeInfo
Creates a RowTypeInfo with projected fields.
PropertiesUtil - org.apache.flink.util中的类
Simple utilities for getting typed values from Properties.
PROXY_ASYNC_QUERY_THREADS - 类 中的静态变量org.apache.flink.configuration.QueryableStateOptions
Number of async query threads for the client proxy (0 => #slots).
PROXY_NETWORK_THREADS - 类 中的静态变量org.apache.flink.configuration.QueryableStateOptions
Number of network (event loop) threads for the client proxy (0 => #slots).
PROXY_PORT_RANGE - 类 中的静态变量org.apache.flink.configuration.QueryableStateOptions
The config parameter defining the server port range of the queryable state proxy.
put(K, V) - 接口 中的方法org.apache.flink.api.common.state.BroadcastState
Associates a new value with the given key.
put(UK, UV) - 接口 中的方法org.apache.flink.api.common.state.MapState
Associates a new value with the given key.
put(int, byte) - 类 中的方法org.apache.flink.core.memory.MemorySegment
Writes the given byte into this buffer at the given position.
put(int, byte[]) - 类 中的方法org.apache.flink.core.memory.MemorySegment
Bulk put method.
put(int, byte[], int, int) - 类 中的方法org.apache.flink.core.memory.MemorySegment
Bulk put method.
put(DataInput, int, int) - 类 中的方法org.apache.flink.core.memory.MemorySegment
Bulk put method.
put(int, ByteBuffer, int) - 类 中的方法org.apache.flink.core.memory.MemorySegment
Bulk put method.
put(K, V) - 类 中的方法org.apache.flink.types.MapValue
 
put(String, K, V) - 类 中的方法org.apache.flink.util.LinkedOptionalMap
 
putAll(Map<K, V>) - 接口 中的方法org.apache.flink.api.common.state.BroadcastState
Copies all of the mappings from the given map into the state.
putAll(Map<UK, UV>) - 接口 中的方法org.apache.flink.api.common.state.MapState
Copies all of the mappings from the given map into the state.
putAll(Map<? extends K, ? extends V>) - 类 中的方法org.apache.flink.types.MapValue
 
putBoolean(int, boolean) - 类 中的方法org.apache.flink.core.memory.MemorySegment
Writes one byte containing the byte value into this buffer at the given position.
putBooleanNormalizedKey(boolean, MemorySegment, int, int) - 类 中的静态方法org.apache.flink.api.common.typeutils.base.NormalizedKeyUtil
 
putByteNormalizedKey(byte, MemorySegment, int, int) - 类 中的静态方法org.apache.flink.api.common.typeutils.base.NormalizedKeyUtil
 
putChar(int, char) - 类 中的方法org.apache.flink.core.memory.MemorySegment
Writes a char value to the given position, in the system's native byte order.
putCharBigEndian(int, char) - 类 中的方法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) - 类 中的方法org.apache.flink.core.memory.MemorySegment
Writes the given character (16 bit, 2 bytes) to the given position in little-endian byte order.
putCharNormalizedKey(char, MemorySegment, int, int) - 类 中的静态方法org.apache.flink.api.common.typeutils.base.NormalizedKeyUtil
 
putDouble(int, double) - 类 中的方法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) - 类 中的方法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) - 类 中的方法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) - 类 中的方法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) - 类 中的方法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) - 类 中的方法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) - 类 中的方法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) - 类 中的方法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) - 类 中的方法org.apache.flink.core.memory.MemorySegment
Writes the given int value (32bit, 4 bytes) to the given position in little endian byte order.
putIntNormalizedKey(int, MemorySegment, int, int) - 类 中的静态方法org.apache.flink.api.common.typeutils.base.NormalizedKeyUtil
 
putLong(int, long) - 类 中的方法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) - 类 中的方法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) - 类 中的方法org.apache.flink.core.memory.MemorySegment
Writes the given long value (64bit, 8 bytes) to the given position in little endian byte order.
putLongNormalizedKey(long, MemorySegment, int, int) - 类 中的静态方法org.apache.flink.api.common.typeutils.base.NormalizedKeyUtil
 
putNormalizedKey(T, MemorySegment, int, int) - 类 中的方法org.apache.flink.api.common.typeutils.base.array.PrimitiveArrayComparator
 
putNormalizedKey(BigDecimal, MemorySegment, int, int) - 类 中的方法org.apache.flink.api.common.typeutils.base.BigDecComparator
Adds a normalized key containing a normalized order of magnitude of the given record. 2 bits determine the sign (negative, zero, positive), 33 bits determine the magnitude.
putNormalizedKey(BigInteger, MemorySegment, int, int) - 类 中的方法org.apache.flink.api.common.typeutils.base.BigIntComparator
Adds a normalized key containing the normalized number of bits and MSBs of the given record. 1 bit determines the sign (negative, zero/positive), 31 bit the bit length of the record.
putNormalizedKey(Boolean, MemorySegment, int, int) - 类 中的方法org.apache.flink.api.common.typeutils.base.BooleanComparator
 
putNormalizedKey(BooleanValue, MemorySegment, int, int) - 类 中的方法org.apache.flink.api.common.typeutils.base.BooleanValueComparator
 
putNormalizedKey(Byte, MemorySegment, int, int) - 类 中的方法org.apache.flink.api.common.typeutils.base.ByteComparator
 
putNormalizedKey(ByteValue, MemorySegment, int, int) - 类 中的方法org.apache.flink.api.common.typeutils.base.ByteValueComparator
 
putNormalizedKey(Character, MemorySegment, int, int) - 类 中的方法org.apache.flink.api.common.typeutils.base.CharComparator
 
putNormalizedKey(CharValue, MemorySegment, int, int) - 类 中的方法org.apache.flink.api.common.typeutils.base.CharValueComparator
 
putNormalizedKey(Date, MemorySegment, int, int) - 类 中的方法org.apache.flink.api.common.typeutils.base.DateComparator
 
putNormalizedKey(Double, MemorySegment, int, int) - 类 中的方法org.apache.flink.api.common.typeutils.base.DoubleComparator
 
putNormalizedKey(DoubleValue, MemorySegment, int, int) - 类 中的方法org.apache.flink.api.common.typeutils.base.DoubleValueComparator
 
putNormalizedKey(T, MemorySegment, int, int) - 类 中的方法org.apache.flink.api.common.typeutils.base.EnumComparator
 
putNormalizedKey(Float, MemorySegment, int, int) - 类 中的方法org.apache.flink.api.common.typeutils.base.FloatComparator
 
putNormalizedKey(FloatValue, MemorySegment, int, int) - 类 中的方法org.apache.flink.api.common.typeutils.base.FloatValueComparator
 
putNormalizedKey(Instant, MemorySegment, int, int) - 类 中的方法org.apache.flink.api.common.typeutils.base.InstantComparator
 
putNormalizedKey(Integer, MemorySegment, int, int) - 类 中的方法org.apache.flink.api.common.typeutils.base.IntComparator
 
putNormalizedKey(IntValue, MemorySegment, int, int) - 类 中的方法org.apache.flink.api.common.typeutils.base.IntValueComparator
 
putNormalizedKey(LocalDate, MemorySegment, int, int) - 类 中的方法org.apache.flink.api.common.typeutils.base.LocalDateComparator
 
putNormalizedKey(LocalDateTime, MemorySegment, int, int) - 类 中的方法org.apache.flink.api.common.typeutils.base.LocalDateTimeComparator
 
putNormalizedKey(LocalTime, MemorySegment, int, int) - 类 中的方法org.apache.flink.api.common.typeutils.base.LocalTimeComparator
 
putNormalizedKey(Long, MemorySegment, int, int) - 类 中的方法org.apache.flink.api.common.typeutils.base.LongComparator
 
putNormalizedKey(LongValue, MemorySegment, int, int) - 类 中的方法org.apache.flink.api.common.typeutils.base.LongValueComparator
 
putNormalizedKey(NullValue, MemorySegment, int, int) - 类 中的方法org.apache.flink.api.common.typeutils.base.NullValueComparator
 
putNormalizedKey(Short, MemorySegment, int, int) - 类 中的方法org.apache.flink.api.common.typeutils.base.ShortComparator
 
putNormalizedKey(ShortValue, MemorySegment, int, int) - 类 中的方法org.apache.flink.api.common.typeutils.base.ShortValueComparator
 
putNormalizedKey(Date, MemorySegment, int, int) - 类 中的方法org.apache.flink.api.common.typeutils.base.SqlTimestampComparator
 
putNormalizedKey(String, MemorySegment, int, int) - 类 中的方法org.apache.flink.api.common.typeutils.base.StringComparator
 
putNormalizedKey(StringValue, MemorySegment, int, int) - 类 中的方法org.apache.flink.api.common.typeutils.base.StringValueComparator
 
putNormalizedKey(T, MemorySegment, int, int) - 类 中的方法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 and writing exactly the given number of bytes.
putNormalizedKey(T, MemorySegment, int, int) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.CopyableValueComparator
 
putNormalizedKey(T, MemorySegment, int, int) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.GenericTypeComparator
 
putNormalizedKey(T, MemorySegment, int, int) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.NullAwareComparator
 
putNormalizedKey(T, MemorySegment, int, int) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.PojoComparator
 
putNormalizedKey(Row, MemorySegment, int, int) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.RowComparator
 
putNormalizedKey(T, MemorySegment, int, int) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.TupleComparator
 
putNormalizedKey(T, MemorySegment, int, int) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.ValueComparator
 
putNormalizedKeyDate(Date, MemorySegment, int, int) - 类 中的静态方法org.apache.flink.api.common.typeutils.base.DateComparator
 
putNormalizedKeyLocalDate(LocalDate, MemorySegment, int, int) - 类 中的静态方法org.apache.flink.api.common.typeutils.base.LocalDateComparator
 
putNormalizedKeyLocalTime(LocalTime, MemorySegment, int, int) - 类 中的静态方法org.apache.flink.api.common.typeutils.base.LocalTimeComparator
 
putShort(int, short) - 类 中的方法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) - 类 中的方法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) - 类 中的方法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.
putShortNormalizedKey(short, MemorySegment, int, int) - 类 中的静态方法org.apache.flink.api.common.typeutils.base.NormalizedKeyUtil
 
putUnsignedIntegerNormalizedKey(int, MemorySegment, int, int) - 类 中的静态方法org.apache.flink.api.common.typeutils.base.NormalizedKeyUtil
 
putUnsignedLongNormalizedKey(long, MemorySegment, int, int) - 类 中的静态方法org.apache.flink.api.common.typeutils.base.NormalizedKeyUtil
 

Q

QuadConsumer<S,T,U,V> - org.apache.flink.util.function中的接口
Operation which is performed on four given arguments.
QuadFunction<S,T,U,V,R> - org.apache.flink.util.function中的接口
Function which takes three arguments.
QUERY_SERVICE_PORT - 类 中的静态变量org.apache.flink.configuration.MetricOptions
The default network port range for Flink's internal metric query service.
QUERY_SERVICE_THREAD_PRIORITY - 类 中的静态变量org.apache.flink.configuration.MetricOptions
The thread priority for Flink's internal metric query service.
QueryableStateOptions - org.apache.flink.configuration中的类
The set of configuration options relating to Queryable State.

R

RangeBoundaries<T> - org.apache.flink.api.common.distributions中的接口
RangeBoundaries is used to split the records into multiple ranges.
reachedEnd() - 类 中的方法org.apache.flink.api.common.io.BinaryInputFormat
 
reachedEnd() - 类 中的方法org.apache.flink.api.common.io.DelimitedInputFormat
Checks whether the current split is at its end.
reachedEnd() - 接口 中的方法org.apache.flink.api.common.io.InputFormat
Method used to check if the end of the input is reached.
reachedEnd() - 类 中的方法org.apache.flink.api.common.io.ReplicatingInputFormat
 
read() - 类 中的方法org.apache.flink.api.common.io.BinaryInputFormat.BlockBasedInput
 
read(byte[]) - 类 中的方法org.apache.flink.api.common.io.BinaryInputFormat.BlockBasedInput
 
read(byte[], int, int) - 类 中的方法org.apache.flink.api.common.io.BinaryInputFormat.BlockBasedInput
 
read(DataInputView) - 类 中的方法org.apache.flink.api.common.io.BlockInfo
 
read() - 类 中的方法org.apache.flink.api.common.io.InputStreamFSInputWrapper
 
read(byte[], int, int) - 类 中的方法org.apache.flink.api.common.io.InputStreamFSInputWrapper
 
read(byte[]) - 类 中的方法org.apache.flink.api.common.io.InputStreamFSInputWrapper
 
read(DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.EnumSerializer.EnumSerializerConfigSnapshot
已过时。
 
read(DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.CompositeTypeSerializerConfigSnapshot
 
read(DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.GenericTypeSerializerConfigSnapshot
 
read(DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.ParameterlessTypeSerializerConfig
已过时。
 
read(DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.TypeSerializerSerializationUtil.TypeSerializerSerializationProxy
已过时。
 
read() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.DataInputViewStream
 
read(byte[], int, int) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.DataInputViewStream
 
read(Kryo, Input, Class) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.kryo.JavaSerializer
 
read(Kryo, Input, Class<T>) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.kryo.Serializers.DummyAvroKryoSerializerClass
 
read(Kryo, Input, Class) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.KryoRegistrationSerializerConfigSnapshot.DummyKryoSerializerClass
 
read(DataInputView) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.KryoRegistrationSerializerConfigSnapshot
 
read() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.NoFetchingInput
 
read(byte[], int, int) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.NoFetchingInput
 
read(DataInputView) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.PojoSerializer.PojoSerializerConfigSnapshot
已过时。
 
read(DataInputView) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.TupleSerializerConfigSnapshot
 
read(DataInputView) - 类 中的方法org.apache.flink.configuration.Configuration
 
read(DataInputView) - 类 中的方法org.apache.flink.configuration.DelegatingConfiguration
 
read() - 类 中的方法org.apache.flink.core.fs.FSDataInputStreamWrapper
 
read(byte[]) - 类 中的方法org.apache.flink.core.fs.FSDataInputStreamWrapper
 
read(byte[], int, int) - 类 中的方法org.apache.flink.core.fs.FSDataInputStreamWrapper
 
read() - 类 中的方法org.apache.flink.core.fs.local.LocalDataInputStream
 
read(byte[], int, int) - 类 中的方法org.apache.flink.core.fs.local.LocalDataInputStream
 
read(DataInputView) - 类 中的方法org.apache.flink.core.fs.Path
 
read(DataInputView) - 接口 中的方法org.apache.flink.core.io.IOReadableWritable
Reads the object's internal data from the given data input view.
read(DataInputView, boolean) - 类 中的方法org.apache.flink.core.io.PostVersionedIOReadableWritable
Read from the provided in.
read(InputStream) - 类 中的方法org.apache.flink.core.io.PostVersionedIOReadableWritable
This read attempts to first identify if the input view contains the special PostVersionedIOReadableWritable.VERSIONED_IDENTIFIER by reading and buffering the first few bytes.
read(DataInputView) - 类 中的方法org.apache.flink.core.io.PostVersionedIOReadableWritable
We do not support reading from a DataInputView, because it does not support pushing back already read bytes.
read(DataInputView) - 类 中的方法org.apache.flink.core.io.VersionedIOReadableWritable
 
read(byte[], int, int) - 类 中的方法org.apache.flink.core.memory.DataInputDeserializer
 
read(byte[]) - 类 中的方法org.apache.flink.core.memory.DataInputDeserializer
 
read(byte[], int, int) - 接口 中的方法org.apache.flink.core.memory.DataInputView
Reads up to len bytes of memory and stores it into b starting at offset off.
read(byte[]) - 接口 中的方法org.apache.flink.core.memory.DataInputView
Tries to fill the given byte array b.
read() - 类 中的方法org.apache.flink.core.memory.MemorySegmentInputStreamWithPos
 
read(byte[], int, int) - 类 中的方法org.apache.flink.core.memory.MemorySegmentInputStreamWithPos
 
read(DataInputView) - 类 中的方法org.apache.flink.types.BooleanValue
 
read(DataInputView) - 类 中的方法org.apache.flink.types.ByteValue
 
read(DataInputView) - 类 中的方法org.apache.flink.types.CharValue
 
read(DataInputView) - 类 中的方法org.apache.flink.types.DoubleValue
 
read(DataInputView) - 类 中的方法org.apache.flink.types.FloatValue
 
read(DataInputView) - 类 中的方法org.apache.flink.types.IntValue
 
read(DataInputView) - 类 中的方法org.apache.flink.types.ListValue
 
read(DataInputView) - 类 中的方法org.apache.flink.types.LongValue
 
read(DataInputView) - 类 中的方法org.apache.flink.types.MapValue
 
read(DataInputView) - 类 中的方法org.apache.flink.types.NullValue
 
read(DataInputView) - 类 中的方法org.apache.flink.types.Record
 
read(DataInputView) - 类 中的方法org.apache.flink.types.ShortValue
 
read(DataInputView) - 类 中的方法org.apache.flink.types.StringValue
 
READ_WHOLE_SPLIT_FLAG - 类 中的静态变量org.apache.flink.api.common.io.FileInputFormat
The splitLength is set to -1L for reading the whole split.
ReadableConfig - org.apache.flink.configuration中的接口
Read access to a configuration object.
readAllBytes(Path) - 类 中的静态方法org.apache.flink.util.FileUtils
Reads all the bytes from a file.
readAndInstantiateSnapshotClass(DataInputView, ClassLoader) - 类 中的静态方法org.apache.flink.api.common.typeutils.TypeSerializerSnapshotSerializationUtil
 
readBigDecimal(DataInputView) - 类 中的静态方法org.apache.flink.api.common.typeutils.base.BigDecSerializer
 
readBigInteger(DataInputView) - 类 中的静态方法org.apache.flink.api.common.typeutils.base.BigIntSerializer
 
readBoolean() - 类 中的方法org.apache.flink.core.memory.DataInputDeserializer
 
readByte() - 类 中的方法org.apache.flink.core.memory.DataInputDeserializer
 
readBytes(byte[], int, int) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.NoFetchingInput
 
readChar() - 类 中的方法org.apache.flink.core.memory.DataInputDeserializer
 
readClassDescriptor() - 类 中的方法org.apache.flink.util.InstantiationUtil.FailureTolerantObjectInputStream
 
readDouble() - 类 中的方法org.apache.flink.core.memory.DataInputDeserializer
 
ReaderInfo - org.apache.flink.api.connector.source中的类
A container class hosting the information of a SourceReader.
ReaderInfo(int, String) - 类 的构造器org.apache.flink.api.connector.source.ReaderInfo
 
ReaderOutput<T> - org.apache.flink.api.connector.source中的接口
The interface provided by the Flink runtime to the SourceReader to emit records, and optionally watermarks, to downstream operators for message processing.
readFile(File, String) - 类 中的静态方法org.apache.flink.util.FileUtils
 
readFileInfoFromConfig(Configuration) - 类 中的静态方法org.apache.flink.api.common.cache.DistributedCache
 
readFileUtf8(File) - 类 中的静态方法org.apache.flink.util.FileUtils
 
readFloat() - 类 中的方法org.apache.flink.core.memory.DataInputDeserializer
 
readFully(byte[]) - 类 中的方法org.apache.flink.core.memory.DataInputDeserializer
 
readFully(byte[], int, int) - 类 中的方法org.apache.flink.core.memory.DataInputDeserializer
 
readFully(InputStream, byte[], int, int) - 类 中的静态方法org.apache.flink.util.IOUtils
Reads len bytes in a loop.
readInt() - 类 中的方法org.apache.flink.core.memory.DataInputDeserializer
 
readIntoAndCopyMask(DataInputView, DataOutputView, boolean[]) - 类 中的静态方法org.apache.flink.api.java.typeutils.runtime.MaskUtils
 
readIntoAndCopyMask(DataInputView, DataOutputView, boolean[], int) - 类 中的静态方法org.apache.flink.api.java.typeutils.runtime.MaskUtils
 
readIntoMask(DataInputView, boolean[]) - 类 中的静态方法org.apache.flink.api.java.typeutils.runtime.MaskUtils
 
readIntoMask(DataInputView, boolean[], int) - 类 中的静态方法org.apache.flink.api.java.typeutils.runtime.MaskUtils
 
readLine() - 类 中的方法org.apache.flink.api.common.io.DelimitedInputFormat
 
readLine() - 类 中的方法org.apache.flink.core.memory.DataInputDeserializer
 
readLong() - 类 中的方法org.apache.flink.core.memory.DataInputDeserializer
 
readNestedSerializerSnapshots(DataInputView, ClassLoader) - 类 中的静态方法org.apache.flink.api.common.typeutils.NestedSerializersSnapshotDelegate
Reads the composite snapshot of all the contained serializers.
readNullableString(DataInputView) - 类 中的静态方法org.apache.flink.util.StringUtils
Reads a String from the given input.
readObjectFromConfig(Configuration, String, ClassLoader) - 类 中的静态方法org.apache.flink.util.InstantiationUtil
 
ReadOnlyBroadcastState<K,V> - org.apache.flink.api.common.state中的接口
A read-only view of the BroadcastState.
readOptionalMap(DataInputView, BiFunctionWithException<DataInputView, String, K, IOException>, BiFunctionWithException<DataInputView, String, V, IOException>) - 类 中的静态方法org.apache.flink.util.LinkedOptionalMapSerializer
 
readOuterSnapshot(int, DataInputView, ClassLoader) - 类 中的方法org.apache.flink.api.common.typeutils.base.GenericArraySerializerSnapshot
 
readOuterSnapshot(int, DataInputView, ClassLoader) - 类 中的方法org.apache.flink.api.common.typeutils.CompositeTypeSerializerSnapshot
Reads the outer snapshot, i.e. any information beyond the nested serializers of the outer serializer.
readOuterSnapshot(int, DataInputView, ClassLoader) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.NullableSerializer.NullableSerializerSnapshot
 
readOuterSnapshot(int, DataInputView, ClassLoader) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.RowSerializer.RowSerializerSnapshot
 
readOuterSnapshot(int, DataInputView, ClassLoader) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.TupleSerializerSnapshot
 
readParametersFromConfig(Configuration, ClassLoader) - 接口 中的方法org.apache.flink.api.common.typeutils.TypeComparatorFactory
 
readParametersFromConfig(Configuration, ClassLoader) - 接口 中的方法org.apache.flink.api.common.typeutils.TypeSerializerFactory
 
readParametersFromConfig(Configuration, ClassLoader) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.RuntimeComparatorFactory
 
readParametersFromConfig(Configuration, ClassLoader) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.RuntimeSerializerFactory
 
readRecord(OT, byte[], int, int) - 类 中的方法org.apache.flink.api.common.io.DelimitedInputFormat
This function parses the given byte array which represents a serialized record.
readSerializersAndConfigsWithResilience(DataInputView, ClassLoader) - 类 中的静态方法org.apache.flink.api.common.typeutils.TypeSerializerSerializationUtil
已过时。
Reads from a data input view a list of serializers and their corresponding config snapshots written using TypeSerializerSerializationUtil.writeSerializersAndConfigsWithResilience(DataOutputView, List).
readSerializerSnapshot(DataInputView, ClassLoader, TypeSerializer<T>) - 类 中的静态方法org.apache.flink.api.common.typeutils.TypeSerializerSnapshotSerializationUtil
readShort() - 类 中的方法org.apache.flink.core.memory.DataInputDeserializer
 
readSnapshot(int, DataInputView, ClassLoader) - 类 中的方法org.apache.flink.api.common.typeutils.BackwardsCompatibleSerializerSnapshot
 
readSnapshot(int, DataInputView, ClassLoader) - 类 中的方法org.apache.flink.api.common.typeutils.base.EnumSerializer.EnumSerializerSnapshot
 
readSnapshot(int, DataInputView, ClassLoader) - 类 中的方法org.apache.flink.api.common.typeutils.base.GenericArraySerializerConfigSnapshot
已过时。
 
readSnapshot(int, DataInputView, ClassLoader) - 类 中的方法org.apache.flink.api.common.typeutils.CompositeTypeSerializerSnapshot
 
readSnapshot(int, DataInputView, ClassLoader) - 类 中的方法org.apache.flink.api.common.typeutils.GenericTypeSerializerSnapshot
 
readSnapshot(int, DataInputView, ClassLoader) - 类 中的方法org.apache.flink.api.common.typeutils.SimpleTypeSerializerSnapshot
 
readSnapshot(int, DataInputView, ClassLoader) - 类 中的方法org.apache.flink.api.common.typeutils.TypeSerializerConfigSnapshot
已过时。
 
readSnapshot(int, DataInputView, ClassLoader) - 接口 中的方法org.apache.flink.api.common.typeutils.TypeSerializerSnapshot
Reads the serializer snapshot from the provided DataInputView.
readSnapshot(int, DataInputView, ClassLoader) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.EitherSerializerSnapshot
已过时。
 
readSnapshot(int, DataInputView, ClassLoader) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializerSnapshot
 
readSnapshot(int, DataInputView, ClassLoader) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.PojoSerializerSnapshot
 
readString(DataInput) - 类 中的静态方法org.apache.flink.types.StringValue
 
readString(DataInputView) - 类 中的静态方法org.apache.flink.util.StringUtils
Reads a non-null String from the given input.
readUnsignedByte() - 类 中的方法org.apache.flink.core.memory.DataInputDeserializer
 
readUnsignedShort() - 类 中的方法org.apache.flink.core.memory.DataInputDeserializer
 
readUTF() - 类 中的方法org.apache.flink.core.memory.DataInputDeserializer
 
readVersionAndDeSerialize(SimpleVersionedSerializer<T>, DataInputView) - 类 中的静态方法org.apache.flink.core.io.SimpleVersionedSerialization
Deserializes the version and datum from a stream.
readVersionAndDeSerialize(SimpleVersionedSerializer<T>, byte[]) - 类 中的静态方法org.apache.flink.core.io.SimpleVersionedSerialization
Deserializes the version and datum from a byte array.
readVersionedSnapshot(DataInputView, ClassLoader) - 接口 中的静态方法org.apache.flink.api.common.typeutils.TypeSerializerSnapshot
Reads a snapshot from the stream, performing resolving This method reads snapshots written by TypeSerializerSnapshot.writeVersionedSnapshot(DataOutputView, TypeSerializerSnapshot).
readWithKeyDenormalization(T, DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.array.PrimitiveArrayComparator
 
readWithKeyDenormalization(T, DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.BasicTypeComparator
 
readWithKeyDenormalization(BooleanValue, DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.BooleanValueComparator
 
readWithKeyDenormalization(ByteValue, DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.ByteValueComparator
 
readWithKeyDenormalization(CharValue, DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.CharValueComparator
 
readWithKeyDenormalization(DoubleValue, DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.DoubleValueComparator
 
readWithKeyDenormalization(FloatValue, DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.FloatValueComparator
 
readWithKeyDenormalization(IntValue, DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.IntValueComparator
 
readWithKeyDenormalization(LocalDate, DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.LocalDateComparator
 
readWithKeyDenormalization(LocalDateTime, DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.LocalDateTimeComparator
 
readWithKeyDenormalization(LongValue, DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.LongValueComparator
 
readWithKeyDenormalization(NullValue, DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.NullValueComparator
 
readWithKeyDenormalization(ShortValue, DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.ShortValueComparator
 
readWithKeyDenormalization(StringValue, DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.StringValueComparator
 
readWithKeyDenormalization(T, DataInputView) - 类 中的方法org.apache.flink.api.common.typeutils.TypeComparator
Reads the record back while de-normalizing the key fields.
readWithKeyDenormalization(T, DataInputView) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.CopyableValueComparator
 
readWithKeyDenormalization(T, DataInputView) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.GenericTypeComparator
 
readWithKeyDenormalization(T, DataInputView) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.NullAwareComparator
 
readWithKeyDenormalization(T, DataInputView) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.PojoComparator
 
readWithKeyDenormalization(Row, DataInputView) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.RowComparator
 
readWithKeyDenormalization(T, DataInputView) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
 
readWithKeyDenormalization(T, DataInputView) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.ValueComparator
 
Record - org.apache.flink.types中的类
The Record represents a multi-valued data record.
Record() - 类 的构造器org.apache.flink.types.Record
Required nullary constructor for instantiation by serialization logic.
Record(Value) - 类 的构造器org.apache.flink.types.Record
Creates a new record containing only a single field, which is the given value.
Record(Value, Value) - 类 的构造器org.apache.flink.types.Record
Creates a new record containing exactly two fields, which are the given values.
Record(int) - 类 的构造器org.apache.flink.types.Record
Creates a new record, containing the given number of fields.
RECORD_DELIMITER - 类 中的静态变量org.apache.flink.api.common.io.DelimitedInputFormat
The configuration key to set the record delimiter.
RecordTimestampAssigner<E> - org.apache.flink.api.common.eventtime中的类
A TimestampAssigner that forwards the already-assigned timestamp.
RecordTimestampAssigner() - 类 的构造器org.apache.flink.api.common.eventtime.RecordTimestampAssigner
 
recover(RecoverableWriter.ResumeRecoverable) - 类 中的方法org.apache.flink.core.fs.local.LocalRecoverableWriter
 
recover(RecoverableWriter.ResumeRecoverable) - 接口 中的方法org.apache.flink.core.fs.RecoverableWriter
Resumes a recoverable stream consistently at the point indicated by the given ResumeRecoverable.
RecoverableFsDataOutputStream - org.apache.flink.core.fs中的类
An output stream to a file system that can be recovered at well defined points.
RecoverableFsDataOutputStream() - 类 的构造器org.apache.flink.core.fs.RecoverableFsDataOutputStream
 
RecoverableFsDataOutputStream.Committer - org.apache.flink.core.fs中的接口
A committer can publish the file of a stream that was closed.
RecoverableWriter - org.apache.flink.core.fs中的接口
The RecoverableWriter creates and recovers RecoverableFsDataOutputStream.
RecoverableWriter.CommitRecoverable - org.apache.flink.core.fs中的接口
A handle to an in-progress stream with a defined and persistent amount of data.
RecoverableWriter.ResumeRecoverable - org.apache.flink.core.fs中的接口
A handle to an in-progress stream with a defined and persistent amount of data.
recoverForCommit(RecoverableWriter.CommitRecoverable) - 类 中的方法org.apache.flink.core.fs.local.LocalRecoverableWriter
 
recoverForCommit(RecoverableWriter.CommitRecoverable) - 接口 中的方法org.apache.flink.core.fs.RecoverableWriter
Recovers a recoverable stream consistently at the point indicated by the given CommitRecoverable for finalizing and committing.
RECOVERY_JOB_DELAY - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
This option is no longer used and has no effect on Flink.
RECOVERY_JOB_MANAGER_PORT - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
Deprecated in favour of ConfigConstants.HA_JOB_MANAGER_PORT.
RECOVERY_MODE - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
Deprecated in favour of ConfigConstants.HA_MODE.
recursivelyRegisterType(TypeInformation<?>, ExecutionConfig, Set<Class<?>>) - 类 中的静态方法org.apache.flink.api.java.typeutils.runtime.kryo.Serializers
 
recursivelyRegisterType(Class<?>, ExecutionConfig, Set<Class<?>>) - 类 中的静态方法org.apache.flink.api.java.typeutils.runtime.kryo.Serializers
 
recycleUnpooledMemorySegments(Collection<MemorySegment>) - 接口 中的方法org.apache.flink.core.memory.MemorySegmentProvider
 
reduce(Iterable<T>, Collector<O>) - 接口 中的方法org.apache.flink.api.common.functions.GroupReduceFunction
The reduce method.
reduce(T, T) - 接口 中的方法org.apache.flink.api.common.functions.ReduceFunction
The core method of ReduceFunction, combining two values into one value of the same type.
reduce(Iterable<IN>, Collector<OUT>) - 类 中的方法org.apache.flink.api.common.functions.RichGroupReduceFunction
 
reduce(T, T) - 类 中的方法org.apache.flink.api.common.functions.RichReduceFunction
 
ReduceFunction<T> - org.apache.flink.api.common.functions中的接口
Base interface for Reduce functions.
ReduceOperatorBase<T,FT extends ReduceFunction<T>> - org.apache.flink.api.common.operators.base中的类
Base data flow operator for Reduce user-defined functions.
ReduceOperatorBase(UserCodeWrapper<FT>, UnaryOperatorInformation<T, T>, int[], String) - 类 的构造器org.apache.flink.api.common.operators.base.ReduceOperatorBase
Creates a grouped reduce data flow operator.
ReduceOperatorBase(FT, UnaryOperatorInformation<T, T>, int[], String) - 类 的构造器org.apache.flink.api.common.operators.base.ReduceOperatorBase
Creates a grouped reduce data flow operator.
ReduceOperatorBase(Class<? extends FT>, UnaryOperatorInformation<T, T>, int[], String) - 类 的构造器org.apache.flink.api.common.operators.base.ReduceOperatorBase
Creates a grouped reduce data flow operator.
ReduceOperatorBase(UserCodeWrapper<FT>, UnaryOperatorInformation<T, T>, String) - 类 的构造器org.apache.flink.api.common.operators.base.ReduceOperatorBase
Creates a non-grouped reduce data flow operator (all-reduce).
ReduceOperatorBase(FT, UnaryOperatorInformation<T, T>, String) - 类 的构造器org.apache.flink.api.common.operators.base.ReduceOperatorBase
Creates a non-grouped reduce data flow operator (all-reduce).
ReduceOperatorBase(Class<? extends FT>, UnaryOperatorInformation<T, T>, String) - 类 的构造器org.apache.flink.api.common.operators.base.ReduceOperatorBase
Creates a non-grouped reduce data flow operator (all-reduce).
ReduceOperatorBase.CombineHint - org.apache.flink.api.common.operators.base中的枚举
An enumeration of hints, optionally usable to tell the system exactly how to execute the combiner phase of a reduce.
ReducingState<T> - org.apache.flink.api.common.state中的接口
State interface for reducing state.
ReducingStateDescriptor<T> - org.apache.flink.api.common.state中的类
ReducingStateDescriptor(String, ReduceFunction<T>, Class<T>) - 类 的构造器org.apache.flink.api.common.state.ReducingStateDescriptor
Creates a new ReducingStateDescriptor with the given name, type, and default value.
ReducingStateDescriptor(String, ReduceFunction<T>, TypeInformation<T>) - 类 的构造器org.apache.flink.api.common.state.ReducingStateDescriptor
Creates a new ReducingStateDescriptor with the given name and default value.
ReducingStateDescriptor(String, ReduceFunction<T>, TypeSerializer<T>) - 类 的构造器org.apache.flink.api.common.state.ReducingStateDescriptor
Creates a new ValueStateDescriptor with the given name and default value.
REDUNDANT_TASK_MANAGER_NUM - 类 中的静态变量org.apache.flink.configuration.ResourceManagerOptions
The number of redundant task managers.
RefCounted - org.apache.flink.util中的接口
Interface to simply add reference counting functionality.
RefCountedFile - org.apache.flink.core.fs中的类
A reference counted file which is deleted as soon as no caller holds a reference to the wrapped File.
RefCountedFile(File) - 类 的构造器org.apache.flink.core.fs.RefCountedFile
 
reference - 类 中的变量org.apache.flink.api.common.typeutils.base.array.PrimitiveArrayComparator
 
ReflectionUtil - org.apache.flink.util中的类
Utility for reflection operations on classes and generic type parametrization.
ReflectionUtil.FullTypeInfo - org.apache.flink.util中的类
Container for the full type information of a type.
REFRESH_INTERVAL - 类 中的静态变量org.apache.flink.configuration.WebOptions
The config parameter defining the refresh interval for the web-frontend in milliseconds.
REFUSED_REGISTRATION_BACKOFF - 类 中的静态变量org.apache.flink.configuration.TaskManagerOptions
REFUSED_REGISTRATION_DELAY - 类 中的静态变量org.apache.flink.configuration.ClusterOptions
 
registerAggregationConvergenceCriterion(String, Aggregator<T>, ConvergenceCriterion<T>) - 类 中的方法org.apache.flink.api.common.aggregators.AggregatorRegistry
 
registerAggregator(String, Aggregator<?>) - 类 中的方法org.apache.flink.api.common.aggregators.AggregatorRegistry
 
registerCachedFile(String, DistributedCache.DistributedCacheEntry) - 类 中的方法org.apache.flink.api.common.Plan
Register cache files at program level.
registerCloseable(C) - 类 中的方法org.apache.flink.util.AbstractCloseableRegistry
Registers a Closeable with the registry.
registeredReaders() - 接口 中的方法org.apache.flink.api.connector.source.SplitEnumeratorContext
Get the currently registered readers.
registerInflaterInputStreamFactory(String, InflaterInputStreamFactory<?>) - 类 中的静态方法org.apache.flink.api.common.io.FileInputFormat
Registers a decompression algorithm through a InflaterInputStreamFactory with a file extension for transparent decompression.
registerKryoType(Class<?>) - 类 中的方法org.apache.flink.api.common.ExecutionConfig
Registers the given type with the serialization stack.
registerNewOutput(String) - 类 中的方法org.apache.flink.api.common.eventtime.WatermarkOutputMultiplexer
Registers a new multiplexed output, which creates internal states for that output and returns an output ID that can be used to get a deferred or immediate WatermarkOutput for that output.
registerPojoType(Class<?>) - 类 中的方法org.apache.flink.api.common.ExecutionConfig
Registers the given type with the serialization stack.
registerProcessingTimer(long, Sink.ProcessingTimeService.ProcessingTimeCallback) - 接口 中的方法org.apache.flink.api.connector.sink.Sink.ProcessingTimeService
Invokes the given callback at the given timestamp.
registerReleaseHookIfAbsent(String, Runnable) - 类 中的方法org.apache.flink.util.SimpleUserCodeClassLoader
 
registerReleaseHookIfAbsent(String, Runnable) - 接口 中的方法org.apache.flink.util.UserCodeClassLoader
Registers a release hook which is being executed before the user code class loader is being released.
registerTypeWithKryoSerializer(Class<?>, T) - 类 中的方法org.apache.flink.api.common.ExecutionConfig
Registers the given type with a Kryo Serializer.
registerTypeWithKryoSerializer(Class<?>, Class<? extends Serializer>) - 类 中的方法org.apache.flink.api.common.ExecutionConfig
Registers the given Serializer via its class as a serializer for the given type at the KryoSerializer
registerUserCodeClassLoaderReleaseHookIfAbsent(String, Runnable) - 接口 中的方法org.apache.flink.api.common.functions.RuntimeContext
Registers a custom hook for the user code class loader release.
registerUserCodeClassLoaderReleaseHookIfAbsent(String, Runnable) - 类 中的方法org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
 
REGISTRATION_MAX_BACKOFF - 类 中的静态变量org.apache.flink.configuration.TaskManagerOptions
已过时。
REGISTRATION_TIMEOUT - 类 中的静态变量org.apache.flink.configuration.TaskManagerOptions
Defines the timeout it can take for the TaskManager registration.
relativeTimeMillis() - 类 中的方法org.apache.flink.util.clock.Clock
Gets the current relative time, in milliseconds.
relativeTimeMillis() - 类 中的方法org.apache.flink.util.clock.ManualClock
 
relativeTimeMillis() - 类 中的方法org.apache.flink.util.clock.SystemClock
 
relativeTimeNanos() - 类 中的方法org.apache.flink.util.clock.Clock
Gets the current relative time, in nanoseconds.
relativeTimeNanos() - 类 中的方法org.apache.flink.util.clock.ManualClock
 
relativeTimeNanos() - 类 中的方法org.apache.flink.util.clock.SystemClock
 
relativizePath(Path, Path) - 类 中的静态方法org.apache.flink.util.FileUtils
Relativize the given path with respect to the given base path if it is absolute.
release() - 类 中的方法org.apache.flink.core.fs.RefCountedFile
 
release() - 接口 中的方法org.apache.flink.util.RefCounted
Decreases the reference counter.
releaseArrays() - 类 中的方法org.apache.flink.core.memory.DataInputDeserializer
 
releaseOutputForSplit(String) - 接口 中的方法org.apache.flink.api.connector.source.ReaderOutput
Releases the SourceOutput created for the split with the given ID.
remove() - 类 中的方法org.apache.flink.api.common.functions.util.CopyingIterator
 
remove() - 类 中的方法org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase.SimpleListIterable.SimpleListIterator
 
remove() - 类 中的方法org.apache.flink.api.common.operators.util.ListKeyGroupedIterator.ValuesIterator
 
remove(K) - 接口 中的方法org.apache.flink.api.common.state.BroadcastState
Deletes the mapping of the given key.
remove(UK) - 接口 中的方法org.apache.flink.api.common.state.MapState
Deletes the mapping of the given key.
remove(int) - 类 中的方法org.apache.flink.types.ListValue
 
remove(Object) - 类 中的方法org.apache.flink.types.ListValue
 
remove(Object) - 类 中的方法org.apache.flink.types.MapValue
 
remove() - 类 中的方法org.apache.flink.util.CloseableIterator.IteratorAdapter
 
remove() - 类 中的方法org.apache.flink.util.LongValueSequenceIterator
 
remove() - 类 中的方法org.apache.flink.util.NumberSequenceIterator
 
remove() - 类 中的方法org.apache.flink.util.UnionIterator
 
removeAll(Collection<?>) - 类 中的方法org.apache.flink.types.ListValue
 
removeCloseableInternal(Closeable) - 类 中的方法org.apache.flink.util.AbstractCloseableRegistry
Removes a mapping from the registry map, respecting locking.
removeConfig(ConfigOption<T>) - 类 中的方法org.apache.flink.configuration.Configuration
Removes given config option from the configuration.
removeConfig(ConfigOption<T>) - 类 中的方法org.apache.flink.configuration.DelegatingConfiguration
 
removeConfig(ConfigOption<T>) - 类 中的方法org.apache.flink.configuration.UnmodifiableConfiguration
 
removeEntropyMarkerIfPresent(FileSystem, Path) - 类 中的静态方法org.apache.flink.core.fs.EntropyInjector
Removes the entropy marker string from the path, if the given file system is an entropy-injecting file system (implements EntropyInjectingFileSystem) and the entropy marker key is present.
removeField(int) - 类 中的方法org.apache.flink.types.Record
Removes the field at the given position.
removeShutdownHook(Thread, String, Logger) - 类 中的静态方法org.apache.flink.util.ShutdownHookUtil
Removes a shutdown hook from the JVM.
rename(Path, Path) - 类 中的方法org.apache.flink.core.fs.FileSystem
Renames the file/directory src to dst.
rename(Path, Path) - 类 中的方法org.apache.flink.core.fs.LimitedConnectionsFileSystem
 
rename(Path, Path) - 类 中的方法org.apache.flink.core.fs.local.LocalFileSystem
 
rename(Path, Path) - 类 中的方法org.apache.flink.core.fs.SafetyNetWrapperFileSystem
 
reopen(FileInputSplit, Tuple2<Long, Long>) - 类 中的方法org.apache.flink.api.common.io.BinaryInputFormat
 
reopen(S, T) - 接口 中的方法org.apache.flink.api.common.io.CheckpointableInputFormat
Restores the state of a parallel instance reading from an InputFormat.
reopen(FileInputSplit, Long) - 类 中的方法org.apache.flink.api.common.io.DelimitedInputFormat
 
replaceNonWordChars(StringValue, char) - 类 中的静态方法org.apache.flink.util.StringValueUtils
Replaces all non-word characters in a string by a given character.
ReplicatingInputFormat<OT,S extends InputSplit> - org.apache.flink.api.common.io中的类
A ReplicatingInputFormat replicates any InputFormat to all parallel instances of a DataSource, i.e., the full input of the replicated InputFormat is completely processed by each parallel instance of the DataSource.
ReplicatingInputFormat(InputFormat<OT, S>) - 类 的构造器org.apache.flink.api.common.io.ReplicatingInputFormat
 
ReplicatingInputSplitAssigner - org.apache.flink.api.common.io中的类
Assigns each InputSplit to each requesting parallel instance.
ReplicatingInputSplitAssigner(Collection<InputSplit>) - 类 的构造器org.apache.flink.api.common.io.ReplicatingInputSplitAssigner
 
ReplicatingInputSplitAssigner(InputSplit[]) - 类 的构造器org.apache.flink.api.common.io.ReplicatingInputSplitAssigner
 
REPORTER_CLASS - 类 中的静态变量org.apache.flink.configuration.MetricOptions
 
REPORTER_CONFIG_PARAMETER - 类 中的静态变量org.apache.flink.configuration.MetricOptions
 
REPORTER_INTERVAL - 类 中的静态变量org.apache.flink.configuration.MetricOptions
 
REPORTERS_LIST - 类 中的静态变量org.apache.flink.configuration.MetricOptions
An optional list of reporter names.
requestUnpooledMemorySegments(int) - 接口 中的方法org.apache.flink.core.memory.MemorySegmentProvider
 
require(int) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.NoFetchingInput
Require makes sure that at least required number of bytes are kept in the buffer.
requiresCleanupOfRecoverableState() - 类 中的方法org.apache.flink.core.fs.local.LocalRecoverableWriter
 
requiresCleanupOfRecoverableState() - 接口 中的方法org.apache.flink.core.fs.RecoverableWriter
Marks if the writer requires to do any additional cleanup/freeing of resources occupied as part of a RecoverableWriter.ResumeRecoverable, e.g. temporarily files created or objects uploaded to external systems.
reset() - 接口 中的方法org.apache.flink.api.common.aggregators.Aggregator
Resets the internal state of the aggregator.
reset() - 类 中的方法org.apache.flink.api.common.aggregators.DoubleSumAggregator
 
reset() - 类 中的方法org.apache.flink.api.common.aggregators.LongSumAggregator
 
reset() - 类 中的方法org.apache.flink.api.common.operators.base.BulkIterationBase.TerminationCriterionAggregator
 
reset() - 类 中的方法org.apache.flink.core.fs.FSDataInputStreamWrapper
 
reset() - 类 中的方法org.apache.flink.core.memory.ByteArrayOutputStreamWithPos
 
reset() - 类 中的方法org.apache.flink.core.memory.MemorySegmentInputStreamWithPos
 
resetErrorStateAndParse(byte[], int, int, byte[], T) - 类 中的方法org.apache.flink.types.parser.FieldParser
Parses the value of a field from the byte array, taking care of properly reset the state of this parser.
resetLocal() - 接口 中的方法org.apache.flink.api.common.accumulators.Accumulator
Reset the local value.
resetLocal() - 类 中的方法org.apache.flink.api.common.accumulators.AverageAccumulator
 
resetLocal() - 类 中的方法org.apache.flink.api.common.accumulators.DoubleCounter
 
resetLocal() - 类 中的方法org.apache.flink.api.common.accumulators.DoubleMaximum
 
resetLocal() - 类 中的方法org.apache.flink.api.common.accumulators.DoubleMinimum
 
resetLocal() - 类 中的方法org.apache.flink.api.common.accumulators.Histogram
 
resetLocal() - 类 中的方法org.apache.flink.api.common.accumulators.IntCounter
 
resetLocal() - 类 中的方法org.apache.flink.api.common.accumulators.IntMaximum
 
resetLocal() - 类 中的方法org.apache.flink.api.common.accumulators.IntMinimum
 
resetLocal() - 类 中的方法org.apache.flink.api.common.accumulators.ListAccumulator
 
resetLocal() - 类 中的方法org.apache.flink.api.common.accumulators.LongCounter
 
resetLocal() - 类 中的方法org.apache.flink.api.common.accumulators.LongMaximum
 
resetLocal() - 类 中的方法org.apache.flink.api.common.accumulators.LongMinimum
 
resetLocal() - 类 中的方法org.apache.flink.api.common.accumulators.SerializedListAccumulator
 
resetParserState() - 类 中的方法org.apache.flink.types.parser.FieldParser
Reset the state of the parser.
ResettableValue<T extends Value> - org.apache.flink.types中的接口
 
resolveClass(ObjectStreamClass) - 类 中的方法org.apache.flink.util.InstantiationUtil.ClassLoaderObjectInputStream
 
resolveClassByName(DataInputView, ClassLoader) - 类 中的静态方法org.apache.flink.util.InstantiationUtil
Loads a class by name from the given input stream and reflectively instantiates it.
resolveClassByName(DataInputView, ClassLoader, Class<? super T>) - 类 中的静态方法org.apache.flink.util.InstantiationUtil
Loads a class by name from the given input stream and reflectively instantiates it.
resolveCompatibilityWithNested(TypeSerializerSchemaCompatibility<?>, TypeSerializer<?>...) - 类 中的方法org.apache.flink.api.common.typeutils.NestedSerializersSnapshotDelegate
已过时。
this no method will be removed in the future. Resolving compatibility for nested serializers is now handled by CompositeTypeSerializerSnapshot.
resolveOuterSchemaCompatibility(GenericArraySerializer<C>) - 类 中的方法org.apache.flink.api.common.typeutils.base.GenericArraySerializerSnapshot
 
resolveOuterSchemaCompatibility(S) - 类 中的方法org.apache.flink.api.common.typeutils.CompositeTypeSerializerSnapshot
Checks the schema compatibility of the given new serializer based on the outer snapshot.
resolveOuterSchemaCompatibility(NullableSerializer<T>) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.NullableSerializer.NullableSerializerSnapshot
 
resolveOuterSchemaCompatibility(RowSerializer) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.RowSerializer.RowSerializerSnapshot
 
resolveProxyClass(String[]) - 类 中的方法org.apache.flink.util.InstantiationUtil.ClassLoaderObjectInputStream
 
resolveSchemaCompatibility(TypeSerializer<T>) - 类 中的方法org.apache.flink.api.common.typeutils.BackwardsCompatibleSerializerSnapshot
 
resolveSchemaCompatibility(TypeSerializer<C>) - 类 中的方法org.apache.flink.api.common.typeutils.base.CollectionSerializerConfigSnapshot
已过时。
 
resolveSchemaCompatibility(TypeSerializer<T>) - 类 中的方法org.apache.flink.api.common.typeutils.base.EnumSerializer.EnumSerializerConfigSnapshot
已过时。
 
resolveSchemaCompatibility(TypeSerializer<T>) - 类 中的方法org.apache.flink.api.common.typeutils.base.EnumSerializer.EnumSerializerSnapshot
 
resolveSchemaCompatibility(TypeSerializer<C[]>) - 类 中的方法org.apache.flink.api.common.typeutils.base.GenericArraySerializerConfigSnapshot
已过时。
 
resolveSchemaCompatibility(TypeSerializer<Map<K, V>>) - 类 中的方法org.apache.flink.api.common.typeutils.base.MapSerializerConfigSnapshot
已过时。
 
resolveSchemaCompatibility(TypeSerializer<T>) - 类 中的方法org.apache.flink.api.common.typeutils.CompositeTypeSerializerSnapshot
 
resolveSchemaCompatibility(TypeSerializer<T>) - 类 中的方法org.apache.flink.api.common.typeutils.GenericTypeSerializerSnapshot
 
resolveSchemaCompatibility(TypeSerializer<T>) - 类 中的方法org.apache.flink.api.common.typeutils.ParameterlessTypeSerializerConfig
已过时。
 
resolveSchemaCompatibility(TypeSerializer<T>) - 类 中的方法org.apache.flink.api.common.typeutils.SimpleTypeSerializerSnapshot
 
resolveSchemaCompatibility(TypeSerializer<T>) - 类 中的方法org.apache.flink.api.common.typeutils.TypeSerializerConfigSnapshot
已过时。
 
resolveSchemaCompatibility(TypeSerializer<T>) - 接口 中的方法org.apache.flink.api.common.typeutils.TypeSerializerSnapshot
Checks a new serializer's compatibility to read data written by the prior serializer.
resolveSchemaCompatibility(TypeSerializer<T>) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer.CopyableValueSerializerConfigSnapshot
已过时。
 
resolveSchemaCompatibility(TypeSerializer<Either<L, R>>) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.EitherSerializerConfigSnapshot
已过时。
 
resolveSchemaCompatibility(TypeSerializer<Either<L, R>>) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.EitherSerializerSnapshot
已过时。
 
resolveSchemaCompatibility(TypeSerializer<T>) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer.KryoSerializerConfigSnapshot
已过时。
 
resolveSchemaCompatibility(TypeSerializer<T>) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializerSnapshot
 
resolveSchemaCompatibility(TypeSerializer<T>) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.NullableSerializer.NullableSerializerConfigSnapshot
已过时。
 
resolveSchemaCompatibility(TypeSerializer<T>) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.PojoSerializer.PojoSerializerConfigSnapshot
已过时。
This legacy snapshot delegates compatibility checks to the PojoSerializerSnapshot.
resolveSchemaCompatibility(TypeSerializer<T>) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.PojoSerializerSnapshot
 
resolveSchemaCompatibility(TypeSerializer<Row>) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.RowSerializer.RowSerializerConfigSnapshot
已过时。
 
resolveSchemaCompatibility(TypeSerializer<T>) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.ValueSerializer.ValueSerializerConfigSnapshot
已过时。
 
resolveSchemaCompatibilityViaRedirectingToNewSnapshotClass(TypeSerializerConfigSnapshot<E>) - 接口 中的方法org.apache.flink.api.common.typeutils.TypeSerializerConfigSnapshot.SelfResolvingTypeSerializer
已过时。
Resolve Schema Compatibility.
resolveSchemaCompatibilityViaRedirectingToNewSnapshotClass(TypeSerializerConfigSnapshot<Tuple0>) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.Tuple0Serializer
 
resolveSchemaCompatibilityViaRedirectingToNewSnapshotClass(TypeSerializerConfigSnapshot<T>) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.TupleSerializer
 
resolveUndefined(boolean) - 枚举 中的方法org.apache.flink.util.TernaryBoolean
Gets the boolean value corresponding to this value.
Resource<T extends Resource<T>> - org.apache.flink.api.common.resources中的类
Base class for resources one can specify.
Resource(String, double) - 类 的构造器org.apache.flink.api.common.resources.Resource
 
Resource(String, BigDecimal) - 类 的构造器org.apache.flink.api.common.resources.Resource
 
RESOURCE_MANAGER_IPC_PORT_KEY - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
RESOURCE_STABILIZATION_TIMEOUT - 类 中的静态变量org.apache.flink.configuration.JobManagerOptions
 
RESOURCE_WAIT_TIMEOUT - 类 中的静态变量org.apache.flink.configuration.JobManagerOptions
 
ResourceGuard - org.apache.flink.util中的类
This class is a guard for shared resources with the following invariants.
ResourceGuard() - 类 的构造器org.apache.flink.util.ResourceGuard
 
ResourceGuard.Lease - org.apache.flink.util中的类
A lease is issued by the ResourceGuard as result of calls to ResourceGuard.acquireResource().
ResourceManagerOptions - org.apache.flink.configuration中的类
The set of configuration options relating to the ResourceManager.
ResourceSpec - org.apache.flink.api.common.operators中的类
Describe the different resource factors of the operator with UDF.
ResourceSpec.Builder - org.apache.flink.api.common.operators中的类
Builder for the ResourceSpec.
RESTART_STRATEGY - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
RESTART_STRATEGY - 类 中的静态变量org.apache.flink.configuration.RestartStrategyOptions
 
RESTART_STRATEGY_EXPONENTIAL_DELAY_BACKOFF_MULTIPLIER - 类 中的静态变量org.apache.flink.configuration.RestartStrategyOptions
 
RESTART_STRATEGY_EXPONENTIAL_DELAY_INITIAL_BACKOFF - 类 中的静态变量org.apache.flink.configuration.RestartStrategyOptions
 
RESTART_STRATEGY_EXPONENTIAL_DELAY_JITTER_FACTOR - 类 中的静态变量org.apache.flink.configuration.RestartStrategyOptions
 
RESTART_STRATEGY_EXPONENTIAL_DELAY_MAX_BACKOFF - 类 中的静态变量org.apache.flink.configuration.RestartStrategyOptions
 
RESTART_STRATEGY_EXPONENTIAL_DELAY_RESET_BACKOFF_THRESHOLD - 类 中的静态变量org.apache.flink.configuration.RestartStrategyOptions
 
RESTART_STRATEGY_FAILURE_RATE_DELAY - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
RESTART_STRATEGY_FAILURE_RATE_DELAY - 类 中的静态变量org.apache.flink.configuration.RestartStrategyOptions
 
RESTART_STRATEGY_FAILURE_RATE_FAILURE_RATE_INTERVAL - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
RESTART_STRATEGY_FAILURE_RATE_FAILURE_RATE_INTERVAL - 类 中的静态变量org.apache.flink.configuration.RestartStrategyOptions
 
RESTART_STRATEGY_FAILURE_RATE_MAX_FAILURES_PER_INTERVAL - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
RESTART_STRATEGY_FAILURE_RATE_MAX_FAILURES_PER_INTERVAL - 类 中的静态变量org.apache.flink.configuration.RestartStrategyOptions
 
RESTART_STRATEGY_FIXED_DELAY_ATTEMPTS - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
RESTART_STRATEGY_FIXED_DELAY_ATTEMPTS - 类 中的静态变量org.apache.flink.configuration.RestartStrategyOptions
 
RESTART_STRATEGY_FIXED_DELAY_DELAY - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
RESTART_STRATEGY_FIXED_DELAY_DELAY - 类 中的静态变量org.apache.flink.configuration.RestartStrategyOptions
 
RestartStrategies - org.apache.flink.api.common.restartstrategy中的类
This class defines methods to generate RestartStrategyConfigurations.
RestartStrategies() - 类 的构造器org.apache.flink.api.common.restartstrategy.RestartStrategies
 
RestartStrategies.ExponentialDelayRestartStrategyConfiguration - org.apache.flink.api.common.restartstrategy中的类
Configuration representing an exponential delay restart strategy.
RestartStrategies.FailureRateRestartStrategyConfiguration - org.apache.flink.api.common.restartstrategy中的类
Configuration representing a failure rate restart strategy.
RestartStrategies.FallbackRestartStrategyConfiguration - org.apache.flink.api.common.restartstrategy中的类
Restart strategy configuration that could be used by jobs to use cluster level restart strategy.
RestartStrategies.FixedDelayRestartStrategyConfiguration - org.apache.flink.api.common.restartstrategy中的类
Configuration representing a fixed delay restart strategy.
RestartStrategies.NoRestartStrategyConfiguration - org.apache.flink.api.common.restartstrategy中的类
Configuration representing no restart strategy.
RestartStrategies.RestartStrategyConfiguration - org.apache.flink.api.common.restartstrategy中的类
Abstract configuration for restart strategies.
RestartStrategyOptions - org.apache.flink.configuration中的类
Config options for restart strategies.
RestOptions - org.apache.flink.configuration中的类
Configuration parameters for REST communication.
RestOptions() - 类 的构造器org.apache.flink.configuration.RestOptions
 
restoreEnumerator(SplitEnumeratorContext<NumberSequenceSource.NumberSequenceSplit>, Collection<NumberSequenceSource.NumberSequenceSplit>) - 类 中的方法org.apache.flink.api.connector.source.lib.NumberSequenceSource
 
restoreEnumerator(SplitEnumeratorContext<SplitT>, EnumChkT) - 接口 中的方法org.apache.flink.api.connector.source.Source
Restores an enumerator from a checkpoint.
restoreSerializer() - 类 中的方法org.apache.flink.api.common.typeutils.BackwardsCompatibleSerializerSnapshot
 
restoreSerializer() - 类 中的方法org.apache.flink.api.common.typeutils.base.EnumSerializer.EnumSerializerSnapshot
 
restoreSerializer() - 类 中的方法org.apache.flink.api.common.typeutils.base.GenericArraySerializerConfigSnapshot
已过时。
 
restoreSerializer() - 类 中的方法org.apache.flink.api.common.typeutils.CompositeTypeSerializerSnapshot
 
restoreSerializer() - 类 中的方法org.apache.flink.api.common.typeutils.GenericTypeSerializerSnapshot
 
restoreSerializer() - 类 中的方法org.apache.flink.api.common.typeutils.SimpleTypeSerializerSnapshot
 
restoreSerializer() - 类 中的方法org.apache.flink.api.common.typeutils.TypeSerializerConfigSnapshot
已过时。
Creates a serializer using this configuration, that is capable of reading data written by the serializer described by this configuration.
restoreSerializer() - 接口 中的方法org.apache.flink.api.common.typeutils.TypeSerializerSnapshot
Recreates a serializer instance from this snapshot.
restoreSerializer() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.EitherSerializerSnapshot
已过时。
 
restoreSerializer() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializerSnapshot
 
restoreSerializer() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.PojoSerializerSnapshot
 
ResultTypeQueryable<T> - org.apache.flink.api.java.typeutils中的接口
This interface can be implemented by functions and input formats to tell the framework about their produced data type.
retain() - 类 中的方法org.apache.flink.core.fs.RefCountedFile
 
retain() - 接口 中的方法org.apache.flink.util.RefCounted
Increases the reference counter.
retainAll(Collection<?>) - 类 中的方法org.apache.flink.types.ListValue
 
rethrow(Throwable) - 类 中的静态方法org.apache.flink.util.ExceptionUtils
Throws the given Throwable in scenarios where the signatures do not allow you to throw an arbitrary Throwable.
rethrow(Throwable, String) - 类 中的静态方法org.apache.flink.util.ExceptionUtils
Throws the given Throwable in scenarios where the signatures do not allow you to throw an arbitrary Throwable.
rethrowException(Throwable, String) - 类 中的静态方法org.apache.flink.util.ExceptionUtils
Throws the given Throwable in scenarios where the signatures do allow to throw a Exception.
rethrowException(Throwable) - 类 中的静态方法org.apache.flink.util.ExceptionUtils
Throws the given Throwable in scenarios where the signatures do allow to throw a Exception.
rethrowIfFatalError(Throwable) - 类 中的静态方法org.apache.flink.util.ExceptionUtils
Rethrows the given Throwable, if it represents an error that is fatal to the JVM.
rethrowIfFatalErrorOrOOM(Throwable) - 类 中的静态方法org.apache.flink.util.ExceptionUtils
Rethrows the given Throwable, if it represents an error that is fatal to the JVM or an out-of-memory error.
rethrowIOException(Throwable) - 类 中的静态方法org.apache.flink.util.ExceptionUtils
Re-throws the given Throwable in scenarios where the signatures allows only IOExceptions (and RuntimeException and Error).
RETRIEVE_TASK_MANAGER_HOSTNAME - 类 中的静态变量org.apache.flink.configuration.JobManagerOptions
Flag indicating whether JobManager would retrieve canonical host name of TaskManager during registration.
retrieveResourceInfo(long) - 接口 中的方法org.apache.flink.api.common.externalresource.ExternalResourceDriver
Retrieve the information of the external resources according to the amount.
retry(Supplier<CompletableFuture<T>>, int, Executor) - 类 中的静态方法org.apache.flink.util.concurrent.FutureUtils
Retry the given operation the given number of times in case of a failure.
retry(Supplier<CompletableFuture<T>>, int, Predicate<Throwable>, Executor) - 类 中的静态方法org.apache.flink.util.concurrent.FutureUtils
Retry the given operation the given number of times in case of a failure only when an exception is retryable.
RETRY_DELAY - 类 中的静态变量org.apache.flink.configuration.RestOptions
The time in ms that the client waits between retries.
RETRY_GATE_CLOSED_FOR - 类 中的静态变量org.apache.flink.configuration.AkkaOptions
Milliseconds a gate should be closed for after a remote connection was disconnected.
RETRY_MAX_ATTEMPTS - 类 中的静态变量org.apache.flink.configuration.RestOptions
The number of retries the client will attempt if a retryable operations fails.
RetryException(String) - 异常错误 的构造器org.apache.flink.util.concurrent.FutureUtils.RetryException
 
RetryException(String, Throwable) - 异常错误 的构造器org.apache.flink.util.concurrent.FutureUtils.RetryException
 
RetryException(Throwable) - 异常错误 的构造器org.apache.flink.util.concurrent.FutureUtils.RetryException
 
RetryStrategy - org.apache.flink.util.concurrent中的接口
Interface that encapsulates retry logic.
retrySuccessfulWithDelay(Supplier<CompletableFuture<T>>, Time, Deadline, Predicate<T>, ScheduledExecutor) - 类 中的静态方法org.apache.flink.util.concurrent.FutureUtils
Retry the given operation with the given delay in between successful completions where the result does not match a given predicate.
retryWithDelay(Supplier<CompletableFuture<T>>, int, Time, Predicate<Throwable>, ScheduledExecutor) - 类 中的静态方法org.apache.flink.util.concurrent.FutureUtils
Retry the given operation with the given delay in between failures.
retryWithDelay(Supplier<CompletableFuture<T>>, RetryStrategy, Predicate<Throwable>, ScheduledExecutor) - 类 中的静态方法org.apache.flink.util.concurrent.FutureUtils
Retry the given operation with the given delay in between failures.
retryWithDelay(Supplier<CompletableFuture<T>>, int, Time, ScheduledExecutor) - 类 中的静态方法org.apache.flink.util.concurrent.FutureUtils
Retry the given operation with the given delay in between failures.
retryWithDelay(Supplier<CompletableFuture<T>>, RetryStrategy, ScheduledExecutor) - 类 中的静态方法org.apache.flink.util.concurrent.FutureUtils
Retry the given operation with the given delay in between failures.
returnExpiredIfNotCleanedUp() - 类 中的方法org.apache.flink.api.common.state.StateTtlConfig.Builder
 
returnInputSplit(List<InputSplit>, int) - 类 中的方法org.apache.flink.api.common.io.DefaultInputSplitAssigner
 
returnInputSplit(List<InputSplit>, int) - 类 中的方法org.apache.flink.api.common.io.LocatableInputSplitAssigner
 
returnInputSplit(List<InputSplit>, int) - 类 中的方法org.apache.flink.api.common.io.ReplicatingInputSplitAssigner
 
returnInputSplit(List<InputSplit>, int) - 接口 中的方法org.apache.flink.core.io.InputSplitAssigner
Return the splits to assigner if the task failed to process it.
RichAggregateFunction<IN,ACC,OUT> - org.apache.flink.api.common.functions中的类
Rich variant of the AggregateFunction.
RichAggregateFunction() - 类 的构造器org.apache.flink.api.common.functions.RichAggregateFunction
 
RichCoGroupFunction<IN1,IN2,OUT> - org.apache.flink.api.common.functions中的类
Rich variant of the CoGroupFunction.
RichCoGroupFunction() - 类 的构造器org.apache.flink.api.common.functions.RichCoGroupFunction
 
RichCrossFunction<IN1,IN2,OUT> - org.apache.flink.api.common.functions中的类
Rich variant of the CrossFunction.
RichCrossFunction() - 类 的构造器org.apache.flink.api.common.functions.RichCrossFunction
 
RichFilterFunction<T> - org.apache.flink.api.common.functions中的类
Rich variant of the FilterFunction.
RichFilterFunction() - 类 的构造器org.apache.flink.api.common.functions.RichFilterFunction
 
RichFlatJoinFunction<IN1,IN2,OUT> - org.apache.flink.api.common.functions中的类
Rich variant of the FlatJoinFunction.
RichFlatJoinFunction() - 类 的构造器org.apache.flink.api.common.functions.RichFlatJoinFunction
 
RichFlatMapFunction<IN,OUT> - org.apache.flink.api.common.functions中的类
Rich variant of the FlatMapFunction.
RichFlatMapFunction() - 类 的构造器org.apache.flink.api.common.functions.RichFlatMapFunction
 
RichFunction - org.apache.flink.api.common.functions中的接口
An base interface for all rich user-defined functions.
RichGroupCombineFunction<IN,OUT> - org.apache.flink.api.common.functions中的类
Rich variant of the GroupCombineFunction.
RichGroupCombineFunction() - 类 的构造器org.apache.flink.api.common.functions.RichGroupCombineFunction
 
RichGroupReduceFunction<IN,OUT> - org.apache.flink.api.common.functions中的类
Rich variant of the GroupReduceFunction.
RichGroupReduceFunction() - 类 的构造器org.apache.flink.api.common.functions.RichGroupReduceFunction
 
RichInputFormat<OT,T extends InputSplit> - org.apache.flink.api.common.io中的类
An abstract stub implementation for Rich input formats.
RichInputFormat() - 类 的构造器org.apache.flink.api.common.io.RichInputFormat
 
RichJoinFunction<IN1,IN2,OUT> - org.apache.flink.api.common.functions中的类
Rich variant of the JoinFunction.
RichJoinFunction() - 类 的构造器org.apache.flink.api.common.functions.RichJoinFunction
 
RichMapFunction<IN,OUT> - org.apache.flink.api.common.functions中的类
Rich variant of the MapFunction.
RichMapFunction() - 类 的构造器org.apache.flink.api.common.functions.RichMapFunction
 
RichMapPartitionFunction<I,O> - org.apache.flink.api.common.functions中的类
Rich variant of the MapPartitionFunction.
RichMapPartitionFunction() - 类 的构造器org.apache.flink.api.common.functions.RichMapPartitionFunction
 
RichOutputFormat<IT> - org.apache.flink.api.common.io中的类
An abstract stub implementation for Rich output formats.
RichOutputFormat() - 类 的构造器org.apache.flink.api.common.io.RichOutputFormat
 
RichReduceFunction<T> - org.apache.flink.api.common.functions中的类
Rich variant of the ReduceFunction.
RichReduceFunction() - 类 的构造器org.apache.flink.api.common.functions.RichReduceFunction
 
right() - 类 中的方法org.apache.flink.types.Either.Left
 
Right(R) - 类 中的静态方法org.apache.flink.types.Either
Create a Right value of Either
right() - 类 中的方法org.apache.flink.types.Either
Retrieve the Right value of Either.
Right(R) - 类 的构造器org.apache.flink.types.Either.Right
 
right() - 类 中的方法org.apache.flink.types.Either.Right
 
roundDownToPowerOf2(int) - 类 中的静态方法org.apache.flink.util.MathUtils
Decrements the given number down to the closest power of two.
roundUpToPowerOfTwo(int) - 类 中的静态方法org.apache.flink.util.MathUtils
Round the given number to the next power of two.
ROW(TypeInformation<?>...) - 类 中的静态方法org.apache.flink.api.common.typeinfo.Types
Returns type information for Row with fields of the given types.
Row - org.apache.flink.types中的类
A row is a fixed-length, null-aware composite type for storing multiple values in a deterministic field order.
Row(RowKind, int) - 类 的构造器org.apache.flink.types.Row
Creates a fixed-length row in position-based field mode.
Row(int) - 类 的构造器org.apache.flink.types.Row
Creates a fixed-length row in position-based field mode.
ROW_KIND_OFFSET - 类 中的静态变量org.apache.flink.api.java.typeutils.runtime.RowSerializer
 
ROW_NAMED(String[], TypeInformation<?>...) - 类 中的静态方法org.apache.flink.api.common.typeinfo.Types
Returns type information for Row with fields of the given types and with given names.
RowComparator - org.apache.flink.api.java.typeutils.runtime中的类
Comparator for Row.
RowComparator(int, int[], TypeComparator<Object>[], TypeSerializer<Object>[], boolean[]) - 类 的构造器org.apache.flink.api.java.typeutils.runtime.RowComparator
General constructor for RowComparator.
RowKind - org.apache.flink.types中的枚举
Lists all kinds of changes that a row can describe in a changelog.
RowSerializer - org.apache.flink.api.java.typeutils.runtime中的类
Serializer for Row.
RowSerializer(TypeSerializer<?>[]) - 类 的构造器org.apache.flink.api.java.typeutils.runtime.RowSerializer
 
RowSerializer(TypeSerializer<?>[], LinkedHashMap<String, Integer>) - 类 的构造器org.apache.flink.api.java.typeutils.runtime.RowSerializer
 
RowSerializer(TypeSerializer<?>[], LinkedHashMap<String, Integer>, boolean) - 类 的构造器org.apache.flink.api.java.typeutils.runtime.RowSerializer
 
RowSerializer.RowSerializerConfigSnapshot - org.apache.flink.api.java.typeutils.runtime中的类
已过时。
this snapshot class is no longer in use, and is maintained only for backwards compatibility. It is fully replaced by RowSerializer.RowSerializerSnapshot.
RowSerializer.RowSerializerSnapshot - org.apache.flink.api.java.typeutils.runtime中的类
A TypeSerializerSnapshot for RowSerializer.
RowSerializerConfigSnapshot() - 类 的构造器org.apache.flink.api.java.typeutils.runtime.RowSerializer.RowSerializerConfigSnapshot
已过时。
This empty nullary constructor is required for deserializing the configuration.
RowSerializerConfigSnapshot(TypeSerializer<?>[]) - 类 的构造器org.apache.flink.api.java.typeutils.runtime.RowSerializer.RowSerializerConfigSnapshot
已过时。
 
RowSerializerSnapshot() - 类 的构造器org.apache.flink.api.java.typeutils.runtime.RowSerializer.RowSerializerSnapshot
 
RowTypeInfo - org.apache.flink.api.java.typeutils中的类
RowTypeInfo(TypeInformation<?>...) - 类 的构造器org.apache.flink.api.java.typeutils.RowTypeInfo
 
RowTypeInfo(TypeInformation<?>[], String[]) - 类 的构造器org.apache.flink.api.java.typeutils.RowTypeInfo
 
RowUtils - org.apache.flink.types中的类
Utilities to deal with Row instances.
RPC_BIND_PORT - 类 中的静态变量org.apache.flink.configuration.JobManagerOptions
The local port that the job manager binds to.
RPC_BIND_PORT - 类 中的静态变量org.apache.flink.configuration.TaskManagerOptions
The local port that the task manager binds to.
RPC_PORT - 类 中的静态变量org.apache.flink.configuration.TaskManagerOptions
The default network port range the task manager expects incoming IPC connections.
run() - 类 中的方法org.apache.flink.api.common.io.FileInputFormat.InputSplitOpenThread
 
run() - 接口 中的方法org.apache.flink.util.function.RunnableWithException
The work method.
run() - 接口 中的方法org.apache.flink.util.function.ThrowingRunnable
The work method.
run() - 类 中的方法org.apache.flink.util.ThrowableCatchingRunnable
 
runAfterwards(CompletableFuture<?>, RunnableWithException) - 类 中的静态方法org.apache.flink.util.concurrent.FutureUtils
Run the given action after the completion of the given future.
runAfterwardsAsync(CompletableFuture<?>, RunnableWithException) - 类 中的静态方法org.apache.flink.util.concurrent.FutureUtils
Run the given action after the completion of the given future.
runAfterwardsAsync(CompletableFuture<?>, RunnableWithException, Executor) - 类 中的静态方法org.apache.flink.util.concurrent.FutureUtils
Run the given action after the completion of the given future.
runCleanupForEveryRecord() - 类 中的方法org.apache.flink.api.common.state.StateTtlConfig.IncrementalCleanupStrategy
 
runIfNotDoneAndGet(RunnableFuture<T>) - 类 中的静态方法org.apache.flink.util.concurrent.FutureUtils
Run the given RunnableFuture if it is not done, and then retrieves its result.
runInCoordinatorThread(Runnable) - 接口 中的方法org.apache.flink.api.connector.source.SplitEnumeratorContext
Invoke the given runnable in the source coordinator thread.
RunnableWithException - org.apache.flink.util.function中的接口
Similar to a Runnable, this interface is used to capture a block of code to be executed.
RUNTIME_HASH_JOIN_BLOOM_FILTERS_KEY - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
RUNTIME_MODE - 类 中的静态变量org.apache.flink.configuration.ExecutionOptions
 
RuntimeComparatorFactory<T> - org.apache.flink.api.java.typeutils.runtime中的类
 
RuntimeComparatorFactory() - 类 的构造器org.apache.flink.api.java.typeutils.runtime.RuntimeComparatorFactory
 
RuntimeComparatorFactory(TypeComparator<T>) - 类 的构造器org.apache.flink.api.java.typeutils.runtime.RuntimeComparatorFactory
 
RuntimeContext - org.apache.flink.api.common.functions中的接口
A RuntimeContext contains information about the context in which functions are executed.
RuntimeContextInitializationContextAdapters - org.apache.flink.api.common.serialization中的类
RuntimeContextInitializationContextAdapters() - 类 的构造器org.apache.flink.api.common.serialization.RuntimeContextInitializationContextAdapters
 
RuntimeExecutionMode - org.apache.flink.api.common中的枚举
Runtime execution mode of DataStream programs.
RuntimePairComparatorFactory<T1,T2> - org.apache.flink.api.java.typeutils.runtime中的类
 
RuntimePairComparatorFactory() - 类 的构造器org.apache.flink.api.java.typeutils.runtime.RuntimePairComparatorFactory
 
RuntimeSerializerFactory<T> - org.apache.flink.api.java.typeutils.runtime中的类
 
RuntimeSerializerFactory() - 类 的构造器org.apache.flink.api.java.typeutils.runtime.RuntimeSerializerFactory
 
RuntimeSerializerFactory(TypeSerializer<T>, Class<T>) - 类 的构造器org.apache.flink.api.java.typeutils.runtime.RuntimeSerializerFactory
 
RuntimeUDFContext - org.apache.flink.api.common.functions.util中的类
A standalone implementation of the RuntimeContext, created by runtime UDF operators.
RuntimeUDFContext(TaskInfo, ClassLoader, ExecutionConfig, Map<String, Future<Path>>, Map<String, Accumulator<?, ?>>, OperatorMetricGroup) - 类 的构造器org.apache.flink.api.common.functions.util.RuntimeUDFContext
 
RuntimeUDFContext(TaskInfo, ClassLoader, ExecutionConfig, Map<String, Future<Path>>, Map<String, Accumulator<?, ?>>, OperatorMetricGroup, JobID) - 类 的构造器org.apache.flink.api.common.functions.util.RuntimeUDFContext
 

S

SafetyNetCloseableRegistry - org.apache.flink.core.fs中的类
This implementation of an AbstractCloseableRegistry registers WrappingProxyCloseable.
SafetyNetWrapperFileSystem - org.apache.flink.core.fs中的类
This is a WrappingProxy around FileSystem which (i) wraps all opened streams as ClosingFSDataInputStream or ClosingFSDataOutputStream and (ii) registers them to a SafetyNetCloseableRegistry.
SafetyNetWrapperFileSystem(FileSystem, SafetyNetCloseableRegistry) - 类 的构造器org.apache.flink.core.fs.SafetyNetWrapperFileSystem
 
SameTypePairComparator<T> - org.apache.flink.api.common.typeutils中的类
 
SameTypePairComparator(TypeComparator<T>) - 类 的构造器org.apache.flink.api.common.typeutils.SameTypePairComparator
 
sameTypeVars(Type, Type) - 类 中的静态方法org.apache.flink.api.java.typeutils.TypeExtractionUtils
Checks whether two types are type variables describing the same.
SAVEPOINT_DIRECTORY - 类 中的静态变量org.apache.flink.configuration.CheckpointingOptions
The default directory for savepoints.
SAVEPOINT_DIRECTORY_KEY - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
SAVEPOINT_FS_DIRECTORY_KEY - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
This key was used in Flink versions <= 1.1.X with the savepoint backend configuration. We now always use the FileSystem for savepoints. For this, the only relevant config key is CheckpointingOptions.SAVEPOINT_DIRECTORY.
schedule(Runnable, long, TimeUnit) - 接口 中的方法org.apache.flink.util.concurrent.ScheduledExecutor
Executes the given command after the given delay.
schedule(Callable<V>, long, TimeUnit) - 接口 中的方法org.apache.flink.util.concurrent.ScheduledExecutor
Executes the given callable after the given delay.
schedule(Runnable, long, TimeUnit) - 类 中的方法org.apache.flink.util.concurrent.ScheduledExecutorServiceAdapter
 
schedule(Callable<V>, long, TimeUnit) - 类 中的方法org.apache.flink.util.concurrent.ScheduledExecutorServiceAdapter
 
scheduleAtFixedRate(Runnable, long, long, TimeUnit) - 接口 中的方法org.apache.flink.util.concurrent.ScheduledExecutor
Executes the given command periodically.
scheduleAtFixedRate(Runnable, long, long, TimeUnit) - 类 中的方法org.apache.flink.util.concurrent.ScheduledExecutorServiceAdapter
 
ScheduledExecutor - org.apache.flink.util.concurrent中的接口
Extension for the Executor interface which is enriched by method for scheduling tasks in the future.
ScheduledExecutorServiceAdapter - org.apache.flink.util.concurrent中的类
Adapter class for a ScheduledExecutorService which shall be used as a ScheduledExecutor.
ScheduledExecutorServiceAdapter(ScheduledExecutorService) - 类 的构造器org.apache.flink.util.concurrent.ScheduledExecutorServiceAdapter
 
SCHEDULER - 类 中的静态变量org.apache.flink.configuration.JobManagerOptions
Config parameter determining the scheduler implementation.
SCHEDULER_MODE - 类 中的静态变量org.apache.flink.configuration.JobManagerOptions
 
SchedulerExecutionMode - org.apache.flink.configuration中的枚举
Enum for controlling whether REACTIVE mode is enabled or not.
scheduleWithDelay(Runnable, Time, ScheduledExecutor) - 类 中的静态方法org.apache.flink.util.concurrent.FutureUtils
Schedule the operation with the given delay.
scheduleWithDelay(Supplier<T>, Time, ScheduledExecutor) - 类 中的静态方法org.apache.flink.util.concurrent.FutureUtils
Schedule the operation with the given delay.
scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - 接口 中的方法org.apache.flink.util.concurrent.ScheduledExecutor
Executed the given command repeatedly with the given delay between the end of an execution and the start of the next execution.
scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - 类 中的方法org.apache.flink.util.concurrent.ScheduledExecutorServiceAdapter
 
schemaEquals(Object) - 类 中的方法org.apache.flink.api.java.typeutils.RowTypeInfo
Tests whether an other object describes the same, schema-equivalent row information.
scope - 枚举 中的变量org.apache.flink.core.memory.ManagedMemoryUseCase
 
SCOPE_DELIMITER - 类 中的静态变量org.apache.flink.configuration.MetricOptions
The delimiter used to assemble the metric identifier.
SCOPE_NAMING_JM - 类 中的静态变量org.apache.flink.configuration.MetricOptions
The scope format string that is applied to all metrics scoped to a JobManager.
SCOPE_NAMING_JM_JOB - 类 中的静态变量org.apache.flink.configuration.MetricOptions
The scope format string that is applied to all metrics scoped to a job on a JobManager.
SCOPE_NAMING_OPERATOR - 类 中的静态变量org.apache.flink.configuration.MetricOptions
The scope format string that is applied to all metrics scoped to an operator.
SCOPE_NAMING_TASK - 类 中的静态变量org.apache.flink.configuration.MetricOptions
The scope format string that is applied to all metrics scoped to a task.
SCOPE_NAMING_TM - 类 中的静态变量org.apache.flink.configuration.MetricOptions
The scope format string that is applied to all metrics scoped to a TaskManager.
SCOPE_NAMING_TM_JOB - 类 中的静态变量org.apache.flink.configuration.MetricOptions
The scope format string that is applied to all metrics scoped to a job on a TaskManager.
seconds(long) - 类 中的静态方法org.apache.flink.api.common.time.Time
Creates a new Time that represents the given number of seconds.
SECURITY_CONTEXT_FACTORY_CLASSES - 类 中的静态变量org.apache.flink.configuration.SecurityOptions
 
SECURITY_MODULE_FACTORY_CLASSES - 类 中的静态变量org.apache.flink.configuration.SecurityOptions
 
SECURITY_SSL_ALGORITHMS - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
SECURITY_SSL_ENABLED - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
SECURITY_SSL_KEY_PASSWORD - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
SECURITY_SSL_KEYSTORE - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
SECURITY_SSL_KEYSTORE_PASSWORD - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
SECURITY_SSL_PROTOCOL - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
SECURITY_SSL_TRUSTSTORE - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
SECURITY_SSL_TRUSTSTORE_PASSWORD - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
SECURITY_SSL_VERIFY_HOSTNAME - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
SecurityOptions - org.apache.flink.configuration中的类
The set of configuration options relating to security.
SecurityOptions() - 类 的构造器org.apache.flink.configuration.SecurityOptions
 
seek(long) - 类 中的方法org.apache.flink.api.common.io.InputStreamFSInputWrapper
 
seek(long) - 类 中的方法org.apache.flink.core.fs.FSDataInputStream
Seek to the given offset from the start of the file.
seek(long) - 类 中的方法org.apache.flink.core.fs.FSDataInputStreamWrapper
 
seek(long) - 类 中的方法org.apache.flink.core.fs.local.LocalDataInputStream
 
SeekableDataInputView - org.apache.flink.core.memory中的接口
Interface marking a DataInputView as seekable.
SeekableDataOutputView - org.apache.flink.core.memory中的接口
Interface marking a DataOutputView as seekable.
SELECT_ALL_CHAR - 类 中的静态变量org.apache.flink.api.common.operators.Keys.ExpressionKeys
 
SELECT_ALL_CHAR_SCALA - 类 中的静态变量org.apache.flink.api.common.operators.Keys.ExpressionKeys
 
SelectorFunctionKeys(KeySelector<T, K>, TypeInformation<T>, TypeInformation<K>) - 类 的构造器org.apache.flink.api.common.operators.Keys.SelectorFunctionKeys
 
SemanticProperties - org.apache.flink.api.common.operators中的接口
Container for the semantic properties associated to an operator.
SemanticProperties.EmptySemanticProperties - org.apache.flink.api.common.operators中的类
 
SemanticProperties.InvalidSemanticAnnotationException - org.apache.flink.api.common.operators中的异常错误
 
SEND_RECEIVE_BUFFER_SIZE - 类 中的静态变量org.apache.flink.configuration.NettyShuffleEnvironmentOptions
 
sendEventToSourceReader(int, SourceEvent) - 接口 中的方法org.apache.flink.api.connector.source.SplitEnumeratorContext
Send a source event to a source reader.
sendSourceEventToCoordinator(SourceEvent) - 接口 中的方法org.apache.flink.api.connector.source.SourceReaderContext
Send a source event to the source coordinator.
sendSplitRequest() - 接口 中的方法org.apache.flink.api.connector.source.SourceReaderContext
Sends a split request to the source's SplitEnumerator.
SeparateThreadExecutor - org.apache.flink.util.concurrent中的类
An Executor that runs every runnable in a separate thread.
SeparateThreadExecutor(ThreadFactory) - 类 的构造器org.apache.flink.util.concurrent.SeparateThreadExecutor
 
SEPARATOR - 类 中的静态变量org.apache.flink.core.fs.Path
The directory separator, a slash.
SEPARATOR_CHAR - 类 中的静态变量org.apache.flink.core.fs.Path
The directory separator, a slash (character).
SerializableFunction<T,R> - org.apache.flink.util.function中的接口
A Function that is also Serializable.
SerializableObject - org.apache.flink.util中的类
A simple object that only implements Serializable, so it can be used in serializable classes.
SerializableObject() - 类 的构造器org.apache.flink.util.SerializableObject
 
SerializableOptional<T extends Serializable> - org.apache.flink.types中的类
Serializable Optional.
SerializableSerializer(T) - 类 的构造器org.apache.flink.api.common.ExecutionConfig.SerializableSerializer
 
SerializableSupplier<T> - org.apache.flink.util.function中的接口
A serializable Supplier.
SerializableTimestampAssigner<T> - org.apache.flink.api.common.eventtime中的接口
serializationAdapter(RuntimeContext) - 类 中的静态方法org.apache.flink.api.common.serialization.RuntimeContextInitializationContextAdapters
 
serializationAdapter(RuntimeContext, Function<MetricGroup, MetricGroup>) - 类 中的静态方法org.apache.flink.api.common.serialization.RuntimeContextInitializationContextAdapters
 
SerializationSchema<T> - org.apache.flink.api.common.serialization中的接口
The serialization schema describes how to turn a data object into a different serialized representation.
SerializationSchema.InitializationContext - org.apache.flink.api.common.serialization中的接口
A contextual information provided for SerializationSchema.open(InitializationContext) method.
serialize(T, DataOutputView) - 类 中的方法org.apache.flink.api.common.io.BinaryOutputFormat
 
serialize(T, DataOutputView) - 类 中的方法org.apache.flink.api.common.io.SerializedOutputFormat
 
serialize(T) - 接口 中的方法org.apache.flink.api.common.serialization.SerializationSchema
Serializes the incoming element to a specified type.
serialize(String) - 类 中的方法org.apache.flink.api.common.serialization.SimpleStringSchema
 
serialize(T) - 类 中的方法org.apache.flink.api.common.serialization.TypeInformationSerializationSchema
 
serialize(boolean[], DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.array.BooleanPrimitiveArraySerializer
 
serialize(byte[], DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.array.BytePrimitiveArraySerializer
 
serialize(char[], DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.array.CharPrimitiveArraySerializer
 
serialize(double[], DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.array.DoublePrimitiveArraySerializer
 
serialize(float[], DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.array.FloatPrimitiveArraySerializer
 
serialize(int[], DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.array.IntPrimitiveArraySerializer
 
serialize(long[], DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.array.LongPrimitiveArraySerializer
 
serialize(short[], DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.array.ShortPrimitiveArraySerializer
 
serialize(String[], DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.array.StringArraySerializer
 
serialize(BigDecimal, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.BigDecSerializer
 
serialize(BigInteger, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.BigIntSerializer
 
serialize(Boolean, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.BooleanSerializer
 
serialize(BooleanValue, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.BooleanValueSerializer
 
serialize(Byte, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.ByteSerializer
 
serialize(ByteValue, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.ByteValueSerializer
 
serialize(Character, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.CharSerializer
 
serialize(CharValue, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.CharValueSerializer
 
serialize(Date, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.DateSerializer
 
serialize(Double, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.DoubleSerializer
 
serialize(DoubleValue, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.DoubleValueSerializer
 
serialize(T, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.EnumSerializer
 
serialize(Float, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.FloatSerializer
 
serialize(FloatValue, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.FloatValueSerializer
 
serialize(C[], DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.GenericArraySerializer
 
serialize(Instant, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.InstantSerializer
 
serialize(Integer, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.IntSerializer
 
serialize(IntValue, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.IntValueSerializer
 
serialize(List<T>, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.ListSerializer
 
serialize(LocalDate, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.LocalDateSerializer
 
serialize(LocalDateTime, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.LocalDateTimeSerializer
 
serialize(LocalTime, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.LocalTimeSerializer
 
serialize(Long, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.LongSerializer
 
serialize(LongValue, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.LongValueSerializer
 
serialize(Map<K, V>, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.MapSerializer
 
serialize(NullValue, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.NullValueSerializer
 
serialize(Short, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.ShortSerializer
 
serialize(ShortValue, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.ShortValueSerializer
 
serialize(Date, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.SqlDateSerializer
 
serialize(Time, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.SqlTimeSerializer
 
serialize(Timestamp, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.SqlTimestampSerializer
 
serialize(String, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.StringSerializer
 
serialize(StringValue, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.StringValueSerializer
 
serialize(Void, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.VoidSerializer
 
serialize(T, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.CompositeSerializer
 
serialize(T, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.SingleThreadAccessCheckingTypeSerializer
 
serialize(T, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.TypeSerializer
Serializes the given record to the given target output view.
serialize(T, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.UnloadableDummyTypeSerializer
 
serialize(T, DataOutputView) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer
 
serialize(Either<L, R>, DataOutputView) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.EitherSerializer
 
serialize(T, DataOutputView) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer
 
serialize(T, DataOutputView) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.NullableSerializer
 
serialize(T, DataOutputView) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.PojoSerializer
 
serialize(Row, DataOutputView) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.RowSerializer
 
serialize(Tuple0, DataOutputView) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.Tuple0Serializer
 
serialize(T, DataOutputView) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.TupleSerializer
 
serialize(T, DataOutputView) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.ValueSerializer
 
serialize(E) - 接口 中的方法org.apache.flink.core.io.SimpleVersionedSerializer
Serializes the given object.
serialize(T, DataOutputView) - 类 中的方法org.apache.flink.core.io.SimpleVersionedSerializerTypeSerializerProxy
 
serialize(DataOutputView) - 类 中的方法org.apache.flink.types.Record
Writes this record to the given output view.
SerializedInputFormat<T extends IOReadableWritable> - org.apache.flink.api.common.io中的类
Reads elements by deserializing them with their regular serialization/deserialization functionality.
SerializedInputFormat() - 类 的构造器org.apache.flink.api.common.io.SerializedInputFormat
 
SerializedListAccumulator<T> - 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() - 类 的构造器org.apache.flink.api.common.accumulators.SerializedListAccumulator
 
SerializedOutputFormat<T extends IOReadableWritable> - org.apache.flink.api.common.io中的类
Stores elements by serializing them with their regular serialization/deserialization functionality.
SerializedOutputFormat() - 类 的构造器org.apache.flink.api.common.io.SerializedOutputFormat
 
SerializedThrowable - org.apache.flink.util中的异常错误
Utility class for dealing with user-defined Throwable types that are serialized (for example during RPC/Actor communication), but cannot be resolved with the default class loader.
SerializedThrowable(Throwable) - 异常错误 的构造器org.apache.flink.util.SerializedThrowable
Create a new SerializedThrowable.
SerializedValue<T> - org.apache.flink.util中的类
This class is used to transfer (via serialization) objects whose classes are not available in the system class loader.
SerializedValue(byte[]) - 类 的构造器org.apache.flink.util.SerializedValue
 
SerializedValue(T) - 类 的构造器org.apache.flink.util.SerializedValue
Constructs a serialized value.
serializeField(Field, ObjectOutputStream) - 类 中的静态方法org.apache.flink.api.java.typeutils.runtime.FieldSerializer
 
serializeObject(Object) - 类 中的静态方法org.apache.flink.util.InstantiationUtil
 
serializeObject(OutputStream, Object) - 类 中的静态方法org.apache.flink.util.InstantiationUtil
 
serializeObjectAndCompress(Object) - 类 中的静态方法org.apache.flink.util.InstantiationUtil
 
serializerClass() - 类 中的方法org.apache.flink.api.common.typeutils.GenericTypeSerializerSnapshot
Gets the serializer's class.
serializerClass() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer.CopyableValueSerializerSnapshot
 
serializerClass() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.ValueSerializer.ValueSerializerSnapshot
 
Serializers - org.apache.flink.api.java.typeutils.runtime.kryo中的类
Class containing utilities for the serializers of the Flink Runtime.
Serializers() - 类 的构造器org.apache.flink.api.java.typeutils.runtime.kryo.Serializers
 
serializers - 类 中的变量org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
serializers to deserialize the first n fields for comparison
Serializers.DummyAvroKryoSerializerClass<T> - org.apache.flink.api.java.typeutils.runtime.kryo中的类
This is used in case we don't have Avro on the classpath.
Serializers.DummyAvroRegisteredClass - org.apache.flink.api.java.typeutils.runtime.kryo中的类
This is used in case we don't have Avro on the classpath.
Serializers.SpecificInstanceCollectionSerializer<T extends Collection> - org.apache.flink.api.java.typeutils.runtime.kryo中的类
Special serializer for Java collections enforcing certain instance types.
Serializers.SpecificInstanceCollectionSerializerForArrayList - org.apache.flink.api.java.typeutils.runtime.kryo中的类
Special serializer for Java's ArrayList used for Avro's GenericData.Array.
serializeToByteArray(TypeSerializer<T>, T) - 类 中的静态方法org.apache.flink.util.InstantiationUtil
 
serialVersionUID - 类 中的静态变量org.apache.flink.api.java.typeutils.runtime.ValueSerializer.ValueSerializerConfigSnapshot
已过时。
 
SERVER_ASYNC_QUERY_THREADS - 类 中的静态变量org.apache.flink.configuration.QueryableStateOptions
Number of async query threads for the KvStateServerHandler (0 => #slots).
SERVER_MAX_CONTENT_LENGTH - 类 中的静态变量org.apache.flink.configuration.RestOptions
The maximum content length that the server will handle.
SERVER_NETWORK_THREADS - 类 中的静态变量org.apache.flink.configuration.QueryableStateOptions
Number of network (event loop) threads for the KvState server (0 => #slots).
SERVER_NUM_THREADS - 类 中的静态变量org.apache.flink.configuration.RestOptions
 
SERVER_PORT_RANGE - 类 中的静态变量org.apache.flink.configuration.QueryableStateOptions
The config parameter defining the server port range of the queryable state server.
SERVER_SOCKET_WORKER_POOL_SIZE_FACTOR - 类 中的静态变量org.apache.flink.configuration.AkkaOptions
 
SERVER_SOCKET_WORKER_POOL_SIZE_MAX - 类 中的静态变量org.apache.flink.configuration.AkkaOptions
 
SERVER_SOCKET_WORKER_POOL_SIZE_MIN - 类 中的静态变量org.apache.flink.configuration.AkkaOptions
 
SERVER_THREAD_PRIORITY - 类 中的静态变量org.apache.flink.configuration.RestOptions
 
set(ConfigOption<T>, T) - 类 中的方法org.apache.flink.configuration.Configuration
 
set(ConfigOption<T>, T) - 类 中的方法org.apache.flink.configuration.DelegatingConfiguration
 
set(ConfigOption<T>, T) - 接口 中的方法org.apache.flink.configuration.WritableConfig
Stores a given value using the metadata included in the ConfigOption.
set(boolean) - 类 中的方法org.apache.flink.types.BooleanValue
 
set(int, V) - 类 中的方法org.apache.flink.types.ListValue
 
setAccumulatedRecordCount(long) - 类 中的方法org.apache.flink.api.common.io.BlockInfo
Sets the accumulatedRecordCount to the specified value.
setAutoWatermarkInterval(long) - 类 中的方法org.apache.flink.api.common.ExecutionConfig
Sets the interval of the automatic watermark emission.
setAvgOutputRecordSize(float) - 类 中的方法org.apache.flink.api.common.operators.CompilerHints
 
setBlockSize(long) - 类 中的方法org.apache.flink.api.common.io.BinaryInputFormat
 
setBoolean(String, boolean) - 类 中的方法org.apache.flink.configuration.Configuration
Adds the given key/value pair to the configuration object.
setBoolean(ConfigOption<Boolean>, boolean) - 类 中的方法org.apache.flink.configuration.Configuration
Adds the given value to the configuration object.
setBoolean(String, boolean) - 类 中的方法org.apache.flink.configuration.DelegatingConfiguration
 
setBoolean(ConfigOption<Boolean>, boolean) - 类 中的方法org.apache.flink.configuration.DelegatingConfiguration
 
setBroadcastVariable(String, List<?>) - 类 中的方法org.apache.flink.api.common.functions.util.RuntimeUDFContext
 
setBroadcastVariable(String, Operator<?>) - 类 中的方法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<?>) - 类 中的方法org.apache.flink.api.common.operators.base.BulkIterationBase
The BulkIteration meta operator cannot have broadcast inputs.
setBroadcastVariable(String, Operator<?>) - 类 中的方法org.apache.flink.api.common.operators.base.DeltaIterationBase
The DeltaIteration meta operator cannot have broadcast inputs.
setBroadcastVariables(Map<String, Operator<T>>) - 类 中的方法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>>) - 类 中的方法org.apache.flink.api.common.operators.base.BulkIterationBase
The BulkIteration meta operator cannot have broadcast inputs.
setBroadcastVariables(Map<String, Operator<X>>) - 类 中的方法org.apache.flink.api.common.operators.base.DeltaIterationBase
The DeltaIteration meta operator cannot have broadcast inputs.
setBuffer(byte[], int, int) - 类 中的方法org.apache.flink.core.memory.ByteArrayInputStreamWithPos
 
setBuffer(ByteBuffer) - 类 中的方法org.apache.flink.core.memory.DataInputDeserializer
 
setBuffer(byte[], int, int) - 类 中的方法org.apache.flink.core.memory.DataInputDeserializer
 
setBuffer(byte[]) - 类 中的方法org.apache.flink.core.memory.DataInputDeserializer
 
setBufferSize(int) - 类 中的方法org.apache.flink.api.common.io.DelimitedInputFormat
 
setBufferTimeout(long) - 类 中的方法org.apache.flink.api.dag.Transformation
Set the buffer timeout of this Transformation.
setBytes(String, byte[]) - 类 中的方法org.apache.flink.configuration.Configuration
Adds the given byte array to the configuration object.
setBytes(String, byte[]) - 类 中的方法org.apache.flink.configuration.DelegatingConfiguration
 
setCharset(String) - 类 中的方法org.apache.flink.api.common.io.DelimitedInputFormat
Set the name of the character set used for the row delimiter.
setCharset(String) - 类 中的方法org.apache.flink.api.common.io.GenericCsvInputFormat
 
setCharset(Charset) - 类 中的方法org.apache.flink.types.parser.FieldParser
Sets the character set used for this parser.
setClass(String, Class<?>) - 类 中的方法org.apache.flink.configuration.Configuration
Adds the given key/value pair to the configuration object.
setClass(String, Class<?>) - 类 中的方法org.apache.flink.configuration.DelegatingConfiguration
 
setClosureCleanerLevel(ExecutionConfig.ClosureCleanerLevel) - 类 中的方法org.apache.flink.api.common.ExecutionConfig
Configures the closure cleaner.
setCoLocationGroupKey(String) - 类 中的方法org.apache.flink.api.dag.Transformation
NOTE: This is an internal undocumented feature for now.
setCombinable(boolean) - 类 中的方法org.apache.flink.api.common.operators.base.GroupReduceOperatorBase
Marks the group reduce operation as combinable.
setCombinableFirst(boolean) - 类 中的方法org.apache.flink.api.common.operators.base.CoGroupOperatorBase
 
setCombinableFirst(boolean) - 类 中的方法org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase
 
setCombinableSecond(boolean) - 类 中的方法org.apache.flink.api.common.operators.base.CoGroupOperatorBase
 
setCombinableSecond(boolean) - 类 中的方法org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase
 
setCombineHint(ReduceOperatorBase.CombineHint) - 类 中的方法org.apache.flink.api.common.operators.base.ReduceOperatorBase
 
setCommentPrefix(String) - 类 中的方法org.apache.flink.api.common.io.GenericCsvInputFormat
 
setCpuCores(double) - 类 中的方法org.apache.flink.api.common.operators.ResourceSpec.Builder
 
setCpuCores(double) - 类 中的方法org.apache.flink.api.common.operators.SlotSharingGroup.Builder
Set the CPU cores for this SlotSharingGroup.
setCrossHint(CrossOperatorBase.CrossHint) - 类 中的方法org.apache.flink.api.common.operators.base.CrossOperatorBase
 
setCustomPartitioner(Partitioner<?>) - 类 中的方法org.apache.flink.api.common.operators.base.CoGroupOperatorBase
 
setCustomPartitioner(Partitioner<?>) - 类 中的方法org.apache.flink.api.common.operators.base.GroupReduceOperatorBase
 
setCustomPartitioner(Partitioner<?>) - 类 中的方法org.apache.flink.api.common.operators.base.JoinOperatorBase
 
setCustomPartitioner(Partitioner<?>) - 类 中的方法org.apache.flink.api.common.operators.base.PartitionOperatorBase
 
setCustomPartitioner(Partitioner<?>) - 类 中的方法org.apache.flink.api.common.operators.base.ReduceOperatorBase
 
setDefaultInputDependencyConstraint(InputDependencyConstraint) - 类 中的方法org.apache.flink.api.common.ExecutionConfig
已过时。
due to the deprecation of InputDependencyConstraint.
setDefaultParallelism(int) - 类 中的方法org.apache.flink.api.common.Plan
Sets the default parallelism for this plan.
setDelimiter(byte[]) - 类 中的方法org.apache.flink.api.common.io.DelimitedInputFormat
 
setDelimiter(char) - 类 中的方法org.apache.flink.api.common.io.DelimitedInputFormat
 
setDelimiter(String) - 类 中的方法org.apache.flink.api.common.io.DelimitedInputFormat
 
setDistribution(DataDistribution) - 类 中的方法org.apache.flink.api.common.operators.base.PartitionOperatorBase
 
setDouble(String, double) - 类 中的方法org.apache.flink.configuration.Configuration
Adds the given key/value pair to the configuration object.
setDouble(ConfigOption<Double>, double) - 类 中的方法org.apache.flink.configuration.Configuration
Adds the given value to the configuration object.
setDouble(String, double) - 类 中的方法org.apache.flink.configuration.DelegatingConfiguration
 
setDouble(ConfigOption<Double>, double) - 类 中的方法org.apache.flink.configuration.DelegatingConfiguration
 
setErrorState(FieldParser.ParseErrorState) - 类 中的方法org.apache.flink.types.parser.FieldParser
Sets the error state of the parser.
setExceptionHandler(Thread.UncaughtExceptionHandler) - 类 中的方法org.apache.flink.util.concurrent.ExecutorThreadFactory.Builder
 
setExecutionConfig(ExecutionConfig) - 类 中的方法org.apache.flink.api.common.Plan
Sets the runtime config object defining execution parameters.
setExecutionMode(ExecutionMode) - 类 中的方法org.apache.flink.api.common.ExecutionConfig
Sets the execution mode to execute the program.
setExecutionRetryDelay(long) - 类 中的方法org.apache.flink.api.common.ExecutionConfig
已过时。
This method will be replaced by ExecutionConfig.setRestartStrategy(org.apache.flink.api.common.restartstrategy.RestartStrategies.RestartStrategyConfiguration). The RestartStrategies.FixedDelayRestartStrategyConfiguration contains the delay between successive execution attempts.
setExtendedResource(ExternalResource) - 类 中的方法org.apache.flink.api.common.operators.ResourceSpec.Builder
Add the given extended resource.
setExtendedResources(Collection<ExternalResource>) - 类 中的方法org.apache.flink.api.common.operators.ResourceSpec.Builder
Add the given extended resources.
setExternalResource(String, double) - 类 中的方法org.apache.flink.api.common.operators.SlotSharingGroup.Builder
Add the given external resource.
setField(T, int, Object) - 类 中的方法org.apache.flink.api.common.typeutils.CompositeSerializer
Modify field of existing instance.
setField(T, int) - 类 中的方法org.apache.flink.api.java.tuple.Tuple
Sets the field at the specified position.
setField(T, int) - 类 中的方法org.apache.flink.api.java.tuple.Tuple0
 
setField(T, int) - 类 中的方法org.apache.flink.api.java.tuple.Tuple1
 
setField(T, int) - 类 中的方法org.apache.flink.api.java.tuple.Tuple10
 
setField(T, int) - 类 中的方法org.apache.flink.api.java.tuple.Tuple11
 
setField(T, int) - 类 中的方法org.apache.flink.api.java.tuple.Tuple12
 
setField(T, int) - 类 中的方法org.apache.flink.api.java.tuple.Tuple13
 
setField(T, int) - 类 中的方法org.apache.flink.api.java.tuple.Tuple14
 
setField(T, int) - 类 中的方法org.apache.flink.api.java.tuple.Tuple15
 
setField(T, int) - 类 中的方法org.apache.flink.api.java.tuple.Tuple16
 
setField(T, int) - 类 中的方法org.apache.flink.api.java.tuple.Tuple17
 
setField(T, int) - 类 中的方法org.apache.flink.api.java.tuple.Tuple18
 
setField(T, int) - 类 中的方法org.apache.flink.api.java.tuple.Tuple19
 
setField(T, int) - 类 中的方法org.apache.flink.api.java.tuple.Tuple2
 
setField(T, int) - 类 中的方法org.apache.flink.api.java.tuple.Tuple20
 
setField(T, int) - 类 中的方法org.apache.flink.api.java.tuple.Tuple21
 
setField(T, int) - 类 中的方法org.apache.flink.api.java.tuple.Tuple22
 
setField(T, int) - 类 中的方法org.apache.flink.api.java.tuple.Tuple23
 
setField(T, int) - 类 中的方法org.apache.flink.api.java.tuple.Tuple24
 
setField(T, int) - 类 中的方法org.apache.flink.api.java.tuple.Tuple25
 
setField(T, int) - 类 中的方法org.apache.flink.api.java.tuple.Tuple3
 
setField(T, int) - 类 中的方法org.apache.flink.api.java.tuple.Tuple4
 
setField(T, int) - 类 中的方法org.apache.flink.api.java.tuple.Tuple5
 
setField(T, int) - 类 中的方法org.apache.flink.api.java.tuple.Tuple6
 
setField(T, int) - 类 中的方法org.apache.flink.api.java.tuple.Tuple7
 
setField(T, int) - 类 中的方法org.apache.flink.api.java.tuple.Tuple8
 
setField(T, int) - 类 中的方法org.apache.flink.api.java.tuple.Tuple9
 
setField(int, Value) - 类 中的方法org.apache.flink.types.Record
Sets the field at the given position to the given value.
setField(int, Object) - 类 中的方法org.apache.flink.types.Row
Sets the field's content at the specified position.
setField(String, Object) - 类 中的方法org.apache.flink.types.Row
Sets the field's content using the specified field name.
setFieldDelimiter(String) - 类 中的方法org.apache.flink.api.common.io.GenericCsvInputFormat
 
setFields(T0) - 类 中的方法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) - 类 中的方法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) - 类 中的方法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) - 类 中的方法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) - 类 中的方法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) - 类 中的方法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) - 类 中的方法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) - 类 中的方法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) - 类 中的方法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) - 类 中的方法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) - 类 中的方法org.apache.flink.api.java.tuple.Tuple19
Sets new values to all fields of the tuple.
setFields(T0, T1) - 类 中的方法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) - 类 中的方法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) - 类 中的方法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) - 类 中的方法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) - 类 中的方法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) - 类 中的方法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) - 类 中的方法org.apache.flink.api.java.tuple.Tuple25
Sets new values to all fields of the tuple.
setFields(T0, T1, T2) - 类 中的方法org.apache.flink.api.java.tuple.Tuple3
Sets new values to all fields of the tuple.
setFields(T0, T1, T2, T3) - 类 中的方法org.apache.flink.api.java.tuple.Tuple4
Sets new values to all fields of the tuple.
setFields(T0, T1, T2, T3, T4) - 类 中的方法org.apache.flink.api.java.tuple.Tuple5
Sets new values to all fields of the tuple.
setFields(T0, T1, T2, T3, T4, T5) - 类 中的方法org.apache.flink.api.java.tuple.Tuple6
Sets new values to all fields of the tuple.
setFields(T0, T1, T2, T3, T4, T5, T6) - 类 中的方法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) - 类 中的方法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) - 类 中的方法org.apache.flink.api.java.tuple.Tuple9
Sets new values to all fields of the tuple.
setFieldsGeneric(int[], Class<?>[]) - 类 中的方法org.apache.flink.api.common.io.GenericCsvInputFormat
 
setFieldsGeneric(boolean[], Class<?>[]) - 类 中的方法org.apache.flink.api.common.io.GenericCsvInputFormat
 
setFieldTypesGeneric(Class<?>...) - 类 中的方法org.apache.flink.api.common.io.GenericCsvInputFormat
 
setFilePath(String) - 类 中的方法org.apache.flink.api.common.io.FileInputFormat
 
setFilePath(Path) - 类 中的方法org.apache.flink.api.common.io.FileInputFormat
Sets a single path of a file to be read.
setFilePaths(String...) - 类 中的方法org.apache.flink.api.common.io.FileInputFormat
Sets multiple paths of files to be read.
setFilePaths(Path...) - 类 中的方法org.apache.flink.api.common.io.FileInputFormat
Sets multiple paths of files to be read.
setFilesFilter(FilePathFilter) - 类 中的方法org.apache.flink.api.common.io.FileInputFormat
 
setFilterFactor(float) - 类 中的方法org.apache.flink.api.common.operators.CompilerHints
 
setFirstInput(Operator<IN1>) - 类 中的方法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>...) - 类 中的方法org.apache.flink.api.common.operators.DualInputOperator
已过时。
This method will be removed in future versions. Use the Union operator instead.
setFirstInputs(List<Operator<IN1>>) - 类 中的方法org.apache.flink.api.common.operators.DualInputOperator
已过时。
This method will be removed in future versions. Use the Union operator instead.
setFirstRecordStart(long) - 类 中的方法org.apache.flink.api.common.io.BlockInfo
Sets the firstRecordStart to the specified value.
setFloat(String, float) - 类 中的方法org.apache.flink.configuration.Configuration
Adds the given key/value pair to the configuration object.
setFloat(ConfigOption<Float>, float) - 类 中的方法org.apache.flink.configuration.Configuration
Adds the given value to the configuration object.
setFloat(String, float) - 类 中的方法org.apache.flink.configuration.DelegatingConfiguration
 
setFloat(ConfigOption<Float>, float) - 类 中的方法org.apache.flink.configuration.DelegatingConfiguration
 
setFromConfiguration(Configuration) - 类 中的静态方法org.apache.flink.core.security.FlinkSecurityManager
 
setFunctionRuntimeContext(Function, RuntimeContext) - 类 中的静态方法org.apache.flink.api.common.functions.util.FunctionUtils
 
setGlobalJobParameters(ExecutionConfig.GlobalJobParameters) - 类 中的方法org.apache.flink.api.common.ExecutionConfig
Register a custom, serializable user configuration object.
setGroupOrder(int, Ordering) - 类 中的方法org.apache.flink.api.common.operators.base.CoGroupOperatorBase
Sets the order of the elements within a group for the given input.
setGroupOrder(int, Ordering) - 类 中的方法org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase
Sets the order of the elements within a group for the given input.
setGroupOrder(Ordering) - 类 中的方法org.apache.flink.api.common.operators.base.GroupCombineOperatorBase
Sets the order of the elements within a reduce group.
setGroupOrder(Ordering) - 类 中的方法org.apache.flink.api.common.operators.base.GroupReduceOperatorBase
Sets the order of the elements within a reduce group.
setGroupOrderForInputOne(Ordering) - 类 中的方法org.apache.flink.api.common.operators.base.CoGroupOperatorBase
Sets the order of the elements within a group for the first input.
setGroupOrderForInputOne(Ordering) - 类 中的方法org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase
Sets the order of the elements within a group for the first input.
setGroupOrderForInputTwo(Ordering) - 类 中的方法org.apache.flink.api.common.operators.base.CoGroupOperatorBase
Sets the order of the elements within a group for the second input.
setGroupOrderForInputTwo(Ordering) - 类 中的方法org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase
Sets the order of the elements within a group for the second input.
setInitialSolutionSet(Operator<ST>) - 类 中的方法org.apache.flink.api.common.operators.base.DeltaIterationBase
Sets the given input as the initial solution set.
setInitialWorkset(Operator<WT>) - 类 中的方法org.apache.flink.api.common.operators.base.DeltaIterationBase
Sets the given input as the initial workset.
setInput(Operator<IN>) - 类 中的方法org.apache.flink.api.common.operators.GenericDataSinkBase
Sets the given operator as the input to this operator.
setInput(Operator<IN>) - 类 中的方法org.apache.flink.api.common.operators.SingleInputOperator
Sets the given operator as the input to this operator.
setInput(Operator<IN>...) - 类 中的方法org.apache.flink.api.common.operators.SingleInputOperator
已过时。
This method will be removed in future versions. Use the Union operator instead.
setInputs(Operator<IN>...) - 类 中的方法org.apache.flink.api.common.operators.GenericDataSinkBase
已过时。
This method will be removed in future versions. Use the Union operator instead.
setInputs(List<Operator<IN>>) - 类 中的方法org.apache.flink.api.common.operators.GenericDataSinkBase
已过时。
This method will be removed in future versions. Use the Union operator instead.
setInputs(List<Operator<IN>>) - 类 中的方法org.apache.flink.api.common.operators.SingleInputOperator
已过时。
This method will be removed in future versions. Use the Union operator instead.
setInputType(TypeInformation<?>, ExecutionConfig) - 接口 中的方法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) - 类 中的方法org.apache.flink.configuration.Configuration
Adds the given key/value pair to the configuration object.
setInteger(ConfigOption<Integer>, int) - 类 中的方法org.apache.flink.configuration.Configuration
Adds the given value to the configuration object.
setInteger(String, int) - 类 中的方法org.apache.flink.configuration.DelegatingConfiguration
 
setInteger(ConfigOption<Integer>, int) - 类 中的方法org.apache.flink.configuration.DelegatingConfiguration
 
setJobId(JobID) - 类 中的方法org.apache.flink.api.common.Plan
Sets the ID of the job that the dataflow plan belongs to.
setJobName(String) - 类 中的方法org.apache.flink.api.common.Plan
Sets the jobName for this Plan.
setJoinHint(JoinOperatorBase.JoinHint) - 类 中的方法org.apache.flink.api.common.operators.base.JoinOperatorBase
 
setKind(RowKind) - 类 中的方法org.apache.flink.types.Row
Sets the kind of change that this row describes in a changelog.
setLatencyTrackingInterval(long) - 类 中的方法org.apache.flink.api.common.ExecutionConfig
Interval for sending latency tracking marks from the sources to the sinks.
setLength(int) - 类 中的方法org.apache.flink.types.StringValue
Sets a new length for the string.
setLenient(boolean) - 类 中的方法org.apache.flink.api.common.io.GenericCsvInputFormat
 
setLineLengthLimit(int) - 类 中的方法org.apache.flink.api.common.io.DelimitedInputFormat
 
setLocalOrder(Ordering) - 类 中的方法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) - 类 中的方法org.apache.flink.configuration.Configuration
Adds the given key/value pair to the configuration object.
setLong(ConfigOption<Long>, long) - 类 中的方法org.apache.flink.configuration.Configuration
Adds the given value to the configuration object.
setLong(String, long) - 类 中的方法org.apache.flink.configuration.DelegatingConfiguration
 
setLong(ConfigOption<Long>, long) - 类 中的方法org.apache.flink.configuration.DelegatingConfiguration
 
setManagedMemory(MemorySize) - 类 中的方法org.apache.flink.api.common.operators.ResourceSpec.Builder
 
setManagedMemory(MemorySize) - 类 中的方法org.apache.flink.api.common.operators.SlotSharingGroup.Builder
Set the task managed memory for this SlotSharingGroup.
setManagedMemoryMB(int) - 类 中的方法org.apache.flink.api.common.operators.ResourceSpec.Builder
 
setManagedMemoryMB(int) - 类 中的方法org.apache.flink.api.common.operators.SlotSharingGroup.Builder
Set the task managed memory for this SlotSharingGroup in MB.
setMaximumNumberOfIterations(int) - 类 中的方法org.apache.flink.api.common.operators.base.BulkIterationBase
 
setMaximumNumberOfIterations(int) - 类 中的方法org.apache.flink.api.common.operators.base.DeltaIterationBase
 
setMaxParallelism(int) - 类 中的方法org.apache.flink.api.common.ExecutionConfig
Sets the maximum degree of parallelism defined for the program.
setMaxParallelism(int) - 类 中的方法org.apache.flink.api.dag.Transformation
Sets the maximum parallelism for this stream transformation.
setMinSplitSize(long) - 类 中的方法org.apache.flink.api.common.io.FileInputFormat
 
setName(String) - 类 中的方法org.apache.flink.api.common.operators.Operator
Sets the name of the contract instance.
setName(String) - 类 中的方法org.apache.flink.api.dag.Transformation
Changes the name of this Transformation.
setNestedFileEnumeration(boolean) - 类 中的方法org.apache.flink.api.common.io.FileInputFormat
 
setNestedSerializersSnapshots(CompositeTypeSerializerSnapshot<?, ?>, TypeSerializerSnapshot<?>...) - 类 中的静态方法org.apache.flink.api.common.typeutils.CompositeTypeSerializerUtil
Overrides the existing nested serializer's snapshots with the provided nestedSnapshots.
setNextPartialSolution(Operator<T>) - 类 中的方法org.apache.flink.api.common.operators.base.BulkIterationBase
 
setNextWorkset(Operator<WT>) - 类 中的方法org.apache.flink.api.common.operators.base.DeltaIterationBase
Sets the contract of the step function that represents the next workset.
setNull(int) - 类 中的方法org.apache.flink.types.Record
Sets the field at the given position to null.
setNull(long) - 类 中的方法org.apache.flink.types.Record
Sets the fields to null using the given bit mask.
setNull(long[]) - 类 中的方法org.apache.flink.types.Record
Sets the fields to null using the given bit mask.
setNumberOfExecutionRetries(int) - 类 中的方法org.apache.flink.api.common.ExecutionConfig
已过时。
This method will be replaced by ExecutionConfig.setRestartStrategy(org.apache.flink.api.common.restartstrategy.RestartStrategies.RestartStrategyConfiguration). The RestartStrategies.FixedDelayRestartStrategyConfiguration contains the number of execution retries.
setNumFields(int) - 类 中的方法org.apache.flink.types.Record
Sets the number of fields in the record.
setNumLineSamples(int) - 类 中的方法org.apache.flink.api.common.io.DelimitedInputFormat
 
setNumSplits(int) - 类 中的方法org.apache.flink.api.common.io.FileInputFormat
 
setOpenTimeout(long) - 类 中的方法org.apache.flink.api.common.io.FileInputFormat
 
setOrdering(Ordering) - 类 中的方法org.apache.flink.api.common.operators.base.PartitionOperatorBase
 
setOuterJoinType(OuterJoinOperatorBase.OuterJoinType) - 类 中的方法org.apache.flink.api.common.operators.base.OuterJoinOperatorBase
 
setOutputCardinality(long) - 类 中的方法org.apache.flink.api.common.operators.CompilerHints
 
setOutputDirectoryMode(FileOutputFormat.OutputDirectoryMode) - 类 中的方法org.apache.flink.api.common.io.FileOutputFormat
 
setOutputFilePath(Path) - 类 中的方法org.apache.flink.api.common.io.FileOutputFormat
 
setOutputSize(long) - 类 中的方法org.apache.flink.api.common.operators.CompilerHints
 
setOutputType(TypeInformation<T>) - 类 中的方法org.apache.flink.api.dag.Transformation
Tries to fill in the type information.
setParallelism(int) - 类 中的方法org.apache.flink.api.common.ExecutionConfig
Sets the parallelism for operations executed through this environment.
setParallelism(int) - 类 中的方法org.apache.flink.api.common.operators.Operator
Sets the parallelism for this contract instance.
setParallelism(int) - 类 中的方法org.apache.flink.api.dag.Transformation
Sets the parallelism of this Transformation.
setParameter(String, String) - 类 中的方法org.apache.flink.api.common.operators.Operator
Sets a stub parameters in the configuration of this contract.
setParameter(String, int) - 类 中的方法org.apache.flink.api.common.operators.Operator
Sets a stub parameters in the configuration of this contract.
setParameter(String, boolean) - 类 中的方法org.apache.flink.api.common.operators.Operator
Sets a stub parameters in the configuration of this contract.
setPoolName(String) - 类 中的方法org.apache.flink.util.concurrent.ExecutorThreadFactory.Builder
 
setPosition(int) - 类 中的方法org.apache.flink.core.memory.ByteArrayOutputStreamWithPos
 
setPosition(int) - 类 中的方法org.apache.flink.core.memory.DataOutputSerializer
 
setPosition(int) - 类 中的方法org.apache.flink.core.memory.MemorySegmentInputStreamWithPos
 
setPositionUnsafe(int) - 类 中的方法org.apache.flink.core.memory.DataOutputSerializer
 
setPriorSerializer(TypeSerializer<T>) - 类 中的方法org.apache.flink.api.common.typeutils.TypeSerializerConfigSnapshot
已过时。
Set the originating serializer of this configuration snapshot.
setQueryable(String) - 类 中的方法org.apache.flink.api.common.state.StateDescriptor
Sets the name for queries of state created from this descriptor.
setRate(long) - 接口 中的方法org.apache.flink.api.common.io.ratelimiting.FlinkConnectorRateLimiter
Sets the desired rate for the rate limiter.
setRate(long) - 类 中的方法org.apache.flink.api.common.io.ratelimiting.GuavaFlinkConnectorRateLimiter
Set the global per consumer and per sub-task rates.
setReadPosition(long) - 接口 中的方法org.apache.flink.core.memory.SeekableDataInputView
Sets the read pointer to the given position.
setRecordCount(long) - 类 中的方法org.apache.flink.api.common.io.BlockInfo
Sets the recordCount to the specified value.
setReference(T) - 类 中的方法org.apache.flink.api.common.typeutils.base.array.PrimitiveArrayComparator
 
setReference(T) - 类 中的方法org.apache.flink.api.common.typeutils.base.BasicTypeComparator
 
setReference(BooleanValue) - 类 中的方法org.apache.flink.api.common.typeutils.base.BooleanValueComparator
 
setReference(ByteValue) - 类 中的方法org.apache.flink.api.common.typeutils.base.ByteValueComparator
 
setReference(CharValue) - 类 中的方法org.apache.flink.api.common.typeutils.base.CharValueComparator
 
setReference(DoubleValue) - 类 中的方法org.apache.flink.api.common.typeutils.base.DoubleValueComparator
 
setReference(FloatValue) - 类 中的方法org.apache.flink.api.common.typeutils.base.FloatValueComparator
 
setReference(IntValue) - 类 中的方法org.apache.flink.api.common.typeutils.base.IntValueComparator
 
setReference(LocalDate) - 类 中的方法org.apache.flink.api.common.typeutils.base.LocalDateComparator
 
setReference(LocalDateTime) - 类 中的方法org.apache.flink.api.common.typeutils.base.LocalDateTimeComparator
 
setReference(LongValue) - 类 中的方法org.apache.flink.api.common.typeutils.base.LongValueComparator
 
setReference(NullValue) - 类 中的方法org.apache.flink.api.common.typeutils.base.NullValueComparator
 
setReference(ShortValue) - 类 中的方法org.apache.flink.api.common.typeutils.base.ShortValueComparator
 
setReference(StringValue) - 类 中的方法org.apache.flink.api.common.typeutils.base.StringValueComparator
 
setReference(T1) - 类 中的方法org.apache.flink.api.common.typeutils.GenericPairComparator
 
setReference(T) - 类 中的方法org.apache.flink.api.common.typeutils.SameTypePairComparator
 
setReference(T) - 类 中的方法org.apache.flink.api.common.typeutils.TypeComparator
Sets the given element as the comparison reference for future calls to TypeComparator.equalToReference(Object) and TypeComparator.compareToReference(TypeComparator).
setReference(T1) - 类 中的方法org.apache.flink.api.common.typeutils.TypePairComparator
Sets the reference for comparisons.
setReference(T) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.CopyableValueComparator
 
setReference(T) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.GenericTypeComparator
 
setReference(T) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.NullAwareComparator
 
setReference(T) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.PojoComparator
 
setReference(Row) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.RowComparator
 
setReference(T) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.TupleComparator
 
setReference(T) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.ValueComparator
 
setResources(ResourceSpec, ResourceSpec) - 类 中的方法org.apache.flink.api.common.operators.Operator
Sets the minimum and preferred resources for this contract instance.
setResources(ResourceSpec, ResourceSpec) - 类 中的方法org.apache.flink.api.dag.Transformation
Sets the minimum and preferred resources for this stream transformation.
setRestartStrategy(RestartStrategies.RestartStrategyConfiguration) - 类 中的方法org.apache.flink.api.common.ExecutionConfig
Sets the restart strategy to be used for recovery.
setRuntimeContext(RuntimeContext) - 类 中的方法org.apache.flink.api.common.functions.AbstractRichFunction
 
setRuntimeContext(RuntimeContext) - 接口 中的方法org.apache.flink.api.common.functions.RichFunction
Sets the function's runtime context.
setRuntimeContext(RuntimeContext) - 类 中的方法org.apache.flink.api.common.io.ReplicatingInputFormat
 
setRuntimeContext(RuntimeContext) - 类 中的方法org.apache.flink.api.common.io.RichInputFormat
 
setRuntimeContext(RuntimeContext) - 类 中的方法org.apache.flink.api.common.io.RichOutputFormat
 
setSecondInput(Operator<IN2>) - 类 中的方法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>...) - 类 中的方法org.apache.flink.api.common.operators.DualInputOperator
已过时。
This method will be removed in future versions. Use the Union operator instead.
setSecondInputs(List<Operator<IN2>>) - 类 中的方法org.apache.flink.api.common.operators.DualInputOperator
已过时。
This method will be removed in future versions. Use the Union operator instead.
setSegment(MemorySegment, int, int) - 类 中的方法org.apache.flink.core.memory.MemorySegmentInputStreamWithPos
 
setSemanticProperties(DualInputSemanticProperties) - 类 中的方法org.apache.flink.api.common.operators.DualInputOperator
 
setSemanticProperties(SingleInputSemanticProperties) - 类 中的方法org.apache.flink.api.common.operators.SingleInputOperator
 
setSkipFirstLineAsHeader(boolean) - 类 中的方法org.apache.flink.api.common.io.GenericCsvInputFormat
 
setSlotSharingGroup(String) - 类 中的方法org.apache.flink.api.dag.Transformation
Sets the slot sharing group of this transformation.
setSlotSharingGroup(SlotSharingGroup) - 类 中的方法org.apache.flink.api.dag.Transformation
Sets the slot sharing group of this transformation.
setSolutionSetDelta(Operator<ST>) - 类 中的方法org.apache.flink.api.common.operators.base.DeltaIterationBase
Sets the contract of the step function that represents the solution set delta.
setSolutionSetUnManaged(boolean) - 类 中的方法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>) - 类 中的方法org.apache.flink.api.common.operators.GenericDataSourceBase
Sets properties of input splits for this data source.
setStateVisibility(StateTtlConfig.StateVisibility) - 类 中的方法org.apache.flink.api.common.state.StateTtlConfig.Builder
Sets the state visibility.
setStatisticsKey(String) - 类 中的方法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) - 类 中的方法org.apache.flink.configuration.Configuration
Adds the given key/value pair to the configuration object.
setString(ConfigOption<String>, String) - 类 中的方法org.apache.flink.configuration.Configuration
Adds the given value to the configuration object.
setString(String, String) - 类 中的方法org.apache.flink.configuration.DelegatingConfiguration
 
setString(ConfigOption<String>, String) - 类 中的方法org.apache.flink.configuration.DelegatingConfiguration
 
setStringToTokenize(StringValue) - 类 中的方法org.apache.flink.util.StringValueUtils.WhitespaceTokenizer
Sets the string to be tokenized and resets the state of the tokenizer.
setTaskCancellationInterval(long) - 类 中的方法org.apache.flink.api.common.ExecutionConfig
Sets the configuration parameter specifying the interval (in milliseconds) between consecutive attempts to cancel a running task.
setTaskCancellationTimeout(long) - 类 中的方法org.apache.flink.api.common.ExecutionConfig
Sets the timeout (in milliseconds) after which an ongoing task cancellation is considered failed, leading to a fatal TaskManager error.
setTaskHeapMemory(MemorySize) - 类 中的方法org.apache.flink.api.common.operators.ResourceSpec.Builder
 
setTaskHeapMemory(MemorySize) - 类 中的方法org.apache.flink.api.common.operators.SlotSharingGroup.Builder
Set the task heap memory for this SlotSharingGroup.
setTaskHeapMemoryMB(int) - 类 中的方法org.apache.flink.api.common.operators.ResourceSpec.Builder
 
setTaskHeapMemoryMB(int) - 类 中的方法org.apache.flink.api.common.operators.SlotSharingGroup.Builder
Set the task heap memory for this SlotSharingGroup in MB.
setTaskOffHeapMemory(MemorySize) - 类 中的方法org.apache.flink.api.common.operators.ResourceSpec.Builder
 
setTaskOffHeapMemory(MemorySize) - 类 中的方法org.apache.flink.api.common.operators.SlotSharingGroup.Builder
Set the task off-heap memory for this SlotSharingGroup.
setTaskOffHeapMemoryMB(int) - 类 中的方法org.apache.flink.api.common.operators.ResourceSpec.Builder
 
setTaskOffHeapMemoryMB(int) - 类 中的方法org.apache.flink.api.common.operators.SlotSharingGroup.Builder
Set the task off-heap memory for this SlotSharingGroup in MB.
setTerminationCriterion(Operator<X>) - 类 中的方法org.apache.flink.api.common.operators.base.BulkIterationBase
 
setThreadPriority(int) - 类 中的方法org.apache.flink.util.concurrent.ExecutorThreadFactory.Builder
 
setTtl(Time) - 类 中的方法org.apache.flink.api.common.state.StateTtlConfig.Builder
Sets the ttl time.
setTtlTimeCharacteristic(StateTtlConfig.TtlTimeCharacteristic) - 类 中的方法org.apache.flink.api.common.state.StateTtlConfig.Builder
Sets the time characteristic.
setUid(String) - 类 中的方法org.apache.flink.api.dag.Transformation
Sets an ID for this Transformation.
setUidHash(String) - 类 中的方法org.apache.flink.api.dag.Transformation
Sets an user provided hash for this operator.
setUpdateType(StateTtlConfig.UpdateType) - 类 中的方法org.apache.flink.api.common.state.StateTtlConfig.Builder
Sets the ttl update type.
setUserCodeClassLoader(ClassLoader) - 类 中的方法org.apache.flink.api.common.typeutils.TypeSerializerConfigSnapshot
已过时。
Set the user code class loader.
setUseSnapshotCompression(boolean) - 类 中的方法org.apache.flink.api.common.ExecutionConfig
 
setValue(boolean) - 类 中的方法org.apache.flink.types.BooleanValue
 
setValue(BooleanValue) - 类 中的方法org.apache.flink.types.BooleanValue
 
setValue(byte) - 类 中的方法org.apache.flink.types.ByteValue
Sets the encapsulated byte to the specified value.
setValue(ByteValue) - 类 中的方法org.apache.flink.types.ByteValue
 
setValue(char) - 类 中的方法org.apache.flink.types.CharValue
Sets the encapsulated char to the specified value.
setValue(CharValue) - 类 中的方法org.apache.flink.types.CharValue
 
setValue(double) - 类 中的方法org.apache.flink.types.DoubleValue
Sets the value of the encapsulated primitive double.
setValue(DoubleValue) - 类 中的方法org.apache.flink.types.DoubleValue
 
setValue(L) - 类 中的方法org.apache.flink.types.Either.Left
Sets the encapsulated value to another value
setValue(R) - 类 中的方法org.apache.flink.types.Either.Right
Sets the encapsulated value to another value
setValue(float) - 类 中的方法org.apache.flink.types.FloatValue
Sets the value of the encapsulated primitive float.
setValue(FloatValue) - 类 中的方法org.apache.flink.types.FloatValue
 
setValue(int) - 类 中的方法org.apache.flink.types.IntValue
Sets the encapsulated int to the specified value.
setValue(IntValue) - 类 中的方法org.apache.flink.types.IntValue
 
setValue(long) - 类 中的方法org.apache.flink.types.LongValue
Sets the value of the encapsulated long to the specified value.
setValue(LongValue) - 类 中的方法org.apache.flink.types.LongValue
 
setValue(T) - 接口 中的方法org.apache.flink.types.ResettableValue
Sets the encapsulated value to another value
setValue(short) - 类 中的方法org.apache.flink.types.ShortValue
Sets the encapsulated short to the specified value.
setValue(ShortValue) - 类 中的方法org.apache.flink.types.ShortValue
 
setValue(CharSequence) - 类 中的方法org.apache.flink.types.StringValue
Sets the value of the StringValue to the given string.
setValue(StringValue) - 类 中的方法org.apache.flink.types.StringValue
Sets the value of the StringValue to the given string.
setValue(StringValue, int, int) - 类 中的方法org.apache.flink.types.StringValue
Sets the value of the StringValue to a substring of the given string.
setValue(CharSequence, int, int) - 类 中的方法org.apache.flink.types.StringValue
Sets the value of the StringValue to a substring of the given string.
setValue(CharBuffer) - 类 中的方法org.apache.flink.types.StringValue
Sets the contents of this string to the contents of the given CharBuffer.
setValue(char[], int, int) - 类 中的方法org.apache.flink.types.StringValue
Sets the value of the StringValue to a substring of the given value.
setValueAscii(byte[], int, int) - 类 中的方法org.apache.flink.types.StringValue
Sets the value of this StringValue, assuming that the binary data is ASCII coded.
setWriteMode(FileSystem.WriteMode) - 类 中的方法org.apache.flink.api.common.io.FileOutputFormat
 
setWritePosition(long) - 接口 中的方法org.apache.flink.core.memory.SeekableDataOutputView
Sets the write pointer to the given position.
SHORT - 类 中的静态变量org.apache.flink.api.common.typeinfo.Types
Returns type information for both a primitive short and Short.
SHORT_ARRAY_TYPE_INFO - 类 中的静态变量org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
 
SHORT_PRIMITIVE_ARRAY_TYPE_INFO - 类 中的静态变量org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
 
SHORT_TYPE_INFO - 类 中的静态变量org.apache.flink.api.common.typeinfo.BasicTypeInfo
 
SHORT_VALUE_TYPE_INFO - 类 中的静态变量org.apache.flink.api.java.typeutils.ValueTypeInfo
 
ShortComparator - org.apache.flink.api.common.typeutils.base中的类
 
ShortComparator(boolean) - 类 的构造器org.apache.flink.api.common.typeutils.base.ShortComparator
 
ShortParser - org.apache.flink.types.parser中的类
Parses a decimal text field into a Short.
ShortParser() - 类 的构造器org.apache.flink.types.parser.ShortParser
 
ShortPrimitiveArrayComparator - org.apache.flink.api.common.typeutils.base.array中的类
 
ShortPrimitiveArrayComparator(boolean) - 类 的构造器org.apache.flink.api.common.typeutils.base.array.ShortPrimitiveArrayComparator
 
ShortPrimitiveArraySerializer - org.apache.flink.api.common.typeutils.base.array中的类
A serializer for short arrays.
ShortPrimitiveArraySerializer() - 类 的构造器org.apache.flink.api.common.typeutils.base.array.ShortPrimitiveArraySerializer
 
ShortPrimitiveArraySerializer.ShortPrimitiveArraySerializerSnapshot - org.apache.flink.api.common.typeutils.base.array中的类
Serializer configuration snapshot for compatibility and format evolution.
ShortPrimitiveArraySerializerSnapshot() - 类 的构造器org.apache.flink.api.common.typeutils.base.array.ShortPrimitiveArraySerializer.ShortPrimitiveArraySerializerSnapshot
 
ShortSerializer - org.apache.flink.api.common.typeutils.base中的类
Type serializer for Byte.
ShortSerializer() - 类 的构造器org.apache.flink.api.common.typeutils.base.ShortSerializer
 
ShortSerializer.ShortSerializerSnapshot - org.apache.flink.api.common.typeutils.base中的类
Serializer configuration snapshot for compatibility and format evolution.
ShortSerializerSnapshot() - 类 的构造器org.apache.flink.api.common.typeutils.base.ShortSerializer.ShortSerializerSnapshot
 
shortString() - 枚举 中的方法org.apache.flink.types.RowKind
Returns a short string representation of this RowKind.
ShortValue - org.apache.flink.types中的类
Boxed serializable and comparable short integer type, representing the primitive type short.
ShortValue() - 类 的构造器org.apache.flink.types.ShortValue
Initializes the encapsulated short with 0.
ShortValue(short) - 类 的构造器org.apache.flink.types.ShortValue
Initializes the encapsulated short with the provided value.
ShortValueComparator - org.apache.flink.api.common.typeutils.base中的类
Specialized comparator for ShortValue based on CopyableValueComparator.
ShortValueComparator(boolean) - 类 的构造器org.apache.flink.api.common.typeutils.base.ShortValueComparator
 
ShortValueParser - org.apache.flink.types.parser中的类
Parses a decimal text field into a ShortValue.
ShortValueParser() - 类 的构造器org.apache.flink.types.parser.ShortValueParser
 
ShortValueSerializer - org.apache.flink.api.common.typeutils.base中的类
 
ShortValueSerializer() - 类 的构造器org.apache.flink.api.common.typeutils.base.ShortValueSerializer
 
ShortValueSerializer.ShortValueSerializerSnapshot - org.apache.flink.api.common.typeutils.base中的类
Serializer configuration snapshot for compatibility and format evolution.
ShortValueSerializerSnapshot() - 类 的构造器org.apache.flink.api.common.typeutils.base.ShortValueSerializer.ShortValueSerializerSnapshot
 
shouldAutocastTo(BasicTypeInfo<?>) - 类 中的方法org.apache.flink.api.common.typeinfo.BasicTypeInfo
Returns whether this type should be automatically casted to the target type in an arithmetic operation.
shouldTriggerCheckpoint() - 接口 中的方法org.apache.flink.api.connector.source.ExternallyInducedSourceReader
A method that informs the Flink runtime whether a checkpoint should be triggered on this Source.
showControlCharacters(String) - 类 中的静态方法org.apache.flink.util.StringUtils
Replaces control characters by their escape-coded version.
SHUFFLE_COMPRESSION_CODEC - 类 中的静态变量org.apache.flink.configuration.NettyShuffleEnvironmentOptions
The codec to be used when compressing shuffle data.
SHUTDOWN_IF_ATTACHED - 类 中的静态变量org.apache.flink.configuration.DeploymentOptions
 
ShutdownHookUtil - org.apache.flink.util中的类
Utils class for dealing with JVM shutdown hooks.
signalNoMoreSplits(int) - 接口 中的方法org.apache.flink.api.connector.source.SplitEnumeratorContext
Signals a subtask that it will not receive any further split.
SimpleAccumulator<T extends Serializable> - org.apache.flink.api.common.accumulators中的接口
Similar to Accumulator, but the type of items to add and the result value must be the same.
SimpleListIterable(List<IN>, TypeComparator<IN>, TypeSerializer<IN>) - 类 的构造器org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase.SimpleListIterable
 
SimpleListIterator(List<IN>, TypeSerializer<IN>) - 类 的构造器org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase.SimpleListIterable.SimpleListIterator
 
SimpleStringEncoder<IN> - org.apache.flink.api.common.serialization中的类
A simple Encoder that uses toString() on the input elements and writes them to the output bucket file separated by newline.
SimpleStringEncoder() - 类 的构造器org.apache.flink.api.common.serialization.SimpleStringEncoder
Creates a new StringWriter that uses "UTF-8" charset to convert strings to bytes.
SimpleStringEncoder(String) - 类 的构造器org.apache.flink.api.common.serialization.SimpleStringEncoder
Creates a new StringWriter that uses the given charset to convert strings to bytes.
SimpleStringSchema - org.apache.flink.api.common.serialization中的类
Very simple serialization schema for strings.
SimpleStringSchema() - 类 的构造器org.apache.flink.api.common.serialization.SimpleStringSchema
Creates a new SimpleStringSchema that uses "UTF-8" as the encoding.
SimpleStringSchema(Charset) - 类 的构造器org.apache.flink.api.common.serialization.SimpleStringSchema
Creates a new SimpleStringSchema that uses the given charset to convert between strings and bytes.
SimpleTypeSerializerSnapshot<T> - org.apache.flink.api.common.typeutils中的类
A simple base class for TypeSerializerSnapshots, for serializers that have no parameters.
SimpleTypeSerializerSnapshot(Supplier<? extends TypeSerializer<T>>) - 类 的构造器org.apache.flink.api.common.typeutils.SimpleTypeSerializerSnapshot
Constructor to create snapshot from serializer (writing the snapshot).
SimpleUserCodeClassLoader - org.apache.flink.util中的类
Simple UserCodeClassLoader implementation which assumes that the provided class loader will never be released and, hence, will never execute the release hooks.
SimpleVersionedSerialization - org.apache.flink.core.io中的类
Simple serialization / deserialization methods for the SimpleVersionedSerializer.
SimpleVersionedSerializer<E> - org.apache.flink.core.io中的接口
A simple serializer interface for versioned serialization.
SimpleVersionedSerializerTypeSerializerProxy<T> - org.apache.flink.core.io中的类
A TypeSerializer that delegates to an underlying SimpleVersionedSerializer.
SimpleVersionedSerializerTypeSerializerProxy(SerializableSupplier<SimpleVersionedSerializer<T>>) - 类 的构造器org.apache.flink.core.io.SimpleVersionedSerializerTypeSerializerProxy
 
SingleInputOperator<IN,OUT,FT extends Function> - 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) - 类 的构造器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) - 类 的构造器org.apache.flink.api.common.operators.SingleInputOperator
Creates a new abstract single-input operator with the given name wrapping the given user function.
SingleInputSemanticProperties - org.apache.flink.api.common.operators中的类
Container for the semantic properties associated to a single input operator.
SingleInputSemanticProperties() - 类 的构造器org.apache.flink.api.common.operators.SingleInputSemanticProperties
 
SingleInputSemanticProperties.AllFieldsForwardedProperties - org.apache.flink.api.common.operators中的类
 
SingleThreadAccessCheckingTypeSerializer<T> - org.apache.flink.api.common.typeutils中的类
 
SingleThreadAccessCheckingTypeSerializer(TypeSerializer<T>) - 类 的构造器org.apache.flink.api.common.typeutils.SingleThreadAccessCheckingTypeSerializer
 
SingleThreadAccessCheckingTypeSerializer.SingleThreadAccessCheckingTypeSerializerSnapshot<T> - org.apache.flink.api.common.typeutils中的类
 
SingleThreadAccessCheckingTypeSerializerSnapshot() - 类 的构造器org.apache.flink.api.common.typeutils.SingleThreadAccessCheckingTypeSerializer.SingleThreadAccessCheckingTypeSerializerSnapshot
 
Sink<InputT,CommT,WriterStateT,GlobalCommT> - org.apache.flink.api.connector.sink中的接口
This interface lets the sink developer build a simple sink topology, which could guarantee the exactly once semantics in both batch and stream execution mode if there is a Committer or GlobalCommitter. 1.
Sink.InitContext - org.apache.flink.api.connector.sink中的接口
The interface exposes some runtime info for creating a SinkWriter.
Sink.ProcessingTimeService - org.apache.flink.api.connector.sink中的接口
A service that allows to get the current processing time and register timers that will execute the given Sink.ProcessingTimeService.ProcessingTimeCallback when firing.
Sink.ProcessingTimeService.ProcessingTimeCallback - org.apache.flink.api.connector.sink中的接口
sinks - 类 中的变量org.apache.flink.api.common.Plan
A collection of all sinks in the plan.
SinkWriter<InputT,CommT,WriterStateT> - org.apache.flink.api.connector.sink中的接口
The SinkWriter is responsible for writing data and handling any potential tmp area used to write yet un-staged data, e.g. in-progress files.
SinkWriter.Context - org.apache.flink.api.connector.sink中的接口
Context that SinkWriter.write(InputT, org.apache.flink.api.connector.sink.SinkWriter.Context) can use for getting additional data about an input record.
size() - 类 中的方法org.apache.flink.api.common.operators.util.FieldSet
 
size() - 类 中的方法org.apache.flink.core.memory.ByteArrayOutputStreamWithPos
 
size() - 类 中的方法org.apache.flink.core.memory.MemorySegment
Gets the size of the memory segment, in bytes.
size() - 类 中的方法org.apache.flink.types.ListValue
 
size() - 类 中的方法org.apache.flink.types.MapValue
 
SIZE - 类 中的静态变量org.apache.flink.util.AbstractID
The size of the ID in byte.
size() - 类 中的方法org.apache.flink.util.LinkedOptionalMap
 
SIZE_MISMATCH_MESSAGE - 异常错误 中的静态变量org.apache.flink.api.common.operators.Keys.IncompatibleKeysException
 
SIZE_UNKNOWN - 接口 中的静态变量org.apache.flink.api.common.io.statistics.BaseStatistics
Constant indicating that the input size is unknown.
skip(long) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.DataInputViewStream
 
skip(int) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.NoFetchingInput
 
skip(long) - 类 中的方法org.apache.flink.core.fs.FSDataInputStreamWrapper
 
skip(long) - 类 中的方法org.apache.flink.core.fs.local.LocalDataInputStream
 
skip(long) - 类 中的方法org.apache.flink.core.memory.MemorySegmentInputStreamWithPos
 
skipBytes(int) - 类 中的方法org.apache.flink.core.memory.DataInputDeserializer
 
skipBytesToRead(int) - 类 中的方法org.apache.flink.core.memory.DataInputDeserializer
 
skipBytesToRead(int) - 接口 中的方法org.apache.flink.core.memory.DataInputView
Skips numBytes bytes of memory.
skipBytesToRead(int) - 类 中的方法org.apache.flink.core.memory.DataInputViewStreamWrapper
 
skipBytesToWrite(int) - 类 中的方法org.apache.flink.core.memory.DataOutputSerializer
 
skipBytesToWrite(int) - 接口 中的方法org.apache.flink.core.memory.DataOutputView
Skips numBytes bytes memory.
skipBytesToWrite(int) - 类 中的方法org.apache.flink.core.memory.DataOutputViewStreamWrapper
 
skipFields(byte[], int, int, byte[]) - 类 中的方法org.apache.flink.api.common.io.GenericCsvInputFormat
 
skipFully(InputStream, long) - 类 中的静态方法org.apache.flink.util.IOUtils
Similar to readFully().
SLOT_IDLE_TIMEOUT - 类 中的静态变量org.apache.flink.configuration.JobManagerOptions
The timeout in milliseconds for a idle slot in Slot Pool.
SLOT_MANAGER_TASK_MANAGER_TIMEOUT - 类 中的静态变量org.apache.flink.configuration.ResourceManagerOptions
SLOT_REQUEST_TIMEOUT - 类 中的静态变量org.apache.flink.configuration.JobManagerOptions
The timeout in milliseconds for requesting a slot from Slot Pool.
SLOT_REQUEST_TIMEOUT - 类 中的静态变量org.apache.flink.configuration.ResourceManagerOptions
SLOT_TIMEOUT - 类 中的静态变量org.apache.flink.configuration.TaskManagerOptions
Timeout for identifying inactive slots.
SlotSharingGroup - org.apache.flink.api.common.operators中的类
Describe the name and the the different resource components of a slot sharing group.
SlotSharingGroup.Builder - org.apache.flink.api.common.operators中的类
Builder for the SlotSharingGroup.
SlotSharingGroupUtils - org.apache.flink.api.common.operators.util中的类
Utils for SlotSharingGroup.
SlotSharingGroupUtils() - 类 的构造器org.apache.flink.api.common.operators.util.SlotSharingGroupUtils
 
SNAPSHOT_COMPRESSION - 类 中的静态变量org.apache.flink.configuration.ExecutionOptions
Should be moved to ExecutionCheckpointingOptions along with ExecutionConfig#useSnapshotCompression, which should be put into CheckpointConfig.
snapshotBackwardsCompatible(TypeSerializer<?>...) - 类 中的静态方法org.apache.flink.api.common.typeutils.TypeSerializerUtils
Takes snapshots of the given serializers.
snapshotBackwardsCompatible(TypeSerializer<T>) - 类 中的静态方法org.apache.flink.api.common.typeutils.TypeSerializerUtils
Takes a snapshot of the given serializer.
snapshotConfiguration() - 类 中的方法org.apache.flink.api.common.typeutils.base.array.BooleanPrimitiveArraySerializer
 
snapshotConfiguration() - 类 中的方法org.apache.flink.api.common.typeutils.base.array.BytePrimitiveArraySerializer
 
snapshotConfiguration() - 类 中的方法org.apache.flink.api.common.typeutils.base.array.CharPrimitiveArraySerializer
 
snapshotConfiguration() - 类 中的方法org.apache.flink.api.common.typeutils.base.array.DoublePrimitiveArraySerializer
 
snapshotConfiguration() - 类 中的方法org.apache.flink.api.common.typeutils.base.array.FloatPrimitiveArraySerializer
 
snapshotConfiguration() - 类 中的方法org.apache.flink.api.common.typeutils.base.array.IntPrimitiveArraySerializer
 
snapshotConfiguration() - 类 中的方法org.apache.flink.api.common.typeutils.base.array.LongPrimitiveArraySerializer
 
snapshotConfiguration() - 类 中的方法org.apache.flink.api.common.typeutils.base.array.ShortPrimitiveArraySerializer
 
snapshotConfiguration() - 类 中的方法org.apache.flink.api.common.typeutils.base.array.StringArraySerializer
 
snapshotConfiguration() - 类 中的方法org.apache.flink.api.common.typeutils.base.BigDecSerializer
 
snapshotConfiguration() - 类 中的方法org.apache.flink.api.common.typeutils.base.BigIntSerializer
 
snapshotConfiguration() - 类 中的方法org.apache.flink.api.common.typeutils.base.BooleanSerializer
 
snapshotConfiguration() - 类 中的方法org.apache.flink.api.common.typeutils.base.BooleanValueSerializer
 
snapshotConfiguration() - 类 中的方法org.apache.flink.api.common.typeutils.base.ByteSerializer
 
snapshotConfiguration() - 类 中的方法org.apache.flink.api.common.typeutils.base.ByteValueSerializer
 
snapshotConfiguration() - 类 中的方法org.apache.flink.api.common.typeutils.base.CharSerializer
 
snapshotConfiguration() - 类 中的方法org.apache.flink.api.common.typeutils.base.CharValueSerializer
 
snapshotConfiguration() - 类 中的方法org.apache.flink.api.common.typeutils.base.DateSerializer
 
snapshotConfiguration() - 类 中的方法org.apache.flink.api.common.typeutils.base.DoubleSerializer
 
snapshotConfiguration() - 类 中的方法org.apache.flink.api.common.typeutils.base.DoubleValueSerializer
 
snapshotConfiguration() - 类 中的方法org.apache.flink.api.common.typeutils.base.EnumSerializer
 
snapshotConfiguration() - 类 中的方法org.apache.flink.api.common.typeutils.base.FloatSerializer
 
snapshotConfiguration() - 类 中的方法org.apache.flink.api.common.typeutils.base.FloatValueSerializer
 
snapshotConfiguration() - 类 中的方法org.apache.flink.api.common.typeutils.base.GenericArraySerializer
 
snapshotConfiguration() - 类 中的方法org.apache.flink.api.common.typeutils.base.InstantSerializer
 
snapshotConfiguration() - 类 中的方法org.apache.flink.api.common.typeutils.base.IntSerializer
 
snapshotConfiguration() - 类 中的方法org.apache.flink.api.common.typeutils.base.IntValueSerializer
 
snapshotConfiguration() - 类 中的方法org.apache.flink.api.common.typeutils.base.ListSerializer
 
snapshotConfiguration() - 类 中的方法org.apache.flink.api.common.typeutils.base.LocalDateSerializer
 
snapshotConfiguration() - 类 中的方法org.apache.flink.api.common.typeutils.base.LocalDateTimeSerializer
 
snapshotConfiguration() - 类 中的方法org.apache.flink.api.common.typeutils.base.LocalTimeSerializer
 
snapshotConfiguration() - 类 中的方法org.apache.flink.api.common.typeutils.base.LongSerializer
 
snapshotConfiguration() - 类 中的方法org.apache.flink.api.common.typeutils.base.LongValueSerializer
 
snapshotConfiguration() - 类 中的方法org.apache.flink.api.common.typeutils.base.MapSerializer
 
snapshotConfiguration() - 类 中的方法org.apache.flink.api.common.typeutils.base.NullValueSerializer
 
snapshotConfiguration() - 类 中的方法org.apache.flink.api.common.typeutils.base.ShortSerializer
 
snapshotConfiguration() - 类 中的方法org.apache.flink.api.common.typeutils.base.ShortValueSerializer
 
snapshotConfiguration() - 类 中的方法org.apache.flink.api.common.typeutils.base.SqlDateSerializer
 
snapshotConfiguration() - 类 中的方法org.apache.flink.api.common.typeutils.base.SqlTimeSerializer
 
snapshotConfiguration() - 类 中的方法org.apache.flink.api.common.typeutils.base.SqlTimestampSerializer
 
snapshotConfiguration() - 类 中的方法org.apache.flink.api.common.typeutils.base.StringSerializer
 
snapshotConfiguration() - 类 中的方法org.apache.flink.api.common.typeutils.base.StringValueSerializer
 
snapshotConfiguration() - 类 中的方法org.apache.flink.api.common.typeutils.base.VoidSerializer
 
snapshotConfiguration() - 类 中的方法org.apache.flink.api.common.typeutils.SingleThreadAccessCheckingTypeSerializer
 
snapshotConfiguration() - 类 中的方法org.apache.flink.api.common.typeutils.TypeSerializer
Snapshots the configuration of this TypeSerializer.
snapshotConfiguration() - 类 中的方法org.apache.flink.api.common.typeutils.UnloadableDummyTypeSerializer
 
snapshotConfiguration() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer
 
snapshotConfiguration() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.EitherSerializer
 
snapshotConfiguration() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer
 
snapshotConfiguration() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.NullableSerializer
 
snapshotConfiguration() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.PojoSerializer
 
snapshotConfiguration() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.RowSerializer
 
snapshotConfiguration() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.Tuple0Serializer
 
snapshotConfiguration() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.TupleSerializer
 
snapshotConfiguration() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.ValueSerializer
 
snapshotConfiguration() - 类 中的方法org.apache.flink.core.io.SimpleVersionedSerializerTypeSerializerProxy
 
snapshotState() - 接口 中的方法org.apache.flink.api.connector.sink.SinkWriter
已过时。
snapshotState(long) - 接口 中的方法org.apache.flink.api.connector.sink.SinkWriter
 
snapshotState(long) - 类 中的方法org.apache.flink.api.connector.source.lib.util.IteratorSourceEnumerator
 
snapshotState(long) - 类 中的方法org.apache.flink.api.connector.source.lib.util.IteratorSourceReader
 
snapshotState(long) - 接口 中的方法org.apache.flink.api.connector.source.SourceReader
Checkpoint on the state of the source.
snapshotState(long) - 接口 中的方法org.apache.flink.api.connector.source.SplitEnumerator
Creates a snapshot of the state of this split enumerator, to be stored in a checkpoint.
SO_TIMEOUT - 类 中的静态变量org.apache.flink.configuration.BlobServerOptions
The socket timeout in milliseconds for the blob client.
socketAddressToUrlString(InetSocketAddress) - 类 中的静态方法org.apache.flink.util.NetUtils
Encodes an IP address and port to be included in URL. in particular, this method makes sure that IPv6 addresses have the proper formatting to be included in URLs.
SolutionSetPlaceHolder(DeltaIterationBase<ST, ?>, OperatorInformation<ST>) - 类 的构造器org.apache.flink.api.common.operators.base.DeltaIterationBase.SolutionSetPlaceHolder
 
SORT_INPUTS - 类 中的静态变量org.apache.flink.configuration.ExecutionOptions
 
SORT_SPILLING_THRESHOLD - 类 中的静态变量org.apache.flink.configuration.AlgorithmOptions
 
SORTED_INPUTS_MEMORY - 类 中的静态变量org.apache.flink.configuration.ExecutionOptions
 
SortPartitionOperatorBase<IN> - org.apache.flink.api.common.operators.base中的类
 
SortPartitionOperatorBase(UnaryOperatorInformation<IN, IN>, Ordering, String) - 类 的构造器org.apache.flink.api.common.operators.base.SortPartitionOperatorBase
 
Source<T,SplitT extends SourceSplit,EnumChkT> - org.apache.flink.api.connector.source中的接口
The interface for Source.
SourceEvent - org.apache.flink.api.connector.source中的接口
An base class for the events passed between the SourceReaders and Enumerators.
SourceOutput<T> - org.apache.flink.api.connector.source中的接口
The SourceOutput is the gateway for a SourceReader) to emit the produced records and watermarks.
SourceReader<T,SplitT extends SourceSplit> - org.apache.flink.api.connector.source中的接口
The interface for a source reader which is responsible for reading the records from the source splits assigned by SplitEnumerator.
SourceReaderContext - org.apache.flink.api.connector.source中的接口
The class that expose some context from runtime to the SourceReader.
SourceSplit - org.apache.flink.api.connector.source中的接口
An interface for all the Split types to extend.
SpecificInstanceCollectionSerializer(Class<T>) - 类 的构造器org.apache.flink.api.java.typeutils.runtime.kryo.Serializers.SpecificInstanceCollectionSerializer
 
SpecificInstanceCollectionSerializerForArrayList() - 类 的构造器org.apache.flink.api.java.typeutils.runtime.kryo.Serializers.SpecificInstanceCollectionSerializerForArrayList
 
SPILLING_MAX_FAN - 类 中的静态变量org.apache.flink.configuration.AlgorithmOptions
 
split(int) - 类 中的方法org.apache.flink.util.LongValueSequenceIterator
 
split(int) - 类 中的方法org.apache.flink.util.NumberSequenceIterator
 
split(int) - 类 中的方法org.apache.flink.util.SplittableIterator
Splits this iterator into a number disjoint iterators.
SplitEnumerator<SplitT extends SourceSplit,CheckpointT> - org.apache.flink.api.connector.source中的接口
A interface of a split enumerator responsible for the followings: 1. discover the splits for the SourceReader to read. 2. assign the splits to the source reader.
SplitEnumeratorContext<SplitT extends SourceSplit> - org.apache.flink.api.connector.source中的接口
A context class for the SplitEnumerator.
splitId() - 类 中的方法org.apache.flink.api.connector.source.lib.NumberSequenceSource.NumberSequenceSplit
 
splitId() - 接口 中的方法org.apache.flink.api.connector.source.SourceSplit
Get the split id of this source split.
splitLength - 类 中的变量org.apache.flink.api.common.io.FileInputFormat
The length of the split that this parallel instance must consume.
splitNumberRange(long, long, int) - 类 中的方法org.apache.flink.api.connector.source.lib.NumberSequenceSource
 
splitPaths(String) - 类 中的静态方法org.apache.flink.configuration.ConfigurationUtils
 
SplitsAssignment<SplitT extends SourceSplit> - org.apache.flink.api.connector.source中的类
A class containing the splits assignment to the source readers.
SplitsAssignment(Map<Integer, List<SplitT>>) - 类 的构造器org.apache.flink.api.connector.source.SplitsAssignment
 
SplitsAssignment(SplitT, int) - 类 的构造器org.apache.flink.api.connector.source.SplitsAssignment
 
splitStart - 类 中的变量org.apache.flink.api.common.io.FileInputFormat
The start of the split that this parallel instance must consume.
SplittableIterator<T> - org.apache.flink.util中的类
Abstract base class for iterators that can split themselves into multiple disjoint iterators.
SplittableIterator() - 类 的构造器org.apache.flink.util.SplittableIterator
 
SQL_DATE - 类 中的静态变量org.apache.flink.api.common.typeinfo.Types
Returns type information for Date.
SQL_TIME - 类 中的静态变量org.apache.flink.api.common.typeinfo.Types
Returns type information for Time.
SQL_TIMESTAMP - 类 中的静态变量org.apache.flink.api.common.typeinfo.Types
Returns type information for Timestamp.
SqlDateParser - org.apache.flink.types.parser中的类
Parses a text field into a Date.
SqlDateParser() - 类 的构造器org.apache.flink.types.parser.SqlDateParser
 
SqlDateSerializer - org.apache.flink.api.common.typeutils.base中的类
 
SqlDateSerializer() - 类 的构造器org.apache.flink.api.common.typeutils.base.SqlDateSerializer
 
SqlDateSerializer.SqlDateSerializerSnapshot - org.apache.flink.api.common.typeutils.base中的类
Serializer configuration snapshot for compatibility and format evolution.
SqlDateSerializerSnapshot() - 类 的构造器org.apache.flink.api.common.typeutils.base.SqlDateSerializer.SqlDateSerializerSnapshot
 
SqlTimeParser - org.apache.flink.types.parser中的类
Parses a text field into a Time.
SqlTimeParser() - 类 的构造器org.apache.flink.types.parser.SqlTimeParser
 
SqlTimeSerializer - org.apache.flink.api.common.typeutils.base中的类
 
SqlTimeSerializer() - 类 的构造器org.apache.flink.api.common.typeutils.base.SqlTimeSerializer
 
SqlTimeSerializer.SqlTimeSerializerSnapshot - org.apache.flink.api.common.typeutils.base中的类
Serializer configuration snapshot for compatibility and format evolution.
SqlTimeSerializerSnapshot() - 类 的构造器org.apache.flink.api.common.typeutils.base.SqlTimeSerializer.SqlTimeSerializerSnapshot
 
SqlTimestampComparator - org.apache.flink.api.common.typeutils.base中的类
Comparator for comparing Java SQL Timestamps.
SqlTimestampComparator(boolean) - 类 的构造器org.apache.flink.api.common.typeutils.base.SqlTimestampComparator
 
SqlTimestampParser - org.apache.flink.types.parser中的类
Parses a text field into a Timestamp.
SqlTimestampParser() - 类 的构造器org.apache.flink.types.parser.SqlTimestampParser
 
SqlTimestampSerializer - org.apache.flink.api.common.typeutils.base中的类
 
SqlTimestampSerializer() - 类 的构造器org.apache.flink.api.common.typeutils.base.SqlTimestampSerializer
 
SqlTimestampSerializer.SqlTimestampSerializerSnapshot - org.apache.flink.api.common.typeutils.base中的类
Serializer configuration snapshot for compatibility and format evolution.
SqlTimestampSerializerSnapshot() - 类 的构造器org.apache.flink.api.common.typeutils.base.SqlTimestampSerializer.SqlTimestampSerializerSnapshot
 
SqlTimeTypeInfo<T> - org.apache.flink.api.common.typeinfo中的类
Type information for Java SQL Date/Time/Timestamp.
SqlTimeTypeInfo(Class<T>, TypeSerializer<T>, Class<? extends TypeComparator<T>>) - 类 的构造器org.apache.flink.api.common.typeinfo.SqlTimeTypeInfo
 
SSL_ALGORITHMS - 类 中的静态变量org.apache.flink.configuration.SecurityOptions
The standard SSL algorithms to be supported.
SSL_ENABLED - 类 中的静态变量org.apache.flink.configuration.AkkaOptions
Override SSL support for the Akka transport.
SSL_ENABLED - 类 中的静态变量org.apache.flink.configuration.BlobServerOptions
Flag to override ssl support for the blob service transport.
SSL_ENABLED - 类 中的静态变量org.apache.flink.configuration.SecurityOptions
SSL_ENABLED - 类 中的静态变量org.apache.flink.configuration.WebOptions
已过时。
SSL_INTERNAL_CERT_FINGERPRINT - 类 中的静态变量org.apache.flink.configuration.SecurityOptions
For internal SSL, the sha1 fingerprint of the internal certificate to verify the client.
SSL_INTERNAL_CLOSE_NOTIFY_FLUSH_TIMEOUT - 类 中的静态变量org.apache.flink.configuration.SecurityOptions
SSL session timeout after flushing the close_notify message.
SSL_INTERNAL_ENABLED - 类 中的静态变量org.apache.flink.configuration.SecurityOptions
Enable SSL for internal communication (akka rpc, netty data transport, blob server).
SSL_INTERNAL_HANDSHAKE_TIMEOUT - 类 中的静态变量org.apache.flink.configuration.SecurityOptions
SSL session timeout during handshakes.
SSL_INTERNAL_KEY_PASSWORD - 类 中的静态变量org.apache.flink.configuration.SecurityOptions
For internal SSL, the password to decrypt the private key.
SSL_INTERNAL_KEYSTORE - 类 中的静态变量org.apache.flink.configuration.SecurityOptions
For internal SSL, the Java keystore file containing the private key and certificate.
SSL_INTERNAL_KEYSTORE_PASSWORD - 类 中的静态变量org.apache.flink.configuration.SecurityOptions
For internal SSL, the password to decrypt the keystore file containing the certificate.
SSL_INTERNAL_SESSION_CACHE_SIZE - 类 中的静态变量org.apache.flink.configuration.SecurityOptions
SSL session cache size.
SSL_INTERNAL_SESSION_TIMEOUT - 类 中的静态变量org.apache.flink.configuration.SecurityOptions
SSL session timeout.
SSL_INTERNAL_TRUSTSTORE - 类 中的静态变量org.apache.flink.configuration.SecurityOptions
For internal SSL, the truststore file containing the public CA certificates to verify the ssl peers.
SSL_INTERNAL_TRUSTSTORE_PASSWORD - 类 中的静态变量org.apache.flink.configuration.SecurityOptions
For internal SSL, the secret to decrypt the truststore.
SSL_KEY_PASSWORD - 类 中的静态变量org.apache.flink.configuration.SecurityOptions
Secret to decrypt the server key.
SSL_KEYSTORE - 类 中的静态变量org.apache.flink.configuration.SecurityOptions
The Java keystore file containing the flink endpoint key and certificate.
SSL_KEYSTORE_PASSWORD - 类 中的静态变量org.apache.flink.configuration.SecurityOptions
Secret to decrypt the keystore file.
SSL_PROTOCOL - 类 中的静态变量org.apache.flink.configuration.SecurityOptions
SSL protocol version to be supported.
SSL_PROVIDER - 类 中的静态变量org.apache.flink.configuration.SecurityOptions
SSL engine provider.
SSL_REST_AUTHENTICATION_ENABLED - 类 中的静态变量org.apache.flink.configuration.SecurityOptions
Enable mututal SSL authentication for external REST endpoints.
SSL_REST_CERT_FINGERPRINT - 类 中的静态变量org.apache.flink.configuration.SecurityOptions
For external (REST) SSL, the sha1 fingerprint of the rest client certificate to verify.
SSL_REST_ENABLED - 类 中的静态变量org.apache.flink.configuration.SecurityOptions
Enable SSL for external REST endpoints.
SSL_REST_KEY_PASSWORD - 类 中的静态变量org.apache.flink.configuration.SecurityOptions
For external (REST) SSL, the password to decrypt the private key.
SSL_REST_KEYSTORE - 类 中的静态变量org.apache.flink.configuration.SecurityOptions
For external (REST) SSL, the Java keystore file containing the private key and certificate.
SSL_REST_KEYSTORE_PASSWORD - 类 中的静态变量org.apache.flink.configuration.SecurityOptions
For external (REST) SSL, the password to decrypt the keystore file containing the certificate.
SSL_REST_TRUSTSTORE - 类 中的静态变量org.apache.flink.configuration.SecurityOptions
For external (REST) SSL, the truststore file containing the public CA certificates to verify the ssl peers.
SSL_REST_TRUSTSTORE_PASSWORD - 类 中的静态变量org.apache.flink.configuration.SecurityOptions
For external (REST) SSL, the secret to decrypt the truststore.
SSL_TRUSTSTORE - 类 中的静态变量org.apache.flink.configuration.SecurityOptions
The truststore file containing the public CA certificates to verify the ssl peers.
SSL_TRUSTSTORE_PASSWORD - 类 中的静态变量org.apache.flink.configuration.SecurityOptions
Secret to decrypt the truststore.
SSL_VERIFY_HOSTNAME - 类 中的静态变量org.apache.flink.configuration.SecurityOptions
Flag to enable/disable hostname verification for the ssl connections.
STANDALONE_CLUSTER_STARTUP_PERIOD_TIME - 类 中的静态变量org.apache.flink.configuration.ResourceManagerOptions
Time in milliseconds of the start-up period of a standalone cluster.
start() - 类 中的方法org.apache.flink.api.connector.source.lib.util.IteratorSourceEnumerator
 
start() - 类 中的方法org.apache.flink.api.connector.source.lib.util.IteratorSourceReader
 
start() - 接口 中的方法org.apache.flink.api.connector.source.SourceReader
Start the reader.
start() - 接口 中的方法org.apache.flink.api.connector.source.SplitEnumerator
Start the split enumerator.
START_WORKER_MAX_FAILURE_RATE - 类 中的静态变量org.apache.flink.configuration.ResourceManagerOptions
The maximum number of start worker failures (Native Kubernetes / Yarn) per minute before pausing requesting new workers.
START_WORKER_RETRY_INTERVAL - 类 中的静态变量org.apache.flink.configuration.ResourceManagerOptions
The time to wait before requesting new workers (Native Kubernetes / Yarn) once the max failure rate of starting workers (ResourceManagerOptions.START_WORKER_MAX_FAILURE_RATE) is reached.
startInstance(String) - 类 中的静态方法org.apache.flink.management.jmx.JMXService
Start the JMV-wide singleton JMX server.
startRecord() - 类 中的方法org.apache.flink.api.common.io.BinaryOutputFormat.BlockBasedOutput
 
startsWith(CharSequence, int) - 类 中的方法org.apache.flink.types.StringValue
Checks whether the substring, starting at the specified index, starts with the given prefix string.
startsWith(CharSequence) - 类 中的方法org.apache.flink.types.StringValue
Checks whether this StringValue starts with the given prefix string.
STARTUP_TIMEOUT - 类 中的静态变量org.apache.flink.configuration.AkkaOptions
Timeout for the startup of the actor system.
State - org.apache.flink.api.common.state中的接口
Interface that different types of partitioned state must implement.
STATE_BACKEND - 类 中的静态变量org.apache.flink.configuration.CheckpointingOptions
STATE_BACKEND - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
STATE_BACKEND - 类 中的静态变量org.apache.flink.configuration.StateBackendOptions
The checkpoint storage used to store operator state locally within the cluster during execution.
STATE_CHANGE_LOG_STORAGE - 类 中的静态变量org.apache.flink.configuration.CheckpointingOptions
Which storage to use to store state changelog.
StateBackendOptions - org.apache.flink.configuration中的类
A collection of all configuration options that relate to state backend.
StateBackendOptions() - 类 的构造器org.apache.flink.configuration.StateBackendOptions
 
StateDescriptor<S extends State,T> - org.apache.flink.api.common.state中的类
Base class for state descriptors.
StateDescriptor(String, TypeSerializer<T>, T) - 类 的构造器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) - 类 的构造器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) - 类 的构造器org.apache.flink.api.common.state.StateDescriptor
Create a new StateDescriptor with the given name and the given type information.
StateDescriptor.Type - org.apache.flink.api.common.state中的枚举
An enumeration of the types of supported states.
StateMigrationException - org.apache.flink.util中的异常错误
Base class for state migration related exceptions.
StateMigrationException(String) - 异常错误 的构造器org.apache.flink.util.StateMigrationException
 
StateMigrationException(Throwable) - 异常错误 的构造器org.apache.flink.util.StateMigrationException
 
StateMigrationException(String, Throwable) - 异常错误 的构造器org.apache.flink.util.StateMigrationException
 
StateTtlConfig - org.apache.flink.api.common.state中的类
Configuration of state TTL logic.
StateTtlConfig.Builder - org.apache.flink.api.common.state中的类
Builder for the StateTtlConfig.
StateTtlConfig.CleanupStrategies - org.apache.flink.api.common.state中的类
TTL cleanup strategies.
StateTtlConfig.IncrementalCleanupStrategy - org.apache.flink.api.common.state中的类
Configuration of cleanup strategy while taking the full snapshot.
StateTtlConfig.RocksdbCompactFilterCleanupStrategy - org.apache.flink.api.common.state中的类
Configuration of cleanup strategy using custom compaction filter in RocksDB.
StateTtlConfig.StateVisibility - org.apache.flink.api.common.state中的枚举
This option configures whether expired user value can be returned or not.
StateTtlConfig.TtlTimeCharacteristic - org.apache.flink.api.common.state中的枚举
This option configures time scale to use for ttl.
StateTtlConfig.UpdateType - org.apache.flink.api.common.state中的枚举
This option value configures when to update last access timestamp which prolongs state TTL.
statisticsKey - 类 中的变量org.apache.flink.api.common.operators.GenericDataSourceBase
 
stopInstance() - 类 中的静态方法org.apache.flink.management.jmx.JMXService
Stop the JMX server.
stopWithSavepoint(boolean, String) - 接口 中的方法org.apache.flink.core.execution.JobClient
Stops the associated job on Flink cluster.
STORAGE_DIRECTORY - 类 中的静态变量org.apache.flink.configuration.BlobServerOptions
The config parameter defining the storage directory to be used by the blob server.
stream - 类 中的变量org.apache.flink.api.common.io.FileInputFormat
The input stream reading from the input file.
stream - 类 中的变量org.apache.flink.api.common.io.FileOutputFormat
The stream to which the data is written;
stream() - 类 中的方法org.apache.flink.core.fs.OutputStreamAndPath
 
streamInactivityTimeout - 类 中的变量org.apache.flink.core.fs.LimitedConnectionsFileSystem.ConnectionLimitingSettings
The inactivity timeout for a stream, in milliseconds.
streamOpenTimeout - 类 中的变量org.apache.flink.core.fs.LimitedConnectionsFileSystem.ConnectionLimitingSettings
The stream opening timeout for a stream, in milliseconds.
StreamTimeoutException() - 异常错误 的构造器org.apache.flink.core.fs.LimitedConnectionsFileSystem.StreamTimeoutException
 
StreamTimeoutException(LimitedConnectionsFileSystem.StreamTimeoutException) - 异常错误 的构造器org.apache.flink.core.fs.LimitedConnectionsFileSystem.StreamTimeoutException
 
STRING - 类 中的静态变量org.apache.flink.api.common.typeinfo.Types
Returns type information for String.
STRING_ARRAY_TYPE_INFO - 类 中的静态变量org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
 
STRING_TYPE_INFO - 类 中的静态变量org.apache.flink.api.common.typeinfo.BasicTypeInfo
 
STRING_VALUE_TYPE_INFO - 类 中的静态变量org.apache.flink.api.java.typeutils.ValueTypeInfo
 
StringArraySerializer - org.apache.flink.api.common.typeutils.base.array中的类
A serializer for String arrays.
StringArraySerializer() - 类 的构造器org.apache.flink.api.common.typeutils.base.array.StringArraySerializer
 
StringArraySerializer.StringArraySerializerSnapshot - org.apache.flink.api.common.typeutils.base.array中的类
Serializer configuration snapshot for compatibility and format evolution.
StringArraySerializerSnapshot() - 类 的构造器org.apache.flink.api.common.typeutils.base.array.StringArraySerializer.StringArraySerializerSnapshot
 
StringBasedID - org.apache.flink.util中的类
Base class for typed IDs that are internally represented by a string.
StringBasedID(String) - 类 的构造器org.apache.flink.util.StringBasedID
Protected constructor to enforce that subclassing.
StringComparator - org.apache.flink.api.common.typeutils.base中的类
 
StringComparator(boolean) - 类 的构造器org.apache.flink.api.common.typeutils.base.StringComparator
 
STRINGIFIED_NULL_EXCEPTION - 类 中的静态变量org.apache.flink.util.ExceptionUtils
The stringified representation of a null exception reference.
stringifyException(Throwable) - 类 中的静态方法org.apache.flink.util.ExceptionUtils
Makes a string representation of the exception's stack trace, or "(null)", if the exception is null.
StringParser - org.apache.flink.types.parser中的类
Converts a variable length field of a byte array into a String.
StringParser() - 类 的构造器org.apache.flink.types.parser.StringParser
 
StringSerializer - org.apache.flink.api.common.typeutils.base中的类
Type serializer for String.
StringSerializer() - 类 的构造器org.apache.flink.api.common.typeutils.base.StringSerializer
 
StringSerializer.StringSerializerSnapshot - org.apache.flink.api.common.typeutils.base中的类
Serializer configuration snapshot for compatibility and format evolution.
StringSerializerSnapshot() - 类 的构造器org.apache.flink.api.common.typeutils.base.StringSerializer.StringSerializerSnapshot
 
stringType() - 类 中的方法org.apache.flink.configuration.ConfigOptions.OptionBuilder
Defines that the value of the option should be of String type.
StringUtils - org.apache.flink.util中的类
Utility class to convert objects into strings in vice-versa.
StringValue - org.apache.flink.types中的类
Mutable string data type that implements the Key interface.
StringValue() - 类 的构造器org.apache.flink.types.StringValue
Initializes the encapsulated String object with an empty string.
StringValue(CharSequence) - 类 的构造器org.apache.flink.types.StringValue
Initializes this StringValue to the value of the given string.
StringValue(StringValue) - 类 的构造器org.apache.flink.types.StringValue
Initializes this StringValue to a copy the given StringValue.
StringValue(StringValue, int, int) - 类 的构造器org.apache.flink.types.StringValue
Initializes the StringValue to a sub-string of the given StringValue.
StringValueComparator - org.apache.flink.api.common.typeutils.base中的类
Specialized comparator for StringValue based on CopyableValueComparator.
StringValueComparator(boolean) - 类 的构造器org.apache.flink.api.common.typeutils.base.StringValueComparator
 
StringValueParser - org.apache.flink.types.parser中的类
Converts a variable length field of a byte array into a StringValue.
StringValueParser() - 类 的构造器org.apache.flink.types.parser.StringValueParser
 
StringValueSerializer - org.apache.flink.api.common.typeutils.base中的类
 
StringValueSerializer() - 类 的构造器org.apache.flink.api.common.typeutils.base.StringValueSerializer
 
StringValueSerializer.StringValueSerializerSnapshot - org.apache.flink.api.common.typeutils.base中的类
Serializer configuration snapshot for compatibility and format evolution.
StringValueSerializerSnapshot() - 类 的构造器org.apache.flink.api.common.typeutils.base.StringValueSerializer.StringValueSerializerSnapshot
 
StringValueUtils - org.apache.flink.util中的类
Utility class for efficient operations on StringValue.
StringValueUtils.WhitespaceTokenizer - org.apache.flink.util中的类
A tokenizer for string values that uses whitespace characters as token delimiters.
stripCompletionException(Throwable) - 类 中的静态方法org.apache.flink.util.ExceptionUtils
Unpacks an CompletionException and returns its cause.
stripException(Throwable, Class<? extends Throwable>) - 类 中的静态方法org.apache.flink.util.ExceptionUtils
Unpacks an specified exception and returns its cause.
stripExecutionException(Throwable) - 类 中的静态方法org.apache.flink.util.ExceptionUtils
Unpacks an ExecutionException and returns its cause.
stripFileExtension(String) - 类 中的静态方法org.apache.flink.util.FileUtils
Remove the extension of the file name.
stripProxy(WrappingProxy<T>) - 类 中的静态方法org.apache.flink.util.WrappingProxyUtil
Expects a proxy, and returns the unproxied delegate.
subList(int, int) - 类 中的方法org.apache.flink.types.ListValue
 
submit(RunnableWithException, String, Object...) - 接口 中的方法org.apache.flink.api.common.operators.MailboxExecutor
Submits the given command for execution in the future in the mailbox thread and returns a Future representing that command.
submit(RunnableWithException, String) - 接口 中的方法org.apache.flink.api.common.operators.MailboxExecutor
Submits the given command for execution in the future in the mailbox thread and returns a Future representing that command.
submit(Callable<T>, String, Object...) - 接口 中的方法org.apache.flink.api.common.operators.MailboxExecutor
Submits the given command for execution in the future in the mailbox thread and returns a Future representing that command.
submit(Callable<T>, String) - 接口 中的方法org.apache.flink.api.common.operators.MailboxExecutor
Submits the given command for execution in the future in the mailbox thread and returns a Future representing that command.
SUBMIT_ENABLE - 类 中的静态变量org.apache.flink.configuration.WebOptions
Config parameter indicating whether jobs can be uploaded and run from the web-frontend.
SubmoduleClassLoader - org.apache.flink.core.classloading中的类
Loads all classes from the submodule jar, except for explicitly white-listed packages.
SubmoduleClassLoader(URL[], ClassLoader) - 类 的构造器org.apache.flink.core.classloading.SubmoduleClassLoader
 
subSequence(int, int) - 类 中的方法org.apache.flink.types.StringValue
 
substring(int) - 类 中的方法org.apache.flink.types.StringValue
Returns a new StringValuestring that is a substring of this string.
substring(int, int) - 类 中的方法org.apache.flink.types.StringValue
Returns a new StringValuestring that is a substring of this string.
substring(StringValue, int) - 类 中的方法org.apache.flink.types.StringValue
Copies a substring of this string into the given target StringValue.
substring(StringValue, int, int) - 类 中的方法org.apache.flink.types.StringValue
Copies a substring of this string into the given target StringValue.
subtract(ResourceSpec) - 类 中的方法org.apache.flink.api.common.operators.ResourceSpec
Subtracts another resource spec from this one.
subtract(T) - 类 中的方法org.apache.flink.api.common.resources.Resource
 
subtract(MemorySize) - 类 中的方法org.apache.flink.configuration.MemorySize
 
suffix(String) - 类 中的方法org.apache.flink.core.fs.Path
Adds a suffix to the final name in the path.
SupplierFromSerializableTimestampAssigner(SerializableTimestampAssigner<T>) - 类 的构造器org.apache.flink.api.common.eventtime.TimestampAssignerSupplier.SupplierFromSerializableTimestampAssigner
 
SupplierWithException<R,E extends Throwable> - org.apache.flink.util.function中的接口
A functional interface for a Supplier that may throw exceptions.
supplyAsync(SupplierWithException<T, ?>, Executor) - 类 中的静态方法org.apache.flink.util.concurrent.FutureUtils
Returns a future which is completed with the result of the SupplierWithException.
supportsCompareAgainstReference() - 类 中的方法org.apache.flink.api.common.typeutils.TypeComparator
 
supportsMultiPaths() - 类 中的方法org.apache.flink.api.common.io.FileInputFormat
已过时。
Will be removed for Flink 2.0.
supportsMultiPaths() - 类 中的方法org.apache.flink.api.common.io.GenericCsvInputFormat
 
supportsNormalizedKey() - 类 中的方法org.apache.flink.api.common.typeutils.base.array.PrimitiveArrayComparator
 
supportsNormalizedKey() - 类 中的方法org.apache.flink.api.common.typeutils.base.BigDecComparator
 
supportsNormalizedKey() - 类 中的方法org.apache.flink.api.common.typeutils.base.BigIntComparator
 
supportsNormalizedKey() - 类 中的方法org.apache.flink.api.common.typeutils.base.BooleanComparator
 
supportsNormalizedKey() - 类 中的方法org.apache.flink.api.common.typeutils.base.BooleanValueComparator
 
supportsNormalizedKey() - 类 中的方法org.apache.flink.api.common.typeutils.base.ByteComparator
 
supportsNormalizedKey() - 类 中的方法org.apache.flink.api.common.typeutils.base.ByteValueComparator
 
supportsNormalizedKey() - 类 中的方法org.apache.flink.api.common.typeutils.base.CharComparator
 
supportsNormalizedKey() - 类 中的方法org.apache.flink.api.common.typeutils.base.CharValueComparator
 
supportsNormalizedKey() - 类 中的方法org.apache.flink.api.common.typeutils.base.DateComparator
 
supportsNormalizedKey() - 类 中的方法org.apache.flink.api.common.typeutils.base.DoubleComparator
 
supportsNormalizedKey() - 类 中的方法org.apache.flink.api.common.typeutils.base.DoubleValueComparator
 
supportsNormalizedKey() - 类 中的方法org.apache.flink.api.common.typeutils.base.EnumComparator
 
supportsNormalizedKey() - 类 中的方法org.apache.flink.api.common.typeutils.base.FloatComparator
 
supportsNormalizedKey() - 类 中的方法org.apache.flink.api.common.typeutils.base.FloatValueComparator
 
supportsNormalizedKey() - 类 中的方法org.apache.flink.api.common.typeutils.base.InstantComparator
 
supportsNormalizedKey() - 类 中的方法org.apache.flink.api.common.typeutils.base.IntComparator
 
supportsNormalizedKey() - 类 中的方法org.apache.flink.api.common.typeutils.base.IntValueComparator
 
supportsNormalizedKey() - 类 中的方法org.apache.flink.api.common.typeutils.base.LocalDateComparator
 
supportsNormalizedKey() - 类 中的方法org.apache.flink.api.common.typeutils.base.LocalDateTimeComparator
 
supportsNormalizedKey() - 类 中的方法org.apache.flink.api.common.typeutils.base.LocalTimeComparator
 
supportsNormalizedKey() - 类 中的方法org.apache.flink.api.common.typeutils.base.LongComparator
 
supportsNormalizedKey() - 类 中的方法org.apache.flink.api.common.typeutils.base.LongValueComparator
 
supportsNormalizedKey() - 类 中的方法org.apache.flink.api.common.typeutils.base.NullValueComparator
 
supportsNormalizedKey() - 类 中的方法org.apache.flink.api.common.typeutils.base.ShortComparator
 
supportsNormalizedKey() - 类 中的方法org.apache.flink.api.common.typeutils.base.ShortValueComparator
 
supportsNormalizedKey() - 类 中的方法org.apache.flink.api.common.typeutils.base.SqlTimestampComparator
 
supportsNormalizedKey() - 类 中的方法org.apache.flink.api.common.typeutils.base.StringComparator
 
supportsNormalizedKey() - 类 中的方法org.apache.flink.api.common.typeutils.base.StringValueComparator
 
supportsNormalizedKey() - 类 中的方法org.apache.flink.api.common.typeutils.TypeComparator
Checks whether the data type supports the creation of a normalized key for comparison.
supportsNormalizedKey() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.CopyableValueComparator
 
supportsNormalizedKey() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.GenericTypeComparator
 
supportsNormalizedKey() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.NullAwareComparator
 
supportsNormalizedKey() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.PojoComparator
 
supportsNormalizedKey() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.RowComparator
 
supportsNormalizedKey() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
 
supportsNormalizedKey() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.ValueComparator
 
supportsResume() - 类 中的方法org.apache.flink.core.fs.local.LocalRecoverableWriter
 
supportsResume() - 接口 中的方法org.apache.flink.core.fs.RecoverableWriter
Checks whether the writer and its streams support resuming (appending to) files after recovery (via the RecoverableWriter.recover(ResumeRecoverable) method).
supportsSerializationWithKeyNormalization() - 类 中的方法org.apache.flink.api.common.typeutils.base.array.PrimitiveArrayComparator
 
supportsSerializationWithKeyNormalization() - 类 中的方法org.apache.flink.api.common.typeutils.base.BasicTypeComparator
 
supportsSerializationWithKeyNormalization() - 类 中的方法org.apache.flink.api.common.typeutils.base.BigDecComparator
 
supportsSerializationWithKeyNormalization() - 类 中的方法org.apache.flink.api.common.typeutils.base.BigIntComparator
 
supportsSerializationWithKeyNormalization() - 类 中的方法org.apache.flink.api.common.typeutils.base.BooleanValueComparator
 
supportsSerializationWithKeyNormalization() - 类 中的方法org.apache.flink.api.common.typeutils.base.ByteValueComparator
 
supportsSerializationWithKeyNormalization() - 类 中的方法org.apache.flink.api.common.typeutils.base.CharValueComparator
 
supportsSerializationWithKeyNormalization() - 类 中的方法org.apache.flink.api.common.typeutils.base.DoubleValueComparator
 
supportsSerializationWithKeyNormalization() - 类 中的方法org.apache.flink.api.common.typeutils.base.FloatValueComparator
 
supportsSerializationWithKeyNormalization() - 类 中的方法org.apache.flink.api.common.typeutils.base.IntValueComparator
 
supportsSerializationWithKeyNormalization() - 类 中的方法org.apache.flink.api.common.typeutils.base.LocalDateComparator
 
supportsSerializationWithKeyNormalization() - 类 中的方法org.apache.flink.api.common.typeutils.base.LocalDateTimeComparator
 
supportsSerializationWithKeyNormalization() - 类 中的方法org.apache.flink.api.common.typeutils.base.LongValueComparator
 
supportsSerializationWithKeyNormalization() - 类 中的方法org.apache.flink.api.common.typeutils.base.NullValueComparator
 
supportsSerializationWithKeyNormalization() - 类 中的方法org.apache.flink.api.common.typeutils.base.ShortValueComparator
 
supportsSerializationWithKeyNormalization() - 类 中的方法org.apache.flink.api.common.typeutils.base.StringComparator
 
supportsSerializationWithKeyNormalization() - 类 中的方法org.apache.flink.api.common.typeutils.base.StringValueComparator
 
supportsSerializationWithKeyNormalization() - 类 中的方法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() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.CopyableValueComparator
 
supportsSerializationWithKeyNormalization() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.GenericTypeComparator
 
supportsSerializationWithKeyNormalization() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.NullAwareComparator
 
supportsSerializationWithKeyNormalization() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.PojoComparator
 
supportsSerializationWithKeyNormalization() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.RowComparator
 
supportsSerializationWithKeyNormalization() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
 
supportsSerializationWithKeyNormalization() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.ValueComparator
 
suppressExceptions(RunnableWithException) - 类 中的静态方法org.apache.flink.util.ExceptionUtils
 
swap() - 类 中的方法org.apache.flink.api.java.tuple.Tuple2
Returns a shallow copy of the tuple with swapped values.
swapBytes(byte[], MemorySegment, int, int, int) - 类 中的方法org.apache.flink.core.memory.MemorySegment
Swaps bytes between two memory segments, using the given auxiliary buffer.
switchExecutor(CompletableFuture<? extends T>, Executor) - 类 中的静态方法org.apache.flink.util.concurrent.FutureUtils
Switches the execution context of the given source future.
sync() - 类 中的方法org.apache.flink.core.fs.FSDataOutputStream
Flushes the data all the way to the persistent non-volatile storage (for example disks).
sync() - 类 中的方法org.apache.flink.core.fs.FSDataOutputStreamWrapper
 
sync() - 类 中的方法org.apache.flink.core.fs.local.LocalDataOutputStream
 
SYSTEM_RESOURCE_METRICS - 类 中的静态变量org.apache.flink.configuration.MetricOptions
Whether Flink should report system resource metrics such as machine's CPU, memory or network usage.
SYSTEM_RESOURCE_METRICS_PROBING_INTERVAL - 类 中的静态变量org.apache.flink.configuration.MetricOptions
Interval between probing of system resource metrics specified in milliseconds.
SystemClock - org.apache.flink.util.clock中的类
A clock that returns the time of the system / process.

T

TARGET - 类 中的静态变量org.apache.flink.configuration.DeploymentOptions
 
TASK_CANCELLATION_INTERVAL - 类 中的静态变量org.apache.flink.configuration.TaskManagerOptions
Time interval in milliseconds between two successive task cancellation attempts.
TASK_CANCELLATION_INTERVAL_MILLIS - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
TASK_CANCELLATION_TIMEOUT - 类 中的静态变量org.apache.flink.configuration.TaskManagerOptions
Timeout in milliseconds after which a task cancellation times out and leads to a fatal TaskManager error.
TASK_CANCELLATION_TIMEOUT_TIMERS - 类 中的静态变量org.apache.flink.configuration.TaskManagerOptions
This configures how long we wait for the timers in milliseconds to finish all pending timer threads when the stream task is cancelled.
TASK_HEAP_MEMORY - 类 中的静态变量org.apache.flink.configuration.TaskManagerOptions
Task Heap Memory size for TaskExecutors.
TASK_MANAGER_DATA_PORT_KEY - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
TASK_MANAGER_DATA_SSL_ENABLED - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
TASK_MANAGER_DEBUG_MEMORY_USAGE_LOG_INTERVAL_MS - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
TASK_MANAGER_DEBUG_MEMORY_USAGE_START_LOG_THREAD - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
TASK_MANAGER_HEAP_MEMORY - 类 中的静态变量org.apache.flink.configuration.TaskManagerOptions
已过时。
use TaskManagerOptions.TOTAL_FLINK_MEMORY for standalone setups and TaskManagerOptions.TOTAL_PROCESS_MEMORY for containerized setups.
TASK_MANAGER_HEAP_MEMORY_MB - 类 中的静态变量org.apache.flink.configuration.TaskManagerOptions
已过时。
use TaskManagerOptions.TOTAL_FLINK_MEMORY for standalone setups and TaskManagerOptions.TOTAL_PROCESS_MEMORY for containerized setups.
TASK_MANAGER_HOSTNAME_KEY - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
TASK_MANAGER_INITIAL_REGISTRATION_PAUSE - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
TASK_MANAGER_IPC_PORT_KEY - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
TASK_MANAGER_LOG_PATH_KEY - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
The config parameter defining the taskmanager log file location.
TASK_MANAGER_MAX_REGISTARTION_PAUSE - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
TASK_MANAGER_MAX_REGISTRATION_DURATION - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
TASK_MANAGER_MEMORY_FRACTION_KEY - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
has no effect
TASK_MANAGER_MEMORY_OFF_HEAP_KEY - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
has no effect
TASK_MANAGER_MEMORY_PRE_ALLOCATE_KEY - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
has no effect
TASK_MANAGER_MEMORY_SEGMENT_SIZE_KEY - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
TASK_MANAGER_MEMORY_SIZE_KEY - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
TASK_MANAGER_NETWORK_DEFAULT_IO_MODE - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
Not used anymore
TASK_MANAGER_NETWORK_NUM_BUFFERS_KEY - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
TASK_MANAGER_NUM_TASK_SLOTS - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
TASK_MANAGER_REFUSED_REGISTRATION_PAUSE - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
TASK_MANAGER_REGISTRATION_TIMEOUT - 类 中的静态变量org.apache.flink.configuration.ResourceManagerOptions
Timeout for TaskManagers to register at the active resource managers.
TASK_MANAGER_RELEASE_WHEN_RESULT_CONSUMED - 类 中的静态变量org.apache.flink.configuration.ResourceManagerOptions
已过时。
The default value should be reasonable enough in all cases, this option is to fallback to older behaviour which will be removed or refactored in future.
TASK_MANAGER_RESOURCE_ID - 类 中的静态变量org.apache.flink.configuration.TaskManagerOptions
The TaskManager's ResourceID.
TASK_MANAGER_RESOURCE_ID_METADATA - 类 中的静态变量org.apache.flink.configuration.TaskManagerOptionsInternal
 
TASK_MANAGER_TIMEOUT - 类 中的静态变量org.apache.flink.configuration.ResourceManagerOptions
The timeout for an idle task manager to be released, in milliseconds.
TASK_MANAGER_TMP_DIR_KEY - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
TASK_OFF_HEAP_MEMORY - 类 中的静态变量org.apache.flink.configuration.TaskManagerOptions
Task Off-Heap Memory size for TaskExecutors.
TaskInfo - org.apache.flink.api.common中的类
Encapsulates task-specific information: name, index of subtask, parallelism and attempt number.
TaskInfo(String, int, int, int, int) - 类 的构造器org.apache.flink.api.common.TaskInfo
 
TaskInfo(String, int, int, int, int, String) - 类 的构造器org.apache.flink.api.common.TaskInfo
 
TaskManagerExceptionUtils - org.apache.flink.util中的类
Exception utils to handle and enrich exceptions occurring in TaskManager.
TaskManagerOptions - org.apache.flink.configuration中的类
The set of configuration options relating to TaskManager and Task settings.
TaskManagerOptionsInternal - org.apache.flink.configuration中的类
TaskManager options that are not meant to be used by the user.
TaskManagerOptionsInternal() - 类 的构造器org.apache.flink.configuration.TaskManagerOptionsInternal
 
TCP_TIMEOUT - 类 中的静态变量org.apache.flink.configuration.AkkaOptions
The Akka tcp connection timeout.
TemporaryClassLoaderContext - org.apache.flink.util中的类
Sets a context class loader in a "try-with-resources" pattern.
TERMINATION_CRITERION_AGGREGATOR_NAME - 类 中的静态变量org.apache.flink.api.common.operators.base.BulkIterationBase
 
terminationCriterion - 类 中的变量org.apache.flink.api.common.operators.base.BulkIterationBase
 
TerminationCriterionAggregationConvergence() - 类 的构造器org.apache.flink.api.common.operators.base.BulkIterationBase.TerminationCriterionAggregationConvergence
 
TerminationCriterionAggregator() - 类 的构造器org.apache.flink.api.common.operators.base.BulkIterationBase.TerminationCriterionAggregator
 
TerminationCriterionMapper() - 类 的构造器org.apache.flink.api.common.operators.base.BulkIterationBase.TerminationCriterionMapper
 
TernaryBoolean - org.apache.flink.util中的枚举
A ternary boolean, which can have the values 'true', 'false', or 'undefined'.
testForUnsplittable(FileStatus) - 类 中的方法org.apache.flink.api.common.io.FileInputFormat
 
text(String, InlineElement...) - 类 中的方法org.apache.flink.configuration.description.Description.DescriptionBuilder
Adds a block of text with placeholders ("%s") that will be replaced with proper string representation of given InlineElement.
text(String) - 类 中的方法org.apache.flink.configuration.description.Description.DescriptionBuilder
Creates a simple block of text.
text(String, InlineElement...) - 类 中的静态方法org.apache.flink.configuration.description.TextElement
Creates a block of text with placeholders ("%s") that will be replaced with proper string representation of given InlineElement.
text(String) - 类 中的静态方法org.apache.flink.configuration.description.TextElement
Creates a simple block of text.
TextElement - org.apache.flink.configuration.description中的类
Represents a text block in the Description.
TextElement.TextStyle - org.apache.flink.configuration.description中的枚举
Styles that can be applied to TextElement e.g. code, bold etc.
thenAcceptAsyncIfNotDone(CompletableFuture<IN>, Executor, Consumer<? super IN>) - 类 中的静态方法org.apache.flink.util.concurrent.FutureUtils
This function takes a CompletableFuture and a consumer to accept the result of this future.
thenApplyAsyncIfNotDone(CompletableFuture<IN>, Executor, Function<? super IN, ? extends OUT>) - 类 中的静态方法org.apache.flink.util.concurrent.FutureUtils
This function takes a CompletableFuture and a function to apply to this future.
thenComposeAsyncIfNotDone(CompletableFuture<IN>, Executor, Function<? super IN, ? extends CompletionStage<OUT>>) - 类 中的静态方法org.apache.flink.util.concurrent.FutureUtils
This function takes a CompletableFuture and a function to compose with this future.
ThrowableCatchingRunnable - org.apache.flink.util中的类
This class catches all the Throwables from the wrapped runnable.
ThrowableCatchingRunnable(Consumer<Throwable>, Runnable) - 类 的构造器org.apache.flink.util.ThrowableCatchingRunnable
 
throwIfCompletedExceptionally(CompletableFuture<?>) - 类 中的静态方法org.apache.flink.util.concurrent.FutureUtils
Throws the causing exception if the given future is completed exceptionally, otherwise do nothing.
ThrowingConsumer<T,E extends Throwable> - org.apache.flink.util.function中的接口
This interface is basically Java's Consumer interface enhanced with the ability to throw an exception.
ThrowingRunnable<E extends Throwable> - org.apache.flink.util.function中的接口
Similar to a Runnable, this interface is used to capture a block of code to be executed.
Time - org.apache.flink.api.common.time中的类
The definition of a time interval.
TIME - 类 中的静态变量org.apache.flink.api.common.typeinfo.SqlTimeTypeInfo
 
timeComparator - 类 中的变量org.apache.flink.api.common.typeutils.base.LocalDateTimeComparator
 
timeLeft() - 类 中的方法org.apache.flink.api.common.time.Deadline
Returns the time left between the deadline and now.
timeLeftIfAny() - 类 中的方法org.apache.flink.api.common.time.Deadline
Returns the time left between the deadline and now.
TIMEOUT - 类 中的静态变量org.apache.flink.configuration.WebOptions
Timeout for asynchronous operations by the web monitor in milliseconds.
TIMESTAMP - 类 中的静态变量org.apache.flink.api.common.typeinfo.SqlTimeTypeInfo
 
timestamp() - 接口 中的方法org.apache.flink.api.connector.sink.SinkWriter.Context
Returns the timestamp of the current input record or null if the element does not have an assigned timestamp.
TimestampAssigner<T> - org.apache.flink.api.common.eventtime中的接口
A TimestampAssigner assigns event time timestamps to elements.
TimestampAssignerSupplier<T> - org.apache.flink.api.common.eventtime中的接口
A supplier for TimestampAssigners.
TimestampAssignerSupplier.Context - org.apache.flink.api.common.eventtime中的接口
TimestampAssignerSupplier.SupplierFromSerializableTimestampAssigner<T> - org.apache.flink.api.common.eventtime中的类
We need an actual class.
TimeUtils - org.apache.flink.util中的类
Collection of utilities about time intervals.
TimeUtils() - 类 的构造器org.apache.flink.util.TimeUtils
 
TMP_DIR - 类 中的静态变量org.apache.flink.configuration.WebOptions
The config parameter defining the flink web directory to be used by the webmonitor.
TMP_DIRS - 类 中的静态变量org.apache.flink.configuration.CoreOptions
The config parameter defining the directories for temporary files, separated by ",", "|", or the system's File.pathSeparator.
to() - 类 中的方法org.apache.flink.api.connector.source.lib.NumberSequenceSource.NumberSequenceSplit
 
toArray() - 类 中的方法org.apache.flink.api.common.operators.util.FieldSet
Transforms the field set into an array of field IDs.
toArray() - 类 中的方法org.apache.flink.types.ListValue
 
toArray(T[]) - 类 中的方法org.apache.flink.types.ListValue
 
toByteArray() - 类 中的方法org.apache.flink.core.memory.ByteArrayOutputStreamWithPos
 
toByteValue() - 枚举 中的方法org.apache.flink.types.RowKind
Returns the byte value representation of this RowKind.
toDuration(Time) - 类 中的静态方法org.apache.flink.util.concurrent.FutureUtils
Converts Flink time into a Duration.
toDuration(Time) - 类 中的静态方法org.apache.flink.util.TimeUtils
Translates Time to Duration.
toFieldList() - 类 中的方法org.apache.flink.api.common.operators.util.FieldList
 
toFieldList() - 类 中的方法org.apache.flink.api.common.operators.util.FieldSet
Turns the FieldSet into an ordered FieldList.
toHexString() - 类 中的方法org.apache.flink.util.AbstractID
Returns pure String representation of the ID in hexadecimal.
toHumanReadableString() - 类 中的方法org.apache.flink.api.common.resources.CPUResource
 
toHumanReadableString() - 类 中的方法org.apache.flink.configuration.MemorySize
 
toLowerCase(StringValue) - 类 中的静态方法org.apache.flink.util.StringValueUtils
Converts the given StringValue into a lower case variant.
toMap() - 类 中的方法org.apache.flink.api.common.ExecutionConfig.GlobalJobParameters
Convert UserConfig into a Map<String, String> representation.
toMap() - 类 中的方法org.apache.flink.configuration.Configuration
 
toMap() - 类 中的方法org.apache.flink.configuration.DelegatingConfiguration
 
toMilliseconds() - 类 中的方法org.apache.flink.api.common.time.Time
Converts the time interval to milliseconds.
toOptional() - 类 中的方法org.apache.flink.types.SerializableOptional
 
toQuotedListString(Object[]) - 类 中的静态方法org.apache.flink.util.StringUtils
Generates a string containing a comma-separated list of values in double-quotes.
toResultMap(Map<String, Accumulator<?, ?>>) - 类 中的静态方法org.apache.flink.api.common.accumulators.AccumulatorHelper
Transform the Map with accumulators into a Map containing only the results.
toStream(Iterable<E>) - 类 中的静态方法org.apache.flink.util.IterableUtils
Convert the given Iterable to a Stream.
toString() - 类 中的方法org.apache.flink.api.common.accumulators.AverageAccumulator
 
toString() - 类 中的方法org.apache.flink.api.common.accumulators.DoubleCounter
 
toString() - 类 中的方法org.apache.flink.api.common.accumulators.DoubleMaximum
 
toString() - 类 中的方法org.apache.flink.api.common.accumulators.DoubleMinimum
 
toString() - 类 中的方法org.apache.flink.api.common.accumulators.Histogram
 
toString() - 类 中的方法org.apache.flink.api.common.accumulators.IntCounter
 
toString() - 类 中的方法org.apache.flink.api.common.accumulators.IntMaximum
 
toString() - 类 中的方法org.apache.flink.api.common.accumulators.IntMinimum
 
toString() - 类 中的方法org.apache.flink.api.common.accumulators.ListAccumulator
 
toString() - 类 中的方法org.apache.flink.api.common.accumulators.LongCounter
 
toString() - 类 中的方法org.apache.flink.api.common.accumulators.LongMaximum
 
toString() - 类 中的方法org.apache.flink.api.common.accumulators.LongMinimum
 
toString() - 类 中的方法org.apache.flink.api.common.accumulators.SerializedListAccumulator
 
toString() - 类 中的方法org.apache.flink.api.common.cache.DistributedCache.DistributedCacheEntry
 
toString() - 类 中的方法org.apache.flink.api.common.eventtime.Watermark
 
toString() - 类 中的方法org.apache.flink.api.common.ExecutionConfig
 
toString() - 类 中的方法org.apache.flink.api.common.functions.util.PrintSinkOutputWriter
 
toString() - 类 中的方法org.apache.flink.api.common.io.FileInputFormat.FileBaseStatistics
 
toString() - 类 中的方法org.apache.flink.api.common.io.FileInputFormat
 
toString() - 类 中的方法org.apache.flink.api.common.JobExecutionResult
 
toString() - 类 中的方法org.apache.flink.api.common.operators.DualInputSemanticProperties
 
toString() - 类 中的方法org.apache.flink.api.common.operators.GenericDataSinkBase
 
toString() - 类 中的方法org.apache.flink.api.common.operators.GenericDataSourceBase
 
toString() - 类 中的方法org.apache.flink.api.common.operators.Keys.ExpressionKeys
 
toString() - 类 中的方法org.apache.flink.api.common.operators.Keys.SelectorFunctionKeys
 
toString() - 类 中的方法org.apache.flink.api.common.operators.Operator
 
toString() - 类 中的方法org.apache.flink.api.common.operators.OperatorInformation
 
toString() - 类 中的方法org.apache.flink.api.common.operators.Ordering
 
toString() - 类 中的方法org.apache.flink.api.common.operators.ResourceSpec
 
toString() - 类 中的方法org.apache.flink.api.common.operators.SingleInputSemanticProperties
 
toString() - 类 中的方法org.apache.flink.api.common.operators.util.FieldSet
 
toString() - 类 中的方法org.apache.flink.api.common.resources.Resource
 
toString() - 类 中的方法org.apache.flink.api.common.restartstrategy.RestartStrategies.RestartStrategyConfiguration
 
toString() - 类 中的方法org.apache.flink.api.common.state.StateDescriptor
 
toString() - 类 中的方法org.apache.flink.api.common.state.StateTtlConfig
 
toString() - 类 中的方法org.apache.flink.api.common.time.Deadline
 
toString() - 类 中的方法org.apache.flink.api.common.time.Time
 
toString() - 类 中的方法org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
 
toString() - 类 中的方法org.apache.flink.api.common.typeinfo.BasicTypeInfo
 
toString() - 类 中的方法org.apache.flink.api.common.typeinfo.LocalTimeTypeInfo
 
toString() - 类 中的方法org.apache.flink.api.common.typeinfo.NothingTypeInfo
 
toString() - 类 中的方法org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
 
toString() - 类 中的方法org.apache.flink.api.common.typeinfo.SqlTimeTypeInfo
 
toString() - 类 中的方法org.apache.flink.api.common.typeinfo.TypeHint
 
toString() - 类 中的方法org.apache.flink.api.common.typeinfo.TypeInformation
 
toString() - 类 中的方法org.apache.flink.api.common.typeutils.base.EnumSerializer
 
toString() - 类 中的方法org.apache.flink.api.common.typeutils.base.GenericArraySerializer
 
toString() - 类 中的方法org.apache.flink.api.common.typeutils.CompositeType.FlatFieldDescriptor
 
toString() - 类 中的方法org.apache.flink.api.common.typeutils.CompositeType
 
toString() - 类 中的方法org.apache.flink.api.common.typeutils.SimpleTypeSerializerSnapshot
 
toString() - 类 中的方法org.apache.flink.api.common.typeutils.TypeSerializerSchemaCompatibility
 
toString() - 类 中的方法org.apache.flink.api.connector.source.lib.NumberSequenceSource.NumberSequenceSplit
 
toString() - 类 中的方法org.apache.flink.api.connector.source.SplitsAssignment
 
toString() - 类 中的方法org.apache.flink.api.dag.Transformation
 
toString() - 类 中的方法org.apache.flink.api.java.tuple.Tuple0
Creates a string representation of the tuple in the form "()".
toString() - 类 中的方法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() - 类 中的方法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() - 类 中的方法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() - 类 中的方法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() - 类 中的方法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() - 类 中的方法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() - 类 中的方法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() - 类 中的方法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() - 类 中的方法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() - 类 中的方法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() - 类 中的方法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() - 类 中的方法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() - 类 中的方法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() - 类 中的方法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() - 类 中的方法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() - 类 中的方法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() - 类 中的方法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() - 类 中的方法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() - 类 中的方法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() - 类 中的方法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() - 类 中的方法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() - 类 中的方法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() - 类 中的方法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() - 类 中的方法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() - 类 中的方法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() - 类 中的方法org.apache.flink.api.java.typeutils.EitherTypeInfo
 
toString() - 类 中的方法org.apache.flink.api.java.typeutils.EnumTypeInfo
 
toString() - 类 中的方法org.apache.flink.api.java.typeutils.GenericTypeInfo
 
toString() - 类 中的方法org.apache.flink.api.java.typeutils.ListTypeInfo
 
toString() - 类 中的方法org.apache.flink.api.java.typeutils.MapTypeInfo
 
toString() - 类 中的方法org.apache.flink.api.java.typeutils.MissingTypeInfo
 
toString() - 类 中的方法org.apache.flink.api.java.typeutils.MultisetTypeInfo
 
toString() - 类 中的方法org.apache.flink.api.java.typeutils.ObjectArrayTypeInfo
 
toString() - 类 中的方法org.apache.flink.api.java.typeutils.PojoField
 
toString() - 类 中的方法org.apache.flink.api.java.typeutils.PojoTypeInfo.NamedFlatFieldDescriptor
 
toString() - 类 中的方法org.apache.flink.api.java.typeutils.PojoTypeInfo
 
toString() - 类 中的方法org.apache.flink.api.java.typeutils.RowTypeInfo
 
toString() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.Tuple0Serializer
 
toString() - 类 中的方法org.apache.flink.api.java.typeutils.TupleTypeInfo
 
toString() - 类 中的方法org.apache.flink.api.java.typeutils.TupleTypeInfoBase
 
toString() - 类 中的方法org.apache.flink.api.java.typeutils.ValueTypeInfo
 
toString() - 类 中的方法org.apache.flink.configuration.ConfigOption
 
toString() - 类 中的方法org.apache.flink.configuration.Configuration
 
toString() - 类 中的方法org.apache.flink.configuration.DelegatingConfiguration
 
toString() - 类 中的方法org.apache.flink.configuration.FallbackKey
 
toString() - 类 中的方法org.apache.flink.configuration.MemorySize
 
toString() - 类 中的方法org.apache.flink.core.execution.DetachedJobExecutionResult
 
toString() - 类 中的方法org.apache.flink.core.fs.ClosingFSDataInputStream
 
toString() - 类 中的方法org.apache.flink.core.fs.ClosingFSDataOutputStream
 
toString() - 类 中的方法org.apache.flink.core.fs.FileInputSplit
 
toString() - 类 中的方法org.apache.flink.core.fs.local.LocalFileStatus
 
toString() - 类 中的方法org.apache.flink.core.fs.Path
 
toString() - 类 中的方法org.apache.flink.core.fs.PluginFileSystemFactory
 
toString() - 类 中的方法org.apache.flink.core.io.GenericInputSplit
 
toString() - 类 中的方法org.apache.flink.core.io.LocatableInputSplit
 
toString() - 类 中的方法org.apache.flink.core.memory.ByteArrayOutputStreamWithPos
 
toString() - 类 中的方法org.apache.flink.core.memory.DataOutputSerializer
 
toString() - 类 中的方法org.apache.flink.core.plugin.DefaultPluginManager
 
toString() - 类 中的方法org.apache.flink.core.plugin.PluginDescriptor
 
toString() - 类 中的方法org.apache.flink.types.BooleanValue
 
toString() - 类 中的方法org.apache.flink.types.ByteValue
 
toString() - 类 中的方法org.apache.flink.types.CharValue
 
toString() - 类 中的方法org.apache.flink.types.DoubleValue
 
toString() - 类 中的方法org.apache.flink.types.Either.Left
 
toString() - 类 中的方法org.apache.flink.types.Either.Right
 
toString() - 类 中的方法org.apache.flink.types.FloatValue
 
toString() - 类 中的方法org.apache.flink.types.IntValue
 
toString() - 类 中的方法org.apache.flink.types.ListValue
 
toString() - 类 中的方法org.apache.flink.types.LongValue
 
toString() - 类 中的方法org.apache.flink.types.MapValue
 
toString() - 类 中的方法org.apache.flink.types.NullValue
 
toString() - 类 中的方法org.apache.flink.types.Row
 
toString() - 类 中的方法org.apache.flink.types.ShortValue
 
toString() - 类 中的方法org.apache.flink.types.StringValue
 
toString() - 类 中的方法org.apache.flink.util.AbstractID
 
toString() - 类 中的方法org.apache.flink.util.CompressedSerializedValue
 
toString() - 类 中的方法org.apache.flink.util.OptionalFailure
 
toString() - 类 中的方法org.apache.flink.util.OutputTag
 
toString() - 类 中的方法org.apache.flink.util.ReflectionUtil.FullTypeInfo
 
toString() - 异常错误 中的方法org.apache.flink.util.SerializedThrowable
 
toString() - 类 中的方法org.apache.flink.util.SerializedValue
 
toString() - 类 中的方法org.apache.flink.util.StringBasedID
 
TOTAL_FLINK_MEMORY - 类 中的静态变量org.apache.flink.configuration.JobManagerOptions
Total Flink Memory size for the JobManager.
TOTAL_FLINK_MEMORY - 类 中的静态变量org.apache.flink.configuration.TaskManagerOptions
Total Flink Memory size for the TaskExecutors.
TOTAL_PROCESS_MEMORY - 类 中的静态变量org.apache.flink.configuration.JobManagerOptions
Total Process Memory size for the JobManager.
TOTAL_PROCESS_MEMORY - 类 中的静态变量org.apache.flink.configuration.TaskManagerOptions
Total Process Memory size for the TaskExecutors.
toUri() - 类 中的方法org.apache.flink.core.fs.Path
Converts the path object to a URI.
toURL(Path) - 类 中的静态方法org.apache.flink.util.FileUtils
Converts the given Path into a file URL.
Transformation<T> - org.apache.flink.api.dag中的类
A Transformation represents the operation that creates a DataStream.
Transformation(String, TypeInformation<T>, int) - 类 的构造器org.apache.flink.api.dag.Transformation
Creates a new Transformation with the given name, output type and parallelism.
transformLegacySerializerSnapshot(TypeSerializerSnapshot<U>) - 接口 中的方法org.apache.flink.api.common.typeutils.LegacySerializerSnapshotTransformer
Transform a TypeSerializerSnapshot that was previously associated with this TypeSerializer.
TRANSPORT_TYPE - 类 中的静态变量org.apache.flink.configuration.NettyShuffleEnvironmentOptions
 
TraversableOnceException - 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() - 异常错误 的构造器org.apache.flink.util.TraversableOnceException
Creates a new exception with a default message.
TriConsumer<S,T,U> - org.apache.flink.util.function中的接口
Operation which is performed on three given arguments.
TriConsumerWithException<S,T,U,E extends Throwable> - org.apache.flink.util.function中的接口
A checked extension of the TriConsumer interface.
TriFunction<S,T,U,R> - org.apache.flink.util.function中的接口
Function which takes three arguments.
TriFunctionWithException<S,T,U,R,E extends Throwable> - org.apache.flink.util.function中的接口
Function which takes three arguments.
triggerSavepoint(String) - 接口 中的方法org.apache.flink.core.execution.JobClient
Triggers a savepoint for the associated job.
TRUE - 类 中的静态变量org.apache.flink.types.BooleanValue
 
tryCleanupOnError() - 接口 中的方法org.apache.flink.api.common.io.CleanupWhenUnsuccessful
Hook that is called upon an unsuccessful execution.
tryCleanupOnError() - 类 中的方法org.apache.flink.api.common.io.FileOutputFormat
 
tryDeserializeAndThrow(Throwable, ClassLoader) - 类 中的静态方法org.apache.flink.util.ExceptionUtils
Tries to find a SerializedThrowable as the cause of the given throwable and throws its deserialized value.
tryEnrichOutOfMemoryError(Throwable, String, String, String) - 类 中的静态方法org.apache.flink.util.ExceptionUtils
Tries to enrich OutOfMemoryErrors being part of the passed root Throwable's cause tree.
tryEnrichTaskManagerError(Throwable) - 类 中的静态方法org.apache.flink.util.TaskManagerExceptionUtils
Tries to enrich the passed exception or its causes with additional information.
tryReadFully(InputStream, byte[]) - 类 中的静态方法org.apache.flink.util.IOUtils
tryReadSerializer(DataInputView, ClassLoader) - 类 中的静态方法org.apache.flink.api.common.typeutils.TypeSerializerSerializationUtil
已过时。
Reads from a data input view a TypeSerializer that was previously written using TypeSerializerSerializationUtil.writeSerializer(DataOutputView, TypeSerializer).
tryReadSerializer(DataInputView, ClassLoader, boolean) - 类 中的静态方法org.apache.flink.api.common.typeutils.TypeSerializerSerializationUtil
已过时。
Reads from a data input view a TypeSerializer that was previously written using TypeSerializerSerializationUtil.writeSerializer(DataOutputView, TypeSerializer).
tryRethrowException(Exception) - 类 中的静态方法org.apache.flink.util.ExceptionUtils
Tries to throw the given exception if not null.
tryRethrowIOException(Throwable) - 类 中的静态方法org.apache.flink.util.ExceptionUtils
Tries to throw the given Throwable in scenarios where the signatures allows only IOExceptions (and RuntimeException and Error).
tryYield() - 接口 中的方法org.apache.flink.api.common.operators.MailboxExecutor
This methods attempts to run the command at the head of the mailbox.
TUPLE(TypeInformation<?>...) - 类 中的静态方法org.apache.flink.api.common.typeinfo.Types
Returns type information for subclasses of Flink's Tuple (namely Tuple0 till Tuple25) with fields of the given types.
TUPLE(Class<T>) - 类 中的静态方法org.apache.flink.api.common.typeinfo.Types
Returns type information for typed subclasses of Flink's Tuple.
Tuple - org.apache.flink.api.java.tuple中的类
The base class of all tuples.
Tuple() - 类 的构造器org.apache.flink.api.java.tuple.Tuple
 
Tuple0 - org.apache.flink.api.java.tuple中的类
A tuple with 0 fields.
Tuple0() - 类 的构造器org.apache.flink.api.java.tuple.Tuple0
 
Tuple0Builder - org.apache.flink.api.java.tuple.builder中的类
A builder class for Tuple0.
Tuple0Builder() - 类 的构造器org.apache.flink.api.java.tuple.builder.Tuple0Builder
 
Tuple0Serializer - org.apache.flink.api.java.typeutils.runtime中的类
 
Tuple0SerializerSnapshot - org.apache.flink.api.java.typeutils.runtime中的类
Tuple0SerializerSnapshot() - 类 的构造器org.apache.flink.api.java.typeutils.runtime.Tuple0SerializerSnapshot
 
Tuple1<T0> - org.apache.flink.api.java.tuple中的类
A tuple with 1 fields.
Tuple1() - 类 的构造器org.apache.flink.api.java.tuple.Tuple1
Creates a new tuple where all fields are null.
Tuple1(T0) - 类 的构造器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> - org.apache.flink.api.java.tuple中的类
A tuple with 10 fields.
Tuple10() - 类 的构造器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) - 类 的构造器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> - org.apache.flink.api.java.tuple.builder中的类
A builder class for Tuple10.
Tuple10Builder() - 类 的构造器org.apache.flink.api.java.tuple.builder.Tuple10Builder
 
Tuple11<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10> - org.apache.flink.api.java.tuple中的类
A tuple with 11 fields.
Tuple11() - 类 的构造器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) - 类 的构造器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> - org.apache.flink.api.java.tuple.builder中的类
A builder class for Tuple11.
Tuple11Builder() - 类 的构造器org.apache.flink.api.java.tuple.builder.Tuple11Builder
 
Tuple12<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11> - org.apache.flink.api.java.tuple中的类
A tuple with 12 fields.
Tuple12() - 类 的构造器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) - 类 的构造器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> - org.apache.flink.api.java.tuple.builder中的类
A builder class for Tuple12.
Tuple12Builder() - 类 的构造器org.apache.flink.api.java.tuple.builder.Tuple12Builder
 
Tuple13<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12> - org.apache.flink.api.java.tuple中的类
A tuple with 13 fields.
Tuple13() - 类 的构造器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) - 类 的构造器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> - org.apache.flink.api.java.tuple.builder中的类
A builder class for Tuple13.
Tuple13Builder() - 类 的构造器org.apache.flink.api.java.tuple.builder.Tuple13Builder
 
Tuple14<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13> - org.apache.flink.api.java.tuple中的类
A tuple with 14 fields.
Tuple14() - 类 的构造器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) - 类 的构造器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> - org.apache.flink.api.java.tuple.builder中的类
A builder class for Tuple14.
Tuple14Builder() - 类 的构造器org.apache.flink.api.java.tuple.builder.Tuple14Builder
 
Tuple15<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14> - org.apache.flink.api.java.tuple中的类
A tuple with 15 fields.
Tuple15() - 类 的构造器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) - 类 的构造器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> - org.apache.flink.api.java.tuple.builder中的类
A builder class for Tuple15.
Tuple15Builder() - 类 的构造器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> - org.apache.flink.api.java.tuple中的类
A tuple with 16 fields.
Tuple16() - 类 的构造器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) - 类 的构造器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> - org.apache.flink.api.java.tuple.builder中的类
A builder class for Tuple16.
Tuple16Builder() - 类 的构造器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> - org.apache.flink.api.java.tuple中的类
A tuple with 17 fields.
Tuple17() - 类 的构造器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) - 类 的构造器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> - org.apache.flink.api.java.tuple.builder中的类
A builder class for Tuple17.
Tuple17Builder() - 类 的构造器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> - org.apache.flink.api.java.tuple中的类
A tuple with 18 fields.
Tuple18() - 类 的构造器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) - 类 的构造器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> - org.apache.flink.api.java.tuple.builder中的类
A builder class for Tuple18.
Tuple18Builder() - 类 的构造器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> - org.apache.flink.api.java.tuple中的类
A tuple with 19 fields.
Tuple19() - 类 的构造器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) - 类 的构造器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> - org.apache.flink.api.java.tuple.builder中的类
A builder class for Tuple19.
Tuple19Builder() - 类 的构造器org.apache.flink.api.java.tuple.builder.Tuple19Builder
 
Tuple1Builder<T0> - org.apache.flink.api.java.tuple.builder中的类
A builder class for Tuple1.
Tuple1Builder() - 类 的构造器org.apache.flink.api.java.tuple.builder.Tuple1Builder
 
Tuple2<T0,T1> - org.apache.flink.api.java.tuple中的类
A tuple with 2 fields.
Tuple2() - 类 的构造器org.apache.flink.api.java.tuple.Tuple2
Creates a new tuple where all fields are null.
Tuple2(T0, T1) - 类 的构造器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> - org.apache.flink.api.java.tuple中的类
A tuple with 20 fields.
Tuple20() - 类 的构造器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) - 类 的构造器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> - org.apache.flink.api.java.tuple.builder中的类
A builder class for Tuple20.
Tuple20Builder() - 类 的构造器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> - org.apache.flink.api.java.tuple中的类
A tuple with 21 fields.
Tuple21() - 类 的构造器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) - 类 的构造器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> - org.apache.flink.api.java.tuple.builder中的类
A builder class for Tuple21.
Tuple21Builder() - 类 的构造器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> - org.apache.flink.api.java.tuple中的类
A tuple with 22 fields.
Tuple22() - 类 的构造器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) - 类 的构造器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> - org.apache.flink.api.java.tuple.builder中的类
A builder class for Tuple22.
Tuple22Builder() - 类 的构造器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> - org.apache.flink.api.java.tuple中的类
A tuple with 23 fields.
Tuple23() - 类 的构造器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) - 类 的构造器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> - org.apache.flink.api.java.tuple.builder中的类
A builder class for Tuple23.
Tuple23Builder() - 类 的构造器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> - org.apache.flink.api.java.tuple中的类
A tuple with 24 fields.
Tuple24() - 类 的构造器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) - 类 的构造器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> - org.apache.flink.api.java.tuple.builder中的类
A builder class for Tuple24.
Tuple24Builder() - 类 的构造器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> - org.apache.flink.api.java.tuple中的类
A tuple with 25 fields.
Tuple25() - 类 的构造器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) - 类 的构造器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> - org.apache.flink.api.java.tuple.builder中的类
A builder class for Tuple25.
Tuple25Builder() - 类 的构造器org.apache.flink.api.java.tuple.builder.Tuple25Builder
 
Tuple2Builder<T0,T1> - org.apache.flink.api.java.tuple.builder中的类
A builder class for Tuple2.
Tuple2Builder() - 类 的构造器org.apache.flink.api.java.tuple.builder.Tuple2Builder
 
Tuple3<T0,T1,T2> - org.apache.flink.api.java.tuple中的类
A tuple with 3 fields.
Tuple3() - 类 的构造器org.apache.flink.api.java.tuple.Tuple3
Creates a new tuple where all fields are null.
Tuple3(T0, T1, T2) - 类 的构造器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> - org.apache.flink.api.java.tuple.builder中的类
A builder class for Tuple3.
Tuple3Builder() - 类 的构造器org.apache.flink.api.java.tuple.builder.Tuple3Builder
 
Tuple4<T0,T1,T2,T3> - org.apache.flink.api.java.tuple中的类
A tuple with 4 fields.
Tuple4() - 类 的构造器org.apache.flink.api.java.tuple.Tuple4
Creates a new tuple where all fields are null.
Tuple4(T0, T1, T2, T3) - 类 的构造器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> - org.apache.flink.api.java.tuple.builder中的类
A builder class for Tuple4.
Tuple4Builder() - 类 的构造器org.apache.flink.api.java.tuple.builder.Tuple4Builder
 
Tuple5<T0,T1,T2,T3,T4> - org.apache.flink.api.java.tuple中的类
A tuple with 5 fields.
Tuple5() - 类 的构造器org.apache.flink.api.java.tuple.Tuple5
Creates a new tuple where all fields are null.
Tuple5(T0, T1, T2, T3, T4) - 类 的构造器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> - org.apache.flink.api.java.tuple.builder中的类
A builder class for Tuple5.
Tuple5Builder() - 类 的构造器org.apache.flink.api.java.tuple.builder.Tuple5Builder
 
Tuple6<T0,T1,T2,T3,T4,T5> - org.apache.flink.api.java.tuple中的类
A tuple with 6 fields.
Tuple6() - 类 的构造器org.apache.flink.api.java.tuple.Tuple6
Creates a new tuple where all fields are null.
Tuple6(T0, T1, T2, T3, T4, T5) - 类 的构造器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> - org.apache.flink.api.java.tuple.builder中的类
A builder class for Tuple6.
Tuple6Builder() - 类 的构造器org.apache.flink.api.java.tuple.builder.Tuple6Builder
 
Tuple7<T0,T1,T2,T3,T4,T5,T6> - org.apache.flink.api.java.tuple中的类
A tuple with 7 fields.
Tuple7() - 类 的构造器org.apache.flink.api.java.tuple.Tuple7
Creates a new tuple where all fields are null.
Tuple7(T0, T1, T2, T3, T4, T5, T6) - 类 的构造器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> - org.apache.flink.api.java.tuple.builder中的类
A builder class for Tuple7.
Tuple7Builder() - 类 的构造器org.apache.flink.api.java.tuple.builder.Tuple7Builder
 
Tuple8<T0,T1,T2,T3,T4,T5,T6,T7> - org.apache.flink.api.java.tuple中的类
A tuple with 8 fields.
Tuple8() - 类 的构造器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) - 类 的构造器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> - org.apache.flink.api.java.tuple.builder中的类
A builder class for Tuple8.
Tuple8Builder() - 类 的构造器org.apache.flink.api.java.tuple.builder.Tuple8Builder
 
Tuple9<T0,T1,T2,T3,T4,T5,T6,T7,T8> - org.apache.flink.api.java.tuple中的类
A tuple with 9 fields.
Tuple9() - 类 的构造器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) - 类 的构造器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> - org.apache.flink.api.java.tuple.builder中的类
A builder class for Tuple9.
Tuple9Builder() - 类 的构造器org.apache.flink.api.java.tuple.builder.Tuple9Builder
 
tupleClass - 类 中的变量org.apache.flink.api.java.typeutils.runtime.TupleSerializerBase
 
TupleComparator<T extends Tuple> - org.apache.flink.api.java.typeutils.runtime中的类
 
TupleComparator(int[], TypeComparator<?>[], TypeSerializer<?>[]) - 类 的构造器org.apache.flink.api.java.typeutils.runtime.TupleComparator
 
TupleComparatorBase<T> - org.apache.flink.api.java.typeutils.runtime中的类
 
TupleComparatorBase(int[], TypeComparator<?>[], TypeSerializer<?>[]) - 类 的构造器org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
 
TupleComparatorBase(TupleComparatorBase<T>) - 类 的构造器org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
 
TupleSerializer<T extends Tuple> - org.apache.flink.api.java.typeutils.runtime中的类
 
TupleSerializer(Class<T>, TypeSerializer<?>[]) - 类 的构造器org.apache.flink.api.java.typeutils.runtime.TupleSerializer
 
TupleSerializerBase<T> - org.apache.flink.api.java.typeutils.runtime中的类
 
TupleSerializerBase(Class<T>, TypeSerializer<?>[]) - 类 的构造器org.apache.flink.api.java.typeutils.runtime.TupleSerializerBase
 
TupleSerializerConfigSnapshot<T> - org.apache.flink.api.java.typeutils.runtime中的类
Snapshot of a tuple serializer's configuration.
TupleSerializerConfigSnapshot() - 类 的构造器org.apache.flink.api.java.typeutils.runtime.TupleSerializerConfigSnapshot
This empty nullary constructor is required for deserializing the configuration.
TupleSerializerConfigSnapshot(Class<T>, TypeSerializer<?>[]) - 类 的构造器org.apache.flink.api.java.typeutils.runtime.TupleSerializerConfigSnapshot
 
TupleSerializerSnapshot<T extends Tuple> - org.apache.flink.api.java.typeutils.runtime中的类
Snapshot of a tuple serializer's configuration.
TupleSerializerSnapshot() - 类 的构造器org.apache.flink.api.java.typeutils.runtime.TupleSerializerSnapshot
 
TupleTypeInfo<T extends Tuple> - org.apache.flink.api.java.typeutils中的类
A TypeInformation for the tuple types of the Java API.
TupleTypeInfo(TypeInformation<?>...) - 类 的构造器org.apache.flink.api.java.typeutils.TupleTypeInfo
 
TupleTypeInfo(Class<T>, TypeInformation<?>...) - 类 的构造器org.apache.flink.api.java.typeutils.TupleTypeInfo
 
TupleTypeInfoBase<T> - org.apache.flink.api.java.typeutils中的类
 
TupleTypeInfoBase(Class<T>, TypeInformation<?>...) - 类 的构造器org.apache.flink.api.java.typeutils.TupleTypeInfoBase
 
TypeComparable<T> - 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>) - 类 的构造器org.apache.flink.api.common.operators.util.TypeComparable
 
TypeComparator<T> - 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() - 类 的构造器org.apache.flink.api.common.typeutils.TypeComparator
 
TypeComparatorFactory<T> - org.apache.flink.api.common.typeutils中的接口
 
TypeExtractionException - org.apache.flink.api.java.typeutils中的异常错误
Type extraction always contains some uncertainty due to unpredictable JVM differences between vendors or versions.
TypeExtractionException() - 异常错误 的构造器org.apache.flink.api.java.typeutils.TypeExtractionException
Creates a new exception with no message.
TypeExtractionException(String) - 异常错误 的构造器org.apache.flink.api.java.typeutils.TypeExtractionException
Creates a new exception with the given message.
TypeExtractionException(String, Throwable) - 异常错误 的构造器org.apache.flink.api.java.typeutils.TypeExtractionException
Creates a new exception with the given message and cause.
TypeExtractionUtils - org.apache.flink.api.java.typeutils中的类
 
TypeExtractionUtils.LambdaExecutable - org.apache.flink.api.java.typeutils中的类
Similar to a Java 8 Executable but with a return type.
TypeExtractor - org.apache.flink.api.java.typeutils中的类
A utility for reflection analysis on classes, to determine the return type of implementations of transformation functions.
TypeExtractor() - 类 的构造器org.apache.flink.api.java.typeutils.TypeExtractor
 
TypeHint<T> - org.apache.flink.api.common.typeinfo中的类
A utility class for describing generic types.
TypeHint() - 类 的构造器org.apache.flink.api.common.typeinfo.TypeHint
Creates a hint for the generic type in the class signature.
TypeInfo - org.apache.flink.api.common.typeinfo中的注释类型
Annotation for specifying a corresponding TypeInfoFactory that can produce TypeInformation for the annotated type.
TypeInfoFactory<T> - org.apache.flink.api.common.typeinfo中的类
Base class for implementing a type information factory.
TypeInfoFactory() - 类 的构造器org.apache.flink.api.common.typeinfo.TypeInfoFactory
 
TypeInformation<T> - org.apache.flink.api.common.typeinfo中的类
TypeInformation is the core class of Flink's type system.
TypeInformation() - 类 的构造器org.apache.flink.api.common.typeinfo.TypeInformation
 
TypeInformationSerializationSchema<T> - org.apache.flink.api.common.serialization中的类
A serialization and deserialization schema that uses Flink's serialization stack to transform typed from and to byte arrays.
TypeInformationSerializationSchema(TypeInformation<T>, ExecutionConfig) - 类 的构造器org.apache.flink.api.common.serialization.TypeInformationSerializationSchema
Creates a new de-/serialization schema for the given type.
TypeInformationSerializationSchema(TypeInformation<T>, TypeSerializer<T>) - 类 的构造器org.apache.flink.api.common.serialization.TypeInformationSerializationSchema
Creates a new de-/serialization schema for the given type.
TypePairComparator<T1,T2> - org.apache.flink.api.common.typeutils中的类
This interface defines the method required by the runtime to use data types in join-like operations.
TypePairComparator() - 类 的构造器org.apache.flink.api.common.typeutils.TypePairComparator
 
TypePairComparatorFactory<T1,T2> - org.apache.flink.api.common.typeutils中的接口
 
types - 类 中的变量org.apache.flink.api.common.operators.Ordering
 
Types - org.apache.flink.api.common.typeinfo中的类
This class gives access to the type information of the most common types for which Flink has built-in serializers and comparators.
Types() - 类 的构造器org.apache.flink.api.common.typeinfo.Types
 
types - 类 中的变量org.apache.flink.api.java.typeutils.TupleTypeInfoBase
 
TypeSerializer<T> - org.apache.flink.api.common.typeutils中的类
This interface describes the methods that are required for a data type to be handled by the Flink runtime.
TypeSerializer() - 类 的构造器org.apache.flink.api.common.typeutils.TypeSerializer
 
TypeSerializerConfigSnapshot<T> - org.apache.flink.api.common.typeutils中的类
已过时。
TypeSerializerConfigSnapshot() - 类 的构造器org.apache.flink.api.common.typeutils.TypeSerializerConfigSnapshot
已过时。
 
TypeSerializerConfigSnapshot.SelfResolvingTypeSerializer<E> - org.apache.flink.api.common.typeutils中的接口
已过时。
This interface assists with the migration path to the new serialization abstraction.
TypeSerializerFactory<T> - org.apache.flink.api.common.typeutils中的接口
 
TypeSerializerSchemaCompatibility<T> - org.apache.flink.api.common.typeutils中的类
A TypeSerializerSchemaCompatibility represents information about whether or not a TypeSerializer can be safely used to read data written by a previous type serializer.
TypeSerializerSerializationProxy(ClassLoader) - 类 的构造器org.apache.flink.api.common.typeutils.TypeSerializerSerializationUtil.TypeSerializerSerializationProxy
已过时。
 
TypeSerializerSerializationProxy(TypeSerializer<T>) - 类 的构造器org.apache.flink.api.common.typeutils.TypeSerializerSerializationUtil.TypeSerializerSerializationProxy
已过时。
 
TypeSerializerSerializationUtil - org.apache.flink.api.common.typeutils中的类
已过时。
This utility class was used to write serializers into checkpoints. Starting from Flink 1.6.x, this should no longer happen, and therefore this class is deprecated. It remains here for backwards compatibility paths.
TypeSerializerSerializationUtil() - 类 的构造器org.apache.flink.api.common.typeutils.TypeSerializerSerializationUtil
已过时。
 
TypeSerializerSerializationUtil.TypeSerializerSerializationProxy<T> - org.apache.flink.api.common.typeutils中的类
已过时。
Utility serialization proxy for a TypeSerializer.
TypeSerializerSingleton<T> - org.apache.flink.api.common.typeutils.base中的类
 
TypeSerializerSingleton() - 类 的构造器org.apache.flink.api.common.typeutils.base.TypeSerializerSingleton
 
TypeSerializerSnapshot<T> - org.apache.flink.api.common.typeutils中的接口
A TypeSerializerSnapshot is a point-in-time view of a TypeSerializer's configuration.
TypeSerializerSnapshotSerializationUtil - org.apache.flink.api.common.typeutils中的类
Utility methods for serialization of TypeSerializerSnapshot.
TypeSerializerSnapshotSerializationUtil() - 类 的构造器org.apache.flink.api.common.typeutils.TypeSerializerSnapshotSerializationUtil
 
TypeSerializerUtils - org.apache.flink.api.common.typeutils中的类
Utilities for dealing with the TypeSerializer and the TypeSerializerSnapshot.
typeToClass(Type) - 类 中的静态方法org.apache.flink.api.java.typeutils.TypeExtractionUtils
Convert ParameterizedType or Class to a Class.
typeUsed - 类 中的变量org.apache.flink.api.dag.Transformation
 

U

UnaryOperatorInformation<IN,OUT> - org.apache.flink.api.common.operators中的类
A class for holding information about a single input operator, such as input/output TypeInformation.
UnaryOperatorInformation(TypeInformation<IN>, TypeInformation<OUT>) - 类 的构造器org.apache.flink.api.common.operators.UnaryOperatorInformation
 
UNCAUGHT_EXCEPTION_HANDLING - 类 中的静态变量org.apache.flink.configuration.ClusterOptions
 
uncaughtException(Thread, Throwable) - 类 中的方法org.apache.flink.util.FatalExitExceptionHandler
 
unchecked(BiConsumerWithException<A, B, ?>) - 接口 中的静态方法org.apache.flink.util.function.BiConsumerWithException
unchecked(BiFunctionWithException<A, B, C, ?>) - 接口 中的静态方法org.apache.flink.util.function.BiFunctionWithException
unchecked(CheckedSupplier<R>) - 接口 中的静态方法org.apache.flink.util.function.CheckedSupplier
 
unchecked(ThrowingRunnable<?>) - 接口 中的静态方法org.apache.flink.util.function.ThrowingRunnable
Converts a ThrowingRunnable into a Runnable which throws all checked exceptions as unchecked.
unchecked(TriConsumerWithException<A, B, C, ?>) - 接口 中的静态方法org.apache.flink.util.function.TriConsumerWithException
unchecked(TriFunctionWithException<A, B, C, D, ?>) - 接口 中的静态方法org.apache.flink.util.function.TriFunctionWithException
uncheckedConsumer(ThrowingConsumer<A, ?>) - 类 中的静态方法org.apache.flink.util.function.FunctionUtils
Converts a ThrowingConsumer into a Consumer which throws checked exceptions as unchecked.
uncheckedFunction(FunctionWithException<A, B, ?>) - 类 中的静态方法org.apache.flink.util.function.FunctionUtils
Convert at FunctionWithException into a Function.
uncheckedSupplier(SupplierWithException<T, ?>) - 类 中的静态方法org.apache.flink.util.function.FunctionUtils
Converts a SupplierWithException into a Supplier which throws all checked exceptions as unchecked.
Union<T> - org.apache.flink.api.common.operators中的类
This operator represents a Union between two inputs.
Union(BinaryOperatorInformation<T, T, T>, String) - 类 的构造器org.apache.flink.api.common.operators.Union
Creates a new Union operator.
Union(Operator<T>, Operator<T>, String) - 类 的构造器org.apache.flink.api.common.operators.Union
 
unionFields(Record) - 类 中的方法org.apache.flink.types.Record
Unions the other record's fields with this records fields.
UnionIterator<T> - org.apache.flink.util中的类
An iterator that concatenates a collection of iterators.
UnionIterator() - 类 的构造器org.apache.flink.util.UnionIterator
 
UNKNOWN - 类 中的静态变量org.apache.flink.api.common.operators.ResourceSpec
A ResourceSpec that indicates an unknown set of resources.
UnloadableDummyTypeSerializer<T> - org.apache.flink.api.common.typeutils中的类
Dummy TypeSerializer to avoid that data is lost when checkpointing again a serializer for which we encountered a ClassNotFoundException or InvalidClassException.
UnloadableDummyTypeSerializer(byte[]) - 类 的构造器org.apache.flink.api.common.typeutils.UnloadableDummyTypeSerializer
 
UnloadableDummyTypeSerializer(byte[], Throwable) - 类 的构造器org.apache.flink.api.common.typeutils.UnloadableDummyTypeSerializer
 
UnmodifiableConfiguration - org.apache.flink.configuration中的类
Unmodifiable version of the Configuration class.
UnmodifiableConfiguration(Configuration) - 类 的构造器org.apache.flink.configuration.UnmodifiableConfiguration
Creates a new UnmodifiableConfiguration, which holds a copy of the given configuration that cannot be altered.
unmonitorUserSystemExitForCurrentThread() - 类 中的静态方法org.apache.flink.core.security.FlinkSecurityManager
 
unregisterCloseable(C) - 类 中的方法org.apache.flink.util.AbstractCloseableRegistry
Removes a Closeable from the registry.
unregisterOutput(String) - 类 中的方法org.apache.flink.api.common.eventtime.WatermarkOutputMultiplexer
 
unresolvedHostAndPortToNormalizedString(String, int) - 类 中的静态方法org.apache.flink.util.NetUtils
Returns a valid address for Akka.
unresolvedHostToNormalizedString(String) - 类 中的静态方法org.apache.flink.util.NetUtils
Returns an address in a normalized format for Akka.
UNSAFE - 类 中的静态变量org.apache.flink.core.memory.MemoryUtils
The "unsafe", which can be used to perform native memory accesses.
unsplittable - 类 中的变量org.apache.flink.api.common.io.FileInputFormat
Some file input formats are not splittable on a block level (deflate) Therefore, the FileInputFormat can only read whole files.
UnsupportedFileSystemSchemeException - org.apache.flink.core.fs中的异常错误
An exception to indicate that a specific file system scheme is not supported.
UnsupportedFileSystemSchemeException(String) - 异常错误 的构造器org.apache.flink.core.fs.UnsupportedFileSystemSchemeException
Creates a new exception with the given message.
UnsupportedFileSystemSchemeException(String, Throwable) - 异常错误 的构造器org.apache.flink.core.fs.UnsupportedFileSystemSchemeException
Creates a new exception with the given message and cause.
unsupportedOperationFuture() - 类 中的静态方法org.apache.flink.util.concurrent.FutureUtils
Returns an exceptionally completed future with an UnsupportedOperationException.
unwrap() - 异常错误 中的方法org.apache.flink.util.WrappingRuntimeException
Recursively unwraps this WrappingRuntimeException and its causes, getting the first non wrapping exception.
unwrapOptionals() - 类 中的方法org.apache.flink.util.LinkedOptionalMap
Assuming all the entries of this map are present (keys and values) this method would return a map with these key and values, stripped from their Optional wrappers.
update(List<T>) - 接口 中的方法org.apache.flink.api.common.state.ListState
Updates the operator state accessible by AppendingState.get() by updating existing values to to the given list of values.
update(T) - 接口 中的方法org.apache.flink.api.common.state.ValueState
Updates the operator state accessible by ValueState.value() to the given value.
updateBinaryRepresenation() - 类 中的方法org.apache.flink.types.Record
Updates the binary representation of the data, such that it reflects the state of the currently stored fields.
updateDetailMessage(Throwable, Function<Throwable, String>) - 类 中的静态方法org.apache.flink.util.ExceptionUtils
Updates error messages of Throwables appearing in the cause tree of the passed root Throwable.
updateManagedMemoryStateBackendUseCase(boolean) - 类 中的方法org.apache.flink.api.dag.Transformation
 
updateStatus(int, boolean) - 类 中的方法org.apache.flink.api.common.eventtime.IndexedCombinedWatermarkStatus
Updates the idleness for the given partial watermark.
updateTtlOnCreateAndWrite() - 类 中的方法org.apache.flink.api.common.state.StateTtlConfig.Builder
 
updateTtlOnReadAndWrite() - 类 中的方法org.apache.flink.api.common.state.StateTtlConfig.Builder
 
updateWatermark(int, long) - 类 中的方法org.apache.flink.api.common.eventtime.IndexedCombinedWatermarkStatus
Updates the value for the given partial watermark.
UPLOAD_DIR - 类 中的静态变量org.apache.flink.configuration.WebOptions
The config parameter defining the directory for uploading the job jars.
UPPER_BOUND_MAX_PARALLELISM - 类 中的静态变量org.apache.flink.api.dag.Transformation
 
upperPart - 类 中的变量org.apache.flink.util.AbstractID
The upper part of the actual ID.
USE_BATCH_STATE_BACKEND - 类 中的静态变量org.apache.flink.configuration.ExecutionOptions
 
USE_LARGE_RECORD_HANDLER_KEY - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
USE_LARGE_RECORDS_HANDLER - 类 中的静态变量org.apache.flink.configuration.AlgorithmOptions
 
USE_LEGACY_TO_STRING - 类 中的静态变量org.apache.flink.types.RowUtils
Internal flag to enable the legacy Row.toString() implementation for tests.
useProcessingTime() - 类 中的方法org.apache.flink.api.common.state.StateTtlConfig.Builder
 
UserCodeClassLoader - org.apache.flink.util中的接口
UserCodeClassLoader allows to register release hooks for a user code class loader.
UserCodeClassWrapper<T> - org.apache.flink.api.common.operators.util中的类
This holds a class containing user defined code.
UserCodeClassWrapper(Class<? extends T>) - 类 的构造器org.apache.flink.api.common.operators.util.UserCodeClassWrapper
 
UserCodeObjectWrapper<T> - org.apache.flink.api.common.operators.util中的类
This holds an actual object containing user defined code.
UserCodeObjectWrapper(T) - 类 的构造器org.apache.flink.api.common.operators.util.UserCodeObjectWrapper
 
UserCodeWrapper<T> - org.apache.flink.api.common.operators.util中的接口
UDf operators can have either a class or an object containing the user code, this is the common interface to access them.
userFunction - 类 中的变量org.apache.flink.api.common.operators.AbstractUdfOperator
The object or class containing the user function.
UserSystemExitException - org.apache.flink.core.security中的异常错误
Indicates that user tried to exit JVM.
UserSystemExitException() - 异常错误 的构造器org.apache.flink.core.security.UserSystemExitException
 
UserSystemExitException(String) - 异常错误 的构造器org.apache.flink.core.security.UserSystemExitException
 
UserSystemExitException(String, Throwable) - 异常错误 的构造器org.apache.flink.core.security.UserSystemExitException
 

V

validate() - 类 中的方法org.apache.flink.api.common.operators.base.BulkIterationBase
 
validateCustomPartitioner(Partitioner<E>, TypeInformation<E>) - 类 中的方法org.apache.flink.api.common.operators.Keys.ExpressionKeys
 
validateCustomPartitioner(Partitioner<E>, TypeInformation<E>) - 类 中的方法org.apache.flink.api.common.operators.Keys.SelectorFunctionKeys
 
validateCustomPartitioner(Partitioner<E>, TypeInformation<E>) - 类 中的方法org.apache.flink.api.common.operators.Keys
 
validateLambdaType(Class<?>, Type) - 类 中的静态方法org.apache.flink.api.java.typeutils.TypeExtractionUtils
Checks whether the given type has the generic parameters declared in the class definition.
validateMaxParallelism(int) - 类 中的静态方法org.apache.flink.api.common.operators.util.OperatorValidationUtils
 
validateMaxParallelism(int, int) - 类 中的静态方法org.apache.flink.api.common.operators.util.OperatorValidationUtils
 
validateMaxParallelism(int, boolean) - 类 中的静态方法org.apache.flink.api.common.operators.util.OperatorValidationUtils
 
validateMaxParallelism(int, int, boolean) - 类 中的静态方法org.apache.flink.api.common.operators.util.OperatorValidationUtils
 
validateMinAndPreferredResources(ResourceSpec, ResourceSpec) - 类 中的静态方法org.apache.flink.api.common.operators.util.OperatorValidationUtils
 
validateParallelism(int) - 类 中的静态方法org.apache.flink.api.common.operators.util.OperatorValidationUtils
 
validateParallelism(int, boolean) - 类 中的静态方法org.apache.flink.api.common.operators.util.OperatorValidationUtils
 
validateResources(ResourceSpec) - 类 中的静态方法org.apache.flink.api.common.operators.util.OperatorValidationUtils
 
value() - 接口 中的方法org.apache.flink.api.common.state.ValueState
Returns the current value for the state.
VALUE(Class<V>) - 类 中的静态方法org.apache.flink.api.common.typeinfo.Types
Returns type information for Flink value types (classes that implement Value).
Value - org.apache.flink.types中的接口
Basic value interface for types that act as serializable values.
ValueComparator<T extends Value & Comparable<T>> - org.apache.flink.api.java.typeutils.runtime中的类
Comparator for all Value types that extend Key
ValueComparator(boolean, Class<T>) - 类 的构造器org.apache.flink.api.java.typeutils.runtime.ValueComparator
 
valueOf(String) - 枚举 中的静态方法org.apache.flink.api.common.BatchShuffleMode
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.api.common.CodeAnalysisMode
已过时。
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.api.common.ExecutionConfig.ClosureCleanerLevel
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.api.common.ExecutionMode
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.api.common.InputDependencyConstraint
已过时。
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.api.common.io.FileOutputFormat.OutputDirectoryMode
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.api.common.JobStatus
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.api.common.operators.base.CrossOperatorBase.CrossHint
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.api.common.operators.base.JoinOperatorBase.JoinHint
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.api.common.operators.base.OuterJoinOperatorBase.OuterJoinType
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.api.common.operators.base.PartitionOperatorBase.PartitionMethod
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.api.common.operators.base.ReduceOperatorBase.CombineHint
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.api.common.operators.Order
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.api.common.RuntimeExecutionMode
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.api.common.state.StateDescriptor.Type
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.api.common.state.StateTtlConfig.StateVisibility
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.api.common.state.StateTtlConfig.TtlTimeCharacteristic
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.api.common.state.StateTtlConfig.UpdateType
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.api.common.typeutils.CompositeTypeSerializerSnapshot.OuterSchemaCompatibility
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.api.connector.source.Boundedness
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.api.java.typeutils.runtime.KryoRegistration.SerializerDefinitionType
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.configuration.ClusterOptions.UncaughtExceptionHandleMode
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.configuration.ClusterOptions.UserSystemExitMode
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.configuration.description.TextElement.TextStyle
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.configuration.JobManagerOptions.SchedulerType
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.configuration.MemorySize.MemoryUnit
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.configuration.SchedulerExecutionMode
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.core.fs.FileSystem.WriteMode
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.core.fs.FileSystemKind
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.core.io.InputStatus
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.core.memory.ManagedMemoryUseCase.Scope
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.core.memory.ManagedMemoryUseCase
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.types.parser.FieldParser.ParseErrorState
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.types.RowKind
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.util.OperatingSystem
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.util.ProcessorArchitecture.MemoryAddressSize
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.util.ProcessorArchitecture
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.util.TernaryBoolean
返回带有指定名称的该类型的枚举常量。
values() - 枚举 中的静态方法org.apache.flink.api.common.BatchShuffleMode
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.api.common.CodeAnalysisMode
已过时。
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.api.common.ExecutionConfig.ClosureCleanerLevel
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.api.common.ExecutionMode
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.api.common.InputDependencyConstraint
已过时。
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.api.common.io.FileOutputFormat.OutputDirectoryMode
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.api.common.JobStatus
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.api.common.operators.base.CrossOperatorBase.CrossHint
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.api.common.operators.base.JoinOperatorBase.JoinHint
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.api.common.operators.base.OuterJoinOperatorBase.OuterJoinType
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.api.common.operators.base.PartitionOperatorBase.PartitionMethod
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.api.common.operators.base.ReduceOperatorBase.CombineHint
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.api.common.operators.Order
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.api.common.RuntimeExecutionMode
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 接口 中的方法org.apache.flink.api.common.state.MapState
Returns all the values in the state.
values() - 枚举 中的静态方法org.apache.flink.api.common.state.StateDescriptor.Type
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.api.common.state.StateTtlConfig.StateVisibility
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.api.common.state.StateTtlConfig.TtlTimeCharacteristic
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.api.common.state.StateTtlConfig.UpdateType
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.api.common.typeutils.CompositeTypeSerializerSnapshot.OuterSchemaCompatibility
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.api.connector.source.Boundedness
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.api.java.typeutils.runtime.KryoRegistration.SerializerDefinitionType
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.configuration.ClusterOptions.UncaughtExceptionHandleMode
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.configuration.ClusterOptions.UserSystemExitMode
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.configuration.description.TextElement.TextStyle
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.configuration.JobManagerOptions.SchedulerType
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.configuration.MemorySize.MemoryUnit
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.configuration.SchedulerExecutionMode
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.core.fs.FileSystem.WriteMode
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.core.fs.FileSystemKind
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.core.io.InputStatus
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.core.memory.ManagedMemoryUseCase.Scope
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.core.memory.ManagedMemoryUseCase
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 类 中的方法org.apache.flink.types.MapValue
 
values() - 枚举 中的静态方法org.apache.flink.types.parser.FieldParser.ParseErrorState
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.types.RowKind
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.util.OperatingSystem
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.util.ProcessorArchitecture.MemoryAddressSize
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.util.ProcessorArchitecture
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.util.TernaryBoolean
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
ValueSerializer<T extends Value> - org.apache.flink.api.java.typeutils.runtime中的类
Serializer for Value types.
ValueSerializer(Class<T>) - 类 的构造器org.apache.flink.api.java.typeutils.runtime.ValueSerializer
 
ValueSerializer.ValueSerializerConfigSnapshot<T extends Value> - org.apache.flink.api.java.typeutils.runtime中的类
已过时。
ValueSerializer.ValueSerializerSnapshot<T extends Value> - org.apache.flink.api.java.typeutils.runtime中的类
ValueSerializer snapshot class.
ValueSerializerConfigSnapshot() - 类 的构造器org.apache.flink.api.java.typeutils.runtime.ValueSerializer.ValueSerializerConfigSnapshot
已过时。
This empty nullary constructor is required for deserializing the configuration.
ValueSerializerConfigSnapshot(Class<T>) - 类 的构造器org.apache.flink.api.java.typeutils.runtime.ValueSerializer.ValueSerializerConfigSnapshot
已过时。
 
ValueSerializerSnapshot() - 类 的构造器org.apache.flink.api.java.typeutils.runtime.ValueSerializer.ValueSerializerSnapshot
 
ValueState<T> - org.apache.flink.api.common.state中的接口
State interface for partitioned single-value state.
ValueStateDescriptor<T> - org.apache.flink.api.common.state中的类
ValueStateDescriptor(String, Class<T>, T) - 类 的构造器org.apache.flink.api.common.state.ValueStateDescriptor
已过时。
Use ValueStateDescriptor.ValueStateDescriptor(String, Class) instead and manually manage the default value by checking whether the contents of the state is null.
ValueStateDescriptor(String, TypeInformation<T>, T) - 类 的构造器org.apache.flink.api.common.state.ValueStateDescriptor
已过时。
Use ValueStateDescriptor.ValueStateDescriptor(String, TypeInformation) instead and manually manage the default value by checking whether the contents of the state is null.
ValueStateDescriptor(String, TypeSerializer<T>, T) - 类 的构造器org.apache.flink.api.common.state.ValueStateDescriptor
已过时。
Use ValueStateDescriptor.ValueStateDescriptor(String, TypeSerializer) instead and manually manage the default value by checking whether the contents of the state is null.
ValueStateDescriptor(String, Class<T>) - 类 的构造器org.apache.flink.api.common.state.ValueStateDescriptor
Creates a new ValueStateDescriptor with the given name and type If this constructor fails (because it is not possible to describe the type via a class), consider using the ValueStateDescriptor.ValueStateDescriptor(String, TypeInformation) constructor.
ValueStateDescriptor(String, TypeInformation<T>) - 类 的构造器org.apache.flink.api.common.state.ValueStateDescriptor
Creates a new ValueStateDescriptor with the given name and type.
ValueStateDescriptor(String, TypeSerializer<T>) - 类 的构造器org.apache.flink.api.common.state.ValueStateDescriptor
Creates a new ValueStateDescriptor with the given name and the specific serializer.
ValueTypeInfo<T extends Value> - org.apache.flink.api.java.typeutils中的类
Type information for data types that extend the Value interface.
ValueTypeInfo(Class<T>) - 类 的构造器org.apache.flink.api.java.typeutils.ValueTypeInfo
 
Versioned - org.apache.flink.core.io中的接口
This interface is implemented by classes that provide a version number.
VersionedIOReadableWritable - org.apache.flink.core.io中的类
This is the abstract base class for IOReadableWritable which allows to differentiate between serialization versions.
VersionedIOReadableWritable() - 类 的构造器org.apache.flink.core.io.VersionedIOReadableWritable
 
VersionMismatchException - org.apache.flink.core.io中的异常错误
This exception signals that incompatible versions have been found during serialization.
VersionMismatchException() - 异常错误 的构造器org.apache.flink.core.io.VersionMismatchException
 
VersionMismatchException(String) - 异常错误 的构造器org.apache.flink.core.io.VersionMismatchException
 
VersionMismatchException(String, Throwable) - 异常错误 的构造器org.apache.flink.core.io.VersionMismatchException
 
VersionMismatchException(Throwable) - 异常错误 的构造器org.apache.flink.core.io.VersionMismatchException
 
Visitable<T extends Visitable<T>> - org.apache.flink.util中的接口
This interface marks types as visitable during a traversal.
Visitor<T extends Visitable<T>> - org.apache.flink.util中的接口
A visitor encapsulates functionality that is applied to each node in the process of a traversal of a tree or DAG.
VOID - 类 中的静态变量org.apache.flink.api.common.typeinfo.Types
Returns type information for Void.
VOID_TYPE_INFO - 类 中的静态变量org.apache.flink.api.common.typeinfo.BasicTypeInfo
 
VoidSerializer - org.apache.flink.api.common.typeutils.base中的类
Serializer for Void.
VoidSerializer() - 类 的构造器org.apache.flink.api.common.typeutils.base.VoidSerializer
 
VoidSerializer.VoidSerializerSnapshot - org.apache.flink.api.common.typeutils.base中的类
Serializer configuration snapshot for compatibility and format evolution.
VoidSerializerSnapshot() - 类 的构造器org.apache.flink.api.common.typeutils.base.VoidSerializer.VoidSerializerSnapshot
 

W

waitForAll(Collection<? extends CompletableFuture<?>>) - 类 中的静态方法org.apache.flink.util.concurrent.FutureUtils
Creates a future that is complete once all of the given futures have completed.
waitForCompletion() - 类 中的方法org.apache.flink.api.common.io.FileInputFormat.InputSplitOpenThread
 
WATCH_HEARTBEAT_INTERVAL - 类 中的静态变量org.apache.flink.configuration.AkkaOptions
已过时。
Don't use this option anymore. It has no effect on Flink.
WATCH_HEARTBEAT_PAUSE - 类 中的静态变量org.apache.flink.configuration.AkkaOptions
已过时。
Don't use this option anymore. It has no effect on Flink.
WATCH_THRESHOLD - 类 中的静态变量org.apache.flink.configuration.AkkaOptions
已过时。
Don't use this option anymore. It has no effect on Flink.
Watermark - org.apache.flink.api.common.eventtime中的类
Watermarks are the progress indicators in the data streams.
Watermark(long) - 类 的构造器org.apache.flink.api.common.eventtime.Watermark
Creates a new watermark with the given timestamp in milliseconds.
WatermarkGenerator<T> - org.apache.flink.api.common.eventtime中的接口
The WatermarkGenerator generates watermarks either based on events or periodically (in a fixed interval).
WatermarkGeneratorSupplier<T> - org.apache.flink.api.common.eventtime中的接口
A supplier for WatermarkGenerators.
WatermarkGeneratorSupplier.Context - org.apache.flink.api.common.eventtime中的接口
WatermarkOutput - org.apache.flink.api.common.eventtime中的接口
An output for watermarks.
WatermarkOutputMultiplexer - org.apache.flink.api.common.eventtime中的类
A WatermarkOutputMultiplexer combines the watermark (and idleness) updates of multiple partitions/shards/splits into one combined watermark update and forwards it to an underlying WatermarkOutput.
WatermarkOutputMultiplexer(WatermarkOutput) - 类 的构造器org.apache.flink.api.common.eventtime.WatermarkOutputMultiplexer
Creates a new WatermarkOutputMultiplexer that emits combined updates to the given WatermarkOutput.
WatermarkStrategy<T> - org.apache.flink.api.common.eventtime中的接口
The WatermarkStrategy defines how to generate Watermarks in the stream sources.
WatermarksWithIdleness<T> - org.apache.flink.api.common.eventtime中的类
A WatermarkGenerator that adds idleness detection to another WatermarkGenerator.
WatermarksWithIdleness(WatermarkGenerator<T>, Duration) - 类 的构造器org.apache.flink.api.common.eventtime.WatermarksWithIdleness
Creates a new WatermarksWithIdleness generator to the given generator idleness detection with the given timeout.
WebOptions - org.apache.flink.configuration中的类
Configuration options for the WebMonitorEndpoint.
whenCompleteAsyncIfNotDone(CompletableFuture<IN>, Executor, BiConsumer<? super IN, ? super Throwable>) - 类 中的静态方法org.apache.flink.util.concurrent.FutureUtils
This function takes a CompletableFuture and a bi-consumer to call on completion of this future.
WhitespaceTokenizer() - 类 的构造器org.apache.flink.util.StringValueUtils.WhitespaceTokenizer
Creates a new tokenizer with an undefined internal state.
withContextClassLoader(ClassLoader, ThrowingRunnable<E>) - 类 中的静态方法org.apache.flink.util.LambdaUtil
Runs the given runnable with the given ClassLoader as the thread's context class loader.
withContextClassLoader(ClassLoader, SupplierWithException<R, E>) - 类 中的静态方法org.apache.flink.util.LambdaUtil
Runs the given runnable with the given ClassLoader as the thread's context class loader.
withDeprecatedKeys(String...) - 类 中的方法org.apache.flink.configuration.ConfigOption
Creates a new config option, using this option's key and default value, and adding the given deprecated keys.
withDescription(String) - 类 中的方法org.apache.flink.configuration.ConfigOption
Creates a new config option, using this option's key and default value, and adding the given description.
withDescription(Description) - 类 中的方法org.apache.flink.configuration.ConfigOption
Creates a new config option, using this option's key and default value, and adding the given description.
withFallbackKeys(String...) - 类 中的方法org.apache.flink.configuration.ConfigOption
Creates a new config option, using this option's key and default value, and adding the given fallback keys.
withIdleness(Duration) - 接口 中的方法org.apache.flink.api.common.eventtime.WatermarkStrategy
Creates a new enriched WatermarkStrategy that also does idleness detection in the created WatermarkGenerator.
withNames(RowKind) - 类 中的静态方法org.apache.flink.types.Row
Creates a variable-length row in name-based field mode.
withNames() - 类 中的静态方法org.apache.flink.types.Row
Creates a variable-length row in name-based field mode.
withPositions(RowKind, int) - 类 中的静态方法org.apache.flink.types.Row
Creates a fixed-length row in position-based field mode.
withPositions(int) - 类 中的静态方法org.apache.flink.types.Row
Creates a fixed-length row in position-based field mode.
withTimestampAssigner(TimestampAssignerSupplier<T>) - 接口 中的方法org.apache.flink.api.common.eventtime.WatermarkStrategy
Creates a new WatermarkStrategy that wraps this strategy but instead uses the given TimestampAssigner (via a TimestampAssignerSupplier).
withTimestampAssigner(SerializableTimestampAssigner<T>) - 接口 中的方法org.apache.flink.api.common.eventtime.WatermarkStrategy
Creates a new WatermarkStrategy that wraps this strategy but instead uses the given SerializableTimestampAssigner.
WorksetPlaceHolder(DeltaIterationBase<?, WT>, OperatorInformation<WT>) - 类 的构造器org.apache.flink.api.common.operators.base.DeltaIterationBase.WorksetPlaceHolder
 
wrap(TypeSerializer<T>, boolean) - 类 中的静态方法org.apache.flink.api.java.typeutils.runtime.NullableSerializer
This method wraps the originalSerializer with the NullableSerializer if not already wrapped.
wrap(InlineElement...) - 类 中的静态方法org.apache.flink.configuration.description.TextElement
Wraps a list of InlineElements into a single TextElement.
wrap(int, int) - 类 中的方法org.apache.flink.core.memory.MemorySegment
Wraps the chunk of the underlying memory located between offset and offset + length in a NIO ByteBuffer.
wrap(byte[]) - 类 中的静态方法org.apache.flink.core.memory.MemorySegmentFactory
Creates a new memory segment that targets the given heap memory region.
wrapAsByteBuffer() - 类 中的方法org.apache.flink.core.memory.DataOutputSerializer
 
wrapCopy(byte[], int, int) - 类 中的静态方法org.apache.flink.core.memory.MemorySegmentFactory
Copies the given heap memory region and creates a new memory segment wrapping it.
wrapIfNecessary(Throwable) - 异常错误 中的静态方法org.apache.flink.util.WrappingRuntimeException
Ensures that any throwable can be thrown as a checked exception by potentially wrapping it.
wrapIfNullIsNotSupported(TypeSerializer<T>, boolean) - 类 中的静态方法org.apache.flink.api.java.typeutils.runtime.NullableSerializer
This method tries to serialize null value with the originalSerializer and wraps it in case of NullPointerException, otherwise it returns the originalSerializer.
wrapInt(int) - 类 中的静态方法org.apache.flink.core.memory.MemorySegmentFactory
Wraps the four bytes representing the given number with a MemorySegment.
wrapOffHeapMemory(ByteBuffer) - 类 中的静态方法org.apache.flink.core.memory.MemorySegmentFactory
Creates a memory segment that wraps the off-heap memory backing the given ByteBuffer.
WrappingProxy<T> - org.apache.flink.util中的接口
Interface for objects that wrap another object and proxy (possibly a subset) of the methods of that object.
WrappingProxyCloseable<T extends Closeable> - org.apache.flink.core.fs中的接口
WrappingProxy for Closeable that is also closeable.
WrappingProxyUtil - org.apache.flink.util中的类
Utilities for working with WrappingProxy.
WrappingRuntimeException - org.apache.flink.util中的异常错误
A runtime exception that is explicitly used to wrap non-runtime exceptions.
WrappingRuntimeException(Throwable) - 异常错误 的构造器org.apache.flink.util.WrappingRuntimeException
 
WrappingRuntimeException(String, Throwable) - 异常错误 的构造器org.apache.flink.util.WrappingRuntimeException
 
wrapSafe(FSDataInputStream, SafetyNetCloseableRegistry) - 类 中的静态方法org.apache.flink.core.fs.ClosingFSDataInputStream
 
wrapSafe(FSDataInputStream, SafetyNetCloseableRegistry, String) - 类 中的静态方法org.apache.flink.core.fs.ClosingFSDataInputStream
 
wrapSafe(FSDataOutputStream, SafetyNetCloseableRegistry) - 类 中的静态方法org.apache.flink.core.fs.ClosingFSDataOutputStream
 
wrapSafe(FSDataOutputStream, SafetyNetCloseableRegistry, String) - 类 中的静态方法org.apache.flink.core.fs.ClosingFSDataOutputStream
 
WritableConfig - org.apache.flink.configuration中的接口
Write access to a configuration object.
write(IN) - 类 中的方法org.apache.flink.api.common.functions.util.PrintSinkOutputWriter
 
write(byte[]) - 类 中的方法org.apache.flink.api.common.io.BinaryOutputFormat.BlockBasedOutput
 
write(byte[], int, int) - 类 中的方法org.apache.flink.api.common.io.BinaryOutputFormat.BlockBasedOutput
 
write(int) - 类 中的方法org.apache.flink.api.common.io.BinaryOutputFormat.BlockBasedOutput
 
write(DataOutputView) - 类 中的方法org.apache.flink.api.common.io.BlockInfo
 
write(DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.EnumSerializer.EnumSerializerConfigSnapshot
已过时。
 
write(DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.CompositeTypeSerializerConfigSnapshot
 
write(DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.GenericTypeSerializerConfigSnapshot
 
write(DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.ParameterlessTypeSerializerConfig
已过时。
 
write(DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.TypeSerializerSerializationUtil.TypeSerializerSerializationProxy
已过时。
 
write(InputT, SinkWriter.Context) - 接口 中的方法org.apache.flink.api.connector.sink.SinkWriter
Add an element to the writer.
write(int) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.DataOutputViewStream
 
write(byte[], int, int) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.DataOutputViewStream
 
write(Kryo, Output, T) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.kryo.JavaSerializer
 
write(Kryo, Output, Object) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.kryo.Serializers.DummyAvroKryoSerializerClass
 
write(Kryo, Output, Object) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.KryoRegistrationSerializerConfigSnapshot.DummyKryoSerializerClass
 
write(DataOutputView) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.KryoRegistrationSerializerConfigSnapshot
 
write(DataOutputView) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.PojoSerializer.PojoSerializerConfigSnapshot
已过时。
 
write(DataOutputView) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.TupleSerializerConfigSnapshot
 
write(DataOutputView) - 类 中的方法org.apache.flink.configuration.Configuration
 
write(DataOutputView) - 类 中的方法org.apache.flink.configuration.DelegatingConfiguration
 
write(int) - 类 中的方法org.apache.flink.core.fs.FSDataOutputStreamWrapper
 
write(byte[]) - 类 中的方法org.apache.flink.core.fs.FSDataOutputStreamWrapper
 
write(byte[], int, int) - 类 中的方法org.apache.flink.core.fs.FSDataOutputStreamWrapper
 
write(int) - 类 中的方法org.apache.flink.core.fs.local.LocalDataOutputStream
 
write(byte[], int, int) - 类 中的方法org.apache.flink.core.fs.local.LocalDataOutputStream
 
write(DataOutputView) - 类 中的方法org.apache.flink.core.fs.Path
 
write(DataOutputView) - 接口 中的方法org.apache.flink.core.io.IOReadableWritable
Writes the object's internal data to the given data output view.
write(DataOutputView) - 类 中的方法org.apache.flink.core.io.PostVersionedIOReadableWritable
 
write(DataOutputView) - 类 中的方法org.apache.flink.core.io.VersionedIOReadableWritable
 
write(int) - 类 中的方法org.apache.flink.core.memory.ByteArrayOutputStreamWithPos
 
write(byte[], int, int) - 类 中的方法org.apache.flink.core.memory.ByteArrayOutputStreamWithPos
 
write(int) - 类 中的方法org.apache.flink.core.memory.DataOutputSerializer
 
write(byte[]) - 类 中的方法org.apache.flink.core.memory.DataOutputSerializer
 
write(byte[], int, int) - 类 中的方法org.apache.flink.core.memory.DataOutputSerializer
 
write(MemorySegment, int, int) - 类 中的方法org.apache.flink.core.memory.DataOutputSerializer
 
write(DataInputView, int) - 类 中的方法org.apache.flink.core.memory.DataOutputSerializer
 
write(DataInputView, int) - 接口 中的方法org.apache.flink.core.memory.DataOutputView
Copies numBytes bytes from the source to this view.
write(DataInputView, int) - 类 中的方法org.apache.flink.core.memory.DataOutputViewStreamWrapper
 
write(MemorySegment, int, int) - 接口 中的方法org.apache.flink.core.memory.MemorySegmentWritable
Writes len bytes from memory segment segment starting at offset off, in order, to the output.
write(DataOutputView) - 类 中的方法org.apache.flink.types.BooleanValue
 
write(DataOutputView) - 类 中的方法org.apache.flink.types.ByteValue
 
write(DataOutputView) - 类 中的方法org.apache.flink.types.CharValue
 
write(DataOutputView) - 类 中的方法org.apache.flink.types.DoubleValue
 
write(DataOutputView) - 类 中的方法org.apache.flink.types.FloatValue
 
write(DataOutputView) - 类 中的方法org.apache.flink.types.IntValue
 
write(DataOutputView) - 类 中的方法org.apache.flink.types.ListValue
 
write(DataOutputView) - 类 中的方法org.apache.flink.types.LongValue
 
write(DataOutputView) - 类 中的方法org.apache.flink.types.MapValue
 
write(DataOutputView) - 类 中的方法org.apache.flink.types.NullValue
 
write(DataOutputView) - 类 中的方法org.apache.flink.types.Record
 
write(DataOutputView) - 类 中的方法org.apache.flink.types.ShortValue
 
write(DataOutputView) - 类 中的方法org.apache.flink.types.StringValue
 
writeBigInteger(BigInteger, DataOutputView) - 类 中的静态方法org.apache.flink.api.common.typeutils.base.BigIntSerializer
 
writeBoolean(boolean) - 类 中的方法org.apache.flink.core.memory.DataOutputSerializer
 
writeByte(int) - 类 中的方法org.apache.flink.core.memory.DataOutputSerializer
 
writeBytes(String) - 类 中的方法org.apache.flink.core.memory.DataOutputSerializer
 
writeChar(int) - 类 中的方法org.apache.flink.core.memory.DataOutputSerializer
 
writeChars(String) - 类 中的方法org.apache.flink.core.memory.DataOutputSerializer
 
writeCompletely(WritableByteChannel, ByteBuffer) - 类 中的静态方法org.apache.flink.util.FileUtils
 
writeDouble(double) - 类 中的方法org.apache.flink.core.memory.DataOutputSerializer
 
writeFile(File, String, String) - 类 中的静态方法org.apache.flink.util.FileUtils
 
writeFileInfoToConfig(String, DistributedCache.DistributedCacheEntry, Configuration) - 类 中的静态方法org.apache.flink.api.common.cache.DistributedCache
 
writeFileUtf8(File, String) - 类 中的静态方法org.apache.flink.util.FileUtils
 
writeFloat(float) - 类 中的方法org.apache.flink.core.memory.DataOutputSerializer
 
writeInt(int) - 类 中的方法org.apache.flink.core.memory.DataOutputSerializer
 
writeIntUnsafe(int, int) - 类 中的方法org.apache.flink.core.memory.DataOutputSerializer
 
writeLong(long) - 类 中的方法org.apache.flink.core.memory.DataOutputSerializer
 
writeMask(boolean[], DataOutputView) - 类 中的静态方法org.apache.flink.api.java.typeutils.runtime.MaskUtils
 
writeMask(boolean[], int, DataOutputView) - 类 中的静态方法org.apache.flink.api.java.typeutils.runtime.MaskUtils
 
writeNestedSerializerSnapshots(DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.NestedSerializersSnapshotDelegate
Writes the composite snapshot of all the contained serializers.
writeNullableString(String, DataOutputView) - 类 中的静态方法org.apache.flink.util.StringUtils
Writes a String to the given output.
writeObjectToConfig(Object, Configuration, String) - 类 中的静态方法org.apache.flink.util.InstantiationUtil
 
writeOptionalMap(DataOutputView, LinkedOptionalMap<K, V>, BiConsumerWithException<DataOutputView, K, IOException>, BiConsumerWithException<DataOutputView, V, IOException>) - 类 中的静态方法org.apache.flink.util.LinkedOptionalMapSerializer
 
writeOuterSnapshot(DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.GenericArraySerializerSnapshot
 
writeOuterSnapshot(DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.CompositeTypeSerializerSnapshot
Writes the outer snapshot, i.e. any information beyond the nested serializers of the outer serializer.
writeOuterSnapshot(DataOutputView) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.NullableSerializer.NullableSerializerSnapshot
 
writeOuterSnapshot(DataOutputView) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.RowSerializer.RowSerializerSnapshot
 
writeOuterSnapshot(DataOutputView) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.TupleSerializerSnapshot
 
writeParametersToConfig(Configuration) - 接口 中的方法org.apache.flink.api.common.typeutils.TypeComparatorFactory
 
writeParametersToConfig(Configuration) - 接口 中的方法org.apache.flink.api.common.typeutils.TypeSerializerFactory
 
writeParametersToConfig(Configuration) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.RuntimeComparatorFactory
 
writeParametersToConfig(Configuration) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.RuntimeSerializerFactory
 
writeRecord(T) - 类 中的方法org.apache.flink.api.common.io.BinaryOutputFormat
 
writeRecord(IT) - 接口 中的方法org.apache.flink.api.common.io.OutputFormat
Adds a record to the output.
writeSerializer(DataOutputView, TypeSerializer<T>) - 类 中的静态方法org.apache.flink.api.common.typeutils.TypeSerializerSerializationUtil
已过时。
Writes a TypeSerializer to the provided data output view.
writeSerializersAndConfigsWithResilience(DataOutputView, List<Tuple2<TypeSerializer<?>, TypeSerializerSnapshot<?>>>) - 类 中的静态方法org.apache.flink.api.common.typeutils.TypeSerializerSerializationUtil
已过时。
Write a list of serializers and their corresponding config snapshots to the provided data output view.
writeSerializerSnapshot(DataOutputView, TypeSerializerSnapshot<T>, TypeSerializer<T>) - 类 中的静态方法org.apache.flink.api.common.typeutils.TypeSerializerSnapshotSerializationUtil
Writes a TypeSerializerSnapshot to the provided data output view.
writeShort(int) - 类 中的方法org.apache.flink.core.memory.DataOutputSerializer
 
writeSnapshot(DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.BackwardsCompatibleSerializerSnapshot
 
writeSnapshot(DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.EnumSerializer.EnumSerializerSnapshot
 
writeSnapshot(DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.GenericArraySerializerConfigSnapshot
已过时。
 
writeSnapshot(DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.CompositeTypeSerializerSnapshot
 
writeSnapshot(DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.GenericTypeSerializerSnapshot
 
writeSnapshot(DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.SimpleTypeSerializerSnapshot
 
writeSnapshot(DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.TypeSerializerConfigSnapshot
已过时。
 
writeSnapshot(DataOutputView) - 接口 中的方法org.apache.flink.api.common.typeutils.TypeSerializerSnapshot
Writes the serializer snapshot to the provided DataOutputView.
writeSnapshot(DataOutputView) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.EitherSerializerSnapshot
已过时。
 
writeSnapshot(DataOutputView) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializerSnapshot
 
writeSnapshot(DataOutputView) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.PojoSerializerSnapshot
 
writeString(CharSequence, DataOutput) - 类 中的静态方法org.apache.flink.types.StringValue
 
writeString(String, DataOutputView) - 类 中的静态方法org.apache.flink.util.StringUtils
Writes a String to the given output.
writeUTF(String) - 类 中的方法org.apache.flink.core.memory.DataOutputSerializer
 
writeVersionAndSerialize(SimpleVersionedSerializer<T>, T, DataOutputView) - 类 中的静态方法org.apache.flink.core.io.SimpleVersionedSerialization
Serializes the version and datum into a stream.
writeVersionAndSerialize(SimpleVersionedSerializer<T>, T) - 类 中的静态方法org.apache.flink.core.io.SimpleVersionedSerialization
Serializes the version and datum into a byte array.
writeVersionedSnapshot(DataOutputView, TypeSerializerSnapshot<?>) - 接口 中的静态方法org.apache.flink.api.common.typeutils.TypeSerializerSnapshot
Writes the given snapshot to the out stream.
writeWatermark(Watermark) - 接口 中的方法org.apache.flink.api.connector.sink.SinkWriter
Add a watermark to the writer.
writeWithKeyNormalization(T, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.array.PrimitiveArrayComparator
 
writeWithKeyNormalization(T, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.BasicTypeComparator
 
writeWithKeyNormalization(BooleanValue, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.BooleanValueComparator
 
writeWithKeyNormalization(ByteValue, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.ByteValueComparator
 
writeWithKeyNormalization(CharValue, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.CharValueComparator
 
writeWithKeyNormalization(DoubleValue, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.DoubleValueComparator
 
writeWithKeyNormalization(FloatValue, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.FloatValueComparator
 
writeWithKeyNormalization(IntValue, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.IntValueComparator
 
writeWithKeyNormalization(LocalDate, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.LocalDateComparator
 
writeWithKeyNormalization(LocalDateTime, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.LocalDateTimeComparator
 
writeWithKeyNormalization(LongValue, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.LongValueComparator
 
writeWithKeyNormalization(NullValue, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.NullValueComparator
 
writeWithKeyNormalization(ShortValue, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.ShortValueComparator
 
writeWithKeyNormalization(StringValue, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.base.StringValueComparator
 
writeWithKeyNormalization(T, DataOutputView) - 类 中的方法org.apache.flink.api.common.typeutils.TypeComparator
Writes the record in such a fashion that all keys are normalizing and at the beginning of the serialized data.
writeWithKeyNormalization(T, DataOutputView) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.CopyableValueComparator
 
writeWithKeyNormalization(T, DataOutputView) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.GenericTypeComparator
 
writeWithKeyNormalization(T, DataOutputView) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.NullAwareComparator
 
writeWithKeyNormalization(T, DataOutputView) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.PojoComparator
 
writeWithKeyNormalization(Row, DataOutputView) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.RowComparator
 
writeWithKeyNormalization(T, DataOutputView) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
 
writeWithKeyNormalization(T, DataOutputView) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.ValueComparator
 

X

XORShiftRandom - org.apache.flink.util中的类
Implement a random number generator based on the XORShift algorithm discovered by George Marsaglia.
XORShiftRandom() - 类 的构造器org.apache.flink.util.XORShiftRandom
 
XORShiftRandom(long) - 类 的构造器org.apache.flink.util.XORShiftRandom
 
XZInputStreamFactory - org.apache.flink.api.common.io.compression中的类
Factory for XZ decompressors.
XZInputStreamFactory() - 类 的构造器org.apache.flink.api.common.io.compression.XZInputStreamFactory
 

Y

YARN_APPLICATION_ATTEMPTS - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
in favor of YarnConfigOptions#APPLICATION_ATTEMPTS.
YARN_APPLICATION_MASTER_ENV_PREFIX - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
Please use CONTAINERIZED_MASTER_ENV_PREFIX.
YARN_APPLICATION_MASTER_PORT - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
in favor of YarnConfigOptions#APPLICATION_MASTER_PORT.
YARN_APPLICATION_TAGS - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
in favor of YarnConfigOptions#APPLICATION_TAGS.
YARN_CONTAINER_START_COMMAND_TEMPLATE - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
Template for the YARN container start invocation.
YARN_HEAP_CUTOFF_MIN - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
Not used anymore, but remain here until Flink 2.0
YARN_HEAP_CUTOFF_RATIO - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
Not used anymore, but remain here until Flink 2.0
YARN_HEARTBEAT_DELAY_SECONDS - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
in favor of YarnConfigOptions#HEARTBEAT_DELAY_SECONDS.
YARN_MAX_FAILED_CONTAINERS - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
in favor of YarnConfigOptions#MAX_FAILED_CONTAINERS.
YARN_PROPERTIES_FILE_LOCATION - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
in favor of YarnConfigOptions#PROPERTIES_FILE_LOCATION.
YARN_REALLOCATE_FAILED_CONTAINERS - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
Not used anymore
YARN_TASK_MANAGER_ENV_PREFIX - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
Please use CONTAINERIZED_TASK_MANAGER_ENV_PREFIX.
YARN_VCORES - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
in favor of YarnConfigOptions#VCORES.
yield() - 接口 中的方法org.apache.flink.api.common.operators.MailboxExecutor
This methods starts running the command at the head of the mailbox and is intended to be used by the mailbox thread to yield from a currently ongoing action to another command.

Z

ZERO - 类 中的静态变量org.apache.flink.api.common.operators.ResourceSpec
A ResourceSpec that indicates zero amount of resources.
ZERO - 类 中的静态变量org.apache.flink.configuration.MemorySize
 
ZOOKEEPER_CHECKPOINT_COUNTER_PATH - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
ZOOKEEPER_CHECKPOINTS_PATH - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
ZOOKEEPER_CLIENT_ACL - 类 中的静态变量org.apache.flink.configuration.HighAvailabilityOptions
 
ZOOKEEPER_CONNECTION_TIMEOUT - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
ZOOKEEPER_CONNECTION_TIMEOUT - 类 中的静态变量org.apache.flink.configuration.HighAvailabilityOptions
 
ZOOKEEPER_DIR_KEY - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
Deprecated in favour of ConfigConstants.HA_ZOOKEEPER_DIR_KEY.
ZOOKEEPER_JOBGRAPHS_PATH - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
ZOOKEEPER_LATCH_PATH - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
ZOOKEEPER_LEADER_PATH - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
ZOOKEEPER_MAX_RETRY_ATTEMPTS - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
ZOOKEEPER_MAX_RETRY_ATTEMPTS - 类 中的静态变量org.apache.flink.configuration.HighAvailabilityOptions
 
ZOOKEEPER_MESOS_WORKERS_PATH - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
has no effect
ZOOKEEPER_NAMESPACE_KEY - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
ZOOKEEPER_QUORUM_KEY - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
ZOOKEEPER_RECOVERY_PATH - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
ZOOKEEPER_RETRY_WAIT - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
ZOOKEEPER_RETRY_WAIT - 类 中的静态变量org.apache.flink.configuration.HighAvailabilityOptions
 
ZOOKEEPER_RUNNING_JOB_REGISTRY_PATH - 类 中的静态变量org.apache.flink.configuration.HighAvailabilityOptions
 
ZOOKEEPER_SASL_DISABLE - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
ZOOKEEPER_SASL_DISABLE - 类 中的静态变量org.apache.flink.configuration.SecurityOptions
 
ZOOKEEPER_SASL_LOGIN_CONTEXT_NAME - 类 中的静态变量org.apache.flink.configuration.SecurityOptions
 
ZOOKEEPER_SASL_SERVICE_NAME - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
ZOOKEEPER_SASL_SERVICE_NAME - 类 中的静态变量org.apache.flink.configuration.SecurityOptions
 
ZOOKEEPER_SESSION_TIMEOUT - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
已过时。
ZOOKEEPER_SESSION_TIMEOUT - 类 中的静态变量org.apache.flink.configuration.HighAvailabilityOptions
 
ZOOKEEPER_TOLERATE_SUSPENDED_CONNECTIONS - 类 中的静态变量org.apache.flink.configuration.HighAvailabilityOptions
 
ZStandardInputStreamFactory - org.apache.flink.api.common.io.compression中的类
Factory for ZStandard decompressors.
ZStandardInputStreamFactory() - 类 的构造器org.apache.flink.api.common.io.compression.ZStandardInputStreamFactory
 
A B C D E F G H I J K L M N O P Q R S T U V W X Y Z 
跳过导航链接

Copyright © 2014–2022 The Apache Software Foundation. All rights reserved.