- absentKeysOrValues() - 类 中的方法org.apache.flink.util.LinkedOptionalMap
-
Returns the key names of any keys or values that are absent.
- 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, ClassLoader, ExecutionConfig, Map<String, Accumulator<?, ?>>, Map<String, Future<Path>>, MetricGroup) - 类 的构造器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(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(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
-
- 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中的类
-
- 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
-
- 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
-
- add(double) - 类 中的方法org.apache.flink.api.common.accumulators.DoubleCounter
-
- add(Double) - 类 中的方法org.apache.flink.api.common.accumulators.DoubleMaximum
-
- add(double) - 类 中的方法org.apache.flink.api.common.accumulators.DoubleMaximum
-
- add(Double) - 类 中的方法org.apache.flink.api.common.accumulators.DoubleMinimum
-
- 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
-
- add(int) - 类 中的方法org.apache.flink.api.common.accumulators.IntCounter
-
- add(Integer) - 类 中的方法org.apache.flink.api.common.accumulators.IntMaximum
-
- add(int) - 类 中的方法org.apache.flink.api.common.accumulators.IntMaximum
-
- add(Integer) - 类 中的方法org.apache.flink.api.common.accumulators.IntMinimum
-
- 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
-
- add(long) - 类 中的方法org.apache.flink.api.common.accumulators.LongCounter
-
- add(Long) - 类 中的方法org.apache.flink.api.common.accumulators.LongMaximum
-
- add(long) - 类 中的方法org.apache.flink.api.common.accumulators.LongMaximum
-
- add(Long) - 类 中的方法org.apache.flink.api.common.accumulators.LongMinimum
-
- 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.ReadableConfigToConfigurationAdapter
-
- addAll(Configuration, String) - 类 中的方法org.apache.flink.configuration.ReadableConfigToConfigurationAdapter
-
- 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.ReadableConfigToConfigurationAdapter
-
- 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
-
- addFirstInputs(List<Operator<IN1>>) - 类 中的方法org.apache.flink.api.common.operators.DualInputOperator
-
- 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
-
- addInput(Operator<IN>...) - 类 中的方法org.apache.flink.api.common.operators.SingleInputOperator
-
- addInput(List<Operator<IN>>) - 类 中的方法org.apache.flink.api.common.operators.SingleInputOperator
-
- addInputs(List<? extends Operator<IN>>) - 类 中的方法org.apache.flink.api.common.operators.GenericDataSinkBase
-
- addList(List<T>) - 类 中的方法org.apache.flink.util.UnionIterator
-
- 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
-
已过时。
- address - 类 中的变量org.apache.flink.core.memory.MemorySegment
-
The address to the data, relative to the heap memory byte array.
- addressLimit - 类 中的变量org.apache.flink.core.memory.MemorySegment
-
The address one byte after the last addressable byte, i.e.
- addSecondInput(Operator<IN2>...) - 类 中的方法org.apache.flink.api.common.operators.DualInputOperator
-
- addSecondInputs(List<Operator<IN2>>) - 类 中的方法org.apache.flink.api.common.operators.DualInputOperator
-
- 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.
- 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
- 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中的接口
-
- AggregatingStateDescriptor<IN,ACC,OUT> - org.apache.flink.api.common.state中的类
-
- 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中的类
-
- 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
-
- 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
-
- AKKA_TRANSPORT_HEARTBEAT_PAUSE - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
-
- AKKA_TRANSPORT_THRESHOLD - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
-
- AKKA_WATCH_HEARTBEAT_INTERVAL - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
-
- AKKA_WATCH_HEARTBEAT_PAUSE - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
-
- AKKA_WATCH_THRESHOLD - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
-
- 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, Object) - 类 中的静态方法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, Object) - 类 中的方法org.apache.flink.core.memory.HeapMemorySegment.HeapMemorySegmentFactory
-
Allocates some unpooled 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.
- 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(Class<OUT>, ArrayList<Type>, ParameterizedType, 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) - 接口 中的方法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
-
- 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, 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
-
This method calls
Object.toString()
on the given object, unless the
object is an array.
- arrayToString(Object) - 类 中的静态方法org.apache.flink.util.StringUtils
-
Returns a string representation of the given array.
- 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
-
- 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
-
- ASK_TIMEOUT - 类 中的静态变量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.
- ASYNC_SNAPSHOTS - 类 中的静态变量org.apache.flink.configuration.CheckpointingOptions
-
Option whether the state backend should use an asynchronous snapshot method where
possible and configurable.
- 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.
- 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.
- cancel() - 接口 中的方法org.apache.flink.core.execution.JobClient
-
Cancels the associated job.
- cancel(boolean) - 类 中的方法org.apache.flink.util.concurrent.NeverCompleteFuture
-
- 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
-
- 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
-
- 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
).
- 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中的接口
-
- 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.
- 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.
- CheckpointableInputFormat<S extends InputSplit,T extends Serializable> - org.apache.flink.api.common.io中的接口
-
An interface that describes
InputFormat
s 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
-
- 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
).
- 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[]) - 类 的构造器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.
- cleanupInBackground() - 类 中的方法org.apache.flink.api.common.state.StateTtlConfig.Builder
-
- cleanupIncrementally(int, boolean) - 类 中的方法org.apache.flink.api.common.state.StateTtlConfig.Builder
-
Cleanup expired state incrementally cleanup local state.
- cleanupInRocksdbCompactFilter() - 类 中的方法org.apache.flink.api.common.state.StateTtlConfig.Builder
-
- 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中的接口
-
OutputFormat
s 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.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
-
Timeout for all blocking calls on the client side.
- 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() - 类 中的方法org.apache.flink.configuration.ReadableConfigToConfigurationAdapter
-
- 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.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.TemporaryClassLoaderContext
-
- 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
-
- 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中的接口
-
- CloseableIterator.IteratorAdapter<E> - org.apache.flink.util中的类
-
- 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(Iterable<? extends AutoCloseable>) - 类 中的静态方法org.apache.flink.util.IOUtils
-
Closes all
AutoCloseable
objects in the parameter, suppressing exceptions.
- 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.
- closeForCommit() - 类 中的方法org.apache.flink.core.fs.RecoverableFsDataOutputStream
-
- 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
-
- closeStream(Closeable) - 类 中的静态方法org.apache.flink.util.IOUtils
-
- 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中的类
-
- ClosingFSDataOutputStream - org.apache.flink.core.fs中的类
-
- 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_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
-
- code(String) - 类 中的静态方法org.apache.flink.configuration.description.TextElement
-
Creates a block of text formatted as code.
- CodeAnalysisMode - org.apache.flink.api.common中的枚举
-
- 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.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中的类
-
- 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
-
- 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() - 接口 中的方法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.
- 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
-
- compareAgainstReference(Comparable[]) - 类 中的方法org.apache.flink.api.common.typeutils.TypeComparator
-
- 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(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.
- 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
-
- 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中的类
-
- 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中的类
-
- 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.
- 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
-
- 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 '.
- 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.ListConfigOptionBuilder<T> - org.apache.flink.configuration中的类
-
- ConfigOptions.OptionBuilder - org.apache.flink.configuration中的类
-
- ConfigOptions.TypedConfigOptionBuilder<T> - org.apache.flink.configuration中的类
-
- 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中的类
-
- 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.
- 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中的类
-
- 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
-
- CONTAINERIZED_HEAP_CUTOFF_MIN - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
-
- CONTAINERIZED_HEAP_CUTOFF_MIN - 类 中的静态变量org.apache.flink.configuration.ResourceManagerOptions
-
Minimum amount of heap memory to remove in Job Master containers, as a safety margin.
- CONTAINERIZED_HEAP_CUTOFF_RATIO - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
-
- CONTAINERIZED_HEAP_CUTOFF_RATIO - 类 中的静态变量org.apache.flink.configuration.ResourceManagerOptions
-
Percentage of heap space to remove from Job Master containers (YARN / Mesos/ Kubernetes), to compensate
for other JVM memory usage.
- 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(ConfigOption<?>) - 类 中的方法org.apache.flink.configuration.ReadableConfigToConfigurationAdapter
-
- 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(String) - 类 中的方法org.apache.flink.configuration.ReadableConfigToConfigurationAdapter
-
- 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
-
- 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() - 类 中的方法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 copied from another row.
- 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中的类
-
- 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
-
- create(InputStream) - 类 中的方法org.apache.flink.api.common.io.compression.XZInputStreamFactory
-
- create(BigDecimal) - 类 中的方法org.apache.flink.api.common.resources.CPUResource
-
- create(BigDecimal) - 类 中的方法org.apache.flink.api.common.resources.GPUResource
-
- 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
-
- 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(Object, Runnable) - 枚举 中的静态方法org.apache.flink.util.JavaGcCleanerWrapper
-
- 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
-
- 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
-
- 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
-
- 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.
- createFrom(CheckedSupplier<T>) - 类 中的静态方法org.apache.flink.util.OptionalFailure
-
- 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
-
Creates the different splits of the input that can be processed in parallel.
- 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
-
- 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
-
- 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
-
- createRecoverableWriter() - 类 中的方法org.apache.flink.core.fs.FileSystem
-
- createRecoverableWriter() - 类 中的方法org.apache.flink.core.fs.local.LocalFileSystem
-
- createRecoverableWriter() - 类 中的方法org.apache.flink.core.fs.SafetyNetWrapperFileSystem
-
- 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.
- 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
-
- 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
-
- 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.
- currentSplit - 类 中的变量org.apache.flink.api.common.io.FileInputFormat
-
The current split that this parallel instance must consume.
- 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中的类
-
- DataInputViewStream(DataInputView) - 类 的构造器org.apache.flink.api.java.typeutils.runtime.DataInputViewStream
-
- DataInputViewStreamWrapper - org.apache.flink.core.memory中的类
-
- 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中的类
-
- 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中的类
-
- DEBUG_MEMORY_LOG - 类 中的静态变量org.apache.flink.configuration.TaskManagerOptions
-
- DEBUG_MEMORY_USAGE_LOG_INTERVAL_MS - 类 中的静态变量org.apache.flink.configuration.TaskManagerOptions
-
- decodeListFromConfig(ReadableConfig, ConfigOption<List<IN>>, Function<IN, OUT>) - 类 中的静态方法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.
- 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
-
- 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
-
- DEFAULT_AKKA_TRANSPORT_HEARTBEAT_PAUSE - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
-
- DEFAULT_AKKA_TRANSPORT_THRESHOLD - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
-
- DEFAULT_AKKA_WATCH_THRESHOLD - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
-
- 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
-
- 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
-
- DEFAULT_HA_MODE - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
-
- 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
-
- DEFAULT_JOB_MANAGER_WEB_CHECKPOINTS_HISTORY_SIZE - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
-
- DEFAULT_JOB_MANAGER_WEB_FRONTEND_ADDRESS - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
-
- DEFAULT_JOB_MANAGER_WEB_FRONTEND_PORT - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
-
- 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_MANAGED_MEMORY_WEIGHT - 类 中的静态变量org.apache.flink.api.dag.Transformation
-
- DEFAULT_MEMORY_MANAGER_MEMORY_FRACTION - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
-
- DEFAULT_MESOS_ARTIFACT_SERVER_PORT - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
-
- DEFAULT_MESOS_ARTIFACT_SERVER_SSL_ENABLED - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
-
- DEFAULT_MESOS_FAILOVER_TIMEOUT_SECS - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
-
- DEFAULT_MESOS_RESOURCEMANAGER_FRAMEWORK_NAME - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
-
- DEFAULT_MESOS_RESOURCEMANAGER_FRAMEWORK_ROLE - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
-
- DEFAULT_MESOS_RESOURCEMANAGER_FRAMEWORK_USER - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
-
- 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
-
- 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
-
- DEFAULT_TASK_MANAGER_MEMORY_SEGMENT_SIZE - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
-
- DEFAULT_TASK_MANAGER_NETWORK_DEFAULT_IO_MODE - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
-
- 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
-
- DEFAULT_USE_LARGE_RECORD_HANDLER - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
-
Whether to use the LargeRecordHandler when spilling.
- DEFAULT_YARN_APPLICATION_MASTER_PORT - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
-
- 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
-
- DEFAULT_YARN_HEAP_CUTOFF_RATIO - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
-
- DEFAULT_YARN_JOB_MANAGER_PORT - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
-
- DEFAULT_YARN_MIN_HEAP_CUTOFF - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
-
- DEFAULT_ZOOKEEPER_CHECKPOINT_COUNTER_PATH - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
-
- DEFAULT_ZOOKEEPER_CHECKPOINTS_PATH - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
-
- DEFAULT_ZOOKEEPER_CLIENT_PORT - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
-
- 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
-
- DEFAULT_ZOOKEEPER_JOBGRAPHS_PATH - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
-
- DEFAULT_ZOOKEEPER_LATCH_PATH - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
-
- DEFAULT_ZOOKEEPER_LEADER_PATH - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
-
- DEFAULT_ZOOKEEPER_LEADER_PORT - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
-
- DEFAULT_ZOOKEEPER_MAX_RETRY_ATTEMPTS - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
-
- DEFAULT_ZOOKEEPER_MESOS_WORKERS_PATH - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
-
- DEFAULT_ZOOKEEPER_NAMESPACE_KEY - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
-
- DEFAULT_ZOOKEEPER_PEER_PORT - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
-
- 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
-
- DefaultExecutorServiceLoader - org.apache.flink.core.execution中的类
-
- DefaultInputSplitAssigner - org.apache.flink.api.common.io中的类
-
- 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.
- defaultValue - 类 中的变量org.apache.flink.api.common.state.StateDescriptor
-
The default value returned by the state when no other value is bound to a key.
- 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
-
- defaultValue(T) - 类 中的方法org.apache.flink.configuration.ConfigOptions.TypedConfigOptionBuilder
-
Creates a ConfigOption with the given default value.
- defaultValues(T...) - 类 中的方法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
-
- 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.
- 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中的类
-
- DeploymentOptions() - 类 的构造器org.apache.flink.configuration.DeploymentOptions
-
- deprecatedKeys() - 类 中的方法org.apache.flink.configuration.ConfigOption
-
- depth() - 类 中的方法org.apache.flink.core.fs.Path
-
Returns the number of elements in this path.
- description() - 类 中的方法org.apache.flink.configuration.ConfigOption
-
Returns the description of this option.
- Description - org.apache.flink.configuration.description中的类
-
- Description.DescriptionBuilder - org.apache.flink.configuration.description中的类
-
- DescriptionBuilder() - 类 的构造器org.apache.flink.configuration.description.Description.DescriptionBuilder
-
- 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.
- 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[]) - 类 中的方法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.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.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
-
- 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
-
- 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.
- disableSysoutLogging() - 类 中的方法org.apache.flink.api.common.ExecutionConfig
-
- 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中的类
-
- 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
-
- 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中的类
-
- 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中的类
-
- 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
-
- 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.
- 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.
- FACTORY - 类 中的静态变量org.apache.flink.core.memory.HeapMemorySegment
-
- 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
-
- 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中的类
-
- 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中的类
-
- 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
-
- 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
OutputFormat
s 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.
- findThrowableWithMessage(Throwable, String) - 类 中的静态方法org.apache.flink.util.ExceptionUtils
-
Checks whether a throwable chain contains a specific error message and returns the corresponding throwable.
- 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.
- 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
-
- 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
-
- FLINK_BASE_DIR_PATH_KEY - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
-
- 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_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_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中的接口
-
- 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.
- 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中的类
-
- 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
-
- fold(T, O) - 接口 中的方法org.apache.flink.api.common.functions.FoldFunction
-
已过时。
The core method of FoldFunction, combining two values into one value of the same type.
- fold(T, O) - 类 中的方法org.apache.flink.api.common.functions.RichFoldFunction
-
已过时。
- FoldFunction<O,T> - org.apache.flink.api.common.functions中的接口
-
- FoldingState<T,ACC> - org.apache.flink.api.common.state中的接口
-
- FoldingStateDescriptor<T,ACC> - org.apache.flink.api.common.state中的类
-
- FoldingStateDescriptor(String, ACC, FoldFunction<T, ACC>, Class<ACC>) - 类 的构造器org.apache.flink.api.common.state.FoldingStateDescriptor
-
已过时。
Creates a new FoldingStateDescriptor
with the given name, type, and initial value.
- FoldingStateDescriptor(String, ACC, FoldFunction<T, ACC>, TypeInformation<ACC>) - 类 的构造器org.apache.flink.api.common.state.FoldingStateDescriptor
-
已过时。
Creates a new FoldingStateDescriptor
with the given name and default value.
- FoldingStateDescriptor(String, ACC, FoldFunction<T, ACC>, TypeSerializer<ACC>) - 类 的构造器org.apache.flink.api.common.state.FoldingStateDescriptor
-
已过时。
Creates a new ValueStateDescriptor
with the given name and default value.
- FORCE_AVRO - 类 中的静态变量org.apache.flink.configuration.PipelineOptions
-
- FORCE_KRYO - 类 中的静态变量org.apache.flink.configuration.PipelineOptions
-
- FORCE_PARTITION_RELEASE_ON_CONSUMPTION - 类 中的静态变量org.apache.flink.configuration.NettyShuffleEnvironmentOptions
-
- forEach(LinkedOptionalMap.ConsumerWithException<K, V, E>) - 类 中的方法org.apache.flink.util.LinkedOptionalMap
-
- forEachRemaining(Consumer<? super E>) - 类 中的方法org.apache.flink.util.CloseableIterator.IteratorAdapter
-
- 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
-
- 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.HeapMemorySegment
-
- free() - 类 中的方法org.apache.flink.core.memory.HybridMemorySegment
-
- free() - 类 中的方法org.apache.flink.core.memory.MemorySegment
-
Frees this memory segment.
- fromBoolean(boolean) - 枚举 中的静态方法org.apache.flink.util.TernaryBoolean
-
- 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.SerializedValue
-
- 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
-
- fromHexString(String) - 类 中的静态方法org.apache.flink.api.common.JobID
-
Parses a JobID from the given string.
- fromJobSubmissionResult(JobSubmissionResult) - 类 中的静态方法org.apache.flink.api.common.JobExecutionResult
-
- fromLocalFile(File) - 类 中的静态方法org.apache.flink.core.fs.Path
-
Creates a path for the given local file.
- fromNow(Duration) - 类 中的静态方法org.apache.flink.api.common.time.Deadline
-
Constructs a Deadline that is a given duration after now.
- 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中的类
-
- 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中的类
-
- 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中的接口
-
- 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中的类
-
- 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中的类
-
- 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.
- 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中的类
-
- 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
-
- get(ConfigOption<T>) - 类 中的方法org.apache.flink.configuration.ReadableConfigToConfigurationAdapter
-
- 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.HeapMemorySegment
-
- get(int, byte[]) - 类 中的方法org.apache.flink.core.memory.HeapMemorySegment
-
- get(int, byte[], int, int) - 类 中的方法org.apache.flink.core.memory.HeapMemorySegment
-
- get(DataOutput, int, int) - 类 中的方法org.apache.flink.core.memory.HeapMemorySegment
-
- get(int, ByteBuffer, int) - 类 中的方法org.apache.flink.core.memory.HeapMemorySegment
-
- get(int) - 类 中的方法org.apache.flink.core.memory.HybridMemorySegment
-
- get(int, byte[]) - 类 中的方法org.apache.flink.core.memory.HybridMemorySegment
-
- get(int, byte[], int, int) - 类 中的方法org.apache.flink.core.memory.HybridMemorySegment
-
- get(DataOutput, int, int) - 类 中的方法org.apache.flink.core.memory.HybridMemorySegment
-
- get(int, ByteBuffer, int) - 类 中的方法org.apache.flink.core.memory.HybridMemorySegment
-
- 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.MemoryArchitecture
-
Gets the processor architecture of this process.
- 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(ClassLoader) - 接口 中的方法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.
- 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
-
- getAllAccumulators() - 接口 中的方法org.apache.flink.api.common.functions.RuntimeContext
-
- getAllAccumulators() - 类 中的方法org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
-
- 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
-
- getAlwaysParentFirstPatterns() - 类 中的方法org.apache.flink.core.plugin.PluginConfig
-
- 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
-
Get the number of fields in the Row.
- getArray() - 类 中的方法org.apache.flink.core.memory.HeapMemorySegment
-
Gets the byte array that backs this memory segment.
- 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.
- 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.
- 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(ConfigOption<Boolean>) - 类 中的方法org.apache.flink.configuration.ReadableConfigToConfigurationAdapter
-
- getBoolean(ConfigOption<Boolean>, boolean) - 类 中的方法org.apache.flink.configuration.ReadableConfigToConfigurationAdapter
-
- getBoolean(String, boolean) - 类 中的方法org.apache.flink.configuration.ReadableConfigToConfigurationAdapter
-
- getBoolean(int) - 类 中的方法org.apache.flink.core.memory.HeapMemorySegment
-
- getBoolean(int) - 类 中的方法org.apache.flink.core.memory.HybridMemorySegment
-
- 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.
- 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
-
- 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
-
- getByteArray() - 类 中的方法org.apache.flink.util.SerializedValue
-
Returns the serialized value or null
if no value is set.
- 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(String, byte[]) - 类 中的方法org.apache.flink.configuration.ReadableConfigToConfigurationAdapter
-
- 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
-
- getClass(String, Class<? extends T>, ClassLoader) - 类 中的方法org.apache.flink.configuration.ReadableConfigToConfigurationAdapter
-
- 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
-
- getCodeAnalysisMode() - 类 中的方法org.apache.flink.api.common.ExecutionConfig
-
- 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.
- 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.
- 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
-
- 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
-
- 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
-
- 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.
- 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
-
- 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
-
- 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
-
Gets the default input dependency constraint for vertex scheduling.
- 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.
- 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.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.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.
- 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(ConfigOption<Double>) - 类 中的方法org.apache.flink.configuration.ReadableConfigToConfigurationAdapter
-
- getDouble(ConfigOption<Double>, double) - 类 中的方法org.apache.flink.configuration.ReadableConfigToConfigurationAdapter
-
- getDouble(String, double) - 类 中的方法org.apache.flink.configuration.ReadableConfigToConfigurationAdapter
-
- 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
-
- getEnum(Class<T>, ConfigOption<String>) - 类 中的方法org.apache.flink.configuration.ReadableConfigToConfigurationAdapter
-
- getErrorState() - 类 中的方法org.apache.flink.types.parser.FieldParser
-
- getExecutionConfig() - 接口 中的方法org.apache.flink.api.common.functions.RuntimeContext
-
- 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
-
- getExecutor(Configuration) - 接口 中的方法org.apache.flink.core.execution.PipelineExecutorFactory
-
- getExecutorFactory(Configuration) - 类 中的方法org.apache.flink.core.execution.DefaultExecutorServiceLoader
-
- getExecutorFactory(Configuration) - 接口 中的方法org.apache.flink.core.execution.PipelineExecutorServiceLoader
-
- 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.
- getExtendedResources() - 类 中的方法org.apache.flink.api.common.operators.ResourceSpec
-
- 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
-
Gets the field at the specified position.
- 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
-
- 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.RowTypeInfo
-
Returns the field types of the row.
- getFile(String) - 类 中的方法org.apache.flink.api.common.cache.DistributedCache
-
- getFile() - 类 中的方法org.apache.flink.core.fs.local.LocalFileStatus
-
- 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
-
- 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(ConfigOption<Float>) - 类 中的方法org.apache.flink.configuration.ReadableConfigToConfigurationAdapter
-
- getFloat(ConfigOption<Float>, float) - 类 中的方法org.apache.flink.configuration.ReadableConfigToConfigurationAdapter
-
- getFloat(String, float) - 类 中的方法org.apache.flink.configuration.ReadableConfigToConfigurationAdapter
-
- 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.
- getFoldFunction() - 类 中的方法org.apache.flink.api.common.state.FoldingStateDescriptor
-
已过时。
Returns the fold function to be used for the folding state.
- getFoldingState(FoldingStateDescriptor<T, ACC>) - 接口 中的方法org.apache.flink.api.common.functions.RuntimeContext
-
- getFoldingState(FoldingStateDescriptor<T, ACC>) - 类 中的方法org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
-
已过时。
- getFoldingState(FoldingStateDescriptor<T, ACC>) - 接口 中的方法org.apache.flink.api.common.state.KeyedStateStore
-
- getFoldReturnTypes(FoldFunction<IN, OUT>, TypeInformation<IN>) - 类 中的静态方法org.apache.flink.api.java.typeutils.TypeExtractor
-
- getFoldReturnTypes(FoldFunction<IN, OUT>, TypeInformation<IN>, String, boolean) - 类 中的静态方法org.apache.flink.api.java.typeutils.TypeExtractor
-
- 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
-
- 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
-
- 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).
- getGlobalJobParameters() - 类 中的方法org.apache.flink.api.common.ArchivedExecutionConfig
-
- getGlobalJobParameters() - 类 中的方法org.apache.flink.api.common.ExecutionConfig
-
- getGPUResource() - 类 中的方法org.apache.flink.api.common.operators.ResourceSpec
-
- 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
-
- getIncrementalCleanupStrategy() - 类 中的方法org.apache.flink.api.common.state.StateTtlConfig.CleanupStrategies
-
- 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
-
- getInfoSize() - 类 中的方法org.apache.flink.api.common.io.BlockInfo
-
- 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
-
- 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
-
Gets the type of the input splits that are processed by this input format.
- 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.typeutils.base.NullValueComparator
-
- getInstance() - 类 中的静态方法org.apache.flink.types.NullValue
-
Returns the NullValue singleton instance.
- 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
-
- 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
-
- getInteger(ConfigOption<Integer>) - 类 中的方法org.apache.flink.configuration.ReadableConfigToConfigurationAdapter
-
- getInteger(ConfigOption<Integer>, int) - 类 中的方法org.apache.flink.configuration.ReadableConfigToConfigurationAdapter
-
- getInteger(String, int) - 类 中的方法org.apache.flink.configuration.ReadableConfigToConfigurationAdapter
-
- 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.
- getJarFiles(String[]) - 类 中的静态方法org.apache.flink.util.JarUtils
-
- 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(ClassLoader) - 接口 中的方法org.apache.flink.core.execution.JobClient
-
- 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.
- getJobManagerHeapMemory(Configuration) - 类 中的静态方法org.apache.flink.configuration.ConfigurationUtils
-
Get job manager's heap memory.
- 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
-
- 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
-
Gets a description of the characteristics of this file system.
- getKind() - 类 中的方法org.apache.flink.core.fs.LimitedConnectionsFileSystem
-
- getKind() - 类 中的方法org.apache.flink.core.fs.local.LocalFileSystem
-
- getKind() - 类 中的方法org.apache.flink.core.fs.SafetyNetWrapperFileSystem
-
- 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
-
- 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.
- 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
-
- 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(ConfigOption<Long>) - 类 中的方法org.apache.flink.configuration.ReadableConfigToConfigurationAdapter
-
- getLong(ConfigOption<Long>, long) - 类 中的方法org.apache.flink.configuration.ReadableConfigToConfigurationAdapter
-
- getLong(String, long) - 类 中的方法org.apache.flink.configuration.ReadableConfigToConfigurationAdapter
-
- 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.
- getManagedMemory() - 类 中的方法org.apache.flink.api.common.operators.ResourceSpec
-
- getManagedMemoryWeight() - 类 中的方法org.apache.flink.api.dag.Transformation
-
Get the managed memory weight which indicates how much this transformation relies
on managed memory, so that a transformation highly relies on managed memory would
be able to acquire more managed memory in runtime (linear association).
- 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.
- 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.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).
- getMerged() - 类 中的方法org.apache.flink.util.LinkedOptionalMap.MergeResult
-
- 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
-
- 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.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
-
- 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
-
- 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.
- 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.
- getNumLineSamples() - 类 中的方法org.apache.flink.api.common.io.DelimitedInputFormat
-
- getNumSplits() - 类 中的方法org.apache.flink.api.common.io.FileInputFormat
-
- getObjectReuseEnabled() - 类 中的方法org.apache.flink.api.common.ArchivedExecutionConfig
-
- getOffHeapBuffer() - 类 中的方法org.apache.flink.core.memory.HybridMemorySegment
-
Gets the buffer that owns the memory of this memory segment.
- 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.
- getOperatorState(ListStateDescriptor<S>) - 接口 中的方法org.apache.flink.api.common.state.OperatorStateStore
-
- getOptional(ConfigOption<T>) - 类 中的方法org.apache.flink.configuration.Configuration
-
- getOptional(ConfigOption<T>) - 类 中的方法org.apache.flink.configuration.DelegatingConfiguration
-
- getOptional(ConfigOption<T>) - 接口 中的方法org.apache.flink.configuration.ReadableConfig
-
- getOptional(ConfigOption<T>) - 类 中的方法org.apache.flink.configuration.ReadableConfigToConfigurationAdapter
-
- 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
-
- 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
-
- 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.
- getPresentEntries() - 类 中的方法org.apache.flink.util.LinkedOptionalMap
-
- getPreviousIterationAggregate(String) - 接口 中的方法org.apache.flink.api.common.functions.IterationRuntimeContext
-
- 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.java.typeutils.ResultTypeQueryable
-
Gets the data type (as a
TypeInformation
) produced by this function or input format.
- 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.
- 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
-
- getResource(String) - 类 中的方法org.apache.flink.util.ChildFirstClassLoader
-
- 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
-
- 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.
- 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 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
-
- 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
-
- getSerializableListState(String) - 接口 中的方法org.apache.flink.api.common.state.OperatorStateStore
-
- 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.
- getSlotSharingGroup() - 类 中的方法org.apache.flink.api.dag.Transformation
-
Returns the slot sharing group of this transformation.
- 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
-
- 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
-
- getString(ConfigOption<String>) - 类 中的方法org.apache.flink.configuration.ReadableConfigToConfigurationAdapter
-
- getString(ConfigOption<String>, String) - 类 中的方法org.apache.flink.configuration.ReadableConfigToConfigurationAdapter
-
- getString(String, String) - 类 中的方法org.apache.flink.configuration.ReadableConfigToConfigurationAdapter
-
- getStringInMillis(Duration) - 类 中的静态方法org.apache.flink.util.TimeUtils
-
- getStyles() - 类 中的方法org.apache.flink.configuration.description.TextElement
-
- 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.
- 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
-
- 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
-
- getTaskNameWithSubtasks() - 类 中的方法org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
-
- getTaskNameWithSubtasks() - 类 中的方法org.apache.flink.api.common.TaskInfo
-
- getTaskOffHeapMemory() - 类 中的方法org.apache.flink.api.common.operators.ResourceSpec
-
- 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
-
- 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 Transformation
s 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.FoldingStateDescriptor
-
已过时。
- 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.
- 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
-
- 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.typeutils.TypeSerializerConfigSnapshot
-
已过时。
Returns the user code class loader.
- 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(ConfigOption<?>) - 类 中的方法org.apache.flink.configuration.ReadableConfigToConfigurationAdapter
-
- 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.
- 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
-
- GLOBAL_JOB_PARAMETERS - 类 中的静态变量org.apache.flink.configuration.PipelineOptions
-
- 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
- GPUResource - org.apache.flink.api.common.resources中的类
-
The GPU resource.
- GPUResource(double) - 类 的构造器org.apache.flink.api.common.resources.GPUResource
-
- gracefulShutdown(long, TimeUnit, ExecutorService...) - 类 中的静态方法org.apache.flink.util.ExecutorUtils
-
- 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中的类
-
- 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
-
- 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.
- 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中的接口
-
- inFullSnapshot() - 类 中的方法org.apache.flink.api.common.state.StateTtlConfig.CleanupStrategies
-
- initDefaultsFromConfiguration(Configuration) - 类 中的静态方法org.apache.flink.api.common.io.FileOutputFormat
-
Initialize defaults for output format.
- INITIAL_REGISTRATION_BACKOFF - 类 中的静态变量org.apache.flink.configuration.TaskManagerOptions
-
The initial registration backoff between two consecutive registration attempts.
- 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
OutputFormat
s 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.
- 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中的枚举
-
This constraint indicates when a task should be scheduled considering its inputs status.
- 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
InputSplit
s 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中的接口
-
- inputStream - 类 中的变量org.apache.flink.core.fs.FSDataInputStreamWrapper
-
- InputStreamFSInputWrapper - org.apache.flink.api.common.io中的类
-
- 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中的接口
-
OutputFormat
s 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.core.execution.DefaultExecutorServiceLoader
-
- INSTANT - 类 中的静态变量org.apache.flink.api.common.typeinfo.Types
-
Returns type infomation 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
-
- 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.
- isAutoTypeRegistrationDisabled() - 类 中的方法org.apache.flink.api.common.ExecutionConfig
-
- 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
-
- isClassFile(Path) - 类 中的静态方法org.apache.flink.util.FileUtils
-
Checks whether the given file has a class extension.
- 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
-
- 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
.
- 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.
- isExactMatch(FieldList) - 类 中的方法org.apache.flink.api.common.operators.util.FieldList
-
- isExecutable - 类 中的变量org.apache.flink.api.common.cache.DistributedCache.DistributedCacheEntry
-
- isFailTaskOnCheckpointError() - 类 中的方法org.apache.flink.api.common.ExecutionConfig
-
- isFailure() - 类 中的方法org.apache.flink.util.OptionalFailure
-
- 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.
- 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
-
- 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
.
- 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
-
- isLatencyTrackingEnabled() - 类 中的方法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(GenericArraySerializer<C>) - 类 中的方法org.apache.flink.api.common.typeutils.base.GenericArraySerializerSnapshot
-
- isOuterSnapshotCompatible(S) - 类 中的方法org.apache.flink.api.common.typeutils.CompositeTypeSerializerSnapshot
-
Checks whether the outer snapshot is compatible with a given new serializer.
- isOuterSnapshotCompatible(NullableSerializer<T>) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.NullableSerializer.NullableSerializerSnapshot
-
- isOverdue() - 类 中的方法org.apache.flink.api.common.time.Deadline
-
Determines whether the deadline is in the past, i.e. whether the time left is 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.
- 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
-
- isSysoutLoggingEnabled() - 类 中的方法org.apache.flink.api.common.ExecutionConfig
-
- 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.
- isZipped - 类 中的变量org.apache.flink.api.common.cache.DistributedCache.DistributedCacheEntry
-
- IterableIterator<E> - org.apache.flink.util中的接口
-
- 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
-
- 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中的类
-
- 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
-
- 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
-
- parseLocalStateDirectories(Configuration) - 类 中的静态方法org.apache.flink.configuration.ConfigurationUtils
-
- parseRecord(Object[], byte[], int, int) - 类 中的方法org.apache.flink.api.common.io.GenericCsvInputFormat
-
- parseTempDirectories(Configuration) - 类 中的静态方法org.apache.flink.configuration.ConfigurationUtils
-
- parseTmResourceDynamicConfigs(String) - 类 中的静态方法org.apache.flink.configuration.ConfigurationUtils
-
- parseTmResourceJvmParams(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中的类
-
- 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
-
- 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.
- PipelineExecutor - org.apache.flink.core.execution中的接口
-
The entity responsible for executing a
Pipeline
, i.e. a user job.
- PipelineExecutorFactory - org.apache.flink.core.execution中的接口
-
- 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中的类
-
- PipelineOptions() - 类 的构造器org.apache.flink.configuration.PipelineOptions
-
- 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中的类
-
- 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中的类
-
- PluginLoader(ClassLoader) - 类 的构造器org.apache.flink.core.plugin.PluginLoader
-
- PluginManager - org.apache.flink.core.plugin中的类
-
Manager class and entry-point for the plugin mechanism in Flink.
- PluginManager(Collection<PluginDescriptor>, String[]) - 类 的构造器org.apache.flink.core.plugin.PluginManager
-
- PluginManager(Collection<PluginDescriptor>, ClassLoader, String[]) - 类 的构造器org.apache.flink.core.plugin.PluginManager
-
- 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
-
- PojoSerializer.PojoSerializerConfigSnapshot<T> - org.apache.flink.api.java.typeutils.runtime中的类
-
- 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中的类
-
- 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中的类
-
- 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
-
- PostVersionedIOReadableWritable - org.apache.flink.core.io中的类
-
- 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.
- 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中的类
-
- 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
-
- 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 from another row.
- project(Collection<I>, Function<I, O>) - 类 中的静态方法org.apache.flink.util.CollectionUtil
-
- projectFields(RowTypeInfo, int[]) - 类 中的静态方法org.apache.flink.api.java.typeutils.RowTypeInfo
-
- 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.
- pruneBuffer() - 类 中的方法org.apache.flink.core.memory.DataOutputSerializer
-
- 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.HeapMemorySegment
-
- put(int, byte[]) - 类 中的方法org.apache.flink.core.memory.HeapMemorySegment
-
- put(int, byte[], int, int) - 类 中的方法org.apache.flink.core.memory.HeapMemorySegment
-
- put(DataInput, int, int) - 类 中的方法org.apache.flink.core.memory.HeapMemorySegment
-
- put(int, ByteBuffer, int) - 类 中的方法org.apache.flink.core.memory.HeapMemorySegment
-
- put(int, byte) - 类 中的方法org.apache.flink.core.memory.HybridMemorySegment
-
- put(int, byte[]) - 类 中的方法org.apache.flink.core.memory.HybridMemorySegment
-
- put(int, byte[], int, int) - 类 中的方法org.apache.flink.core.memory.HybridMemorySegment
-
- put(DataInput, int, int) - 类 中的方法org.apache.flink.core.memory.HybridMemorySegment
-
- put(int, ByteBuffer, int) - 类 中的方法org.apache.flink.core.memory.HybridMemorySegment
-
- 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.HeapMemorySegment
-
- putBoolean(int, boolean) - 类 中的方法org.apache.flink.core.memory.HybridMemorySegment
-
- 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
-
- 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(DataInputView) - 类 中的方法org.apache.flink.configuration.ReadableConfigToConfigurationAdapter
-
- 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
-
- 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.
- ReadableConfigToConfigurationAdapter - org.apache.flink.configuration中的类
-
- ReadableConfigToConfigurationAdapter(ReadableConfig) - 类 的构造器org.apache.flink.configuration.ReadableConfigToConfigurationAdapter
-
- 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
-
- 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
-
- readIntoAndCopyNullMask(int, DataInputView, DataOutputView, boolean[]) - 类 中的静态方法org.apache.flink.api.java.typeutils.runtime.NullMaskUtils
-
- readIntoNullMask(int, DataInputView, boolean[]) - 类 中的静态方法org.apache.flink.api.java.typeutils.runtime.NullMaskUtils
-
- 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中的接口
-
- 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.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
-
已过时。
- 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
-
- 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
-
- 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.
- 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中的接口
-
- 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
-
- RECOVERY_JOB_MANAGER_PORT - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
-
- RECOVERY_MODE - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
-
- 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
-
- recycleMemorySegments(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.
- 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
-
The backoff after a registration has been refused by the job manager before retrying to connect.
- 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
-
- registerInflaterInputStreamFactory(String, InflaterInputStreamFactory<?>) - 类 中的静态方法org.apache.flink.api.common.io.FileInputFormat
-
- registerKryoType(Class<?>) - 类 中的方法org.apache.flink.api.common.ExecutionConfig
-
Registers the given type with the serialization stack.
- registerPojoType(Class<?>) - 类 中的方法org.apache.flink.api.common.ExecutionConfig
-
Registers the given type with the serialization stack.
- 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
- REGISTRATION_MAX_BACKOFF - 类 中的静态变量org.apache.flink.configuration.TaskManagerOptions
-
The maximum registration backoff between two consecutive registration attempts.
- REGISTRATION_TIMEOUT - 类 中的静态变量org.apache.flink.configuration.TaskManagerOptions
-
Defines the timeout it can take for the TaskManager registration.
- relativizePath(Path, Path) - 类 中的静态方法org.apache.flink.util.FileUtils
-
Relativize the given path with respect to the given base path if it is absolute.
- releaseArrays() - 类 中的方法org.apache.flink.core.memory.DataInputDeserializer
-
- 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.ReadableConfigToConfigurationAdapter
-
- 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.
- requestMemorySegments() - 接口 中的方法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
-
- 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
-
已过时。
- 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 - 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
-
- 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中的类
-
- 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中的类
-
- RESTART_STRATEGY - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
-
- RESTART_STRATEGY - 类 中的静态变量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.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
-
- 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.
- 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).
- 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.
- 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中的类
-
- RichAggregateFunction() - 类 的构造器org.apache.flink.api.common.functions.RichAggregateFunction
-
- RichCoGroupFunction<IN1,IN2,OUT> - org.apache.flink.api.common.functions中的类
-
- RichCoGroupFunction() - 类 的构造器org.apache.flink.api.common.functions.RichCoGroupFunction
-
- RichCrossFunction<IN1,IN2,OUT> - org.apache.flink.api.common.functions中的类
-
- RichCrossFunction() - 类 的构造器org.apache.flink.api.common.functions.RichCrossFunction
-
- RichFilterFunction<T> - org.apache.flink.api.common.functions中的类
-
- RichFilterFunction() - 类 的构造器org.apache.flink.api.common.functions.RichFilterFunction
-
- RichFlatJoinFunction<IN1,IN2,OUT> - org.apache.flink.api.common.functions中的类
-
- RichFlatJoinFunction() - 类 的构造器org.apache.flink.api.common.functions.RichFlatJoinFunction
-
- RichFlatMapFunction<IN,OUT> - org.apache.flink.api.common.functions中的类
-
- RichFlatMapFunction() - 类 的构造器org.apache.flink.api.common.functions.RichFlatMapFunction
-
- RichFoldFunction<O,T> - org.apache.flink.api.common.functions中的类
-
- RichFoldFunction() - 类 的构造器org.apache.flink.api.common.functions.RichFoldFunction
-
已过时。
- 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中的类
-
- RichGroupCombineFunction() - 类 的构造器org.apache.flink.api.common.functions.RichGroupCombineFunction
-
- RichGroupReduceFunction<IN,OUT> - org.apache.flink.api.common.functions中的类
-
- 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中的类
-
- RichJoinFunction() - 类 的构造器org.apache.flink.api.common.functions.RichJoinFunction
-
- RichMapFunction<IN,OUT> - org.apache.flink.api.common.functions中的类
-
- RichMapFunction() - 类 的构造器org.apache.flink.api.common.functions.RichMapFunction
-
- RichMapPartitionFunction<I,O> - org.apache.flink.api.common.functions中的类
-
- 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中的类
-
- 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 can have arbitrary number of fields and contain a set of fields, which may all be
different types.
- Row(int) - 类 的构造器org.apache.flink.types.Row
-
Create a new Row instance.
- 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中的类
-
- RowComparator(int, int[], TypeComparator<Object>[], TypeSerializer<Object>[], boolean[]) - 类 的构造器org.apache.flink.api.java.typeutils.runtime.RowComparator
-
General constructor for RowComparator.
- RowSerializer - org.apache.flink.api.java.typeutils.runtime中的类
-
- RowSerializer(TypeSerializer<?>[]) - 类 的构造器org.apache.flink.api.java.typeutils.runtime.RowSerializer
-
- RowSerializer.RowSerializerConfigSnapshot - org.apache.flink.api.java.typeutils.runtime中的类
-
- RowSerializer.RowSerializerSnapshot - org.apache.flink.api.java.typeutils.runtime中的类
-
- 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
-
- 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.
- runCleanupForEveryRecord() - 类 中的方法org.apache.flink.api.common.state.StateTtlConfig.IncrementalCleanupStrategy
-
- 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
-
- 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.
- 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<?, ?>>, MetricGroup) - 类 的构造器org.apache.flink.api.common.functions.util.RuntimeUDFContext
-
- SafetyNetCloseableRegistry - org.apache.flink.core.fs中的类
-
- SafetyNetWrapperFileSystem - org.apache.flink.core.fs中的类
-
- 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
-
- SCHEDULER - 类 中的静态变量org.apache.flink.configuration.JobManagerOptions
-
Config parameter determining the scheduler implementation.
- schemaEquals(Object) - 类 中的方法org.apache.flink.api.java.typeutils.RowTypeInfo
-
Tests whether an other object describes the same, schema-equivalent row information.
- 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_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中的接口
-
- SeekableDataOutputView - org.apache.flink.core.memory中的接口
-
- 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
-
- 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).
- 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中的类
-
- SerializableSerializer(T) - 类 的构造器org.apache.flink.api.common.ExecutionConfig.SerializableSerializer
-
- SerializationSchema<T> - org.apache.flink.api.common.serialization中的接口
-
The serialization schema describes how to turn a data object into a different serialized
representation.
- 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(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(T) - 类 的构造器org.apache.flink.util.SerializedValue
-
- 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
-
- 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.ReadableConfigToConfigurationAdapter
-
- 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
-
- setBoolean(String, boolean) - 类 中的方法org.apache.flink.configuration.ReadableConfigToConfigurationAdapter
-
- setBoolean(ConfigOption<Boolean>, boolean) - 类 中的方法org.apache.flink.configuration.ReadableConfigToConfigurationAdapter
-
- 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
-
- setBytes(String, byte[]) - 类 中的方法org.apache.flink.configuration.ReadableConfigToConfigurationAdapter
-
- 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
-
- setClass(String, Class<?>) - 类 中的方法org.apache.flink.configuration.ReadableConfigToConfigurationAdapter
-
- setClosureCleanerLevel(ExecutionConfig.ClosureCleanerLevel) - 类 中的方法org.apache.flink.api.common.ExecutionConfig
-
Configures the closure cleaner.
- setCodeAnalysisMode(CodeAnalysisMode) - 类 中的方法org.apache.flink.api.common.ExecutionConfig
-
- 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
-
- 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
-
Sets the default input dependency constraint for vertex scheduling.
- 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
-
- setDouble(String, double) - 类 中的方法org.apache.flink.configuration.ReadableConfigToConfigurationAdapter
-
- setDouble(ConfigOption<Double>, double) - 类 中的方法org.apache.flink.configuration.ReadableConfigToConfigurationAdapter
-
- setErrorState(FieldParser.ParseErrorState) - 类 中的方法org.apache.flink.types.parser.FieldParser
-
Sets the error state of the parser.
- 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
-
- setFailTaskOnCheckpointError(boolean) - 类 中的方法org.apache.flink.api.common.ExecutionConfig
-
- 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 at the specified position.
- 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
-
- setFirstInputs(List<Operator<IN1>>) - 类 中的方法org.apache.flink.api.common.operators.DualInputOperator
-
- 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
-
- setFloat(String, float) - 类 中的方法org.apache.flink.configuration.ReadableConfigToConfigurationAdapter
-
- setFloat(ConfigOption<Float>, float) - 类 中的方法org.apache.flink.configuration.ReadableConfigToConfigurationAdapter
-
- 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.
- setGPUResource(double) - 类 中的方法org.apache.flink.api.common.operators.ResourceSpec.Builder
-
- 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
-
- setInputs(Operator<IN>...) - 类 中的方法org.apache.flink.api.common.operators.GenericDataSinkBase
-
- setInputs(List<Operator<IN>>) - 类 中的方法org.apache.flink.api.common.operators.GenericDataSinkBase
-
- setInputs(List<Operator<IN>>) - 类 中的方法org.apache.flink.api.common.operators.SingleInputOperator
-
- 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
-
- setInteger(String, int) - 类 中的方法org.apache.flink.configuration.ReadableConfigToConfigurationAdapter
-
- setInteger(ConfigOption<Integer>, int) - 类 中的方法org.apache.flink.configuration.ReadableConfigToConfigurationAdapter
-
- 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
-
- 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
-
- setLong(String, long) - 类 中的方法org.apache.flink.configuration.ReadableConfigToConfigurationAdapter
-
- setLong(ConfigOption<Long>, long) - 类 中的方法org.apache.flink.configuration.ReadableConfigToConfigurationAdapter
-
- setManagedMemory(MemorySize) - 类 中的方法org.apache.flink.api.common.operators.ResourceSpec.Builder
-
- setManagedMemoryMB(int) - 类 中的方法org.apache.flink.api.common.operators.ResourceSpec.Builder
-
- setManagedMemoryWeight(int) - 类 中的方法org.apache.flink.api.dag.Transformation
-
Set the managed memory weight which indicates how much this transformation relies
on managed memory, so that a transformation highly relies on managed memory would
be able to acquire more managed memory in runtime (linear association).
- 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
-
- 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
-
- setOffTaskHeapMemoryMB(int) - 类 中的方法org.apache.flink.api.common.operators.ResourceSpec.Builder
-
- 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.
- setPosition(int) - 类 中的方法org.apache.flink.core.memory.ByteArrayOutputStreamWithPos
-
- setPosition(int) - 类 中的方法org.apache.flink.core.memory.DataOutputSerializer
-
- setPosition(int) - 类 中的方法org.apache.flink.core.memory.MemorySegmentInputStreamWithPos
-
- 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
-
- 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
-
- setSecondInputs(List<Operator<IN2>>) - 类 中的方法org.apache.flink.api.common.operators.DualInputOperator
-
- 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.
- 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
-
- setString(String, String) - 类 中的方法org.apache.flink.configuration.ReadableConfigToConfigurationAdapter
-
- setString(ConfigOption<String>, String) - 类 中的方法org.apache.flink.configuration.ReadableConfigToConfigurationAdapter
-
- 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
-
- setTaskHeapMemoryMB(int) - 类 中的方法org.apache.flink.api.common.operators.ResourceSpec.Builder
-
- setTaskOffHeapMemory(MemorySize) - 类 中的方法org.apache.flink.api.common.operators.ResourceSpec.Builder
-
- setTerminationCriterion(Operator<X>) - 类 中的方法org.apache.flink.api.common.operators.base.BulkIterationBase
-
- 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
-
- 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
-
- 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中的类
-
- 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.
- 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.
- 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).
- SimpleVersionedSerialization - org.apache.flink.core.io中的类
-
- SimpleVersionedSerializer<E> - org.apache.flink.core.io中的接口
-
A simple serializer interface for versioned serialization.
- 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
-
- sinks - 类 中的变量org.apache.flink.api.common.Plan
-
A collection of all sinks in the plan.
- size() - 类 中的方法org.apache.flink.api.common.operators.util.FieldSet
-
- size() - 类 中的方法org.apache.flink.core.memory.ByteArrayOutputStreamWithPos
-
- size - 类 中的变量org.apache.flink.core.memory.MemorySegment
-
The size in bytes of the memory segment.
- 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
-
- 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
-
- 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_SPILLING_THRESHOLD - 类 中的静态变量org.apache.flink.configuration.AlgorithmOptions
-
- SortPartitionOperatorBase<IN> - org.apache.flink.api.common.operators.base中的类
-
- SortPartitionOperatorBase(UnaryOperatorInformation<IN, IN>, Ordering, String) - 类 的构造器org.apache.flink.api.common.operators.base.SortPartitionOperatorBase
-
- 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.
- splitLength - 类 中的变量org.apache.flink.api.common.io.FileInputFormat
-
The length of the split that this parallel instance must consume.
- splitPaths(String) - 类 中的静态方法org.apache.flink.configuration.ConfigurationUtils
-
- 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
-
- 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中的类
-
- 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.
- 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
-
The state backend to be used to store and checkpoint state.
- STATE_BACKEND - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
-
- 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中的类
-
- 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
-
- 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中的类
-
- 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
-
- 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
-
- 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_ENABLE - 类 中的静态变量org.apache.flink.configuration.WebOptions
-
Config parameter indicating whether jobs can be uploaded and run from the web-frontend.
- 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(Resource) - 类 中的方法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.
- SupplierWithException<R,E extends Throwable> - org.apache.flink.util.function中的接口
-
A functional interface for a
Supplier
that may
throw exceptions.
- supportsCompareAgainstReference() - 类 中的方法org.apache.flink.api.common.typeutils.TypeComparator
-
- supportsMultiPaths() - 类 中的方法org.apache.flink.api.common.io.FileInputFormat
-
- 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
-
- 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.
- 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.
- 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_CHECKPOINT_ALIGNMENT_BYTES_LIMIT - 类 中的静态变量org.apache.flink.configuration.TaskManagerOptions
-
The maximum number of bytes that a checkpoint alignment may buffer.
- 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
-
- TASK_MANAGER_HEAP_MEMORY_MB - 类 中的静态变量org.apache.flink.configuration.TaskManagerOptions
-
- 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
-
- TASK_MANAGER_MEMORY_OFF_HEAP_KEY - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
-
- TASK_MANAGER_MEMORY_PRE_ALLOCATE_KEY - 类 中的静态变量org.apache.flink.configuration.ConfigConstants
-
- 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
-
- 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_RELEASE_WHEN_RESULT_CONSUMED - 类 中的静态变量org.apache.flink.configuration.ResourceManagerOptions
-
- 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
-
- TaskManagerOptions - org.apache.flink.configuration中的类
-
The set of configuration options relating to TaskManager and Task settings.
- TCP_TIMEOUT - 类 中的静态变量org.apache.flink.configuration.AkkaOptions
-
The Akka tcp connection timeout.
- TemporaryClassLoaderContext - org.apache.flink.core.plugin中的类
-
Utility class to temporarily change the context classloader.
- TemporaryClassLoaderContext(ClassLoader) - 类 的构造器org.apache.flink.core.plugin.TemporaryClassLoaderContext
-
- 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中的类
-
- TextElement.TextStyle - org.apache.flink.configuration.description中的枚举
-
Styles that can be applied to
TextElement
e.g. code, bold etc.
- 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
-
- 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
.
- 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
-
- 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.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
-
- toMap() - 类 中的方法org.apache.flink.configuration.ReadableConfigToConfigurationAdapter
-
- 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
-
- 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.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.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.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.configuration.ReadableConfigToConfigurationAdapter
-
- 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.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.PluginDescriptor
-
- toString() - 类 中的方法org.apache.flink.core.plugin.PluginManager
-
- 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.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.TaskManagerOptions
-
Total Flink Memory size for the TaskExecutors.
- 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
-
- TRANSPORT_HEARTBEAT_INTERVAL - 类 中的静态变量org.apache.flink.configuration.AkkaOptions
-
Heartbeat interval of the transport failure detector.
- TRANSPORT_HEARTBEAT_PAUSE - 类 中的静态变量org.apache.flink.configuration.AkkaOptions
-
Allowed heartbeat pause for the transport failure detector.
- TRANSPORT_THRESHOLD - 类 中的静态变量org.apache.flink.configuration.AkkaOptions
-
Detection threshold of transport failure detector.
- 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.
- 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.
- tryEnrichTaskManagerError(Throwable) - 类 中的静态方法org.apache.flink.util.ExceptionUtils
-
Tries to enrich the passed exception with additional information.
- tryReadSerializer(DataInputView, ClassLoader) - 类 中的静态方法org.apache.flink.api.common.typeutils.TypeSerializerSerializationUtil
-
已过时。
- tryReadSerializer(DataInputView, ClassLoader, boolean) - 类 中的静态方法org.apache.flink.api.common.typeutils.TypeSerializerSerializationUtil
-
已过时。
- 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).
- 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中的类
-
- 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中的类
-
- 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中的类
-
- 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中的类
-
- 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中的类
-
- 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中的类
-
- 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中的类
-
- 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中的类
-
- 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中的类
-
- 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中的类
-
- 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中的类
-
- Tuple19Builder() - 类 的构造器org.apache.flink.api.java.tuple.builder.Tuple19Builder
-
- Tuple1Builder<T0> - org.apache.flink.api.java.tuple.builder中的类
-
- 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中的类
-
- 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中的类
-
- 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中的类
-
- 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中的类
-
- 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中的类
-
- 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中的类
-
- Tuple25Builder() - 类 的构造器org.apache.flink.api.java.tuple.builder.Tuple25Builder
-
- Tuple2Builder<T0,T1> - org.apache.flink.api.java.tuple.builder中的类
-
- 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中的类
-
- 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中的类
-
- 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中的类
-
- 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中的类
-
- 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中的类
-
- 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中的类
-
- 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中的类
-
- 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中的类
-
- 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中的注释类型
-
- 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中的类
-
- TypeSerializerSerializationUtil() - 类 的构造器org.apache.flink.api.common.typeutils.TypeSerializerSerializationUtil
-
已过时。
- TypeSerializerSerializationUtil.TypeSerializerSerializationProxy<T> - org.apache.flink.api.common.typeutils中的类
-
已过时。
- 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中的类
-
- TypeSerializerSnapshotSerializationUtil() - 类 的构造器org.apache.flink.api.common.typeutils.TypeSerializerSnapshotSerializationUtil
-
- TypeSerializerUtils - org.apache.flink.api.common.typeutils中的类
-
- typeToClass(Type) - 类 中的静态方法org.apache.flink.api.java.typeutils.TypeExtractionUtils
-
Convert ParameterizedType or Class to a Class.
- typeUsed - 类 中的变量org.apache.flink.api.dag.Transformation
-