- abort() - Method in class org.apache.flink.runtime.operators.hash.AbstractMutableHashTable
-
- abort() - Method in class org.apache.flink.runtime.operators.hash.CompactingHashTable
-
- abort() - Method in class org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable
-
- abort() - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
-
- abort() - Method in class org.apache.flink.runtime.operators.hash.NonReusingBuildFirstHashJoinIterator
-
- abort() - Method in class org.apache.flink.runtime.operators.hash.NonReusingBuildSecondHashJoinIterator
-
- abort() - Method in class org.apache.flink.runtime.operators.hash.ReusingBuildFirstHashJoinIterator
-
- abort() - Method in class org.apache.flink.runtime.operators.hash.ReusingBuildSecondHashJoinIterator
-
- abort() - Method in class org.apache.flink.runtime.operators.sort.AbstractMergeIterator
-
- abort() - Method in interface org.apache.flink.runtime.operators.util.JoinTaskIterator
-
Aborts the matching process.
- abort(TXN) - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
-
Abort a transaction.
- abort(FlinkKafkaProducer011.KafkaTransactionState) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer011
-
- abortCheckpointOnBarrier(long, Throwable) - Method in class org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
-
Aborts a checkpoint as the result of receiving possibly some checkpoint barriers,
but at least one
CancelCheckpointMarker
.
- abortCheckpointOnBarrier(long, Throwable) - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- abortDeclined() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
-
- abortError(Throwable) - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
-
Aborts the pending checkpoint due to an error.
- abortExpired() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
-
Aborts a checkpoint because it expired (took too long).
- abortSubsumed() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
-
Aborts the pending checkpoint because a newer completed checkpoint subsumed it.
- abortTransaction() - Method in class org.apache.flink.streaming.connectors.kafka.internal.FlinkKafkaProducer
-
- absoluteTimeMillis() - Method in class org.apache.flink.runtime.util.clock.Clock
-
- absoluteTimeMillis() - Method in class org.apache.flink.runtime.util.clock.SystemClock
-
- AbstractAggregatedMetricsHeaders<P extends AbstractAggregatedMetricsParameters<?>> - Class in org.apache.flink.runtime.rest.messages.job.metrics
-
- AbstractAggregatedMetricsHeaders() - Constructor for class org.apache.flink.runtime.rest.messages.job.metrics.AbstractAggregatedMetricsHeaders
-
- AbstractAggregatedMetricsParameters<M extends MessageQueryParameter<?>> - Class in org.apache.flink.runtime.rest.messages.job.metrics
-
- AbstractAggregatingMetricsHandler<P extends AbstractAggregatedMetricsParameters<?>> - Class in org.apache.flink.runtime.rest.handler.job.metrics
-
Abstract request handler for querying aggregated metrics.
- AbstractAggregatingMetricsHandler(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, AbstractAggregatedMetricsHeaders<P>, Executor, MetricFetcher<?>) - Constructor for class org.apache.flink.runtime.rest.handler.job.metrics.AbstractAggregatingMetricsHandler
-
- AbstractAsyncCallableWithResources<V> - Class in org.apache.flink.runtime.io.async
-
This abstract class encapsulates the lifecycle and execution strategy for asynchronous operations that use resources.
- AbstractAsyncCallableWithResources() - Constructor for class org.apache.flink.runtime.io.async.AbstractAsyncCallableWithResources
-
- AbstractAsynchronousOperationHandlers<K extends OperationKey,R> - Class in org.apache.flink.runtime.rest.handler.async
-
HTTP handlers for asynchronous operations.
- AbstractAsynchronousOperationHandlers() - Constructor for class org.apache.flink.runtime.rest.handler.async.AbstractAsynchronousOperationHandlers
-
- AbstractAsynchronousOperationHandlers.StatusHandler<T extends RestfulGateway,V,M extends MessageParameters> - Class in org.apache.flink.runtime.rest.handler.async
-
Handler which will be polled to retrieve the asynchronous operation's result.
- AbstractAsynchronousOperationHandlers.TriggerHandler<T extends RestfulGateway,B extends RequestBody,M extends MessageParameters> - Class in org.apache.flink.runtime.rest.handler.async
-
Handler which is responsible for triggering an asynchronous operation.
- AbstractBlobCache - Class in org.apache.flink.runtime.blob
-
Abstract base class for permanent and transient BLOB files.
- AbstractBlobCache(Configuration, BlobView, Logger, InetSocketAddress) - Constructor for class org.apache.flink.runtime.blob.AbstractBlobCache
-
- AbstractBoltSink - Class in org.apache.flink.storm.util
-
Implements a sink that write the received data so some external output.
- AbstractBoltSink(OutputFormatter) - Constructor for class org.apache.flink.storm.util.AbstractBoltSink
-
- AbstractBroadcastStateMetaInfoReader(ClassLoader) - Constructor for class org.apache.flink.runtime.state.OperatorBackendStateMetaInfoSnapshotReaderWriters.AbstractBroadcastStateMetaInfoReader
-
- AbstractBroadcastStateMetaInfoWriter(RegisteredBroadcastBackendStateMetaInfo.Snapshot<K, V>) - Constructor for class org.apache.flink.runtime.state.OperatorBackendStateMetaInfoSnapshotReaderWriters.AbstractBroadcastStateMetaInfoWriter
-
- AbstractCachedBuildSideJoinDriver<IT1,IT2,OT> - Class in org.apache.flink.runtime.operators
-
- AbstractCachedBuildSideJoinDriver(int, int) - Constructor for class org.apache.flink.runtime.operators.AbstractCachedBuildSideJoinDriver
-
- AbstractCassandraTupleSink<IN> - Class in org.apache.flink.streaming.connectors.cassandra
-
Abstract sink to write tuple-like values into a Cassandra cluster.
- AbstractCassandraTupleSink(String, ClusterBuilder) - Constructor for class org.apache.flink.streaming.connectors.cassandra.AbstractCassandraTupleSink
-
- AbstractCheckpointHandler<R extends ResponseBody,M extends CheckpointMessageParameters> - Class in org.apache.flink.runtime.rest.handler.job.checkpoints
-
Base class for checkpoint related REST handler.
- AbstractCheckpointHandler(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MessageHeaders<EmptyRequestBody, R, M>, ExecutionGraphCache, Executor, CheckpointStatsCache) - Constructor for class org.apache.flink.runtime.rest.handler.job.checkpoints.AbstractCheckpointHandler
-
- AbstractCheckpointMessage - Class in org.apache.flink.runtime.messages.checkpoint
-
The base class of all checkpoint messages.
- AbstractCheckpointMessage(JobID, ExecutionAttemptID, long) - Constructor for class org.apache.flink.runtime.messages.checkpoint.AbstractCheckpointMessage
-
- AbstractCheckpointStats - Class in org.apache.flink.runtime.checkpoint
-
Base class for checkpoint statistics.
- AbstractCloseableRegistry<C extends Closeable,T> - Class in 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>) - Constructor for class org.apache.flink.util.AbstractCloseableRegistry
-
- AbstractCustomCommandLine<T> - Class in org.apache.flink.client.cli
-
Base class for
CustomCommandLine
implementations which specify a JobManager address and
a ZooKeeper namespace.
- AbstractCustomCommandLine(Configuration) - Constructor for class org.apache.flink.client.cli.AbstractCustomCommandLine
-
- AbstractDeserializationSchema<T> - Class in 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() - Constructor for class org.apache.flink.api.common.serialization.AbstractDeserializationSchema
-
Creates a new AbstractDeserializationSchema and tries to infer the type returned by this
DeserializationSchema.
- AbstractDeserializationSchema(Class<T>) - Constructor for class org.apache.flink.api.common.serialization.AbstractDeserializationSchema
-
Creates an AbstractDeserializationSchema that returns the TypeInformation
indicated by the given class.
- AbstractDeserializationSchema(TypeHint<T>) - Constructor for class org.apache.flink.api.common.serialization.AbstractDeserializationSchema
-
Creates an AbstractDeserializationSchema that returns the TypeInformation
indicated by the given type hint.
- AbstractDeserializationSchema(TypeInformation<T>) - Constructor for class org.apache.flink.api.common.serialization.AbstractDeserializationSchema
-
Creates an AbstractDeserializationSchema that returns the given TypeInformation
for the produced type.
- AbstractDeserializationSchema<T> - Class in org.apache.flink.streaming.util.serialization
-
- AbstractDeserializationSchema() - Constructor for class org.apache.flink.streaming.util.serialization.AbstractDeserializationSchema
-
Deprecated.
- AbstractEvent - Class in org.apache.flink.runtime.event
-
This type of event can be used to exchange notification messages between
different
TaskManager
objects
at runtime using the communication channels.
- AbstractEvent() - Constructor for class org.apache.flink.runtime.event.AbstractEvent
-
- AbstractExecutionGraphHandler<R extends ResponseBody,M extends JobMessageParameters> - Class in org.apache.flink.runtime.rest.handler.job
-
- AbstractExecutionGraphHandler(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MessageHeaders<EmptyRequestBody, R, M>, ExecutionGraphCache, Executor) - Constructor for class org.apache.flink.runtime.rest.handler.job.AbstractExecutionGraphHandler
-
- AbstractExecutionGraphRequestHandler - Class in org.apache.flink.runtime.rest.handler.legacy
-
Base class for request handlers whose response depends on an ExecutionGraph
that can be retrieved via "jobid" parameter.
- AbstractExecutionGraphRequestHandler(ExecutionGraphCache, Executor) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.AbstractExecutionGraphRequestHandler
-
- AbstractFetcher<T,KPH> - Class in org.apache.flink.streaming.connectors.kafka.internals
-
Base class for all fetchers, which implement the connections to Kafka brokers and
pull records from Kafka partitions.
- AbstractFetcher(SourceFunction.SourceContext<T>, Map<KafkaTopicPartition, Long>, SerializedValue<AssignerWithPeriodicWatermarks<T>>, SerializedValue<AssignerWithPunctuatedWatermarks<T>>, ProcessingTimeService, long, ClassLoader, MetricGroup, boolean) - Constructor for class org.apache.flink.streaming.connectors.kafka.internals.AbstractFetcher
-
- AbstractFileIOChannel - Class in org.apache.flink.runtime.io.disk.iomanager
-
- AbstractFileIOChannel(FileIOChannel.ID, boolean) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.AbstractFileIOChannel
-
Creates a new channel to the path indicated by the given ID.
- AbstractFileStateBackend - Class in org.apache.flink.runtime.state.filesystem
-
A base class for all state backends that store their metadata (and data) in files.
- AbstractFileStateBackend(URI, URI) - Constructor for class org.apache.flink.runtime.state.filesystem.AbstractFileStateBackend
-
Creates a backend with the given optional checkpoint- and savepoint base directories.
- AbstractFileStateBackend(Path, Path) - Constructor for class org.apache.flink.runtime.state.filesystem.AbstractFileStateBackend
-
Creates a backend with the given optional checkpoint- and savepoint base directories.
- AbstractFileStateBackend(Path, Path, Configuration) - Constructor for class org.apache.flink.runtime.state.filesystem.AbstractFileStateBackend
-
Creates a new backend using the given checkpoint-/savepoint directories, or the values defined in
the given configuration.
- AbstractFsCheckpointStorage - Class in org.apache.flink.runtime.state.filesystem
-
An implementation of durable checkpoint storage to file systems.
- AbstractFsCheckpointStorage(JobID, Path) - Constructor for class org.apache.flink.runtime.state.filesystem.AbstractFsCheckpointStorage
-
Creates a new checkpoint storage.
- AbstractHandler<T extends RestfulGateway,R extends RequestBody,M extends MessageParameters> - Class in org.apache.flink.runtime.rest.handler
-
Super class for netty-based handlers that work with
RequestBody
.
- AbstractHandler(CompletableFuture<String>, GatewayRetriever<? extends T>, Time, Map<String, String>, UntypedResponseMessageHeaders<R, M>) - Constructor for class org.apache.flink.runtime.rest.handler.AbstractHandler
-
- AbstractHashTableProber<PT,BT> - Class in org.apache.flink.runtime.operators.hash
-
- AbstractHashTableProber(TypeComparator<PT>, TypePairComparator<PT, BT>) - Constructor for class org.apache.flink.runtime.operators.hash.AbstractHashTableProber
-
- AbstractHeapMergingState<K,N,IN,SV,OUT,S extends State> - Class in org.apache.flink.runtime.state.heap
-
- AbstractHeapMergingState(StateTable<K, N, SV>, TypeSerializer<K>, TypeSerializer<SV>, TypeSerializer<N>, SV) - Constructor for class org.apache.flink.runtime.state.heap.AbstractHeapMergingState
-
Creates a new key/value state for the given hash map of key/value pairs.
- AbstractHeapState<K,N,SV,S extends State> - Class in org.apache.flink.runtime.state.heap
-
Base class for partitioned
State
implementations that are backed by a regular
heap hash map.
- AbstractHeapState(StateTable<K, N, SV>, TypeSerializer<K>, TypeSerializer<SV>, TypeSerializer<N>, SV) - Constructor for class org.apache.flink.runtime.state.heap.AbstractHeapState
-
Creates a new key/value state for the given hash map of key/value pairs.
- AbstractID - Class in org.apache.flink.util
-
A statistically unique identification number.
- AbstractID(byte[]) - Constructor for class org.apache.flink.util.AbstractID
-
Constructs a new ID with a specific bytes value.
- AbstractID(long, long) - Constructor for class org.apache.flink.util.AbstractID
-
Constructs a new abstract ID.
- AbstractID(AbstractID) - Constructor for class org.apache.flink.util.AbstractID
-
Copy constructor: Creates a new abstract ID from the given one.
- AbstractID() - Constructor for class org.apache.flink.util.AbstractID
-
Constructs a new random ID from a uniform distribution.
- AbstractInvokable - Class in org.apache.flink.runtime.jobgraph.tasks
-
This is the abstract base class for every task that can be executed by a TaskManager.
- AbstractInvokable(Environment) - Constructor for class org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
-
Create an Invokable task and set its environment.
- AbstractIterativeTask<S extends Function,OT> - Class in org.apache.flink.runtime.iterative.task
-
The abstract base class for all tasks able to participate in an iteration.
- AbstractIterativeTask(Environment) - Constructor for class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
-
Create an Invokable task and set its environment.
- AbstractJobVertexHandler<R extends ResponseBody,M extends JobVertexMessageParameters> - Class in org.apache.flink.runtime.rest.handler.job
-
- AbstractJobVertexHandler(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MessageHeaders<EmptyRequestBody, R, M>, ExecutionGraphCache, Executor) - Constructor for class org.apache.flink.runtime.rest.handler.job.AbstractJobVertexHandler
-
Instantiates a new Abstract job vertex handler.
- AbstractJobVertexRequestHandler - Class in org.apache.flink.runtime.rest.handler.legacy
-
Base class for request handlers whose response depends on a specific job vertex (defined
via the "vertexid" parameter) in a specific job, defined via (defined via the "jobid" parameter).
- AbstractJobVertexRequestHandler(ExecutionGraphCache, Executor) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.AbstractJobVertexRequestHandler
-
- AbstractJoinDescriptor - Class in org.apache.flink.optimizer.operators
-
Defines the possible global properties for a join.
- AbstractJoinDescriptor(FieldList, FieldList) - Constructor for class org.apache.flink.optimizer.operators.AbstractJoinDescriptor
-
- AbstractJoinDescriptor(FieldList, FieldList, boolean, boolean, boolean) - Constructor for class org.apache.flink.optimizer.operators.AbstractJoinDescriptor
-
- AbstractJsonRequestHandler - Class in org.apache.flink.runtime.rest.handler.legacy
-
Base class for most request handlers.
- AbstractJsonRequestHandler(Executor) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.AbstractJsonRequestHandler
-
- AbstractKeyedCEPPatternOperator<IN,KEY,OUT,F extends Function> - Class in org.apache.flink.cep.operator
-
Abstract CEP pattern operator for a keyed input stream.
- AbstractKeyedCEPPatternOperator(TypeSerializer<IN>, boolean, NFACompiler.NFAFactory<IN>, EventComparator<IN>, AfterMatchSkipStrategy, F) - Constructor for class org.apache.flink.cep.operator.AbstractKeyedCEPPatternOperator
-
- AbstractKeyedStateBackend<K> - Class in org.apache.flink.runtime.state
-
Base implementation of KeyedStateBackend.
- AbstractKeyedStateBackend(TaskKvStateRegistry, TypeSerializer<K>, ClassLoader, int, KeyGroupRange, ExecutionConfig) - Constructor for class org.apache.flink.runtime.state.AbstractKeyedStateBackend
-
- AbstractLineSpout - Class in org.apache.flink.storm.util
-
Base class for Spouts that read data line by line from an arbitrary source.
- AbstractLineSpout() - Constructor for class org.apache.flink.storm.util.AbstractLineSpout
-
- AbstractMergeInnerJoinIterator<T1,T2,O> - Class in org.apache.flink.runtime.operators.sort
-
An implementation of the
JoinTaskIterator
that realizes the
joining through a sort-merge join strategy.
- AbstractMergeInnerJoinIterator(MutableObjectIterator<T1>, MutableObjectIterator<T2>, TypeSerializer<T1>, TypeComparator<T1>, TypeSerializer<T2>, TypeComparator<T2>, TypePairComparator<T1, T2>, MemoryManager, IOManager, int, AbstractInvokable) - Constructor for class org.apache.flink.runtime.operators.sort.AbstractMergeInnerJoinIterator
-
- AbstractMergeIterator<T1,T2,O> - Class in org.apache.flink.runtime.operators.sort
-
- AbstractMergeIterator(MutableObjectIterator<T1>, MutableObjectIterator<T2>, TypeSerializer<T1>, TypeComparator<T1>, TypeSerializer<T2>, TypeComparator<T2>, TypePairComparator<T1, T2>, MemoryManager, IOManager, int, AbstractInvokable) - Constructor for class org.apache.flink.runtime.operators.sort.AbstractMergeIterator
-
- AbstractMergeOuterJoinIterator<T1,T2,O> - Class in org.apache.flink.runtime.operators.sort
-
An implementation of the
JoinTaskIterator
that realizes the
outer join through a sort-merge join strategy.
- AbstractMergeOuterJoinIterator(OuterJoinOperatorBase.OuterJoinType, MutableObjectIterator<T1>, MutableObjectIterator<T2>, TypeSerializer<T1>, TypeComparator<T1>, TypeSerializer<T2>, TypeComparator<T2>, TypePairComparator<T1, T2>, MemoryManager, IOManager, int, AbstractInvokable) - Constructor for class org.apache.flink.runtime.operators.sort.AbstractMergeOuterJoinIterator
-
- AbstractMesosServices - Class in org.apache.flink.mesos.runtime.clusterframework.services
-
- AbstractMesosServices(ActorSystem, MesosArtifactServer) - Constructor for class org.apache.flink.mesos.runtime.clusterframework.services.AbstractMesosServices
-
- AbstractMetricGroup<A extends AbstractMetricGroup<?>> - Class in org.apache.flink.runtime.metrics.groups
-
Abstract
MetricGroup
that contains key functionality for adding metrics and groups.
- AbstractMetricGroup(MetricRegistry, String[], A) - Constructor for class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
-
- AbstractMetricGroup.ChildType - Enum in org.apache.flink.runtime.metrics.groups
-
Enum for indicating which child group should be created.
- AbstractMetricsHandler<M extends MessageParameters> - Class in org.apache.flink.runtime.rest.handler.job.metrics
-
Request handler that returns for a given task a list of all available metrics or the values for a set of metrics.
- AbstractMetricsHandler(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MessageHeaders<EmptyRequestBody, MetricCollectionResponseBody, M>, MetricFetcher) - Constructor for class org.apache.flink.runtime.rest.handler.job.metrics.AbstractMetricsHandler
-
- AbstractMetricsHandler - Class in org.apache.flink.runtime.rest.handler.legacy.metrics
-
Abstract request handler that returns a list of all available metrics or the values for a set of metrics.
- AbstractMetricsHandler(Executor, MetricFetcher) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.metrics.AbstractMetricsHandler
-
- AbstractMetricsHeaders<M extends MessageParameters> - Class in org.apache.flink.runtime.rest.messages.job.metrics
-
- AbstractMetricsHeaders() - Constructor for class org.apache.flink.runtime.rest.messages.job.metrics.AbstractMetricsHeaders
-
- AbstractMultiFSDataInputStream - Class in org.apache.flink.core.fs
-
Abstract base class for wrappers over multiple
FSDataInputStream
, which gives a contiguous view on all inner
streams and makes them look like a single stream, in which we can read, seek, etc.
- AbstractMultiFSDataInputStream() - Constructor for class org.apache.flink.core.fs.AbstractMultiFSDataInputStream
-
- AbstractMutableHashTable<T> - Class in org.apache.flink.runtime.operators.hash
-
- AbstractMutableHashTable(TypeSerializer<T>, TypeComparator<T>) - Constructor for class org.apache.flink.runtime.operators.hash.AbstractMutableHashTable
-
- AbstractNonHaServices - Class in org.apache.flink.runtime.highavailability.nonha
-
Abstract base class for non high-availability services.
- AbstractNonHaServices() - Constructor for class org.apache.flink.runtime.highavailability.nonha.AbstractNonHaServices
-
- AbstractOperatorBackendStateMetaInfoReader(ClassLoader) - Constructor for class org.apache.flink.runtime.state.OperatorBackendStateMetaInfoSnapshotReaderWriters.AbstractOperatorBackendStateMetaInfoReader
-
- AbstractOperatorBackendStateMetaInfoWriter(RegisteredOperatorBackendStateMetaInfo.Snapshot<S>) - Constructor for class org.apache.flink.runtime.state.OperatorBackendStateMetaInfoSnapshotReaderWriters.AbstractOperatorBackendStateMetaInfoWriter
-
- AbstractOperatorDescriptor - Interface in org.apache.flink.optimizer.operators
-
The root of all descriptions of an operator to the optimizer.
- AbstractOuterJoinDriver<IT1,IT2,OT> - Class in org.apache.flink.runtime.operators
-
The abstract outer join driver implements the logic of an outer join operator at runtime.
- AbstractOuterJoinDriver() - Constructor for class org.apache.flink.runtime.operators.AbstractOuterJoinDriver
-
- AbstractPagedInputView - Class in org.apache.flink.runtime.memory
-
The base class for all input views that are backed by multiple memory pages.
- AbstractPagedInputView(MemorySegment, int, int) - Constructor for class org.apache.flink.runtime.memory.AbstractPagedInputView
-
Creates a new view that starts with the given segment.
- AbstractPagedInputView(int) - Constructor for class org.apache.flink.runtime.memory.AbstractPagedInputView
-
Creates a new view that is initially not bound to a memory segment.
- AbstractPagedOutputView - Class in org.apache.flink.runtime.memory
-
The base class for all output views that are backed by multiple memory pages.
- AbstractPagedOutputView(MemorySegment, int, int) - Constructor for class org.apache.flink.runtime.memory.AbstractPagedOutputView
-
Creates a new output view that writes initially to the given initial segment.
- AbstractPagedOutputView(int, int) - Constructor for class org.apache.flink.runtime.memory.AbstractPagedOutputView
-
- AbstractPartialSolutionNode - Class in org.apache.flink.optimizer.dag
-
The optimizer's internal representation of the partial solution that is input to a bulk iteration.
- AbstractPartialSolutionNode(Operator<?>) - Constructor for class org.apache.flink.optimizer.dag.AbstractPartialSolutionNode
-
- AbstractPartitionDiscoverer - Class in org.apache.flink.streaming.connectors.kafka.internals
-
Base class for all partition discoverers.
- AbstractPartitionDiscoverer(KafkaTopicsDescriptor, int, int) - Constructor for class org.apache.flink.streaming.connectors.kafka.internals.AbstractPartitionDiscoverer
-
- AbstractPartitionDiscoverer.ClosedException - Exception in org.apache.flink.streaming.connectors.kafka.internals
-
Thrown if this discoverer was used to discover partitions after it was closed.
- AbstractPartitionDiscoverer.WakeupException - Exception in org.apache.flink.streaming.connectors.kafka.internals
-
Signaling exception to indicate that an actual Kafka call was interrupted.
- AbstractPerWindowStateStore(KeyedStateBackend<?>, ExecutionConfig) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.AbstractPerWindowStateStore
-
- AbstractPythonUDF<F extends Function> - Class in org.apache.flink.streaming.python.api.functions
-
Generic base-class for wrappers of python functions implenting the
Function
interface.
- AbstractReader - Class in org.apache.flink.runtime.io.network.api.reader
-
A basic reader implementation, which wraps an input gate and handles events.
- AbstractReader(InputGate) - Constructor for class org.apache.flink.runtime.io.network.api.reader.AbstractReader
-
- AbstractReporter - Class in org.apache.flink.metrics.reporter
-
Base interface for custom metric reporters.
- AbstractReporter() - Constructor for class org.apache.flink.metrics.reporter.AbstractReporter
-
- AbstractRestHandler<T extends RestfulGateway,R extends RequestBody,P extends ResponseBody,M extends MessageParameters> - Class in org.apache.flink.runtime.rest.handler
-
- AbstractRestHandler(CompletableFuture<String>, GatewayRetriever<? extends T>, Time, Map<String, String>, MessageHeaders<R, P, M>) - Constructor for class org.apache.flink.runtime.rest.handler.AbstractRestHandler
-
- AbstractRichFunction - Class in org.apache.flink.api.common.functions
-
An abstract stub implementation for rich user-defined functions.
- AbstractRichFunction() - Constructor for class org.apache.flink.api.common.functions.AbstractRichFunction
-
- AbstractRocksDBState<K,N,V,S extends State> - Class in org.apache.flink.contrib.streaming.state
-
Base class for
State
implementations that store state in a RocksDB database.
- AbstractRocksDBState(ColumnFamilyHandle, TypeSerializer<N>, TypeSerializer<V>, V, RocksDBKeyedStateBackend<K>) - Constructor for class org.apache.flink.contrib.streaming.state.AbstractRocksDBState
-
Creates a new RocksDB backed state.
- AbstractRuntimeUDFContext - Class in org.apache.flink.api.common.functions.util
-
A standalone implementation of the
RuntimeContext
, created by runtime UDF operators.
- AbstractRuntimeUDFContext(TaskInfo, ClassLoader, ExecutionConfig, Map<String, Accumulator<?, ?>>, Map<String, Future<Path>>, MetricGroup) - Constructor for class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
-
- AbstractServerBase<REQ extends MessageBody,RESP extends MessageBody> - Class in org.apache.flink.queryablestate.network
-
The base class for every server in the queryable state module.
- AbstractServerBase(String, InetAddress, Iterator<Integer>, Integer, Integer) - Constructor for class org.apache.flink.queryablestate.network.AbstractServerBase
-
- AbstractServerHandler<REQ extends MessageBody,RESP extends MessageBody> - Class in org.apache.flink.queryablestate.network
-
- AbstractServerHandler(AbstractServerBase<REQ, RESP>, MessageSerializer<REQ, RESP>, KvStateRequestStats) - Constructor for class org.apache.flink.queryablestate.network.AbstractServerHandler
-
Create the handler.
- AbstractSortMergeJoinDescriptor - Class in org.apache.flink.optimizer.operators
-
- AbstractSortMergeJoinDescriptor(FieldList, FieldList) - Constructor for class org.apache.flink.optimizer.operators.AbstractSortMergeJoinDescriptor
-
- AbstractSortMergeJoinDescriptor(FieldList, FieldList, boolean, boolean, boolean) - Constructor for class org.apache.flink.optimizer.operators.AbstractSortMergeJoinDescriptor
-
- AbstractStateBackend - Class in org.apache.flink.runtime.state
-
An abstract base implementation of the
StateBackend
interface.
- AbstractStateBackend() - Constructor for class org.apache.flink.runtime.state.AbstractStateBackend
-
- AbstractStreamOperator<OUT> - Class in org.apache.flink.streaming.api.operators
-
Base class for all stream operators.
- AbstractStreamOperator() - Constructor for class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- AbstractStreamOperator.CountingOutput - Class in org.apache.flink.streaming.api.operators
-
Wrapping
Output
that updates metrics on the number of emitted elements.
- AbstractSubtaskAttemptHandler<R extends ResponseBody,M extends SubtaskAttemptMessageParameters> - Class in org.apache.flink.runtime.rest.handler.job
-
- AbstractSubtaskAttemptHandler(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MessageHeaders<EmptyRequestBody, R, M>, ExecutionGraphCache, Executor) - Constructor for class org.apache.flink.runtime.rest.handler.job.AbstractSubtaskAttemptHandler
-
Instantiates a new Abstract job vertex handler.
- AbstractSubtaskAttemptRequestHandler - Class in org.apache.flink.runtime.rest.handler.legacy
-
Base class for request handlers whose response depends on a specific subtask execution attempt
(defined via the "attempt" parameter) of a specific subtask (defined via the
"subtasknum" parameter) in a specific job vertex (defined via the "vertexid" parameter) in a
specific job, defined via (defined voa the "jobid" parameter).
- AbstractSubtaskAttemptRequestHandler(ExecutionGraphCache, Executor) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.AbstractSubtaskAttemptRequestHandler
-
- AbstractSubtaskHandler<R extends ResponseBody,M extends SubtaskMessageParameters> - Class in org.apache.flink.runtime.rest.handler.job
-
- AbstractSubtaskHandler(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MessageHeaders<EmptyRequestBody, R, M>, ExecutionGraphCache, Executor) - Constructor for class org.apache.flink.runtime.rest.handler.job.AbstractSubtaskHandler
-
Instantiates a new Abstract job vertex handler.
- AbstractSubtaskRequestHandler - Class in org.apache.flink.runtime.rest.handler.legacy
-
Base class for request handlers whose response depends on a specific subtask (defined via the
"subtasknum" parameter) in a specific job vertex (defined via the "vertexid" parameter) in a
specific job, defined via (defined voa the "jobid" parameter).
- AbstractSubtaskRequestHandler(ExecutionGraphCache, Executor) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.AbstractSubtaskRequestHandler
-
- AbstractTableInputFormat<T> - Class in org.apache.flink.addons.hbase
-
- AbstractTableInputFormat() - Constructor for class org.apache.flink.addons.hbase.AbstractTableInputFormat
-
- AbstractTaskManagerFileHandler<M extends TaskManagerMessageParameters> - Class in org.apache.flink.runtime.rest.handler.taskmanager
-
- AbstractTaskManagerFileHandler(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, UntypedResponseMessageHeaders<EmptyRequestBody, M>, GatewayRetriever<ResourceManagerGateway>, TransientBlobService, Time) - Constructor for class org.apache.flink.runtime.rest.handler.taskmanager.AbstractTaskManagerFileHandler
-
- AbstractTestBase - Class in org.apache.flink.test.util
-
Base class for unit tests that run multiple tests and want to reuse the same
Flink cluster.
- AbstractTestBase() - Constructor for class org.apache.flink.test.util.AbstractTestBase
-
- AbstractUdfOperator<OUT,FT extends Function> - Class in org.apache.flink.api.common.operators
-
Abstract superclass for all contracts that represent actual operators.
- AbstractUdfOperator(UserCodeWrapper<FT>, OperatorInformation<OUT>, String) - Constructor for class org.apache.flink.api.common.operators.AbstractUdfOperator
-
Creates a new abstract operator with the given name wrapping the given user function.
- AbstractUdfStreamOperator<OUT,F extends Function> - Class in org.apache.flink.streaming.api.operators
-
This is used as the base class for operators that have a user-defined
function.
- AbstractUdfStreamOperator(F) - Constructor for class org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
-
- AbstractYarnClusterDescriptor - Class in org.apache.flink.yarn
-
The descriptor with deployment information for spawning or resuming a
YarnClusterClient
.
- AbstractYarnClusterDescriptor(Configuration, YarnConfiguration, String, YarnClient, boolean) - Constructor for class org.apache.flink.yarn.AbstractYarnClusterDescriptor
-
- AbstractYarnNonHaServices - Class in org.apache.flink.yarn.highavailability
-
Abstract base class for the high availability services for Flink YARN applications that support
no master fail over.
- AbstractYarnNonHaServices(Configuration, Configuration) - Constructor for class org.apache.flink.yarn.highavailability.AbstractYarnNonHaServices
-
Creates new YARN high-availability services, configuring the file system and recovery
data directory based on the working directory in the given Hadoop configuration.
- accept(Visitor<Operator<?>>) - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase.PartialSolutionPlaceHolder
-
- accept(Visitor<Operator<?>>) - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase.SolutionSetPlaceHolder
-
- accept(Visitor<Operator<?>>) - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase.WorksetPlaceHolder
-
- accept(Visitor<Operator<?>>) - Method in class org.apache.flink.api.common.operators.DualInputOperator
-
- accept(Visitor<Operator<?>>) - Method in class org.apache.flink.api.common.operators.GenericDataSinkBase
-
Accepts the visitor and applies it this instance.
- accept(Visitor<Operator<?>>) - Method in class org.apache.flink.api.common.operators.GenericDataSourceBase
-
Accepts the visitor and applies it this instance.
- accept(Visitor<Operator<?>>) - Method in class org.apache.flink.api.common.operators.SingleInputOperator
-
Accepts the visitor and applies it this instance.
- accept(Visitor<Operator<?>>) - Method in class org.apache.flink.api.common.Plan
-
Traverses the job depth first from all data sinks on towards the sources.
- accept(Visitor<OptimizerNode>) - Method in class org.apache.flink.optimizer.dag.AbstractPartialSolutionNode
-
- accept(Visitor<OptimizerNode>) - Method in class org.apache.flink.optimizer.dag.DataSinkNode
-
- accept(Visitor<OptimizerNode>) - Method in class org.apache.flink.optimizer.dag.DataSourceNode
-
- accept(Visitor<OptimizerNode>) - Method in class org.apache.flink.optimizer.dag.OptimizerNode
-
This method implements the visit of a depth-first graph traversing visitor.
- accept(Visitor<OptimizerNode>) - Method in class org.apache.flink.optimizer.dag.SingleInputNode
-
- accept(Visitor<OptimizerNode>) - Method in class org.apache.flink.optimizer.dag.TwoInputNode
-
- accept(Visitor<PlanNode>) - Method in class org.apache.flink.optimizer.plan.BulkPartialSolutionPlanNode
-
- accept(Visitor<PlanNode>) - Method in class org.apache.flink.optimizer.plan.DualInputPlanNode
-
- accept(Visitor<PlanNode>) - Method in class org.apache.flink.optimizer.plan.NAryUnionPlanNode
-
- accept(Visitor<PlanNode>) - Method in class org.apache.flink.optimizer.plan.OptimizedPlan
-
Applies the given visitor top down to all nodes, starting at the sinks.
- accept(Visitor<PlanNode>) - Method in class org.apache.flink.optimizer.plan.SingleInputPlanNode
-
- accept(Visitor<PlanNode>) - Method in class org.apache.flink.optimizer.plan.SolutionSetPlanNode
-
- accept(Visitor<PlanNode>) - Method in class org.apache.flink.optimizer.plan.SourcePlanNode
-
- accept(Visitor<PlanNode>) - Method in class org.apache.flink.optimizer.plan.WorksetPlanNode
-
- accept(T) - Method in interface org.apache.flink.util.concurrent.FutureConsumerWithException
-
- accept(T, U) - Method in interface org.apache.flink.util.function.BiConsumerWithException
-
Performs this operation on the given arguments.
- accept(T) - Method in interface org.apache.flink.util.function.ThrowingConsumer
-
Performs this operation on the given argument.
- accept(S, T, U) - Method in interface org.apache.flink.util.function.TriConsumer
-
Performs this operation on the given arguments.
- accept(Visitor<T>) - Method in interface org.apache.flink.util.Visitable
-
Contains the logic to invoke the visitor and continue the traversal.
- acceptFile(FileStatus) - Method in class org.apache.flink.api.common.io.FileInputFormat
-
A simple hook to filter files and directories from the input.
- acceptForStepFunction(Visitor<OptimizerNode>) - Method in class org.apache.flink.optimizer.dag.BulkIterationNode
-
- acceptForStepFunction(Visitor<OptimizerNode>) - Method in interface org.apache.flink.optimizer.dag.IterationNode
-
- acceptForStepFunction(Visitor<OptimizerNode>) - Method in class org.apache.flink.optimizer.dag.WorksetIterationNode
-
- acceptForStepFunction(Visitor<PlanNode>) - Method in class org.apache.flink.optimizer.plan.BulkIterationPlanNode
-
- acceptForStepFunction(Visitor<PlanNode>) - Method in interface org.apache.flink.optimizer.plan.IterationPlanNode
-
- acceptForStepFunction(Visitor<PlanNode>) - Method in class org.apache.flink.optimizer.plan.WorksetIterationPlanNode
-
- acceptOffers(AcceptOffers) - Method in class org.apache.flink.mesos.runtime.clusterframework.MesosResourceManager
-
Accept offers as advised by the launch coordinator.
- acceptOffers(AcceptOffers) - Method in interface org.apache.flink.mesos.runtime.clusterframework.MesosResourceManagerActions
-
Accept the given offers as advised by the launch coordinator.
- AcceptOffers - Class in org.apache.flink.mesos.scheduler.messages
-
Local message sent by the launch coordinator to the scheduler to accept offers.
- AcceptOffers(String, Collection<Protos.OfferID>, Collection<Protos.Offer.Operation>) - Constructor for class org.apache.flink.mesos.scheduler.messages.AcceptOffers
-
- AcceptOffers(String, Collection<Protos.OfferID>, Collection<Protos.Offer.Operation>, Protos.Filters) - Constructor for class org.apache.flink.mesos.scheduler.messages.AcceptOffers
-
- acceptsFileUploads() - Method in class org.apache.flink.runtime.rest.messages.job.JobSubmitHeaders
-
- acceptsFileUploads() - Method in interface org.apache.flink.runtime.rest.messages.UntypedResponseMessageHeaders
-
Returns whether this header allows file uploads.
- acceptsFileUploads() - Method in class org.apache.flink.runtime.webmonitor.handlers.JarUploadHeaders
-
- acceptWithException(T) - Method in interface org.apache.flink.util.concurrent.FutureConsumerWithException
-
- ACCESS_CONTROL_ALLOW_ORIGIN - Static variable in class org.apache.flink.configuration.WebOptions
-
The config parameter defining the Access-Control-Allow-Origin header for all
responses from the web-frontend.
- AccessExecution - Interface in org.apache.flink.runtime.executiongraph
-
Common interface for the runtime Execution and {@link ArchivedExecution}.
- AccessExecutionGraph - Interface in org.apache.flink.runtime.executiongraph
-
- AccessExecutionJobVertex - Interface in org.apache.flink.runtime.executiongraph
-
- AccessExecutionVertex - Interface in org.apache.flink.runtime.executiongraph
-
- accessField(Field, Object) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoComparator
-
This method is handling the IllegalAccess exceptions of Field.get()
- Accumulator<V,R extends Serializable> - Interface in org.apache.flink.api.common.accumulators
-
Accumulators collect distributed statistics or aggregates in a from user functions
and operators.
- AccumulatorHelper - Class in org.apache.flink.api.common.accumulators
-
- AccumulatorHelper() - Constructor for class org.apache.flink.api.common.accumulators.AccumulatorHelper
-
- accumulatorMap - Variable in class org.apache.flink.runtime.operators.BatchTask
-
The accumulator map used in the RuntimeContext.
- AccumulatorRegistry - Class in org.apache.flink.runtime.accumulators
-
Main accumulator registry which encapsulates user-defined accumulators.
- AccumulatorRegistry(JobID, ExecutionAttemptID) - Constructor for class org.apache.flink.runtime.accumulators.AccumulatorRegistry
-
- AccumulatorReport - Class in org.apache.flink.runtime.taskexecutor
-
A report about the current values of all accumulators of the TaskExecutor for a given job.
- AccumulatorReport(List<AccumulatorSnapshot>) - Constructor for class org.apache.flink.runtime.taskexecutor.AccumulatorReport
-
- accumulatorResults(Map<String, SerializedValue<OptionalFailure<Object>>>) - Method in class org.apache.flink.runtime.jobmaster.JobResult.Builder
-
- AccumulatorsIncludeSerializedValueQueryParameter - Class in org.apache.flink.runtime.rest.messages
-
- AccumulatorsIncludeSerializedValueQueryParameter() - Constructor for class org.apache.flink.runtime.rest.messages.AccumulatorsIncludeSerializedValueQueryParameter
-
- AccumulatorSnapshot - Class in org.apache.flink.runtime.accumulators
-
This class encapsulates a map of accumulators for a single task.
- AccumulatorSnapshot(JobID, ExecutionAttemptID, Map<String, Accumulator<?, ?>>) - Constructor for class org.apache.flink.runtime.accumulators.AccumulatorSnapshot
-
- ack(Object) - Method in class org.apache.flink.storm.util.AbstractLineSpout
-
- ack(Object) - Method in class org.apache.flink.storm.util.NullTerminatingSpout
-
- Acknowledge - Class in org.apache.flink.runtime.messages
-
A generic acknowledgement message.
- acknowledgeCheckpoint(JobID, ExecutionAttemptID, long, CheckpointMetrics, TaskStateSnapshot) - Method in interface org.apache.flink.runtime.checkpoint.CheckpointCoordinatorGateway
-
- acknowledgeCheckpoint(long, CheckpointMetrics) - Method in interface org.apache.flink.runtime.execution.Environment
-
Confirms that the invokable has successfully completed all steps it needed to
to for the checkpoint with the give checkpoint-ID.
- acknowledgeCheckpoint(long, CheckpointMetrics, TaskStateSnapshot) - Method in interface org.apache.flink.runtime.execution.Environment
-
Confirms that the invokable has successfully completed all required steps for
the checkpoint with the give checkpoint-ID.
- acknowledgeCheckpoint(JobID, ExecutionAttemptID, long, CheckpointMetrics, TaskStateSnapshot) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
-
- AcknowledgeCheckpoint - Class in org.apache.flink.runtime.messages.checkpoint
-
This message is sent from the
TaskManager
to the
JobManager
to signal that the checkpoint of an
individual task is completed.
- AcknowledgeCheckpoint(JobID, ExecutionAttemptID, long, CheckpointMetrics, TaskStateSnapshot) - Constructor for class org.apache.flink.runtime.messages.checkpoint.AcknowledgeCheckpoint
-
- AcknowledgeCheckpoint(JobID, ExecutionAttemptID, long) - Constructor for class org.apache.flink.runtime.messages.checkpoint.AcknowledgeCheckpoint
-
- acknowledgeCheckpoint(JobID, ExecutionAttemptID, long, CheckpointMetrics, TaskStateSnapshot) - Method in class org.apache.flink.runtime.taskexecutor.rpc.RpcCheckpointResponder
-
- acknowledgeCheckpoint(JobID, ExecutionAttemptID, long, CheckpointMetrics, TaskStateSnapshot) - Method in class org.apache.flink.runtime.taskmanager.ActorGatewayCheckpointResponder
-
- acknowledgeCheckpoint(JobID, ExecutionAttemptID, long, CheckpointMetrics, TaskStateSnapshot) - Method in interface org.apache.flink.runtime.taskmanager.CheckpointResponder
-
Acknowledges the given checkpoint.
- acknowledgeCheckpoint(long, CheckpointMetrics) - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
-
- acknowledgeCheckpoint(long, CheckpointMetrics, TaskStateSnapshot) - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
-
- acknowledgeIDs(long, Set<UId>) - Method in class org.apache.flink.streaming.api.functions.source.MessageAcknowledgingSourceBase
-
This method must be implemented to acknowledge the given set of IDs back to the message queue.
- acknowledgeIDs(long, Set<UId>) - Method in class org.apache.flink.streaming.api.functions.source.MultipleIdsMessageAcknowledgingSourceBase
-
Acknowledges the session ids.
- acknowledgeSessionIDs(List<SessionId>) - Method in class org.apache.flink.streaming.api.functions.source.MultipleIdsMessageAcknowledgingSourceBase
-
Acknowledges the session ids.
- acknowledgeSessionIDs(List<Long>) - Method in class org.apache.flink.streaming.connectors.rabbitmq.RMQSource
-
- acknowledgeTask(ExecutionAttemptID, TaskStateSnapshot, CheckpointMetrics) - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
-
Acknowledges the task with the given execution attempt id and the given subtask state.
- acquireResource() - Method in class org.apache.flink.util.ResourceGuard
-
Acquired access from one new client for the guarded resource.
- acquireResources() - Method in class org.apache.flink.runtime.io.async.AbstractAsyncCallableWithResources
-
Open the IO Handle (e.g.
- ActionRequestFailureHandler - Interface in org.apache.flink.streaming.connectors.elasticsearch
-
- activate(String) - Method in class org.apache.flink.storm.api.FlinkLocalCluster
-
- activate() - Method in class org.apache.flink.storm.util.AbstractLineSpout
-
- activate() - Method in class org.apache.flink.storm.util.NullTerminatingSpout
-
- ACTIVE - Static variable in class org.apache.flink.streaming.runtime.streamstatus.StreamStatus
-
- ACTIVE_STATUS - Static variable in class org.apache.flink.streaming.runtime.streamstatus.StreamStatus
-
- actor() - Method in interface org.apache.flink.runtime.instance.ActorGateway
-
Returns the underlying actor with which is communicated
- actor() - Method in class org.apache.flink.runtime.instance.AkkaActorGateway
-
Returns ActorRef
of the target actor
- ActorGateway - Interface in org.apache.flink.runtime.instance
-
Interface to abstract the communication with an actor.
- ActorGatewayCheckpointResponder - Class in org.apache.flink.runtime.taskmanager
-
- ActorGatewayCheckpointResponder(ActorGateway) - Constructor for class org.apache.flink.runtime.taskmanager.ActorGatewayCheckpointResponder
-
- ActorGatewayKvStateLocationOracle - Class in org.apache.flink.runtime.taskmanager
-
- ActorGatewayKvStateLocationOracle(ActorGateway, Time) - Constructor for class org.apache.flink.runtime.taskmanager.ActorGatewayKvStateLocationOracle
-
- ActorGatewayKvStateRegistryListener - Class in org.apache.flink.runtime.taskmanager
-
This implementation uses
ActorGateway
to forward key-value state notifications to the job
manager.
- ActorGatewayKvStateRegistryListener(ActorGateway, InetSocketAddress) - Constructor for class org.apache.flink.runtime.taskmanager.ActorGatewayKvStateRegistryListener
-
- ActorGatewayPartitionProducerStateChecker - Class in org.apache.flink.runtime.taskmanager
-
This implementation uses
ActorGateway
to trigger the partition state check at the job
manager.
- ActorGatewayPartitionProducerStateChecker(ActorGateway, FiniteDuration) - Constructor for class org.apache.flink.runtime.taskmanager.ActorGatewayPartitionProducerStateChecker
-
- ActorGatewayResultPartitionConsumableNotifier - Class in org.apache.flink.runtime.taskmanager
-
This implementation uses
ActorGateway
to notify the job manager about consumable
partitions.
- ActorGatewayResultPartitionConsumableNotifier(ExecutionContext, ActorGateway, FiniteDuration) - Constructor for class org.apache.flink.runtime.taskmanager.ActorGatewayResultPartitionConsumableNotifier
-
- ActorGatewayTaskExecutionStateListener - Class in org.apache.flink.runtime.taskmanager
-
- ActorGatewayTaskExecutionStateListener(ActorGateway) - Constructor for class org.apache.flink.runtime.taskmanager.ActorGatewayTaskExecutionStateListener
-
- ActorGatewayTaskManagerActions - Class in org.apache.flink.runtime.taskmanager
-
- ActorGatewayTaskManagerActions(ActorGateway) - Constructor for class org.apache.flink.runtime.taskmanager.ActorGatewayTaskManagerActions
-
- actorSystemLoader - Variable in class org.apache.flink.client.program.ClusterClient
-
The actor system used to communicate with the JobManager.
- ActorSystemScheduledExecutorAdapter - Class in org.apache.flink.runtime.concurrent.akka
-
- ActorSystemScheduledExecutorAdapter(ActorSystem) - Constructor for class org.apache.flink.runtime.concurrent.akka.ActorSystemScheduledExecutorAdapter
-
- ActorTaskManagerGateway - Class in org.apache.flink.runtime.jobmanager.slots
-
- ActorTaskManagerGateway(ActorGateway) - Constructor for class org.apache.flink.runtime.jobmanager.slots.ActorTaskManagerGateway
-
- ActorUtils - Class in org.apache.flink.runtime.akka
-
Utility functions for the interaction with Akka Actor
.
- actualModVersion() - Method in exception org.apache.flink.runtime.executiongraph.GlobalModVersionMismatch
-
- AdamicAdar<K extends CopyableValue<K>,VV,EV> - Class in org.apache.flink.graph.drivers
-
- AdamicAdar() - Constructor for class org.apache.flink.graph.drivers.AdamicAdar
-
- AdamicAdar<K extends CopyableValue<K>,VV,EV> - Class in org.apache.flink.graph.library.similarity
-
http://social.cs.uiuc.edu/class/cs591kgk/friendsadamic.pdf
- AdamicAdar() - Constructor for class org.apache.flink.graph.library.similarity.AdamicAdar
-
- AdamicAdar.Result<T> - Class in org.apache.flink.graph.library.similarity
-
A result for the Adamic-Adar algorithm.
- adapt(Object) - Static method in class org.apache.flink.streaming.python.util.AdapterMap
-
Convert java object to its corresponding PyObject representation.
- AdapterMap<IN> - Class in org.apache.flink.streaming.python.util
-
A generic map operator that convert any java type to PyObject.
- AdapterMap() - Constructor for class org.apache.flink.streaming.python.util.AdapterMap
-
- add(V) - Method in interface org.apache.flink.api.common.accumulators.Accumulator
-
- add(Double) - Method in class org.apache.flink.api.common.accumulators.AverageAccumulator
-
- add(double) - Method in class org.apache.flink.api.common.accumulators.AverageAccumulator
-
- add(long) - Method in class org.apache.flink.api.common.accumulators.AverageAccumulator
-
- add(int) - Method in class org.apache.flink.api.common.accumulators.AverageAccumulator
-
- add(Double) - Method in class org.apache.flink.api.common.accumulators.DoubleCounter
-
- add(double) - Method in class org.apache.flink.api.common.accumulators.DoubleCounter
-
- add(Double) - Method in class org.apache.flink.api.common.accumulators.DoubleMaximum
-
- add(double) - Method in class org.apache.flink.api.common.accumulators.DoubleMaximum
-
- add(Double) - Method in class org.apache.flink.api.common.accumulators.DoubleMinimum
-
- add(double) - Method in class org.apache.flink.api.common.accumulators.DoubleMinimum
-
- add(Integer) - Method in class org.apache.flink.api.common.accumulators.Histogram
-
- add(Integer) - Method in class org.apache.flink.api.common.accumulators.IntCounter
-
- add(int) - Method in class org.apache.flink.api.common.accumulators.IntCounter
-
- add(Integer) - Method in class org.apache.flink.api.common.accumulators.IntMaximum
-
- add(int) - Method in class org.apache.flink.api.common.accumulators.IntMaximum
-
- add(Integer) - Method in class org.apache.flink.api.common.accumulators.IntMinimum
-
- add(int) - Method in class org.apache.flink.api.common.accumulators.IntMinimum
-
- add(T) - Method in class org.apache.flink.api.common.accumulators.ListAccumulator
-
- add(Long) - Method in class org.apache.flink.api.common.accumulators.LongCounter
-
- add(long) - Method in class org.apache.flink.api.common.accumulators.LongCounter
-
- add(Long) - Method in class org.apache.flink.api.common.accumulators.LongMaximum
-
- add(long) - Method in class org.apache.flink.api.common.accumulators.LongMaximum
-
- add(Long) - Method in class org.apache.flink.api.common.accumulators.LongMinimum
-
- add(long) - Method in class org.apache.flink.api.common.accumulators.LongMinimum
-
- add(T) - Method in class org.apache.flink.api.common.accumulators.SerializedListAccumulator
-
- add(T, TypeSerializer<T>) - Method in class org.apache.flink.api.common.accumulators.SerializedListAccumulator
-
- add(IN, ACC) - Method in interface org.apache.flink.api.common.functions.AggregateFunction
-
Adds the given input value to the given accumulator, returning the
new accumulator value.
- add(IN, ACC) - Method in class org.apache.flink.api.common.functions.RichAggregateFunction
-
- add(IN) - Method in interface 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(double, double) - Method in class org.apache.flink.api.java.summarize.aggregation.CompensatedSum
-
Increments the Kahan sum by adding a value and a correction term.
- add(double) - Method in class org.apache.flink.api.java.summarize.aggregation.CompensatedSum
-
Increments the Kahan sum by adding a value without a correction term.
- add(CompensatedSum) - Method in class org.apache.flink.api.java.summarize.aggregation.CompensatedSum
-
Increments the Kahan sum by adding two sums, and updating the correction term for reducing numeric errors.
- add() - Method in class org.apache.flink.api.java.tuple.builder.Tuple0Builder
-
- add(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9) - Method in class org.apache.flink.api.java.tuple.builder.Tuple10Builder
-
- add(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10) - Method in class org.apache.flink.api.java.tuple.builder.Tuple11Builder
-
- add(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11) - Method in class org.apache.flink.api.java.tuple.builder.Tuple12Builder
-
- add(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12) - Method in class org.apache.flink.api.java.tuple.builder.Tuple13Builder
-
- add(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13) - Method in class org.apache.flink.api.java.tuple.builder.Tuple14Builder
-
- add(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14) - Method in class org.apache.flink.api.java.tuple.builder.Tuple15Builder
-
- add(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15) - Method in class org.apache.flink.api.java.tuple.builder.Tuple16Builder
-
- add(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16) - Method in class org.apache.flink.api.java.tuple.builder.Tuple17Builder
-
- add(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17) - Method in class org.apache.flink.api.java.tuple.builder.Tuple18Builder
-
- add(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18) - Method in class org.apache.flink.api.java.tuple.builder.Tuple19Builder
-
- add(T0) - Method in class org.apache.flink.api.java.tuple.builder.Tuple1Builder
-
- add(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19) - Method in class org.apache.flink.api.java.tuple.builder.Tuple20Builder
-
- add(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20) - Method in class org.apache.flink.api.java.tuple.builder.Tuple21Builder
-
- add(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, T21) - Method in class org.apache.flink.api.java.tuple.builder.Tuple22Builder
-
- add(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, T21, T22) - Method in class org.apache.flink.api.java.tuple.builder.Tuple23Builder
-
- add(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, T21, T22, T23) - Method in class org.apache.flink.api.java.tuple.builder.Tuple24Builder
-
- add(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, T21, T22, T23, T24) - Method in class org.apache.flink.api.java.tuple.builder.Tuple25Builder
-
- add(T0, T1) - Method in class org.apache.flink.api.java.tuple.builder.Tuple2Builder
-
- add(T0, T1, T2) - Method in class org.apache.flink.api.java.tuple.builder.Tuple3Builder
-
- add(T0, T1, T2, T3) - Method in class org.apache.flink.api.java.tuple.builder.Tuple4Builder
-
- add(T0, T1, T2, T3, T4) - Method in class org.apache.flink.api.java.tuple.builder.Tuple5Builder
-
- add(T0, T1, T2, T3, T4, T5) - Method in class org.apache.flink.api.java.tuple.builder.Tuple6Builder
-
- add(T0, T1, T2, T3, T4, T5, T6) - Method in class org.apache.flink.api.java.tuple.builder.Tuple7Builder
-
- add(T0, T1, T2, T3, T4, T5, T6, T7) - Method in class org.apache.flink.api.java.tuple.builder.Tuple8Builder
-
- add(T0, T1, T2, T3, T4, T5, T6, T7, T8) - Method in class org.apache.flink.api.java.tuple.builder.Tuple9Builder
-
- add(Utils.ChecksumHashCode) - Method in class org.apache.flink.api.java.Utils.ChecksumHashCode
-
- add(String) - Method in class org.apache.flink.api.java.utils.RequiredParameters
-
Add a parameter based on its name.
- add(Option) - Method in class org.apache.flink.api.java.utils.RequiredParameters
-
Add a parameter encapsulated in an
Option
object.
- add(T) - Method in class org.apache.flink.contrib.streaming.state.RocksDBAggregatingState
-
- add(T) - Method in class org.apache.flink.contrib.streaming.state.RocksDBFoldingState
-
Deprecated.
- add(V) - Method in class org.apache.flink.contrib.streaming.state.RocksDBListState
-
- add(V) - Method in class org.apache.flink.contrib.streaming.state.RocksDBReducingState
-
- add(KMeans.Point) - Method in class org.apache.flink.examples.java.clustering.KMeans.Point
-
- add(Integer) - Method in class org.apache.flink.examples.java.relational.EmptyFieldsCountAccumulator.VectorAccumulator
-
Increases the result vector component at the specified position by 1.
- add(ChecksumHashCode.Checksum) - Method in class org.apache.flink.graph.asm.dataset.ChecksumHashCode.Checksum
-
- add(ByteValue) - Method in class org.apache.flink.graph.types.valuearray.ByteValueArray
-
- add(CharValue) - Method in class org.apache.flink.graph.types.valuearray.CharValueArray
-
- add(DoubleValue) - Method in class org.apache.flink.graph.types.valuearray.DoubleValueArray
-
- add(FloatValue) - Method in class org.apache.flink.graph.types.valuearray.FloatValueArray
-
- add(IntValue) - Method in class org.apache.flink.graph.types.valuearray.IntValueArray
-
- add(LongValue) - Method in class org.apache.flink.graph.types.valuearray.LongValueArray
-
- add(NullValue) - Method in class org.apache.flink.graph.types.valuearray.NullValueArray
-
- add(ShortValue) - Method in class org.apache.flink.graph.types.valuearray.ShortValueArray
-
- add(StringValue) - Method in class org.apache.flink.graph.types.valuearray.StringValueArray
-
- add(T) - Method in interface org.apache.flink.graph.types.valuearray.ValueArray
-
Appends the value to this array if and only if the array capacity would
not be exceeded.
- add(SearchArgument.Builder) - Method in class org.apache.flink.orc.OrcRowInputFormat.Between
-
- add(SearchArgument.Builder) - Method in class org.apache.flink.orc.OrcRowInputFormat.Equals
-
- add(SearchArgument.Builder) - Method in class org.apache.flink.orc.OrcRowInputFormat.In
-
- add(SearchArgument.Builder) - Method in class org.apache.flink.orc.OrcRowInputFormat.IsNull
-
- add(SearchArgument.Builder) - Method in class org.apache.flink.orc.OrcRowInputFormat.LessThan
-
- add(SearchArgument.Builder) - Method in class org.apache.flink.orc.OrcRowInputFormat.LessThanEquals
-
- add(SearchArgument.Builder) - Method in class org.apache.flink.orc.OrcRowInputFormat.Not
-
- add(SearchArgument.Builder) - Method in class org.apache.flink.orc.OrcRowInputFormat.NullSafeEquals
-
- add(SearchArgument.Builder) - Method in class org.apache.flink.orc.OrcRowInputFormat.Or
-
- add(SearchArgument.Builder) - Method in class org.apache.flink.orc.OrcRowInputFormat.Predicate
-
- add(int, D) - Method in class org.apache.flink.python.api.util.SetCache
-
Adds the given
DataSet
to this cache for the given ID.
- add(int, U) - Method in class org.apache.flink.python.api.util.SetCache
-
- add(int, S) - Method in class org.apache.flink.python.api.util.SetCache
-
- add(Object) - Method in class org.apache.flink.queryablestate.client.state.ImmutableAggregatingState
-
- add(Object) - Method in class org.apache.flink.queryablestate.client.state.ImmutableFoldingState
-
Deprecated.
- add(V) - Method in class org.apache.flink.queryablestate.client.state.ImmutableListState
-
- add(V) - Method in class org.apache.flink.queryablestate.client.state.ImmutableReducingState
-
- add(T) - Method in class org.apache.flink.runtime.checkpoint.StateObjectCollection
-
- add(BufferConsumer) - Method in class org.apache.flink.runtime.io.network.partition.ResultSubpartition
-
Adds the given buffer.
- add(MetricDump) - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.MetricStore
-
- add(IN) - Method in class org.apache.flink.runtime.state.heap.HeapAggregatingState
-
- add(T) - Method in class org.apache.flink.runtime.state.heap.HeapFoldingState
-
Deprecated.
- add(V) - Method in class org.apache.flink.runtime.state.heap.HeapListState
-
- add(V) - Method in class org.apache.flink.runtime.state.heap.HeapReducingState
-
- add(Task) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlot
-
Add the given task to the task slot.
- add(T) - Method in class org.apache.flink.runtime.util.EvictingBoundedList
-
- add(int) - Method in class org.apache.flink.runtime.util.IntArrayList
-
- add(long) - Method in class org.apache.flink.runtime.util.LongArrayList
-
- add(Object, Object) - Method in class org.apache.flink.streaming.api.functions.aggregation.SumFunction
-
- add(Extractor<TO, OUT>) - Method in class org.apache.flink.streaming.api.functions.windowing.delta.extractor.ConcatenatedExtract
-
- add(ActionRequest...) - Method in interface org.apache.flink.streaming.connectors.elasticsearch.RequestIndexer
-
Add multiple ActionRequest
to the indexer to prepare for sending requests to Elasticsearch.
- add(ActionRequest...) - Method in interface org.apache.flink.streaming.connectors.elasticsearch2.RequestIndexer
-
Deprecated.
- add(E) - Method in class org.apache.flink.streaming.connectors.kafka.internals.ClosableBlockingQueue
-
Adds the element to the queue, or fails with an exception, if the queue is closed.
- add(BufferOrEvent) - Method in interface org.apache.flink.streaming.runtime.io.BufferBlocker
-
Adds a buffer or event to the blocker.
- add(BufferOrEvent) - Method in class org.apache.flink.streaming.runtime.io.BufferSpiller
-
Deprecated.
Adds a buffer or event to the sequence of spilled buffers and events.
- add(BufferOrEvent) - Method in class org.apache.flink.streaming.runtime.io.CachedBufferBlocker
-
- add(int, V) - Method in class org.apache.flink.types.ListValue
-
- add(V) - Method in class org.apache.flink.types.ListValue
-
- add(Iterator<T>) - Method in class org.apache.flink.util.UnionIterator
-
- add_java_source(SourceFunction<Object>) - Method in class org.apache.flink.streaming.python.api.environment.PythonStreamExecutionEnvironment
-
Add a java source to the streaming topology.
- add_sink(SinkFunction<PyObject>) - Method in class org.apache.flink.streaming.python.api.datastream.PythonDataStream
-
- addAccumulator(String, Accumulator<V, A>) - Method in interface org.apache.flink.api.common.functions.RuntimeContext
-
Add this accumulator.
- addAccumulator(String, Accumulator<V, A>) - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
-
- addAccumulator(String, Accumulator<V, A>) - Method in class org.apache.flink.graph.AnalyticHelper
-
Adds an accumulator by prepending the given name with a random string.
- addAll(AggregatorRegistry) - Method in class org.apache.flink.api.common.aggregators.AggregatorRegistry
-
- addAll(List<T>) - Method in interface 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) - Method in class org.apache.flink.configuration.Configuration
-
- addAll(Configuration, String) - Method in class org.apache.flink.configuration.Configuration
-
Adds all entries from the given configuration into this configuration.
- addAll(Configuration) - Method in class org.apache.flink.configuration.DelegatingConfiguration
-
- addAll(Configuration, String) - Method in class org.apache.flink.configuration.DelegatingConfiguration
-
- addAll(Configuration) - Method in class org.apache.flink.configuration.UnmodifiableConfiguration
-
- addAll(Configuration, String) - Method in class org.apache.flink.configuration.UnmodifiableConfiguration
-
- addAll(List<V>) - Method in class org.apache.flink.contrib.streaming.state.RocksDBListState
-
- addAll(ValueArray<ByteValue>) - Method in class org.apache.flink.graph.types.valuearray.ByteValueArray
-
- addAll(ValueArray<CharValue>) - Method in class org.apache.flink.graph.types.valuearray.CharValueArray
-
- addAll(ValueArray<DoubleValue>) - Method in class org.apache.flink.graph.types.valuearray.DoubleValueArray
-
- addAll(ValueArray<FloatValue>) - Method in class org.apache.flink.graph.types.valuearray.FloatValueArray
-
- addAll(ValueArray<IntValue>) - Method in class org.apache.flink.graph.types.valuearray.IntValueArray
-
- addAll(ValueArray<LongValue>) - Method in class org.apache.flink.graph.types.valuearray.LongValueArray
-
- addAll(ValueArray<NullValue>) - Method in class org.apache.flink.graph.types.valuearray.NullValueArray
-
- addAll(ValueArray<ShortValue>) - Method in class org.apache.flink.graph.types.valuearray.ShortValueArray
-
- addAll(ValueArray<StringValue>) - Method in class org.apache.flink.graph.types.valuearray.StringValueArray
-
- addAll(ValueArray<T>) - Method in interface org.apache.flink.graph.types.valuearray.ValueArray
-
Appends all of the values in the specified array to the end of this
array.
- addAll(List<V>) - Method in class org.apache.flink.queryablestate.client.state.ImmutableListState
-
- addAll(Collection<? extends T>) - Method in class org.apache.flink.runtime.checkpoint.StateObjectCollection
-
- addAll(List<V>) - Method in class org.apache.flink.runtime.state.heap.HeapListState
-
- addAll(List<T>) - Method in interface org.apache.flink.runtime.state.internal.InternalListState
-
Updates the operator state accessible by
AppendingState.get()
by adding the given values
to existing list of values.
- addAll(Collection<? extends V>) - Method in class org.apache.flink.types.ListValue
-
- addAll(int, Collection<? extends V>) - Method in class org.apache.flink.types.ListValue
-
- addAllToProperties(Properties) - Method in class org.apache.flink.configuration.Configuration
-
Adds all entries in this
Configuration
to the given
Properties
.
- addAllToProperties(Properties) - Method in class org.apache.flink.configuration.DelegatingConfiguration
-
- addAllToProperties(Properties) - Method in class org.apache.flink.configuration.UnmodifiableConfiguration
-
- addAndLock(String, T) - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
-
Creates a state handle, stores it in ZooKeeper and locks it.
- addAppConfigurationEntry(String, AppConfigurationEntry...) - Method in class org.apache.flink.runtime.security.DynamicConfiguration
-
Add entries for the given application name.
- addArtificialDamCost(EstimateProvider, long, Costs) - Method in class org.apache.flink.optimizer.costs.CostEstimator
-
- addArtificialDamCost(EstimateProvider, long, Costs) - Method in class org.apache.flink.optimizer.costs.DefaultCostEstimator
-
- addAvroGenericDataArrayRegistration(LinkedHashMap<String, KryoRegistration>) - Method in class org.apache.flink.api.java.typeutils.AvroUtils
-
Registers a special Serializer for GenericData.Array.
- addAvroGenericDataArrayRegistration(LinkedHashMap<String, KryoRegistration>) - Method in class org.apache.flink.formats.avro.utils.AvroKryoSerializerUtils
-
- addAvroSerializersIfRequired(ExecutionConfig, Class<?>) - Method in class org.apache.flink.api.java.typeutils.AvroUtils
-
Loads the utility class from flink-avro
and adds Avro-specific serializers.
- addAvroSerializersIfRequired(ExecutionConfig, Class<?>) - Method in class org.apache.flink.formats.avro.utils.AvroKryoSerializerUtils
-
- addBlob(PermanentBlobKey) - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
Adds the BLOB referenced by the key to the JobGraph's dependencies.
- addBlockNestedLoopsCosts(EstimateProvider, EstimateProvider, long, Costs, int) - Method in class org.apache.flink.optimizer.costs.CostEstimator
-
- addBlockNestedLoopsCosts(EstimateProvider, EstimateProvider, long, Costs, int) - Method in class org.apache.flink.optimizer.costs.DefaultCostEstimator
-
- addBroadcastConnection(String, DagConnection) - Method in class org.apache.flink.optimizer.dag.OptimizerNode
-
Adds the broadcast connection identified by the given name
to this node.
- addBroadcastCost(EstimateProvider, int, Costs) - Method in class org.apache.flink.optimizer.costs.CostEstimator
-
- addBroadcastCost(EstimateProvider, int, Costs) - Method in class org.apache.flink.optimizer.costs.DefaultCostEstimator
-
- addBroadcastInputToGroup(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- addBroadcastSet(String, DataSet<?>) - Method in class org.apache.flink.graph.pregel.VertexCentricConfiguration
-
Adds a data set as a broadcast set to the compute function.
- addBroadcastSetForApplyFunction(String, DataSet<?>) - Method in class org.apache.flink.graph.gsa.GSAConfiguration
-
Adds a data set as a broadcast set to the apply function.
- addBroadcastSetForGatherFunction(String, DataSet<?>) - Method in class org.apache.flink.graph.gsa.GSAConfiguration
-
Adds a data set as a broadcast set to the gather function.
- addBroadcastSetForGatherFunction(String, DataSet<?>) - Method in class org.apache.flink.graph.spargel.ScatterGatherConfiguration
-
Adds a data set as a broadcast set to the gather function.
- addBroadcastSetForScatterFunction(String, DataSet<?>) - Method in class org.apache.flink.graph.spargel.ScatterGatherConfiguration
-
Adds a data set as a broadcast set to the scatter function.
- addBroadcastSetForSumFunction(String, DataSet<?>) - Method in class org.apache.flink.graph.gsa.GSAConfiguration
-
Adds a data set as a broadcast set to the sum function.
- addBufferConsumer(BufferConsumer, int) - Method in interface org.apache.flink.runtime.io.network.api.writer.ResultPartitionWriter
-
Adds the bufferConsumer to the subpartition with the given index.
- addBufferConsumer(BufferConsumer, int) - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
-
- addBufferListener(BufferListener) - Method in interface org.apache.flink.runtime.io.network.buffer.BufferProvider
-
Adds a buffer availability listener to the buffer provider.
- addCachedHybridHashCosts(EstimateProvider, EstimateProvider, Costs, int) - Method in class org.apache.flink.optimizer.costs.CostEstimator
-
- addCachedHybridHashCosts(EstimateProvider, EstimateProvider, Costs, int) - Method in class org.apache.flink.optimizer.costs.DefaultCostEstimator
-
Calculates the costs for the cached variant of the hybrid hash join.
- addChainedTask(Class<? extends ChainedDriver>, TaskConfig, String) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- addCheckpoint(CompletedCheckpoint) - Method in interface org.apache.flink.runtime.checkpoint.CompletedCheckpointStore
-
- addCheckpoint(CompletedCheckpoint) - Method in class org.apache.flink.runtime.checkpoint.StandaloneCompletedCheckpointStore
-
- addCheckpoint(CompletedCheckpoint) - Method in class org.apache.flink.runtime.checkpoint.ZooKeeperCompletedCheckpointStore
-
Synchronously writes the new checkpoints to ZooKeeper and asynchronously removes older ones.
- addChoices(String...) - Method in class org.apache.flink.graph.drivers.parameter.ChoiceParameter
-
Add additional choices.
- addClass(Class<?>) - Method in class org.apache.flink.runtime.util.JarFileCreator
-
Adds a
Class
object to the set of classes which shall eventually be included in the jar file.
- addCloseableInternal(Closeable, T) - Method in class org.apache.flink.util.AbstractCloseableRegistry
-
Adds a mapping to the registry map, respecting locking.
- addClosedBranch(OptimizerNode) - Method in class org.apache.flink.optimizer.dag.OptimizerNode
-
- addClosedBranches(Set<OptimizerNode>) - Method in class org.apache.flink.optimizer.dag.OptimizerNode
-
- addColumn(String, String, Class<?>) - Method in class org.apache.flink.addons.hbase.HBaseTableSource
-
Adds a column defined by family, qualifier, and type to the table schema.
- addComparatorField(int, TypeComparator<?>) - Method in interface org.apache.flink.api.common.typeutils.CompositeType.TypeComparatorBuilder
-
- addConnectorProperties(DescriptorProperties) - Method in class org.apache.flink.table.descriptors.Kafka
-
Internal method for connector properties conversion.
- addConsumer(JobEdge) - Method in class org.apache.flink.runtime.jobgraph.IntermediateDataSet
-
- addContainerMapping(String, TaggedValue, ModifiedASMFrame) - Method in class org.apache.flink.api.java.sca.TaggedValue
-
- addCoOperator(Integer, String, TwoInputStreamOperator<IN1, IN2, OUT>, TypeInformation<IN1>, TypeInformation<IN2>, TypeInformation<OUT>, String) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- addCosts(Costs) - Method in class org.apache.flink.optimizer.costs.Costs
-
Adds the given costs to these costs.
- addCpuCost(double) - Method in class org.apache.flink.optimizer.costs.Costs
-
Adds the given CPU cost to the current CPU cost for this Costs object.
- addCredit(int) - Method in interface org.apache.flink.runtime.io.network.NetworkSequenceViewReader
-
The credits from consumer are added in incremental way.
- addDataSink(GenericDataSinkBase<?>) - Method in class org.apache.flink.api.common.Plan
-
Adds a data sink to the set of sinks in this program.
- addDefaultKryoSerializer(Class<?>, T) - Method in class org.apache.flink.api.common.ExecutionConfig
-
Adds a new Kryo default serializer to the Runtime.
- addDefaultKryoSerializer(Class<?>, Class<? extends Serializer<?>>) - Method in class org.apache.flink.api.common.ExecutionConfig
-
Adds a new Kryo default serializer to the Runtime.
- addDefaultKryoSerializer(Class<?>, T) - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
Adds a new Kryo default serializer to the Runtime.
- addDefaultKryoSerializer(Class<?>, Class<? extends Serializer<?>>) - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
Adds a new Kryo default serializer to the Runtime.
- addDefaultKryoSerializer(Class<?>, T) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Adds a new Kryo default serializer to the Runtime.
- addDefaultKryoSerializer(Class<?>, Class<? extends Serializer<?>>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Adds a new Kryo default serializer to the Runtime.
- addDefaultResource(String) - Static method in class org.apache.hadoop.conf.Configuration
-
Add a default resource.
- addDeprecation(String, String[], String) - Static method in class org.apache.hadoop.conf.Configuration
-
- addDeprecation(String, String, String) - Static method in class org.apache.hadoop.conf.Configuration
-
Adds the deprecated key to the global deprecation map.
- addDeprecation(String, String[]) - Static method in class org.apache.hadoop.conf.Configuration
-
- addDeprecation(String, String) - Static method in class org.apache.hadoop.conf.Configuration
-
Adds the deprecated key to the global deprecation map when no custom
message is provided.
- addDeprecations(Configuration.DeprecationDelta[]) - Static method in class org.apache.hadoop.conf.Configuration
-
Adds a set of deprecated keys to the global deprecations.
- addDimension(long, boolean) - Method in class org.apache.flink.graph.generator.GridGraph
-
Required configuration for each dimension of the graph.
- addDiscoveredPartitions(List<KafkaTopicPartition>) - Method in class org.apache.flink.streaming.connectors.kafka.internals.AbstractFetcher
-
Adds a list of newly discovered partitions to the fetcher for consuming.
- addDiskCost(double) - Method in class org.apache.flink.optimizer.costs.Costs
-
Adds the costs for disk to the current disk costs
for this Costs object.
- addEdge(Vertex<K, VV>, Vertex<K, VV>, EV) - Method in class org.apache.flink.graph.Graph
-
Adds the given edge to the graph.
- addEdge(Integer, Integer, int) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- addEdges(List<Edge<K, EV>>) - Method in class org.apache.flink.graph.Graph
-
Adds the given list edges to the graph.
- addFeedbackEdge(StreamTransformation<F>) - Method in class org.apache.flink.streaming.api.transformations.CoFeedbackTransformation
-
Adds a feedback edge.
- addFeedbackEdge(StreamTransformation<T>) - Method in class org.apache.flink.streaming.api.transformations.FeedbackTransformation
-
Adds a feedback edge.
- addField(Integer) - Method in class org.apache.flink.api.common.operators.util.FieldList
-
- addField(Integer) - Method in class org.apache.flink.api.common.operators.util.FieldSet
-
- addField(Value) - Method in class org.apache.flink.types.Record
-
- addFields(int...) - Method in class org.apache.flink.api.common.operators.util.FieldList
-
- addFields(FieldSet) - Method in class org.apache.flink.api.common.operators.util.FieldList
-
- addFields(int...) - Method in class org.apache.flink.api.common.operators.util.FieldSet
-
- addFields(FieldSet) - Method in class org.apache.flink.api.common.operators.util.FieldSet
-
- addFile(File, String) - Method in class org.apache.flink.mesos.util.MesosArtifactServer
-
Adds a file to the artifact server.
- addFileInputCost(long, Costs) - Method in class org.apache.flink.optimizer.costs.CostEstimator
-
- addFileInputCost(long, Costs) - Method in class org.apache.flink.optimizer.costs.DefaultCostEstimator
-
- addFirstInput(Operator<IN1>...) - Method in class org.apache.flink.api.common.operators.DualInputOperator
-
- addFirstInputs(List<Operator<IN1>>) - Method in class org.apache.flink.api.common.operators.DualInputOperator
-
- addFormatProperties(DescriptorProperties) - Method in class org.apache.flink.table.descriptors.Json
-
Internal method for format properties conversion.
- addForwardedField(int, int, int) - Method in class org.apache.flink.api.common.operators.DualInputSemanticProperties
-
Adds, to the existing information, a field that is forwarded directly
from the source record(s) in the first input to the destination
record(s).
- addForwardedField(int, int) - Method in class org.apache.flink.api.common.operators.SingleInputSemanticProperties
-
Adds, to the existing information, a field that is forwarded directly
from the source record(s) to the destination record(s).
- addForwardedField(int, int) - Method in class org.apache.flink.api.common.operators.SingleInputSemanticProperties.AllFieldsForwardedProperties
-
- addGeneralOptions(Options) - Method in class org.apache.flink.client.cli.AbstractCustomCommandLine
-
- addGeneralOptions(Options) - Method in interface org.apache.flink.client.cli.CustomCommandLine
-
Adds custom options to the existing general options.
- addGeneralOptions(Options) - Method in class org.apache.flink.client.cli.DefaultCLI
-
- addGeneralOptions(Options) - Method in class org.apache.flink.yarn.cli.FlinkYarnSessionCli
-
- addGlobalProperties(RequestedGlobalProperties) - Method in class org.apache.flink.optimizer.dataproperties.InterestingProperties
-
- addGroup(int) - Method in class org.apache.flink.metrics.groups.UnregisteredMetricsGroup
-
- addGroup(String) - Method in class org.apache.flink.metrics.groups.UnregisteredMetricsGroup
-
- addGroup(String, String) - Method in class org.apache.flink.metrics.groups.UnregisteredMetricsGroup
-
- addGroup(int) - Method in interface org.apache.flink.metrics.MetricGroup
-
Creates a new MetricGroup and adds it to this groups sub-groups.
- addGroup(String) - Method in interface org.apache.flink.metrics.MetricGroup
-
Creates a new MetricGroup and adds it to this groups sub-groups.
- addGroup(String, String) - Method in interface org.apache.flink.metrics.MetricGroup
-
Creates a new key-value MetricGroup pair.
- addGroup(int) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
-
- addGroup(String) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
-
- addGroup(String, String) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
-
- addGroup(String, String) - Method in class org.apache.flink.runtime.metrics.groups.GenericKeyMetricGroup
-
- addGroup(int) - Method in class org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
-
- addGroup(String) - Method in class org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
-
- addGroup(String, String) - Method in class org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
-
- addHash(int) - Method in class org.apache.flink.runtime.operators.util.BloomFilter
-
- addHashPartitioningCost(EstimateProvider, Costs) - Method in class org.apache.flink.optimizer.costs.CostEstimator
-
- addHashPartitioningCost(EstimateProvider, Costs) - Method in class org.apache.flink.optimizer.costs.DefaultCostEstimator
-
- addHeuristicCpuCost(double) - Method in class org.apache.flink.optimizer.costs.Costs
-
Adds the given heuristic CPU cost to the current heuristic CPU cost for this Costs object.
- addHeuristicDiskCost(double) - Method in class org.apache.flink.optimizer.costs.Costs
-
Adds the heuristic costs for disk to the current heuristic disk costs
for this Costs object.
- addHeuristicNetworkCost(double) - Method in class org.apache.flink.optimizer.costs.Costs
-
Adds the heuristic costs for network to the current heuristic network costs
for this Costs object.
- addHiddenChoices(String...) - Method in class org.apache.flink.graph.drivers.parameter.ChoiceParameter
-
Add additional hidden choices.
- addHybridHashCosts(EstimateProvider, EstimateProvider, Costs, int) - Method in class org.apache.flink.optimizer.costs.CostEstimator
-
- addHybridHashCosts(EstimateProvider, EstimateProvider, Costs, int) - Method in class org.apache.flink.optimizer.costs.DefaultCostEstimator
-
- addId(UId) - Method in class org.apache.flink.streaming.api.functions.source.MessageAcknowledgingSourceBase
-
Adds an ID to be stored with the current checkpoint.
- addIfOpen(E) - Method in class org.apache.flink.streaming.connectors.kafka.internals.ClosableBlockingQueue
-
Tries to add an element to the queue, if the queue is still open.
- addIgnore(IterativeCondition<T>) - Method in class org.apache.flink.cep.nfa.State
-
- addIgnore(State<T>, IterativeCondition<T>) - Method in class org.apache.flink.cep.nfa.State
-
- addInEdge(StreamEdge) - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- addInput(Operator<IN>...) - Method in class org.apache.flink.api.common.operators.GenericDataSinkBase
-
- addInput(Operator<IN>...) - Method in class org.apache.flink.api.common.operators.SingleInputOperator
-
- addInput(List<Operator<IN>>) - Method in class org.apache.flink.api.common.operators.SingleInputOperator
-
- addInputChannel(RemoteInputChannel) - Method in interface org.apache.flink.runtime.io.network.NetworkClientHandler
-
- addInputs(List<? extends Operator<IN>>) - Method in class org.apache.flink.api.common.operators.GenericDataSinkBase
-
- addInputToGroup(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- addInstanceListener(InstanceListener) - Method in class org.apache.flink.runtime.instance.InstanceManager
-
- addInterestingProperties(InterestingProperties) - Method in class org.apache.flink.optimizer.dataproperties.InterestingProperties
-
- addIOMetrics(AccessExecution, MetricFetcher, String, String) - Method in class org.apache.flink.runtime.rest.handler.util.MutableIOMetrics
-
Adds the IO metrics for the given attempt to this object.
- addIterationAggregator(String, Aggregator<?>) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- addIterationAggregators(Collection<AggregatorWithName<?>>) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- addJar(Path) - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
Adds the path of a JAR file required to run the job on a task manager.
- addJob(JobGraph) - Method in class org.apache.flink.runtime.metrics.groups.JobManagerMetricGroup
-
- addJob(JobGraph) - Method in class org.apache.flink.runtime.metrics.groups.UnregisteredMetricGroups.UnregisteredJobManagerMetricGroup
-
- addJob(JobID) - Method in class org.apache.flink.runtime.resourcemanager.JobLeaderIdService
-
Add a job to be monitored to retrieve the job leader id.
- addJob(JobID, String) - Method in class org.apache.flink.runtime.taskexecutor.JobLeaderService
-
Add the given job to be monitored.
- addLibFolderToShipFiles(Collection<File>) - Method in class org.apache.flink.yarn.AbstractYarnClusterDescriptor
-
- addList(List<T>) - Method in class org.apache.flink.util.UnionIterator
-
- addLocalCandidates(Channel, List<Set<? extends NamedChannel>>, RequestedGlobalProperties, List<PlanNode>, CostEstimator) - Method in class org.apache.flink.optimizer.dag.SingleInputNode
-
- addLocalCandidates(Channel, Channel, List<Set<? extends NamedChannel>>, RequestedGlobalProperties, RequestedGlobalProperties, List<PlanNode>, OperatorDescriptorDual.LocalPropertiesPair[], CostEstimator) - Method in class org.apache.flink.optimizer.dag.TwoInputNode
-
- addLocalMergeCost(EstimateProvider, EstimateProvider, Costs, int) - Method in class org.apache.flink.optimizer.costs.CostEstimator
-
- addLocalMergeCost(EstimateProvider, EstimateProvider, Costs, int) - Method in class org.apache.flink.optimizer.costs.DefaultCostEstimator
-
- addLocalProperties(RequestedLocalProperties) - Method in class org.apache.flink.optimizer.dataproperties.InterestingProperties
-
- addLocalSortCost(EstimateProvider, Costs) - Method in class org.apache.flink.optimizer.costs.CostEstimator
-
- addLocalSortCost(EstimateProvider, Costs) - Method in class org.apache.flink.optimizer.costs.DefaultCostEstimator
-
- AddLongValue() - Constructor for class org.apache.flink.graph.utils.GraphUtils.AddLongValue
-
- addMasterHook(MasterTriggerRestoreHook<?>) - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
Adds the given master hook to the checkpoint coordinator.
- addMasterState(MasterState) - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
-
Adds a master state (state generated on the checkpoint coordinator) to
the pending checkpoint.
- addMetric(DMetric) - Method in class org.apache.flink.metrics.datadog.DSeries
-
- addMetric(String, Metric) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
-
Adds the given metric to the group and registers it at the registry, if the group
is not yet closed, and if no metric with the same name has been registered before.
- addMonths(long, int) - Static method in class org.apache.calcite.avatica.util.DateTimeUtils
-
Adds a given number of months to a timestamp, represented as the number
of milliseconds since the epoch.
- addMonths(int, int) - Static method in class org.apache.calcite.avatica.util.DateTimeUtils
-
Adds a given number of months to a date, represented as the number of
days since the epoch.
- addNameSpace(Set<String>) - Method in class org.apache.flink.runtime.util.DependencyVisitor
-
- addNetworkCost(double) - Method in class org.apache.flink.optimizer.costs.Costs
-
Adds the costs for network to the current network costs
for this Costs object.
- addNode(Integer, String, Class<? extends AbstractInvokable>, StreamOperator<?>, String) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- addOperator(String) - Method in class org.apache.flink.runtime.metrics.groups.TaskMetricGroup
-
- addOperator(OperatorID, String) - Method in class org.apache.flink.runtime.metrics.groups.TaskMetricGroup
-
- addOperator(OperatorID, String) - Method in class org.apache.flink.runtime.metrics.groups.UnregisteredMetricGroups.UnregisteredTaskMetricGroup
-
- addOperator(StreamTransformation<?>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- addOperator(Integer, String, StreamOperator<OUT>, TypeInformation<IN>, TypeInformation<OUT>, String) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- addOutEdge(StreamEdge) - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- addOutgoingChannel(Channel) - Method in class org.apache.flink.optimizer.plan.PlanNode
-
Adds a channel to a successor node to this node.
- addOutgoingConnection(DagConnection) - Method in class org.apache.flink.optimizer.dag.BinaryUnionNode
-
- addOutgoingConnection(DagConnection) - Method in class org.apache.flink.optimizer.dag.OptimizerNode
-
Adds a new outgoing connection to this node.
- addOutputSelector(Integer, OutputSelector<T>) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- addOutputSelector(OutputSelector<?>) - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- addOutputShipStrategy(ShipStrategyType) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- addPackage(String) - Method in class org.apache.flink.runtime.util.JarFileCreator
-
Manually specify the package of the dependencies.
- addPackages(String[]) - Method in class org.apache.flink.runtime.util.JarFileCreator
-
Manually specify the packages of the dependencies.
- addParameter(Parameter<?>) - Method in class org.apache.flink.graph.drivers.parameter.ParameterizedBase
-
Adds a parameter to the list.
- addPath(Path, Path) - Method in class org.apache.flink.mesos.util.MesosArtifactServer
-
Adds a path to the artifact server.
- addPredicate(OrcRowInputFormat.Predicate) - Method in class org.apache.flink.orc.OrcRowInputFormat
-
Adds a filter predicate to reduce the number of rows to be returned by the input format.
- addProceed(State<T>, IterativeCondition<T>) - Method in class org.apache.flink.cep.nfa.State
-
- addProperties(DescriptorProperties) - Method in class org.apache.flink.table.client.config.Source
-
- addRandomPartitioningCost(EstimateProvider, Costs) - Method in class org.apache.flink.optimizer.costs.CostEstimator
-
- addRandomPartitioningCost(EstimateProvider, Costs) - Method in class org.apache.flink.optimizer.costs.DefaultCostEstimator
-
- addRange(long, long) - Method in class org.apache.flink.graph.generator.CirculantGraph
-
Required configuration for each range of offsets in the graph.
- addRangePartitionCost(EstimateProvider, Costs) - Method in class org.apache.flink.optimizer.costs.CostEstimator
-
- addRangePartitionCost(EstimateProvider, Costs) - Method in class org.apache.flink.optimizer.costs.DefaultCostEstimator
-
- addReadFields(int, FieldSet) - Method in class org.apache.flink.api.common.operators.DualInputSemanticProperties
-
Adds, to the existing information, field(s) that are read in
the source record(s) from the first input.
- addReadFields(FieldSet) - Method in class org.apache.flink.api.common.operators.SingleInputSemanticProperties
-
Adds, to the existing information, field(s) that are read in
the source record(s).
- addRecord(T) - Method in interface org.apache.flink.runtime.io.network.api.serialization.RecordSerializer
-
Starts serializing and copying the given record to the target buffer
(if available).
- addRecord(T) - Method in class org.apache.flink.runtime.io.network.api.serialization.SpanningRecordSerializer
-
Serializes the complete record to an intermediate data serialization
buffer and starts copying it to the target buffer (if available).
- addRecord(T) - Method in class org.apache.flink.runtime.operators.sort.LargeRecordHandler
-
- addRequest(R) - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousFileIOChannel
-
- addResource(String) - Method in class org.apache.hadoop.conf.Configuration
-
Add a configuration resource.
- addResource(URL) - Method in class org.apache.hadoop.conf.Configuration
-
Add a configuration resource.
- addResource(Path) - Method in class org.apache.hadoop.conf.Configuration
-
Add a configuration resource.
- addResource(InputStream) - Method in class org.apache.hadoop.conf.Configuration
-
Add a configuration resource.
- addResource(InputStream, String) - Method in class org.apache.hadoop.conf.Configuration
-
Add a configuration resource.
- addResource(Configuration) - Method in class org.apache.hadoop.conf.Configuration
-
Add a configuration resource.
- ADDRESS - Static variable in class org.apache.flink.configuration.JobManagerOptions
-
The config parameter defining the network address to connect to
for communication with the job manager.
- ADDRESS - Static variable in class org.apache.flink.configuration.RestOptions
-
The address that should be used by clients to connect to the server.
- ADDRESS - Static variable in class org.apache.flink.configuration.WebOptions
-
Config parameter defining the runtime monitor web-frontend server address.
- address - Variable in class org.apache.flink.core.memory.MemorySegment
-
The address to the data, relative to the heap memory byte array.
- address() - Method in class org.apache.flink.runtime.taskmanager.TaskManagerLocation
-
Returns the network address the instance's task manager binds its sockets to.
- address() - Method in class org.apache.flink.streaming.examples.statemachine.event.Alert
-
- ADDRESS_OPTION - Static variable in class org.apache.flink.client.cli.CliFrontendParser
-
- addressLimit - Variable in class org.apache.flink.core.memory.MemorySegment
-
The address one byte after the last addressable byte, i.e.
- addressOption - Variable in class org.apache.flink.client.cli.AbstractCustomCommandLine
-
- addressString() - Method in class org.apache.flink.runtime.taskmanager.TaskManagerLocation
-
Gets the IP address where the TaskManager operates.
- addRunOptions(Options) - Method in class org.apache.flink.client.cli.AbstractCustomCommandLine
-
- addRunOptions(Options) - Method in interface org.apache.flink.client.cli.CustomCommandLine
-
Adds custom options to the existing run options.
- addRunOptions(Options) - Method in class org.apache.flink.yarn.cli.FlinkYarnSessionCli
-
- addSecondInput(Operator<IN2>...) - Method in class org.apache.flink.api.common.operators.DualInputOperator
-
- addSecondInputs(List<Operator<IN2>>) - Method in class org.apache.flink.api.common.operators.DualInputOperator
-
- addSemanticPropertiesHints() - Method in class org.apache.flink.api.java.sca.UdfAnalyzer
-
- addSharedSlotAndAllocateSubSlot(SharedSlot, Locality, JobVertexID) - Method in class org.apache.flink.runtime.instance.SlotSharingGroupAssignment
-
- addSharedSlotAndAllocateSubSlot(SharedSlot, Locality, CoLocationConstraint) - Method in class org.apache.flink.runtime.instance.SlotSharingGroupAssignment
-
- addShipFiles(List<File>) - Method in class org.apache.flink.yarn.AbstractYarnClusterDescriptor
-
Adds the given files to the list of files to ship.
- addShutdownHook(AutoCloseable, String, Logger) - Static method in class org.apache.flink.util.ShutdownHookUtil
-
Adds a shutdown hook to the JVM and returns the Thread, which has been registered.
- addShutdownHookThread(Thread, String, Logger) - Static method in class org.apache.flink.util.ShutdownHookUtil
-
Adds a shutdown hook to the JVM and returns the Thread, which has been registered.
- addSink(SinkFunction<T>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Adds the given sink to this DataStream.
- addSink(SinkFunction<T>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
- addSink(Integer, String, StreamOperator<OUT>, TypeInformation<IN>, TypeInformation<OUT>, String) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- addSink(DataStream<IN>) - Static method in class org.apache.flink.streaming.connectors.cassandra.CassandraSink
-
Writes a DataStream into a Cassandra database.
- addSink(DataStream<IN>) - Static method in class org.apache.flink.streaming.connectors.cassandra.CassandraSink
-
Writes a DataStream into a Cassandra database.
- addSource(SourceFunction<OUT>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Adds a Data Source to the streaming topology.
- addSource(SourceFunction<OUT>, String) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Ads a data source with a custom type information thus opening a
DataStream
.
- addSource(SourceFunction<OUT>, TypeInformation<OUT>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Ads a data source with a custom type information thus opening a
DataStream
.
- addSource(SourceFunction<OUT>, String, TypeInformation<OUT>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Ads a data source with a custom type information thus opening a
DataStream
.
- addSource(Integer, String, StreamOperator<OUT>, TypeInformation<IN>, TypeInformation<OUT>, String) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- addSourceFieldOffset(SingleInputSemanticProperties, int, int) - Static method in class org.apache.flink.api.java.functions.SemanticPropUtil
-
Creates SemanticProperties by adding an offset to each input field index of the given SemanticProperties.
- addSourceFieldOffsets(DualInputSemanticProperties, int, int, int, int) - Static method in class org.apache.flink.api.java.functions.SemanticPropUtil
-
Creates SemanticProperties by adding offsets to each input field index of the given SemanticProperties.
- addStage() - Method in class org.apache.flink.cep.nfa.DeweyNumber
-
Creates a new dewey number from this such that a 0 is appended as new last digit.
- addState(State<T>) - Method in class org.apache.flink.cep.nfa.NFA
-
- addStates(Collection<State<T>>) - Method in class org.apache.flink.cep.nfa.NFA
-
- addStateTransition(StateTransitionAction, State<T>, IterativeCondition<T>) - Method in class org.apache.flink.cep.nfa.State
-
- addStreamedNestedLoopsCosts(EstimateProvider, EstimateProvider, long, Costs, int) - Method in class org.apache.flink.optimizer.costs.CostEstimator
-
- addStreamedNestedLoopsCosts(EstimateProvider, EstimateProvider, long, Costs, int) - Method in class org.apache.flink.optimizer.costs.DefaultCostEstimator
-
- addTake(State<T>, IterativeCondition<T>) - Method in class org.apache.flink.cep.nfa.State
-
- addTake(IterativeCondition<T>) - Method in class org.apache.flink.cep.nfa.State
-
- addTask(JobVertexID, ExecutionAttemptID, String, int, int) - Method in class org.apache.flink.runtime.metrics.groups.TaskManagerJobMetricGroup
-
- addTask(JobVertexID, ExecutionAttemptID, String, int, int) - Method in class org.apache.flink.runtime.metrics.groups.UnregisteredMetricGroups.UnregisteredTaskManagerJobMetricGroup
-
- addTask(Task) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
-
Add the given task to the slot identified by the task's allocation id.
- addTaskForJob(JobID, String, JobVertexID, ExecutionAttemptID, String, int, int) - Method in class org.apache.flink.runtime.metrics.groups.TaskManagerMetricGroup
-
- addTaskForJob(JobID, String, JobVertexID, ExecutionAttemptID, String, int, int) - Method in class org.apache.flink.runtime.metrics.groups.UnregisteredMetricGroups.UnregisteredTaskManagerMetricGroup
-
- addToDefaults(String, String) - Method in class org.apache.flink.api.java.utils.ParameterTool
-
- addToEnvironment(Map<String, String>, String, String) - Static method in class org.apache.flink.yarn.Utils
-
Copied method from org.apache.hadoop.yarn.util.Apps.
- addToMessageDigest(MessageDigest) - Method in class org.apache.flink.runtime.blob.BlobKey
-
- addUniqueField(FieldSet) - Method in class org.apache.flink.api.common.operators.CompilerHints
-
Adds a FieldSet to be unique
- addUniqueField(int) - Method in class org.apache.flink.api.common.operators.CompilerHints
-
Adds a field as having only unique values.
- addUniqueFieldCombination(FieldSet) - Method in class org.apache.flink.optimizer.dataproperties.GlobalProperties
-
- addUniqueFields(Set<FieldSet>) - Method in class org.apache.flink.api.common.operators.CompilerHints
-
Adds multiple FieldSets to be unique
- addUniqueFields(FieldSet) - Method in class org.apache.flink.optimizer.dataproperties.LocalProperties
-
Adds a combination of fields that are unique in these data properties.
- addVertex(Vertex<K, VV>) - Method in class org.apache.flink.graph.Graph
-
Adds the input vertex to the graph.
- addVertex(JobVertex) - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
Adds a new task vertex to the job graph if it is not already included.
- addVertex(JobVertex) - Method in class org.apache.flink.runtime.jobmanager.scheduler.CoLocationGroup
-
- addVertexToGroup(JobVertexID) - Method in class org.apache.flink.runtime.jobmanager.scheduler.SlotSharingGroup
-
- addVertices(List<Vertex<K, VV>>) - Method in class org.apache.flink.graph.Graph
-
Adds the list of vertices, passed as input, to the graph.
- addVirtualPartitionNode(Integer, Integer, StreamPartitioner<?>) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
Adds a new virtual node that is used to connect a downstream vertex to an input with a
certain partitioning.
- addVirtualSelectNode(Integer, Integer, List<String>) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
Adds a new virtual node that is used to connect a downstream vertex to only the outputs
with the selected names.
- addVirtualSideOutputNode(Integer, Integer, OutputTag) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
Adds a new virtual node that is used to connect a downstream vertex to only the outputs with
the selected side-output
OutputTag
.
- addWindow(W, MergingWindowSet.MergeFunction<W>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.MergingWindowSet
-
Adds a new Window
to the set of in-flight windows.
- adjustGlobalPropertiesForFullParallelismChange() - Method in class org.apache.flink.optimizer.plan.Channel
-
- adjustTop() - Method in class org.apache.flink.runtime.operators.sort.PartialOrderPriorityQueue
-
Should be called when the Object at top changes values.
- advance() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
-
Advances the view to the next memory segment.
- advance() - Method in class org.apache.flink.runtime.memory.AbstractPagedOutputView
-
Moves the output view to the next page.
- advanceWatermark(long) - Method in class org.apache.flink.streaming.api.operators.HeapInternalTimerService
-
- advanceWatermark(Watermark) - Method in class org.apache.flink.streaming.api.operators.InternalTimeServiceManager
-
- after() - Method in class org.apache.flink.test.util.MiniClusterResource
-
- AfterMatchSkipStrategy - Class in org.apache.flink.cep.nfa
-
Indicate the skip strategy after a match process.
- afterMatchSkipStrategy - Variable in class org.apache.flink.cep.operator.AbstractKeyedCEPPatternOperator
-
- AfterMatchSkipStrategy.SkipStrategy - Enum in org.apache.flink.cep.nfa
-
Skip Strategy Enum.
- aggregate(T) - Method in interface org.apache.flink.api.common.aggregators.Aggregator
-
Aggregates the given element.
- aggregate(DoubleValue) - Method in class org.apache.flink.api.common.aggregators.DoubleSumAggregator
-
- aggregate(double) - Method in class org.apache.flink.api.common.aggregators.DoubleSumAggregator
-
Adds the given value to the current aggregate.
- aggregate(LongValue) - Method in class org.apache.flink.api.common.aggregators.LongSumAggregator
-
- aggregate(long) - Method in class org.apache.flink.api.common.aggregators.LongSumAggregator
-
Adds the given value to the current aggregate.
- aggregate(long) - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase.TerminationCriterionAggregator
-
- aggregate(LongValue) - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase.TerminationCriterionAggregator
-
- aggregate(T) - Method in class org.apache.flink.api.java.aggregation.AggregationFunction
-
- aggregate(Aggregations, int) - Method in class org.apache.flink.api.java.DataSet
-
Applies an Aggregate transformation on a non-grouped
Tuple
DataSet
.
- aggregate(Aggregations, int) - Method in class org.apache.flink.api.java.operators.UnsortedGrouping
-
Applies an Aggregate transformation on a grouped
Tuple
DataSet
.
- aggregate(T) - Method in interface org.apache.flink.api.java.summarize.aggregation.Aggregator
-
Add a value to the current aggregation.
- aggregate(Boolean) - Method in class org.apache.flink.api.java.summarize.aggregation.BooleanSummaryAggregator
-
- aggregate(Double) - Method in class org.apache.flink.api.java.summarize.aggregation.DoubleSummaryAggregator.MaxDoubleAggregator
-
- aggregate(Double) - Method in class org.apache.flink.api.java.summarize.aggregation.DoubleSummaryAggregator.MinDoubleAggregator
-
- aggregate(Double) - Method in class org.apache.flink.api.java.summarize.aggregation.DoubleSummaryAggregator.SumDoubleAggregator
-
- aggregate(Float) - Method in class org.apache.flink.api.java.summarize.aggregation.FloatSummaryAggregator.MaxFloatAggregator
-
- aggregate(Float) - Method in class org.apache.flink.api.java.summarize.aggregation.FloatSummaryAggregator.MinFloatAggregator
-
- aggregate(Float) - Method in class org.apache.flink.api.java.summarize.aggregation.FloatSummaryAggregator.SumFloatAggregator
-
- aggregate(Integer) - Method in class org.apache.flink.api.java.summarize.aggregation.IntegerSummaryAggregator.MaxIntegerAggregator
-
- aggregate(Integer) - Method in class org.apache.flink.api.java.summarize.aggregation.IntegerSummaryAggregator.MinIntegerAggregator
-
- aggregate(Integer) - Method in class org.apache.flink.api.java.summarize.aggregation.IntegerSummaryAggregator.SumIntegerAggregator
-
- aggregate(Long) - Method in class org.apache.flink.api.java.summarize.aggregation.LongSummaryAggregator.MaxLongAggregator
-
- aggregate(Long) - Method in class org.apache.flink.api.java.summarize.aggregation.LongSummaryAggregator.MinLongAggregator
-
- aggregate(T) - Method in class org.apache.flink.api.java.summarize.aggregation.NumericSummaryAggregator
-
Add a value to the current aggregation.
- aggregate(Object) - Method in class org.apache.flink.api.java.summarize.aggregation.ObjectSummaryAggregator
-
- aggregate(Short) - Method in class org.apache.flink.api.java.summarize.aggregation.ShortSummaryAggregator.MaxShortAggregator
-
- aggregate(Short) - Method in class org.apache.flink.api.java.summarize.aggregation.ShortSummaryAggregator.MinShortAggregator
-
- aggregate(Short) - Method in class org.apache.flink.api.java.summarize.aggregation.ShortSummaryAggregator.SumShortAggregator
-
- aggregate(String) - Method in class org.apache.flink.api.java.summarize.aggregation.StringSummaryAggregator
-
- aggregate(Tuple) - Method in class org.apache.flink.api.java.summarize.aggregation.TupleSummaryAggregator
-
- aggregate(VT) - Method in class org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator
-
- aggregate(AggregateFunction<T, ACC, R>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies the given AggregateFunction
to each window.
- aggregate(AggregateFunction<T, ACC, R>, TypeInformation<ACC>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies the given AggregateFunction
to each window.
- aggregate(AggregateFunction<T, ACC, V>, AllWindowFunction<V, R, W>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies the given window function to each window.
- aggregate(AggregateFunction<T, ACC, V>, AllWindowFunction<V, R, W>, TypeInformation<ACC>, TypeInformation<V>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies the given window function to each window.
- aggregate(AggregateFunction<T, ACC, V>, ProcessAllWindowFunction<V, R, W>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies the given window function to each window.
- aggregate(AggregateFunction<T, ACC, V>, ProcessAllWindowFunction<V, R, W>, TypeInformation<ACC>, TypeInformation<V>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies the given window function to each window.
- aggregate(AggregationFunction<T>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
- aggregate(AggregateFunction<T, ACC, R>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies the given aggregation function to each window.
- aggregate(AggregateFunction<T, ACC, R>, TypeInformation<ACC>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies the given aggregation function to each window.
- aggregate(AggregateFunction<T, ACC, V>, WindowFunction<V, R, K, W>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies the given window function to each window.
- aggregate(AggregateFunction<T, ACC, V>, WindowFunction<V, R, K, W>, TypeInformation<ACC>, TypeInformation<V>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies the given window function to each window.
- aggregate(AggregateFunction<T, ACC, V>, ProcessWindowFunction<V, R, K, W>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies the given window function to each window.
- aggregate(AggregateFunction<T, ACC, V>, ProcessWindowFunction<V, R, K, W>, TypeInformation<ACC>, TypeInformation<V>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies the given window function to each window.
- AggregateApplyAllWindowFunction<W extends Window,T,ACC,V,R> - Class in org.apache.flink.streaming.api.functions.windowing
-
- AggregateApplyAllWindowFunction(AggregateFunction<T, ACC, V>, AllWindowFunction<V, R, W>) - Constructor for class org.apache.flink.streaming.api.functions.windowing.AggregateApplyAllWindowFunction
-
- AggregateApplyWindowFunction<K,W extends Window,T,ACC,V,R> - Class in org.apache.flink.streaming.api.functions.windowing
-
- AggregateApplyWindowFunction(AggregateFunction<T, ACC, V>, WindowFunction<V, R, K, W>) - Constructor for class org.apache.flink.streaming.api.functions.windowing.AggregateApplyWindowFunction
-
- AggregatedJobMetricsHeaders - Class in org.apache.flink.runtime.rest.messages.job.metrics
-
Headers for aggregating job metrics.
- AggregatedJobMetricsParameters - Class in org.apache.flink.runtime.rest.messages.job.metrics
-
Parameters for aggregating job metrics.
- AggregatedJobMetricsParameters() - Constructor for class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedJobMetricsParameters
-
- AggregatedMetric - Class in org.apache.flink.runtime.rest.messages.job.metrics
-
Response type for aggregated metrics.
- AggregatedMetric(String, Double, Double, Double, Double) - Constructor for class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedMetric
-
- AggregatedMetric(String) - Constructor for class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedMetric
-
- AggregatedMetricsResponseBody - Class in org.apache.flink.runtime.rest.messages.job.metrics
-
Response type for a collection of aggregated metrics.
- AggregatedMetricsResponseBody(Collection<AggregatedMetric>) - Constructor for class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedMetricsResponseBody
-
- AggregatedMetricsResponseBody.Deserializer - Class in org.apache.flink.runtime.rest.messages.job.metrics
-
- AggregatedMetricsResponseBody.Serializer - Class in org.apache.flink.runtime.rest.messages.job.metrics
-
- AggregatedSubtaskMetricsHeaders - Class in org.apache.flink.runtime.rest.messages.job.metrics
-
Headers for aggregating subtask metrics.
- AggregatedSubtaskMetricsParameters - Class in org.apache.flink.runtime.rest.messages.job.metrics
-
Parameters for aggregating subtask metrics.
- AggregatedSubtaskMetricsParameters() - Constructor for class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedSubtaskMetricsParameters
-
- AggregatedTaskManagerMetricsHeaders - Class in org.apache.flink.runtime.rest.messages.job.metrics
-
Headers for aggregating task manager metrics.
- AggregateFunction<IN,ACC,OUT> - Interface in 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.
Support for distributive aggregations: Different intermediate aggregates can be
merged together, to allow for pre-aggregation/final-aggregation optimizations.
- AggregateOperator<IN> - Class in org.apache.flink.api.java.operators
-
This operator represents the application of a "aggregate" operation on a data set, and the
result data set produced by the function.
- AggregateOperator(DataSet<IN>, Aggregations, int, String) - Constructor for class org.apache.flink.api.java.operators.AggregateOperator
-
Non grouped aggregation.
- AggregateOperator(Grouping<IN>, Aggregations, int, String) - Constructor for class org.apache.flink.api.java.operators.AggregateOperator
-
Grouped aggregation.
- AggregateReduceFunctionsRule - Class in org.apache.calcite.rel.rules
-
Planner rule that reduces aggregate functions in
Aggregate
s to simpler forms.
- AggregateReduceFunctionsRule(RelOptRuleOperand, RelBuilderFactory) - Constructor for class org.apache.calcite.rel.rules.AggregateReduceFunctionsRule
-
Creates an AggregateReduceFunctionsRule.
- AggregateTaskManagerMetricsParameters - Class in org.apache.flink.runtime.rest.messages.job.metrics
-
Parameters for aggregating task manager metrics.
- AggregateTaskManagerMetricsParameters() - Constructor for class org.apache.flink.runtime.rest.messages.job.metrics.AggregateTaskManagerMetricsParameters
-
- aggregateUserAccumulators() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
Merges all accumulator results from the tasks previously executed in the Executions.
- AggregatingJobsMetricsHandler - Class in org.apache.flink.runtime.rest.handler.job.metrics
-
Request handler that returns, aggregated across jobs, a list of all available metrics or the values
for a set of metrics.
- AggregatingJobsMetricsHandler(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, Executor, MetricFetcher<?>) - Constructor for class org.apache.flink.runtime.rest.handler.job.metrics.AggregatingJobsMetricsHandler
-
- AggregatingJobsMetricsHandler - Class in org.apache.flink.runtime.rest.handler.legacy.metrics
-
Request handler that returns, aggregated across all jobs, a list of all available metrics or the values
for a set of metrics.
- AggregatingJobsMetricsHandler(Executor, MetricFetcher) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.metrics.AggregatingJobsMetricsHandler
-
- AggregatingState<IN,OUT> - Interface in org.apache.flink.api.common.state
-
- AggregatingStateDescriptor<IN,ACC,OUT> - Class in org.apache.flink.api.common.state
-
- AggregatingStateDescriptor(String, AggregateFunction<IN, ACC, OUT>, Class<ACC>) - Constructor for class 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>) - Constructor for class 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>) - Constructor for class org.apache.flink.api.common.state.AggregatingStateDescriptor
-
Creates a new ValueStateDescriptor
with the given name and default value.
- AggregatingSubtasksMetricsHandler - Class in org.apache.flink.runtime.rest.handler.job.metrics
-
Request handler that returns, aggregated across subtasks, a list of all available metrics or the values
for a set of metrics.
- AggregatingSubtasksMetricsHandler(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, Executor, MetricFetcher<?>) - Constructor for class org.apache.flink.runtime.rest.handler.job.metrics.AggregatingSubtasksMetricsHandler
-
- AggregatingSubtasksMetricsHandler - Class in org.apache.flink.runtime.rest.handler.legacy.metrics
-
Request handler that returns, aggregated across all subtasks, a list of all available metrics or the values
for a set of metrics.
- AggregatingSubtasksMetricsHandler(Executor, MetricFetcher) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.metrics.AggregatingSubtasksMetricsHandler
-
- AggregatingTaskManagersMetricsHandler - Class in org.apache.flink.runtime.rest.handler.job.metrics
-
Request handler that returns, aggregated across task managers, a list of all available metrics or the values for
a set of metrics.
- AggregatingTaskManagersMetricsHandler(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, Executor, MetricFetcher<?>) - Constructor for class org.apache.flink.runtime.rest.handler.job.metrics.AggregatingTaskManagersMetricsHandler
-
- AggregatingTaskManagersMetricsHandler - Class in org.apache.flink.runtime.rest.handler.legacy.metrics
-
Request handler that returns, aggregated across all task managers, a list of all available metrics or the values for
a set of metrics.
- AggregatingTaskManagersMetricsHandler(Executor, MetricFetcher) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.metrics.AggregatingTaskManagersMetricsHandler
-
- AggregationFunction<T> - Class in org.apache.flink.api.java.aggregation
-
- AggregationFunction() - Constructor for class org.apache.flink.api.java.aggregation.AggregationFunction
-
- AggregationFunction<T> - Class in org.apache.flink.streaming.api.functions.aggregation
-
Holder class for aggregation types that can be used on a windowed stream or keyed stream.
- AggregationFunction() - Constructor for class org.apache.flink.streaming.api.functions.aggregation.AggregationFunction
-
- AggregationFunction.AggregationType - Enum in org.apache.flink.streaming.api.functions.aggregation
-
Aggregation types that can be used on a windowed stream or keyed stream.
- AggregationFunctionFactory - Interface in org.apache.flink.api.java.aggregation
-
- Aggregations - Enum in org.apache.flink.api.java.aggregation
-
Shortcuts for Aggregation factories.
- Aggregator<T extends Value> - Interface in org.apache.flink.api.common.aggregators
-
Aggregators are a means of aggregating values across parallel instances of a function.
- Aggregator<T,R> - Interface in org.apache.flink.api.java.summarize.aggregation
-
Generic interface for aggregation.
- AGGREGATOR_NAME - Static variable in class org.apache.flink.runtime.iterative.convergence.WorksetEmptyConvergenceCriterion
-
- AggregatorRegistry - Class in org.apache.flink.api.common.aggregators
-
- AggregatorRegistry() - Constructor for class org.apache.flink.api.common.aggregators.AggregatorRegistry
-
- AggregatorWithName<T extends Value> - Class in org.apache.flink.api.common.aggregators
-
Simple utility class holding an
Aggregator
with the name it is registered under.
- AggregatorWithName(String, Aggregator<T>) - Constructor for class org.apache.flink.api.common.aggregators.AggregatorWithName
-
Creates a new instance for the given aggregator and name.
- AKKA_ASK_TIMEOUT - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- AKKA_CLIENT_TIMEOUT - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- AKKA_DISPATCHER_THROUGHPUT - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- AKKA_FRAMESIZE - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- AKKA_JVM_EXIT_ON_FATAL_ERROR - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- AKKA_LOG_LIFECYCLE_EVENTS - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- AKKA_LOOKUP_TIMEOUT - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- AKKA_SSL_ENABLED - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- AKKA_STARTUP_TIMEOUT - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- AKKA_TCP_TIMEOUT - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- AKKA_TRANSPORT_HEARTBEAT_INTERVAL - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- AKKA_TRANSPORT_HEARTBEAT_PAUSE - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- AKKA_TRANSPORT_THRESHOLD - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- AKKA_WATCH_HEARTBEAT_INTERVAL - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- AKKA_WATCH_HEARTBEAT_PAUSE - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- AKKA_WATCH_THRESHOLD - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- AkkaActorGateway - Class in org.apache.flink.runtime.instance
-
Concrete
ActorGateway
implementation which uses Akka to communicate with remote actors.
- AkkaActorGateway(ActorRef, UUID) - Constructor for class org.apache.flink.runtime.instance.AkkaActorGateway
-
- AkkaHandshakeException - Exception in org.apache.flink.runtime.rpc.akka.exceptions
-
Exception which is thrown if the handshake fails.
- AkkaHandshakeException(String) - Constructor for exception org.apache.flink.runtime.rpc.akka.exceptions.AkkaHandshakeException
-
- AkkaHandshakeException(String, Throwable) - Constructor for exception org.apache.flink.runtime.rpc.akka.exceptions.AkkaHandshakeException
-
- AkkaHandshakeException(Throwable) - Constructor for exception org.apache.flink.runtime.rpc.akka.exceptions.AkkaHandshakeException
-
- AkkaJobManagerGateway - Class in org.apache.flink.runtime.akka
-
- AkkaJobManagerGateway(ActorGateway) - Constructor for class org.apache.flink.runtime.akka.AkkaJobManagerGateway
-
- AkkaJobManagerRetriever - Class in org.apache.flink.runtime.webmonitor.retriever.impl
-
- AkkaJobManagerRetriever(ActorSystem, Time, int, Time) - Constructor for class org.apache.flink.runtime.webmonitor.retriever.impl.AkkaJobManagerRetriever
-
- AkkaOptions - Class in org.apache.flink.configuration
-
Akka configuration options.
- AkkaOptions() - Constructor for class org.apache.flink.configuration.AkkaOptions
-
- AkkaQueryServiceGateway - Class in org.apache.flink.runtime.webmonitor.retriever.impl
-
- AkkaQueryServiceGateway(ActorRef) - Constructor for class org.apache.flink.runtime.webmonitor.retriever.impl.AkkaQueryServiceGateway
-
- AkkaQueryServiceRetriever - Class in org.apache.flink.runtime.webmonitor.retriever.impl
-
- AkkaQueryServiceRetriever(ActorSystem, Time) - Constructor for class org.apache.flink.runtime.webmonitor.retriever.impl.AkkaQueryServiceRetriever
-
- AkkaRpcException - Exception in org.apache.flink.runtime.rpc.akka.exceptions
-
Base class for Akka RPC related exceptions.
- AkkaRpcException(String) - Constructor for exception org.apache.flink.runtime.rpc.akka.exceptions.AkkaRpcException
-
- AkkaRpcException(String, Throwable) - Constructor for exception org.apache.flink.runtime.rpc.akka.exceptions.AkkaRpcException
-
- AkkaRpcException(Throwable) - Constructor for exception org.apache.flink.runtime.rpc.akka.exceptions.AkkaRpcException
-
- AkkaRpcService - Class in org.apache.flink.runtime.rpc.akka
-
- AkkaRpcService(ActorSystem, Time) - Constructor for class org.apache.flink.runtime.rpc.akka.AkkaRpcService
-
- AkkaRpcServiceUtils - Class in org.apache.flink.runtime.rpc.akka
-
These RPC utilities contain helper methods around RPC use, such as starting an RPC service,
or constructing RPC addresses.
- AkkaRpcServiceUtils.AkkaProtocol - Enum in org.apache.flink.runtime.rpc.akka
-
- AkkaUnknownMessageException - Exception in org.apache.flink.runtime.rpc.akka.exceptions
-
Exception which indicates that the AkkaRpcActor has received an
unknown message type.
- AkkaUnknownMessageException(String) - Constructor for exception org.apache.flink.runtime.rpc.akka.exceptions.AkkaUnknownMessageException
-
- AkkaUnknownMessageException(String, Throwable) - Constructor for exception org.apache.flink.runtime.rpc.akka.exceptions.AkkaUnknownMessageException
-
- AkkaUnknownMessageException(Throwable) - Constructor for exception org.apache.flink.runtime.rpc.akka.exceptions.AkkaUnknownMessageException
-
- Alert - Class in org.apache.flink.streaming.examples.statemachine.event
-
Data type for alerts.
- Alert(int, State, EventType) - Constructor for class org.apache.flink.streaming.examples.statemachine.event.Alert
-
Creates a new alert.
- AlgorithmOptions - Class in org.apache.flink.configuration
-
Configuration parameters for join/sort algorithms.
- AlgorithmOptions() - Constructor for class org.apache.flink.configuration.AlgorithmOptions
-
- AlignmentLimitExceededException - Exception in org.apache.flink.runtime.checkpoint.decline
-
Exception indicating that a checkpoint was declined because too many bytes were
buffered in the alignment phase.
- AlignmentLimitExceededException(long) - Constructor for exception org.apache.flink.runtime.checkpoint.decline.AlignmentLimitExceededException
-
- AllFieldsForwardedProperties() - Constructor for class org.apache.flink.api.common.operators.SingleInputSemanticProperties.AllFieldsForwardedProperties
-
- AllGroupCombineDriver<IN,OUT> - Class in org.apache.flink.runtime.operators
-
Non-chained driver for the partial group reduce operator that acts like a combiner with a custom output type OUT.
- AllGroupCombineDriver() - Constructor for class org.apache.flink.runtime.operators.AllGroupCombineDriver
-
- AllGroupCombineProperties - Class in org.apache.flink.optimizer.operators
-
- AllGroupCombineProperties() - Constructor for class org.apache.flink.optimizer.operators.AllGroupCombineProperties
-
- AllGroupReduceDriver<IT,OT> - Class in org.apache.flink.runtime.operators
-
GroupReduceDriver task which is executed by a Task Manager.
- AllGroupReduceDriver() - Constructor for class org.apache.flink.runtime.operators.AllGroupReduceDriver
-
- AllGroupReduceProperties - Class in org.apache.flink.optimizer.operators
-
- AllGroupReduceProperties() - Constructor for class org.apache.flink.optimizer.operators.AllGroupReduceProperties
-
- AllGroupWithPartialPreGroupProperties - Class in org.apache.flink.optimizer.operators
-
- AllGroupWithPartialPreGroupProperties() - Constructor for class org.apache.flink.optimizer.operators.AllGroupWithPartialPreGroupProperties
-
- alloc() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
-
- allocate(JobID, AllocationID) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlot
-
Allocate the task slot for the given job and allocation id.
- allocateAndAssignSlotForExecution(SlotProvider, boolean, LocationPreferenceConstraint, Time) - Method in class org.apache.flink.runtime.executiongraph.Execution
-
Allocates and assigns a slot obtained from the slot provider to the execution.
- AllocatedSlotActions - Interface in org.apache.flink.runtime.jobmaster.slotpool
-
Interface for components which have to perform actions on allocated slots.
- allocatePages(Object, int) - Method in class org.apache.flink.runtime.memory.MemoryManager
-
Allocates a set of memory segments from this memory manager.
- allocatePages(Object, List<MemorySegment>, int) - Method in class org.apache.flink.runtime.memory.MemoryManager
-
Allocates a set of memory segments from this memory manager.
- allocateResource(ResourceProfile) - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerServices
-
Allocates a resource according to the resource profile.
- allocateResource(ResourceProfile) - Method in interface org.apache.flink.runtime.resourcemanager.slotmanager.ResourceActions
-
- allocateResourcesForAll(SlotProvider, boolean, LocationPreferenceConstraint, Time) - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
Acquires a slot for all the execution vertices of this ExecutionJobVertex.
- allocateSegments(int) - Method in class org.apache.flink.runtime.operators.hash.InMemoryPartition
-
attempts to allocate specified number of segments and should only be used by compaction partition
fails silently if not enough segments are available since next compaction could still succeed
- allocateSharedSlot(SlotSharingGroupAssignment) - Method in class org.apache.flink.runtime.instance.Instance
-
Allocates a shared slot on this TaskManager instance.
- allocateSimpleSlot() - Method in class org.apache.flink.runtime.instance.Instance
-
Allocates a simple slot on this TaskManager instance.
- allocateSlot(SlotRequestId, ScheduledUnit, boolean, SlotProfile, Time) - Method in class org.apache.flink.runtime.jobmanager.scheduler.Scheduler
-
- allocateSlot(SlotRequestId, ScheduledUnit, SlotProfile, boolean, Time) - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotPool
-
- allocateSlot(SlotRequestId, ScheduledUnit, SlotProfile, boolean, Time) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.SlotPoolGateway
-
- allocateSlot(SlotRequestId, ScheduledUnit, boolean, SlotProfile, Time) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.SlotProvider
-
Allocating slot with specific requirement.
- allocateSlot(ScheduledUnit, boolean, SlotProfile, Time) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.SlotProvider
-
Allocating slot with specific requirement.
- allocateSlot(int, JobID, AllocationID, Time) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
-
Allocate the slot with the given index for the given job and allocation id.
- allocateUnpooledSegment(int, Object) - Method in class org.apache.flink.core.memory.HeapMemorySegment.HeapMemorySegmentFactory
-
Allocates some unpooled memory and creates a new memory segment that represents
that memory.
- allocateUnpooledSegment(int) - Static method in class org.apache.flink.core.memory.MemorySegmentFactory
-
Allocates some unpooled memory and creates a new memory segment that represents
that memory.
- allocateUnpooledSegment(int, Object) - Static method in class org.apache.flink.core.memory.MemorySegmentFactory
-
Allocates some unpooled memory and creates a new memory segment that represents
that memory.
- allocationBaseDirectory(long) - Method in interface org.apache.flink.runtime.state.LocalRecoveryDirectoryProvider
-
Returns the local state allocation base directory for given checkpoint id w.r.t.
- allocationBaseDirectory(long) - Method in class org.apache.flink.runtime.state.LocalRecoveryDirectoryProviderImpl
-
- allocationBaseDirsCount() - Method in interface org.apache.flink.runtime.state.LocalRecoveryDirectoryProvider
-
Returns the total number of allocation base directories.
- allocationBaseDirsCount() - Method in class org.apache.flink.runtime.state.LocalRecoveryDirectoryProviderImpl
-
- allocationFuture - Variable in class org.apache.flink.runtime.executiongraph.ExecutionAndAllocationFuture
-
- AllocationID - Class in org.apache.flink.runtime.clusterframework.types
-
Unique identifier for a physical slot allocated by a JobManager via the ResourceManager
from a TaskManager.
- AllocationID() - Constructor for class org.apache.flink.runtime.clusterframework.types.AllocationID
-
Constructs a new random AllocationID.
- AllocationID(long, long) - Constructor for class org.apache.flink.runtime.clusterframework.types.AllocationID
-
Constructs a new AllocationID with the given parts.
- allOutputs - Variable in class org.apache.flink.streaming.api.collector.selector.DirectedOutput
-
- allowCombinations() - Method in class org.apache.flink.cep.pattern.Pattern
-
- allowedLateness(Time) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Sets the time by which elements are allowed to be late.
- allowedLateness(Time) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Sets the time by which elements are allowed to be late.
- allowedLateness - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
The allowed lateness for elements.
- allowLazyDeployment() - Method in enum org.apache.flink.runtime.jobgraph.ScheduleMode
-
Returns whether we are allowed to deploy consumers lazily.
- allowNonRestoredState() - Method in class org.apache.flink.runtime.jobgraph.SavepointRestoreSettings
-
Returns whether non restored state is allowed if the savepoint contains
state that cannot be mapped back to the job.
- AllowNonRestoredStateQueryParameter - Class in org.apache.flink.runtime.webmonitor.handlers
-
Query parameter that specifies whether non restored state is allowed if the savepoint
contains state for an operator that is not part of the job.
- AllowNonRestoredStateQueryParameter() - Constructor for class org.apache.flink.runtime.webmonitor.handlers.AllowNonRestoredStateQueryParameter
-
- allowNonRestoredStateQueryParameter - Variable in class org.apache.flink.runtime.webmonitor.handlers.JarRunMessageParameters
-
- AllReduceDriver<T> - Class in org.apache.flink.runtime.operators
-
Reduce task which is executed by a Task Manager.
- AllReduceDriver() - Constructor for class org.apache.flink.runtime.operators.AllReduceDriver
-
- AllReduceProperties - Class in org.apache.flink.optimizer.operators
-
- AllReduceProperties() - Constructor for class org.apache.flink.optimizer.operators.AllReduceProperties
-
- allStartedWorkers() - Method in class org.apache.flink.runtime.clusterframework.FlinkResourceManager
-
Gets an iterable for all currently started TaskManagers.
- AllWindowedStream<T,W extends Window> - Class in org.apache.flink.streaming.api.datastream
-
A
AllWindowedStream
represents a data stream where the stream of
elements is split into windows based on a
WindowAssigner
.
- AllWindowedStream(DataStream<T>, WindowAssigner<? super T, W>) - Constructor for class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
- AllWindowFunction<IN,OUT,W extends Window> - Interface in org.apache.flink.streaming.api.functions.windowing
-
Base interface for functions that are evaluated over non-keyed windows.
- AllWorkersDoneEvent - Class in org.apache.flink.runtime.iterative.event
-
Event sent by the IterationSynchronizationSinkTask
to each
IterationHead
signaling to start a new superstep.
- AllWorkersDoneEvent() - Constructor for class org.apache.flink.runtime.iterative.event.AllWorkersDoneEvent
-
- AllWorkersDoneEvent(Map<String, Aggregator<?>>) - Constructor for class org.apache.flink.runtime.iterative.event.AllWorkersDoneEvent
-
- alt(String) - Method in class org.apache.flink.api.java.utils.Option
-
Define an alternative / short name of the parameter.
- ALWAYS_PARENT_FIRST_LOADER_PATTERNS - Static variable in class 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 - Static variable in class org.apache.flink.configuration.CoreOptions
-
- amount - Variable in class org.apache.flink.table.examples.java.StreamSQLExample.Order
-
- AnalyticHelper<T> - Class in org.apache.flink.graph
-
A
GraphAnalytic
computes over a DataSet and returns the results via
Flink accumulators.
- AnalyticHelper() - Constructor for class org.apache.flink.graph.AnalyticHelper
-
- analyze() - Method in class org.apache.flink.api.java.sca.NestedMethodAnalyzer
-
- analyze() - Method in class org.apache.flink.api.java.sca.UdfAnalyzer
-
- analyzeDualInputUdf(TwoInputUdfOperator<?, ?, ?, ?>, Class<?>, String, Function, Keys<?>, Keys<?>) - Static method in class org.apache.flink.api.java.operators.UdfOperatorUtils
-
- analyzePojo(Class<OUT>, ArrayList<Type>, ParameterizedType, TypeInformation<IN1>, TypeInformation<IN2>) - Method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
- analyzeSingleInputUdf(SingleInputUdfOperator<?, ?, ?>, Class<?>, String, Function, Keys<?>) - Static method in class org.apache.flink.api.java.operators.UdfOperatorUtils
-
- and(Aggregations, int) - Method in class org.apache.flink.api.java.operators.AggregateOperator
-
- and(Aggregations, int) - Method in class org.apache.flink.api.scala.operators.ScalaAggregateOperator
-
- AndCondition<T> - Class in org.apache.flink.cep.pattern.conditions
-
A
condition
which combines two conditions with a logical
AND
and returns
true
if both are
true
.
- AndCondition(IterativeCondition<T>, IterativeCondition<T>) - Constructor for class org.apache.flink.cep.pattern.conditions.AndCondition
-
- andMax(int) - Method in class org.apache.flink.api.java.operators.AggregateOperator
-
- andMin(int) - Method in class org.apache.flink.api.java.operators.AggregateOperator
-
- andSum(int) - Method in class org.apache.flink.api.java.operators.AggregateOperator
-
- AnnotationVisitorImpl(int) - Constructor for class org.apache.flink.runtime.util.DependencyVisitor.AnnotationVisitorImpl
-
- AntiJoinVisits() - Constructor for class org.apache.flink.examples.java.relational.WebLogAnalysis.AntiJoinVisits
-
- API_KEY - Static variable in class org.apache.flink.metrics.datadog.DatadogHttpReporter
-
- APP_MASTER_RPC_ADDRESS - Static variable in class org.apache.flink.yarn.configuration.YarnConfigOptions
-
The hostname or address where the application master RPC system is listening.
- APP_MASTER_RPC_PORT - Static variable in class org.apache.flink.yarn.configuration.YarnConfigOptions
-
The port where the application master RPC system is listening.
- append(ByteBuffer) - Method in class org.apache.flink.runtime.io.network.buffer.BufferBuilder
-
Append as many data as possible from source
.
- append(char) - Method in class org.apache.flink.types.StringValue
-
- append(CharSequence) - Method in class org.apache.flink.types.StringValue
-
- append(CharSequence, int, int) - Method in class org.apache.flink.types.StringValue
-
- append(StringValue) - Method in class org.apache.flink.types.StringValue
-
- append(StringValue, int, int) - Method in class org.apache.flink.types.StringValue
-
- appendAndCommit(ByteBuffer) - Method in class org.apache.flink.runtime.io.network.buffer.BufferBuilder
-
- AppendingState<IN,OUT> - Interface in org.apache.flink.api.common.state
-
Base interface for partitioned state that supports adding elements and inspecting the current
state.
- appendKeyExtractor(Operator<T>, Keys.SelectorFunctionKeys<T, K>) - Static method in class org.apache.flink.api.java.operators.KeyFunctions
-
- appendKeyExtractor(Operator<T>, Keys.SelectorFunctionKeys<T, K1>, Keys.SelectorFunctionKeys<T, K2>) - Static method in class org.apache.flink.api.java.operators.KeyFunctions
-
- appendKeyRemover(Operator<Tuple2<K, T>>, Keys.SelectorFunctionKeys<T, K>) - Static method in class org.apache.flink.api.java.operators.KeyFunctions
-
- appendOrdering(Integer, Class<? extends Comparable<?>>, Order) - Method in class org.apache.flink.api.common.operators.Ordering
-
Extends this ordering by appending an additional order requirement.
- appendRecord(T) - Method in class org.apache.flink.runtime.operators.hash.InMemoryPartition
-
Inserts the given object into the current buffer.
- APPLICATION_ATTEMPTS - Static variable in class org.apache.flink.yarn.configuration.YarnConfigOptions
-
Set the number of retries for failed YARN ApplicationMasters/JobManagers in high
availability mode.
- APPLICATION_MASTER_PORT - Static variable in class org.apache.flink.yarn.configuration.YarnConfigOptions
-
The config parameter defining the Akka actor system port for the ApplicationMaster and
JobManager.
- APPLICATION_TAGS - Static variable in class org.apache.flink.yarn.configuration.YarnConfigOptions
-
A comma-separated list of strings to use as YARN application tags.
- ApplicationStatus - Enum in org.apache.flink.runtime.clusterframework
-
The status of an application.
- applicationStatus(ApplicationStatus) - Method in class org.apache.flink.runtime.jobmaster.JobResult.Builder
-
- apply(M, VV) - Method in class org.apache.flink.graph.gsa.ApplyFunction
-
- apply(S, T) - Method in interface org.apache.flink.runtime.state.StateTransformationFunction
-
Binary function that applies a given value to the given old state to compute the new state.
- apply(AllWindowFunction<T, R, W>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies the given window function to each window.
- apply(AllWindowFunction<T, R, W>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies the given window function to each window.
- apply(ReduceFunction<T>, AllWindowFunction<T, R, W>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
- apply(ReduceFunction<T>, AllWindowFunction<T, R, W>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
- apply(R, FoldFunction<T, R>, AllWindowFunction<R, R, W>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
- apply(R, FoldFunction<T, R>, AllWindowFunction<R, R, W>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
- apply(CoGroupFunction<T1, T2, T>) - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.WithWindow
-
Completes the co-group operation with the user function that is executed
for windowed groups.
- apply(CoGroupFunction<T1, T2, T>, TypeInformation<T>) - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.WithWindow
-
Completes the co-group operation with the user function that is executed
for windowed groups.
- apply(JoinFunction<T1, T2, T>) - Method in class org.apache.flink.streaming.api.datastream.JoinedStreams.WithWindow
-
Completes the join operation with the user function that is executed
for each combination of elements with the same key in a window.
- apply(FlatJoinFunction<T1, T2, T>, TypeInformation<T>) - Method in class org.apache.flink.streaming.api.datastream.JoinedStreams.WithWindow
-
Completes the join operation with the user function that is executed
for each combination of elements with the same key in a window.
- apply(FlatJoinFunction<T1, T2, T>) - Method in class org.apache.flink.streaming.api.datastream.JoinedStreams.WithWindow
-
Completes the join operation with the user function that is executed
for each combination of elements with the same key in a window.
- apply(JoinFunction<T1, T2, T>, TypeInformation<T>) - Method in class org.apache.flink.streaming.api.datastream.JoinedStreams.WithWindow
-
Completes the join operation with the user function that is executed
for each combination of elements with the same key in a window.
- apply(WindowFunction<T, R, K, W>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies the given window function to each window.
- apply(WindowFunction<T, R, K, W>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies the given window function to each window.
- apply(ReduceFunction<T>, WindowFunction<T, R, K, W>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
- apply(ReduceFunction<T>, WindowFunction<T, R, K, W>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
- apply(R, FoldFunction<T, R>, WindowFunction<R, R, K, W>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
- apply(R, FoldFunction<T, R>, WindowFunction<R, R, K, W>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
- apply(W, Iterable<T>, Collector<R>) - Method in class org.apache.flink.streaming.api.functions.windowing.AggregateApplyAllWindowFunction
-
- apply(K, W, Iterable<T>, Collector<R>) - Method in class org.apache.flink.streaming.api.functions.windowing.AggregateApplyWindowFunction
-
- apply(W, Iterable<IN>, Collector<OUT>) - Method in interface org.apache.flink.streaming.api.functions.windowing.AllWindowFunction
-
Evaluates the window and outputs none or several elements.
- apply(W, Iterable<T>, Collector<R>) - Method in class org.apache.flink.streaming.api.functions.windowing.FoldApplyAllWindowFunction
-
Deprecated.
- apply(K, W, Iterable<T>, Collector<R>) - Method in class org.apache.flink.streaming.api.functions.windowing.FoldApplyWindowFunction
-
Deprecated.
- apply(W, Iterable<T>, Collector<T>) - Method in class org.apache.flink.streaming.api.functions.windowing.PassThroughAllWindowFunction
-
- apply(K, W, Iterable<T>, Collector<T>) - Method in class org.apache.flink.streaming.api.functions.windowing.PassThroughWindowFunction
-
- apply(W, Iterable<T>, Collector<R>) - Method in class org.apache.flink.streaming.api.functions.windowing.ReduceApplyAllWindowFunction
-
- apply(K, W, Iterable<T>, Collector<R>) - Method in class org.apache.flink.streaming.api.functions.windowing.ReduceApplyWindowFunction
-
- apply(KEY, W, Iterable<IN>, Collector<OUT>) - Method in interface org.apache.flink.streaming.api.functions.windowing.WindowFunction
-
Evaluates the window and outputs none or several elements.
- apply(TimeWindow, Iterable<Integer>, Collector<Double[]>) - Method in class org.apache.flink.streaming.examples.ml.IncrementalLearningSkeleton.PartialModelBuilder
-
- apply(WindowFunction<PyObject, Object, Object, W>) - Method in class org.apache.flink.streaming.python.api.datastream.PythonWindowedStream
-
- apply(PyKey, W, Iterable<PyObject>, Collector<PyObject>) - Method in class org.apache.flink.streaming.python.api.functions.PythonApplyFunction
-
- apply(Statement, Description) - Method in class org.apache.flink.testutils.junit.RetryRule
-
- apply(T, U) - Method in interface org.apache.flink.util.function.BiFunctionWithException
-
Apply the given values t and u to obtain the resulting value.
- apply(T) - Method in interface org.apache.flink.util.function.FunctionWithException
-
Calls this function.
- apply(S, T, U) - Method in interface org.apache.flink.util.function.TriFunction
-
Applies this function to the given arguments.
- applyCommandLineOptionsToConfiguration(CommandLine) - Method in class org.apache.flink.client.cli.AbstractCustomCommandLine
-
Override configuration settings by specified command line options.
- applyCommandLineOptionsToConfiguration(CommandLine) - Method in class org.apache.flink.yarn.cli.FlinkYarnSessionCli
-
- ApplyFunction<K,VV,M> - Class in org.apache.flink.graph.gsa
-
- ApplyFunction() - Constructor for class org.apache.flink.graph.gsa.ApplyFunction
-
- applyIteratorTrueAssumption() - Method in class org.apache.flink.api.java.sca.UdfAnalyzer
-
- applyOverlays(Configuration, ContainerSpecification) - Static method in class org.apache.flink.mesos.entrypoint.MesosEntrypointUtils
-
Generate a container specification as a TaskManager template.
- applyPredicate(List<Expression>) - Method in class org.apache.flink.orc.OrcTableSource
-
- applyRegistrations(Kryo, Collection<KryoRegistration>) - Static method in class org.apache.flink.api.java.typeutils.runtime.KryoUtils
-
- applyRepartitioner(OperatorID, OperatorStateRepartitioner, List<OperatorStateHandle>, int, int) - Static method in class org.apache.flink.runtime.checkpoint.StateAssignmentOperation
-
- applyRepartitioner(OperatorStateRepartitioner, List<OperatorStateHandle>, int, int) - Static method in class org.apache.flink.runtime.checkpoint.StateAssignmentOperation
-
- applyTo(ParameterTool) - Method in class org.apache.flink.api.java.utils.RequiredParameters
-
Check for all required parameters defined:
- has a value been passed
- if not, does the parameter have an associated default value
- does the type of the parameter match the one defined in RequiredParameters
- does the value provided in the parameterTool adhere to the choices defined in the option.
- applyToAllKeys(N, TypeSerializer<N>, StateDescriptor<S, T>, KeyedStateFunction<K, S>) - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
-
- applyToAllKeys(N, TypeSerializer<N>, StateDescriptor<S, T>, KeyedStateFunction<K, S>) - Method in class org.apache.flink.runtime.state.heap.HeapKeyedStateBackend
-
- applyToAllKeys(N, TypeSerializer<N>, StateDescriptor<S, T>, KeyedStateFunction<K, S>) - Method in interface org.apache.flink.runtime.state.KeyedStateBackend
-
- applyToAllWhileSuppressingExceptions(Iterable<T>, ThrowingConsumer<T, ? extends Exception>) - Static method in class org.apache.flink.util.LambdaUtil
-
This method supplies all elements from the input to the consumer.
- applyToKeyedState(StateDescriptor<S, VS>, KeyedStateFunction<KS, S>) - Method in class org.apache.flink.streaming.api.functions.co.KeyedBroadcastProcessFunction.Context
-
Applies the provided function
to the state
associated with the provided state descriptor
.
- archive() - Method in interface org.apache.flink.api.common.Archiveable
-
- archive() - Method in class org.apache.flink.api.common.ExecutionConfig
-
- archive() - Method in class org.apache.flink.runtime.executiongraph.Execution
-
- archive() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
- archive() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- ARCHIVE_COUNT - Static variable in class org.apache.flink.configuration.WebOptions
-
The config parameter defining the number of archived jobs for the jobmanager.
- ARCHIVE_DIR - Static variable in class org.apache.flink.configuration.JobManagerOptions
-
The location where the JobManager stores the archives of completed jobs.
- ARCHIVE_NAME - Static variable in class org.apache.flink.runtime.jobmaster.JobMaster
-
- Archiveable<T extends Serializable> - Interface in org.apache.flink.api.common
-
- ArchivedExecution - Class in org.apache.flink.runtime.executiongraph
-
- ArchivedExecution(Execution) - Constructor for class org.apache.flink.runtime.executiongraph.ArchivedExecution
-
- ArchivedExecution(StringifiedAccumulatorResult[], IOMetrics, ExecutionAttemptID, int, ExecutionState, String, TaskManagerLocation, AllocationID, int, long[]) - Constructor for class org.apache.flink.runtime.executiongraph.ArchivedExecution
-
- ArchivedExecutionConfig - Class in org.apache.flink.api.common
-
Serializable class which is created when archiving the job.
- ArchivedExecutionConfig(ExecutionConfig) - Constructor for class org.apache.flink.api.common.ArchivedExecutionConfig
-
- ArchivedExecutionConfig(String, String, int, boolean, Map<String, String>) - Constructor for class org.apache.flink.api.common.ArchivedExecutionConfig
-
- ArchivedExecutionGraph - Class in org.apache.flink.runtime.executiongraph
-
An archived execution graph represents a serializable form of the
ExecutionGraph
.
- ArchivedExecutionGraph(JobID, String, Map<JobVertexID, ArchivedExecutionJobVertex>, List<ArchivedExecutionJobVertex>, long[], JobStatus, ErrorInfo, String, StringifiedAccumulatorResult[], Map<String, SerializedValue<OptionalFailure<Object>>>, ArchivedExecutionConfig, boolean, CheckpointCoordinatorConfiguration, CheckpointStatsSnapshot) - Constructor for class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
-
- ArchivedExecutionGraphStore - Interface in org.apache.flink.runtime.dispatcher
-
- ArchivedExecutionJobVertex - Class in org.apache.flink.runtime.executiongraph
-
- ArchivedExecutionJobVertex(ExecutionJobVertex) - Constructor for class org.apache.flink.runtime.executiongraph.ArchivedExecutionJobVertex
-
- ArchivedExecutionJobVertex(ArchivedExecutionVertex[], JobVertexID, String, int, int, StringifiedAccumulatorResult[]) - Constructor for class org.apache.flink.runtime.executiongraph.ArchivedExecutionJobVertex
-
- ArchivedExecutionVertex - Class in org.apache.flink.runtime.executiongraph
-
- ArchivedExecutionVertex(ExecutionVertex) - Constructor for class org.apache.flink.runtime.executiongraph.ArchivedExecutionVertex
-
- ArchivedExecutionVertex(int, String, ArchivedExecution, EvictingBoundedList<ArchivedExecution>) - Constructor for class org.apache.flink.runtime.executiongraph.ArchivedExecutionVertex
-
- ArchivedJson - Class in org.apache.flink.runtime.webmonitor.history
-
A simple container for a handler's JSON response and the REST URLs for which the response would've been returned.
- ArchivedJson(String, String) - Constructor for class org.apache.flink.runtime.webmonitor.history.ArchivedJson
-
- ArchivedJson(String, ResponseBody) - Constructor for class org.apache.flink.runtime.webmonitor.history.ArchivedJson
-
- archiveExecutionGraph(AccessExecutionGraph) - Method in interface org.apache.flink.runtime.dispatcher.HistoryServerArchivist
-
- archiveJob(Path, AccessExecutionGraph) - Static method in class org.apache.flink.runtime.history.FsJobArchivist
-
- archiveJob(Path, JobID, Collection<ArchivedJson>) - Static method in class org.apache.flink.runtime.history.FsJobArchivist
-
- archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.job.checkpoints.CheckpointConfigHandler
-
- archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.job.checkpoints.CheckpointingStatisticsHandler
-
- archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.job.checkpoints.CheckpointStatisticDetailsHandler
-
- archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.job.checkpoints.TaskCheckpointStatisticDetailsHandler
-
- archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.job.JobAccumulatorsHandler
-
- archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.job.JobConfigHandler
-
- archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.job.JobDetailsHandler
-
- archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.job.JobExceptionsHandler
-
- archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.job.JobPlanHandler
-
- archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.job.JobsOverviewHandler
-
- archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.job.JobVertexDetailsHandler
-
- archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.job.JobVertexTaskManagersHandler
-
- archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.job.SubtaskExecutionAttemptAccumulatorsHandler
-
- archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.job.SubtaskExecutionAttemptDetailsHandler
-
- archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.job.SubtasksTimesHandler
-
- archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.legacy.checkpoints.CheckpointConfigHandler.CheckpointConfigJsonArchivist
-
- archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.legacy.checkpoints.CheckpointStatsDetailsHandler.CheckpointStatsDetailsJsonArchivist
-
- archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.legacy.checkpoints.CheckpointStatsDetailsSubtasksHandler.CheckpointStatsDetailsSubtasksJsonArchivist
-
- archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.legacy.checkpoints.CheckpointStatsHandler.CheckpointStatsJsonArchivist
-
- archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.legacy.JobAccumulatorsHandler.JobAccumulatorsJsonArchivist
-
- archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.legacy.JobConfigHandler.JobConfigJsonArchivist
-
- archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.legacy.JobDetailsHandler.JobDetailsJsonArchivist
-
- archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.legacy.JobExceptionsHandler.JobExceptionsJsonArchivist
-
- archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.legacy.JobPlanHandler.JobPlanJsonArchivist
-
- archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.legacy.JobsOverviewHandler.CurrentJobsOverviewJsonArchivist
-
- archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.legacy.JobVertexAccumulatorsHandler.JobVertexAccumulatorsJsonArchivist
-
- archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.legacy.JobVertexDetailsHandler.JobVertexDetailsJsonArchivist
-
- archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.legacy.JobVertexTaskManagersHandler.JobVertexTaskManagersJsonArchivist
-
- archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.legacy.SubtaskExecutionAttemptAccumulatorsHandler.SubtaskExecutionAttemptAccumulatorsJsonArchivist
-
- archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.legacy.SubtaskExecutionAttemptDetailsHandler.SubtaskExecutionAttemptDetailsJsonArchivist
-
- archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.legacy.SubtasksAllAccumulatorsHandler.SubtasksAllAccumulatorsJsonArchivist
-
- archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.legacy.SubtasksTimesHandler.SubtasksTimesJsonArchivist
-
- archiveJsonWithPath(AccessExecutionGraph) - Method in interface org.apache.flink.runtime.webmonitor.history.JsonArchivist
-
Returns a
Collection
of
ArchivedJson
s containing JSON responses and their respective REST URL
for a given job.
- archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.webmonitor.WebMonitorEndpoint
-
- areBranchCompatible(PlanNode, PlanNode) - Method in class org.apache.flink.optimizer.dag.OptimizerNode
-
Checks whether to candidate plans for the sub-plan of this node are comparable.
- areCoFulfilled(RequestedLocalProperties, RequestedLocalProperties, LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.AbstractSortMergeJoinDescriptor
-
- areCoFulfilled(RequestedLocalProperties, RequestedLocalProperties, LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.BinaryUnionOpDescriptor
-
- areCoFulfilled(RequestedLocalProperties, RequestedLocalProperties, LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.CartesianProductDescriptor
-
- areCoFulfilled(RequestedLocalProperties, RequestedLocalProperties, LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.CoGroupDescriptor
-
- areCoFulfilled(RequestedLocalProperties, RequestedLocalProperties, LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.CoGroupRawDescriptor
-
- areCoFulfilled(RequestedLocalProperties, RequestedLocalProperties, LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.CoGroupWithSolutionSetFirstDescriptor
-
- areCoFulfilled(RequestedLocalProperties, RequestedLocalProperties, LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.CoGroupWithSolutionSetSecondDescriptor
-
- areCoFulfilled(RequestedLocalProperties, RequestedLocalProperties, LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.HashFullOuterJoinBuildFirstDescriptor
-
- areCoFulfilled(RequestedLocalProperties, RequestedLocalProperties, LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.HashFullOuterJoinBuildSecondDescriptor
-
- areCoFulfilled(RequestedLocalProperties, RequestedLocalProperties, LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.HashJoinBuildFirstProperties
-
- areCoFulfilled(RequestedLocalProperties, RequestedLocalProperties, LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.HashJoinBuildSecondProperties
-
- areCoFulfilled(RequestedLocalProperties, RequestedLocalProperties, LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.HashLeftOuterJoinBuildFirstDescriptor
-
- areCoFulfilled(RequestedLocalProperties, RequestedLocalProperties, LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.HashLeftOuterJoinBuildSecondDescriptor
-
- areCoFulfilled(RequestedLocalProperties, RequestedLocalProperties, LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.HashRightOuterJoinBuildFirstDescriptor
-
- areCoFulfilled(RequestedLocalProperties, RequestedLocalProperties, LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.HashRightOuterJoinBuildSecondDescriptor
-
- areCoFulfilled(RequestedLocalProperties, RequestedLocalProperties, LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.OperatorDescriptorDual
-
- areCoFulfilled(RequestedLocalProperties, RequestedLocalProperties, LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.UtilSinkJoinOpDescriptor
-
- areCompatible(Keys<?>) - Method in class org.apache.flink.api.common.operators.Keys
-
Check if two sets of keys are compatible to each other (matching types, key counts)
- areCompatible(RequestedGlobalProperties, RequestedGlobalProperties, GlobalProperties, GlobalProperties) - Method in class org.apache.flink.optimizer.operators.AbstractJoinDescriptor
-
- areCompatible(RequestedGlobalProperties, RequestedGlobalProperties, GlobalProperties, GlobalProperties) - Method in class org.apache.flink.optimizer.operators.BinaryUnionOpDescriptor
-
- areCompatible(RequestedGlobalProperties, RequestedGlobalProperties, GlobalProperties, GlobalProperties) - Method in class org.apache.flink.optimizer.operators.CartesianProductDescriptor
-
- areCompatible(RequestedGlobalProperties, RequestedGlobalProperties, GlobalProperties, GlobalProperties) - Method in class org.apache.flink.optimizer.operators.CoGroupDescriptor
-
- areCompatible(RequestedGlobalProperties, RequestedGlobalProperties, GlobalProperties, GlobalProperties) - Method in class org.apache.flink.optimizer.operators.CoGroupRawDescriptor
-
- areCompatible(RequestedGlobalProperties, RequestedGlobalProperties, GlobalProperties, GlobalProperties) - Method in class org.apache.flink.optimizer.operators.OperatorDescriptorDual
-
- areCompatible(RequestedGlobalProperties, RequestedGlobalProperties, GlobalProperties, GlobalProperties) - Method in class org.apache.flink.optimizer.operators.UtilSinkJoinOpDescriptor
-
- areExplicitEnvironmentsAllowed() - Static method in class org.apache.flink.api.java.ExecutionEnvironment
-
Checks whether it is currently permitted to explicitly instantiate a LocalEnvironment
or a RemoteEnvironment.
- areFieldsUnique(FieldSet) - Method in class org.apache.flink.optimizer.dataproperties.LocalProperties
-
Checks whether the given set of fields is unique, as specified in these local properties.
- ARG_CONVERSION_DURATION - Static variable in class org.apache.flink.dropwizard.ScheduledDropwizardReporter
-
- ARG_CONVERSION_RATE - Static variable in class org.apache.flink.dropwizard.ScheduledDropwizardReporter
-
- ARG_HOST - Static variable in class org.apache.flink.dropwizard.ScheduledDropwizardReporter
-
- ARG_HOST - Static variable in class org.apache.flink.metrics.statsd.StatsDReporter
-
- ARG_PORT - Static variable in class org.apache.flink.dropwizard.ScheduledDropwizardReporter
-
- ARG_PORT - Static variable in class org.apache.flink.metrics.jmx.JMXReporter
-
- ARG_PORT - Static variable in class org.apache.flink.metrics.statsd.StatsDReporter
-
- ARG_PREFIX - Static variable in class org.apache.flink.dropwizard.ScheduledDropwizardReporter
-
- ARG_PROTOCOL - Static variable in class org.apache.flink.metrics.graphite.GraphiteReporter
-
- arity - Variable in class org.apache.flink.api.java.typeutils.runtime.TupleSerializerBase
-
- array() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
-
- arrayAwareToString(Object) - Static method in class org.apache.flink.util.StringUtils
-
This method calls
Object.toString()
on the given object, unless the
object is an array.
- ArrayFromTuple - Class in org.apache.flink.streaming.api.functions.windowing.delta.extractor
-
Converts a Tuple to an Object-Array.
- ArrayFromTuple() - Constructor for class org.apache.flink.streaming.api.functions.windowing.delta.extractor.ArrayFromTuple
-
Using this constructor the extractor will convert the whole tuple (all
fields in the original order) to an array.
- ArrayFromTuple(int...) - Constructor for class org.apache.flink.streaming.api.functions.windowing.delta.extractor.ArrayFromTuple
-
Using this constructor the extractor will combine the fields as specified
in the indexes parameter in an object array.
- ArrayListSerializer<T> - Class in org.apache.flink.runtime.state
-
- ArrayListSerializer(TypeSerializer<T>) - Constructor for class org.apache.flink.runtime.state.ArrayListSerializer
-
- arrayNext() - Method in class org.apache.flink.formats.avro.utils.DataInputDecoder
-
- arrayOffset() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
-
- arrayToMap(String[]) - Static method in class org.apache.flink.runtime.metrics.scope.ScopeFormat
-
- arrayToString(Object) - Static method in class org.apache.flink.util.StringUtils
-
Returns a string representation of the given array.
- Artifact(Path, Path, boolean, boolean, boolean) - Constructor for class org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact
-
- ARTIFACT_SERVER_PORT - Static variable in class org.apache.flink.mesos.configuration.MesosOptions
-
The config parameter defining the Mesos artifact server port to use.
- ARTIFACT_SERVER_SSL_ENABLED - Static variable in class org.apache.flink.mesos.configuration.MesosOptions
-
Config parameter to override SSL support for the Artifact Server.
- ArtificalOperatorStateMapper<IN,OUT> - Class in org.apache.flink.streaming.tests.artificialstate
-
A self-verifiable
RichMapFunction
used to verify checkpointing and restore semantics for various
kinds of operator state.
- ArtificalOperatorStateMapper(MapFunction<IN, OUT>) - Constructor for class org.apache.flink.streaming.tests.artificialstate.ArtificalOperatorStateMapper
-
- ArtificialKeyedStateMapper<IN,OUT> - Class in org.apache.flink.streaming.tests.artificialstate
-
- ArtificialKeyedStateMapper(MapFunction<IN, OUT>, ArtificialStateBuilder<IN>) - Constructor for class org.apache.flink.streaming.tests.artificialstate.ArtificialKeyedStateMapper
-
- ArtificialKeyedStateMapper(MapFunction<IN, OUT>, List<ArtificialStateBuilder<IN>>) - Constructor for class org.apache.flink.streaming.tests.artificialstate.ArtificialKeyedStateMapper
-
- ArtificialListStateBuilder<IN,STATE> - Class in org.apache.flink.streaming.tests.artificialstate.builder
-
- ArtificialListStateBuilder(String, JoinFunction<IN, Iterable<STATE>, List<STATE>>, JoinFunction<IN, Iterable<STATE>, List<STATE>>, TypeSerializer<STATE>) - Constructor for class org.apache.flink.streaming.tests.artificialstate.builder.ArtificialListStateBuilder
-
- ArtificialMapStateBuilder<IN,K,V> - Class in org.apache.flink.streaming.tests.artificialstate.builder
-
- ArtificialMapStateBuilder(String, JoinFunction<IN, Iterator<Map.Entry<K, V>>, Iterator<Map.Entry<K, V>>>, TypeSerializer<K>, TypeSerializer<V>) - Constructor for class org.apache.flink.streaming.tests.artificialstate.builder.ArtificialMapStateBuilder
-
- ArtificialStateBuilder<T> - Class in org.apache.flink.streaming.tests.artificialstate.builder
-
The state builder wraps the logic of registering state in user
functions, as well as how state is updated per input element..
- ArtificialStateBuilder(String) - Constructor for class org.apache.flink.streaming.tests.artificialstate.builder.ArtificialStateBuilder
-
- artificialStateForElement(IN) - Method in class org.apache.flink.streaming.tests.artificialstate.builder.ArtificialListStateBuilder
-
- artificialStateForElement(IN) - Method in class org.apache.flink.streaming.tests.artificialstate.builder.ArtificialMapStateBuilder
-
- artificialStateForElement(T) - Method in class org.apache.flink.streaming.tests.artificialstate.builder.ArtificialStateBuilder
-
Manipulate the state for an input element.
- artificialStateForElement(IN) - Method in class org.apache.flink.streaming.tests.artificialstate.builder.ArtificialValueStateBuilder
-
- ArtificialValueStateBuilder<IN,STATE> - Class in org.apache.flink.streaming.tests.artificialstate.builder
-
- ArtificialValueStateBuilder(String, JoinFunction<IN, STATE, STATE>, TypeSerializer<STATE>) - Constructor for class org.apache.flink.streaming.tests.artificialstate.builder.ArtificialValueStateBuilder
-
- asArray(Class<U>) - Static method in class org.apache.flink.api.common.operators.AbstractUdfOperator
-
Generic utility function that wraps a single class object into an array of that class type.
- asByteBuf() - Method in interface org.apache.flink.runtime.io.network.buffer.Buffer
-
- asByteBuf() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
-
- asByteBuf() - Method in class org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
-
- ascending - Variable in class org.apache.flink.api.common.typeutils.base.array.PrimitiveArrayComparator
-
- ascendingComparison - Variable in class org.apache.flink.api.common.typeutils.base.BasicTypeComparator
-
- AscendingTimestampExtractor<T> - Class in org.apache.flink.streaming.api.functions
-
- AscendingTimestampExtractor() - Constructor for class org.apache.flink.streaming.api.functions.AscendingTimestampExtractor
-
Deprecated.
- AscendingTimestampExtractor<T> - Class in org.apache.flink.streaming.api.functions.timestamps
-
A timestamp assigner and watermark generator for streams where timestamps are monotonously
ascending.
- AscendingTimestampExtractor() - Constructor for class org.apache.flink.streaming.api.functions.timestamps.AscendingTimestampExtractor
-
- AscendingTimestampExtractor.FailingHandler - Class in org.apache.flink.streaming.api.functions.timestamps
-
Handler that fails the program when timestamp monotony is violated.
- AscendingTimestampExtractor.IgnoringHandler - Class in org.apache.flink.streaming.api.functions.timestamps
-
Handler that does nothing when timestamp monotony is violated.
- AscendingTimestampExtractor.LoggingHandler - Class in org.apache.flink.streaming.api.functions.timestamps
-
Handler that only logs violations of timestamp monotony, on WARN log level.
- AscendingTimestampExtractor.MonotonyViolationHandler - Interface in org.apache.flink.streaming.api.functions.timestamps
-
Interface for handlers that handle violations of the monotonous ascending timestamps
property.
- asFile(String) - Static method in class org.apache.flink.test.util.TestBaseUtils
-
- asFlinkTuples() - Method in class org.apache.flink.hcatalog.HCatInputFormatBase
-
Specifies that the InputFormat returns Flink tuples instead of
HCatRecord
.
- ask(Object, FiniteDuration) - Method in interface org.apache.flink.runtime.instance.ActorGateway
-
Sends a message asynchronously and returns its response.
- ask(Object, FiniteDuration) - Method in class org.apache.flink.runtime.instance.AkkaActorGateway
-
Sends a message asynchronously and returns its response.
- ask(Object, Time) - Method in class org.apache.flink.runtime.rpc.akka.FencedAkkaInvocationHandler
-
- ASK_TIMEOUT - Static variable in class org.apache.flink.configuration.AkkaOptions
-
Timeout for akka ask calls.
- asLatencyMarker() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElement
-
Casts this element into a LatencyMarker.
- asQueryableState(String) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Publishes the keyed stream as queryable ValueState instance.
- asQueryableState(String, ValueStateDescriptor<T>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Publishes the keyed stream as a queryable ValueState instance.
- asQueryableState(String, FoldingStateDescriptor<T, ACC>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
- asQueryableState(String, ReducingStateDescriptor<T>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Publishes the keyed stream as a queryable ReducingState instance.
- asRecord() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElement
-
Casts this element into a StreamRecord.
- asResultCollection() - Method in interface org.apache.flink.streaming.api.operators.async.queue.AsyncResult
-
Return this async result as a async result collection.
- asResultCollection() - Method in class org.apache.flink.streaming.api.operators.async.queue.StreamElementQueueEntry
-
- assign(KafkaTopicPartition, int) - Static method in class org.apache.flink.streaming.connectors.kafka.internals.KafkaTopicPartitionAssigner
-
Returns the index of the target subtask that a specific Kafka partition should be
assigned to.
- AssignerWithPeriodicWatermarks<T> - Interface in org.apache.flink.streaming.api.functions
-
The AssignerWithPeriodicWatermarks
assigns event time timestamps to elements,
and generates low watermarks that signal event time progress within the stream.
- AssignerWithPunctuatedWatermarks<T> - Interface in org.apache.flink.streaming.api.functions
-
The AssignerWithPunctuatedWatermarks
assigns event time timestamps to elements,
and generates low watermarks that signal event time progress within the stream.
- assignExclusiveSegments(NetworkBufferPool, int) - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
-
Assign the exclusive buffers to all remote input channels directly for credit-based mode.
- assignKeyToParallelOperator(Object, int, int) - Static method in class org.apache.flink.runtime.state.KeyGroupRangeAssignment
-
Assigns the given key to a parallel operator index.
- assignPartition(int, byte) - Static method in class org.apache.flink.runtime.operators.hash.MutableHashTable
-
Assigns a partition to a bucket.
- assignPartitions(KafkaConsumer<?, ?>, List<TopicPartition>) - Method in class org.apache.flink.streaming.connectors.kafka.internal.KafkaConsumerCallBridge
-
- assignPartitions(KafkaConsumer<?, ?>, List<TopicPartition>) - Method in class org.apache.flink.streaming.connectors.kafka.internal.KafkaConsumerCallBridge010
-
- assignPendingSlotRequest(PendingSlotRequest) - Method in class org.apache.flink.runtime.clusterframework.types.TaskManagerSlot
-
- AssignRangeIndex<IN> - Class in org.apache.flink.runtime.operators.udf
-
This mapPartition function require a DataSet with RangeBoundaries as broadcast input, it
generate Tuple2 which includes range index and record itself as output.
- AssignRangeIndex(TypeComparatorFactory<IN>) - Constructor for class org.apache.flink.runtime.operators.udf.AssignRangeIndex
-
- assignStates() - Method in class org.apache.flink.runtime.checkpoint.StateAssignmentOperation
-
- assignTimestamps(TimestampExtractor<T>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
- assignTimestampsAndWatermarks(AssignerWithPeriodicWatermarks<T>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Assigns timestamps to the elements in the data stream and periodically creates
watermarks to signal event time progress.
- assignTimestampsAndWatermarks(AssignerWithPunctuatedWatermarks<T>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Assigns timestamps to the elements in the data stream and creates watermarks to
signal event time progress based on the elements themselves.
- assignTimestampsAndWatermarks(AssignerWithPunctuatedWatermarks<T>) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumerBase
-
- assignTimestampsAndWatermarks(AssignerWithPeriodicWatermarks<T>) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumerBase
-
- assignToKeyGroup(Object, int) - Static method in class org.apache.flink.runtime.state.KeyGroupRangeAssignment
-
Assigns the given key to a key-group index.
- assignWindows(Object, long, WindowAssigner.WindowAssignerContext) - Method in class org.apache.flink.streaming.api.windowing.assigners.BaseAlignedWindowAssigner
-
- assignWindows(T, long, WindowAssigner.WindowAssignerContext) - Method in class org.apache.flink.streaming.api.windowing.assigners.DynamicEventTimeSessionWindows
-
- assignWindows(T, long, WindowAssigner.WindowAssignerContext) - Method in class org.apache.flink.streaming.api.windowing.assigners.DynamicProcessingTimeSessionWindows
-
- assignWindows(Object, long, WindowAssigner.WindowAssignerContext) - Method in class org.apache.flink.streaming.api.windowing.assigners.EventTimeSessionWindows
-
- assignWindows(Object, long, WindowAssigner.WindowAssignerContext) - Method in class org.apache.flink.streaming.api.windowing.assigners.GlobalWindows
-
- assignWindows(Object, long, WindowAssigner.WindowAssignerContext) - Method in class org.apache.flink.streaming.api.windowing.assigners.ProcessingTimeSessionWindows
-
- assignWindows(Object, long, WindowAssigner.WindowAssignerContext) - Method in class org.apache.flink.streaming.api.windowing.assigners.SlidingEventTimeWindows
-
- assignWindows(Object, long, WindowAssigner.WindowAssignerContext) - Method in class org.apache.flink.streaming.api.windowing.assigners.SlidingProcessingTimeWindows
-
- assignWindows(Object, long, WindowAssigner.WindowAssignerContext) - Method in class org.apache.flink.streaming.api.windowing.assigners.TumblingEventTimeWindows
-
- assignWindows(Object, long, WindowAssigner.WindowAssignerContext) - Method in class org.apache.flink.streaming.api.windowing.assigners.TumblingProcessingTimeWindows
-
- assignWindows(T, long, WindowAssigner.WindowAssignerContext) - Method in class org.apache.flink.streaming.api.windowing.assigners.WindowAssigner
-
Returns a Collection
of windows that should be assigned to the element.
- asStreamStatus() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElement
-
Casts this element into a StreamStatus.
- asVariable(String) - Static method in class org.apache.flink.runtime.metrics.scope.ScopeFormat
-
Formats the given string to resemble a scope variable.
- asWatermark() - Method in interface org.apache.flink.streaming.api.operators.async.queue.AsyncResult
-
Return this async result as a async watermark result.
- asWatermark() - Method in class org.apache.flink.streaming.api.operators.async.queue.StreamElementQueueEntry
-
- asWatermark() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElement
-
Casts this element into a Watermark.
- ASYNC_SNAPSHOTS - Static variable in class org.apache.flink.configuration.CheckpointingOptions
-
Option whether the state backend should use an asynchronous snapshot method where
possible and configurable.
- AsyncCollectionResult<T> - Interface in org.apache.flink.streaming.api.operators.async.queue
-
AsyncResult
sub class for asynchronous result collections.
- AsyncDataStream - Class in org.apache.flink.streaming.api.datastream
-
- AsyncDataStream() - Constructor for class org.apache.flink.streaming.api.datastream.AsyncDataStream
-
- AsyncDataStream.OutputMode - Enum in org.apache.flink.streaming.api.datastream
-
Output mode for asynchronous operations.
- AsyncDoneCallback - Interface in org.apache.flink.runtime.io.async
-
Callback for an asynchronous operation that is called on termination
- asyncException - Variable in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducerBase
-
Errors encountered in the async producer are stored here.
- AsyncExceptionHandler - Interface in org.apache.flink.streaming.runtime.tasks
-
An interface marking a task as capable of handling exceptions thrown
by different threads, other than the one executing the task itself.
- AsyncFunction<IN,OUT> - Interface in org.apache.flink.streaming.api.functions.async
-
A function to trigger Async I/O operation.
- AsynchronousBlockReader - Class in org.apache.flink.runtime.io.disk.iomanager
-
A reader that reads data in blocks from a file channel.
- AsynchronousBlockReader(FileIOChannel.ID, RequestQueue<ReadRequest>, LinkedBlockingQueue<MemorySegment>) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBlockReader
-
Creates a new block channel reader for the given channel.
- AsynchronousBlockWriter - Class in org.apache.flink.runtime.io.disk.iomanager
-
- AsynchronousBlockWriter(FileIOChannel.ID, RequestQueue<WriteRequest>, LinkedBlockingQueue<MemorySegment>) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBlockWriter
-
Creates a new block channel writer for the given channel.
- AsynchronousBlockWriterWithCallback - Class in org.apache.flink.runtime.io.disk.iomanager
-
- AsynchronousBlockWriterWithCallback(FileIOChannel.ID, RequestQueue<WriteRequest>, RequestDoneCallback<MemorySegment>) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBlockWriterWithCallback
-
Creates a new asynchronous block writer for the given channel.
- AsynchronousBufferFileReader - Class in org.apache.flink.runtime.io.disk.iomanager
-
- AsynchronousBufferFileReader(FileIOChannel.ID, RequestQueue<ReadRequest>, RequestDoneCallback<Buffer>) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBufferFileReader
-
- AsynchronousBufferFileSegmentReader - Class in org.apache.flink.runtime.io.disk.iomanager
-
- AsynchronousBufferFileSegmentReader(FileIOChannel.ID, RequestQueue<ReadRequest>, RequestDoneCallback<FileSegment>) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBufferFileSegmentReader
-
- AsynchronousBufferFileWriter - Class in org.apache.flink.runtime.io.disk.iomanager
-
- AsynchronousBufferFileWriter(FileIOChannel.ID, RequestQueue<WriteRequest>) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBufferFileWriter
-
- AsynchronousBulkBlockReader - Class in org.apache.flink.runtime.io.disk.iomanager
-
- AsynchronousBulkBlockReader(FileIOChannel.ID, RequestQueue<ReadRequest>, List<MemorySegment>, int) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBulkBlockReader
-
- AsynchronousException - Exception in org.apache.flink.streaming.runtime.tasks
-
An exception for wrapping exceptions that are thrown by an operator in threads other than the
main compute thread of that operator.
- AsynchronousException(Throwable) - Constructor for exception org.apache.flink.streaming.runtime.tasks.AsynchronousException
-
- AsynchronousException(String, Throwable) - Constructor for exception org.apache.flink.streaming.runtime.tasks.AsynchronousException
-
- AsynchronousFileIOChannel<T,R extends org.apache.flink.runtime.io.disk.iomanager.IORequest> - Class in org.apache.flink.runtime.io.disk.iomanager
-
A base class for readers and writers that accept read or write requests for whole blocks.
- AsynchronousFileIOChannel(FileIOChannel.ID, RequestQueue<R>, RequestDoneCallback<T>, boolean) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.AsynchronousFileIOChannel
-
Creates a new channel access to the path indicated by the given ID.
- AsynchronousJobOperationKey - Class in org.apache.flink.runtime.rest.handler.job
-
A pair of
JobID
and
TriggerId
used as a key to a hash based
collection.
- AsynchronouslyCreatedResource<T> - Interface in org.apache.flink.runtime.rest.messages.queue
-
Interface for REST resources that are created asynchronously.
- AsynchronousOperationInfo - Class in org.apache.flink.runtime.rest.handler.async
-
Basic information object for asynchronous operations.
- AsynchronousOperationResult<V> - Class in org.apache.flink.runtime.rest.handler.async
-
Result of an asynchronous operation.
- AsynchronousOperationStatusMessageHeaders<V,M extends MessageParameters> - Class in org.apache.flink.runtime.rest.handler.async
-
Message headers for the status polling of an asynchronous operation.
- AsynchronousOperationStatusMessageHeaders() - Constructor for class org.apache.flink.runtime.rest.handler.async.AsynchronousOperationStatusMessageHeaders
-
- AsynchronousOperationTriggerMessageHeaders<R extends RequestBody,M extends MessageParameters> - Class in org.apache.flink.runtime.rest.handler.async
-
Message headers for the triggering of an asynchronous operation.
- AsynchronousOperationTriggerMessageHeaders() - Constructor for class org.apache.flink.runtime.rest.handler.async.AsynchronousOperationTriggerMessageHeaders
-
- asyncInvoke(IN, ResultFuture<OUT>) - Method in interface org.apache.flink.streaming.api.functions.async.AsyncFunction
-
Trigger async operation for each stream input.
- asyncInvoke(IN, ResultFuture<OUT>) - Method in class org.apache.flink.streaming.api.functions.async.RichAsyncFunction
-
- AsyncIOExample - Class in org.apache.flink.streaming.examples.async
-
- AsyncIOExample() - Constructor for class org.apache.flink.streaming.examples.async.AsyncIOExample
-
- AsyncResult - Interface in org.apache.flink.streaming.api.operators.async.queue
-
- AsyncStoppable - Interface in org.apache.flink.runtime.io.async
-
An asynchronous operation that can be stopped.
- AsyncStoppableTaskWithCallback<V> - Class in org.apache.flink.runtime.io.async
-
- AsyncStoppableTaskWithCallback(StoppableCallbackCallable<V>) - Constructor for class org.apache.flink.runtime.io.async.AsyncStoppableTaskWithCallback
-
- AsyncWaitOperator<IN,OUT> - Class in org.apache.flink.streaming.api.operators.async
-
- AsyncWaitOperator(AsyncFunction<IN, OUT>, long, int, AsyncDataStream.OutputMode) - Constructor for class org.apache.flink.streaming.api.operators.async.AsyncWaitOperator
-
- AsyncWatermarkResult - Interface in org.apache.flink.streaming.api.operators.async.queue
-
- AtomicDisposableReferenceCounter - Class in org.apache.flink.runtime.util
-
Atomic reference counter, which enters a "disposed" state after it reaches a configurable
reference count (default 0).
- AtomicDisposableReferenceCounter() - Constructor for class org.apache.flink.runtime.util.AtomicDisposableReferenceCounter
-
- AtomicDisposableReferenceCounter(int) - Constructor for class org.apache.flink.runtime.util.AtomicDisposableReferenceCounter
-
- AtomicKvStateRequestStats - Class in org.apache.flink.queryablestate.network.stats
-
- AtomicKvStateRequestStats() - Constructor for class org.apache.flink.queryablestate.network.stats.AtomicKvStateRequestStats
-
- AtomicType<T> - Interface in org.apache.flink.api.common.typeinfo
-
An atomic type is a type that is treated as one indivisible unit and where the entire type acts
as a key.
- attachJobGraph(List<JobVertex>) - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- attachToRunningJob(JobID, Configuration, ActorSystem, HighAvailabilityServices, FiniteDuration, boolean) - Static method in class org.apache.flink.runtime.client.JobClient
-
Attaches to a running Job using the JobID.
- attemptNumber() - Method in class org.apache.flink.runtime.metrics.groups.TaskMetricGroup
-
- ATTRIBUTE_COUNT - Static variable in class org.apache.flink.storm.wordcount.operators.BoltCounter
-
- ATTRIBUTE_COUNT - Static variable in class org.apache.flink.storm.wordcount.operators.BoltCounterByName
-
- ATTRIBUTE_COUNT - Static variable in class org.apache.flink.storm.wordcount.operators.BoltTokenizer
-
- ATTRIBUTE_COUNT - Static variable in class org.apache.flink.storm.wordcount.operators.BoltTokenizerByName
-
- ATTRIBUTE_COUNT_INDEX - Static variable in class org.apache.flink.storm.wordcount.operators.BoltTokenizer
-
- ATTRIBUTE_COUNT_INDEX - Static variable in class org.apache.flink.storm.wordcount.operators.BoltTokenizerByName
-
- ATTRIBUTE_LINE - Static variable in class org.apache.flink.storm.util.AbstractLineSpout
-
- ATTRIBUTE_WORD - Static variable in class org.apache.flink.storm.wordcount.operators.BoltCounter
-
- ATTRIBUTE_WORD - Static variable in class org.apache.flink.storm.wordcount.operators.BoltCounterByName
-
- ATTRIBUTE_WORD - Static variable in class org.apache.flink.storm.wordcount.operators.BoltTokenizer
-
- ATTRIBUTE_WORD - Static variable in class org.apache.flink.storm.wordcount.operators.BoltTokenizerByName
-
- ATTRIBUTE_WORD_INDEX - Static variable in class org.apache.flink.storm.wordcount.operators.BoltTokenizer
-
- ATTRIBUTE_WORD_INDEX - Static variable in class org.apache.flink.storm.wordcount.operators.BoltTokenizerByName
-
- autoAck - Variable in class org.apache.flink.streaming.connectors.rabbitmq.RMQSource
-
- AutoCloseableAsync - Interface in org.apache.flink.util
-
Closeable interface which allows to close a resource in a non
blocking fashion.
- AuxiliaryConverter - Interface in org.apache.calcite.sql2rel
-
Converts an expression for a group window function (e.g.
- AuxiliaryConverter.Impl - Class in org.apache.calcite.sql2rel
-
- available() - Method in class org.apache.flink.core.fs.FSDataInputStreamWrapper
-
- available() - Method in class org.apache.flink.core.fs.local.LocalDataInputStream
-
- available() - Method in class org.apache.flink.core.memory.ByteArrayInputStreamWithPos
-
- available() - Method in class org.apache.flink.core.memory.DataInputDeserializer
-
- available() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopDataInputStream
-
- available() - Method in class org.apache.flink.runtime.state.BoundedInputStream
-
- available() - Method in class org.apache.flink.runtime.util.ForwardingInputStream
-
- availableMemory - Variable in class org.apache.flink.runtime.operators.hash.MutableHashTable
-
The free memory segments currently available to the hash join.
- AverageAccumulator - Class in org.apache.flink.api.common.accumulators
-
An accumulator that computes the average value.
- AverageAccumulator() - Constructor for class org.apache.flink.api.common.accumulators.AverageAccumulator
-
- AverageClusteringCoefficient<K extends Comparable<K> & CopyableValue<K>,VV,EV> - Class in org.apache.flink.graph.library.clustering.directed
-
The average clustering coefficient measures the mean connectedness of a
graph.
- AverageClusteringCoefficient() - Constructor for class org.apache.flink.graph.library.clustering.directed.AverageClusteringCoefficient
-
- AverageClusteringCoefficient<K extends Comparable<K> & CopyableValue<K>,VV,EV> - Class in org.apache.flink.graph.library.clustering.undirected
-
The average clustering coefficient measures the mean connectedness of a
graph.
- AverageClusteringCoefficient() - Constructor for class org.apache.flink.graph.library.clustering.undirected.AverageClusteringCoefficient
-
- AverageClusteringCoefficient.Result - Class in org.apache.flink.graph.library.clustering.directed
-
Wraps global clustering coefficient metrics.
- AverageClusteringCoefficient.Result - Class in org.apache.flink.graph.library.clustering.undirected
-
Wraps global clustering coefficient metrics.
- AVG_RECORD_BYTES_UNKNOWN - Static variable in interface org.apache.flink.api.common.io.statistics.BaseStatistics
-
Constant indicating that average record width is unknown.
- avgBytesPerRecord - Variable in class org.apache.flink.api.common.io.FileInputFormat.FileBaseStatistics
-
- AvroInputFormat<E> - Class in org.apache.flink.formats.avro
-
- AvroInputFormat(Path, Class<E>) - Constructor for class org.apache.flink.formats.avro.AvroInputFormat
-
- AvroKeyValue(GenericRecord) - Constructor for class org.apache.flink.streaming.connectors.fs.AvroKeyValueSinkWriter.AvroKeyValue
-
Wraps a GenericRecord that is a key value pair.
- AvroKeyValueSinkWriter<K,V> - Class in org.apache.flink.streaming.connectors.fs
-
Implementation of AvroKeyValue writer that can be used in Sink.
- AvroKeyValueSinkWriter(Map<String, String>) - Constructor for class org.apache.flink.streaming.connectors.fs.AvroKeyValueSinkWriter
-
C'tor for the writer.
- AvroKeyValueSinkWriter(AvroKeyValueSinkWriter<K, V>) - Constructor for class org.apache.flink.streaming.connectors.fs.AvroKeyValueSinkWriter
-
- AvroKeyValueSinkWriter.AvroKeyValue<K,V> - Class in org.apache.flink.streaming.connectors.fs
-
A reusable Avro generic record for writing key/value pairs to the
file.
- AvroKryoSerializerUtils - Class in org.apache.flink.formats.avro.utils
-
Utilities for integrating Avro serializers in Kryo.
- AvroKryoSerializerUtils() - Constructor for class org.apache.flink.formats.avro.utils.AvroKryoSerializerUtils
-
- AvroKryoSerializerUtils.AvroSchemaSerializer - Class in org.apache.flink.formats.avro.utils
-
Slow serialization approach for Avro schemas.
- AvroOutputFormat<E> - Class in org.apache.flink.formats.avro
-
- AvroOutputFormat(Path, Class<E>) - Constructor for class org.apache.flink.formats.avro.AvroOutputFormat
-
- AvroOutputFormat(Class<E>) - Constructor for class org.apache.flink.formats.avro.AvroOutputFormat
-
- AvroOutputFormat.Codec - Enum in org.apache.flink.formats.avro
-
Wrapper which encapsulates the supported codec and a related serialization byte.
- AvroRowDeserializationSchema - Class in org.apache.flink.formats.avro
-
Deserialization schema from Avro bytes over
SpecificRecord
to
Row
.
- AvroRowDeserializationSchema(Class<? extends SpecificRecord>) - Constructor for class org.apache.flink.formats.avro.AvroRowDeserializationSchema
-
Creates a Avro deserialization schema for the given record.
- AvroRowSerializationSchema - Class in org.apache.flink.formats.avro
-
Serialization schema that serializes
Row
over
SpecificRecord
into a Avro bytes.
- AvroRowSerializationSchema(Class<? extends SpecificRecord>) - Constructor for class org.apache.flink.formats.avro.AvroRowSerializationSchema
-
Creates a Avro serialization schema for the given schema.
- AvroSchemaSerializer() - Constructor for class org.apache.flink.formats.avro.utils.AvroKryoSerializerUtils.AvroSchemaSerializer
-
- AvroSchemaSerializerConfigSnapshot() - Constructor for class org.apache.flink.formats.avro.typeutils.AvroSerializer.AvroSchemaSerializerConfigSnapshot
-
Default constructor for instantiation via reflection.
- AvroSchemaSerializerConfigSnapshot(String) - Constructor for class org.apache.flink.formats.avro.typeutils.AvroSerializer.AvroSchemaSerializerConfigSnapshot
-
- AvroSerializer<T> - Class in org.apache.flink.api.java.typeutils.runtime
-
Deprecated.
- AvroSerializer(Class<T>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.AvroSerializer
-
Deprecated.
- AvroSerializer(Class<T>, Class<? extends T>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.AvroSerializer
-
Deprecated.
- AvroSerializer<T> - Class in org.apache.flink.formats.avro.typeutils
-
A serializer that serializes types via Avro.
- AvroSerializer(Class<T>) - Constructor for class org.apache.flink.formats.avro.typeutils.AvroSerializer
-
Creates a new AvroSerializer for the type indicated by the given class.
- AvroSerializer(Class<T>, Class<? extends T>) - Constructor for class org.apache.flink.formats.avro.typeutils.AvroSerializer
-
- AvroSerializer.AvroSchemaSerializerConfigSnapshot - Class in org.apache.flink.formats.avro.typeutils
-
A config snapshot for the Avro Serializer that stores the Avro Schema to check compatibility.
- AvroSerializer.AvroSerializerConfigSnapshot<T> - Class in org.apache.flink.api.java.typeutils.runtime
-
Deprecated.
Config snapshot for this serializer.
- AvroSerializer.AvroSerializerConfigSnapshot<T> - Class in org.apache.flink.formats.avro.typeutils
-
- AvroSerializerConfigSnapshot() - Constructor for class org.apache.flink.api.java.typeutils.runtime.AvroSerializer.AvroSerializerConfigSnapshot
-
Deprecated.
- AvroSerializerConfigSnapshot(Class<T>, Class<? extends T>, LinkedHashMap<String, KryoRegistration>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.AvroSerializer.AvroSerializerConfigSnapshot
-
Deprecated.
- AvroSerializerConfigSnapshot() - Constructor for class org.apache.flink.formats.avro.typeutils.AvroSerializer.AvroSerializerConfigSnapshot
-
Deprecated.
- AvroTypeInfo<T extends org.apache.avro.specific.SpecificRecordBase> - Class in org.apache.flink.api.java.typeutils
-
- AvroTypeInfo(Class<T>) - Constructor for class org.apache.flink.api.java.typeutils.AvroTypeInfo
-
Deprecated.
- AvroTypeInfo<T extends org.apache.avro.specific.SpecificRecordBase> - Class in org.apache.flink.formats.avro.typeutils
-
Special type information to generate a special AvroTypeInfo for Avro POJOs (implementing SpecificRecordBase, the typed Avro POJOs)
- AvroTypeInfo(Class<T>) - Constructor for class org.apache.flink.formats.avro.typeutils.AvroTypeInfo
-
Creates a new Avro type info for the given class.
- AvroTypeInfo(Class<T>, boolean) - Constructor for class org.apache.flink.formats.avro.typeutils.AvroTypeInfo
-
Creates a new Avro type info for the given class.
- AvroUtils - Class in org.apache.flink.api.java.typeutils
-
Utility methods for dealing with Avro types.
- AvroUtils() - Constructor for class org.apache.flink.api.java.typeutils.AvroUtils
-
- await() - Method in class org.apache.flink.core.testutils.MultiShotLatch
-
- await() - Method in class org.apache.flink.core.testutils.OneShotLatch
-
- await(long, TimeUnit) - Method in class org.apache.flink.core.testutils.OneShotLatch
-
- AWAIT_LEADER_TIMEOUT - Static variable in class org.apache.flink.configuration.RestOptions
-
The time in ms that the client waits for the leader address, e.g., Dispatcher or
WebMonitorEndpoint.
- awaitBlocker() - Method in class org.apache.flink.core.testutils.BlockerSync
-
- awaitJobResult(JobListeningContext) - Static method in class org.apache.flink.runtime.client.JobClient
-
Given a JobListeningContext, awaits the result of the job execution that this context is bound to
- awaitPendingAfterQuiesce() - Method in class org.apache.flink.streaming.runtime.tasks.ProcessingTimeService
-
- awaitPendingAfterQuiesce() - Method in class org.apache.flink.streaming.runtime.tasks.SystemProcessingTimeService
-
- awaitPendingAfterQuiesce() - Method in class org.apache.flink.streaming.runtime.tasks.TestProcessingTimeService
-
- awaitStartOfSuperstepOrTermination(int) - Method in class org.apache.flink.runtime.iterative.concurrent.SuperstepKickoffLatch
-
- cachable - Variable in class org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact.Builder
-
- cachable - Variable in class org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact
-
- cacheBaseStatistics(BaseStatistics, String) - Method in class org.apache.flink.optimizer.DataStatistics
-
Caches the given statistics.
- CachedBufferBlocker - Class in org.apache.flink.streaming.runtime.io
-
The cached buffer blocker takes the buffers and events from a data stream and adds them to a memory queue.
- CachedBufferBlocker(int) - Constructor for class org.apache.flink.streaming.runtime.io.CachedBufferBlocker
-
Creates a new buffer blocker, caching the buffers or events in memory queue.
- CachedBufferBlocker.CachedBufferOrEventSequence - Class in org.apache.flink.streaming.runtime.io
-
This class represents a sequence of cached buffers and events, created by the
CachedBufferBlocker
.
- cachedPlans - Variable in class org.apache.flink.optimizer.dag.OptimizerNode
-
- cacheFile - Variable in class org.apache.flink.api.common.Plan
-
Hash map for files in the distributed cache: registered name to cache entry.
- cacheFile - Variable in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- cachePartitionInfo(PartialInputChannelDeploymentDescriptor) - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- calculateCutoffMB(Configuration, long) - Static method in class org.apache.flink.runtime.clusterframework.ContaineredTaskManagerParameters
-
Calcuate cutoff memory size used by container, it will throw an
IllegalArgumentException
if the config is invalid or return the cutoff value if valid.
- calculateHeapSize(int, Configuration) - Static method in class org.apache.flink.yarn.Utils
-
See documentation.
- calculateHeapSizeMB(long, Configuration) - Static method in class org.apache.flink.runtime.taskexecutor.TaskManagerServices
-
Calculates the amount of heap memory to use (to set via -Xmx and -Xms)
based on the total memory to use and the given configuration parameters.
- calculateNetworkBufferMemory(long, Configuration) - Static method in class org.apache.flink.runtime.taskexecutor.TaskManagerServices
-
Calculates the amount of memory used for network buffers based on the total memory to use and
the according configuration parameters.
- calculateNetworkBufferMemory(TaskManagerServicesConfiguration, long) - Static method in class org.apache.flink.runtime.taskexecutor.TaskManagerServices
-
Calculates the amount of memory used for network buffers inside the current JVM instance
based on the available heap or the max heap size and the according configuration parameters.
- calculatePreferredLocations(LocationPreferenceConstraint) - Method in class org.apache.flink.runtime.executiongraph.Execution
-
Calculates the preferred locations based on the location preference constraint.
- calendar() - Static method in class org.apache.calcite.avatica.util.DateTimeUtils
-
Creates an instance of
Calendar
in the root locale and UTC time
zone.
- call() - Method in class org.apache.flink.runtime.io.async.AbstractAsyncCallableWithResources
-
This method implements the strategy for the actual IO operation:
- call() - Method in class org.apache.flink.yarn.YarnTaskManagerRunnerFactory.Runner
-
- callAsync(Callable<V>, Time) - Method in interface org.apache.flink.runtime.rpc.MainThreadExecutable
-
Execute the callable in the main thread of the underlying RPC endpoint and return a future for
the callable result.
- CallAsync - Class in org.apache.flink.runtime.rpc.messages
-
Message for asynchronous callable invocations
- CallAsync(Callable<?>) - Constructor for class org.apache.flink.runtime.rpc.messages.CallAsync
-
- callAsync(Callable<V>, Time) - Method in class org.apache.flink.runtime.rpc.RpcEndpoint
-
Execute the callable in the main thread of the underlying RPC service, returning a future for
the result of the callable.
- callAsyncWithoutFencing(Callable<V>, Time) - Method in class org.apache.flink.runtime.rpc.akka.FencedAkkaInvocationHandler
-
- callAsyncWithoutFencing(Callable<V>, Time) - Method in interface org.apache.flink.runtime.rpc.FencedMainThreadExecutable
-
Run the given callable in the main thread without attaching a fencing token.
- callAsyncWithoutFencing(Callable<V>, Time) - Method in class org.apache.flink.runtime.rpc.FencedRpcEndpoint
-
Run the given callable in the main thread of the RpcEndpoint without checking the fencing
token.
- callback - Variable in class org.apache.flink.streaming.connectors.cassandra.CassandraSinkBase
-
- callback - Variable in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducerBase
-
The callback than handles error propagation or logging callbacks.
- callWithNextKey(FlatJoinFunction<V1, V2, O>, Collector<O>) - Method in class org.apache.flink.runtime.operators.hash.NonReusingBuildFirstHashJoinIterator
-
- callWithNextKey(FlatJoinFunction<V1, V2, O>, Collector<O>) - Method in class org.apache.flink.runtime.operators.hash.NonReusingBuildSecondHashJoinIterator
-
- callWithNextKey(FlatJoinFunction<V1, V2, O>, Collector<O>) - Method in class org.apache.flink.runtime.operators.hash.ReusingBuildFirstHashJoinIterator
-
- callWithNextKey(FlatJoinFunction<V1, V2, O>, Collector<O>) - Method in class org.apache.flink.runtime.operators.hash.ReusingBuildSecondHashJoinIterator
-
- callWithNextKey(FlatJoinFunction<T1, T2, O>, Collector<O>) - Method in class org.apache.flink.runtime.operators.sort.AbstractMergeInnerJoinIterator
-
Calls the JoinFunction#join()
method for all two key-value pairs that share the same key and come
from different inputs.
- callWithNextKey(FlatJoinFunction<T1, T2, O>, Collector<O>) - Method in class org.apache.flink.runtime.operators.sort.AbstractMergeIterator
-
Calls the JoinFunction#join()
method for all two key-value pairs that share the same key and come
from different inputs.
- callWithNextKey(FlatJoinFunction<T1, T2, O>, Collector<O>) - Method in class org.apache.flink.runtime.operators.sort.AbstractMergeOuterJoinIterator
-
Calls the JoinFunction#join()
method for all two key-value pairs that share the same key and come
from different inputs.
- callWithNextKey(FlatJoinFunction<V1, V2, O>, Collector<O>) - Method in interface org.apache.flink.runtime.operators.util.JoinTaskIterator
-
Moves the internal pointer to the next key that both inputs share.
- canBeSubsumed() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
-
Checks whether this checkpoint can be subsumed or whether it should always continue, regardless
of newer checkpoints in progress.
- cancel(String[]) - Method in class org.apache.flink.client.cli.CliFrontend
-
Executes the CANCEL action.
- cancel(JobID) - Method in class org.apache.flink.client.program.ClusterClient
-
Cancels a job identified by the job id.
- cancel(JobID) - Method in class org.apache.flink.client.program.MiniClusterClient
-
- cancel(JobID) - Method in class org.apache.flink.client.program.rest.RestClusterClient
-
- cancel() - Method in class org.apache.flink.runtime.executiongraph.Execution
-
- cancel() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- cancel() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
Cancels all currently running vertex executions.
- cancel() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
Cancels this ExecutionVertex.
- cancel(boolean) - Method in class org.apache.flink.runtime.io.async.AsyncStoppableTaskWithCallback
-
- cancel() - Method in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
-
- cancel() - Method in class org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
-
This method is called when a task is canceled either as a result of a user abort or an execution failure.
- cancel(Time) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
-
- cancel(Time) - Method in interface org.apache.flink.runtime.jobmaster.JobMasterGateway
-
Cancels the currently executed job.
- cancel() - Method in class org.apache.flink.runtime.operators.AbstractCachedBuildSideJoinDriver
-
- cancel() - Method in class org.apache.flink.runtime.operators.AbstractOuterJoinDriver
-
- cancel() - Method in class org.apache.flink.runtime.operators.AllGroupCombineDriver
-
- cancel() - Method in class org.apache.flink.runtime.operators.AllGroupReduceDriver
-
- cancel() - Method in class org.apache.flink.runtime.operators.AllReduceDriver
-
- cancel() - Method in class org.apache.flink.runtime.operators.BatchTask
-
- cancel() - Method in class org.apache.flink.runtime.operators.CoGroupDriver
-
- cancel() - Method in class org.apache.flink.runtime.operators.CoGroupRawDriver
-
- cancel() - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetFirstDriver
-
- cancel() - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetSecondDriver
-
- cancel() - Method in class org.apache.flink.runtime.operators.CrossDriver
-
- cancel() - Method in class org.apache.flink.runtime.operators.DataSinkTask
-
- cancel() - Method in class org.apache.flink.runtime.operators.DataSourceTask
-
- cancel() - Method in interface org.apache.flink.runtime.operators.Driver
-
This method is invoked when the driver must aborted in mid processing.
- cancel() - Method in class org.apache.flink.runtime.operators.FlatMapDriver
-
- cancel() - Method in class org.apache.flink.runtime.operators.GroupReduceCombineDriver
-
- cancel() - Method in class org.apache.flink.runtime.operators.GroupReduceDriver
-
- cancel() - Method in class org.apache.flink.runtime.operators.JoinDriver
-
- cancel() - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetFirstDriver
-
- cancel() - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetSecondDriver
-
- cancel() - Method in class org.apache.flink.runtime.operators.MapDriver
-
- cancel() - Method in class org.apache.flink.runtime.operators.MapPartitionDriver
-
- cancel() - Method in class org.apache.flink.runtime.operators.NoOpDriver
-
- cancel() - Method in class org.apache.flink.runtime.operators.ReduceCombineDriver
-
- cancel() - Method in class org.apache.flink.runtime.operators.ReduceDriver
-
- cancel() - Method in class org.apache.flink.runtime.operators.UnionWithTempOperator
-
- cancel() - Method in class org.apache.flink.runtime.registration.RetryingRegistration
-
Cancels the registration procedure.
- cancel(boolean) - Method in class org.apache.flink.runtime.state.DoneFuture
-
- cancel() - Method in class org.apache.flink.sql.tests.StreamSQLTestProgram.Generator
-
- cancel() - Method in class org.apache.flink.storm.wrappers.SpoutWrapper
-
Cancels the source.
- cancel() - Method in class org.apache.flink.streaming.api.functions.source.ContinuousFileMonitoringFunction
-
- cancel() - Method in class org.apache.flink.streaming.api.functions.source.FileMonitoringFunction
-
Deprecated.
- cancel() - Method in class org.apache.flink.streaming.api.functions.source.FromElementsFunction
-
- cancel() - Method in class org.apache.flink.streaming.api.functions.source.FromIteratorFunction
-
- cancel() - Method in class org.apache.flink.streaming.api.functions.source.FromSplittableIteratorFunction
-
- cancel() - Method in class org.apache.flink.streaming.api.functions.source.InputFormatSourceFunction
-
- cancel() - Method in class org.apache.flink.streaming.api.functions.source.SocketTextStreamFunction
-
- cancel() - Method in interface org.apache.flink.streaming.api.functions.source.SourceFunction
-
Cancels the source.
- cancel() - Method in class org.apache.flink.streaming.api.functions.source.StatefulSequenceSource
-
- cancel() - Method in class org.apache.flink.streaming.api.operators.OperatorSnapshotFutures
-
- cancel() - Method in class org.apache.flink.streaming.api.operators.StreamSource
-
- cancel() - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumerBase
-
- cancel() - Method in class org.apache.flink.streaming.connectors.kafka.internal.Kafka09Fetcher
-
- cancel() - Method in class org.apache.flink.streaming.connectors.kafka.internals.AbstractFetcher
-
- cancel() - Method in class org.apache.flink.streaming.connectors.kafka.internals.Kafka08Fetcher
-
- cancel() - Method in class org.apache.flink.streaming.connectors.nifi.NiFiSource
-
- cancel() - Method in class org.apache.flink.streaming.connectors.rabbitmq.RMQSource
-
- cancel() - Method in class org.apache.flink.streaming.connectors.twitter.TwitterSource
-
- cancel() - Method in class org.apache.flink.streaming.connectors.wikiedits.WikipediaEditsSource
-
- cancel() - Method in class org.apache.flink.streaming.examples.ml.IncrementalLearningSkeleton.FiniteNewDataSource
-
- cancel() - Method in class org.apache.flink.streaming.examples.ml.IncrementalLearningSkeleton.FiniteTrainingDataSource
-
- cancel() - Method in class org.apache.flink.streaming.examples.statemachine.generator.EventsGeneratorSource
-
- cancel() - Method in class org.apache.flink.streaming.python.api.functions.PythonGeneratorFunction
-
- cancel() - Method in class org.apache.flink.streaming.python.api.functions.PythonIteratorFunction
-
- cancel() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- cancel() - Method in class org.apache.flink.streaming.tests.BucketingSinkTestProgram.Generator
-
- cancel() - Method in class org.apache.flink.streaming.tests.SequenceGeneratorSource
-
- cancelAndReleaseAllSlots() - Method in class org.apache.flink.runtime.instance.Instance
-
- cancelChainedTasks(List<ChainedDriver<?, ?>>) - Static method in class org.apache.flink.runtime.operators.BatchTask
-
- CancelCheckpointMarker - Class in org.apache.flink.runtime.io.network.api
-
The CancelCheckpointMarker travels through the data streams, similar to the
CheckpointBarrier
,
but signals that a certain checkpoint should be canceled.
- CancelCheckpointMarker(long) - Constructor for class org.apache.flink.runtime.io.network.api.CancelCheckpointMarker
-
- cancelCleanupTask() - Method in class org.apache.flink.runtime.blob.AbstractBlobCache
-
Cancels any cleanup task that subclasses may be executing.
- cancelCleanupTask() - Method in class org.apache.flink.runtime.blob.PermanentBlobCache
-
- cancelCleanupTask() - Method in class org.apache.flink.runtime.blob.TransientBlobCache
-
- cancelExecution() - Method in class org.apache.flink.runtime.taskmanager.Task
-
Cancels the task execution.
- cancelJob(JobID, Time) - Method in class org.apache.flink.runtime.akka.AkkaJobManagerGateway
-
- cancelJob(JobID, Time) - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
-
- cancelJob(JobID, Time) - Method in interface org.apache.flink.runtime.jobmaster.JobManagerGateway
-
Cancels the given job.
- cancelJob(JobID) - Method in class org.apache.flink.runtime.minicluster.MiniCluster
-
- cancelJob(JobID, Time) - Method in interface org.apache.flink.runtime.webmonitor.RestfulGateway
-
Cancel the given job.
- cancelJobWithSavepoint(JobID, String, Time) - Method in class org.apache.flink.runtime.akka.AkkaJobManagerGateway
-
- cancelJobWithSavepoint(JobID, String, Time) - Method in interface org.apache.flink.runtime.jobmaster.JobManagerGateway
-
Cancels the given job after taking a savepoint and returning its path.
- CancelOptions - Class in org.apache.flink.client.cli
-
Command line options for the CANCEL command.
- CancelOptions(CommandLine) - Constructor for class org.apache.flink.client.cli.CancelOptions
-
- cancelQuery(SessionContext, String) - Method in interface org.apache.flink.table.client.gateway.Executor
-
Cancels a table program and stops the result retrieval.
- cancelQuery(SessionContext, String) - Method in class org.apache.flink.table.client.gateway.local.LocalExecutor
-
- cancelRequestFor(InputChannelID) - Method in interface org.apache.flink.runtime.io.network.NetworkClientHandler
-
- cancelSlotRequest(SlotRequestId, SlotSharingGroupId, Throwable) - Method in class org.apache.flink.runtime.jobmanager.scheduler.Scheduler
-
- cancelSlotRequest(SlotRequestId, SlotSharingGroupId, Throwable) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.SlotProvider
-
- cancelSlotRequest(AllocationID) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
-
- cancelSlotRequest(AllocationID) - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
-
Cancel the slot allocation requests from the resource manager.
- cancelStackTraceSample(int, Throwable) - Method in class org.apache.flink.runtime.rest.handler.legacy.backpressure.StackTraceSampleCoordinator
-
Cancels a pending sample.
- cancelStreamRegistry - Variable in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
-
Registry for all opened streams, so they can be closed if the task using this backend is closed
- cancelTask(ExecutionAttemptID, Time) - Method in class org.apache.flink.runtime.jobmanager.slots.ActorTaskManagerGateway
-
- cancelTask(ExecutionAttemptID, Time) - Method in interface org.apache.flink.runtime.jobmanager.slots.TaskManagerGateway
-
Cancel the given task.
- cancelTask(ExecutionAttemptID, Time) - Method in class org.apache.flink.runtime.jobmaster.RpcTaskManagerGateway
-
- cancelTask() - Method in class org.apache.flink.runtime.operators.chaining.ChainedAllReduceDriver
-
- cancelTask() - Method in class org.apache.flink.runtime.operators.chaining.ChainedDriver
-
- cancelTask() - Method in class org.apache.flink.runtime.operators.chaining.ChainedFlatMapDriver
-
- cancelTask() - Method in class org.apache.flink.runtime.operators.chaining.ChainedMapDriver
-
- cancelTask() - Method in class org.apache.flink.runtime.operators.chaining.ChainedReduceCombineDriver
-
- cancelTask() - Method in class org.apache.flink.runtime.operators.chaining.ChainedTerminationCriterionDriver
-
- cancelTask() - Method in class org.apache.flink.runtime.operators.chaining.GroupCombineChainedDriver
-
- cancelTask() - Method in class org.apache.flink.runtime.operators.chaining.SynchronousChainedCombineDriver
-
- cancelTask() - Method in class org.apache.flink.runtime.operators.NoOpChainedDriver
-
- cancelTask(ExecutionAttemptID, Time) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutor
-
- cancelTask(ExecutionAttemptID, Time) - Method in interface org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
-
Cancel the given task.
- cancelTask() - Method in class org.apache.flink.streaming.runtime.tasks.OneInputStreamTask
-
- cancelTask() - Method in class org.apache.flink.streaming.runtime.tasks.SourceStreamTask
-
- cancelTask() - Method in class org.apache.flink.streaming.runtime.tasks.StreamIterationHead
-
- cancelTask() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- cancelTask() - Method in class org.apache.flink.streaming.runtime.tasks.TwoInputStreamTask
-
- CancelTaskException - Exception in org.apache.flink.runtime.execution
-
Thrown to trigger a canceling of the executing task.
- CancelTaskException(Throwable) - Constructor for exception org.apache.flink.runtime.execution.CancelTaskException
-
- CancelTaskException(String) - Constructor for exception org.apache.flink.runtime.execution.CancelTaskException
-
- CancelTaskException() - Constructor for exception org.apache.flink.runtime.execution.CancelTaskException
-
- cancelWithFuture() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
Cancels all currently running vertex executions.
- cancelWithSavepoint(JobID, String) - Method in class org.apache.flink.client.program.ClusterClient
-
Cancels a job identified by the job id and triggers a savepoint.
- cancelWithSavepoint(JobID, String) - Method in class org.apache.flink.client.program.MiniClusterClient
-
- cancelWithSavepoint(JobID, String) - Method in class org.apache.flink.client.program.rest.RestClusterClient
-
- canContainFields() - Method in class org.apache.flink.api.java.sca.TaggedValue
-
- canContainInput() - Method in class org.apache.flink.api.java.sca.TaggedValue
-
- canEqual(Object) - Method in class org.apache.flink.api.common.ExecutionConfig
-
- canEqual(Object) - Method in class org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
-
- canEqual(Object) - Method in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
-
- canEqual(Object) - Method in class org.apache.flink.api.common.typeinfo.NothingTypeInfo
-
- canEqual(Object) - Method in class org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
-
- canEqual(Object) - Method in class org.apache.flink.api.common.typeinfo.SqlTimeTypeInfo
-
- canEqual(Object) - Method in class org.apache.flink.api.common.typeinfo.TypeInformation
-
Returns true if the given object can be equaled with this object.
- canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.array.BooleanPrimitiveArraySerializer
-
- canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.array.BytePrimitiveArraySerializer
-
- canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.array.CharPrimitiveArraySerializer
-
- canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.array.DoublePrimitiveArraySerializer
-
- canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.array.FloatPrimitiveArraySerializer
-
- canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.array.IntPrimitiveArraySerializer
-
- canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.array.LongPrimitiveArraySerializer
-
- canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.array.ShortPrimitiveArraySerializer
-
- canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.array.StringArraySerializer
-
- canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.BigDecSerializer
-
- canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.BigIntSerializer
-
- canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.BooleanSerializer
-
- canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueSerializer
-
- canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.ByteSerializer
-
- canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.ByteValueSerializer
-
- canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.CharSerializer
-
- canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.CharValueSerializer
-
- canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.DateSerializer
-
- canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.DoubleSerializer
-
- canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueSerializer
-
- canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.EnumSerializer
-
- canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.FloatSerializer
-
- canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.FloatValueSerializer
-
- canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.GenericArraySerializer
-
- canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.IntSerializer
-
- canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.IntValueSerializer
-
- canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.ListSerializer
-
- canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.LongSerializer
-
- canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.LongValueSerializer
-
- canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.MapSerializer
-
- canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.NullValueSerializer
-
- canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.ShortSerializer
-
- canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.ShortValueSerializer
-
- canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.SqlDateSerializer
-
- canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.SqlTimeSerializer
-
- canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.SqlTimestampSerializer
-
- canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.StringSerializer
-
- canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.StringValueSerializer
-
- canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.VoidSerializer
-
- canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.CompositeType
-
- canEqual(Object) - Method in interface org.apache.flink.api.common.typeutils.TypeDeserializer
-
Returns true if the given object can be equaled with this object.
- canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.TypeDeserializerAdapter
-
- canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.TypeSerializer
-
Returns true if the given object can be equaled with this object.
- canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.UnloadableDummyTypeSerializer
-
- canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.EitherTypeInfo
-
- canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.EnumTypeInfo
-
- canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.GenericTypeInfo
-
- canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.ListTypeInfo
-
- canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.MapTypeInfo
-
- canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.MissingTypeInfo
-
- canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.MultisetTypeInfo
-
- canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.ObjectArrayTypeInfo
-
- canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.PojoField
-
- canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo
-
- canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.RowTypeInfo
-
- canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.runtime.AvroSerializer
-
Deprecated.
- canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer
-
- canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.runtime.EitherSerializer
-
- canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer
-
- canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer
-
- canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.runtime.RowSerializer
-
- canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.runtime.Tuple0Serializer
-
- canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializerBase
-
- canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.runtime.ValueSerializer
-
- canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.runtime.WritableSerializer
-
- canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfo
-
- canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfoBase
-
- canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.ValueTypeInfo
-
- canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.WritableTypeInfo
-
- canEqual(Object) - Method in class org.apache.flink.cep.nfa.DeweyNumber.DeweyNumberSerializer
-
- canEqual(Object) - Method in class org.apache.flink.cep.nfa.NFA.NFASerializer
-
- canEqual(Object) - Method in class org.apache.flink.cep.nfa.SharedBuffer.SharedBufferSerializer
-
- canEqual(Object) - Method in class org.apache.flink.formats.avro.typeutils.AvroSerializer
-
- canEqual(Object) - Method in class org.apache.flink.formats.avro.typeutils.BackwardsCompatibleAvroSerializer
-
- canEqual(Object) - Method in class org.apache.flink.graph.drivers.transform.LongValueWithProperHashCode.LongValueWithProperHashCodeSerializer
-
- canEqual(Object) - Method in class org.apache.flink.graph.drivers.transform.LongValueWithProperHashCode.LongValueWithProperHashCodeTypeInfo
-
- canEqual(Object) - Method in class org.apache.flink.graph.types.valuearray.ByteValueArraySerializer
-
- canEqual(Object) - Method in class org.apache.flink.graph.types.valuearray.CharValueArraySerializer
-
- canEqual(Object) - Method in class org.apache.flink.graph.types.valuearray.DoubleValueArraySerializer
-
- canEqual(Object) - Method in class org.apache.flink.graph.types.valuearray.FloatValueArraySerializer
-
- canEqual(Object) - Method in class org.apache.flink.graph.types.valuearray.IntValueArraySerializer
-
- canEqual(Object) - Method in class org.apache.flink.graph.types.valuearray.LongValueArraySerializer
-
- canEqual(Object) - Method in class org.apache.flink.graph.types.valuearray.NullValueArraySerializer
-
- canEqual(Object) - Method in class org.apache.flink.graph.types.valuearray.ShortValueArraySerializer
-
- canEqual(Object) - Method in class org.apache.flink.graph.types.valuearray.StringValueArraySerializer
-
- canEqual(Object) - Method in class org.apache.flink.graph.types.valuearray.ValueArrayTypeInfo
-
- canEqual(Object) - Method in class org.apache.flink.queryablestate.client.VoidNamespaceSerializer
-
- canEqual(Object) - Method in class org.apache.flink.queryablestate.client.VoidNamespaceTypeInfo
-
- canEqual(Object) - Method in class org.apache.flink.runtime.state.ArrayListSerializer
-
- canEqual(Object) - Method in class org.apache.flink.runtime.state.VoidNamespaceSerializer
-
- canEqual(Object) - Method in class org.apache.flink.runtime.state.VoidNamespaceTypeInfo
-
- canEqual(Object) - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.StateSerializer
-
- canEqual(Object) - Method in class org.apache.flink.streaming.api.operators.InternalTimer.TimerSerializer
-
- canEqual(Object) - Method in class org.apache.flink.streaming.api.windowing.windows.GlobalWindow.Serializer
-
- canEqual(Object) - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow.Serializer
-
- canEqual(Object) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer011.ContextStateSerializer
-
- canEqual(Object) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer011.TransactionStateSerializer
-
- canEqual(Object) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
-
- canMerge() - Method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousEventTimeTrigger
-
- canMerge() - Method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousProcessingTimeTrigger
-
- canMerge() - Method in class org.apache.flink.streaming.api.windowing.triggers.CountTrigger
-
- canMerge() - Method in class org.apache.flink.streaming.api.windowing.triggers.EventTimeTrigger
-
- canMerge() - Method in class org.apache.flink.streaming.api.windowing.triggers.ProcessingTimeTrigger
-
- canMerge() - Method in class org.apache.flink.streaming.api.windowing.triggers.PurgingTrigger
-
- canMerge() - Method in class org.apache.flink.streaming.api.windowing.triggers.Trigger
-
Returns true if this trigger supports merging of trigger state and can therefore
be used with a
MergingWindowAssigner
.
- canMergeConfigurationWith(GraphAlgorithmWrappingBase) - Method in class org.apache.flink.graph.asm.degree.annotate.directed.VertexDegrees
-
- canMergeConfigurationWith(GraphAlgorithmWrappingBase) - Method in class org.apache.flink.graph.asm.degree.annotate.directed.VertexInDegree
-
- canMergeConfigurationWith(GraphAlgorithmWrappingBase) - Method in class org.apache.flink.graph.asm.degree.annotate.directed.VertexOutDegree
-
- canMergeConfigurationWith(GraphAlgorithmWrappingBase) - Method in class org.apache.flink.graph.asm.degree.annotate.undirected.VertexDegree
-
- canMergeConfigurationWith(GraphAlgorithmWrappingBase) - Method in class org.apache.flink.graph.asm.degree.filter.undirected.MaximumDegree
-
- canMergeConfigurationWith(GraphAlgorithmWrappingBase) - Method in class org.apache.flink.graph.asm.simple.undirected.Simplify
-
- canMergeConfigurationWith(GraphAlgorithmWrappingBase) - Method in class org.apache.flink.graph.asm.translate.TranslateEdgeValues
-
- canMergeConfigurationWith(GraphAlgorithmWrappingBase) - Method in class org.apache.flink.graph.asm.translate.TranslateGraphIds
-
- canMergeConfigurationWith(GraphAlgorithmWrappingBase) - Method in class org.apache.flink.graph.asm.translate.TranslateVertexValues
-
- canMergeConfigurationWith(GraphAlgorithmWrappingBase) - Method in class org.apache.flink.graph.library.clustering.directed.LocalClusteringCoefficient
-
- canMergeConfigurationWith(GraphAlgorithmWrappingBase) - Method in class org.apache.flink.graph.library.clustering.TriangleListingBase
-
- canMergeConfigurationWith(GraphAlgorithmWrappingBase) - Method in class org.apache.flink.graph.library.clustering.undirected.LocalClusteringCoefficient
-
- canMergeConfigurationWith(GraphAlgorithmWrappingBase) - Method in class org.apache.flink.graph.library.linkanalysis.PageRank
-
- canMergeConfigurationWith(GraphAlgorithmWrappingBase) - Method in class org.apache.flink.graph.library.similarity.AdamicAdar
-
- canMergeConfigurationWith(GraphAlgorithmWrappingBase) - Method in class org.apache.flink.graph.library.similarity.JaccardIndex
-
- canMergeConfigurationWith(GraphAlgorithmWrappingBase) - Method in class org.apache.flink.graph.utils.proxy.GraphAlgorithmWrappingBase
-
- canNotContainInput() - Method in class org.apache.flink.api.java.sca.TaggedValue
-
- canReadInt() - Method in class org.apache.flink.api.java.typeutils.runtime.NoFetchingInput
-
- canReadLong() - Method in class org.apache.flink.api.java.typeutils.runtime.NoFetchingInput
-
- canRestart() - Method in class org.apache.flink.runtime.executiongraph.restart.FailureRateRestartStrategy
-
- canRestart() - Method in class org.apache.flink.runtime.executiongraph.restart.FixedDelayRestartStrategy
-
- canRestart() - Method in class org.apache.flink.runtime.executiongraph.restart.NoRestartStrategy
-
- canRestart() - Method in interface org.apache.flink.runtime.executiongraph.restart.RestartStrategy
-
True if the restart strategy can be applied to restart the
ExecutionGraph
.
- capacity() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
-
- capacity(int) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
-
- CAR_DATA - Static variable in class org.apache.flink.streaming.examples.windowing.util.TopSpeedWindowingExampleData
-
- CartesianProductDescriptor - Class in org.apache.flink.optimizer.operators
-
- CartesianProductDescriptor(boolean, boolean) - Constructor for class org.apache.flink.optimizer.operators.CartesianProductDescriptor
-
- CaseInsensitiveOrderComparator() - Constructor for class org.apache.flink.runtime.rest.RestServerEndpoint.RestHandlerUrlComparator.CaseInsensitiveOrderComparator
-
- CassandraAppendTableSink - Class in org.apache.flink.streaming.connectors.cassandra
-
An AppendStreamTableSink
to write an append stream Table to a Cassandra table.
- CassandraAppendTableSink(ClusterBuilder, String) - Constructor for class org.apache.flink.streaming.connectors.cassandra.CassandraAppendTableSink
-
- CassandraAppendTableSink(ClusterBuilder, String, Properties) - Constructor for class org.apache.flink.streaming.connectors.cassandra.CassandraAppendTableSink
-
- CassandraCommitter - Class in org.apache.flink.streaming.connectors.cassandra
-
CheckpointCommitter that saves information about completed checkpoints within a separate table in a cassandra
database.
- CassandraCommitter(ClusterBuilder) - Constructor for class org.apache.flink.streaming.connectors.cassandra.CassandraCommitter
-
- CassandraCommitter(ClusterBuilder, String) - Constructor for class org.apache.flink.streaming.connectors.cassandra.CassandraCommitter
-
- CassandraInputFormat<OUT extends Tuple> - Class in org.apache.flink.batch.connectors.cassandra
-
InputFormat to read data from Apache Cassandra and generate $
Tuple
.
- CassandraInputFormat(String, ClusterBuilder) - Constructor for class org.apache.flink.batch.connectors.cassandra.CassandraInputFormat
-
- CassandraOutputFormat<OUT extends Tuple> - Class in org.apache.flink.batch.connectors.cassandra
-
- CassandraOutputFormat(String, ClusterBuilder) - Constructor for class org.apache.flink.batch.connectors.cassandra.CassandraOutputFormat
-
Deprecated.
- CassandraOutputFormatBase<OUT> - Class in org.apache.flink.batch.connectors.cassandra
-
CassandraOutputFormatBase is the common abstract class for writing into Apache Cassandra.
- CassandraOutputFormatBase(String, ClusterBuilder) - Constructor for class org.apache.flink.batch.connectors.cassandra.CassandraOutputFormatBase
-
- CassandraPojoSink<IN> - Class in org.apache.flink.streaming.connectors.cassandra
-
- CassandraPojoSink(Class<IN>, ClusterBuilder) - Constructor for class org.apache.flink.streaming.connectors.cassandra.CassandraPojoSink
-
The main constructor for creating CassandraPojoSink.
- CassandraPojoSink(Class<IN>, ClusterBuilder, MapperOptions) - Constructor for class org.apache.flink.streaming.connectors.cassandra.CassandraPojoSink
-
- CassandraPojoSinkBuilder(DataStream<IN>, TypeInformation<IN>, TypeSerializer<IN>) - Constructor for class org.apache.flink.streaming.connectors.cassandra.CassandraSink.CassandraPojoSinkBuilder
-
- CassandraRowOutputFormat - Class in org.apache.flink.batch.connectors.cassandra
-
OutputFormat to write Flink
Row
s into a Cassandra cluster.
- CassandraRowOutputFormat(String, ClusterBuilder) - Constructor for class org.apache.flink.batch.connectors.cassandra.CassandraRowOutputFormat
-
- CassandraRowSink - Class in org.apache.flink.streaming.connectors.cassandra
-
A SinkFunction to write Row records into a Cassandra table.
- CassandraRowSink(int, String, ClusterBuilder) - Constructor for class org.apache.flink.streaming.connectors.cassandra.CassandraRowSink
-
- CassandraRowSinkBuilder(DataStream<Row>, TypeInformation<Row>, TypeSerializer<Row>) - Constructor for class org.apache.flink.streaming.connectors.cassandra.CassandraSink.CassandraRowSinkBuilder
-
- CassandraRowWriteAheadSink - Class in org.apache.flink.streaming.connectors.cassandra
-
Sink that emits its input elements into a Cassandra table.
- CassandraRowWriteAheadSink(String, TypeSerializer<Row>, ClusterBuilder, CheckpointCommitter) - Constructor for class org.apache.flink.streaming.connectors.cassandra.CassandraRowWriteAheadSink
-
- CassandraScalaProductSink<IN extends scala.Product> - Class in org.apache.flink.streaming.connectors.cassandra
-
Sink to write scala tuples and case classes into a Cassandra cluster.
- CassandraScalaProductSink(String, ClusterBuilder) - Constructor for class org.apache.flink.streaming.connectors.cassandra.CassandraScalaProductSink
-
- CassandraScalaProductSinkBuilder(DataStream<IN>, TypeInformation<IN>, TypeSerializer<IN>) - Constructor for class org.apache.flink.streaming.connectors.cassandra.CassandraSink.CassandraScalaProductSinkBuilder
-
- CassandraSink<IN> - Class in org.apache.flink.streaming.connectors.cassandra
-
This class wraps different Cassandra sink implementations to provide a common interface for all of them.
- CassandraSink.CassandraPojoSinkBuilder<IN> - Class in org.apache.flink.streaming.connectors.cassandra
-
- CassandraSink.CassandraRowSinkBuilder - Class in org.apache.flink.streaming.connectors.cassandra
-
- CassandraSink.CassandraScalaProductSinkBuilder<IN extends scala.Product> - Class in org.apache.flink.streaming.connectors.cassandra
-
- CassandraSink.CassandraSinkBuilder<IN> - Class in org.apache.flink.streaming.connectors.cassandra
-
- CassandraSink.CassandraTupleSinkBuilder<IN extends Tuple> - Class in org.apache.flink.streaming.connectors.cassandra
-
- CassandraSinkBase<IN,V> - Class in org.apache.flink.streaming.connectors.cassandra
-
- CassandraSinkBuilder(DataStream<IN>, TypeInformation<IN>, TypeSerializer<IN>) - Constructor for class org.apache.flink.streaming.connectors.cassandra.CassandraSink.CassandraSinkBuilder
-
- CassandraTupleOutputFormat<OUT extends Tuple> - Class in org.apache.flink.batch.connectors.cassandra
-
OutputFormat to write Flink
Tuple
s into a Cassandra cluster.
- CassandraTupleOutputFormat(String, ClusterBuilder) - Constructor for class org.apache.flink.batch.connectors.cassandra.CassandraTupleOutputFormat
-
- CassandraTupleSink<IN extends Tuple> - Class in org.apache.flink.streaming.connectors.cassandra
-
Sink to write Flink
Tuple
s into a Cassandra cluster.
- CassandraTupleSink(String, ClusterBuilder) - Constructor for class org.apache.flink.streaming.connectors.cassandra.CassandraTupleSink
-
- CassandraTupleSinkBuilder(DataStream<IN>, TypeInformation<IN>, TypeSerializer<IN>) - Constructor for class org.apache.flink.streaming.connectors.cassandra.CassandraSink.CassandraTupleSinkBuilder
-
- CassandraTupleWriteAheadSink<IN extends Tuple> - Class in org.apache.flink.streaming.connectors.cassandra
-
Sink that emits its input elements into a Cassandra database.
- CassandraTupleWriteAheadSink(String, TypeSerializer<IN>, ClusterBuilder, CheckpointCommitter) - Constructor for class org.apache.flink.streaming.connectors.cassandra.CassandraTupleWriteAheadSink
-
- CCMessenger(TypeInformation<VV>) - Constructor for class org.apache.flink.graph.library.ConnectedComponents.CCMessenger
-
- CCUpdater() - Constructor for class org.apache.flink.graph.library.ConnectedComponents.CCUpdater
-
- CENTERS_2D_AFTER_20_ITERATIONS_DOUBLE_DIGIT - Static variable in class org.apache.flink.test.testdata.KMeansData
-
- CENTERS_2D_AFTER_SINGLE_ITERATION_DOUBLE_DIGIT - Static variable in class org.apache.flink.test.testdata.KMeansData
-
- CENTERS_AFTER_20_ITERATIONS_DOUBLE_DIGIT - Static variable in class org.apache.flink.test.testdata.KMeansData
-
- CENTERS_AFTER_20_ITERATIONS_SINGLE_DIGIT - Static variable in class org.apache.flink.test.testdata.KMeansData
-
- CENTERS_AFTER_ONE_STEP - Static variable in class org.apache.flink.test.testdata.KMeansData
-
- CENTERS_AFTER_ONE_STEP_SINGLE_DIGIT - Static variable in class org.apache.flink.test.testdata.KMeansData
-
- Centroid() - Constructor for class org.apache.flink.examples.java.clustering.KMeans.Centroid
-
- Centroid(int, double, double) - Constructor for class org.apache.flink.examples.java.clustering.KMeans.Centroid
-
- Centroid(int, KMeans.Point) - Constructor for class org.apache.flink.examples.java.clustering.KMeans.Centroid
-
- CentroidAccumulator() - Constructor for class org.apache.flink.examples.java.clustering.KMeans.CentroidAccumulator
-
- CentroidAverager() - Constructor for class org.apache.flink.examples.java.clustering.KMeans.CentroidAverager
-
- CENTROIDS - Static variable in class org.apache.flink.examples.java.clustering.util.KMeansData
-
- CEP - Class in org.apache.flink.cep
-
Utility class for complex event processing.
- CEP() - Constructor for class org.apache.flink.cep.CEP
-
- CEPOperatorUtils - Class in org.apache.flink.cep.operator
-
- CEPOperatorUtils() - Constructor for class org.apache.flink.cep.operator.CEPOperatorUtils
-
- ChainedAllReduceDriver<IT> - Class in org.apache.flink.runtime.operators.chaining
-
- ChainedAllReduceDriver() - Constructor for class org.apache.flink.runtime.operators.chaining.ChainedAllReduceDriver
-
- ChainedDriver<IT,OT> - Class in org.apache.flink.runtime.operators.chaining
-
The interface to be implemented by drivers that do not run in an own task context, but are chained to other
tasks.
- ChainedDriver() - Constructor for class org.apache.flink.runtime.operators.chaining.ChainedDriver
-
- ChainedFlatMapDriver<IT,OT> - Class in org.apache.flink.runtime.operators.chaining
-
- ChainedFlatMapDriver() - Constructor for class org.apache.flink.runtime.operators.chaining.ChainedFlatMapDriver
-
- ChainedMapDriver<IT,OT> - Class in org.apache.flink.runtime.operators.chaining
-
- ChainedMapDriver() - Constructor for class org.apache.flink.runtime.operators.chaining.ChainedMapDriver
-
- ChainedReduceCombineDriver<T> - Class in org.apache.flink.runtime.operators.chaining
-
Chained version of ReduceCombineDriver.
- ChainedReduceCombineDriver() - Constructor for class org.apache.flink.runtime.operators.chaining.ChainedReduceCombineDriver
-
- ChainedStateHandle<T extends StateObject> - Class in org.apache.flink.runtime.state
-
Handle to state handles for the operators in an operator chain.
- ChainedStateHandle(List<? extends T>) - Constructor for class org.apache.flink.runtime.state.ChainedStateHandle
-
Wraps a list to the state handles for the operators in a chain.
- chainedTasks - Variable in class org.apache.flink.runtime.operators.BatchTask
-
A list of chained drivers, if there are any.
- ChainedTerminationCriterionDriver<IT,OT> - Class in org.apache.flink.runtime.operators.chaining
-
- ChainedTerminationCriterionDriver() - Constructor for class org.apache.flink.runtime.operators.chaining.ChainedTerminationCriterionDriver
-
- chainingStrategy - Variable in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- ChainingStrategy - Enum in org.apache.flink.streaming.api.operators
-
Defines the chaining scheme for the operator.
- ChangelogCollectStreamResult<C> - Class in org.apache.flink.table.client.gateway.local
-
Collects results and returns them as a changelog.
- ChangelogCollectStreamResult(TypeInformation<Row>, ExecutionConfig, InetAddress, int) - Constructor for class org.apache.flink.table.client.gateway.local.ChangelogCollectStreamResult
-
- ChangelogResult<C> - Interface in org.apache.flink.table.client.gateway.local
-
A result that is represented as a changelog consisting of insert and delete records.
- Channel - Class in org.apache.flink.optimizer.plan
-
A Channel represents the result produced by an operator and the data exchange
before the consumption by the target operator.
- Channel(PlanNode) - Constructor for class org.apache.flink.optimizer.plan.Channel
-
- Channel(PlanNode, TempMode) - Constructor for class org.apache.flink.optimizer.plan.Channel
-
- channel - Variable in class org.apache.flink.streaming.connectors.rabbitmq.RMQSink
-
- channel - Variable in class org.apache.flink.streaming.connectors.rabbitmq.RMQSource
-
- channelActive(ChannelHandlerContext) - Method in class org.apache.flink.queryablestate.network.AbstractServerHandler
-
- channelInactive(ChannelHandlerContext) - Method in class org.apache.flink.queryablestate.network.AbstractServerHandler
-
- channelInactive(ChannelHandlerContext) - Method in class org.apache.flink.queryablestate.network.ClientHandler
-
- channelIndex - Variable in class org.apache.flink.runtime.io.network.partition.consumer.InputChannel
-
- channelRead(ChannelHandlerContext, Object) - Method in class org.apache.flink.queryablestate.network.AbstractServerHandler
-
- channelRead(ChannelHandlerContext, Object) - Method in class org.apache.flink.queryablestate.network.ClientHandler
-
- channelRead0(ChannelHandlerContext, Object) - Method in class org.apache.flink.mesos.util.MesosArtifactServer.UnknownFileHandler
-
- channelRead0(ChannelHandlerContext, Routed) - Method in class org.apache.flink.mesos.util.MesosArtifactServer.VirtualFileServerHandler
-
- channelRead0(ChannelHandlerContext, HttpObject) - Method in class org.apache.flink.runtime.rest.FileUploadHandler
-
- channelRead0(ChannelHandlerContext, Routed) - Method in class org.apache.flink.runtime.rest.handler.legacy.ConstantTextHandler
-
- channelRead0(ChannelHandlerContext, HttpRequest) - Method in class org.apache.flink.runtime.rest.handler.PipelineErrorHandler
-
- channelRead0(ChannelHandlerContext, Routed) - Method in class org.apache.flink.runtime.rest.handler.RedirectHandler
-
- channelRead0(ChannelHandlerContext, Routed) - Method in class org.apache.flink.runtime.webmonitor.history.HistoryServerStaticFileServerHandler
-
- channelRead0(ChannelHandlerContext, HttpObject) - Method in class org.apache.flink.runtime.webmonitor.HttpRequestHandler
-
- channelRead0(ChannelHandlerContext, Object) - Method in class org.apache.flink.runtime.webmonitor.PipelineErrorHandler
-
- ChannelReaderInputView - Class in org.apache.flink.runtime.io.disk.iomanager
-
- ChannelReaderInputView(BlockChannelReader<MemorySegment>, List<MemorySegment>, boolean) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.ChannelReaderInputView
-
Creates a new channel reader that reads from the given channel until the last block
(as marked by a
ChannelWriterOutputView
) is found.
- ChannelReaderInputView(BlockChannelReader<MemorySegment>, List<MemorySegment>, int, boolean) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.ChannelReaderInputView
-
Creates a new channel reader that reads from the given channel, expecting a specified
number of blocks in the channel.
- ChannelReaderInputViewIterator<E> - Class in org.apache.flink.runtime.io.disk
-
A simple iterator over the input read though an I/O channel.
- ChannelReaderInputViewIterator(IOManager, FileIOChannel.ID, List<MemorySegment>, List<MemorySegment>, TypeSerializer<E>, int) - Constructor for class org.apache.flink.runtime.io.disk.ChannelReaderInputViewIterator
-
- ChannelReaderInputViewIterator(IOManager, FileIOChannel.ID, LinkedBlockingQueue<MemorySegment>, List<MemorySegment>, List<MemorySegment>, TypeSerializer<E>, int) - Constructor for class org.apache.flink.runtime.io.disk.ChannelReaderInputViewIterator
-
- ChannelReaderInputViewIterator(BlockChannelReader<MemorySegment>, LinkedBlockingQueue<MemorySegment>, List<MemorySegment>, List<MemorySegment>, TypeSerializer<E>, int) - Constructor for class org.apache.flink.runtime.io.disk.ChannelReaderInputViewIterator
-
- ChannelReaderInputViewIterator(ChannelReaderInputView, List<MemorySegment>, TypeSerializer<E>) - Constructor for class org.apache.flink.runtime.io.disk.ChannelReaderInputViewIterator
-
- ChannelSelector<T extends IOReadableWritable> - Interface in org.apache.flink.runtime.io.network.api.writer
-
The
ChannelSelector
determines to which logical channels a record
should be written to.
- channelUnregistered(ChannelHandlerContext) - Method in class org.apache.flink.runtime.webmonitor.HttpRequestHandler
-
- ChannelWithBlockCount(FileIOChannel.ID, int) - Constructor for class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.ChannelWithBlockCount
-
- ChannelWriterOutputView - Class in org.apache.flink.runtime.io.disk.iomanager
-
- ChannelWriterOutputView(BlockChannelWriter<MemorySegment>, List<MemorySegment>, int) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.ChannelWriterOutputView
-
Creates an new ChannelWriterOutputView that writes to the given channel and buffers data
in the given memory segments.
- ChannelWriterOutputView(BlockChannelWriter<MemorySegment>, int) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.ChannelWriterOutputView
-
Creates an new ChannelWriterOutputView that writes to the given channel.
- CHAR - Static variable in class org.apache.flink.api.common.typeinfo.Types
-
Returns type information for both a primitive
char
and
Character
.
- CHAR_ARRAY_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
-
- CHAR_PRIMITIVE_ARRAY_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
-
- CHAR_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
-
- CHAR_VALUE_TYPE_INFO - Static variable in class org.apache.flink.api.java.typeutils.ValueTypeInfo
-
- CharacterFilter - Interface in org.apache.flink.metrics
-
Interface for a character filter function.
- charAt(int) - Method in class org.apache.flink.types.StringValue
-
- CharComparator - Class in org.apache.flink.api.common.typeutils.base
-
- CharComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.CharComparator
-
- CharPrimitiveArrayComparator - Class in org.apache.flink.api.common.typeutils.base.array
-
- CharPrimitiveArrayComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.array.CharPrimitiveArrayComparator
-
- CharPrimitiveArraySerializer - Class in org.apache.flink.api.common.typeutils.base.array
-
A serializer for char arrays.
- CharPrimitiveArraySerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.array.CharPrimitiveArraySerializer
-
- CharSerializer - Class in org.apache.flink.api.common.typeutils.base
-
- CharSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.CharSerializer
-
- CharValue - Class in org.apache.flink.types
-
Boxed serializable and comparable character type, representing the primitive
type char
.
- CharValue() - Constructor for class org.apache.flink.types.CharValue
-
Initializes the encapsulated char with 0.
- CharValue(char) - Constructor for class org.apache.flink.types.CharValue
-
Initializes the encapsulated char with the provided value.
- CharValueArray - Class in org.apache.flink.graph.types.valuearray
-
- CharValueArray() - Constructor for class org.apache.flink.graph.types.valuearray.CharValueArray
-
Initializes an expandable array with default capacity.
- CharValueArray(int) - Constructor for class org.apache.flink.graph.types.valuearray.CharValueArray
-
Initializes a fixed-size array with the provided number of chars.
- CharValueArrayComparator - Class in org.apache.flink.graph.types.valuearray
-
Specialized comparator for CharValueArray based on CopyableValueComparator.
- CharValueArrayComparator(boolean) - Constructor for class org.apache.flink.graph.types.valuearray.CharValueArrayComparator
-
- CharValueArraySerializer - Class in org.apache.flink.graph.types.valuearray
-
Specialized serializer for CharValueArray
.
- CharValueArraySerializer() - Constructor for class org.apache.flink.graph.types.valuearray.CharValueArraySerializer
-
- CharValueComparator - Class in org.apache.flink.api.common.typeutils.base
-
Specialized comparator for CharValue based on CopyableValueComparator.
- CharValueComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.CharValueComparator
-
- CharValueSerializer - Class in org.apache.flink.api.common.typeutils.base
-
- CharValueSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.CharValueSerializer
-
- CheckAndAllocateContainers - Class in org.apache.flink.runtime.clusterframework.messages
-
This message signals the resource master to check how many TaskManagers are
desired, how many are available, and to trigger adjustments if needed.
- checkAndCoSort(int[], Class<?>[]) - Static method in class org.apache.flink.api.common.io.GenericCsvInputFormat
-
- checkAndCreateUploadDir(File) - Static method in class org.apache.flink.runtime.webmonitor.WebRuntimeMonitor
-
Checks whether the given directory exists and is writable.
- checkAndExtractLambda(Function) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractionUtils
-
Checks if the given function has been implemented using a Java 8 lambda.
- checkAndGetNewWatermark(T, long) - Method in class org.apache.flink.streaming.connectors.kafka.internals.KafkaTopicPartitionStateWithPunctuatedWatermarks
-
- checkAndGetNextWatermark(T, long) - Method in interface org.apache.flink.streaming.api.functions.AssignerWithPunctuatedWatermarks
-
Asks this implementation if it wants to emit a watermark.
- checkAndThrowException() - Method in class org.apache.flink.streaming.connectors.kafka.internals.ExceptionProxy
-
- checkArgument(boolean) - Static method in class 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) - Static method in class 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...) - Static method in class org.apache.flink.util.Preconditions
-
Checks the given boolean condition, and throws an IllegalArgumentException
if
the condition is not met (evaluates to false
).
- checkCollection(Collection<X>, Class<X>) - Static method in class org.apache.flink.api.java.io.CollectionInputFormat
-
- checkCollection(Collection<OUT>, Class<OUT>) - Static method in class org.apache.flink.streaming.api.functions.source.FromElementsFunction
-
Verifies that all elements in the collection are non-null, and are of the given class, or
a subclass thereof.
- checkDateFormat(String) - Static method in class org.apache.calcite.avatica.util.DateTimeUtils
-
Checks if the date/time format is valid
- checked(Supplier<R>) - Static method in interface org.apache.flink.util.function.CheckedSupplier
-
- checkedDownCast(long) - Static method in class org.apache.flink.util.MathUtils
-
Casts the given value to a 32 bit integer, if it can be safely done.
- CheckedSupplier<R> - Interface in org.apache.flink.util.function
-
- CheckedThread - Class in org.apache.flink.core.testutils
-
A thread that additionally catches exceptions and offers a joining method that
re-throws the exceptions.
- CheckedThread() - Constructor for class org.apache.flink.core.testutils.CheckedThread
-
Unnamed checked thread.
- CheckedThread(String) - Constructor for class org.apache.flink.core.testutils.CheckedThread
-
Checked thread with a name.
- checkElementIndex(int, int) - Static method in class 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) - Static method in class org.apache.flink.util.Preconditions
-
Ensures that the given index is valid for an array, list or string of the given size.
- checkEquivalentFieldPositionsInKeyFields(FieldList, FieldList) - Method in class org.apache.flink.optimizer.operators.OperatorDescriptorDual
-
- checkEquivalentFieldPositionsInKeyFields(FieldList, FieldList, int) - Method in class org.apache.flink.optimizer.operators.OperatorDescriptorDual
-
- checkErroneous() - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousFileIOChannel
-
Checks the exception state of this channel.
- checkErroneous() - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducerBase
-
- checkError() - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputChannel
-
Checks for an error and rethrows it if one was reported.
- checkForInstantiation(Class<?>) - Static method in class org.apache.flink.util.InstantiationUtil
-
Performs a standard check whether the class can be instantiated by Class#newInstance()
.
- checkForInstantiationError(Class<?>) - Static method in class org.apache.flink.util.InstantiationUtil
-
- checkForMonotonousOrder(int[], Class<?>[]) - Static method in class org.apache.flink.api.common.io.GenericCsvInputFormat
-
- checkInterrupted(Throwable) - Static method in class org.apache.flink.util.ExceptionUtils
-
Checks whether the given exception is a
InterruptedException
and sets
the interrupted flag accordingly.
- checkJarFile(URL) - Static method in class org.apache.flink.client.program.JobWithJars
-
- checkJoinKeyFields(int[]) - Method in class org.apache.flink.api.java.operators.DeltaIteration.SolutionSetPlaceHolder
-
- checkLinesAgainstRegexp(String, String) - Static method in class org.apache.flink.test.util.TestBaseUtils
-
- checkNameUniqueness(String) - Method in class org.apache.flink.cep.nfa.compiler.NFAStateNameHandler
-
Checks if the given name is already used or not.
- checkNetworkBufferConfig(int, float, long, long) - Static method in class org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
-
Validates the (new) network buffer configuration.
- checkNetworkConfigOld(int) - Static method in class org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
-
Validates the (old) network buffer configuration.
- checkNotNull(T) - Static method in class org.apache.flink.util.Preconditions
-
Ensures that the given object reference is not null.
- checkNotNull(T, String) - Static method in class org.apache.flink.util.Preconditions
-
Ensures that the given object reference is not null.
- checkNotNull(T, String, Object...) - Static method in class org.apache.flink.util.Preconditions
-
Ensures that the given object reference is not null.
- checkNotShutdown() - Method in class org.apache.flink.runtime.highavailability.nonha.AbstractNonHaServices
-
- checkOddEvenResult(BufferedReader) - Static method in class org.apache.flink.test.testdata.ConnectedComponentsData
-
- checkOddEvenResult(List<Tuple2<Long, Long>>) - Static method in class org.apache.flink.test.testdata.ConnectedComponentsData
-
- checkOddEvenResult(BufferedReader) - Static method in class org.apache.flink.test.testdata.TransitiveClosureData
-
- checkParallelismPreconditions(List<OperatorState>, ExecutionJobVertex) - Method in class org.apache.flink.runtime.checkpoint.StateAssignmentOperation
-
- checkParallelismPreconditions(int) - Static method in class org.apache.flink.runtime.state.KeyGroupRangeAssignment
-
- checkParameter(boolean, Object) - Static method in class org.apache.flink.graph.drivers.parameter.Util
-
Checks the given boolean condition, and throws an ProgramParametrizationException
if
the condition is not met (evaluates to false
).
- checkPartialSolutionPropertiesMet(PlanNode, GlobalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.plan.PlanNode
-
- CHECKPOINT_DIR_PREFIX - Static variable in class org.apache.flink.runtime.state.filesystem.AbstractFsCheckpointStorage
-
The prefix of the directory containing the data exclusive to a checkpoint.
- CHECKPOINT_SHARED_STATE_DIR - Static variable in class org.apache.flink.runtime.state.filesystem.AbstractFsCheckpointStorage
-
The name of the directory for shared checkpoint state.
- CHECKPOINT_TASK_OWNED_STATE_DIR - Static variable in class org.apache.flink.runtime.state.filesystem.AbstractFsCheckpointStorage
-
The name of the directory for state not owned/released by the master, but by the TaskManagers.
- CheckpointableInputFormat<S extends InputSplit,T extends Serializable> - Interface in org.apache.flink.api.common.io
-
An interface that describes
InputFormat
s that allow checkpointing/restoring their state.
- CheckpointAlignment(long, long) - Constructor for class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics.CheckpointAlignment
-
- CheckpointAlignment(MinMaxAvgStatistics, MinMaxAvgStatistics) - Constructor for class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.CheckpointAlignment
-
- CheckpointBarrier - Class in org.apache.flink.runtime.io.network.api
-
Checkpoint barriers are used to align checkpoints throughout the streaming topology.
- CheckpointBarrier(long, long, CheckpointOptions) - Constructor for class org.apache.flink.runtime.io.network.api.CheckpointBarrier
-
- CheckpointBarrierHandler - Interface in org.apache.flink.streaming.runtime.io
-
The CheckpointBarrierHandler reacts to checkpoint barrier arriving from the input channels.
- CheckpointCommitter - Class in org.apache.flink.streaming.runtime.operators
-
This class is used to save information about which sink operator instance has committed checkpoints to a backend.
- CheckpointCommitter() - Constructor for class org.apache.flink.streaming.runtime.operators.CheckpointCommitter
-
- CheckpointConfig - Class in org.apache.flink.streaming.api.environment
-
Configuration that captures all checkpointing related settings.
- CheckpointConfig() - Constructor for class org.apache.flink.streaming.api.environment.CheckpointConfig
-
- CheckpointConfig.ExternalizedCheckpointCleanup - Enum in org.apache.flink.streaming.api.environment
-
Cleanup behaviour for externalized checkpoints when the job is cancelled.
- CheckpointConfigHandler - Class in org.apache.flink.runtime.rest.handler.job.checkpoints
-
Handler which serves the checkpoint configuration.
- CheckpointConfigHandler(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MessageHeaders<EmptyRequestBody, CheckpointConfigInfo, JobMessageParameters>, ExecutionGraphCache, Executor) - Constructor for class org.apache.flink.runtime.rest.handler.job.checkpoints.CheckpointConfigHandler
-
- CheckpointConfigHandler - Class in org.apache.flink.runtime.rest.handler.legacy.checkpoints
-
Handler that returns a job's snapshotting settings.
- CheckpointConfigHandler(ExecutionGraphCache, Executor) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.checkpoints.CheckpointConfigHandler
-
- CheckpointConfigHandler.CheckpointConfigJsonArchivist - Class in org.apache.flink.runtime.rest.handler.legacy.checkpoints
-
Archivist for the CheckpointConfigHandler.
- CheckpointConfigHeaders - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
- CheckpointConfigInfo - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
- CheckpointConfigInfo(CheckpointConfigInfo.ProcessingMode, long, long, long, int, CheckpointConfigInfo.ExternalizedCheckpointInfo) - Constructor for class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigInfo
-
- CheckpointConfigInfo.ExternalizedCheckpointInfo - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
Contains information about the externalized checkpoint configuration.
- CheckpointConfigInfo.ProcessingMode - Enum in org.apache.flink.runtime.rest.messages.checkpoints
-
Processing mode.
- CheckpointConfigInfo.ProcessingModeDeserializer - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
Processing mode deserializer.
- CheckpointConfigInfo.ProcessingModeSerializer - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
- CheckpointConfigJsonArchivist() - Constructor for class org.apache.flink.runtime.rest.handler.legacy.checkpoints.CheckpointConfigHandler.CheckpointConfigJsonArchivist
-
- CheckpointCoordinator - Class in org.apache.flink.runtime.checkpoint
-
The checkpoint coordinator coordinates the distributed snapshots of operators and state.
- CheckpointCoordinator(JobID, long, long, long, int, CheckpointRetentionPolicy, ExecutionVertex[], ExecutionVertex[], ExecutionVertex[], CheckpointIDCounter, CompletedCheckpointStore, StateBackend, Executor, SharedStateRegistryFactory) - Constructor for class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
- CheckpointCoordinatorConfiguration - Class in org.apache.flink.runtime.jobgraph.tasks
-
- CheckpointCoordinatorConfiguration(long, long, long, int, CheckpointRetentionPolicy, boolean) - Constructor for class org.apache.flink.runtime.jobgraph.tasks.CheckpointCoordinatorConfiguration
-
- CheckpointCoordinatorDeActivator - Class in org.apache.flink.runtime.checkpoint
-
This actor listens to changes in the JobStatus and activates or deactivates the periodic
checkpoint scheduler.
- CheckpointCoordinatorDeActivator(CheckpointCoordinator) - Constructor for class org.apache.flink.runtime.checkpoint.CheckpointCoordinatorDeActivator
-
- CheckpointCoordinatorGateway - Interface in org.apache.flink.runtime.checkpoint
-
- CheckpointDeclineException - Exception in org.apache.flink.runtime.checkpoint.decline
-
Base class of all exceptions that indicate a declined checkpoint.
- CheckpointDeclineException(String) - Constructor for exception org.apache.flink.runtime.checkpoint.decline.CheckpointDeclineException
-
- CheckpointDeclineException(String, Throwable) - Constructor for exception org.apache.flink.runtime.checkpoint.decline.CheckpointDeclineException
-
- CheckpointDeclineOnCancellationBarrierException - Exception in org.apache.flink.runtime.checkpoint.decline
-
Exception indicating that a checkpoint was declined because a cancellation
barrier was received.
- CheckpointDeclineOnCancellationBarrierException() - Constructor for exception org.apache.flink.runtime.checkpoint.decline.CheckpointDeclineOnCancellationBarrierException
-
- CheckpointDeclineReason - Enum in org.apache.flink.runtime.checkpoint
-
Various reasons why a checkpoint was declined.
- CheckpointDeclineSubsumedException - Exception in org.apache.flink.runtime.checkpoint.decline
-
Exception indicating that a checkpoint was declined because a newer checkpoint
barrier was received on an input before the pending checkpoint's barrier.
- CheckpointDeclineSubsumedException(long) - Constructor for exception org.apache.flink.runtime.checkpoint.decline.CheckpointDeclineSubsumedException
-
- CheckpointDeclineTaskNotCheckpointingException - Exception in org.apache.flink.runtime.checkpoint.decline
-
Exception indicating that a checkpoint was declined because a task does not support
checkpointing.
- CheckpointDeclineTaskNotCheckpointingException(String) - Constructor for exception org.apache.flink.runtime.checkpoint.decline.CheckpointDeclineTaskNotCheckpointingException
-
- CheckpointDeclineTaskNotReadyException - Exception in org.apache.flink.runtime.checkpoint.decline
-
Exception indicating that a checkpoint was declined because a task was not
ready to perform a checkpoint.
- CheckpointDeclineTaskNotReadyException(String) - Constructor for exception org.apache.flink.runtime.checkpoint.decline.CheckpointDeclineTaskNotReadyException
-
- CheckpointDuration(long, long) - Constructor for class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics.CheckpointDuration
-
- CheckpointDuration(MinMaxAvgStatistics, MinMaxAvgStatistics) - Constructor for class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.CheckpointDuration
-
- CheckpointedFunction - Interface in org.apache.flink.streaming.api.checkpoint
-
This is the core interface for stateful transformation functions, meaning functions
that maintain state across individual stream records.
- CheckpointedStateScope - Enum in org.apache.flink.runtime.state
-
The scope for a chunk of checkpointed state.
- CheckpointException - Exception in org.apache.flink.runtime.checkpoint
-
Base class for checkpoint related exceptions.
- CheckpointException(String, Throwable) - Constructor for exception org.apache.flink.runtime.checkpoint.CheckpointException
-
- CheckpointException(String) - Constructor for exception org.apache.flink.runtime.checkpoint.CheckpointException
-
- CheckpointException - Exception in org.apache.flink.runtime.taskexecutor.exceptions
-
Exception indicating a problem with checkpointing on the
TaskExecutor
side.
- CheckpointException(String) - Constructor for exception org.apache.flink.runtime.taskexecutor.exceptions.CheckpointException
-
- CheckpointException(String, Throwable) - Constructor for exception org.apache.flink.runtime.taskexecutor.exceptions.CheckpointException
-
- CheckpointException(Throwable) - Constructor for exception org.apache.flink.runtime.taskexecutor.exceptions.CheckpointException
-
- CheckpointExceptionHandler - Interface in org.apache.flink.streaming.runtime.tasks
-
Handler for exceptions that happen on checkpointing.
- CheckpointExceptionHandlerFactory - Class in org.apache.flink.streaming.runtime.tasks
-
- CheckpointExceptionHandlerFactory() - Constructor for class org.apache.flink.streaming.runtime.tasks.CheckpointExceptionHandlerFactory
-
- CheckpointIDCounter - Interface in org.apache.flink.runtime.checkpoint
-
A checkpoint ID counter.
- CheckpointIdPathParameter - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
Path parameter for the checkpoint id of type
Long
.
- CheckpointIdPathParameter() - Constructor for class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointIdPathParameter
-
- checkpointIdPathParameter - Variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointMessageParameters
-
- checkpointIdToPath(long) - Static method in class org.apache.flink.runtime.checkpoint.ZooKeeperCompletedCheckpointStore
-
Convert a checkpoint id into a ZooKeeper path.
- checkpointingLock - Variable in class org.apache.flink.streaming.api.operators.async.AsyncWaitOperator
-
- CheckpointingMode - Enum in org.apache.flink.streaming.api
-
The checkpointing mode defines what consistency guarantees the system gives in the presence of
failures.
- CheckpointingOptions - Class in org.apache.flink.configuration
-
A collection of all configuration options that relate to checkpoints
and savepoints.
- CheckpointingOptions() - Constructor for class org.apache.flink.configuration.CheckpointingOptions
-
- CheckpointingStatistics - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
- CheckpointingStatistics(CheckpointingStatistics.Counts, CheckpointingStatistics.Summary, CheckpointingStatistics.LatestCheckpoints, List<CheckpointStatistics>) - Constructor for class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics
-
- CheckpointingStatistics.Counts - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
Checkpoint counts.
- CheckpointingStatistics.LatestCheckpoints - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
Statistics about the latest checkpoints.
- CheckpointingStatistics.RestoredCheckpointStatistics - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
Statistics for a restored checkpoint.
- CheckpointingStatistics.Summary - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
Checkpoint summary.
- CheckpointingStatisticsHandler - Class in org.apache.flink.runtime.rest.handler.job.checkpoints
-
Handler which serves the checkpoint statistics.
- CheckpointingStatisticsHandler(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MessageHeaders<EmptyRequestBody, CheckpointingStatistics, JobMessageParameters>, ExecutionGraphCache, Executor) - Constructor for class org.apache.flink.runtime.rest.handler.job.checkpoints.CheckpointingStatisticsHandler
-
- CheckpointingStatisticsHeaders - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
- CheckpointingStatisticsHeaders() - Constructor for class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatisticsHeaders
-
- CheckpointListener - Interface in org.apache.flink.runtime.state
-
This interface must be implemented by functions/operations that want to receive
a commit notification once a checkpoint has been completely acknowledged by all
participants.
- CheckpointMessageParameters - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
Message parameters for checkpoint related messages.
- CheckpointMessageParameters() - Constructor for class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointMessageParameters
-
- CheckpointMetaData - Class in org.apache.flink.runtime.checkpoint
-
Encapsulates all the meta data for a checkpoint.
- CheckpointMetaData(long, long) - Constructor for class org.apache.flink.runtime.checkpoint.CheckpointMetaData
-
- CheckpointMetadataOutputStream - Class in org.apache.flink.runtime.state
-
- CheckpointMetadataOutputStream() - Constructor for class org.apache.flink.runtime.state.CheckpointMetadataOutputStream
-
- CheckpointMetrics - Class in org.apache.flink.runtime.checkpoint
-
A collection of simple metrics, around the triggering of a checkpoint.
- CheckpointMetrics() - Constructor for class org.apache.flink.runtime.checkpoint.CheckpointMetrics
-
- CheckpointMetrics(long, long, long, long) - Constructor for class org.apache.flink.runtime.checkpoint.CheckpointMetrics
-
- CheckpointOptions - Class in org.apache.flink.runtime.checkpoint
-
Options for performing the checkpoint.
- CheckpointOptions(CheckpointType, CheckpointStorageLocationReference) - Constructor for class org.apache.flink.runtime.checkpoint.CheckpointOptions
-
- CheckpointProperties - Class in org.apache.flink.runtime.checkpoint
-
The configuration of a checkpoint.
- CheckpointRecoveryFactory - Interface in org.apache.flink.runtime.checkpoint
-
A factory for per Job checkpoint recovery components.
- CheckpointResponder - Interface in org.apache.flink.runtime.taskmanager
-
Responder for checkpoint acknowledge and decline messages in the
Task
.
- CheckpointRetentionPolicy - Enum in org.apache.flink.runtime.checkpoint
-
Policy for whether checkpoints are retained after a job terminates.
- Checkpoints - Class in org.apache.flink.runtime.checkpoint
-
A utility class with the methods to write/load/dispose the checkpoint and savepoint metadata.
- CHECKPOINTS_DIRECTORY - Static variable in class 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 - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- CHECKPOINTS_HISTORY_SIZE - Static variable in class org.apache.flink.configuration.WebOptions
-
Config parameter defining the number of checkpoints to remember for recent history.
- checkpointsMatch(Collection<CompletedCheckpoint>, Collection<CompletedCheckpoint>) - Static method in class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
-
- CheckpointStateOutputStream() - Constructor for class org.apache.flink.runtime.state.CheckpointStreamFactory.CheckpointStateOutputStream
-
- CheckpointStatisticDetailsHandler - Class in org.apache.flink.runtime.rest.handler.job.checkpoints
-
REST handler which returns the details for a checkpoint.
- CheckpointStatisticDetailsHandler(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MessageHeaders<EmptyRequestBody, CheckpointStatistics, CheckpointMessageParameters>, ExecutionGraphCache, Executor, CheckpointStatsCache) - Constructor for class org.apache.flink.runtime.rest.handler.job.checkpoints.CheckpointStatisticDetailsHandler
-
- CheckpointStatisticDetailsHeaders - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
- CheckpointStatistics - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
Statistics for a checkpoint.
- CheckpointStatistics.CompletedCheckpointStatistics - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
Statistics for a completed checkpoint.
- CheckpointStatistics.FailedCheckpointStatistics - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
Statistics for a failed checkpoint.
- CheckpointStatistics.PendingCheckpointStatistics - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
Statistics for a pending checkpoint.
- CheckpointStatsCache - Class in org.apache.flink.runtime.rest.handler.job.checkpoints
-
A size-based cache of accessed checkpoints for completed and failed
checkpoints.
- CheckpointStatsCache(int) - Constructor for class org.apache.flink.runtime.rest.handler.job.checkpoints.CheckpointStatsCache
-
- CheckpointStatsCounts - Class in org.apache.flink.runtime.checkpoint
-
Counts of checkpoints.
- CheckpointStatsDetailsHandler - Class in org.apache.flink.runtime.rest.handler.legacy.checkpoints
-
Request handler that returns checkpoint stats for a single job vertex.
- CheckpointStatsDetailsHandler(ExecutionGraphCache, Executor, CheckpointStatsCache) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.checkpoints.CheckpointStatsDetailsHandler
-
- CheckpointStatsDetailsHandler.CheckpointStatsDetailsJsonArchivist - Class in org.apache.flink.runtime.rest.handler.legacy.checkpoints
-
Archivist for the CheckpointStatsDetails.
- CheckpointStatsDetailsJsonArchivist() - Constructor for class org.apache.flink.runtime.rest.handler.legacy.checkpoints.CheckpointStatsDetailsHandler.CheckpointStatsDetailsJsonArchivist
-
- CheckpointStatsDetailsSubtasksHandler - Class in org.apache.flink.runtime.rest.handler.legacy.checkpoints
-
Request handler that returns checkpoint stats for a single job vertex with
the summary stats and all subtasks.
- CheckpointStatsDetailsSubtasksHandler(ExecutionGraphCache, Executor, CheckpointStatsCache) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.checkpoints.CheckpointStatsDetailsSubtasksHandler
-
- CheckpointStatsDetailsSubtasksHandler.CheckpointStatsDetailsSubtasksJsonArchivist - Class in org.apache.flink.runtime.rest.handler.legacy.checkpoints
-
Archivist for the CheckpointStatsDetailsSubtasksHandler.
- CheckpointStatsDetailsSubtasksJsonArchivist() - Constructor for class org.apache.flink.runtime.rest.handler.legacy.checkpoints.CheckpointStatsDetailsSubtasksHandler.CheckpointStatsDetailsSubtasksJsonArchivist
-
- CheckpointStatsHandler - Class in org.apache.flink.runtime.rest.handler.legacy.checkpoints
-
Handler that returns checkpoint statistics for a job.
- CheckpointStatsHandler(ExecutionGraphCache, Executor) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.checkpoints.CheckpointStatsHandler
-
- CheckpointStatsHandler.CheckpointStatsJsonArchivist - Class in org.apache.flink.runtime.rest.handler.legacy.checkpoints
-
Archivist for the CheckpointStatsJsonHandler.
- CheckpointStatsHistory - Class in org.apache.flink.runtime.checkpoint
-
An array based history of checkpoint stats.
- CheckpointStatsJsonArchivist() - Constructor for class org.apache.flink.runtime.rest.handler.legacy.checkpoints.CheckpointStatsHandler.CheckpointStatsJsonArchivist
-
- CheckpointStatsSnapshot - Class in org.apache.flink.runtime.checkpoint
-
A snapshot of the checkpoint stats.
- CheckpointStatsStatus - Enum in org.apache.flink.runtime.checkpoint
-
Status of the tracked checkpoint.
- CheckpointStatsTracker - Class in org.apache.flink.runtime.checkpoint
-
Tracker for checkpoint statistics.
- CheckpointStatsTracker(int, List<ExecutionJobVertex>, CheckpointCoordinatorConfiguration, MetricGroup) - Constructor for class org.apache.flink.runtime.checkpoint.CheckpointStatsTracker
-
Creates a new checkpoint stats tracker.
- CheckpointStorage - Interface in org.apache.flink.runtime.state
-
CheckpointStorage implements the durable storage of checkpoint data and metadata streams.
- CheckpointStorageLocation - Interface in org.apache.flink.runtime.state
-
A storage location for one particular checkpoint, offering data persistent, metadata persistence,
and lifecycle/cleanup methods.
- CheckpointStorageLocationReference - Class in org.apache.flink.runtime.state
-
A reference to a storage location.
- CheckpointStorageLocationReference(byte[]) - Constructor for class org.apache.flink.runtime.state.CheckpointStorageLocationReference
-
Creates a new location reference.
- CheckpointStreamFactory - Interface in org.apache.flink.runtime.state
-
A factory for checkpoint output streams, which are used to persist data for checkpoints.
- CheckpointStreamFactory.CheckpointStateOutputStream - Class in org.apache.flink.runtime.state
-
- CheckpointStreamWithResultProvider - Interface in org.apache.flink.runtime.state
-
Interface that provides access to a CheckpointStateOutputStream and a method to provide the
SnapshotResult
.
- CheckpointStreamWithResultProvider.PrimaryAndSecondaryStream - Class in org.apache.flink.runtime.state
-
- CheckpointStreamWithResultProvider.PrimaryStreamOnly - Class in org.apache.flink.runtime.state
-
- CheckpointTriggerException - Exception in org.apache.flink.runtime.checkpoint
-
Exceptions which indicate that a checkpoint triggering has failed.
- CheckpointTriggerException(String, CheckpointDeclineReason) - Constructor for exception org.apache.flink.runtime.checkpoint.CheckpointTriggerException
-
- CheckpointTriggerResult - Class in org.apache.flink.runtime.checkpoint
-
The result of triggering a checkpoint.
- CheckpointType - Enum in org.apache.flink.runtime.checkpoint
-
The type of checkpoint to perform.
- checkResultsWithDelta(String, List<String>, double) - Static method in class org.apache.flink.test.testdata.KMeansData
-
- checkSameExecutionContext(DataSet<?>, DataSet<?>) - Static method in class org.apache.flink.api.java.DataSet
-
- checkSameOrdering(GlobalProperties, GlobalProperties, int) - Method in class org.apache.flink.optimizer.operators.OperatorDescriptorDual
-
- checkSameOrdering(LocalProperties, LocalProperties, int) - Method in class org.apache.flink.optimizer.operators.OperatorDescriptorDual
-
- checkState(boolean) - Static method in class 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) - Static method in class 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...) - Static method in class org.apache.flink.util.Preconditions
-
Checks the given boolean condition, and throws an IllegalStateException
if
the condition is not met (evaluates to false
).
- Checksum(long, long) - Constructor for class org.apache.flink.graph.asm.dataset.ChecksumHashCode.Checksum
-
Instantiate an immutable result.
- ChecksumHashCode() - Constructor for class org.apache.flink.api.java.Utils.ChecksumHashCode
-
- ChecksumHashCode(long, long) - Constructor for class org.apache.flink.api.java.Utils.ChecksumHashCode
-
- checksumHashCode(DataSet<T>) - Static method in class org.apache.flink.api.java.utils.DataSetUtils
-
- ChecksumHashCode<T> - Class in org.apache.flink.graph.asm.dataset
-
Convenience method to get the count (number of elements) of a
DataSet
as well as the checksum (sum over element hashes).
- ChecksumHashCode() - Constructor for class org.apache.flink.graph.asm.dataset.ChecksumHashCode
-
- ChecksumHashCode<K,VV,EV> - Class in org.apache.flink.graph.library.metric
-
Convenience method to get the count (number of elements) of a Graph
as well as the checksum (sum over element hashes).
- ChecksumHashCode() - Constructor for class org.apache.flink.graph.library.metric.ChecksumHashCode
-
- ChecksumHashCode.Checksum - Class in org.apache.flink.graph.asm.dataset
-
Wraps checksum and count.
- ChecksumHashCodeHelper(String) - Constructor for class org.apache.flink.api.java.Utils.ChecksumHashCodeHelper
-
- child() - Method in class org.apache.flink.orc.OrcRowInputFormat.Not
-
- childFirst(URL[], ClassLoader, String[]) - Static method in class org.apache.flink.runtime.execution.librarycache.FlinkUserCodeClassLoaders
-
- children() - Method in class org.apache.flink.orc.OrcRowInputFormat.Or
-
- ChoiceParameter - Class in org.apache.flink.graph.drivers.parameter
-
A
Parameter
storing a list of
String
choices and parsing
the user's configured selection.
- ChoiceParameter(ParameterizedBase, String) - Constructor for class org.apache.flink.graph.drivers.parameter.ChoiceParameter
-
Set the parameter name and add this parameter to the list of parameters
stored by owner.
- choices(String...) - Method in class org.apache.flink.api.java.utils.Option
-
Restrict the list of possible values of the parameter.
- ChunkedByteBuf - Class in org.apache.flink.queryablestate.network
-
A ByteBuf
instance to be consumed in chunks by ChunkedWriteHandler
,
respecting the high and low watermarks.
- ChunkedByteBuf(ByteBuf, int) - Constructor for class org.apache.flink.queryablestate.network.ChunkedByteBuf
-
- CirculantGraph - Class in org.apache.flink.graph.drivers.input
-
- CirculantGraph() - Constructor for class org.apache.flink.graph.drivers.input.CirculantGraph
-
- CirculantGraph - Class in org.apache.flink.graph.generator
-
- CirculantGraph(ExecutionEnvironment, long) - Constructor for class org.apache.flink.graph.generator.CirculantGraph
-
An oriented
Graph
with
n
vertices where each vertex
v
i is connected to vertex v
(i+j)%n for each
configured offset
j
.
- CirculantGraph.OffsetRange - Class in org.apache.flink.graph.generator
-
Stores the start offset and length configuration for an offset range.
- CircularElement() - Constructor for class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.CircularElement
-
- CircularElement(int, InMemorySorter<E>, List<MemorySegment>) - Constructor for class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.CircularElement
-
- CircularQueues() - Constructor for class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.CircularQueues
-
- CircularQueues(int) - Constructor for class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.CircularQueues
-
- ClassLayout - Class in org.openjdk.jol.info
-
Mock class avoid a dependency on OpenJDK JOL,
which is incompatible with the Apache License.
- ClassLayout() - Constructor for class org.openjdk.jol.info.ClassLayout
-
- classLoader - Variable in class org.apache.flink.util.InstantiationUtil.ClassLoaderObjectInputStream
-
- CLASSLOADER_RESOLVE_ORDER - Static variable in class 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"
)
- ClassLoaderObjectInputStream(InputStream, ClassLoader) - Constructor for class org.apache.flink.util.InstantiationUtil.ClassLoaderObjectInputStream
-
- ClassLoaderTestProgram - Class in org.apache.flink.streaming.tests
-
End-to-end test program for verifying that the classloader.resolve-order
setting
is being honored by Flink.
- ClassLoaderTestProgram() - Constructor for class org.apache.flink.streaming.tests.ClassLoaderTestProgram
-
- ClassLoaderUtil - Class in org.apache.flink.runtime.util
-
Utilities for information with respect to class loaders, specifically class loaders for
the dynamic loading of user defined classes.
- ClassloadingProps - Class in org.apache.flink.runtime.jobmaster.message
-
The response of classloading props request to JobManager.
- ClassloadingProps(int, Collection<PermanentBlobKey>, Collection<URL>) - Constructor for class org.apache.flink.runtime.jobmaster.message.ClassloadingProps
-
Constructor of ClassloadingProps.
- CLASSPATH_INCLUDE_USER_JAR - Static variable in class org.apache.flink.yarn.configuration.YarnConfigOptions
-
Defines whether user-jars are included in the system class path for per-job-clusters as well as their positioning
in the path.
- classpathsToAttach - Variable in class org.apache.flink.client.program.ContextEnvironment
-
- clazz - Variable in class org.apache.flink.streaming.connectors.cassandra.CassandraPojoSink
-
- clean(Object, boolean) - Static method in class org.apache.flink.api.java.ClosureCleaner
-
Tries to clean the closure of the given object, if the object is a non-static inner
class.
- clean(F) - Method in class org.apache.flink.api.java.DataSet
-
- clean(F) - Method in class org.apache.flink.streaming.api.datastream.BroadcastConnectedStream
-
- clean(F) - Method in class org.apache.flink.streaming.api.datastream.BroadcastStream
-
- clean(F) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
- clean(F) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Returns a "closure-cleaned" version of the given function.
- cleanDirectory(File) - Static method in class org.apache.flink.util.FileUtils
-
Removes all files contained within a directory, without removing the directory itself.
- cleanFile(String) - Method in class org.apache.flink.streaming.api.functions.sink.WriteSinkFunction
-
Deprecated.
Creates target file if it does not exist, cleans it if it exists.
- cleanup() - Method in class org.apache.flink.runtime.operators.AbstractCachedBuildSideJoinDriver
-
- cleanup() - Method in class org.apache.flink.runtime.operators.AbstractOuterJoinDriver
-
- cleanup() - Method in class org.apache.flink.runtime.operators.AllGroupCombineDriver
-
- cleanup() - Method in class org.apache.flink.runtime.operators.AllGroupReduceDriver
-
- cleanup() - Method in class org.apache.flink.runtime.operators.AllReduceDriver
-
- cleanup() - Method in class org.apache.flink.runtime.operators.CoGroupDriver
-
- cleanup() - Method in class org.apache.flink.runtime.operators.CoGroupRawDriver
-
- cleanup() - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetFirstDriver
-
- cleanup() - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetSecondDriver
-
- cleanup() - Method in class org.apache.flink.runtime.operators.CrossDriver
-
- cleanup() - Method in interface org.apache.flink.runtime.operators.Driver
-
This method is invoked in any case (clean termination and exception) at the end of the tasks operation.
- cleanup() - Method in class org.apache.flink.runtime.operators.FlatMapDriver
-
- cleanup() - Method in class org.apache.flink.runtime.operators.GroupReduceCombineDriver
-
- cleanup() - Method in class org.apache.flink.runtime.operators.GroupReduceDriver
-
- cleanup() - Method in class org.apache.flink.runtime.operators.JoinDriver
-
- cleanup() - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetFirstDriver
-
- cleanup() - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetSecondDriver
-
- cleanup() - Method in class org.apache.flink.runtime.operators.MapDriver
-
- cleanup() - Method in class org.apache.flink.runtime.operators.MapPartitionDriver
-
- cleanup() - Method in class org.apache.flink.runtime.operators.NoOpDriver
-
- cleanup() - Method in class org.apache.flink.runtime.operators.ReduceCombineDriver
-
- cleanup() - Method in class org.apache.flink.runtime.operators.ReduceDriver
-
- cleanup() - Method in class org.apache.flink.runtime.operators.UnionWithTempOperator
-
- cleanup() - Method in class org.apache.flink.runtime.rest.handler.legacy.ExecutionGraphCache
-
Perform the cleanup of out dated ExecutionGraphEntry
.
- cleanup() - Method in class org.apache.flink.runtime.state.SnapshotDirectory
-
Calling this method will attempt delete the underlying snapshot directory recursively, if the state is
"ongoing".
- cleanup() - Method in class org.apache.flink.storm.exclamation.operators.ExclamationBolt
-
- cleanup() - Method in class org.apache.flink.storm.util.AbstractBoltSink
-
- cleanup() - Method in class org.apache.flink.storm.util.BoltFileSink
-
- cleanup() - Method in class org.apache.flink.storm.wordcount.operators.BoltCounter
-
- cleanup() - Method in class org.apache.flink.storm.wordcount.operators.BoltCounterByName
-
- cleanup() - Method in class org.apache.flink.storm.wordcount.operators.BoltTokenizer
-
- cleanup() - Method in class org.apache.flink.storm.wordcount.operators.BoltTokenizerByName
-
- cleanup() - Method in class org.apache.flink.streaming.connectors.elasticsearch.Elasticsearch1ApiCallBridge
-
- cleanup() - Method in interface org.apache.flink.streaming.connectors.elasticsearch.ElasticsearchApiCallBridge
-
Perform any necessary state cleanup.
- cleanup() - Method in class org.apache.flink.streaming.connectors.elasticsearch2.Elasticsearch2ApiCallBridge
-
- cleanup() - Method in class org.apache.flink.streaming.connectors.elasticsearch5.Elasticsearch5ApiCallBridge
-
- cleanup() - Method in class org.apache.flink.streaming.runtime.io.BarrierBuffer
-
- cleanup() - Method in class org.apache.flink.streaming.runtime.io.BarrierTracker
-
- cleanup() - Method in interface org.apache.flink.streaming.runtime.io.BufferOrEventSequence
-
Cleans up all the resources held by the sequence.
- cleanup() - Method in class org.apache.flink.streaming.runtime.io.BufferSpiller.SpilledBufferOrEventSequence
-
Deprecated.
- cleanup() - Method in class org.apache.flink.streaming.runtime.io.CachedBufferBlocker.CachedBufferOrEventSequence
-
- cleanup() - Method in interface org.apache.flink.streaming.runtime.io.CheckpointBarrierHandler
-
Cleans up all internally held resources.
- cleanup() - Method in class org.apache.flink.streaming.runtime.io.StreamInputProcessor
-
- cleanup() - Method in class org.apache.flink.streaming.runtime.io.StreamTwoInputProcessor
-
- cleanup() - Method in class org.apache.flink.streaming.runtime.tasks.OneInputStreamTask
-
- cleanup() - Method in class org.apache.flink.streaming.runtime.tasks.SourceStreamTask
-
- cleanup() - Method in class org.apache.flink.streaming.runtime.tasks.StreamIterationHead
-
- cleanup() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- cleanup() - Method in class org.apache.flink.streaming.runtime.tasks.TwoInputStreamTask
-
- cleanUp() - Method in class org.apache.flink.table.client.cli.CliInputView
-
- cleanUp() - Method in class org.apache.flink.table.client.cli.CliResultView
-
- cleanUp() - Method in class org.apache.flink.table.client.cli.CliRowView
-
- cleanUp() - Method in class org.apache.flink.table.client.cli.CliView
-
- cleanup() - Static method in class org.apache.flink.test.util.SecureTestEnvironment
-
- cleanup(Logger, AutoCloseable...) - Static method in class org.apache.flink.util.IOUtils
-
Close the AutoCloseable objects and
ignore any
Exception
or
null pointers.
- CLEANUP_INTERVAL - Static variable in class org.apache.flink.configuration.BlobServerOptions
-
Cleanup interval of the blob caches at the task managers (in seconds).
- cleanupJob(JobID, boolean) - Method in class org.apache.flink.runtime.blob.BlobServer
-
Removes all BLOBs from local and HA store belonging to the given job ID.
- cleanUpOperatorStatsCache() - Method in interface org.apache.flink.runtime.rest.handler.legacy.backpressure.BackPressureStatsTracker
-
Cleans up the operator stats cache if it contains timed out entries.
- cleanUpOperatorStatsCache() - Method in class org.apache.flink.runtime.rest.handler.legacy.backpressure.BackPressureStatsTrackerImpl
-
Cleans up the operator stats cache if it contains timed out entries.
- CleanupWhenUnsuccessful - Interface in org.apache.flink.api.common.io
-
OutputFormat
s may implement this interface to run a cleanup hook when the execution is not successful.
- clear() - Method in interface org.apache.flink.api.common.state.State
-
Removes the value mapped under the current key.
- clear() - Method in class org.apache.flink.cep.nfa.compiler.NFAStateNameHandler
-
Clear the names added during checking name uniqueness.
- clear() - Method in class org.apache.flink.contrib.streaming.state.AbstractRocksDBState
-
- clear() - Method in class org.apache.flink.contrib.streaming.state.RocksDBMapState
-
- clear() - Method in class org.apache.flink.core.memory.DataOutputSerializer
-
- clear() - Method in class org.apache.flink.examples.java.clustering.KMeans.Point
-
- clear() - Method in class org.apache.flink.graph.types.valuearray.ByteValueArray
-
- clear() - Method in class org.apache.flink.graph.types.valuearray.CharValueArray
-
- clear() - Method in class org.apache.flink.graph.types.valuearray.DoubleValueArray
-
- clear() - Method in class org.apache.flink.graph.types.valuearray.FloatValueArray
-
- clear() - Method in class org.apache.flink.graph.types.valuearray.IntValueArray
-
- clear() - Method in class org.apache.flink.graph.types.valuearray.LongValueArray
-
- clear() - Method in class org.apache.flink.graph.types.valuearray.NullValueArray
-
- clear() - Method in class org.apache.flink.graph.types.valuearray.ShortValueArray
-
- clear() - Method in class org.apache.flink.graph.types.valuearray.StringValueArray
-
- clear() - Method in interface org.apache.flink.graph.types.valuearray.ValueArray
-
Resets the array to the empty state.
- clear() - Method in class org.apache.flink.queryablestate.client.state.ImmutableAggregatingState
-
- clear() - Method in class org.apache.flink.queryablestate.client.state.ImmutableFoldingState
-
Deprecated.
- clear() - Method in class org.apache.flink.queryablestate.client.state.ImmutableListState
-
- clear() - Method in class org.apache.flink.queryablestate.client.state.ImmutableMapState
-
- clear() - Method in class org.apache.flink.queryablestate.client.state.ImmutableReducingState
-
- clear() - Method in class org.apache.flink.queryablestate.client.state.ImmutableValueState
-
- clear() - Method in class org.apache.flink.runtime.checkpoint.StateObjectCollection
-
- clear() - Method in interface org.apache.flink.runtime.io.network.api.serialization.RecordDeserializer
-
- clear() - Method in interface org.apache.flink.runtime.io.network.api.serialization.RecordSerializer
-
Clear and release internal state.
- clear() - Method in class org.apache.flink.runtime.io.network.api.serialization.SpanningRecordSerializer
-
- clear() - Method in class org.apache.flink.runtime.io.network.api.serialization.SpillingAdaptiveSpanningRecordDeserializer
-
- clear() - Method in class org.apache.flink.runtime.jobmanager.scheduler.SetQueue
-
- clear() - Method in class org.apache.flink.runtime.jobmaster.slotpool.DualKeyMap
-
- clear() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
-
Clears the internal state of the view.
- clear() - Method in class org.apache.flink.runtime.memory.AbstractPagedOutputView
-
Clears the internal state.
- clear() - Method in class org.apache.flink.runtime.operators.sort.PartialOrderPriorityQueue
-
Removes all entries from the PriorityQueue.
- clear() - Method in class org.apache.flink.runtime.operators.util.BitSet
-
Clear the bit set.
- clear() - Method in class org.apache.flink.runtime.operators.util.BloomFilter.BitSet
-
Clear the bit set.
- clear() - Method in class org.apache.flink.runtime.query.KvStateEntry
-
- clear() - Method in class org.apache.flink.runtime.resourcemanager.JobLeaderIdService
-
Stop and clear the currently registered job leader id listeners.
- clear() - Method in class org.apache.flink.runtime.state.heap.AbstractHeapState
-
- clear() - Method in class org.apache.flink.runtime.state.HeapBroadcastState
-
- clear() - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlot
-
Removes all tasks from this task slot.
- clear() - Method in class org.apache.flink.runtime.util.EvictingBoundedList
-
- clear() - Method in class org.apache.flink.runtime.util.IntArrayList
-
- clear() - Method in class org.apache.flink.runtime.util.LongArrayList
-
- clear() - Method in class org.apache.flink.storm.util.StormConfig
-
- clear(ProcessAllWindowFunction<T, R, W>.Context) - Method in class org.apache.flink.streaming.api.functions.windowing.FoldApplyProcessAllWindowFunction
-
Deprecated.
- clear(ProcessWindowFunction<T, R, K, W>.Context) - Method in class org.apache.flink.streaming.api.functions.windowing.FoldApplyProcessWindowFunction
-
Deprecated.
- clear(ProcessAllWindowFunction<IN, OUT, W>.Context) - Method in class org.apache.flink.streaming.api.functions.windowing.ProcessAllWindowFunction
-
Deletes any state in the Context
when the Window is purged.
- clear(ProcessWindowFunction<IN, OUT, KEY, W>.Context) - Method in class org.apache.flink.streaming.api.functions.windowing.ProcessWindowFunction
-
Deletes any state in the Context
when the Window is purged.
- clear(ProcessAllWindowFunction<T, R, W>.Context) - Method in class org.apache.flink.streaming.api.functions.windowing.ReduceApplyProcessAllWindowFunction
-
- clear(ProcessWindowFunction<T, R, K, W>.Context) - Method in class org.apache.flink.streaming.api.functions.windowing.ReduceApplyProcessWindowFunction
-
- clear() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
Remove all registered nodes etc.
- clear(GlobalWindow, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.assigners.GlobalWindows.NeverTrigger
-
- clear(W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousEventTimeTrigger
-
- clear(W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousProcessingTimeTrigger
-
- clear(W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.CountTrigger
-
- clear(W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.DeltaTrigger
-
- clear(TimeWindow, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.EventTimeTrigger
-
- clear(TimeWindow, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.ProcessingTimeTrigger
-
- clear(W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.PurgingTrigger
-
- clear(W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.Trigger
-
Clears any state that the trigger might still hold for the given window.
- clear(W, InternalWindowFunction.InternalWindowContext) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalAggregateProcessAllWindowFunction
-
- clear(W, InternalWindowFunction.InternalWindowContext) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalAggregateProcessWindowFunction
-
- clear(W, InternalWindowFunction.InternalWindowContext) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableAllWindowFunction
-
- clear(W, InternalWindowFunction.InternalWindowContext) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableProcessAllWindowFunction
-
- clear(W, InternalWindowFunction.InternalWindowContext) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableProcessWindowFunction
-
- clear(W, InternalWindowFunction.InternalWindowContext) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableWindowFunction
-
- clear(W, InternalWindowFunction.InternalWindowContext) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueAllWindowFunction
-
- clear(W, InternalWindowFunction.InternalWindowContext) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueProcessAllWindowFunction
-
- clear(W, InternalWindowFunction.InternalWindowContext) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueProcessWindowFunction
-
- clear(W, InternalWindowFunction.InternalWindowContext) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueWindowFunction
-
- clear(W, InternalWindowFunction.InternalWindowContext) - Method in interface org.apache.flink.streaming.runtime.operators.windowing.functions.InternalWindowFunction
-
Deletes any state in the Context
when the Window is purged.
- clear() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
-
- clear() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.WindowContext
-
- clear() - Method in class org.apache.flink.types.ListValue
-
- clear() - Method in class org.apache.flink.types.MapValue
-
- clear() - Method in class org.apache.flink.types.Record
-
Clears the record.
- clear() - Method in class org.apache.flink.util.UnionIterator
-
- clear() - Method in class org.apache.hadoop.conf.Configuration
-
Clears all keys from the configuration.
- clearAll() - Method in class org.apache.flink.runtime.io.network.TaskEventDispatcher
-
Removes all registered event handlers.
- clearAllBroadcastVariables() - Method in class org.apache.flink.api.common.functions.util.RuntimeUDFContext
-
- clearAllBroadcastVariables() - Method in class org.apache.flink.runtime.operators.util.DistributedRuntimeUDFContext
-
- clearAllMemory(List<MemorySegment>) - Method in class org.apache.flink.runtime.operators.hash.HashPartition
-
- clearAllMemory(List<MemorySegment>) - Method in class org.apache.flink.runtime.operators.hash.InMemoryPartition
-
releases all of the partition's segments (pages and overflow buckets)
- clearAllMemory(List<MemorySegment>) - Method in class org.apache.flink.runtime.operators.hash.ReOpenableHashPartition
-
- clearBroadcastVariable(String) - Method in class org.apache.flink.api.common.functions.util.RuntimeUDFContext
-
- clearBroadcastVariable(String) - Method in class org.apache.flink.runtime.operators.util.DistributedRuntimeUDFContext
-
- clearBuffers() - Method in interface org.apache.flink.runtime.io.network.api.reader.MutableReader
-
- clearBuffers() - Method in class org.apache.flink.runtime.io.network.api.reader.MutableRecordReader
-
- clearBuffers() - Method in interface org.apache.flink.runtime.io.network.api.reader.Reader
-
- clearBuffers() - Method in class org.apache.flink.runtime.io.network.api.reader.RecordReader
-
- clearBuffers() - Method in class org.apache.flink.runtime.io.network.api.writer.RecordWriter
-
- clearContainerMappingMarkedFields() - Method in class org.apache.flink.api.java.sca.TaggedValue
-
- clearFirstInput() - Method in class org.apache.flink.api.common.operators.DualInputOperator
-
Clears this operator's first input.
- clearInputs() - Method in class org.apache.flink.api.common.operators.SingleInputOperator
-
Removes all inputs.
- clearInterestingProperties() - Method in class org.apache.flink.optimizer.dag.BulkIterationNode
-
- clearInterestingProperties() - Method in class org.apache.flink.optimizer.dag.DagConnection
-
- clearInterestingProperties() - Method in class org.apache.flink.optimizer.dag.OptimizerNode
-
- clearInterestingProperties() - Method in class org.apache.flink.optimizer.dag.WorksetIterationNode
-
- clearJob(JobID) - Method in class org.apache.flink.runtime.highavailability.FsNegativeRunningJobsRegistry
-
- clearJob(JobID) - Method in class org.apache.flink.runtime.highavailability.nonha.standalone.StandaloneRunningJobsRegistry
-
- clearJob(JobID) - Method in interface org.apache.flink.runtime.highavailability.RunningJobsRegistry
-
Clear job state form the registry, usually called after job finish.
- clearJob(JobID) - Method in class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperRunningJobsRegistry
-
- clearPartitions() - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
-
This method clears all partitions currently residing (partially) in memory.
- clearPendingSlotRequest() - Method in class org.apache.flink.runtime.clusterframework.types.TaskManagerSlot
-
- clearReaders(MutableReader<?>[]) - Static method in class org.apache.flink.runtime.operators.BatchTask
-
- clearSecondInput() - Method in class org.apache.flink.api.common.operators.DualInputOperator
-
Clears this operator's second input.
- clearStateAsync() - Method in class org.apache.flink.mesos.runtime.clusterframework.MesosResourceManager
-
- clearStateAsync() - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
-
This method can be overridden to add a (non-blocking) state clearing routine to the
ResourceManager that will be called when leadership is revoked.
- clearTaskAssignment() - Method in class org.apache.flink.runtime.jobmanager.scheduler.SlotSharingGroup
-
- clearTerminal() - Method in class org.apache.flink.table.client.cli.CliClient
-
- clearUniqueFieldCombinations() - Method in class org.apache.flink.optimizer.dataproperties.GlobalProperties
-
- clearUniqueFields() - Method in class org.apache.flink.api.common.operators.CompilerHints
-
- clearUniqueFieldSets() - Method in class org.apache.flink.optimizer.dataproperties.LocalProperties
-
- clearWriters(List<RecordWriter<?>>) - Static method in class org.apache.flink.runtime.operators.BatchTask
-
- CLI_NAME - Static variable in class org.apache.flink.table.client.cli.CliStrings
-
- CliArgsException - Exception in org.apache.flink.client.cli
-
Special exception that is thrown when the command line parsing fails.
- CliArgsException(String) - Constructor for exception org.apache.flink.client.cli.CliArgsException
-
- CliArgsException(String, Throwable) - Constructor for exception org.apache.flink.client.cli.CliArgsException
-
- CliChangelogResultView - Class in org.apache.flink.table.client.cli
-
CLI view for retrieving and displaying a changelog stream.
- CliChangelogResultView(CliClient, ResultDescriptor) - Constructor for class org.apache.flink.table.client.cli.CliChangelogResultView
-
- CliChangelogResultView.ResultChangelogOperation - Enum in org.apache.flink.table.client.cli
-
Available operations for this view.
- CliClient - Class in org.apache.flink.table.client.cli
-
SQL CLI client.
- CliClient(SessionContext, Executor) - Constructor for class org.apache.flink.table.client.cli.CliClient
-
- client - Variable in class org.apache.flink.client.program.ContextEnvironment
-
- Client<REQ extends MessageBody,RESP extends MessageBody> - Class in org.apache.flink.queryablestate.network
-
The base class for every client in the queryable state module.
- Client(String, int, MessageSerializer<REQ, RESP>, KvStateRequestStats) - Constructor for class org.apache.flink.queryablestate.network.Client
-
Creates a client with the specified number of event loop threads.
- client - Variable in class org.apache.flink.runtime.client.JobClientActor
-
The client which the actor is responsible for
- client - Variable in class org.apache.flink.table.client.cli.CliView
-
- CLIENT_BUFFER_SIZE - Static variable in class org.apache.flink.streaming.connectors.twitter.TwitterSource
-
- CLIENT_CONNECT_TIMEOUT_SECONDS - Static variable in class org.apache.flink.runtime.io.network.netty.NettyConfig
-
- CLIENT_HOSTS - Static variable in class org.apache.flink.streaming.connectors.twitter.TwitterSource
-
- CLIENT_MAX_CONTENT_LENGTH - Static variable in class org.apache.flink.configuration.RestOptions
-
The maximum content length that the client will handle.
- CLIENT_NAME - Static variable in class org.apache.flink.streaming.connectors.twitter.TwitterSource
-
- CLIENT_NETWORK_THREADS - Static variable in class 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 - Static variable in class org.apache.flink.configuration.AkkaOptions
-
- CLIENT_SOCKET_WORKER_POOL_SIZE_MAX - Static variable in class org.apache.flink.configuration.AkkaOptions
-
- CLIENT_SOCKET_WORKER_POOL_SIZE_MIN - Static variable in class org.apache.flink.configuration.AkkaOptions
-
- CLIENT_TIMEOUT - Static variable in class org.apache.flink.configuration.AkkaOptions
-
Timeout for all blocking calls on the client side.
- clientConfiguration - Variable in class org.apache.flink.api.java.RemoteEnvironment
-
The configuration used by the client that connects to the cluster.
- ClientHandler<REQ extends MessageBody,RESP extends MessageBody> - Class in org.apache.flink.queryablestate.network
-
The handler used by a
Client
to handling incoming messages.
- ClientHandler(String, MessageSerializer<REQ, RESP>, ClientHandlerCallback<RESP>) - Constructor for class org.apache.flink.queryablestate.network.ClientHandler
-
Creates a handler with the callback.
- ClientHandlerCallback<RESP extends MessageBody> - Interface in org.apache.flink.queryablestate.network
-
- ClientUtils - Class in org.apache.flink.client
-
A class that provides some utility methods.
- ClientUtils() - Constructor for class org.apache.flink.client.ClientUtils
-
- CliFrontend - Class in org.apache.flink.client.cli
-
Implementation of a simple command line frontend for executing programs.
- CliFrontend(Configuration, List<CustomCommandLine<?>>) - Constructor for class org.apache.flink.client.cli.CliFrontend
-
- CliFrontendParser - Class in org.apache.flink.client.cli
-
A simple command line parser (based on Apache Commons CLI) that extracts command
line options.
- CliFrontendParser() - Constructor for class org.apache.flink.client.cli.CliFrontendParser
-
- CliInputView - Class in org.apache.flink.table.client.cli
-
CLI view for entering a string.
- CliInputView(CliClient, String, Function<String, Boolean>) - Constructor for class org.apache.flink.table.client.cli.CliInputView
-
- CliInputView.InputOperation - Enum in org.apache.flink.table.client.cli
-
Available operations for this view.
- CliOptions - Class in org.apache.flink.table.client.cli
-
Command line options to configure the SQL client.
- CliOptions(boolean, String, URL, URL, List<URL>, List<URL>) - Constructor for class org.apache.flink.table.client.cli.CliOptions
-
- CliOptionsParser - Class in org.apache.flink.table.client.cli
-
Parser for command line options.
- CliOptionsParser() - Constructor for class org.apache.flink.table.client.cli.CliOptionsParser
-
- CliResultView<O extends Enum<O>> - Class in org.apache.flink.table.client.cli
-
Abstract CLI view for showing results (either as changelog or table).
- CliResultView(CliClient, ResultDescriptor) - Constructor for class org.apache.flink.table.client.cli.CliResultView
-
- CliRowView - Class in org.apache.flink.table.client.cli
-
CLI view for visualizing a row.
- CliRowView(CliClient, String[], String[], String[]) - Constructor for class org.apache.flink.table.client.cli.CliRowView
-
- CliRowView.RowOperation - Enum in org.apache.flink.table.client.cli
-
Available operations for this view.
- CliStrings - Class in org.apache.flink.table.client.cli
-
Utility class that contains all strings for CLI commands and messages.
- CliTableResultView - Class in org.apache.flink.table.client.cli
-
CLI view for retrieving and displaying a table.
- CliTableResultView(CliClient, ResultDescriptor) - Constructor for class org.apache.flink.table.client.cli.CliTableResultView
-
- CliTableResultView.ResultTableOperation - Enum in org.apache.flink.table.client.cli
-
Available operations for this view.
- CliUtils - Class in org.apache.flink.table.client.cli
-
Utilities for CLI formatting.
- CliView<OP extends Enum<OP>,OUT> - Class in org.apache.flink.table.client.cli
-
Framework for a CLI view with header, footer, and main part that is scrollable.
- CliView(CliClient) - Constructor for class org.apache.flink.table.client.cli.CliView
-
- Clock - Class in org.apache.flink.runtime.util.clock
-
A clock that gives access to time.
- Clock() - Constructor for class org.apache.flink.runtime.util.clock.Clock
-
- Clock - Interface in org.apache.flink.streaming.connectors.fs
-
A clock that can provide the current time.
- clone() - Method in interface org.apache.flink.api.common.accumulators.Accumulator
-
Duplicates the accumulator.
- clone() - Method in class org.apache.flink.api.common.accumulators.AverageAccumulator
-
- clone() - Method in class org.apache.flink.api.common.accumulators.DoubleCounter
-
- clone() - Method in class org.apache.flink.api.common.accumulators.DoubleMaximum
-
- clone() - Method in class org.apache.flink.api.common.accumulators.DoubleMinimum
-
- clone() - Method in class org.apache.flink.api.common.accumulators.Histogram
-
- clone() - Method in class org.apache.flink.api.common.accumulators.IntCounter
-
- clone() - Method in class org.apache.flink.api.common.accumulators.IntMaximum
-
- clone() - Method in class org.apache.flink.api.common.accumulators.IntMinimum
-
- clone() - Method in class org.apache.flink.api.common.accumulators.ListAccumulator
-
- clone() - Method in class org.apache.flink.api.common.accumulators.LongCounter
-
- clone() - Method in class org.apache.flink.api.common.accumulators.LongMaximum
-
- clone() - Method in class org.apache.flink.api.common.accumulators.LongMinimum
-
- clone() - Method in class org.apache.flink.api.common.accumulators.SerializedListAccumulator
-
- clone() - Method in class org.apache.flink.api.common.operators.Ordering
-
- clone() - Method in class org.apache.flink.api.common.operators.util.FieldSet
-
Since instances of FieldSet are strictly immutable, this method does not actually clone,
but it only returns the original instance.
- clone() - Method in class org.apache.flink.api.java.Utils.ChecksumHashCode
-
- clone() - Method in class org.apache.flink.api.java.utils.ParameterTool
-
- clone() - Method in class org.apache.flink.configuration.Configuration
-
- clone() - Method in class org.apache.flink.configuration.DelegatingConfiguration
-
- clone() - Method in class org.apache.flink.examples.java.relational.EmptyFieldsCountAccumulator.VectorAccumulator
-
- clone() - Method in class org.apache.flink.graph.asm.dataset.ChecksumHashCode.Checksum
-
- clone() - Method in class org.apache.flink.optimizer.costs.Costs
-
- clone() - Method in class org.apache.flink.optimizer.dataproperties.GlobalProperties
-
- clone() - Method in class org.apache.flink.optimizer.dataproperties.InterestingProperties
-
- clone() - Method in class org.apache.flink.optimizer.dataproperties.LocalProperties
-
- clone() - Method in class org.apache.flink.optimizer.dataproperties.RequestedGlobalProperties
-
- clone() - Method in class org.apache.flink.optimizer.dataproperties.RequestedLocalProperties
-
- clone() - Method in class org.apache.flink.optimizer.plan.Channel
-
- clone() - Method in class org.apache.flink.runtime.clusterframework.ContainerSpecification
-
- clone(T) - Static method in class org.apache.flink.util.InstantiationUtil
-
Clones the given serializable object using Java serialization.
- clone(T, ClassLoader) - Static method in class org.apache.flink.util.InstantiationUtil
-
Clones the given serializable object using Java serialization, using the given classloader to
resolve the cloned classes.
- cloneConfiguration(Configuration) - Static method in class org.apache.flink.runtime.clusterframework.BootstrapTools
-
Clones the given configuration and resets instance specific config options.
- ClosableBlockingQueue<E> - Class in org.apache.flink.streaming.connectors.kafka.internals
-
A special form of blocking queue with two additions:
The queue can be closed atomically when empty.
- ClosableBlockingQueue() - Constructor for class org.apache.flink.streaming.connectors.kafka.internals.ClosableBlockingQueue
-
Creates a new empty queue.
- ClosableBlockingQueue(int) - Constructor for class org.apache.flink.streaming.connectors.kafka.internals.ClosableBlockingQueue
-
Creates a new empty queue, reserving space for at least the specified number
of elements.
- ClosableBlockingQueue(Collection<? extends E>) - Constructor for class org.apache.flink.streaming.connectors.kafka.internals.ClosableBlockingQueue
-
Creates a new queue that contains the given elements.
- close() - Method in class org.apache.flink.addons.hbase.AbstractTableInputFormat
-
- close() - Method in class org.apache.flink.api.common.functions.AbstractRichFunction
-
- close() - Method in interface org.apache.flink.api.common.functions.RichFunction
-
Tear-down method for the user code.
- close() - Method in class org.apache.flink.api.common.functions.util.CopyingListCollector
-
- close() - Method in class org.apache.flink.api.common.functions.util.ListCollector
-
- close() - Method in class org.apache.flink.api.common.io.BinaryOutputFormat.BlockBasedOutput
-
- close() - Method in class org.apache.flink.api.common.io.BinaryOutputFormat
-
- close() - Method in class org.apache.flink.api.common.io.DelimitedInputFormat
-
Closes the input by releasing all buffers and closing the file input stream.
- close() - Method in class org.apache.flink.api.common.io.FileInputFormat
-
Closes the file input stream of the input format.
- close() - Method in class org.apache.flink.api.common.io.FileOutputFormat
-
- close() - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
-
- close() - Method in class org.apache.flink.api.common.io.GenericInputFormat
-
- close() - Method in interface org.apache.flink.api.common.io.InputFormat
-
Method that marks the end of the life-cycle of an input split.
- close() - Method in class org.apache.flink.api.common.io.InputStreamFSInputWrapper
-
- close() - Method in interface org.apache.flink.api.common.io.OutputFormat
-
Method that marks the end of the life-cycle of parallel output instance.
- close() - Method in class org.apache.flink.api.common.io.ReplicatingInputFormat
-
- close() - Method in class org.apache.flink.api.java.hadoop.mapred.HadoopInputFormatBase
-
- close() - Method in class org.apache.flink.api.java.hadoop.mapred.HadoopOutputFormatBase
-
commit the task by moving the output file out from the temporary directory.
- close() - Method in class org.apache.flink.api.java.hadoop.mapreduce.HadoopInputFormatBase
-
- close() - Method in class org.apache.flink.api.java.hadoop.mapreduce.HadoopOutputFormatBase
-
commit the task by moving the output file out from the temporary directory.
- close() - Method in class org.apache.flink.api.java.io.CsvOutputFormat
-
- close() - Method in class org.apache.flink.api.java.io.DiscardingOutputFormat
-
- close() - Method in class org.apache.flink.api.java.io.jdbc.JDBCInputFormat
-
Closes all resources used.
- close() - Method in class org.apache.flink.api.java.io.jdbc.JDBCOutputFormat
-
Executes prepared statement and closes all resources of this instance.
- close() - Method in class org.apache.flink.api.java.io.LocalCollectionOutputFormat
-
- close() - Method in class org.apache.flink.api.java.io.PrintingOutputFormat
-
- close() - Method in class org.apache.flink.api.java.operators.translation.Tuple3WrappingCollector
-
- close() - Method in class org.apache.flink.api.java.operators.translation.TupleWrappingCollector
-
- close() - Method in class org.apache.flink.api.java.operators.translation.WrappingFunction
-
- close() - Method in class org.apache.flink.api.java.Utils.ChecksumHashCodeHelper
-
- close() - Method in class org.apache.flink.api.java.Utils.CollectHelper
-
- close() - Method in class org.apache.flink.api.java.Utils.CountHelper
-
- close() - Method in class org.apache.flink.api.scala.operators.ScalaCsvOutputFormat
-
- close() - Method in class org.apache.flink.batch.connectors.cassandra.CassandraInputFormat
-
Closes all resources used.
- close() - Method in class org.apache.flink.batch.connectors.cassandra.CassandraOutputFormatBase
-
Closes all resources used.
- close() - Method in class org.apache.flink.batch.tests.DataSetAllroundTestProgram.Generator
-
- close() - Method in class org.apache.flink.cep.operator.TimestampedSideOutputCollector
-
- close() - Method in class org.apache.flink.client.deployment.LegacyStandaloneClusterDescriptor
-
- close() - Method in class org.apache.flink.client.deployment.StandaloneClusterDescriptor
-
- close() - Method in class org.apache.flink.contrib.streaming.state.RocksDBWriteBatchWrapper
-
- close() - Method in class org.apache.flink.contrib.streaming.state.RocksIteratorWrapper
-
- close() - Method in class org.apache.flink.core.fs.AbstractMultiFSDataInputStream
-
- close() - Method in class org.apache.flink.core.fs.ClosingFSDataInputStream
-
- close() - Method in class org.apache.flink.core.fs.ClosingFSDataOutputStream
-
- close() - Method in class org.apache.flink.core.fs.FSDataInputStreamWrapper
-
- close() - Method in class org.apache.flink.core.fs.FSDataOutputStream
-
Closes the output stream.
- close() - Method in class org.apache.flink.core.fs.FSDataOutputStreamWrapper
-
- close() - Method in class org.apache.flink.core.fs.local.LocalDataInputStream
-
- close() - Method in class org.apache.flink.core.fs.local.LocalDataOutputStream
-
- close() - Method in class org.apache.flink.core.fs.SafetyNetCloseableRegistry
-
- close() - Method in class org.apache.flink.core.memory.ByteArrayInputStreamWithPos
-
- close() - Method in class org.apache.flink.core.memory.ByteArrayOutputStreamWithPos
-
- close() - Method in class org.apache.flink.dropwizard.ScheduledDropwizardReporter
-
- close() - Method in class org.apache.flink.examples.java.distcp.FileCopyTaskInputFormat
-
- close() - Method in class org.apache.flink.formats.avro.AvroOutputFormat
-
- close() - Method in class org.apache.flink.formats.avro.utils.FSDataInputStreamWrapper
-
- close() - Method in class org.apache.flink.hcatalog.HCatInputFormatBase
-
- close(boolean) - Method in class org.apache.flink.mesos.runtime.clusterframework.services.AbstractMesosServices
-
- close(boolean) - Method in interface org.apache.flink.mesos.runtime.clusterframework.services.MesosServices
-
Closes all state maintained by the mesos services implementation.
- close(boolean) - Method in class org.apache.flink.mesos.runtime.clusterframework.services.StandaloneMesosServices
-
- close(boolean) - Method in class org.apache.flink.mesos.runtime.clusterframework.services.ZooKeeperMesosServices
-
- close() - Method in class org.apache.flink.metrics.datadog.DatadogHttpClient
-
- close() - Method in class org.apache.flink.metrics.datadog.DatadogHttpReporter
-
- close() - Method in class org.apache.flink.metrics.jmx.JMXReporter
-
- close() - Method in class org.apache.flink.metrics.prometheus.PrometheusReporter
-
- close() - Method in interface org.apache.flink.metrics.reporter.MetricReporter
-
Closes this reporter.
- close() - Method in class org.apache.flink.metrics.slf4j.Slf4jReporter
-
- close() - Method in class org.apache.flink.metrics.statsd.StatsDReporter
-
- close() - Method in class org.apache.flink.networking.NetworkFailuresProxy
-
- close() - Method in class org.apache.flink.orc.OrcRowInputFormat
-
- close() - Method in class org.apache.flink.python.api.functions.PythonCoGroup
-
Closes this function.
- close() - Method in class org.apache.flink.python.api.functions.PythonMapPartition
-
Closes this function.
- close() - Method in class org.apache.flink.python.api.streaming.data.PythonReceiver
-
- close() - Method in class org.apache.flink.python.api.streaming.data.PythonSender
-
- close() - Method in class org.apache.flink.python.api.streaming.data.PythonStreamer
-
Closes this streamer.
- close() - Method in class org.apache.flink.python.api.streaming.plan.PythonPlanStreamer
-
- close() - Method in class org.apache.flink.queryablestate.network.ChunkedByteBuf
-
- close() - Method in class org.apache.flink.runtime.blob.AbstractBlobCache
-
- close() - Method in class org.apache.flink.runtime.blob.BlobCacheService
-
- close() - Method in class org.apache.flink.runtime.blob.BlobClient
-
- close() - Method in class org.apache.flink.runtime.blob.BlobServer
-
Shuts down the BLOB server.
- close() - Method in class org.apache.flink.runtime.blob.FileSystemBlobStore
-
- close() - Method in class org.apache.flink.runtime.blob.VoidBlobStore
-
- close(Collection<MasterTriggerRestoreHook<?>>, Logger) - Static method in class org.apache.flink.runtime.checkpoint.hooks.MasterHooks
-
Closes the master hooks.
- close() - Method in interface org.apache.flink.runtime.checkpoint.MasterTriggerRestoreHook
-
Tear-down method for the hook.
- close() - Method in class org.apache.flink.runtime.dispatcher.FileArchivedExecutionGraphStore
-
- close() - Method in class org.apache.flink.runtime.dispatcher.MemoryArchivedExecutionGraphStore
-
- close() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopDataInputStream
-
- close() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopDataOutputStream
-
- close() - Method in interface org.apache.flink.runtime.highavailability.HighAvailabilityServices
-
Closes the high availability services, releasing all resources.
- close() - Method in class org.apache.flink.runtime.highavailability.nonha.AbstractNonHaServices
-
- close() - Method in class org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedHaServices
-
- close() - Method in class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperHaServices
-
- close() - Method in class org.apache.flink.runtime.io.disk.FileChannelInputView
-
- close() - Method in class org.apache.flink.runtime.io.disk.FileChannelOutputView
-
Closes this output, writing pending data and releasing the memory.
- close() - Method in class org.apache.flink.runtime.io.disk.iomanager.AbstractFileIOChannel
-
- close() - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousFileIOChannel
-
Closes the channel and waits until all pending asynchronous requests are processed.
- close() - Method in class org.apache.flink.runtime.io.disk.iomanager.ChannelReaderInputView
-
Closes this InputView, closing the underlying reader and returning all memory segments.
- close() - Method in class org.apache.flink.runtime.io.disk.iomanager.ChannelWriterOutputView
-
Closes this OutputView, closing the underlying writer and returning all memory segments.
- close() - Method in interface org.apache.flink.runtime.io.disk.iomanager.FileIOChannel
-
Closes the channel.
- close() - Method in class org.apache.flink.runtime.io.disk.iomanager.RequestQueue
-
Closes this request queue.
- close() - Method in class org.apache.flink.runtime.io.disk.iomanager.SynchronousFileIOChannel
-
- close() - Method in class org.apache.flink.runtime.io.disk.SeekableFileChannelInputView
-
- close() - Method in class org.apache.flink.runtime.io.disk.SpillingBuffer
-
- close() - Method in class org.apache.flink.runtime.io.network.buffer.BufferConsumer
-
- close(RemoteInputChannel) - Method in class org.apache.flink.runtime.io.network.netty.PartitionRequestClient
-
- close() - Method in class org.apache.flink.runtime.iterative.io.SerializedUpdateBuffer
-
- close() - Method in class org.apache.flink.runtime.iterative.io.SolutionSetFastUpdateOutputCollector
-
- close() - Method in class org.apache.flink.runtime.iterative.io.SolutionSetObjectsUpdateOutputCollector
-
- close() - Method in class org.apache.flink.runtime.iterative.io.SolutionSetUpdateOutputCollector
-
- close() - Method in class org.apache.flink.runtime.iterative.io.WorksetUpdateOutputCollector
-
- close() - Method in class org.apache.flink.runtime.metrics.dump.MetricDumpSerialization.MetricDumpSerializer
-
- close() - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
-
- close() - Method in class org.apache.flink.runtime.metrics.groups.ComponentMetricGroup
-
Closes the component group by removing and closing all metrics and subgroups
(inherited from
AbstractMetricGroup
), plus closing and removing all dedicated
component subgroups.
- close() - Method in class org.apache.flink.runtime.metrics.groups.TaskMetricGroup
-
- close() - Method in class org.apache.flink.runtime.operators.chaining.ChainedAllReduceDriver
-
- close() - Method in class org.apache.flink.runtime.operators.chaining.ChainedFlatMapDriver
-
- close() - Method in class org.apache.flink.runtime.operators.chaining.ChainedMapDriver
-
- close() - Method in class org.apache.flink.runtime.operators.chaining.ChainedReduceCombineDriver
-
- close() - Method in class org.apache.flink.runtime.operators.chaining.ChainedTerminationCriterionDriver
-
- close() - Method in class org.apache.flink.runtime.operators.chaining.GroupCombineChainedDriver
-
- close() - Method in class org.apache.flink.runtime.operators.chaining.SynchronousChainedCombineDriver
-
- close() - Method in class org.apache.flink.runtime.operators.hash.AbstractMutableHashTable
-
Closes the hash table.
- close() - Method in class org.apache.flink.runtime.operators.hash.CompactingHashTable
-
Closes the hash table.
- close() - Method in class org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable
-
- close() - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
-
Closes the hash table.
- close() - Method in class org.apache.flink.runtime.operators.hash.NonReusingBuildFirstHashJoinIterator
-
- close() - Method in class org.apache.flink.runtime.operators.hash.NonReusingBuildSecondHashJoinIterator
-
- close() - Method in class org.apache.flink.runtime.operators.hash.ReOpenableMutableHashTable
-
- close() - Method in class org.apache.flink.runtime.operators.hash.ReusingBuildFirstHashJoinIterator
-
- close() - Method in class org.apache.flink.runtime.operators.hash.ReusingBuildSecondHashJoinIterator
-
- close() - Method in class org.apache.flink.runtime.operators.NoOpChainedDriver
-
- close() - Method in class org.apache.flink.runtime.operators.resettable.BlockResettableMutableObjectIterator
-
- close() - Method in class org.apache.flink.runtime.operators.resettable.NonReusingBlockResettableIterator
-
- close() - Method in class org.apache.flink.runtime.operators.resettable.SpillingResettableIterator
-
- close() - Method in class org.apache.flink.runtime.operators.resettable.SpillingResettableMutableObjectIterator
-
- close() - Method in class org.apache.flink.runtime.operators.shipping.OutputCollector
-
- close() - Method in class org.apache.flink.runtime.operators.sort.AbstractMergeIterator
-
- close() - Method in class org.apache.flink.runtime.operators.sort.LargeRecordHandler
-
Closes all structures and deletes all temporary files.
- close() - Method in class org.apache.flink.runtime.operators.sort.NonReusingSortMergeCoGroupIterator
-
- close() - Method in class org.apache.flink.runtime.operators.sort.ReusingSortMergeCoGroupIterator
-
- close() - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger
-
Shuts down all the threads initiated by this sort/merger.
- close() - Method in class org.apache.flink.runtime.operators.TempBarrier
-
- close() - Method in interface org.apache.flink.runtime.operators.util.CoGroupTaskIterator
-
General-purpose close method.
- close() - Method in interface org.apache.flink.runtime.operators.util.JoinTaskIterator
-
General-purpose close method.
- close() - Method in class org.apache.flink.runtime.operators.util.metrics.CountingCollector
-
- close() - Method in class org.apache.flink.runtime.operators.util.SimpleCloseableInputProvider
-
- close() - Method in class org.apache.flink.runtime.registration.RegisteredRpcConnection
-
Close connection.
- close() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
-
Closes the slot manager.
- close() - Method in class org.apache.flink.runtime.rest.handler.FileUploads
-
- close() - Method in class org.apache.flink.runtime.rest.handler.legacy.ExecutionGraphCache
-
- close() - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
-
- close() - Method in class org.apache.flink.runtime.state.BoundedInputStream
-
- close() - Method in class org.apache.flink.runtime.state.CheckpointMetadataOutputStream
-
This method should close the stream, if has not been closed before.
- close() - Method in class org.apache.flink.runtime.state.CheckpointStreamFactory.CheckpointStateOutputStream
-
This method should close the stream, if has not been closed before.
- close() - Method in interface org.apache.flink.runtime.state.CheckpointStreamWithResultProvider
-
- close() - Method in class org.apache.flink.runtime.state.DefaultOperatorStateBackend
-
- close() - Method in class org.apache.flink.runtime.state.DuplicatingCheckpointOutputStream
-
- close() - Method in class org.apache.flink.runtime.state.filesystem.FileBasedStateOutputStream
-
- close() - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointMetadataOutputStream
-
- close() - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStreamFactory.FsCheckpointStateOutputStream
-
If the stream is only closed, we remove the produced file (cleanup through the auto close
feature, for example).
- close() - Method in class org.apache.flink.runtime.state.KeyedStateCheckpointOutputStream
-
- close() - Method in class org.apache.flink.runtime.state.memory.MemCheckpointStreamFactory.MemoryCheckpointOutputStream
-
- close() - Method in class org.apache.flink.runtime.state.NonClosingCheckpointOutputStream
-
- close() - Method in class org.apache.flink.runtime.state.RetrievableStreamStateHandle
-
- close() - Method in class org.apache.flink.runtime.state.SharedStateRegistry
-
- close() - Method in class org.apache.flink.runtime.state.StateSnapshotContextSynchronousImpl
-
- close() - Method in class org.apache.flink.runtime.util.ForwardingInputStream
-
- close() - Method in class org.apache.flink.runtime.util.ForwardingOutputStream
-
- close() - Method in class org.apache.flink.runtime.util.NonClosingInputStreamDecorator
-
- close() - Method in class org.apache.flink.runtime.util.NonClosingOutpusStreamDecorator
-
- close() - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperSharedCount
-
- close() - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperSharedValue
-
- close(boolean) - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperUtilityFactory
-
Closes the ZooKeeperUtilityFactory.
- close() - Method in class org.apache.flink.storm.util.AbstractLineSpout
-
- close() - Method in class org.apache.flink.storm.util.FileSpout
-
- close() - Method in class org.apache.flink.storm.util.NullTerminatingSpout
-
- close() - Method in class org.apache.flink.storm.wrappers.SpoutWrapper
-
- close() - Method in class org.apache.flink.streaming.api.collector.selector.DirectedOutput
-
- close() - Method in class org.apache.flink.streaming.api.functions.sink.OutputFormatSinkFunction
-
Deprecated.
- close() - Method in class org.apache.flink.streaming.api.functions.sink.PrintSinkFunction
-
- close() - Method in class org.apache.flink.streaming.api.functions.sink.SocketClientSink
-
Closes the connection with the Socket server.
- close() - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
-
- close() - Method in class org.apache.flink.streaming.api.functions.source.ContinuousFileMonitoringFunction
-
- close() - Method in class org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperator
-
- close() - Method in class org.apache.flink.streaming.api.functions.source.InputFormatSourceFunction
-
- close() - Method in class org.apache.flink.streaming.api.functions.source.MessageAcknowledgingSourceBase
-
- close() - Method in class org.apache.flink.streaming.api.functions.source.MultipleIdsMessageAcknowledgingSourceBase
-
- close() - Method in interface org.apache.flink.streaming.api.functions.source.SourceFunction.SourceContext
-
This method is called by the system to shut down the context.
- close() - Method in class org.apache.flink.streaming.api.functions.windowing.FoldApplyProcessAllWindowFunction
-
Deprecated.
- close() - Method in class org.apache.flink.streaming.api.functions.windowing.FoldApplyProcessWindowFunction
-
Deprecated.
- close() - Method in class org.apache.flink.streaming.api.functions.windowing.ReduceApplyProcessAllWindowFunction
-
- close() - Method in class org.apache.flink.streaming.api.functions.windowing.ReduceApplyProcessWindowFunction
-
- close() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- close() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator.CountingOutput
-
- close() - Method in class org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
-
- close() - Method in class org.apache.flink.streaming.api.operators.async.AsyncWaitOperator
-
- close() - Method in interface org.apache.flink.streaming.api.operators.StreamOperator
-
- close() - Method in class org.apache.flink.streaming.api.operators.TimestampedCollector
-
- close() - Method in class org.apache.flink.streaming.connectors.cassandra.CassandraCommitter
-
- close() - Method in class org.apache.flink.streaming.connectors.cassandra.CassandraRowWriteAheadSink
-
- close() - Method in class org.apache.flink.streaming.connectors.cassandra.CassandraSinkBase
-
- close() - Method in class org.apache.flink.streaming.connectors.cassandra.CassandraTupleWriteAheadSink
-
- close() - Method in class org.apache.flink.streaming.connectors.elasticsearch.ElasticsearchSinkBase
-
- close() - Method in class org.apache.flink.streaming.connectors.fs.AvroKeyValueSinkWriter
-
- close() - Method in class org.apache.flink.streaming.connectors.fs.bucketing.BucketingSink
-
- close() - Method in class org.apache.flink.streaming.connectors.fs.RollingSink
-
Deprecated.
- close() - Method in class org.apache.flink.streaming.connectors.fs.SequenceFileWriter
-
- close() - Method in class org.apache.flink.streaming.connectors.fs.StreamWriterBase
-
- close() - Method in interface org.apache.flink.streaming.connectors.fs.Writer
-
Closes the Writer
.
- close() - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumerBase
-
- close() - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer011
-
- close() - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducerBase
-
- close() - Method in class org.apache.flink.streaming.connectors.kafka.internal.FlinkKafkaProducer
-
- close(long, TimeUnit) - Method in class org.apache.flink.streaming.connectors.kafka.internal.FlinkKafkaProducer
-
- close() - Method in class org.apache.flink.streaming.connectors.kafka.internal.Handover
-
Closes the handover.
- close() - Method in class org.apache.flink.streaming.connectors.kafka.internals.AbstractPartitionDiscoverer
-
Closes the partition discoverer, cleaning up all Kafka connections.
- close() - Method in class org.apache.flink.streaming.connectors.kafka.internals.ClosableBlockingQueue
-
Tries to close the queue.
- close() - Method in class org.apache.flink.streaming.connectors.kafka.internals.ZookeeperOffsetHandler
-
Closes the offset handler.
- close() - Method in class org.apache.flink.streaming.connectors.nifi.NiFiSink
-
- close() - Method in class org.apache.flink.streaming.connectors.nifi.NiFiSource
-
- close() - Method in class org.apache.flink.streaming.connectors.rabbitmq.RMQSink
-
- close() - Method in class org.apache.flink.streaming.connectors.rabbitmq.RMQSource
-
- close() - Method in class org.apache.flink.streaming.connectors.twitter.TwitterSource
-
- close() - Method in class org.apache.flink.streaming.experimental.CollectSink
-
Closes the connection with the Socket server.
- close() - Method in class org.apache.flink.streaming.experimental.SocketStreamIterator
-
- close() - Method in class org.apache.flink.streaming.python.api.functions.AbstractPythonUDF
-
- close() - Method in class org.apache.flink.streaming.python.api.functions.PythonIteratorFunction
-
- close() - Method in class org.apache.flink.streaming.python.util.PythonCollector
-
- close() - Method in interface org.apache.flink.streaming.runtime.io.BufferBlocker
-
Cleans up all the resources in the current sequence.
- close() - Method in class org.apache.flink.streaming.runtime.io.BufferSpiller
-
Deprecated.
Cleans up the current spilling channel and file.
- close() - Method in class org.apache.flink.streaming.runtime.io.CachedBufferBlocker
-
- close() - Method in class org.apache.flink.streaming.runtime.io.RecordWriterOutput
-
- close() - Method in class org.apache.flink.streaming.runtime.io.StreamRecordWriter
-
Closes the writer.
- close() - Method in class org.apache.flink.streaming.runtime.operators.CheckpointCommitter
-
Closes the resource/connection to it.
- close() - Method in class org.apache.flink.streaming.runtime.operators.GenericWriteAheadSink
-
- close() - Method in class org.apache.flink.streaming.runtime.operators.TimestampsAndPeriodicWatermarksOperator
-
- close() - Method in class org.apache.flink.streaming.runtime.operators.windowing.EvictingWindowOperator
-
- close() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
- close() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask.AsyncCheckpointRunnable
-
- close() - Method in class org.apache.flink.table.client.cli.CliView
-
- close(SqlExecutionException) - Method in class org.apache.flink.table.client.cli.CliView
-
- close(OUT) - Method in class org.apache.flink.table.client.cli.CliView
-
- close() - Method in class org.apache.flink.table.client.gateway.local.CollectStreamResult
-
- close() - Method in interface org.apache.flink.table.client.gateway.local.DynamicResult
-
Closes the retrieval and all involved threads.
- close() - Method in class org.apache.flink.util.AbstractCloseableRegistry
-
- close() - Method in interface org.apache.flink.util.AutoCloseableAsync
-
- close() - Method in class org.apache.flink.util.CloseableIterable.Empty
-
- close() - Method in interface org.apache.flink.util.Collector
-
Closes the collector.
- close() - Method in class org.apache.flink.util.ResourceGuard
-
Closed the resource guard.
- close() - Method in class org.apache.flink.util.ResourceGuard.Lease
-
- close() - Method in class org.apache.flink.yarn.AbstractYarnClusterDescriptor
-
- close() - Method in class org.apache.flink.yarn.cli.YarnApplicationStatusMonitor
-
- close() - Method in class org.apache.flink.yarn.highavailability.YarnHighAvailabilityServices
-
- close() - Method in class org.apache.flink.yarn.highavailability.YarnIntraNonHaMasterServices
-
- CLOSE_MUTEX - Static variable in class org.apache.flink.api.java.hadoop.mapred.HadoopOutputFormatBase
-
- CLOSE_MUTEX - Static variable in class org.apache.flink.api.java.hadoop.mapreduce.HadoopOutputFormatBase
-
- close_with(PythonDataStream<? extends DataStream<PyObject>>) - Method in class org.apache.flink.streaming.python.api.datastream.PythonIterativeStream
-
- CloseableInputProvider<E> - Interface in org.apache.flink.runtime.operators.util
-
Utility interface for a provider of an input that can be closed.
- CloseableIterable<T> - Interface in org.apache.flink.util
-
This interface represents an iterable that is also closeable.
- CloseableIterable.Empty<T> - Class in org.apache.flink.util
-
Empty iterator.
- CloseableRegistry - Class in org.apache.flink.core.fs
-
This class allows to register instances of
Closeable
, which are all closed if this registry is closed.
- CloseableRegistry() - Constructor for class org.apache.flink.core.fs.CloseableRegistry
-
- closeAll(Iterable<? extends AutoCloseable>) - Static method in class org.apache.flink.util.IOUtils
-
Closes all
AutoCloseable
objects in the parameter, suppressing exceptions.
- closeAllQuietly(Iterable<? extends AutoCloseable>) - Static method in class org.apache.flink.util.IOUtils
-
Closes all elements in the iterable with closeQuietly().
- closeAndCleanupAllData() - Method in interface org.apache.flink.runtime.blob.BlobStoreService
-
Closes and cleans up the store.
- closeAndCleanupAllData() - Method in class org.apache.flink.runtime.blob.FileSystemBlobStore
-
- closeAndCleanupAllData() - Method in class org.apache.flink.runtime.blob.VoidBlobStore
-
- closeAndCleanupAllData() - Method in interface org.apache.flink.runtime.highavailability.HighAvailabilityServices
-
Closes the high availability services (releasing all resources) and deletes
all data stored by these services in external stores.
- closeAndCleanupAllData() - Method in class org.apache.flink.runtime.highavailability.nonha.AbstractNonHaServices
-
- closeAndCleanupAllData() - Method in class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperHaServices
-
- closeAndCleanupAllData() - Method in class org.apache.flink.yarn.highavailability.YarnHighAvailabilityServices
-
- closeAndDelete() - Method in class org.apache.flink.runtime.io.disk.FileChannelInputView
-
- closeAndDelete() - Method in class org.apache.flink.runtime.io.disk.FileChannelOutputView
-
Closes this output, writing pending data and releasing the memory.
- closeAndDelete() - Method in class org.apache.flink.runtime.io.disk.iomanager.AbstractFileIOChannel
-
- closeAndDelete() - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousFileIOChannel
-
This method waits for all pending asynchronous requests to return.
- closeAndDelete() - Method in interface org.apache.flink.runtime.io.disk.iomanager.FileIOChannel
-
Closes the channel and deletes the underlying file.
- closeAndDelete() - Method in class org.apache.flink.runtime.io.disk.SeekableFileChannelInputView
-
- closeAndFinalizeCheckpoint() - Method in class org.apache.flink.runtime.state.CheckpointMetadataOutputStream
-
- closeAndFinalizeCheckpoint() - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointMetadataOutputStream
-
- closeAndFinalizeCheckpointStreamResult() - Method in interface org.apache.flink.runtime.state.CheckpointStreamWithResultProvider
-
Closes the stream ans returns a snapshot result with the stream handle(s).
- closeAndFinalizeCheckpointStreamResult() - Method in class org.apache.flink.runtime.state.CheckpointStreamWithResultProvider.PrimaryAndSecondaryStream
-
- closeAndFinalizeCheckpointStreamResult() - Method in class org.apache.flink.runtime.state.CheckpointStreamWithResultProvider.PrimaryStreamOnly
-
- closeAndGetBytes() - Method in class org.apache.flink.runtime.state.memory.MemCheckpointStreamFactory.MemoryCheckpointOutputStream
-
Closes the stream and returns the byte array containing the stream's data.
- closeAndGetHandle() - Method in class org.apache.flink.runtime.state.CheckpointStreamFactory.CheckpointStateOutputStream
-
Closes the stream and gets a state handle that can create an input stream
producing the data written to this stream.
- closeAndGetHandle() - Method in class org.apache.flink.runtime.state.DuplicatingCheckpointOutputStream
-
- closeAndGetHandle() - Method in class org.apache.flink.runtime.state.filesystem.FileBasedStateOutputStream
-
- closeAndGetHandle() - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStreamFactory.FsCheckpointStateOutputStream
-
- closeAndGetHandle() - Method in class org.apache.flink.runtime.state.memory.MemCheckpointStreamFactory.MemoryCheckpointOutputStream
-
- closeAndGetPrimaryHandle() - Method in class org.apache.flink.runtime.state.DuplicatingCheckpointOutputStream
-
- closeAndGetSecondaryHandle() - Method in class org.apache.flink.runtime.state.DuplicatingCheckpointOutputStream
-
- closeAsync() - Method in class org.apache.flink.runtime.jobmaster.JobManagerRunner
-
- closeAsync() - Method in class org.apache.flink.runtime.minicluster.MiniCluster
-
Shuts down the mini cluster, failing all currently executing jobs.
- closeAsync() - Method in class org.apache.flink.runtime.minicluster.StandaloneMiniCluster
-
- closeAsync() - Method in class org.apache.flink.runtime.resourcemanager.ResourceManagerRunner
-
- closeAsync() - Method in class org.apache.flink.runtime.rest.handler.AbstractHandler
-
- closeAsync() - Method in class org.apache.flink.runtime.rest.RestClient
-
- closeAsync() - Method in class org.apache.flink.runtime.rest.RestServerEndpoint
-
- closeAsync() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerRunner
-
- closeAsync() - Method in enum org.apache.flink.runtime.webmonitor.WebMonitorExtension.EmptyWebMonitorExtension
-
- closeAsync() - Method in class org.apache.flink.runtime.webmonitor.WebSubmissionExtension
-
- closeAsync() - Method in interface org.apache.flink.util.AutoCloseableAsync
-
Trigger the closing of the resource and return the corresponding
close future.
- closeChainedTasks(List<ChainedDriver<?, ?>>, AbstractInvokable) - Static method in class org.apache.flink.runtime.operators.BatchTask
-
Closes all chained tasks, in the order as they are stored in the array.
- closeConnections() - Method in class org.apache.flink.streaming.connectors.kafka.internal.Kafka09PartitionDiscoverer
-
- closeConnections() - Method in class org.apache.flink.streaming.connectors.kafka.internals.AbstractPartitionDiscoverer
-
Close all established connections.
- closeConnections() - Method in class org.apache.flink.streaming.connectors.kafka.internals.Kafka08PartitionDiscoverer
-
- closed - Variable in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousFileIOChannel
-
Flag marking this channel as closed
- closed - Variable in class org.apache.flink.runtime.operators.hash.AbstractMutableHashTable
-
Flag to mark the table as open / closed.
- closed - Variable in class org.apache.flink.runtime.operators.hash.MutableHashTable
-
Flag indicating that the closing logic has been invoked.
- closed - Variable in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger
-
Flag indicating that the sorter was closed.
- closedBranchingNodes - Variable in class org.apache.flink.optimizer.dag.OptimizerNode
-
- ClosedException() - Constructor for exception org.apache.flink.streaming.connectors.kafka.internal.Handover.ClosedException
-
- ClosedException() - Constructor for exception org.apache.flink.streaming.connectors.kafka.internals.AbstractPartitionDiscoverer.ClosedException
-
- closeFunction(Function) - Static method in class org.apache.flink.api.common.functions.util.FunctionUtils
-
- closeHandlerAsync() - Method in class org.apache.flink.runtime.rest.handler.AbstractHandler
-
- closeHandlerAsync() - Method in class org.apache.flink.runtime.rest.handler.async.AbstractAsynchronousOperationHandlers.StatusHandler
-
- closeInputFormat() - Method in class org.apache.flink.addons.hbase.AbstractTableInputFormat
-
- closeInputFormat() - Method in class org.apache.flink.api.common.io.ReplicatingInputFormat
-
- closeInputFormat() - Method in class org.apache.flink.api.common.io.RichInputFormat
-
Closes this InputFormat instance.
- closeInputFormat() - Method in class org.apache.flink.api.java.io.jdbc.JDBCInputFormat
-
- closeInputFormat() - Method in class org.apache.flink.orc.OrcRowInputFormat
-
- closeJobManagerConnection(JobID, Exception) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
-
This method should be called by the framework once it detects that a currently registered
job manager has failed.
- closeLocalStrategiesAndCaches() - Method in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
-
- closeLocalStrategiesAndCaches() - Method in class org.apache.flink.runtime.operators.BatchTask
-
- closeLock - Variable in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousFileIOChannel
-
The lock that is used during closing to synchronize the thread that waits for all
requests to be handled with the asynchronous I/O thread.
- closeOpenChannelConnections(ConnectionID) - Method in interface org.apache.flink.runtime.io.network.ConnectionManager
-
Closes opened ChannelConnections in case of a resource release.
- closeOpenChannelConnections(ConnectionID) - Method in class org.apache.flink.runtime.io.network.LocalConnectionManager
-
- closeOpenChannelConnections(ConnectionID) - Method in class org.apache.flink.runtime.io.network.netty.NettyConnectionManager
-
- closeQuietly(AutoCloseable) - Static method in class org.apache.flink.util.IOUtils
-
Closes the given AutoCloseable.
- closeSafetyNetAndGuardedResourcesForThread() - Static method in class org.apache.flink.core.fs.FileSystemSafetyNet
-
Closes the safety net for a thread.
- closeSocket(Socket) - Static method in class org.apache.flink.util.IOUtils
-
- closeStream(Closeable) - Static method in class org.apache.flink.util.IOUtils
-
- closeTask() - Method in class org.apache.flink.runtime.operators.chaining.ChainedAllReduceDriver
-
- closeTask() - Method in class org.apache.flink.runtime.operators.chaining.ChainedDriver
-
- closeTask() - Method in class org.apache.flink.runtime.operators.chaining.ChainedFlatMapDriver
-
- closeTask() - Method in class org.apache.flink.runtime.operators.chaining.ChainedMapDriver
-
- closeTask() - Method in class org.apache.flink.runtime.operators.chaining.ChainedReduceCombineDriver
-
- closeTask() - Method in class org.apache.flink.runtime.operators.chaining.ChainedTerminationCriterionDriver
-
- closeTask() - Method in class org.apache.flink.runtime.operators.chaining.GroupCombineChainedDriver
-
- closeTask() - Method in class org.apache.flink.runtime.operators.chaining.SynchronousChainedCombineDriver
-
- closeTask() - Method in class org.apache.flink.runtime.operators.NoOpChainedDriver
-
- closeTaskManagerConnection(ResourceID, Exception) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
-
This method should be called by the framework once it detects that a currently registered
task executor has failed.
- closeUserCode(Function) - Static method in class org.apache.flink.runtime.operators.BatchTask
-
- closeWith(DataSet<ST>, DataSet<WT>) - Method in class org.apache.flink.api.java.operators.DeltaIteration
-
Closes the delta iteration.
- closeWith(DataSet<T>) - Method in class org.apache.flink.api.java.operators.IterativeDataSet
-
Closes the iteration.
- closeWith(DataSet<T>, DataSet<?>) - Method in class org.apache.flink.api.java.operators.IterativeDataSet
-
Closes the iteration and specifies a termination criterion.
- closeWith(DataStream<T>) - Method in class org.apache.flink.streaming.api.datastream.IterativeStream
-
Closes the iteration.
- closeWith(DataStream<F>) - Method in class org.apache.flink.streaming.api.datastream.IterativeStream.ConnectedIterativeStreams
-
Closes the iteration.
- ClosingFSDataInputStream - Class in org.apache.flink.core.fs
-
- ClosingFSDataOutputStream - Class in org.apache.flink.core.fs
-
- ClosingFSDataOutputStream(FSDataOutputStream, SafetyNetCloseableRegistry) - Constructor for class org.apache.flink.core.fs.ClosingFSDataOutputStream
-
- ClosureCleaner - Class in 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() - Constructor for class org.apache.flink.api.java.ClosureCleaner
-
- cluster - Variable in class org.apache.flink.streaming.connectors.cassandra.CassandraRowWriteAheadSink
-
- cluster - Variable in class org.apache.flink.streaming.connectors.cassandra.CassandraSinkBase
-
- cluster - Variable in class org.apache.flink.streaming.connectors.cassandra.CassandraTupleWriteAheadSink
-
- CLUSTER_CONFIG_REST_PATH - Static variable in class org.apache.flink.runtime.rest.messages.ClusterConfigurationInfoHeaders
-
- ClusterBuilder - Class in org.apache.flink.streaming.connectors.cassandra
-
This class is used to configure a Cluster
after deployment.
- ClusterBuilder() - Constructor for class org.apache.flink.streaming.connectors.cassandra.ClusterBuilder
-
- ClusterClient<T> - Class in org.apache.flink.client.program
-
Encapsulates the functionality necessary to submit a program to a remote cluster.
- ClusterClient(Configuration) - Constructor for class org.apache.flink.client.program.ClusterClient
-
Creates a instance that submits the programs to the JobManager defined in the
configuration.
- ClusterClient(Configuration, HighAvailabilityServices, boolean) - Constructor for class org.apache.flink.client.program.ClusterClient
-
Creates a instance that submits the programs to the JobManager defined in the
configuration.
- ClusterClient.LazyActorSystemLoader - Class in org.apache.flink.client.program
-
Utility class to lazily instantiate an ActorSystem
.
- ClusterConfigHandler - Class in org.apache.flink.runtime.rest.handler.cluster
-
Handler which serves the cluster's configuration.
- ClusterConfigHandler(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MessageHeaders<EmptyRequestBody, ClusterConfigurationInfo, EmptyMessageParameters>, Configuration) - Constructor for class org.apache.flink.runtime.rest.handler.cluster.ClusterConfigHandler
-
- ClusterConfigHandler - Class in org.apache.flink.runtime.rest.handler.legacy
-
Returns the Job Manager's configuration.
- ClusterConfigHandler(Executor, Configuration) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.ClusterConfigHandler
-
- ClusterConfiguration - Class in org.apache.flink.runtime.entrypoint
-
Configuration class which contains the parsed command line arguments for
the
ClusterEntrypoint
.
- ClusterConfiguration(String, String, int) - Constructor for class org.apache.flink.runtime.entrypoint.ClusterConfiguration
-
- clusterConfiguration - Variable in class org.apache.flink.runtime.webmonitor.WebMonitorEndpoint
-
- ClusterConfigurationInfo - Class in org.apache.flink.runtime.rest.messages
-
- ClusterConfigurationInfo() - Constructor for class org.apache.flink.runtime.rest.messages.ClusterConfigurationInfo
-
- ClusterConfigurationInfo(int) - Constructor for class org.apache.flink.runtime.rest.messages.ClusterConfigurationInfo
-
- ClusterConfigurationInfoEntry - Class in org.apache.flink.runtime.rest.messages
-
- ClusterConfigurationInfoEntry(String, String) - Constructor for class org.apache.flink.runtime.rest.messages.ClusterConfigurationInfoEntry
-
- ClusterConfigurationInfoHeaders - Class in org.apache.flink.runtime.rest.messages
-
- ClusterDeploymentException - Exception in org.apache.flink.client.deployment
-
Class which indicates a problem when deploying a Flink cluster.
- ClusterDeploymentException(String) - Constructor for exception org.apache.flink.client.deployment.ClusterDeploymentException
-
- ClusterDeploymentException(Throwable) - Constructor for exception org.apache.flink.client.deployment.ClusterDeploymentException
-
- ClusterDeploymentException(String, Throwable) - Constructor for exception org.apache.flink.client.deployment.ClusterDeploymentException
-
- ClusterDescriptor<T> - Interface in org.apache.flink.client.deployment
-
A descriptor to deploy a cluster (e.g.
- ClusterEntrypoint - Class in org.apache.flink.runtime.entrypoint
-
Base class for the Flink cluster entry points.
- ClusterEntrypoint(Configuration) - Constructor for class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
-
- ClusterEntrypoint.ExecutionMode - Enum in org.apache.flink.runtime.entrypoint
-
- ClusterInformation - Class in org.apache.flink.runtime.entrypoint
-
Information about the cluster which is shared with the cluster components.
- ClusterInformation(String, int) - Constructor for class org.apache.flink.runtime.entrypoint.ClusterInformation
-
- ClusteringCoefficient<K extends Comparable<K> & CopyableValue<K>,VV,EV> - Class in org.apache.flink.graph.drivers
-
Driver for directed and undirected clustering coefficient algorithm and analytics.
- ClusteringCoefficient() - Constructor for class org.apache.flink.graph.drivers.ClusteringCoefficient
-
- ClusterOverview - Class in org.apache.flink.runtime.messages.webmonitor
-
- ClusterOverview(int, int, int, int, int, int, int) - Constructor for class org.apache.flink.runtime.messages.webmonitor.ClusterOverview
-
- ClusterOverview(int, int, int, JobsOverview, JobsOverview) - Constructor for class org.apache.flink.runtime.messages.webmonitor.ClusterOverview
-
- ClusterOverview(ResourceOverview, JobsOverview) - Constructor for class org.apache.flink.runtime.messages.webmonitor.ClusterOverview
-
- ClusterOverviewHandler - Class in org.apache.flink.runtime.rest.handler.cluster
-
Handler which returns the cluster overview information with version.
- ClusterOverviewHandler(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MessageHeaders<EmptyRequestBody, ClusterOverviewWithVersion, EmptyMessageParameters>) - Constructor for class org.apache.flink.runtime.rest.handler.cluster.ClusterOverviewHandler
-
- ClusterOverviewHandler - Class in org.apache.flink.runtime.rest.handler.legacy
-
Responder that returns the status of the Flink cluster, such as how many
TaskManagers are currently connected, and how many jobs are running.
- ClusterOverviewHandler(Executor, Time) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.ClusterOverviewHandler
-
- ClusterOverviewHeaders - Class in org.apache.flink.runtime.rest.messages
-
- ClusterOverviewWithVersion - Class in org.apache.flink.runtime.rest.handler.legacy.messages
-
Cluster overview message including the current Flink version and commit id.
- ClusterOverviewWithVersion(int, int, int, int, int, int, int, String, String) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.messages.ClusterOverviewWithVersion
-
- ClusterOverviewWithVersion(int, int, int, JobsOverview, JobsOverview, String, String) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.messages.ClusterOverviewWithVersion
-
- ClusterRetrieveException - Exception in org.apache.flink.client.deployment
-
Exception which indicates that a cluster could not be retrieved.
- ClusterRetrieveException(String) - Constructor for exception org.apache.flink.client.deployment.ClusterRetrieveException
-
- ClusterRetrieveException(Throwable) - Constructor for exception org.apache.flink.client.deployment.ClusterRetrieveException
-
- ClusterRetrieveException(String, Throwable) - Constructor for exception org.apache.flink.client.deployment.ClusterRetrieveException
-
- ClusterSpecification - Class in org.apache.flink.client.deployment
-
- ClusterSpecification.ClusterSpecificationBuilder - Class in org.apache.flink.client.deployment
-
- ClusterSpecificationBuilder() - Constructor for class org.apache.flink.client.deployment.ClusterSpecification.ClusterSpecificationBuilder
-
- CoBroadcastWithKeyedOperator<KS,IN1,IN2,OUT> - Class in org.apache.flink.streaming.api.operators.co
-
- CoBroadcastWithKeyedOperator(KeyedBroadcastProcessFunction<KS, IN1, IN2, OUT>, List<MapStateDescriptor<?, ?>>) - Constructor for class org.apache.flink.streaming.api.operators.co.CoBroadcastWithKeyedOperator
-
- CoBroadcastWithNonKeyedOperator<IN1,IN2,OUT> - Class in org.apache.flink.streaming.api.operators.co
-
- CoBroadcastWithNonKeyedOperator(BroadcastProcessFunction<IN1, IN2, OUT>, List<MapStateDescriptor<?, ?>>) - Constructor for class org.apache.flink.streaming.api.operators.co.CoBroadcastWithNonKeyedOperator
-
- CodeAnalysisMode - Enum in org.apache.flink.api.common
-
Specifies to which extent user-defined functions are analyzed in order
to give the Flink optimizer an insight of UDF internals and inform
the user about common implementation mistakes.
- CodeAnalyzerException - Exception in org.apache.flink.api.java.sca
-
Exception that is thrown if code analysis could not run properly.
- CodeAnalyzerException() - Constructor for exception org.apache.flink.api.java.sca.CodeAnalyzerException
-
- CodeAnalyzerException(String, Throwable) - Constructor for exception org.apache.flink.api.java.sca.CodeAnalyzerException
-
- CodeAnalyzerException(String) - Constructor for exception org.apache.flink.api.java.sca.CodeAnalyzerException
-
- CodeAnalyzerException(Throwable) - Constructor for exception org.apache.flink.api.java.sca.CodeAnalyzerException
-
- CODEBASE_KEY - Static variable in class org.apache.flink.test.util.MiniClusterResource
-
- CodeErrorException - Exception in org.apache.flink.api.java.sca
-
Exception that is thrown if code errors could be found during analysis.
- CodeErrorException() - Constructor for exception org.apache.flink.api.java.sca.CodeErrorException
-
- CodeErrorException(String, Throwable) - Constructor for exception org.apache.flink.api.java.sca.CodeErrorException
-
- CodeErrorException(String) - Constructor for exception org.apache.flink.api.java.sca.CodeErrorException
-
- CodeErrorException(Throwable) - Constructor for exception org.apache.flink.api.java.sca.CodeErrorException
-
- CoFeedbackTransformation<F> - Class in org.apache.flink.streaming.api.transformations
-
This represents a feedback point in a topology.
- CoFeedbackTransformation(int, TypeInformation<F>, Long) - Constructor for class org.apache.flink.streaming.api.transformations.CoFeedbackTransformation
-
Creates a new CoFeedbackTransformation
from the given input.
- CoFlatMapFunction<IN1,IN2,OUT> - Interface in org.apache.flink.streaming.api.functions.co
-
A CoFlatMapFunction implements a flat-map transformation over two
connected streams.
- coGroup(Iterable<IN1>, Iterable<IN2>, Collector<O>) - Method in interface org.apache.flink.api.common.functions.CoGroupFunction
-
This method must be implemented to provide a user implementation of a
coGroup.
- coGroup(Iterable<IN1>, Iterable<IN2>, Collector<OUT>) - Method in class org.apache.flink.api.common.functions.RichCoGroupFunction
-
- coGroup(DataSet<R>) - Method in class org.apache.flink.api.java.DataSet
-
Initiates a CoGroup transformation.
- coGroup(Iterable<Tuple3<Integer, String, Integer>>, Iterable<Tuple1<String>>, Collector<Tuple3<Integer, String, Integer>>) - Method in class org.apache.flink.examples.java.relational.WebLogAnalysis.AntiJoinVisits
-
If the visit iterator is empty, all pairs of the rank iterator are emitted.
- coGroup(Iterable<IN1>, Iterable<IN2>, Collector<OUT>) - Method in class org.apache.flink.python.api.functions.PythonCoGroup
-
Calls the external python function.
- coGroup(DataStream<T2>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Creates a join operation.
- CoGroupDescriptor - Class in org.apache.flink.optimizer.operators
-
- CoGroupDescriptor(FieldList, FieldList) - Constructor for class org.apache.flink.optimizer.operators.CoGroupDescriptor
-
- CoGroupDescriptor(FieldList, FieldList, Ordering, Ordering) - Constructor for class org.apache.flink.optimizer.operators.CoGroupDescriptor
-
- CoGroupDriver<IT1,IT2,OT> - Class in org.apache.flink.runtime.operators
-
CoGroup task which is executed by a Task Manager.
- CoGroupDriver() - Constructor for class org.apache.flink.runtime.operators.CoGroupDriver
-
- CoGroupedStreams<T1,T2> - Class in org.apache.flink.streaming.api.datastream
-
CoGroupedStreams
represents two
DataStreams
that have been co-grouped.
- CoGroupedStreams(DataStream<T1>, DataStream<T2>) - Constructor for class org.apache.flink.streaming.api.datastream.CoGroupedStreams
-
Creates new CoGrouped data streams, which are the first step towards building a streaming
co-group.
- CoGroupedStreams.TaggedUnion<T1,T2> - Class in org.apache.flink.streaming.api.datastream
-
Internal class for implementing tagged union co-group.
- CoGroupedStreams.UnionSerializerConfigSnapshot<T1,T2> - Class in org.apache.flink.streaming.api.datastream
-
- CoGroupedStreams.Where<KEY> - Class in org.apache.flink.streaming.api.datastream
-
CoGrouped streams that have the key for one side defined.
- CoGroupedStreams.Where.EqualTo - Class in org.apache.flink.streaming.api.datastream
-
A co-group operation that has
KeySelectors
defined for both inputs.
- CoGroupedStreams.WithWindow<T1,T2,KEY,W extends Window> - Class in org.apache.flink.streaming.api.datastream
-
- CoGroupFunction<IN1,IN2,O> - Interface in org.apache.flink.api.common.functions
-
The interface for CoGroup functions.
- CoGroupNode - Class in org.apache.flink.optimizer.dag
-
The Optimizer representation of a CoGroup operator.
- CoGroupNode(CoGroupOperatorBase<?, ?, ?, ?>) - Constructor for class org.apache.flink.optimizer.dag.CoGroupNode
-
- CoGroupOperator<I1,I2,OUT> - Class in org.apache.flink.api.java.operators
-
A
DataSet
that is the result of a CoGroup transformation.
- CoGroupOperator(DataSet<I1>, DataSet<I2>, Keys<I1>, Keys<I2>, CoGroupFunction<I1, I2, OUT>, TypeInformation<OUT>, Partitioner<?>, String) - Constructor for class org.apache.flink.api.java.operators.CoGroupOperator
-
- CoGroupOperator(DataSet<I1>, DataSet<I2>, Keys<I1>, Keys<I2>, CoGroupFunction<I1, I2, OUT>, TypeInformation<OUT>, List<Pair<Integer, Order>>, List<Pair<Integer, Order>>, Partitioner<?>, String) - Constructor for class org.apache.flink.api.java.operators.CoGroupOperator
-
- CoGroupOperator.CoGroupOperatorSets<I1,I2> - Class in org.apache.flink.api.java.operators
-
Intermediate step of a CoGroup transformation.
- CoGroupOperator.CoGroupOperatorSets.CoGroupOperatorSetsPredicate - Class in org.apache.flink.api.java.operators
-
Intermediate step of a CoGroup transformation.
- CoGroupOperator.CoGroupOperatorSets.CoGroupOperatorSetsPredicate.CoGroupOperatorWithoutFunction - Class in org.apache.flink.api.java.operators
-
- CoGroupOperatorBase<IN1,IN2,OUT,FT extends CoGroupFunction<IN1,IN2,OUT>> - Class in org.apache.flink.api.common.operators.base
-
- CoGroupOperatorBase(UserCodeWrapper<FT>, BinaryOperatorInformation<IN1, IN2, OUT>, int[], int[], String) - Constructor for class org.apache.flink.api.common.operators.base.CoGroupOperatorBase
-
- CoGroupOperatorBase(FT, BinaryOperatorInformation<IN1, IN2, OUT>, int[], int[], String) - Constructor for class org.apache.flink.api.common.operators.base.CoGroupOperatorBase
-
- CoGroupOperatorBase(Class<? extends FT>, BinaryOperatorInformation<IN1, IN2, OUT>, int[], int[], String) - Constructor for class org.apache.flink.api.common.operators.base.CoGroupOperatorBase
-
- CoGroupOperatorSets(DataSet<I1>, DataSet<I2>) - Constructor for class org.apache.flink.api.java.operators.CoGroupOperator.CoGroupOperatorSets
-
- CoGroupRawDescriptor - Class in org.apache.flink.optimizer.operators
-
- CoGroupRawDescriptor(FieldList, FieldList) - Constructor for class org.apache.flink.optimizer.operators.CoGroupRawDescriptor
-
- CoGroupRawDescriptor(FieldList, FieldList, Ordering, Ordering) - Constructor for class org.apache.flink.optimizer.operators.CoGroupRawDescriptor
-
- CoGroupRawDriver<IT1,IT2,OT> - Class in org.apache.flink.runtime.operators
-
- CoGroupRawDriver() - Constructor for class org.apache.flink.runtime.operators.CoGroupRawDriver
-
- CoGroupRawDriver.SimpleIterable<IN> - Class in org.apache.flink.runtime.operators
-
- CoGroupRawDriver.SimpleIterable.SimpleIterator<IN> - Class in org.apache.flink.runtime.operators
-
- CoGroupRawNode - Class in org.apache.flink.optimizer.dag
-
The Optimizer representation of a CoGroupRaw operator.
- CoGroupRawNode(CoGroupRawOperatorBase<?, ?, ?, ?>) - Constructor for class org.apache.flink.optimizer.dag.CoGroupRawNode
-
- CoGroupRawOperator<I1,I2,OUT> - Class in org.apache.flink.api.java.operators
-
A
DataSet
that is the result of a CoGroup transformation.
- CoGroupRawOperator(DataSet<I1>, DataSet<I2>, Keys<I1>, Keys<I2>, CoGroupFunction<I1, I2, OUT>, TypeInformation<OUT>, String) - Constructor for class org.apache.flink.api.java.operators.CoGroupRawOperator
-
- CoGroupRawOperatorBase<IN1,IN2,OUT,FT extends CoGroupFunction<IN1,IN2,OUT>> - Class in org.apache.flink.api.common.operators.base
-
- CoGroupRawOperatorBase(UserCodeWrapper<FT>, BinaryOperatorInformation<IN1, IN2, OUT>, int[], int[], String) - Constructor for class org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase
-
- CoGroupRawOperatorBase(FT, BinaryOperatorInformation<IN1, IN2, OUT>, int[], int[], String) - Constructor for class org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase
-
- CoGroupRawOperatorBase(Class<? extends FT>, BinaryOperatorInformation<IN1, IN2, OUT>, int[], int[], String) - Constructor for class org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase
-
- CoGroupRawOperatorBase.SimpleListIterable<IN> - Class in org.apache.flink.api.common.operators.base
-
- CoGroupRawOperatorBase.SimpleListIterable.SimpleListIterator<IN> - Class in org.apache.flink.api.common.operators.base
-
- CoGroupTaskIterator<T1,T2> - Interface in org.apache.flink.runtime.operators.util
-
Interface describing the methods that have to be implemented by local strategies for the CoGroup Pact.
- CoGroupWithSolutionSetFirstDescriptor - Class in org.apache.flink.optimizer.operators
-
- CoGroupWithSolutionSetFirstDescriptor(FieldList, FieldList) - Constructor for class org.apache.flink.optimizer.operators.CoGroupWithSolutionSetFirstDescriptor
-
- CoGroupWithSolutionSetFirstDriver<IT1,IT2,OT> - Class in org.apache.flink.runtime.operators
-
- CoGroupWithSolutionSetFirstDriver() - Constructor for class org.apache.flink.runtime.operators.CoGroupWithSolutionSetFirstDriver
-
- CoGroupWithSolutionSetSecondDescriptor - Class in org.apache.flink.optimizer.operators
-
- CoGroupWithSolutionSetSecondDescriptor(FieldList, FieldList) - Constructor for class org.apache.flink.optimizer.operators.CoGroupWithSolutionSetSecondDescriptor
-
- CoGroupWithSolutionSetSecondDriver<IT1,IT2,OT> - Class in org.apache.flink.runtime.operators
-
- CoGroupWithSolutionSetSecondDriver() - Constructor for class org.apache.flink.runtime.operators.CoGroupWithSolutionSetSecondDriver
-
- collect(T) - Method in class org.apache.flink.api.common.functions.util.CopyingListCollector
-
- collect(T) - Method in class org.apache.flink.api.common.functions.util.ListCollector
-
- collect() - Method in class org.apache.flink.api.java.DataSet
-
Convenience method to get the elements of a DataSet as a List.
- collect(IN) - Method in class org.apache.flink.api.java.operators.translation.Tuple3WrappingCollector
-
- collect(IN) - Method in class org.apache.flink.api.java.operators.translation.TupleWrappingCollector
-
- collect(T) - Method in class org.apache.flink.cep.operator.TimestampedSideOutputCollector
-
- Collect<T> - Class in org.apache.flink.graph.asm.dataset
-
- Collect() - Constructor for class org.apache.flink.graph.asm.dataset.Collect
-
- collect(KEY, VALUE) - Method in class org.apache.flink.hadoopcompatibility.mapred.wrapper.HadoopOutputCollector
-
Use the wrapped Flink collector to collect a key-value pair for Flink.
- collect(Channel, List<Channel>) - Method in class org.apache.flink.optimizer.traversals.BinaryUnionReplacer
-
- collect(T) - Method in class org.apache.flink.runtime.iterative.io.SolutionSetFastUpdateOutputCollector
-
- collect(T) - Method in class org.apache.flink.runtime.iterative.io.SolutionSetObjectsUpdateOutputCollector
-
- collect(T) - Method in class org.apache.flink.runtime.iterative.io.SolutionSetUpdateOutputCollector
-
- collect(T) - Method in class org.apache.flink.runtime.iterative.io.WorksetUpdateOutputCollector
-
- collect(IT) - Method in class org.apache.flink.runtime.operators.chaining.ChainedAllReduceDriver
-
- collect(IT) - Method in class org.apache.flink.runtime.operators.chaining.ChainedDriver
-
- collect(IT) - Method in class org.apache.flink.runtime.operators.chaining.ChainedFlatMapDriver
-
- collect(IT) - Method in class org.apache.flink.runtime.operators.chaining.ChainedMapDriver
-
- collect(T) - Method in class org.apache.flink.runtime.operators.chaining.ChainedReduceCombineDriver
-
- collect(IT) - Method in class org.apache.flink.runtime.operators.chaining.ChainedTerminationCriterionDriver
-
- collect(IN) - Method in class org.apache.flink.runtime.operators.chaining.GroupCombineChainedDriver
-
- collect(IN) - Method in class org.apache.flink.runtime.operators.chaining.SynchronousChainedCombineDriver
-
- collect(IT) - Method in class org.apache.flink.runtime.operators.NoOpChainedDriver
-
- collect(T) - Method in class org.apache.flink.runtime.operators.shipping.OutputCollector
-
Collects a record and emits it to all writers.
- collect(OUT) - Method in class org.apache.flink.runtime.operators.util.metrics.CountingCollector
-
- collect(StreamRecord<OUT>) - Method in class org.apache.flink.streaming.api.collector.selector.CopyingDirectedOutput
-
- collect(StreamRecord<OUT>) - Method in class org.apache.flink.streaming.api.collector.selector.DirectedOutput
-
- collect(OutputTag<X>, StreamRecord<X>) - Method in class org.apache.flink.streaming.api.collector.selector.DirectedOutput
-
- collect(DataStream<OUT>) - Static method in class org.apache.flink.streaming.api.datastream.DataStreamUtils
-
Returns an iterator to iterate over the elements of the DataStream.
- collect(T) - Method in interface org.apache.flink.streaming.api.functions.source.SourceFunction.SourceContext
-
Emits one element from the source, without attaching a timestamp.
- collect(StreamRecord<OUT>) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator.CountingOutput
-
- collect(OutputTag<X>, StreamRecord<X>) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator.CountingOutput
-
- collect(OutputTag<X>, StreamRecord<X>) - Method in interface org.apache.flink.streaming.api.operators.Output
-
Emits a record the side output identified by the given
OutputTag
.
- collect(T) - Method in class org.apache.flink.streaming.api.operators.TimestampedCollector
-
- collect(Object) - Method in class org.apache.flink.streaming.python.util.PythonCollector
-
- collect(StreamRecord<OUT>) - Method in class org.apache.flink.streaming.runtime.io.RecordWriterOutput
-
- collect(OutputTag<X>, StreamRecord<X>) - Method in class org.apache.flink.streaming.runtime.io.RecordWriterOutput
-
- collect(T) - Method in interface org.apache.flink.util.Collector
-
Emits a record.
- collectBuffer(Collector<OUT>, int) - Method in class org.apache.flink.python.api.streaming.data.PythonReceiver
-
Reads a buffer of the given size from the memory-mapped file, and collects all records contained.
- CollectHelper(String, TypeSerializer<T>) - Constructor for class org.apache.flink.api.java.Utils.CollectHelper
-
- collection - Variable in class org.apache.flink.api.common.operators.util.FieldSet
-
- CollectionEnvironment - Class in org.apache.flink.api.java
-
Version of
ExecutionEnvironment
that allows serial, local, collection-based executions of Flink programs.
- CollectionEnvironment() - Constructor for class org.apache.flink.api.java.CollectionEnvironment
-
- CollectionExecutionExample - Class in org.apache.flink.examples.java.misc
-
This example shows how to use the collection based execution of Flink.
- CollectionExecutionExample() - Constructor for class org.apache.flink.examples.java.misc.CollectionExecutionExample
-
- CollectionExecutionExample.EMail - Class in org.apache.flink.examples.java.misc
-
POJO for an EMail.
- CollectionExecutionExample.User - Class in org.apache.flink.examples.java.misc
-
POJO class representing a user.
- CollectionExecutor - Class in org.apache.flink.api.common.operators
-
Execution utility for serial, local, collection-based executions of Flink programs.
- CollectionExecutor(ExecutionConfig) - Constructor for class org.apache.flink.api.common.operators.CollectionExecutor
-
- CollectionInputFormat<T> - Class in org.apache.flink.api.java.io
-
An input format that returns objects from a collection.
- CollectionInputFormat(Collection<T>, TypeSerializer<T>) - Constructor for class org.apache.flink.api.java.io.CollectionInputFormat
-
- CollectionSerializerConfigSnapshot<T> - Class in org.apache.flink.api.common.typeutils.base
-
Configuration snapshot of a serializer for collection types.
- CollectionSerializerConfigSnapshot() - Constructor for class org.apache.flink.api.common.typeutils.base.CollectionSerializerConfigSnapshot
-
This empty nullary constructor is required for deserializing the configuration.
- CollectionSerializerConfigSnapshot(TypeSerializer<T>) - Constructor for class org.apache.flink.api.common.typeutils.base.CollectionSerializerConfigSnapshot
-
- CollectionTestEnvironment - Class in org.apache.flink.test.util
-
- CollectionTestEnvironment() - Constructor for class org.apache.flink.test.util.CollectionTestEnvironment
-
- CollectionUtil - Class in org.apache.flink.util
-
Simple utility to work with Java collections.
- collector - Variable in class org.apache.flink.storm.util.AbstractLineSpout
-
- Collector<T> - Interface in org.apache.flink.util
-
Collects a record and forwards it.
- CollectSink<IN> - Class in org.apache.flink.streaming.experimental
-
A specialized data sink to be used by DataStreamUtils.collect().
- CollectSink(InetAddress, int, TypeSerializer<IN>) - Constructor for class org.apache.flink.streaming.experimental.CollectSink
-
Creates a CollectSink that will send the data to the specified host.
- collectStackTraces(int, ExecutionAttemptID, List<StackTraceElement[]>) - Method in class org.apache.flink.runtime.rest.handler.legacy.backpressure.StackTraceSampleCoordinator
-
Collects stack traces of a task.
- CollectStreamResult<C> - Class in org.apache.flink.table.client.gateway.local
-
- CollectStreamResult(TypeInformation<Row>, ExecutionConfig, InetAddress, int) - Constructor for class org.apache.flink.table.client.gateway.local.CollectStreamResult
-
- CollectStreamTableSink - Class in org.apache.flink.table.client.gateway.local
-
Table sink for collecting the results locally using sockets.
- CollectStreamTableSink(InetAddress, int, TypeSerializer<Tuple2<Boolean, Row>>) - Constructor for class org.apache.flink.table.client.gateway.local.CollectStreamTableSink
-
- collectWithTimestamp(T, long) - Method in interface org.apache.flink.streaming.api.functions.source.SourceFunction.SourceContext
-
Emits one element from the source, and attaches the given timestamp.
- CoLocationConstraint - Class in org.apache.flink.runtime.jobmanager.scheduler
-
A CoLocationConstraint manages the location of a set of tasks
(Execution Vertices).
- CoLocationGroup - Class in org.apache.flink.runtime.jobmanager.scheduler
-
A Co-location group is a group of JobVertices, where the i-th subtask of one vertex
has to be executed on the same TaskManager as the i-th subtask of all
other JobVertices in the same group.
- CoLocationGroup() - Constructor for class org.apache.flink.runtime.jobmanager.scheduler.CoLocationGroup
-
- CoLocationGroup(JobVertex...) - Constructor for class org.apache.flink.runtime.jobmanager.scheduler.CoLocationGroup
-
- columnFamily - Variable in class org.apache.flink.contrib.streaming.state.AbstractRocksDBState
-
The column family of this particular instance of state.
- ColumnSummary - Class in org.apache.flink.api.java.summarize
-
Summary for a column of values.
- ColumnSummary() - Constructor for class org.apache.flink.api.java.summarize.ColumnSummary
-
- CoMapFunction<IN1,IN2,OUT> - Interface in org.apache.flink.streaming.api.functions.co
-
A CoFlatMapFunction implements a map() transformation over two
connected streams.
- CoMapTimeout() - Constructor for class org.apache.flink.cep.PatternStream.CoMapTimeout
-
- combinations() - Method in class org.apache.flink.cep.pattern.Quantifier
-
- combine(Iterable<IN>) - Method in interface org.apache.flink.api.common.functions.CombineFunction
-
The combine method, called (potentially multiple timed) with subgroups of elements.
- combine(Iterable<IN>, Collector<OUT>) - Method in interface org.apache.flink.api.common.functions.GroupCombineFunction
-
The combine method, called (potentially multiple timed) with subgroups of elements.
- combine(Iterable<IN>, Collector<OUT>) - Method in class org.apache.flink.api.common.functions.RichGroupCombineFunction
-
- combine(Iterable<T>, Collector<T>) - Method in class org.apache.flink.api.java.functions.FirstReducer
-
- combine(Iterable<IN>, Collector<IN>) - Method in class org.apache.flink.api.java.operators.translation.CombineToGroupCombineWrapper
-
- combine(Iterable<IN>, Collector<IN>) - Method in class org.apache.flink.api.java.operators.translation.RichCombineToGroupCombineWrapper
-
- combine(Aggregator<T, R>) - Method in interface org.apache.flink.api.java.summarize.aggregation.Aggregator
-
Combine two aggregations of the same type.
- combine(Aggregator<Boolean, BooleanColumnSummary>) - Method in class org.apache.flink.api.java.summarize.aggregation.BooleanSummaryAggregator
-
- combine(Aggregator<Double, Double>) - Method in class org.apache.flink.api.java.summarize.aggregation.DoubleSummaryAggregator.MaxDoubleAggregator
-
- combine(Aggregator<Double, Double>) - Method in class org.apache.flink.api.java.summarize.aggregation.DoubleSummaryAggregator.MinDoubleAggregator
-
- combine(Aggregator<Double, Double>) - Method in class org.apache.flink.api.java.summarize.aggregation.DoubleSummaryAggregator.SumDoubleAggregator
-
- combine(Aggregator<Float, Float>) - Method in class org.apache.flink.api.java.summarize.aggregation.FloatSummaryAggregator.MaxFloatAggregator
-
- combine(Aggregator<Float, Float>) - Method in class org.apache.flink.api.java.summarize.aggregation.FloatSummaryAggregator.MinFloatAggregator
-
- combine(Aggregator<Float, Float>) - Method in class org.apache.flink.api.java.summarize.aggregation.FloatSummaryAggregator.SumFloatAggregator
-
- combine(Aggregator<Integer, Integer>) - Method in class org.apache.flink.api.java.summarize.aggregation.IntegerSummaryAggregator.MaxIntegerAggregator
-
- combine(Aggregator<Integer, Integer>) - Method in class org.apache.flink.api.java.summarize.aggregation.IntegerSummaryAggregator.MinIntegerAggregator
-
- combine(Aggregator<Integer, Integer>) - Method in class org.apache.flink.api.java.summarize.aggregation.IntegerSummaryAggregator.SumIntegerAggregator
-
- combine(Aggregator<Long, Long>) - Method in class org.apache.flink.api.java.summarize.aggregation.LongSummaryAggregator.MaxLongAggregator
-
- combine(Aggregator<Long, Long>) - Method in class org.apache.flink.api.java.summarize.aggregation.LongSummaryAggregator.MinLongAggregator
-
- combine(Aggregator<T, NumericColumnSummary<T>>) - Method in class org.apache.flink.api.java.summarize.aggregation.NumericSummaryAggregator
-
combine two aggregations.
- combine(Aggregator<Object, ObjectColumnSummary>) - Method in class org.apache.flink.api.java.summarize.aggregation.ObjectSummaryAggregator
-
- combine(Aggregator<Short, Short>) - Method in class org.apache.flink.api.java.summarize.aggregation.ShortSummaryAggregator.MaxShortAggregator
-
- combine(Aggregator<Short, Short>) - Method in class org.apache.flink.api.java.summarize.aggregation.ShortSummaryAggregator.MinShortAggregator
-
- combine(Aggregator<Short, Short>) - Method in class org.apache.flink.api.java.summarize.aggregation.ShortSummaryAggregator.SumShortAggregator
-
- combine(Aggregator<String, StringColumnSummary>) - Method in class org.apache.flink.api.java.summarize.aggregation.StringSummaryAggregator
-
- combine(Aggregator<Tuple, R>) - Method in class org.apache.flink.api.java.summarize.aggregation.TupleSummaryAggregator
-
- combine(Aggregator<VT, R>) - Method in class org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator
-
- combine(Iterable<Tuple2<KEYIN, VALUEIN>>, Collector<Tuple2<KEYIN, VALUEIN>>) - Method in class org.apache.flink.hadoopcompatibility.mapred.HadoopReduceCombineFunction
-
- combine(GlobalProperties, GlobalProperties) - Static method in class org.apache.flink.optimizer.dataproperties.GlobalProperties
-
- combine(LocalProperties, LocalProperties) - Static method in class org.apache.flink.optimizer.dataproperties.LocalProperties
-
- combine(JobsOverview) - Method in class org.apache.flink.runtime.messages.webmonitor.JobsOverview
-
Combines the given jobs overview with this.
- combineAll(Collection<? extends CompletableFuture<? extends T>>) - Static method in class org.apache.flink.runtime.concurrent.FutureUtils
-
Creates a future that is complete once multiple other futures completed.
- CombineFunction<IN,OUT> - Interface in org.apache.flink.api.common.functions
-
Generic interface used for combine functions ("combiners").
- combineGroup(GroupCombineFunction<T, R>) - Method in class org.apache.flink.api.java.DataSet
-
Applies a GroupCombineFunction on a non-grouped
DataSet
.
- combineGroup(GroupCombineFunction<T, R>) - Method in class org.apache.flink.api.java.operators.SortedGrouping
-
Applies a GroupCombineFunction on a grouped
DataSet
.
- combineGroup(GroupCombineFunction<T, R>) - Method in class org.apache.flink.api.java.operators.UnsortedGrouping
-
Applies a GroupCombineFunction on a grouped
DataSet
.
- combineMessages(MessageIterator<Double>) - Method in class org.apache.flink.graph.examples.PregelSSSP.SSSPCombiner
-
- combineMessages(MessageIterator<Message>) - Method in class org.apache.flink.graph.pregel.MessageCombiner
-
Combines messages sent from different vertices to a target vertex.
- CombineToGroupCombineWrapper<IN,OUT,F extends CombineFunction<IN,IN> & GroupReduceFunction<IN,OUT>> - Class in org.apache.flink.api.java.operators.translation
-
- CombineToGroupCombineWrapper(F) - Constructor for class org.apache.flink.api.java.operators.translation.CombineToGroupCombineWrapper
-
- CombiningSpillingThread(ExceptionHandler<IOException>, UnilateralSortMerger.CircularQueues<E>, AbstractInvokable, MemoryManager, IOManager, TypeSerializer<E>, TypeComparator<E>, List<MemorySegment>, List<MemorySegment>, int, boolean) - Constructor for class org.apache.flink.runtime.operators.sort.CombiningUnilateralSortMerger.CombiningSpillingThread
-
- CombiningUnilateralSortMerger<E> - Class in org.apache.flink.runtime.operators.sort
-
The CombiningUnilateralSortMerger is part of a merge-sort implementation.
- CombiningUnilateralSortMerger(GroupCombineFunction<E, E>, MemoryManager, IOManager, MutableObjectIterator<E>, AbstractInvokable, TypeSerializerFactory<E>, TypeComparator<E>, double, int, float, boolean, boolean) - Constructor for class org.apache.flink.runtime.operators.sort.CombiningUnilateralSortMerger
-
Creates a new sorter that reads the data from a given reader and provides an iterator returning that
data in a sorted manner.
- CombiningUnilateralSortMerger(GroupCombineFunction<E, E>, MemoryManager, IOManager, MutableObjectIterator<E>, AbstractInvokable, TypeSerializerFactory<E>, TypeComparator<E>, double, int, int, float, boolean, boolean) - Constructor for class org.apache.flink.runtime.operators.sort.CombiningUnilateralSortMerger
-
Creates a new sorter that reads the data from a given reader and provides an iterator returning that
data in a sorted manner.
- CombiningUnilateralSortMerger.CombiningSpillingThread - Class in org.apache.flink.runtime.operators.sort
-
- command() - Method in class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManagerParameters
-
Get the command.
- command - Variable in class org.apache.flink.table.client.cli.SqlCommandParser.SqlCommandCall
-
- CommandLineOptions - Class in org.apache.flink.client.cli
-
Base class for all options parsed from the command line.
- CommandLineOptions(CommandLine) - Constructor for class org.apache.flink.client.cli.CommandLineOptions
-
- commentCount - Variable in class org.apache.flink.api.common.io.GenericCsvInputFormat
-
- commentPrefix - Variable in class org.apache.flink.api.common.io.GenericCsvInputFormat
-
- commentPrefix - Variable in class org.apache.flink.api.java.io.CsvReader
-
- commit() - Method in class org.apache.flink.runtime.io.network.buffer.BufferBuilder
-
Make the change visible to the readers.
- commit(TXN) - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
-
Commit a pre-committed transaction.
- commit(FlinkKafkaProducer011.KafkaTransactionState) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer011
-
- commitCheckpoint(int, long) - Method in class org.apache.flink.streaming.connectors.cassandra.CassandraCommitter
-
- commitCheckpoint(int, long) - Method in class org.apache.flink.streaming.runtime.operators.CheckpointCommitter
-
Mark the given checkpoint as completed in the resource.
- commitDate - Variable in class org.apache.flink.runtime.util.EnvironmentInformation.RevisionInformation
-
The git commit date
- commitId - Variable in class org.apache.flink.runtime.util.EnvironmentInformation.RevisionInformation
-
The git commit id (hash)
- commitInternalOffsetsToKafka(Map<KafkaTopicPartition, Long>, KafkaCommitCallback) - Method in class org.apache.flink.streaming.connectors.kafka.internals.AbstractFetcher
-
Commits the given partition offsets to the Kafka brokers (or to ZooKeeper for
older Kafka versions).
- COMMITS_FAILED_METRICS_COUNTER - Static variable in class org.apache.flink.streaming.connectors.kafka.internals.metrics.KafkaConsumerMetricConstants
-
- COMMITS_SUCCEEDED_METRICS_COUNTER - Static variable in class org.apache.flink.streaming.connectors.kafka.internals.metrics.KafkaConsumerMetricConstants
-
- COMMITTED_OFFSETS_METRICS_GAUGE - Static variable in class org.apache.flink.streaming.connectors.kafka.internals.metrics.KafkaConsumerMetricConstants
-
- committer - Variable in class org.apache.flink.streaming.connectors.cassandra.CassandraSink.CassandraSinkBuilder
-
- commitTransaction() - Method in class org.apache.flink.streaming.connectors.kafka.internal.FlinkKafkaProducer
-
- CommonRangeBoundaries<T> - Class in org.apache.flink.api.common.distributions
-
- CommonRangeBoundaries(TypeComparator<T>, Object[][]) - Constructor for class org.apache.flink.api.common.distributions.CommonRangeBoundaries
-
- CommonTestUtils - Class in org.apache.flink.core.testutils
-
This class contains reusable utility methods for unit tests.
- CommonTestUtils() - Constructor for class org.apache.flink.core.testutils.CommonTestUtils
-
- COMMUNITIES_RESULT - Static variable in class org.apache.flink.graph.examples.data.MusicProfilesData
-
- COMMUNITIES_SINGLE_ITERATION - Static variable in class org.apache.flink.graph.examples.data.CommunityDetectionData
-
- COMMUNITIES_WITH_TIE - Static variable in class org.apache.flink.graph.examples.data.CommunityDetectionData
-
- CommunityDetection<K> - Class in org.apache.flink.graph.library
-
Community Detection Algorithm.
- CommunityDetection(int, double) - Constructor for class org.apache.flink.graph.library.CommunityDetection
-
Creates a new Community Detection algorithm instance.
- CommunityDetectionData - Class in org.apache.flink.graph.examples.data
-
Provides the default data set used for the Simple Community Detection test program.
- CompactingHashTable<T> - Class in org.apache.flink.runtime.operators.hash
-
A hash table that uses Flink's managed memory and supports replacement of records or
updates to records.
- CompactingHashTable(TypeSerializer<T>, TypeComparator<T>, List<MemorySegment>) - Constructor for class org.apache.flink.runtime.operators.hash.CompactingHashTable
-
- CompactingHashTable(TypeSerializer<T>, TypeComparator<T>, List<MemorySegment>, int) - Constructor for class org.apache.flink.runtime.operators.hash.CompactingHashTable
-
- CompactingHashTable.EntryIterator - Class in org.apache.flink.runtime.operators.hash
-
Iterator that traverses the whole hash table once
If entries are inserted during iteration they may be overlooked by the iterator
- CompactingHashTable.HashTableProber<PT> - Class in org.apache.flink.runtime.operators.hash
-
- ComparableAggregator<T> - Class in org.apache.flink.streaming.api.functions.aggregation
-
- ComparableAggregator(int, TypeInformation<T>, AggregationFunction.AggregationType, ExecutionConfig) - Constructor for class org.apache.flink.streaming.api.functions.aggregation.ComparableAggregator
-
- ComparableAggregator(int, TypeInformation<T>, AggregationFunction.AggregationType, boolean, ExecutionConfig) - Constructor for class org.apache.flink.streaming.api.functions.aggregation.ComparableAggregator
-
- ComparableAggregator(String, TypeInformation<T>, AggregationFunction.AggregationType, boolean, ExecutionConfig) - Constructor for class org.apache.flink.streaming.api.functions.aggregation.ComparableAggregator
-
- comparator - Variable in class org.apache.flink.api.common.typeutils.base.array.PrimitiveArrayComparator
-
- comparator - Variable in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SpillingThread
-
- Comparator - Class in org.apache.flink.streaming.api.functions.aggregation
-
- Comparator() - Constructor for class org.apache.flink.streaming.api.functions.aggregation.Comparator
-
- Comparator() - Constructor for class org.apache.flink.streaming.connectors.kafka.internals.KafkaTopicPartition.Comparator
-
- comparators - Variable in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
-
comparators for the key fields, in the same order as the key fields
- compare(boolean[], boolean[]) - Method in class org.apache.flink.api.common.typeutils.base.array.BooleanPrimitiveArrayComparator
-
- compare(byte[], byte[]) - Method in class org.apache.flink.api.common.typeutils.base.array.BytePrimitiveArrayComparator
-
- compare(char[], char[]) - Method in class org.apache.flink.api.common.typeutils.base.array.CharPrimitiveArrayComparator
-
- compare(double[], double[]) - Method in class org.apache.flink.api.common.typeutils.base.array.DoublePrimitiveArrayComparator
-
- compare(float[], float[]) - Method in class org.apache.flink.api.common.typeutils.base.array.FloatPrimitiveArrayComparator
-
- compare(int[], int[]) - Method in class org.apache.flink.api.common.typeutils.base.array.IntPrimitiveArrayComparator
-
- compare(long[], long[]) - Method in class org.apache.flink.api.common.typeutils.base.array.LongPrimitiveArrayComparator
-
- compare(short[], short[]) - Method in class org.apache.flink.api.common.typeutils.base.array.ShortPrimitiveArrayComparator
-
- compare(T, T) - Method in class org.apache.flink.api.common.typeutils.base.BasicTypeComparator
-
- compare(BooleanValue, BooleanValue) - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueComparator
-
- compare(ByteValue, ByteValue) - Method in class org.apache.flink.api.common.typeutils.base.ByteValueComparator
-
- compare(CharValue, CharValue) - Method in class org.apache.flink.api.common.typeutils.base.CharValueComparator
-
- compare(DoubleValue, DoubleValue) - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueComparator
-
- compare(FloatValue, FloatValue) - Method in class org.apache.flink.api.common.typeutils.base.FloatValueComparator
-
- compare(IntValue, IntValue) - Method in class org.apache.flink.api.common.typeutils.base.IntValueComparator
-
- compare(LongValue, LongValue) - Method in class org.apache.flink.api.common.typeutils.base.LongValueComparator
-
- compare(NullValue, NullValue) - Method in class org.apache.flink.api.common.typeutils.base.NullValueComparator
-
- compare(ShortValue, ShortValue) - Method in class org.apache.flink.api.common.typeutils.base.ShortValueComparator
-
- compare(StringValue, StringValue) - Method in class org.apache.flink.api.common.typeutils.base.StringValueComparator
-
- compare(T, T) - Method in class org.apache.flink.api.common.typeutils.TypeComparator
-
Compares two records in object form.
- compare(T, T) - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueComparator
-
- compare(T, T) - Method in class org.apache.flink.api.java.typeutils.runtime.GenericTypeComparator
-
- compare(T, T) - Method in class org.apache.flink.api.java.typeutils.runtime.NullAwareComparator
-
- compare(T, T) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoComparator
-
- compare(Row, Row) - Method in class org.apache.flink.api.java.typeutils.runtime.RowComparator
-
- compare(T, T) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparator
-
- compare(T, T) - Method in class org.apache.flink.api.java.typeutils.runtime.ValueComparator
-
- compare(T, T) - Method in class org.apache.flink.api.java.typeutils.runtime.WritableComparator
-
- compare(StreamRecord<IN>, StreamRecord<IN>) - Method in class org.apache.flink.cep.operator.StreamRecordComparator
-
- compare(MemorySegment, int, int, int) - Method in class org.apache.flink.core.memory.MemorySegment
-
Compares two memory segment regions.
- compare(ByteValueArray, ByteValueArray) - Method in class org.apache.flink.graph.types.valuearray.ByteValueArrayComparator
-
- compare(CharValueArray, CharValueArray) - Method in class org.apache.flink.graph.types.valuearray.CharValueArrayComparator
-
- compare(DoubleValueArray, DoubleValueArray) - Method in class org.apache.flink.graph.types.valuearray.DoubleValueArrayComparator
-
- compare(FloatValueArray, FloatValueArray) - Method in class org.apache.flink.graph.types.valuearray.FloatValueArrayComparator
-
- compare(IntValueArray, IntValueArray) - Method in class org.apache.flink.graph.types.valuearray.IntValueArrayComparator
-
- compare(LongValueArray, LongValueArray) - Method in class org.apache.flink.graph.types.valuearray.LongValueArrayComparator
-
- compare(NullValueArray, NullValueArray) - Method in class org.apache.flink.graph.types.valuearray.NullValueArrayComparator
-
- compare(ShortValueArray, ShortValueArray) - Method in class org.apache.flink.graph.types.valuearray.ShortValueArrayComparator
-
- compare(StringValueArray, StringValueArray) - Method in class org.apache.flink.graph.types.valuearray.StringValueArrayComparator
-
- compare(int, int) - Method in class org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
-
- compare(int, int, int, int) - Method in class org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
-
- compare(int, int) - Method in interface org.apache.flink.runtime.operators.sort.IndexedSortable
-
- compare(int, int, int, int) - Method in interface org.apache.flink.runtime.operators.sort.IndexedSortable
-
- compare(int, int) - Method in class org.apache.flink.runtime.operators.sort.NormalizedKeySorter
-
- compare(int, int, int, int) - Method in class org.apache.flink.runtime.operators.sort.NormalizedKeySorter
-
- compare(String, String) - Method in class org.apache.flink.runtime.rest.RestServerEndpoint.RestHandlerUrlComparator.CaseInsensitiveOrderComparator
-
- compare(Tuple2<RestHandlerSpecification, ChannelInboundHandler>, Tuple2<RestHandlerSpecification, ChannelInboundHandler>) - Method in class org.apache.flink.runtime.rest.RestServerEndpoint.RestHandlerUrlComparator
-
- compare(KafkaTopicPartition, KafkaTopicPartition) - Method in class org.apache.flink.streaming.connectors.kafka.internals.KafkaTopicPartition.Comparator
-
- compare(T, T) - Method in class org.apache.flink.test.util.TestBaseUtils.TupleComparator
-
- compareAccumulatorTypes(Object, Class<? extends Accumulator>, Class<? extends Accumulator>) - Static method in class org.apache.flink.api.common.accumulators.AccumulatorHelper
-
- compareAgainstReference(Comparable[]) - Method in class org.apache.flink.api.common.typeutils.TypeComparator
-
- compareKeyValuePairsWithDelta(String, String, String, double) - Static method in class org.apache.flink.test.util.TestBaseUtils
-
- compareKeyValuePairsWithDelta(String, String, String[], String, double) - Static method in class org.apache.flink.test.util.TestBaseUtils
-
- compareOrderedResultAsText(List<T>, String) - Static method in class org.apache.flink.test.util.TestBaseUtils
-
- compareOrderedResultAsText(List<T>, String, boolean) - Static method in class org.apache.flink.test.util.TestBaseUtils
-
- compareResultAsText(List<T>, String) - Static method in class org.apache.flink.test.util.TestBaseUtils
-
- compareResultAsTuples(List<T>, String) - Static method in class org.apache.flink.test.util.TestBaseUtils
-
- compareResultCollections(List<X>, List<X>, Comparator<X>) - Static method in class org.apache.flink.test.util.TestBaseUtils
-
- compareResultsByLinesInMemory(String, String) - Static method in class org.apache.flink.test.util.TestBaseUtils
-
- compareResultsByLinesInMemory(String, String, String[]) - Static method in class org.apache.flink.test.util.TestBaseUtils
-
- compareResultsByLinesInMemoryWithStrictOrder(String, String) - Static method in class org.apache.flink.test.util.TestBaseUtils
-
- compareResultsByLinesInMemoryWithStrictOrder(String, String, String[]) - Static method in class org.apache.flink.test.util.TestBaseUtils
-
- compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.array.PrimitiveArrayComparator
-
- compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.BigDecComparator
-
- compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.BigIntComparator
-
- compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.BooleanComparator
-
- compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueComparator
-
- compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.ByteComparator
-
- compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.ByteValueComparator
-
- compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.CharComparator
-
- compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.CharValueComparator
-
- compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.DateComparator
-
- compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.DoubleComparator
-
- compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueComparator
-
- compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.EnumComparator
-
- compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.FloatComparator
-
- compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.FloatValueComparator
-
- compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.IntComparator
-
- compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.IntValueComparator
-
- compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.LongComparator
-
- compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.LongValueComparator
-
- compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.NullValueComparator
-
- compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.ShortComparator
-
- compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.ShortValueComparator
-
- compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.SqlTimestampComparator
-
- compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.StringComparator
-
- compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.StringValueComparator
-
- compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.TypeComparator
-
Compares two records in serialized form.
- compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueComparator
-
- compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.GenericTypeComparator
-
- compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.NullAwareComparator
-
- compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoComparator
-
- compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.RowComparator
-
- compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
-
- compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.ValueComparator
-
- compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.WritableComparator
-
- compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.graph.types.valuearray.ByteValueArrayComparator
-
- compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.graph.types.valuearray.CharValueArrayComparator
-
- compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.graph.types.valuearray.DoubleValueArrayComparator
-
- compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.graph.types.valuearray.FloatValueArrayComparator
-
- compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.graph.types.valuearray.IntValueArrayComparator
-
- compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.graph.types.valuearray.LongValueArrayComparator
-
- compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.graph.types.valuearray.NullValueArrayComparator
-
- compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.graph.types.valuearray.ShortValueArrayComparator
-
- compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.graph.types.valuearray.StringValueArrayComparator
-
- compareSerializedDate(DataInputView, DataInputView, boolean) - Static method in class org.apache.flink.api.common.typeutils.base.DateComparator
-
- compareTo(IntermediateSampleData<T>) - Method in class org.apache.flink.api.java.sampling.IntermediateSampleData
-
- compareTo(BlockLocation) - Method in class org.apache.flink.core.fs.local.LocalBlockLocation
-
- compareTo(Object) - Method in class org.apache.flink.core.fs.Path
-
- compareTo(CirculantGraph.OffsetRange) - Method in class org.apache.flink.graph.generator.CirculantGraph.OffsetRange
-
- compareTo(AdamicAdar.Result<T>) - Method in class org.apache.flink.graph.library.similarity.AdamicAdar.Result
-
- compareTo(JaccardIndex.Result<T>) - Method in class org.apache.flink.graph.library.similarity.JaccardIndex.Result
-
- compareTo(ValueArray<ByteValue>) - Method in class org.apache.flink.graph.types.valuearray.ByteValueArray
-
- compareTo(ValueArray<CharValue>) - Method in class org.apache.flink.graph.types.valuearray.CharValueArray
-
- compareTo(ValueArray<DoubleValue>) - Method in class org.apache.flink.graph.types.valuearray.DoubleValueArray
-
- compareTo(ValueArray<FloatValue>) - Method in class org.apache.flink.graph.types.valuearray.FloatValueArray
-
- compareTo(ValueArray<IntValue>) - Method in class org.apache.flink.graph.types.valuearray.IntValueArray
-
- compareTo(ValueArray<LongValue>) - Method in class org.apache.flink.graph.types.valuearray.LongValueArray
-
- compareTo(ValueArray<NullValue>) - Method in class org.apache.flink.graph.types.valuearray.NullValueArray
-
- compareTo(ValueArray<ShortValue>) - Method in class org.apache.flink.graph.types.valuearray.ShortValueArray
-
- compareTo(ValueArray<StringValue>) - Method in class org.apache.flink.graph.types.valuearray.StringValueArray
-
- compareTo(Costs) - Method in class org.apache.flink.optimizer.costs.Costs
-
The order of comparison is: network first, then disk, then CPU.
- compareTo(BlobKey) - Method in class org.apache.flink.runtime.blob.BlobKey
-
- compareTo(ResourceProfile) - Method in class org.apache.flink.runtime.clusterframework.types.ResourceProfile
-
- compareTo(BlockLocation) - Method in class org.apache.flink.runtime.fs.hdfs.HadoopBlockLocation
-
- compareTo(TaskManagerLocation) - Method in class org.apache.flink.runtime.taskmanager.TaskManagerLocation
-
- compareTo(TimestampedFileInputSplit) - Method in class org.apache.flink.streaming.api.functions.source.TimestampedFileInputSplit
-
- compareTo(InternalTimer<K, N>) - Method in class org.apache.flink.streaming.api.operators.InternalTimer
-
- compareTo(WindowOperator.Timer<K, W>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Timer
-
- compareTo(BooleanValue) - Method in class org.apache.flink.types.BooleanValue
-
- compareTo(ByteValue) - Method in class org.apache.flink.types.ByteValue
-
- compareTo(CharValue) - Method in class org.apache.flink.types.CharValue
-
- compareTo(DoubleValue) - Method in class org.apache.flink.types.DoubleValue
-
- compareTo(FloatValue) - Method in class org.apache.flink.types.FloatValue
-
- compareTo(IntValue) - Method in class org.apache.flink.types.IntValue
-
- compareTo(LongValue) - Method in class org.apache.flink.types.LongValue
-
- compareTo(NullValue) - Method in class org.apache.flink.types.NullValue
-
- compareTo(ShortValue) - Method in class org.apache.flink.types.ShortValue
-
- compareTo(StringValue) - Method in class org.apache.flink.types.StringValue
-
- compareTo(AbstractID) - Method in class org.apache.flink.util.AbstractID
-
- compareToReference(TypeComparator<T>) - Method in class org.apache.flink.api.common.typeutils.base.array.PrimitiveArrayComparator
-
- compareToReference(TypeComparator<T>) - Method in class org.apache.flink.api.common.typeutils.base.BasicTypeComparator
-
- compareToReference(TypeComparator<BooleanValue>) - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueComparator
-
- compareToReference(TypeComparator<ByteValue>) - Method in class org.apache.flink.api.common.typeutils.base.ByteValueComparator
-
- compareToReference(TypeComparator<CharValue>) - Method in class org.apache.flink.api.common.typeutils.base.CharValueComparator
-
- compareToReference(TypeComparator<DoubleValue>) - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueComparator
-
- compareToReference(TypeComparator<FloatValue>) - Method in class org.apache.flink.api.common.typeutils.base.FloatValueComparator
-
- compareToReference(TypeComparator<IntValue>) - Method in class org.apache.flink.api.common.typeutils.base.IntValueComparator
-
- compareToReference(TypeComparator<LongValue>) - Method in class org.apache.flink.api.common.typeutils.base.LongValueComparator
-
- compareToReference(TypeComparator<NullValue>) - Method in class org.apache.flink.api.common.typeutils.base.NullValueComparator
-
- compareToReference(TypeComparator<ShortValue>) - Method in class org.apache.flink.api.common.typeutils.base.ShortValueComparator
-
- compareToReference(TypeComparator<StringValue>) - Method in class org.apache.flink.api.common.typeutils.base.StringValueComparator
-
- compareToReference(T2) - Method in class org.apache.flink.api.common.typeutils.GenericPairComparator
-
- compareToReference(T) - Method in class org.apache.flink.api.common.typeutils.SameTypePairComparator
-
- compareToReference(TypeComparator<T>) - Method in class org.apache.flink.api.common.typeutils.TypeComparator
-
This method compares the element that has been set as reference in this type accessor, to the
element set as reference in the given type accessor.
- compareToReference(T2) - Method in class org.apache.flink.api.common.typeutils.TypePairComparator
-
- compareToReference(TypeComparator<T>) - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueComparator
-
- compareToReference(TypeComparator<T>) - Method in class org.apache.flink.api.java.typeutils.runtime.GenericTypeComparator
-
- compareToReference(TypeComparator<T>) - Method in class org.apache.flink.api.java.typeutils.runtime.NullAwareComparator
-
- compareToReference(TypeComparator<T>) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoComparator
-
- compareToReference(TypeComparator<Row>) - Method in class org.apache.flink.api.java.typeutils.runtime.RowComparator
-
- compareToReference(TypeComparator<T>) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
-
- compareToReference(TypeComparator<T>) - Method in class org.apache.flink.api.java.typeutils.runtime.ValueComparator
-
- compareToReference(TypeComparator<T>) - Method in class org.apache.flink.api.java.typeutils.runtime.WritableComparator
-
- compareToReference(TypeComparator<ByteValueArray>) - Method in class org.apache.flink.graph.types.valuearray.ByteValueArrayComparator
-
- compareToReference(TypeComparator<CharValueArray>) - Method in class org.apache.flink.graph.types.valuearray.CharValueArrayComparator
-
- compareToReference(TypeComparator<DoubleValueArray>) - Method in class org.apache.flink.graph.types.valuearray.DoubleValueArrayComparator
-
- compareToReference(TypeComparator<FloatValueArray>) - Method in class org.apache.flink.graph.types.valuearray.FloatValueArrayComparator
-
- compareToReference(TypeComparator<IntValueArray>) - Method in class org.apache.flink.graph.types.valuearray.IntValueArrayComparator
-
- compareToReference(TypeComparator<LongValueArray>) - Method in class org.apache.flink.graph.types.valuearray.LongValueArrayComparator
-
- compareToReference(TypeComparator<NullValueArray>) - Method in class org.apache.flink.graph.types.valuearray.NullValueArrayComparator
-
- compareToReference(TypeComparator<ShortValueArray>) - Method in class org.apache.flink.graph.types.valuearray.ShortValueArrayComparator
-
- compareToReference(TypeComparator<StringValueArray>) - Method in class org.apache.flink.graph.types.valuearray.StringValueArrayComparator
-
- CompatibilityResult<T> - Class in org.apache.flink.api.common.typeutils
-
A CompatibilityResult
contains information about whether or not data migration
is required in order to continue using new serializers for previously serialized data.
- CompatibilityUtil - Class in org.apache.flink.api.common.typeutils
-
Utilities related to serializer compatibility.
- CompatibilityUtil() - Constructor for class org.apache.flink.api.common.typeutils.CompatibilityUtil
-
- compatible() - Static method in class org.apache.flink.api.common.typeutils.CompatibilityResult
-
Returns a result that signals that the new serializer is compatible and no migration is required.
- CompensatedSum - Class in org.apache.flink.api.java.summarize.aggregation
-
Used to calculate sums using the Kahan summation algorithm.
- CompensatedSum(double, double) - Constructor for class org.apache.flink.api.java.summarize.aggregation.CompensatedSum
-
Used to calculate sums using the Kahan summation algorithm.
- compile(Pattern<T, ?>, TypeSerializer<T>, boolean) - Static method in class org.apache.flink.cep.nfa.compiler.NFACompiler
-
Compiles the given pattern into a
NFA
.
- compile(Plan) - Method in class org.apache.flink.optimizer.Optimizer
-
Translates the given program to an OptimizedPlan, where all nodes have their local strategy assigned
and all channels have a shipping strategy assigned.
- compileFactory(Pattern<T, ?>, TypeSerializer<T>, boolean) - Static method in class org.apache.flink.cep.nfa.compiler.NFACompiler
-
- compileJobGraph(OptimizedPlan) - Method in class org.apache.flink.optimizer.plantranslate.JobGraphGenerator
-
- compileJobGraph(OptimizedPlan, JobID) - Method in class org.apache.flink.optimizer.plantranslate.JobGraphGenerator
-
- CompilerException - Exception in org.apache.flink.optimizer
-
An exception that is thrown by the Optimizer when encountering an illegal condition.
- CompilerException() - Constructor for exception org.apache.flink.optimizer.CompilerException
-
Creates a compiler exception with no message and no cause.
- CompilerException(String) - Constructor for exception org.apache.flink.optimizer.CompilerException
-
Creates a compiler exception with the given message and no cause.
- CompilerException(Throwable) - Constructor for exception org.apache.flink.optimizer.CompilerException
-
Creates a compiler exception with the given cause and no message.
- CompilerException(String, Throwable) - Constructor for exception org.apache.flink.optimizer.CompilerException
-
Creates a compiler exception with the given message and cause.
- CompilerHints - Class in org.apache.flink.api.common.operators
-
A class encapsulating compiler hints describing the behavior of the user function.
- CompilerHints() - Constructor for class org.apache.flink.api.common.operators.CompilerHints
-
- compilerHints - Variable in class org.apache.flink.api.common.operators.Operator
-
- CompilerPostPassException - Exception in org.apache.flink.optimizer
-
An exception that is thrown by the Optimizer when encountering
a problem during the optimizer post pass.
- CompilerPostPassException() - Constructor for exception org.apache.flink.optimizer.CompilerPostPassException
-
Creates a post pass exception with no message and no cause.
- CompilerPostPassException(String) - Constructor for exception org.apache.flink.optimizer.CompilerPostPassException
-
Creates a post pass exception with the given message and no cause.
- CompilerPostPassException(Throwable) - Constructor for exception org.apache.flink.optimizer.CompilerPostPassException
-
Creates a post pass exception with the given cause and no message.
- CompilerPostPassException(String, Throwable) - Constructor for exception org.apache.flink.optimizer.CompilerPostPassException
-
Creates a post pass exception with the given message and cause.
- complementBlockInfo(BlockInfo) - Method in class org.apache.flink.api.common.io.BinaryOutputFormat
-
- complete() - Static method in class org.apache.flink.runtime.rest.handler.async.AsynchronousOperationInfo
-
- complete(Collection<OUT>) - Method in interface org.apache.flink.streaming.api.functions.async.ResultFuture
-
Completes the result future with a collection of result objects.
- complete(Collection<OUT>) - Method in class org.apache.flink.streaming.api.operators.async.queue.StreamRecordQueueEntry
-
- completeAll(Collection<? extends CompletableFuture<?>>) - Static method in class org.apache.flink.runtime.concurrent.FutureUtils
-
- completeAllocation(AllocationID, JobID) - Method in class org.apache.flink.runtime.clusterframework.types.TaskManagerSlot
-
- completed(V) - Static method in class org.apache.flink.runtime.rest.handler.async.AsynchronousOperationResult
-
- completed() - Static method in class org.apache.flink.runtime.rest.messages.queue.QueueStatus
-
- CompletedCheckpoint - Class in org.apache.flink.runtime.checkpoint
-
A CompletedCheckpoint describes a checkpoint after all required tasks acknowledged it (with their state)
and that is considered successful.
- CompletedCheckpoint(JobID, long, long, long, Map<OperatorID, OperatorState>, Collection<MasterState>, CheckpointProperties, CompletedCheckpointStorageLocation) - Constructor for class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
-
- CompletedCheckpointStatistics(long, CheckpointStatsStatus, boolean, long, long, long, long, long, int, int, Map<JobVertexID, TaskCheckpointStatistics>, String, boolean) - Constructor for class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics.CompletedCheckpointStatistics
-
- CompletedCheckpointStats - Class in org.apache.flink.runtime.checkpoint
-
Statistics for a successfully completed checkpoint.
- CompletedCheckpointStatsSummary - Class in org.apache.flink.runtime.checkpoint
-
Summary over all completed checkpoints.
- CompletedCheckpointStorageLocation - Interface in org.apache.flink.runtime.state
-
The CompletedCheckpointStorageLocation describes the storage aspect of a completed checkpoint.
- CompletedCheckpointStore - Interface in org.apache.flink.runtime.checkpoint
-
- completedExceptionally(Throwable) - Static method in class org.apache.flink.runtime.concurrent.FutureUtils
-
- CompletedSubtaskCheckpointStatistics(int, long, long, long, SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics.CheckpointDuration, SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics.CheckpointAlignment) - Constructor for class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics
-
- completeExceptional(SerializedThrowable) - Static method in class org.apache.flink.runtime.rest.handler.async.AsynchronousOperationInfo
-
- completeExceptionally(Throwable) - Method in interface org.apache.flink.streaming.api.functions.async.ResultFuture
-
Completes the result future exceptionally with an exception.
- completeExceptionally(Throwable) - Method in class org.apache.flink.streaming.api.operators.async.queue.StreamRecordQueueEntry
-
- CompleteGraph - Class in org.apache.flink.graph.drivers.input
-
- CompleteGraph() - Constructor for class org.apache.flink.graph.drivers.input.CompleteGraph
-
- CompleteGraph - Class in org.apache.flink.graph.generator
-
- CompleteGraph(ExecutionEnvironment, long) - Constructor for class org.apache.flink.graph.generator.CompleteGraph
-
An undirected
Graph
connecting every distinct pair of vertices.
- completeSnapshotAndGetHandle() - Method in class org.apache.flink.runtime.state.SnapshotDirectory
-
Calling this method completes the snapshot for this snapshot directory, if possible, and creates a corresponding
DirectoryStateHandle
that points to the snapshot directory.
- ComplexPayload - Class in org.apache.flink.streaming.tests.artificialstate
-
- ComplexPayload(Event, String) - Constructor for class org.apache.flink.streaming.tests.artificialstate.ComplexPayload
-
- ComplexPayload(Event) - Constructor for class org.apache.flink.streaming.tests.artificialstate.ComplexPayload
-
- ComplexPayload.InnerPayLoad - Class in org.apache.flink.streaming.tests.artificialstate
-
Nested class in state type.
- ComponentIdFilter() - Constructor for class org.apache.flink.examples.java.graph.ConnectedComponents.ComponentIdFilter
-
- ComponentMetricGroup<P extends AbstractMetricGroup<?>> - Class in org.apache.flink.runtime.metrics.groups
-
Abstract
MetricGroup
for system components (e.g.,
TaskManager, Job, Task, Operator).
- ComponentMetricGroup(MetricRegistry, String[], P) - Constructor for class org.apache.flink.runtime.metrics.groups.ComponentMetricGroup
-
Creates a new ComponentMetricGroup.
- composeAfterwards(CompletableFuture<?>, Supplier<CompletableFuture<?>>) - Static method in class org.apache.flink.runtime.concurrent.FutureUtils
-
Run the given asynchronous action after the completion of the given future.
- compositeBuffer() - Method in class org.apache.flink.queryablestate.network.NettyBufferPool
-
- compositeBuffer(int) - Method in class org.apache.flink.queryablestate.network.NettyBufferPool
-
- CompositeContainerOverlay - Class in org.apache.flink.runtime.clusterframework.overlays
-
A composite overlay that delegates to a set of inner overlays.
- CompositeContainerOverlay(ContainerOverlay...) - Constructor for class org.apache.flink.runtime.clusterframework.overlays.CompositeContainerOverlay
-
- CompositeContainerOverlay(List<ContainerOverlay>) - Constructor for class org.apache.flink.runtime.clusterframework.overlays.CompositeContainerOverlay
-
- compositeDirectBuffer() - Method in class org.apache.flink.queryablestate.network.NettyBufferPool
-
- compositeDirectBuffer(int) - Method in class org.apache.flink.queryablestate.network.NettyBufferPool
-
- compositeHeapBuffer() - Method in class org.apache.flink.queryablestate.network.NettyBufferPool
-
- compositeHeapBuffer(int) - Method in class org.apache.flink.queryablestate.network.NettyBufferPool
-
- compositeHeapBuffer() - Method in class org.apache.flink.runtime.io.network.netty.NettyBufferPool
-
- compositeHeapBuffer(int) - Method in class org.apache.flink.runtime.io.network.netty.NettyBufferPool
-
- CompositeStateHandle - Interface in org.apache.flink.runtime.state
-
Base of all snapshots that are taken by
StateBackend
s and some other
components in tasks.
- CompositeType<T> - Class in org.apache.flink.api.common.typeutils
-
Base type information class for Tuple and Pojo types
The class is taking care of serialization and comparators for Tuples as well.
- CompositeType(Class<T>) - Constructor for class org.apache.flink.api.common.typeutils.CompositeType
-
- CompositeType.FlatFieldDescriptor - Class in org.apache.flink.api.common.typeutils
-
- CompositeType.InvalidFieldReferenceException - Exception in org.apache.flink.api.common.typeutils
-
- CompositeType.TypeComparatorBuilder<T> - Interface in org.apache.flink.api.common.typeutils
-
- CompositeTypeComparator<T> - Class in org.apache.flink.api.common.typeutils
-
- CompositeTypeComparator() - Constructor for class org.apache.flink.api.common.typeutils.CompositeTypeComparator
-
- CompositeTypeSerializerConfigSnapshot - Class in org.apache.flink.api.common.typeutils
-
- CompositeTypeSerializerConfigSnapshot() - Constructor for class org.apache.flink.api.common.typeutils.CompositeTypeSerializerConfigSnapshot
-
This empty nullary constructor is required for deserializing the configuration.
- CompositeTypeSerializerConfigSnapshot(TypeSerializer<?>...) - Constructor for class org.apache.flink.api.common.typeutils.CompositeTypeSerializerConfigSnapshot
-
- ComputationState<T> - Class in org.apache.flink.cep.nfa
-
Helper class which encapsulates the state of the NFA computation.
- ComputationState.ConditionContext - Class in org.apache.flink.cep.nfa
-
The context used when evaluating this computation state.
- compute(Vertex<Long, Double>, MessageIterator<Double>) - Method in class org.apache.flink.graph.examples.PregelSSSP.SSSPComputeFunction
-
- compute(Vertex<K, VV>, MessageIterator<Message>) - Method in class org.apache.flink.graph.pregel.ComputeFunction
-
This method is invoked once per superstep, for each active vertex.
- computeColumnWidth(int) - Method in class org.apache.flink.table.client.cli.CliChangelogResultView
-
- computeColumnWidth(int) - Method in class org.apache.flink.table.client.cli.CliResultView
-
- computeColumnWidth(int) - Method in class org.apache.flink.table.client.cli.CliTableResultView
-
- computeDefaultMaxParallelism(int) - Static method in class org.apache.flink.runtime.state.KeyGroupRangeAssignment
-
Computes a default maximum parallelism from the operator parallelism.
- computeFooterLines() - Method in class org.apache.flink.table.client.cli.CliChangelogResultView
-
- computeFooterLines() - Method in class org.apache.flink.table.client.cli.CliInputView
-
- computeFooterLines() - Method in class org.apache.flink.table.client.cli.CliRowView
-
- computeFooterLines() - Method in class org.apache.flink.table.client.cli.CliTableResultView
-
- computeFooterLines() - Method in class org.apache.flink.table.client.cli.CliView
-
- ComputeFunction<K,VV,EV,Message> - Class in org.apache.flink.graph.pregel
-
- ComputeFunction() - Constructor for class org.apache.flink.graph.pregel.ComputeFunction
-
- computeGlobalProperties(GlobalProperties) - Method in class org.apache.flink.optimizer.dag.PartitionNode.PartitionDescriptor
-
- computeGlobalProperties(GlobalProperties) - Method in class org.apache.flink.optimizer.dag.SortPartitionNode.SortPartitionDescriptor
-
- computeGlobalProperties(GlobalProperties, GlobalProperties) - Method in class org.apache.flink.optimizer.operators.AbstractJoinDescriptor
-
- computeGlobalProperties(GlobalProperties) - Method in class org.apache.flink.optimizer.operators.AllGroupCombineProperties
-
- computeGlobalProperties(GlobalProperties) - Method in class org.apache.flink.optimizer.operators.AllGroupReduceProperties
-
- computeGlobalProperties(GlobalProperties) - Method in class org.apache.flink.optimizer.operators.AllGroupWithPartialPreGroupProperties
-
- computeGlobalProperties(GlobalProperties) - Method in class org.apache.flink.optimizer.operators.AllReduceProperties
-
- computeGlobalProperties(GlobalProperties, GlobalProperties) - Method in class org.apache.flink.optimizer.operators.BinaryUnionOpDescriptor
-
- computeGlobalProperties(GlobalProperties, GlobalProperties) - Method in class org.apache.flink.optimizer.operators.CartesianProductDescriptor
-
- computeGlobalProperties(GlobalProperties, GlobalProperties) - Method in class org.apache.flink.optimizer.operators.CoGroupDescriptor
-
- computeGlobalProperties(GlobalProperties, GlobalProperties) - Method in class org.apache.flink.optimizer.operators.CoGroupRawDescriptor
-
- computeGlobalProperties(GlobalProperties) - Method in class org.apache.flink.optimizer.operators.FilterDescriptor
-
- computeGlobalProperties(GlobalProperties) - Method in class org.apache.flink.optimizer.operators.FlatMapDescriptor
-
- computeGlobalProperties(GlobalProperties) - Method in class org.apache.flink.optimizer.operators.GroupCombineProperties
-
- computeGlobalProperties(GlobalProperties) - Method in class org.apache.flink.optimizer.operators.GroupReduceProperties
-
- computeGlobalProperties(GlobalProperties) - Method in class org.apache.flink.optimizer.operators.GroupReduceWithCombineProperties
-
- computeGlobalProperties(GlobalProperties) - Method in class org.apache.flink.optimizer.operators.MapDescriptor
-
- computeGlobalProperties(GlobalProperties) - Method in class org.apache.flink.optimizer.operators.MapPartitionDescriptor
-
- computeGlobalProperties(GlobalProperties) - Method in class org.apache.flink.optimizer.operators.NoOpDescriptor
-
- computeGlobalProperties(GlobalProperties, GlobalProperties) - Method in class org.apache.flink.optimizer.operators.OperatorDescriptorDual
-
- computeGlobalProperties(GlobalProperties) - Method in class org.apache.flink.optimizer.operators.OperatorDescriptorSingle
-
Returns the global properties which are present after the operator was applied on the
provided global properties.
- computeGlobalProperties(GlobalProperties) - Method in class org.apache.flink.optimizer.operators.PartialGroupProperties
-
- computeGlobalProperties(GlobalProperties) - Method in class org.apache.flink.optimizer.operators.ReduceProperties
-
- computeGlobalProperties(GlobalProperties) - Method in class org.apache.flink.optimizer.operators.SolutionSetDeltaOperator
-
- computeGlobalProperties(GlobalProperties, GlobalProperties) - Method in class org.apache.flink.optimizer.operators.UtilSinkJoinOpDescriptor
-
- computeHeaderLines() - Method in class org.apache.flink.table.client.cli.CliChangelogResultView
-
- computeHeaderLines() - Method in class org.apache.flink.table.client.cli.CliInputView
-
- computeHeaderLines() - Method in class org.apache.flink.table.client.cli.CliRowView
-
- computeHeaderLines() - Method in class org.apache.flink.table.client.cli.CliTableResultView
-
- computeHeaderLines() - Method in class org.apache.flink.table.client.cli.CliView
-
- computeInterestingPropertiesForInputs(CostEstimator) - Method in class org.apache.flink.optimizer.dag.AbstractPartialSolutionNode
-
- computeInterestingPropertiesForInputs(CostEstimator) - Method in class org.apache.flink.optimizer.dag.BinaryUnionNode
-
- computeInterestingPropertiesForInputs(CostEstimator) - Method in class org.apache.flink.optimizer.dag.BulkIterationNode
-
- computeInterestingPropertiesForInputs(CostEstimator) - Method in class org.apache.flink.optimizer.dag.DataSinkNode
-
- computeInterestingPropertiesForInputs(CostEstimator) - Method in class org.apache.flink.optimizer.dag.DataSourceNode
-
- computeInterestingPropertiesForInputs(CostEstimator) - Method in class org.apache.flink.optimizer.dag.OptimizerNode
-
Tells the node to compute the interesting properties for its inputs.
- computeInterestingPropertiesForInputs(CostEstimator) - Method in class org.apache.flink.optimizer.dag.SingleInputNode
-
- computeInterestingPropertiesForInputs(CostEstimator) - Method in class org.apache.flink.optimizer.dag.TwoInputNode
-
- computeInterestingPropertiesForInputs(CostEstimator) - Method in class org.apache.flink.optimizer.dag.WorksetIterationNode
-
- computeKeyGroupForKeyHash(int, int) - Static method in class org.apache.flink.runtime.state.KeyGroupRangeAssignment
-
Assigns the given key to a key-group index.
- computeKeyGroupRangeForOperatorIndex(int, int, int) - Static method in class org.apache.flink.runtime.state.KeyGroupRangeAssignment
-
Computes the range of key-groups that are assigned to a given operator under the given parallelism and maximum
parallelism.
- computeLocalProperties(LocalProperties) - Method in class org.apache.flink.optimizer.dag.PartitionNode.PartitionDescriptor
-
- computeLocalProperties(LocalProperties) - Method in class org.apache.flink.optimizer.dag.SortPartitionNode.SortPartitionDescriptor
-
- computeLocalProperties(LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.AbstractSortMergeJoinDescriptor
-
- computeLocalProperties(LocalProperties) - Method in class org.apache.flink.optimizer.operators.AllGroupCombineProperties
-
- computeLocalProperties(LocalProperties) - Method in class org.apache.flink.optimizer.operators.AllGroupReduceProperties
-
- computeLocalProperties(LocalProperties) - Method in class org.apache.flink.optimizer.operators.AllGroupWithPartialPreGroupProperties
-
- computeLocalProperties(LocalProperties) - Method in class org.apache.flink.optimizer.operators.AllReduceProperties
-
- computeLocalProperties(LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.BinaryUnionOpDescriptor
-
- computeLocalProperties(LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.CoGroupDescriptor
-
- computeLocalProperties(LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.CoGroupRawDescriptor
-
- computeLocalProperties(LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.CoGroupWithSolutionSetFirstDescriptor
-
- computeLocalProperties(LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.CoGroupWithSolutionSetSecondDescriptor
-
- computeLocalProperties(LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.CrossBlockOuterFirstDescriptor
-
- computeLocalProperties(LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.CrossBlockOuterSecondDescriptor
-
- computeLocalProperties(LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.CrossStreamOuterFirstDescriptor
-
- computeLocalProperties(LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.CrossStreamOuterSecondDescriptor
-
- computeLocalProperties(LocalProperties) - Method in class org.apache.flink.optimizer.operators.FilterDescriptor
-
- computeLocalProperties(LocalProperties) - Method in class org.apache.flink.optimizer.operators.FlatMapDescriptor
-
- computeLocalProperties(LocalProperties) - Method in class org.apache.flink.optimizer.operators.GroupCombineProperties
-
- computeLocalProperties(LocalProperties) - Method in class org.apache.flink.optimizer.operators.GroupReduceProperties
-
- computeLocalProperties(LocalProperties) - Method in class org.apache.flink.optimizer.operators.GroupReduceWithCombineProperties
-
- computeLocalProperties(LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.HashFullOuterJoinBuildFirstDescriptor
-
- computeLocalProperties(LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.HashFullOuterJoinBuildSecondDescriptor
-
- computeLocalProperties(LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.HashJoinBuildFirstProperties
-
- computeLocalProperties(LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.HashJoinBuildSecondProperties
-
- computeLocalProperties(LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.HashLeftOuterJoinBuildFirstDescriptor
-
- computeLocalProperties(LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.HashLeftOuterJoinBuildSecondDescriptor
-
- computeLocalProperties(LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.HashRightOuterJoinBuildFirstDescriptor
-
- computeLocalProperties(LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.HashRightOuterJoinBuildSecondDescriptor
-
- computeLocalProperties(LocalProperties) - Method in class org.apache.flink.optimizer.operators.MapDescriptor
-
- computeLocalProperties(LocalProperties) - Method in class org.apache.flink.optimizer.operators.MapPartitionDescriptor
-
- computeLocalProperties(LocalProperties) - Method in class org.apache.flink.optimizer.operators.NoOpDescriptor
-
- computeLocalProperties(LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.OperatorDescriptorDual
-
- computeLocalProperties(LocalProperties) - Method in class org.apache.flink.optimizer.operators.OperatorDescriptorSingle
-
Returns the local properties which are present after the operator was applied on the
provided local properties.
- computeLocalProperties(LocalProperties) - Method in class org.apache.flink.optimizer.operators.PartialGroupProperties
-
- computeLocalProperties(LocalProperties) - Method in class org.apache.flink.optimizer.operators.ReduceProperties
-
- computeLocalProperties(LocalProperties) - Method in class org.apache.flink.optimizer.operators.SolutionSetDeltaOperator
-
- computeLocalProperties(LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.UtilSinkJoinOpDescriptor
-
- computeLogicalKeyPositions() - Method in class org.apache.flink.api.common.operators.Keys
-
- computeLogicalKeyPositions() - Method in class org.apache.flink.api.common.operators.Keys.ExpressionKeys
-
- computeLogicalKeyPositions() - Method in class org.apache.flink.api.common.operators.Keys.SelectorFunctionKeys
-
- computeMainHeaderLines() - Method in class org.apache.flink.table.client.cli.CliChangelogResultView
-
- computeMainHeaderLines() - Method in class org.apache.flink.table.client.cli.CliInputView
-
- computeMainHeaderLines() - Method in class org.apache.flink.table.client.cli.CliRowView
-
- computeMainHeaderLines() - Method in class org.apache.flink.table.client.cli.CliTableResultView
-
- computeMainHeaderLines() - Method in class org.apache.flink.table.client.cli.CliView
-
- computeMainLines() - Method in class org.apache.flink.table.client.cli.CliInputView
-
- computeMainLines() - Method in class org.apache.flink.table.client.cli.CliResultView
-
- computeMainLines() - Method in class org.apache.flink.table.client.cli.CliRowView
-
- computeMainLines() - Method in class org.apache.flink.table.client.cli.CliView
-
- computeMemorySize(double) - Method in class org.apache.flink.runtime.memory.MemoryManager
-
Computes the memory size of the fraction per slot.
- computeNumberOfPages(double) - Method in class org.apache.flink.runtime.memory.MemoryManager
-
Computes to how many pages the given number of bytes corresponds.
- computeOperatorIndexForKeyGroup(int, int, int) - Static method in class org.apache.flink.runtime.state.KeyGroupRangeAssignment
-
Computes the index of the operator to which a key-group belongs under the given parallelism and maximum
parallelism.
- computeOperatorSpecificDefaultEstimates(DataStatistics) - Method in class org.apache.flink.optimizer.dag.AbstractPartialSolutionNode
-
- computeOperatorSpecificDefaultEstimates(DataStatistics) - Method in class org.apache.flink.optimizer.dag.BinaryUnionNode
-
- computeOperatorSpecificDefaultEstimates(DataStatistics) - Method in class org.apache.flink.optimizer.dag.BulkIterationNode
-
- computeOperatorSpecificDefaultEstimates(DataStatistics) - Method in class org.apache.flink.optimizer.dag.CoGroupNode
-
- computeOperatorSpecificDefaultEstimates(DataStatistics) - Method in class org.apache.flink.optimizer.dag.CoGroupRawNode
-
- computeOperatorSpecificDefaultEstimates(DataStatistics) - Method in class org.apache.flink.optimizer.dag.CrossNode
-
We assume that the cardinality is the product of the input cardinalities
and that the result width is the sum of the input widths.
- computeOperatorSpecificDefaultEstimates(DataStatistics) - Method in class org.apache.flink.optimizer.dag.DataSinkNode
-
Computes the estimated outputs for the data sink.
- computeOperatorSpecificDefaultEstimates(DataStatistics) - Method in class org.apache.flink.optimizer.dag.DataSourceNode
-
- computeOperatorSpecificDefaultEstimates(DataStatistics) - Method in class org.apache.flink.optimizer.dag.FilterNode
-
Computes the estimates for the Filter operator.
- computeOperatorSpecificDefaultEstimates(DataStatistics) - Method in class org.apache.flink.optimizer.dag.FlatMapNode
-
Computes the estimates for the FlatMap operator.
- computeOperatorSpecificDefaultEstimates(DataStatistics) - Method in class org.apache.flink.optimizer.dag.GroupCombineNode
-
- computeOperatorSpecificDefaultEstimates(DataStatistics) - Method in class org.apache.flink.optimizer.dag.GroupReduceNode
-
- computeOperatorSpecificDefaultEstimates(DataStatistics) - Method in class org.apache.flink.optimizer.dag.JoinNode
-
The default estimates build on the principle of inclusion: The smaller input key domain is included in the larger
input key domain.
- computeOperatorSpecificDefaultEstimates(DataStatistics) - Method in class org.apache.flink.optimizer.dag.MapNode
-
Computes the estimates for the Map operator.
- computeOperatorSpecificDefaultEstimates(DataStatistics) - Method in class org.apache.flink.optimizer.dag.MapPartitionNode
-
Computes the estimates for the MapPartition operator.
- computeOperatorSpecificDefaultEstimates(DataStatistics) - Method in class org.apache.flink.optimizer.dag.NoOpNode
-
- computeOperatorSpecificDefaultEstimates(DataStatistics) - Method in class org.apache.flink.optimizer.dag.OptimizerNode
-
- computeOperatorSpecificDefaultEstimates(DataStatistics) - Method in class org.apache.flink.optimizer.dag.OuterJoinNode
-
- computeOperatorSpecificDefaultEstimates(DataStatistics) - Method in class org.apache.flink.optimizer.dag.PartitionNode
-
- computeOperatorSpecificDefaultEstimates(DataStatistics) - Method in class org.apache.flink.optimizer.dag.ReduceNode
-
- computeOperatorSpecificDefaultEstimates(DataStatistics) - Method in class org.apache.flink.optimizer.dag.SinkJoiner
-
- computeOperatorSpecificDefaultEstimates(DataStatistics) - Method in class org.apache.flink.optimizer.dag.SortPartitionNode
-
- computeOperatorSpecificDefaultEstimates(DataStatistics) - Method in class org.apache.flink.optimizer.dag.UnaryOperatorNode
-
- computeOperatorSpecificDefaultEstimates(DataStatistics) - Method in class org.apache.flink.optimizer.dag.WorksetIterationNode
-
- computeOperatorSpecificDefaultEstimates(DataStatistics) - Method in class org.apache.flink.optimizer.dag.WorksetIterationNode.SingleRootJoiner
-
- computeOutputEstimates(DataStatistics) - Method in class org.apache.flink.optimizer.dag.BinaryUnionNode
-
- computeOutputEstimates(DataStatistics) - Method in class org.apache.flink.optimizer.dag.BulkPartialSolutionNode
-
- computeOutputEstimates(DataStatistics) - Method in class org.apache.flink.optimizer.dag.OptimizerNode
-
Causes this node to compute its output estimates (such as number of rows, size in bytes)
based on the inputs and the compiler hints.
- computeOutputEstimates(DataStatistics) - Method in class org.apache.flink.optimizer.dag.SinkJoiner
-
- computeOutputEstimates(DataStatistics) - Method in class org.apache.flink.optimizer.dag.SolutionSetNode
-
- computeOutputEstimates(DataStatistics) - Method in class org.apache.flink.optimizer.dag.WorksetNode
-
- computeUnclosedBranchStack() - Method in class org.apache.flink.optimizer.dag.BulkIterationNode
-
- computeUnclosedBranchStack() - Method in class org.apache.flink.optimizer.dag.BulkPartialSolutionNode
-
- computeUnclosedBranchStack() - Method in class org.apache.flink.optimizer.dag.DataSinkNode
-
- computeUnclosedBranchStack() - Method in class org.apache.flink.optimizer.dag.DataSourceNode
-
- computeUnclosedBranchStack() - Method in class org.apache.flink.optimizer.dag.OptimizerNode
-
This method causes the node to compute the description of open branches in its sub-plan.
- computeUnclosedBranchStack() - Method in class org.apache.flink.optimizer.dag.SingleInputNode
-
- computeUnclosedBranchStack() - Method in class org.apache.flink.optimizer.dag.SinkJoiner
-
- computeUnclosedBranchStack() - Method in class org.apache.flink.optimizer.dag.SolutionSetNode
-
- computeUnclosedBranchStack() - Method in class org.apache.flink.optimizer.dag.TwoInputNode
-
- computeUnclosedBranchStack() - Method in class org.apache.flink.optimizer.dag.WorksetIterationNode
-
- computeUnclosedBranchStack() - Method in class org.apache.flink.optimizer.dag.WorksetNode
-
- computeUnclosedBranchStackForBroadcastInputs(List<OptimizerNode.UnclosedBranchDescriptor>) - Method in class org.apache.flink.optimizer.dag.OptimizerNode
-
- computeUnionOfInterestingPropertiesFromSuccessors() - Method in class org.apache.flink.optimizer.dag.BinaryUnionNode
-
- computeUnionOfInterestingPropertiesFromSuccessors() - Method in class org.apache.flink.optimizer.dag.OptimizerNode
-
Computes all the interesting properties that are relevant to this node.
- concat(String...) - Static method in class org.apache.flink.runtime.metrics.scope.ScopeFormat
-
- concat(CharacterFilter, String...) - Static method in class org.apache.flink.runtime.metrics.scope.ScopeFormat
-
- concat(Character, String...) - Static method in class org.apache.flink.runtime.metrics.scope.ScopeFormat
-
- concat(CharacterFilter, Character, String...) - Static method in class org.apache.flink.runtime.metrics.scope.ScopeFormat
-
Concatenates the given component names separated by the delimiter character.
- concatenate(Record) - Method in class org.apache.flink.types.Record
-
- ConcatenatedExtract<FROM,OVER,TO> - Class in org.apache.flink.streaming.api.functions.windowing.delta.extractor
-
Combines two extractors which will be executed one after each other.
- ConcatenatedExtract(Extractor<FROM, OVER>, Extractor<OVER, TO>) - Constructor for class org.apache.flink.streaming.api.functions.windowing.delta.extractor.ConcatenatedExtract
-
Combines two extractors which will be executed one after each other.
- concatenateWithAnd(String, String) - Static method in class org.apache.flink.util.StringUtils
-
If both string arguments are non-null, this method concatenates them with ' and '.
- concatScopes(String) - Method in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo
-
- ConditionContext(NFA<T>, ComputationState<T>) - Constructor for class org.apache.flink.cep.nfa.ComputationState.ConditionContext
-
- CONF_COMPRESS - Static variable in class org.apache.flink.streaming.connectors.fs.AvroKeyValueSinkWriter
-
- CONF_COMPRESS_CODEC - Static variable in class org.apache.flink.streaming.connectors.fs.AvroKeyValueSinkWriter
-
- CONF_DEFLATE_LEVEL - Static variable in class org.apache.flink.streaming.connectors.fs.AvroKeyValueSinkWriter
-
- CONF_OUTPUT_KEY_SCHEMA - Static variable in class org.apache.flink.streaming.connectors.fs.AvroKeyValueSinkWriter
-
- CONF_OUTPUT_VALUE_SCHEMA - Static variable in class org.apache.flink.streaming.connectors.fs.AvroKeyValueSinkWriter
-
- CONF_XZ_LEVEL - Static variable in class org.apache.flink.streaming.connectors.fs.AvroKeyValueSinkWriter
-
- confData - Variable in class org.apache.flink.configuration.Configuration
-
Stores the concrete key/value pairs of this configuration object.
- config - Variable in class org.apache.flink.runtime.clusterframework.FlinkResourceManager
-
The Flink configuration object
- config - Variable in class org.apache.flink.runtime.operators.BatchTask
-
The task configuration with the setup parameters.
- config - Variable in class org.apache.flink.runtime.operators.chaining.ChainedDriver
-
- config - Variable in class org.apache.flink.runtime.operators.util.TaskConfig
-
- config - Variable in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- CONFIG_FILE_LOG4J_NAME - Static variable in class org.apache.flink.yarn.cli.FlinkYarnSessionCli
-
- CONFIG_FILE_LOGBACK_NAME - Static variable in class org.apache.flink.yarn.cli.FlinkYarnSessionCli
-
- CONFIG_KEY_BULK_FLUSH_BACKOFF_DELAY - Static variable in class org.apache.flink.streaming.connectors.elasticsearch.ElasticsearchSinkBase
-
- CONFIG_KEY_BULK_FLUSH_BACKOFF_ENABLE - Static variable in class org.apache.flink.streaming.connectors.elasticsearch.ElasticsearchSinkBase
-
- CONFIG_KEY_BULK_FLUSH_BACKOFF_RETRIES - Static variable in class org.apache.flink.streaming.connectors.elasticsearch.ElasticsearchSinkBase
-
- CONFIG_KEY_BULK_FLUSH_BACKOFF_TYPE - Static variable in class org.apache.flink.streaming.connectors.elasticsearch.ElasticsearchSinkBase
-
- CONFIG_KEY_BULK_FLUSH_INTERVAL_MS - Static variable in class org.apache.flink.streaming.connectors.elasticsearch.ElasticsearchSinkBase
-
- CONFIG_KEY_BULK_FLUSH_MAX_ACTIONS - Static variable in class org.apache.flink.streaming.connectors.elasticsearch.ElasticsearchSinkBase
-
- CONFIG_KEY_BULK_FLUSH_MAX_SIZE_MB - Static variable in class org.apache.flink.streaming.connectors.elasticsearch.ElasticsearchSinkBase
-
- ConfigConstants - Class in org.apache.flink.configuration
-
This class contains all constants for the configuration.
- ConfigGroup - Annotation Type in org.apache.flink.annotation.docs
-
A class that specifies a group of config options.
- ConfigGroups - Annotation Type in org.apache.flink.annotation.docs
-
Annotation used on classes containing config optionss that enables the separation of options into different
tables based on key prefixes.
- ConfigOption<T> - Class in org.apache.flink.configuration
-
A ConfigOption
describes a configuration parameter.
- ConfigOptions - Class in org.apache.flink.configuration
-
- ConfigOptions.OptionBuilder - Class in org.apache.flink.configuration
-
- ConfigOptionsDocGenerator - Class in org.apache.flink.docs.configuration
-
Class used for generating code based documentation of configuration parameters.
- ConfigurableStateBackend - Interface in org.apache.flink.runtime.state
-
An interface for state backends that pick up additional parameters from a configuration.
- ConfigurableStreamPartitioner - Interface in org.apache.flink.streaming.runtime.partitioner
-
Interface for
StreamPartitioner
which have to be configured with the maximum parallelism
of the stream transformation.
- configuration - Variable in class org.apache.flink.api.java.hadoop.mapreduce.HadoopOutputFormatBase
-
- configuration - Variable in class org.apache.flink.client.cli.AbstractCustomCommandLine
-
- Configuration - Class in org.apache.flink.configuration
-
Lightweight configuration object which stores key/value pairs.
- Configuration() - Constructor for class org.apache.flink.configuration.Configuration
-
Creates a new empty configuration.
- Configuration(Configuration) - Constructor for class org.apache.flink.configuration.Configuration
-
Creates a new configuration with the copy of the given configuration.
- configuration - Variable in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
The configuration of this streaming task.
- Configuration - Class in org.apache.hadoop.conf
-
Provides access to configuration parameters.
- Configuration() - Constructor for class org.apache.hadoop.conf.Configuration
-
A new configuration.
- Configuration(boolean) - Constructor for class org.apache.hadoop.conf.Configuration
-
A new configuration where the behavior of reading from the default
resources can be turned off.
- Configuration(Configuration) - Constructor for class org.apache.hadoop.conf.Configuration
-
A new configuration with the same settings cloned from another.
- Configuration.DeprecationDelta - Class in org.apache.hadoop.conf
-
A pending addition to the global set of deprecated keys.
- Configuration.IntegerRanges - Class in org.apache.hadoop.conf
-
A class that represents a set of positive integer ranges.
- ConfigurationException - Exception in org.apache.flink.util
-
Exception which occurs when creating a configuration object fails.
- ConfigurationException(String) - Constructor for exception org.apache.flink.util.ConfigurationException
-
- ConfigurationException(String, Throwable) - Constructor for exception org.apache.flink.util.ConfigurationException
-
- ConfigurationException(Throwable) - Constructor for exception org.apache.flink.util.ConfigurationException
-
- ConfigurationUtils - Class in org.apache.flink.configuration
-
- configure(Configuration) - Method in class org.apache.flink.addons.hbase.AbstractTableInputFormat
-
Creates a Scan
object and opens the HTable
connection.
- configure(Configuration) - Method in class org.apache.flink.addons.hbase.HBaseRowInputFormat
-
- configure(Configuration) - Method in class org.apache.flink.addons.hbase.TableInputFormat
-
Creates a Scan
object and opens the HTable
connection.
- configure(Configuration) - Method in class org.apache.flink.api.common.io.BinaryInputFormat
-
- configure(Configuration) - Method in class org.apache.flink.api.common.io.BinaryOutputFormat
-
- configure(Configuration) - Method in class org.apache.flink.api.common.io.DelimitedInputFormat
-
Configures this input format by reading the path to the file from the configuration and the string that
defines the record delimiter.
- configure(Configuration) - Method in class org.apache.flink.api.common.io.FileInputFormat
-
Configures the file input format by reading the file path from the configuration.
- configure(Configuration) - Method in class org.apache.flink.api.common.io.FileOutputFormat
-
- configure(Configuration) - Method in class org.apache.flink.api.common.io.GenericInputFormat
-
- configure(Configuration) - Method in interface org.apache.flink.api.common.io.InputFormat
-
Configures this input format.
- configure(Configuration) - Method in interface org.apache.flink.api.common.io.OutputFormat
-
Configures this output format.
- configure(Configuration) - Method in class org.apache.flink.api.common.io.ReplicatingInputFormat
-
- configure(Configuration) - Method in class org.apache.flink.api.java.hadoop.mapred.HadoopInputFormatBase
-
- configure(Configuration) - Method in class org.apache.flink.api.java.hadoop.mapred.HadoopOutputFormatBase
-
- configure(Configuration) - Method in class org.apache.flink.api.java.hadoop.mapreduce.HadoopInputFormatBase
-
- configure(Configuration) - Method in class org.apache.flink.api.java.hadoop.mapreduce.HadoopOutputFormatBase
-
- configure(Configuration) - Method in class org.apache.flink.api.java.io.DiscardingOutputFormat
-
- configure(String[], TypeInformation<?>[]) - Method in class org.apache.flink.api.java.io.jdbc.JDBCAppendTableSink
-
- configure(Configuration) - Method in class org.apache.flink.api.java.io.jdbc.JDBCInputFormat
-
- configure(Configuration) - Method in class org.apache.flink.api.java.io.jdbc.JDBCOutputFormat
-
- configure(Configuration) - Method in class org.apache.flink.api.java.io.LocalCollectionOutputFormat
-
- configure(Configuration) - Method in class org.apache.flink.api.java.io.PrintingOutputFormat
-
- configure(Configuration) - Method in class org.apache.flink.api.java.io.TextInputFormat
-
- configure(Configuration) - Method in class org.apache.flink.api.java.io.TextValueInputFormat
-
- configure(Configuration) - Method in class org.apache.flink.api.java.Utils.ChecksumHashCodeHelper
-
- configure(Configuration) - Method in class org.apache.flink.api.java.Utils.CollectHelper
-
- configure(Configuration) - Method in class org.apache.flink.api.java.Utils.CountHelper
-
- configure(Configuration) - Method in class org.apache.flink.batch.connectors.cassandra.CassandraInputFormat
-
- configure(Configuration) - Method in class org.apache.flink.batch.connectors.cassandra.CassandraOutputFormatBase
-
- configure(Configuration) - Method in class org.apache.flink.batch.tests.DataSetAllroundTestProgram.Generator
-
- configure(Configuration) - Method in class org.apache.flink.contrib.streaming.state.RocksDBStateBackend
-
Creates a copy of this state backend that uses the values defined in the configuration
for fields where that were not yet specified in this state backend.
- configure(Configuration) - Method in class org.apache.flink.core.fs.ConnectionLimitingFactory
-
- configure(Configuration) - Method in interface org.apache.flink.core.fs.FileSystemFactory
-
Applies the given configuration to this factory.
- configure(Configuration) - Method in class org.apache.flink.core.fs.local.LocalFileSystemFactory
-
- configure(Configuration) - Method in class org.apache.flink.examples.java.distcp.FileCopyTaskInputFormat
-
- configure(Configuration) - Method in class org.apache.flink.fs.openstackhadoop.SwiftFileSystemFactory
-
- configure(Configuration) - Method in class org.apache.flink.fs.s3hadoop.S3FileSystemFactory
-
- configure(Configuration) - Method in class org.apache.flink.fs.s3presto.S3FileSystemFactory
-
- configure(Configuration) - Method in class org.apache.flink.graph.AnalyticHelper
-
- configure(ParameterTool) - Method in class org.apache.flink.graph.drivers.input.CirculantGraph
-
- configure(ParameterTool) - Method in class org.apache.flink.graph.drivers.input.GridGraph
-
- configure(ParameterTool) - Method in class org.apache.flink.graph.drivers.parameter.BooleanParameter
-
- configure(ParameterTool) - Method in class org.apache.flink.graph.drivers.parameter.ChoiceParameter
-
- configure(ParameterTool) - Method in class org.apache.flink.graph.drivers.parameter.DoubleParameter
-
- configure(ParameterTool) - Method in class org.apache.flink.graph.drivers.parameter.IterationConvergence
-
- configure(ParameterTool) - Method in class org.apache.flink.graph.drivers.parameter.LongParameter
-
- configure(ParameterTool) - Method in interface org.apache.flink.graph.drivers.parameter.Parameter
-
Read and parse the parameter value from command-line arguments.
- configure(ParameterTool) - Method in interface org.apache.flink.graph.drivers.parameter.Parameterized
-
Read parameter values from the command-line arguments.
- configure(ParameterTool) - Method in class org.apache.flink.graph.drivers.parameter.ParameterizedBase
-
- configure(ParameterTool) - Method in class org.apache.flink.graph.drivers.parameter.Simplify
-
- configure(ParameterTool) - Method in class org.apache.flink.graph.drivers.parameter.StringParameter
-
- configure(GSAConfiguration) - Method in class org.apache.flink.graph.gsa.GatherSumApplyIteration
-
Configures this gather-sum-apply iteration with the provided parameters.
- configure(VertexCentricConfiguration) - Method in class org.apache.flink.graph.pregel.VertexCentricIteration
-
Configures this vertex-centric iteration with the provided parameters.
- configure(ScatterGatherConfiguration) - Method in class org.apache.flink.graph.spargel.ScatterGatherIteration
-
Configures this scatter-gather iteration with the provided parameters.
- configure(Configuration) - Method in class org.apache.flink.hcatalog.HCatInputFormatBase
-
- configure(ContainerSpecification) - Method in class org.apache.flink.runtime.clusterframework.overlays.CompositeContainerOverlay
-
- configure(ContainerSpecification) - Method in interface org.apache.flink.runtime.clusterframework.overlays.ContainerOverlay
-
Configure the given container specification.
- configure(ContainerSpecification) - Method in class org.apache.flink.runtime.clusterframework.overlays.FlinkDistributionOverlay
-
- configure(ContainerSpecification) - Method in class org.apache.flink.runtime.clusterframework.overlays.HadoopConfOverlay
-
- configure(ContainerSpecification) - Method in class org.apache.flink.runtime.clusterframework.overlays.HadoopUserOverlay
-
- configure(ContainerSpecification) - Method in class org.apache.flink.runtime.clusterframework.overlays.KeytabOverlay
-
- configure(ContainerSpecification) - Method in class org.apache.flink.runtime.clusterframework.overlays.Krb5ConfOverlay
-
- configure(ContainerSpecification) - Method in class org.apache.flink.runtime.clusterframework.overlays.SSLStoreOverlay
-
- configure(Configuration) - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFsFactory
-
- configure(Configuration) - Method in class org.apache.flink.runtime.fs.maprfs.MapRFsFactory
-
- configure(Configuration) - Method in interface org.apache.flink.runtime.state.ConfigurableStateBackend
-
Creates a variant of the state backend that applies additional configuration parameters.
- configure(Configuration) - Method in class org.apache.flink.runtime.state.filesystem.FsStateBackend
-
Creates a copy of this state backend that uses the values defined in the configuration
for fields where that were not specified in this state backend.
- configure(Configuration) - Method in class org.apache.flink.runtime.state.memory.MemoryStateBackend
-
Creates a copy of this state backend that uses the values defined in the configuration
for fields where that were not specified in this state backend.
- configure(String[], TypeInformation<?>[]) - Method in class org.apache.flink.streaming.connectors.cassandra.CassandraAppendTableSink
-
- configure(String[], TypeInformation<?>[]) - Method in class org.apache.flink.streaming.connectors.kafka.KafkaTableSink
-
- configure(int) - Method in interface org.apache.flink.streaming.runtime.partitioner.ConfigurableStreamPartitioner
-
Configure the
StreamPartitioner
with the maximum parallelism of the down stream
operator.
- configure(int) - Method in class org.apache.flink.streaming.runtime.partitioner.KeyGroupStreamPartitioner
-
- configure(String[], TypeInformation<?>[]) - Method in class org.apache.flink.table.client.gateway.local.CollectStreamTableSink
-
- CONFIGURE_MUTEX - Static variable in class org.apache.flink.api.java.hadoop.mapred.HadoopOutputFormatBase
-
- CONFIGURE_MUTEX - Static variable in class org.apache.flink.api.java.hadoop.mapreduce.HadoopOutputFormatBase
-
- configureBulkProcessorBackoff(BulkProcessor.Builder, ElasticsearchSinkBase.BulkFlushBackoffPolicy) - Method in class org.apache.flink.streaming.connectors.elasticsearch.Elasticsearch1ApiCallBridge
-
- configureBulkProcessorBackoff(BulkProcessor.Builder, ElasticsearchSinkBase.BulkFlushBackoffPolicy) - Method in interface org.apache.flink.streaming.connectors.elasticsearch.ElasticsearchApiCallBridge
-
Set backoff-related configurations on the provided BulkProcessor.Builder
.
- configureBulkProcessorBackoff(BulkProcessor.Builder, ElasticsearchSinkBase.BulkFlushBackoffPolicy) - Method in class org.apache.flink.streaming.connectors.elasticsearch2.Elasticsearch2ApiCallBridge
-
- configureBulkProcessorBackoff(BulkProcessor.Builder, ElasticsearchSinkBase.BulkFlushBackoffPolicy) - Method in class org.apache.flink.streaming.connectors.elasticsearch5.Elasticsearch5ApiCallBridge
-
- configureFileSystems(Configuration) - Method in class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
-
- configureTableSource(T) - Method in class org.apache.flink.streaming.connectors.kafka.KafkaAvroTableSource.Builder
-
- configureTableSource(T) - Method in class org.apache.flink.streaming.connectors.kafka.KafkaJsonTableSource.Builder
-
- configureTableSource(T) - Method in class org.apache.flink.streaming.connectors.kafka.KafkaTableSource.Builder
-
Configures a TableSource with optional parameters.
- ConfigUtil - Class in org.apache.flink.table.client.config
-
Auxiliary functions for configuration file handling.
- ConfigUtil.LowerCaseYamlMapper - Class in org.apache.flink.table.client.config
-
Modified object mapper that converts to lower-case keys.
- confirmCheckpoint(long) - Method in class org.apache.flink.runtime.state.NoOpTaskLocalStateStoreImpl
-
- confirmCheckpoint(long) - Method in interface org.apache.flink.runtime.state.TaskLocalStateStore
-
Notifies that the checkpoint with the given id was confirmed as complete.
- confirmCheckpoint(long) - Method in class org.apache.flink.runtime.state.TaskLocalStateStoreImpl
-
- confirmCheckpoint(ExecutionAttemptID, long, long) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutor
-
- confirmCheckpoint(ExecutionAttemptID, long, long) - Method in interface org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
-
Confirm a checkpoint for the given task.
- confirmLeaderSessionID(UUID) - Method in class org.apache.flink.runtime.highavailability.nonha.leaderelection.SingleLeaderElectionService
-
- confirmLeaderSessionID(UUID) - Method in interface org.apache.flink.runtime.leaderelection.LeaderElectionService
-
Confirms that the new leader session ID has been successfully received by the new leader.
- confirmLeaderSessionID(UUID) - Method in class org.apache.flink.runtime.leaderelection.StandaloneLeaderElectionService
-
- confirmLeaderSessionID(UUID) - Method in class org.apache.flink.runtime.leaderelection.ZooKeeperLeaderElectionService
-
- ConflictingFieldTypeInfoException - Exception in org.apache.flink.optimizer.postpass
-
- ConflictingFieldTypeInfoException(int, Object, Object) - Constructor for exception org.apache.flink.optimizer.postpass.ConflictingFieldTypeInfoException
-
- conflictsWith(OptionalBoolean) - Method in class org.apache.flink.graph.utils.proxy.OptionalBoolean
-
The conflicting states are true with false and false with true.
- ConjunctFuture() - Constructor for class org.apache.flink.runtime.concurrent.FutureUtils.ConjunctFuture
-
- connecDataSet(IntermediateDataSet) - Method in class org.apache.flink.runtime.jobgraph.JobEdge
-
- connect(String, Class<C>) - Method in class org.apache.flink.runtime.rpc.akka.AkkaRpcService
-
- connect(String, F, Class<C>) - Method in class org.apache.flink.runtime.rpc.akka.AkkaRpcService
-
- connect(String, Class<C>) - Method in interface org.apache.flink.runtime.rpc.RpcService
-
Connect to a remote rpc server under the provided address.
- connect(String, F, Class<C>) - Method in interface org.apache.flink.runtime.rpc.RpcService
-
Connect to ta remote fenced rpc server under the provided address.
- connect(DataStream<R>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
- connect(BroadcastStream<R>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
- CONNECT_BACKLOG - Static variable in class org.apache.flink.runtime.io.network.netty.NettyConfig
-
- connectDataSetAsInput(IntermediateDataSet, DistributionPattern) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
- Connected - Class in org.apache.flink.mesos.scheduler.messages
-
Message sent by the callback handler to the scheduler actor
when the scheduler becomes "connected" to the master.
- Connected() - Constructor for class org.apache.flink.mesos.scheduler.messages.Connected
-
- ConnectedComponents - Class in org.apache.flink.examples.java.graph
-
An implementation of the connected components algorithm, using a delta iteration.
- ConnectedComponents() - Constructor for class org.apache.flink.examples.java.graph.ConnectedComponents
-
- ConnectedComponents<K extends Comparable<K>,VV,EV> - Class in org.apache.flink.graph.drivers
-
- ConnectedComponents() - Constructor for class org.apache.flink.graph.drivers.ConnectedComponents
-
- ConnectedComponents<K,VV extends Comparable<VV>,EV> - Class in org.apache.flink.graph.library
-
A scatter-gather implementation of the Weakly Connected Components algorithm.
- ConnectedComponents(Integer) - Constructor for class org.apache.flink.graph.library.ConnectedComponents
-
Creates an instance of the Connected Components algorithm.
- ConnectedComponents.CCMessenger<K,VV extends Comparable<VV>> - Class in org.apache.flink.graph.library
-
Sends the current vertex value to all adjacent vertices.
- ConnectedComponents.CCUpdater<K,VV extends Comparable<VV>> - Class in org.apache.flink.graph.library
-
Updates the value of a vertex by picking the minimum neighbor value out of all the incoming messages.
- ConnectedComponents.ComponentIdFilter - Class in org.apache.flink.examples.java.graph
-
Emit the candidate (Vertex-ID, Component-ID) pair if and only if the
candidate component ID is less than the vertex's current component ID.
- ConnectedComponents.DuplicateValue<T> - Class in org.apache.flink.examples.java.graph
-
Function that turns a value into a 2-tuple where both fields are that value.
- ConnectedComponents.NeighborWithComponentIDJoin - Class in org.apache.flink.examples.java.graph
-
UDF that joins a (Vertex-ID, Component-ID) pair that represents the current component that
a vertex is associated with, with a (Source-Vertex-ID, Target-VertexID) edge.
- ConnectedComponents.UndirectEdge - Class in org.apache.flink.examples.java.graph
-
Undirected edges by emitting for each input edge the input edges itself and an inverted version.
- ConnectedComponentsData - Class in org.apache.flink.examples.java.graph.util
-
Provides the default data sets used for the Connected Components example program.
- ConnectedComponentsData() - Constructor for class org.apache.flink.examples.java.graph.util.ConnectedComponentsData
-
- ConnectedComponentsData - Class in org.apache.flink.test.testdata
-
Test data for ConnectedComponents programs.
- ConnectedComponentsDefaultData - Class in org.apache.flink.graph.examples.data
-
Provides the default data sets used for the connected components example program.
- ConnectedIterativeStreams(DataStream<I>, TypeInformation<F>, long) - Constructor for class org.apache.flink.streaming.api.datastream.IterativeStream.ConnectedIterativeStreams
-
- ConnectedStreams<IN1,IN2> - Class in org.apache.flink.streaming.api.datastream
-
ConnectedStreams represent two connected streams of (possibly) different data types.
- ConnectedStreams(StreamExecutionEnvironment, DataStream<IN1>, DataStream<IN2>) - Constructor for class org.apache.flink.streaming.api.datastream.ConnectedStreams
-
- connectedToJobManager() - Method in class org.apache.flink.runtime.client.JobAttachmentClientActor
-
- connectedToJobManager() - Method in class org.apache.flink.runtime.client.JobClientActor
-
Hook to be called once a connection has been established with the JobManager.
- connectedToJobManager() - Method in class org.apache.flink.runtime.client.JobSubmissionClientActor
-
- connectIdInput(IntermediateDataSetID, DistributionPattern) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
- connection - Variable in class org.apache.flink.streaming.connectors.rabbitmq.RMQSink
-
- connection - Variable in class org.apache.flink.streaming.connectors.rabbitmq.RMQSource
-
- CONNECTION_TIMEOUT - Static variable in class org.apache.flink.configuration.RestOptions
-
The maximum time in ms for the client to establish a TCP connection.
- ConnectionClosedException - Exception in org.apache.flink.runtime.rest
-
Exception which is thrown if the
RestClient
detects that a connection
was closed.
- ConnectionClosedException(String) - Constructor for exception org.apache.flink.runtime.rest.ConnectionClosedException
-
- ConnectionClosedException(String, Throwable) - Constructor for exception org.apache.flink.runtime.rest.ConnectionClosedException
-
- ConnectionClosedException(Throwable) - Constructor for exception org.apache.flink.runtime.rest.ConnectionClosedException
-
- ConnectionException - Exception in org.apache.flink.runtime.rest
-
Base class for all connection related exception thrown by the
RestClient
.
- ConnectionException(String) - Constructor for exception org.apache.flink.runtime.rest.ConnectionException
-
- ConnectionException(String, Throwable) - Constructor for exception org.apache.flink.runtime.rest.ConnectionException
-
- ConnectionException(Throwable) - Constructor for exception org.apache.flink.runtime.rest.ConnectionException
-
- ConnectionID - Class in org.apache.flink.runtime.io.network
-
A
ConnectionID
identifies a connection to a remote task manager by the socket address and
a connection index.
- ConnectionID(TaskManagerLocation, int) - Constructor for class org.apache.flink.runtime.io.network.ConnectionID
-
- ConnectionID(InetSocketAddress, int) - Constructor for class org.apache.flink.runtime.io.network.ConnectionID
-
- ConnectionIdleException - Exception in org.apache.flink.runtime.rest
-
Exception which is thrown by the
RestClient
if a connection
becomes idle.
- ConnectionIdleException(String) - Constructor for exception org.apache.flink.runtime.rest.ConnectionIdleException
-
- ConnectionIdleException(String, Throwable) - Constructor for exception org.apache.flink.runtime.rest.ConnectionIdleException
-
- ConnectionIdleException(Throwable) - Constructor for exception org.apache.flink.runtime.rest.ConnectionIdleException
-
- ConnectionLimitingFactory - Class in org.apache.flink.core.fs
-
- ConnectionLimitingSettings(int, int, int, long, long) - Constructor for class org.apache.flink.core.fs.LimitedConnectionsFileSystem.ConnectionLimitingSettings
-
Creates a new ConnectionLimitingSettings with the given parameters.
- ConnectionManager - Interface in org.apache.flink.runtime.io.network
-
The connection manager manages physical connections for the (logical) remote
input channels at runtime.
- ConnectionUtils - Class in org.apache.flink.runtime.net
-
Utilities to determine the network interface and address that should be used to bind the
TaskManager communication to.
- ConnectionUtils() - Constructor for class org.apache.flink.runtime.net.ConnectionUtils
-
- ConnectionUtils.LeaderConnectingAddressListener - Class in org.apache.flink.runtime.net
-
- connectNewDataSetAsInput(JobVertex, DistributionPattern, ResultPartitionType) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
- CONNECTOR_PROPERTIES - Static variable in class org.apache.flink.table.descriptors.KafkaValidator
-
- CONNECTOR_PROPERTIES_KEY - Static variable in class org.apache.flink.table.descriptors.KafkaValidator
-
- CONNECTOR_PROPERTIES_VALUE - Static variable in class org.apache.flink.table.descriptors.KafkaValidator
-
- CONNECTOR_SPECIFIC_OFFSETS - Static variable in class org.apache.flink.table.descriptors.KafkaValidator
-
- CONNECTOR_SPECIFIC_OFFSETS_OFFSET - Static variable in class org.apache.flink.table.descriptors.KafkaValidator
-
- CONNECTOR_SPECIFIC_OFFSETS_PARTITION - Static variable in class org.apache.flink.table.descriptors.KafkaValidator
-
- CONNECTOR_STARTUP_MODE - Static variable in class org.apache.flink.table.descriptors.KafkaValidator
-
- CONNECTOR_STARTUP_MODE_VALUE_EARLIEST - Static variable in class org.apache.flink.table.descriptors.KafkaValidator
-
- CONNECTOR_STARTUP_MODE_VALUE_GROUP_OFFSETS - Static variable in class org.apache.flink.table.descriptors.KafkaValidator
-
- CONNECTOR_STARTUP_MODE_VALUE_LATEST - Static variable in class org.apache.flink.table.descriptors.KafkaValidator
-
- CONNECTOR_STARTUP_MODE_VALUE_SPECIFIC_OFFSETS - Static variable in class org.apache.flink.table.descriptors.KafkaValidator
-
- CONNECTOR_TOPIC - Static variable in class org.apache.flink.table.descriptors.KafkaValidator
-
- CONNECTOR_TYPE_VALUE_KAFKA - Static variable in class org.apache.flink.table.descriptors.KafkaValidator
-
- CONNECTOR_VERSION_VALUE_010 - Static variable in class org.apache.flink.table.descriptors.KafkaValidator
-
- CONNECTOR_VERSION_VALUE_011 - Static variable in class org.apache.flink.table.descriptors.KafkaValidator
-
- CONNECTOR_VERSION_VALUE_08 - Static variable in class org.apache.flink.table.descriptors.KafkaValidator
-
- CONNECTOR_VERSION_VALUE_09 - Static variable in class org.apache.flink.table.descriptors.KafkaValidator
-
- connectSource(int, IntermediateResult, JobEdge, int) - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- connectToJob(JobID) - Method in class org.apache.flink.client.program.ClusterClient
-
Reattaches to a running job with the given job id.
- connectToPredecessors(Map<IntermediateDataSetID, IntermediateResult>) - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
- connectToResourceManager(ResourceManagerGateway) - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotPool
-
- connectToResourceManager(ResourceManagerGateway) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.SlotPoolGateway
-
Connects the SlotPool to the given ResourceManager.
- consecutive() - Method in class org.apache.flink.cep.pattern.Pattern
-
- consecutive() - Method in class org.apache.flink.cep.pattern.Quantifier
-
- ConstantTextHandler - Class in org.apache.flink.runtime.rest.handler.legacy
-
Responder that returns a constant String.
- ConstantTextHandler(String) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.ConstantTextHandler
-
- constraints() - Method in class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManagerParameters
-
Get the placement constraints.
- constructLogString(String, String, AbstractInvokable) - Static method in class org.apache.flink.runtime.operators.BatchTask
-
Utility function that composes a string for logging purposes.
- constructTestPath(Class<?>, String) - Static method in class org.apache.flink.test.util.TestBaseUtils
-
- constructTestURI(Class<?>, String) - Static method in class org.apache.flink.test.util.TestBaseUtils
-
- consumeAndCacheRemainingData() - Method in class org.apache.flink.runtime.operators.resettable.SpillingResettableMutableObjectIterator
-
- consumer - Variable in class org.apache.flink.streaming.connectors.rabbitmq.RMQSource
-
- CONSUMER_KEY - Static variable in class org.apache.flink.streaming.connectors.twitter.TwitterSource
-
- CONSUMER_SECRET - Static variable in class org.apache.flink.streaming.connectors.twitter.TwitterSource
-
- container() - Method in class org.apache.flink.yarn.YarnContainerInLaunch
-
- containerContains(String) - Method in class org.apache.flink.api.java.sca.TaggedValue
-
- containeredParameters() - Method in class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManagerParameters
-
Get the common containered parameters.
- ContaineredTaskManagerParameters - Class in org.apache.flink.runtime.clusterframework
-
This class describes the basic parameters for launching a TaskManager process.
- ContaineredTaskManagerParameters(long, long, long, int, HashMap<String, String>) - Constructor for class org.apache.flink.runtime.clusterframework.ContaineredTaskManagerParameters
-
- containerHasReferences() - Method in class org.apache.flink.api.java.sca.TaggedValue
-
- containerImageName() - Method in class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManagerParameters
-
Get the container image name.
- CONTAINERIZED_HEAP_CUTOFF_MIN - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- CONTAINERIZED_HEAP_CUTOFF_MIN - Static variable in class org.apache.flink.configuration.ResourceManagerOptions
-
Minimum amount of heap memory to remove in containers, as a safety margin.
- CONTAINERIZED_HEAP_CUTOFF_RATIO - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- CONTAINERIZED_HEAP_CUTOFF_RATIO - Static variable in class org.apache.flink.configuration.ResourceManagerOptions
-
Percentage of heap space to remove from containers (YARN / Mesos), to compensate
for other JVM memory usage.
- CONTAINERIZED_MASTER_ENV_PREFIX - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- CONTAINERIZED_MASTER_ENV_PREFIX - Static variable in class org.apache.flink.configuration.ResourceManagerOptions
-
Prefix for passing custom environment variables to Flink's master process.
- CONTAINERIZED_TASK_MANAGER_ENV_PREFIX - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- CONTAINERIZED_TASK_MANAGER_ENV_PREFIX - Static variable in class org.apache.flink.configuration.ResourceManagerOptions
-
Similar to the CONTAINERIZED_MASTER_ENV_PREFIX
, this configuration prefix allows
setting custom environment variables for the workers (TaskManagers).
- ContainerOverlay - Interface in org.apache.flink.runtime.clusterframework.overlays
-
A container overlay to produce a container specification.
- containers() - Method in class org.apache.flink.yarn.messages.ContainersAllocated
-
- containers() - Method in class org.apache.flink.yarn.messages.ContainersComplete
-
- ContainersAllocated - Class in org.apache.flink.yarn.messages
-
Message sent by the callback handler to the
YarnFlinkResourceManager
to notify it that a set of new containers is available.
- ContainersAllocated(List<Container>) - Constructor for class org.apache.flink.yarn.messages.ContainersAllocated
-
- ContainersComplete - Class in org.apache.flink.yarn.messages
-
Message sent by the callback handler to the
YarnFlinkResourceManager
to notify it that a set of new containers is complete.
- ContainersComplete(List<ContainerStatus>) - Constructor for class org.apache.flink.yarn.messages.ContainersComplete
-
- ContainerSpecification - Class in org.apache.flink.runtime.clusterframework
-
Encapsulates a container specification, including artifacts, environment variables,
system properties, and Flink configuration settings.
- ContainerSpecification() - Constructor for class org.apache.flink.runtime.clusterframework.ContainerSpecification
-
- ContainerSpecification.Artifact - Class in org.apache.flink.runtime.clusterframework
-
An artifact to be copied into the container.
- ContainerSpecification.Artifact.Builder - Class in org.apache.flink.runtime.clusterframework
-
- containerType() - Method in class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManagerParameters
-
Get the container type (Mesos or Docker).
- containerVolumes() - Method in class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManagerParameters
-
Get the container volumes string.
- containingIteration - Variable in class org.apache.flink.api.common.operators.base.DeltaIterationBase.SolutionSetPlaceHolder
-
- contains(Integer) - Method in class org.apache.flink.api.common.operators.util.FieldSet
-
- contains(UK) - Method in interface org.apache.flink.api.common.state.MapState
-
Returns whether there exists the given mapping.
- contains(K) - Method in interface org.apache.flink.api.common.state.ReadOnlyBroadcastState
-
Returns whether there exists the given mapping.
- contains(ConfigOption<?>) - Method in class org.apache.flink.configuration.Configuration
-
Checks whether there is an entry for the given config option.
- contains(ConfigOption<?>) - Method in class org.apache.flink.configuration.DelegatingConfiguration
-
- contains(UK) - Method in class org.apache.flink.contrib.streaming.state.RocksDBMapState
-
- contains(K) - Method in class org.apache.flink.queryablestate.client.state.ImmutableMapState
-
- contains(Object) - Method in class org.apache.flink.runtime.checkpoint.StateObjectCollection
-
- contains(Object) - Method in class org.apache.flink.runtime.jobmanager.scheduler.SetQueue
-
- contains(SlotRequestId) - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotSharingManager
-
- contains(AbstractID) - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotSharingManager.MultiTaskSlot
-
Checks whether this slot or any of its children contains the given groupId.
- contains(AbstractID) - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotSharingManager.TaskSlot
-
Check whether the task slot contains the given groupId.
- contains(UK) - Method in class org.apache.flink.runtime.state.heap.HeapMapState
-
- contains(K) - Method in class org.apache.flink.runtime.state.HeapBroadcastState
-
- contains(int) - Method in class org.apache.flink.runtime.state.KeyGroupRange
-
Checks whether or not a single key-group is contained in the range.
- contains(int) - Method in interface org.apache.flink.runtime.state.KeyGroupsList
-
Returns true, if the given key group id is contained in the list, otherwise false.
- contains(JobID) - Method in class org.apache.flink.runtime.taskexecutor.JobManagerTable
-
- contains(String) - Method in class org.apache.flink.storm.wrappers.StormTuple
-
- contains(Object) - Method in class org.apache.flink.types.ListValue
-
- containsAll(Collection<?>) - Method in class org.apache.flink.runtime.checkpoint.StateObjectCollection
-
- containsAll(Collection<?>) - Method in class org.apache.flink.runtime.jobmanager.scheduler.SetQueue
-
- containsAll(Collection<?>) - Method in class org.apache.flink.types.ListValue
-
- containsCause(Throwable, Class<? extends Throwable>) - Static method in class org.apache.flink.core.testutils.CommonTestUtils
-
Checks whether the given throwable contains the given cause as a cause.
- containsJob(JobID) - Method in class org.apache.flink.runtime.resourcemanager.JobLeaderIdService
-
Check whether the given job is being monitored or not.
- containsJob(JobID) - Method in class org.apache.flink.runtime.taskexecutor.JobLeaderService
-
Check whether the service monitors the given job.
- containsKey(String) - Method in class org.apache.flink.configuration.Configuration
-
Checks whether there is an entry with the specified key.
- containsKey(String) - Method in class org.apache.flink.configuration.DelegatingConfiguration
-
- containsKey(N) - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateTable
-
- containsKey(N) - Method in class org.apache.flink.runtime.state.heap.NestedMapsStateTable
-
- containsKey(N) - Method in class org.apache.flink.runtime.state.heap.StateTable
-
Returns whether this table contains a mapping for the composite of active key and given namespace.
- containsKey(Object) - Method in class org.apache.flink.storm.util.StormConfig
-
- containsKey(Object) - Method in class org.apache.flink.types.MapValue
-
- containsKeyA(A) - Method in class org.apache.flink.runtime.jobmaster.slotpool.DualKeyMap
-
- containsKeyB(B) - Method in class org.apache.flink.runtime.jobmaster.slotpool.DualKeyMap
-
- containsNonNull() - Method in class org.apache.flink.api.java.summarize.ColumnSummary
-
True if this column contains any non-null values.
- containsNull() - Method in class org.apache.flink.api.java.summarize.ColumnSummary
-
True if this column contains any null values.
- containsResultAsText(List<T>, String) - Static method in class org.apache.flink.test.util.TestBaseUtils
-
The expected string contains all expected results separate with line break, check whether all elements in result
are contained in the expected string.
- containsSlot(SlotID) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerRegistration
-
- containsValue(Object) - Method in class org.apache.flink.storm.util.StormConfig
-
- containsValue(Object) - Method in class org.apache.flink.types.MapValue
-
- CONTENT_TYPE_BINARY - Static variable in enum org.apache.flink.runtime.rest.util.RestConstants
-
- CONTENT_TYPE_JAR - Static variable in enum org.apache.flink.runtime.rest.util.RestConstants
-
- CONTENTS - Static variable in class org.apache.flink.streaming.api.graph.JSONGenerator
-
- context - Variable in class org.apache.flink.api.java.DataSet
-
- context - Variable in class org.apache.flink.api.java.hadoop.mapred.HadoopOutputFormatBase
-
- context - Variable in class org.apache.flink.api.java.hadoop.mapreduce.HadoopOutputFormatBase
-
- Context() - Constructor for class org.apache.flink.streaming.api.functions.co.BaseBroadcastProcessFunction.Context
-
- Context() - Constructor for class org.apache.flink.streaming.api.functions.co.BroadcastProcessFunction.Context
-
- Context() - Constructor for class org.apache.flink.streaming.api.functions.co.CoProcessFunction.Context
-
- Context() - Constructor for class org.apache.flink.streaming.api.functions.co.KeyedBroadcastProcessFunction.Context
-
- Context() - Constructor for class org.apache.flink.streaming.api.functions.KeyedProcessFunction.Context
-
- Context() - Constructor for class org.apache.flink.streaming.api.functions.ProcessFunction.Context
-
- context - Variable in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.State
-
- Context() - Constructor for class org.apache.flink.streaming.api.functions.windowing.ProcessAllWindowFunction.Context
-
- Context() - Constructor for class org.apache.flink.streaming.api.functions.windowing.ProcessWindowFunction.Context
-
- Context(K, W) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
-
- ContextEnvironment - Class in org.apache.flink.client.program
-
Execution Environment for remote execution with the Client.
- ContextEnvironment(ClusterClient<?>, List<URL>, List<URL>, ClassLoader, SavepointRestoreSettings) - Constructor for class org.apache.flink.client.program.ContextEnvironment
-
- ContextEnvironmentFactory - Class in org.apache.flink.client.program
-
The factory that instantiates the environment to be used when running jobs that are
submitted through a pre-configured client connection.
- ContextEnvironmentFactory(ClusterClient<?>, List<URL>, List<URL>, ClassLoader, int, boolean, SavepointRestoreSettings) - Constructor for class org.apache.flink.client.program.ContextEnvironmentFactory
-
- ContextStateSerializer() - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer011.ContextStateSerializer
-
- continueWritingWithNextBufferBuilder(BufferBuilder) - Method in interface org.apache.flink.runtime.io.network.api.serialization.RecordSerializer
-
Sets a (next) target buffer to use and continues writing remaining data
to it until it is full.
- continueWritingWithNextBufferBuilder(BufferBuilder) - Method in class org.apache.flink.runtime.io.network.api.serialization.SpanningRecordSerializer
-
- ContinuousEventTimeTrigger<W extends Window> - Class in org.apache.flink.streaming.api.windowing.triggers
-
A
Trigger
that continuously fires based on a given time interval.
- ContinuousFileMonitoringFunction<OUT> - Class in org.apache.flink.streaming.api.functions.source
-
This is the single (non-parallel) monitoring task which takes a
FileInputFormat
and, depending on the
FileProcessingMode
and the
FilePathFilter
, it is responsible for:
Monitoring a user-provided path.
Deciding which files should be further read and processed.
Creating the
splits
corresponding to those files.
Assigning them to downstream tasks for further processing.
- ContinuousFileMonitoringFunction(FileInputFormat<OUT>, FileProcessingMode, int, long) - Constructor for class org.apache.flink.streaming.api.functions.source.ContinuousFileMonitoringFunction
-
- ContinuousFileReaderOperator<OUT> - Class in org.apache.flink.streaming.api.functions.source
-
- ContinuousFileReaderOperator(FileInputFormat<OUT>) - Constructor for class org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperator
-
- ContinuousProcessingTimeTrigger<W extends Window> - Class in org.apache.flink.streaming.api.windowing.triggers
-
A
Trigger
that continuously fires based on a given time interval as measured by
the clock of the machine on which the job is running.
- ConvergenceCriterion<T extends Value> - Interface in org.apache.flink.api.common.aggregators
-
Used to check for convergence.
- convergenceThreshold - Variable in class org.apache.flink.graph.drivers.parameter.IterationConvergence.Value
-
- ConversionException - Exception in org.apache.flink.runtime.rest.messages
-
Exception which is thrown if an input cannot be converted into the requested type.
- ConversionException(String) - Constructor for exception org.apache.flink.runtime.rest.messages.ConversionException
-
- ConversionException(Throwable) - Constructor for exception org.apache.flink.runtime.rest.messages.ConversionException
-
- ConversionException(String, Throwable) - Constructor for exception org.apache.flink.runtime.rest.messages.ConversionException
-
- convert(RexBuilder, RexNode, RexNode) - Method in interface org.apache.calcite.sql2rel.AuxiliaryConverter
-
Converts an expression.
- convert(RexBuilder, RexNode, RexNode) - Method in class org.apache.calcite.sql2rel.AuxiliaryConverter.Impl
-
- convert(String) - Static method in class org.apache.flink.formats.json.JsonSchemaConverter
-
Converts a JSON schema into Flink's type information.
- convertBoxedJavaType(Object) - Static method in class org.apache.flink.types.JavaToValueConverter
-
- convertFromString(String) - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointIdPathParameter
-
- convertFromString(String) - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskAttemptPathParameter
-
- convertFromString(String) - Method in class org.apache.flink.runtime.rest.messages.JobIDPathParameter
-
- convertFromString(String) - Method in class org.apache.flink.runtime.rest.messages.JobVertexIdPathParameter
-
- convertFromString(String) - Method in class org.apache.flink.runtime.rest.messages.MessageParameter
-
Converts the given string to a valid value of this parameter.
- convertFromString(String) - Method in class org.apache.flink.runtime.rest.messages.MessageQueryParameter
-
- convertFromString(String) - Method in class org.apache.flink.runtime.rest.messages.SubtaskIndexPathParameter
-
- convertFromString(String) - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerIdPathParameter
-
- convertFromString(String) - Method in class org.apache.flink.runtime.rest.messages.TriggerIdPathParameter
-
- convertFromString(String) - Method in class org.apache.flink.runtime.webmonitor.handlers.JarIdPathParameter
-
- convertInetSocketAddresses(List<InetSocketAddress>) - Static method in class org.apache.flink.streaming.connectors.elasticsearch.util.ElasticsearchUtils
-
- convertStringToValue(String) - Method in class org.apache.flink.runtime.rest.messages.AccumulatorsIncludeSerializedValueQueryParameter
-
- convertStringToValue(String) - Method in class org.apache.flink.runtime.rest.messages.job.metrics.JobsFilterQueryParameter
-
- convertStringToValue(String) - Method in class org.apache.flink.runtime.rest.messages.job.metrics.MetricsAggregationParameter
-
- convertStringToValue(String) - Method in class org.apache.flink.runtime.rest.messages.job.metrics.MetricsFilterParameter
-
- convertStringToValue(String) - Method in class org.apache.flink.runtime.rest.messages.job.metrics.SubtasksFilterQueryParameter
-
- convertStringToValue(String) - Method in class org.apache.flink.runtime.rest.messages.job.metrics.TaskManagersFilterQueryParameter
-
- convertStringToValue(String) - Method in class org.apache.flink.runtime.rest.messages.MessageQueryParameter
-
Converts the given string to a valid value of this parameter.
- convertStringToValue(String) - Method in class org.apache.flink.runtime.rest.messages.RescalingParallelismQueryParameter
-
- convertStringToValue(String) - Method in class org.apache.flink.runtime.rest.messages.TerminationModeQueryParameter
-
- convertStringToValue(String) - Method in class org.apache.flink.runtime.webmonitor.handlers.AllowNonRestoredStateQueryParameter
-
- convertStringToValue(String) - Method in class org.apache.flink.runtime.webmonitor.handlers.ParallelismQueryParameter
-
- convertStringToValue(String) - Method in class org.apache.flink.runtime.webmonitor.handlers.StringQueryParameter
-
- convertToOperatorStateSavepointV2(Map<JobVertexID, ExecutionJobVertex>, Savepoint) - Static method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV2
-
- convertToString(Long) - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointIdPathParameter
-
- convertToString(Integer) - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskAttemptPathParameter
-
- convertToString(JobID) - Method in class org.apache.flink.runtime.rest.messages.JobIDPathParameter
-
- convertToString(JobVertexID) - Method in class org.apache.flink.runtime.rest.messages.JobVertexIdPathParameter
-
- convertToString(X) - Method in class org.apache.flink.runtime.rest.messages.MessageParameter
-
Converts the given value to its string representation.
- convertToString(List<X>) - Method in class org.apache.flink.runtime.rest.messages.MessageQueryParameter
-
- convertToString(Integer) - Method in class org.apache.flink.runtime.rest.messages.SubtaskIndexPathParameter
-
- convertToString(ResourceID) - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerIdPathParameter
-
- convertToString(TriggerId) - Method in class org.apache.flink.runtime.rest.messages.TriggerIdPathParameter
-
- convertToString(String) - Method in class org.apache.flink.runtime.webmonitor.handlers.JarIdPathParameter
-
- convertTypeInfoToTaggedValue(TaggedValue.Input, TypeInformation<?>, String, List<CompositeType.FlatFieldDescriptor>, int[]) - Static method in class org.apache.flink.api.java.sca.UdfAnalyzerUtils
-
- convertValueToString(Boolean) - Method in class org.apache.flink.runtime.rest.messages.AccumulatorsIncludeSerializedValueQueryParameter
-
- convertValueToString(JobID) - Method in class org.apache.flink.runtime.rest.messages.job.metrics.JobsFilterQueryParameter
-
- convertValueToString(MetricsAggregationParameter.AggregationMode) - Method in class org.apache.flink.runtime.rest.messages.job.metrics.MetricsAggregationParameter
-
- convertValueToString(String) - Method in class org.apache.flink.runtime.rest.messages.job.metrics.MetricsFilterParameter
-
- convertValueToString(String) - Method in class org.apache.flink.runtime.rest.messages.job.metrics.SubtasksFilterQueryParameter
-
- convertValueToString(ResourceID) - Method in class org.apache.flink.runtime.rest.messages.job.metrics.TaskManagersFilterQueryParameter
-
- convertValueToString(X) - Method in class org.apache.flink.runtime.rest.messages.MessageQueryParameter
-
Converts the given value to its string representation.
- convertValueToString(Integer) - Method in class org.apache.flink.runtime.rest.messages.RescalingParallelismQueryParameter
-
- convertValueToString(TerminationModeQueryParameter.TerminationMode) - Method in class org.apache.flink.runtime.rest.messages.TerminationModeQueryParameter
-
- convertValueToString(Boolean) - Method in class org.apache.flink.runtime.webmonitor.handlers.AllowNonRestoredStateQueryParameter
-
- convertValueToString(Integer) - Method in class org.apache.flink.runtime.webmonitor.handlers.ParallelismQueryParameter
-
- convertValueToString(String) - Method in class org.apache.flink.runtime.webmonitor.handlers.StringQueryParameter
-
- convertValueType(Value) - Static method in class org.apache.flink.types.JavaToValueConverter
-
- CoProcessFunction<IN1,IN2,OUT> - Class in org.apache.flink.streaming.api.functions.co
-
A function that processes elements of two streams and produces a single output one.
- CoProcessFunction() - Constructor for class org.apache.flink.streaming.api.functions.co.CoProcessFunction
-
- CoProcessFunction.Context - Class in org.apache.flink.streaming.api.functions.co
-
- CoProcessFunction.OnTimerContext - Class in org.apache.flink.streaming.api.functions.co
-
- CoProcessOperator<IN1,IN2,OUT> - Class in org.apache.flink.streaming.api.operators.co
-
- CoProcessOperator(CoProcessFunction<IN1, IN2, OUT>) - Constructor for class org.apache.flink.streaming.api.operators.co.CoProcessOperator
-
- copy(Map<String, Accumulator<?, ?>>) - Static method in class org.apache.flink.api.common.accumulators.AccumulatorHelper
-
- copy(boolean[]) - Method in class org.apache.flink.api.common.typeutils.base.array.BooleanPrimitiveArraySerializer
-
- copy(boolean[], boolean[]) - Method in class org.apache.flink.api.common.typeutils.base.array.BooleanPrimitiveArraySerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.array.BooleanPrimitiveArraySerializer
-
- copy(byte[]) - Method in class org.apache.flink.api.common.typeutils.base.array.BytePrimitiveArraySerializer
-
- copy(byte[], byte[]) - Method in class org.apache.flink.api.common.typeutils.base.array.BytePrimitiveArraySerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.array.BytePrimitiveArraySerializer
-
- copy(char[]) - Method in class org.apache.flink.api.common.typeutils.base.array.CharPrimitiveArraySerializer
-
- copy(char[], char[]) - Method in class org.apache.flink.api.common.typeutils.base.array.CharPrimitiveArraySerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.array.CharPrimitiveArraySerializer
-
- copy(double[]) - Method in class org.apache.flink.api.common.typeutils.base.array.DoublePrimitiveArraySerializer
-
- copy(double[], double[]) - Method in class org.apache.flink.api.common.typeutils.base.array.DoublePrimitiveArraySerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.array.DoublePrimitiveArraySerializer
-
- copy(float[]) - Method in class org.apache.flink.api.common.typeutils.base.array.FloatPrimitiveArraySerializer
-
- copy(float[], float[]) - Method in class org.apache.flink.api.common.typeutils.base.array.FloatPrimitiveArraySerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.array.FloatPrimitiveArraySerializer
-
- copy(int[]) - Method in class org.apache.flink.api.common.typeutils.base.array.IntPrimitiveArraySerializer
-
- copy(int[], int[]) - Method in class org.apache.flink.api.common.typeutils.base.array.IntPrimitiveArraySerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.array.IntPrimitiveArraySerializer
-
- copy(long[]) - Method in class org.apache.flink.api.common.typeutils.base.array.LongPrimitiveArraySerializer
-
- copy(long[], long[]) - Method in class org.apache.flink.api.common.typeutils.base.array.LongPrimitiveArraySerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.array.LongPrimitiveArraySerializer
-
- copy(short[]) - Method in class org.apache.flink.api.common.typeutils.base.array.ShortPrimitiveArraySerializer
-
- copy(short[], short[]) - Method in class org.apache.flink.api.common.typeutils.base.array.ShortPrimitiveArraySerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.array.ShortPrimitiveArraySerializer
-
- copy(String[]) - Method in class org.apache.flink.api.common.typeutils.base.array.StringArraySerializer
-
- copy(String[], String[]) - Method in class org.apache.flink.api.common.typeutils.base.array.StringArraySerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.array.StringArraySerializer
-
- copy(BigDecimal) - Method in class org.apache.flink.api.common.typeutils.base.BigDecSerializer
-
- copy(BigDecimal, BigDecimal) - Method in class org.apache.flink.api.common.typeutils.base.BigDecSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.BigDecSerializer
-
- copy(BigInteger) - Method in class org.apache.flink.api.common.typeutils.base.BigIntSerializer
-
- copy(BigInteger, BigInteger) - Method in class org.apache.flink.api.common.typeutils.base.BigIntSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.BigIntSerializer
-
- copy(Boolean) - Method in class org.apache.flink.api.common.typeutils.base.BooleanSerializer
-
- copy(Boolean, Boolean) - Method in class org.apache.flink.api.common.typeutils.base.BooleanSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.BooleanSerializer
-
- copy(BooleanValue) - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueSerializer
-
- copy(BooleanValue, BooleanValue) - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueSerializer
-
- copy(Byte) - Method in class org.apache.flink.api.common.typeutils.base.ByteSerializer
-
- copy(Byte, Byte) - Method in class org.apache.flink.api.common.typeutils.base.ByteSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.ByteSerializer
-
- copy(ByteValue) - Method in class org.apache.flink.api.common.typeutils.base.ByteValueSerializer
-
- copy(ByteValue, ByteValue) - Method in class org.apache.flink.api.common.typeutils.base.ByteValueSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.ByteValueSerializer
-
- copy(Character) - Method in class org.apache.flink.api.common.typeutils.base.CharSerializer
-
- copy(Character, Character) - Method in class org.apache.flink.api.common.typeutils.base.CharSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.CharSerializer
-
- copy(CharValue) - Method in class org.apache.flink.api.common.typeutils.base.CharValueSerializer
-
- copy(CharValue, CharValue) - Method in class org.apache.flink.api.common.typeutils.base.CharValueSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.CharValueSerializer
-
- copy(Date) - Method in class org.apache.flink.api.common.typeutils.base.DateSerializer
-
- copy(Date, Date) - Method in class org.apache.flink.api.common.typeutils.base.DateSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.DateSerializer
-
- copy(Double) - Method in class org.apache.flink.api.common.typeutils.base.DoubleSerializer
-
- copy(Double, Double) - Method in class org.apache.flink.api.common.typeutils.base.DoubleSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.DoubleSerializer
-
- copy(DoubleValue) - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueSerializer
-
- copy(DoubleValue, DoubleValue) - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueSerializer
-
- copy(T) - Method in class org.apache.flink.api.common.typeutils.base.EnumSerializer
-
- copy(T, T) - Method in class org.apache.flink.api.common.typeutils.base.EnumSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.EnumSerializer
-
- copy(Float) - Method in class org.apache.flink.api.common.typeutils.base.FloatSerializer
-
- copy(Float, Float) - Method in class org.apache.flink.api.common.typeutils.base.FloatSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.FloatSerializer
-
- copy(FloatValue) - Method in class org.apache.flink.api.common.typeutils.base.FloatValueSerializer
-
- copy(FloatValue, FloatValue) - Method in class org.apache.flink.api.common.typeutils.base.FloatValueSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.FloatValueSerializer
-
- copy(C[]) - Method in class org.apache.flink.api.common.typeutils.base.GenericArraySerializer
-
- copy(C[], C[]) - Method in class org.apache.flink.api.common.typeutils.base.GenericArraySerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.GenericArraySerializer
-
- copy(Integer) - Method in class org.apache.flink.api.common.typeutils.base.IntSerializer
-
- copy(Integer, Integer) - Method in class org.apache.flink.api.common.typeutils.base.IntSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.IntSerializer
-
- copy(IntValue) - Method in class org.apache.flink.api.common.typeutils.base.IntValueSerializer
-
- copy(IntValue, IntValue) - Method in class org.apache.flink.api.common.typeutils.base.IntValueSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.IntValueSerializer
-
- copy(List<T>) - Method in class org.apache.flink.api.common.typeutils.base.ListSerializer
-
- copy(List<T>, List<T>) - Method in class org.apache.flink.api.common.typeutils.base.ListSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.ListSerializer
-
- copy(Long) - Method in class org.apache.flink.api.common.typeutils.base.LongSerializer
-
- copy(Long, Long) - Method in class org.apache.flink.api.common.typeutils.base.LongSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.LongSerializer
-
- copy(LongValue) - Method in class org.apache.flink.api.common.typeutils.base.LongValueSerializer
-
- copy(LongValue, LongValue) - Method in class org.apache.flink.api.common.typeutils.base.LongValueSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.LongValueSerializer
-
- copy(Map<K, V>) - Method in class org.apache.flink.api.common.typeutils.base.MapSerializer
-
- copy(Map<K, V>, Map<K, V>) - Method in class org.apache.flink.api.common.typeutils.base.MapSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.MapSerializer
-
- copy(NullValue) - Method in class org.apache.flink.api.common.typeutils.base.NullValueSerializer
-
- copy(NullValue, NullValue) - Method in class org.apache.flink.api.common.typeutils.base.NullValueSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.NullValueSerializer
-
- copy(Short) - Method in class org.apache.flink.api.common.typeutils.base.ShortSerializer
-
- copy(Short, Short) - Method in class org.apache.flink.api.common.typeutils.base.ShortSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.ShortSerializer
-
- copy(ShortValue) - Method in class org.apache.flink.api.common.typeutils.base.ShortValueSerializer
-
- copy(ShortValue, ShortValue) - Method in class org.apache.flink.api.common.typeutils.base.ShortValueSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.ShortValueSerializer
-
- copy(Date) - Method in class org.apache.flink.api.common.typeutils.base.SqlDateSerializer
-
- copy(Date, Date) - Method in class org.apache.flink.api.common.typeutils.base.SqlDateSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.SqlDateSerializer
-
- copy(Time) - Method in class org.apache.flink.api.common.typeutils.base.SqlTimeSerializer
-
- copy(Time, Time) - Method in class org.apache.flink.api.common.typeutils.base.SqlTimeSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.SqlTimeSerializer
-
- copy(Timestamp) - Method in class org.apache.flink.api.common.typeutils.base.SqlTimestampSerializer
-
- copy(Timestamp, Timestamp) - Method in class org.apache.flink.api.common.typeutils.base.SqlTimestampSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.SqlTimestampSerializer
-
- copy(String) - Method in class org.apache.flink.api.common.typeutils.base.StringSerializer
-
- copy(String, String) - Method in class org.apache.flink.api.common.typeutils.base.StringSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.StringSerializer
-
- copy(StringValue) - Method in class org.apache.flink.api.common.typeutils.base.StringValueSerializer
-
- copy(StringValue, StringValue) - Method in class org.apache.flink.api.common.typeutils.base.StringValueSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.StringValueSerializer
-
- copy(Void) - Method in class org.apache.flink.api.common.typeutils.base.VoidSerializer
-
- copy(Void, Void) - Method in class org.apache.flink.api.common.typeutils.base.VoidSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.VoidSerializer
-
- copy(T) - Method in class org.apache.flink.api.common.typeutils.TypeDeserializerAdapter
-
- copy(T, T) - Method in class org.apache.flink.api.common.typeutils.TypeDeserializerAdapter
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.TypeDeserializerAdapter
-
- copy(T) - Method in class org.apache.flink.api.common.typeutils.TypeSerializer
-
Creates a deep copy of the given element in a new element.
- copy(T, T) - Method in class org.apache.flink.api.common.typeutils.TypeSerializer
-
Creates a copy from the given element.
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.TypeSerializer
-
Copies exactly one record from the source input view to the target output view.
- copy(T) - Method in class org.apache.flink.api.common.typeutils.UnloadableDummyTypeSerializer
-
- copy(T, T) - Method in class org.apache.flink.api.common.typeutils.UnloadableDummyTypeSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.UnloadableDummyTypeSerializer
-
- copy() - Method in class org.apache.flink.api.java.sca.TaggedValue
-
- copy(Type) - Method in class org.apache.flink.api.java.sca.TaggedValue
-
- copy() - Method in class org.apache.flink.api.java.tuple.Tuple
-
Shallow tuple copy.
- copy() - Method in class org.apache.flink.api.java.tuple.Tuple0
-
Shallow tuple copy.
- copy() - Method in class org.apache.flink.api.java.tuple.Tuple1
-
Shallow tuple copy.
- copy() - Method in class org.apache.flink.api.java.tuple.Tuple10
-
Shallow tuple copy.
- copy() - Method in class org.apache.flink.api.java.tuple.Tuple11
-
Shallow tuple copy.
- copy() - Method in class org.apache.flink.api.java.tuple.Tuple12
-
Shallow tuple copy.
- copy() - Method in class org.apache.flink.api.java.tuple.Tuple13
-
Shallow tuple copy.
- copy() - Method in class org.apache.flink.api.java.tuple.Tuple14
-
Shallow tuple copy.
- copy() - Method in class org.apache.flink.api.java.tuple.Tuple15
-
Shallow tuple copy.
- copy() - Method in class org.apache.flink.api.java.tuple.Tuple16
-
Shallow tuple copy.
- copy() - Method in class org.apache.flink.api.java.tuple.Tuple17
-
Shallow tuple copy.
- copy() - Method in class org.apache.flink.api.java.tuple.Tuple18
-
Shallow tuple copy.
- copy() - Method in class org.apache.flink.api.java.tuple.Tuple19
-
Shallow tuple copy.
- copy() - Method in class org.apache.flink.api.java.tuple.Tuple2
-
Shallow tuple copy.
- copy() - Method in class org.apache.flink.api.java.tuple.Tuple20
-
Shallow tuple copy.
- copy() - Method in class org.apache.flink.api.java.tuple.Tuple21
-
Shallow tuple copy.
- copy() - Method in class org.apache.flink.api.java.tuple.Tuple22
-
Shallow tuple copy.
- copy() - Method in class org.apache.flink.api.java.tuple.Tuple23
-
Shallow tuple copy.
- copy() - Method in class org.apache.flink.api.java.tuple.Tuple24
-
Shallow tuple copy.
- copy() - Method in class org.apache.flink.api.java.tuple.Tuple25
-
Shallow tuple copy.
- copy() - Method in class org.apache.flink.api.java.tuple.Tuple3
-
Shallow tuple copy.
- copy() - Method in class org.apache.flink.api.java.tuple.Tuple4
-
Shallow tuple copy.
- copy() - Method in class org.apache.flink.api.java.tuple.Tuple5
-
Shallow tuple copy.
- copy() - Method in class org.apache.flink.api.java.tuple.Tuple6
-
Shallow tuple copy.
- copy() - Method in class org.apache.flink.api.java.tuple.Tuple7
-
Shallow tuple copy.
- copy() - Method in class org.apache.flink.api.java.tuple.Tuple8
-
Shallow tuple copy.
- copy() - Method in class org.apache.flink.api.java.tuple.Tuple9
-
Shallow tuple copy.
- copy(T) - Method in class org.apache.flink.api.java.typeutils.runtime.AvroSerializer
-
Deprecated.
- copy(T, T) - Method in class org.apache.flink.api.java.typeutils.runtime.AvroSerializer
-
Deprecated.
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.AvroSerializer
-
Deprecated.
- copy(T) - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer
-
- copy(T, T) - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer
-
- copy(Either<L, R>) - Method in class org.apache.flink.api.java.typeutils.runtime.EitherSerializer
-
- copy(Either<L, R>, Either<L, R>) - Method in class org.apache.flink.api.java.typeutils.runtime.EitherSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.EitherSerializer
-
- copy(T) - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer
-
- copy(T, T) - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer
-
- copy(T, Kryo, TypeSerializer<T>) - Static method in class org.apache.flink.api.java.typeutils.runtime.KryoUtils
-
Tries to copy the given record from using the provided Kryo instance.
- copy(T, T, Kryo, TypeSerializer<T>) - Static method in class org.apache.flink.api.java.typeutils.runtime.KryoUtils
-
Tries to copy the given record from using the provided Kryo instance.
- copy(T) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer
-
- copy(T, T) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer
-
- copy(Row) - Method in class org.apache.flink.api.java.typeutils.runtime.RowSerializer
-
- copy(Row, Row) - Method in class org.apache.flink.api.java.typeutils.runtime.RowSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.RowSerializer
-
- copy(Tuple0) - Method in class org.apache.flink.api.java.typeutils.runtime.Tuple0Serializer
-
- copy(Tuple0, Tuple0) - Method in class org.apache.flink.api.java.typeutils.runtime.Tuple0Serializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.Tuple0Serializer
-
- copy(T) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializer
-
- copy(T, T) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializerBase
-
- copy(T) - Method in class org.apache.flink.api.java.typeutils.runtime.ValueSerializer
-
- copy(T, T) - Method in class org.apache.flink.api.java.typeutils.runtime.ValueSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.ValueSerializer
-
- copy(T) - Method in class org.apache.flink.api.java.typeutils.runtime.WritableSerializer
-
- copy(T, T) - Method in class org.apache.flink.api.java.typeutils.runtime.WritableSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.WritableSerializer
-
- copy(DeweyNumber) - Method in class org.apache.flink.cep.nfa.DeweyNumber.DeweyNumberSerializer
-
- copy(DeweyNumber, DeweyNumber) - Method in class org.apache.flink.cep.nfa.DeweyNumber.DeweyNumberSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.cep.nfa.DeweyNumber.DeweyNumberSerializer
-
- copy(NFA<T>) - Method in class org.apache.flink.cep.nfa.NFA.NFASerializer
-
- copy(NFA<T>, NFA<T>) - Method in class org.apache.flink.cep.nfa.NFA.NFASerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.cep.nfa.NFA.NFASerializer
-
- copy(SharedBuffer<K, V>) - Method in class org.apache.flink.cep.nfa.SharedBuffer.SharedBufferSerializer
-
- copy(SharedBuffer<K, V>, SharedBuffer<K, V>) - Method in class org.apache.flink.cep.nfa.SharedBuffer.SharedBufferSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.cep.nfa.SharedBuffer.SharedBufferSerializer
-
- copy(T) - Method in class org.apache.flink.formats.avro.typeutils.AvroSerializer
-
- copy(T, T) - Method in class org.apache.flink.formats.avro.typeutils.AvroSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.formats.avro.typeutils.AvroSerializer
-
- copy(T) - Method in class org.apache.flink.formats.avro.typeutils.BackwardsCompatibleAvroSerializer
-
- copy(T, T) - Method in class org.apache.flink.formats.avro.typeutils.BackwardsCompatibleAvroSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.formats.avro.typeutils.BackwardsCompatibleAvroSerializer
-
- copy(LongValueWithProperHashCode) - Method in class org.apache.flink.graph.drivers.transform.LongValueWithProperHashCode.LongValueWithProperHashCodeSerializer
-
- copy(LongValueWithProperHashCode, LongValueWithProperHashCode) - Method in class org.apache.flink.graph.drivers.transform.LongValueWithProperHashCode.LongValueWithProperHashCodeSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.graph.drivers.transform.LongValueWithProperHashCode.LongValueWithProperHashCodeSerializer
-
- copy() - Method in class org.apache.flink.graph.types.valuearray.ByteValueArray
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.graph.types.valuearray.ByteValueArray
-
- copy(ByteValueArray) - Method in class org.apache.flink.graph.types.valuearray.ByteValueArraySerializer
-
- copy(ByteValueArray, ByteValueArray) - Method in class org.apache.flink.graph.types.valuearray.ByteValueArraySerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.graph.types.valuearray.ByteValueArraySerializer
-
- copy() - Method in class org.apache.flink.graph.types.valuearray.CharValueArray
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.graph.types.valuearray.CharValueArray
-
- copy(CharValueArray) - Method in class org.apache.flink.graph.types.valuearray.CharValueArraySerializer
-
- copy(CharValueArray, CharValueArray) - Method in class org.apache.flink.graph.types.valuearray.CharValueArraySerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.graph.types.valuearray.CharValueArraySerializer
-
- copy() - Method in class org.apache.flink.graph.types.valuearray.DoubleValueArray
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.graph.types.valuearray.DoubleValueArray
-
- copy(DoubleValueArray) - Method in class org.apache.flink.graph.types.valuearray.DoubleValueArraySerializer
-
- copy(DoubleValueArray, DoubleValueArray) - Method in class org.apache.flink.graph.types.valuearray.DoubleValueArraySerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.graph.types.valuearray.DoubleValueArraySerializer
-
- copy() - Method in class org.apache.flink.graph.types.valuearray.FloatValueArray
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.graph.types.valuearray.FloatValueArray
-
- copy(FloatValueArray) - Method in class org.apache.flink.graph.types.valuearray.FloatValueArraySerializer
-
- copy(FloatValueArray, FloatValueArray) - Method in class org.apache.flink.graph.types.valuearray.FloatValueArraySerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.graph.types.valuearray.FloatValueArraySerializer
-
- copy() - Method in class org.apache.flink.graph.types.valuearray.IntValueArray
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.graph.types.valuearray.IntValueArray
-
- copy(IntValueArray) - Method in class org.apache.flink.graph.types.valuearray.IntValueArraySerializer
-
- copy(IntValueArray, IntValueArray) - Method in class org.apache.flink.graph.types.valuearray.IntValueArraySerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.graph.types.valuearray.IntValueArraySerializer
-
- copy() - Method in class org.apache.flink.graph.types.valuearray.LongValueArray
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.graph.types.valuearray.LongValueArray
-
- copy(LongValueArray) - Method in class org.apache.flink.graph.types.valuearray.LongValueArraySerializer
-
- copy(LongValueArray, LongValueArray) - Method in class org.apache.flink.graph.types.valuearray.LongValueArraySerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.graph.types.valuearray.LongValueArraySerializer
-
- copy() - Method in class org.apache.flink.graph.types.valuearray.NullValueArray
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.graph.types.valuearray.NullValueArray
-
- copy(NullValueArray) - Method in class org.apache.flink.graph.types.valuearray.NullValueArraySerializer
-
- copy(NullValueArray, NullValueArray) - Method in class org.apache.flink.graph.types.valuearray.NullValueArraySerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.graph.types.valuearray.NullValueArraySerializer
-
- copy() - Method in class org.apache.flink.graph.types.valuearray.ShortValueArray
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.graph.types.valuearray.ShortValueArray
-
- copy(ShortValueArray) - Method in class org.apache.flink.graph.types.valuearray.ShortValueArraySerializer
-
- copy(ShortValueArray, ShortValueArray) - Method in class org.apache.flink.graph.types.valuearray.ShortValueArraySerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.graph.types.valuearray.ShortValueArraySerializer
-
- copy() - Method in class org.apache.flink.graph.types.valuearray.StringValueArray
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.graph.types.valuearray.StringValueArray
-
- copy(StringValueArray) - Method in class org.apache.flink.graph.types.valuearray.StringValueArraySerializer
-
- copy(StringValueArray, StringValueArray) - Method in class org.apache.flink.graph.types.valuearray.StringValueArraySerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.graph.types.valuearray.StringValueArraySerializer
-
- copy(VoidNamespace) - Method in class org.apache.flink.queryablestate.client.VoidNamespaceSerializer
-
- copy(VoidNamespace, VoidNamespace) - Method in class org.apache.flink.queryablestate.client.VoidNamespaceSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.queryablestate.client.VoidNamespaceSerializer
-
- copy(Path, Path, boolean) - Static method in class org.apache.flink.runtime.filecache.FileCache
-
- copy() - Method in class org.apache.flink.runtime.io.network.buffer.BufferConsumer
-
Creates a retained copy of self with separate indexes which allows two read from the same
MemorySegment
twice.
- copy(int, int) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
-
- copy(String) - Method in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo
-
Create a copy of this QueryScopeInfo and append the given scope.
- copy(String) - Method in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.JobManagerQueryScopeInfo
-
- copy(String) - Method in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.JobQueryScopeInfo
-
- copy(String) - Method in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.OperatorQueryScopeInfo
-
- copy(String) - Method in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.TaskManagerQueryScopeInfo
-
- copy(String) - Method in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.TaskQueryScopeInfo
-
- copy(ArrayList<T>) - Method in class org.apache.flink.runtime.state.ArrayListSerializer
-
- copy(ArrayList<T>, ArrayList<T>) - Method in class org.apache.flink.runtime.state.ArrayListSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.runtime.state.ArrayListSerializer
-
- copy(VoidNamespace) - Method in class org.apache.flink.runtime.state.VoidNamespaceSerializer
-
- copy(VoidNamespace, VoidNamespace) - Method in class org.apache.flink.runtime.state.VoidNamespaceSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.runtime.state.VoidNamespaceSerializer
-
- copy(TwoPhaseCommitSinkFunction.State<TXN, CONTEXT>) - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.StateSerializer
-
- copy(TwoPhaseCommitSinkFunction.State<TXN, CONTEXT>, TwoPhaseCommitSinkFunction.State<TXN, CONTEXT>) - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.StateSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.StateSerializer
-
- copy(InternalTimer<K, N>) - Method in class org.apache.flink.streaming.api.operators.InternalTimer.TimerSerializer
-
- copy(InternalTimer<K, N>, InternalTimer<K, N>) - Method in class org.apache.flink.streaming.api.operators.InternalTimer.TimerSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.streaming.api.operators.InternalTimer.TimerSerializer
-
- copy(GlobalWindow) - Method in class org.apache.flink.streaming.api.windowing.windows.GlobalWindow.Serializer
-
- copy(GlobalWindow, GlobalWindow) - Method in class org.apache.flink.streaming.api.windowing.windows.GlobalWindow.Serializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.streaming.api.windowing.windows.GlobalWindow.Serializer
-
- copy(TimeWindow) - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow.Serializer
-
- copy(TimeWindow, TimeWindow) - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow.Serializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow.Serializer
-
- copy(FlinkKafkaProducer011.KafkaTransactionContext) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer011.ContextStateSerializer
-
- copy(FlinkKafkaProducer011.KafkaTransactionContext, FlinkKafkaProducer011.KafkaTransactionContext) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer011.ContextStateSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer011.ContextStateSerializer
-
- copy(FlinkKafkaProducer011.KafkaTransactionState) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer011.TransactionStateSerializer
-
- copy(FlinkKafkaProducer011.KafkaTransactionState, FlinkKafkaProducer011.KafkaTransactionState) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer011.TransactionStateSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer011.TransactionStateSerializer
-
- copy() - Method in class org.apache.flink.streaming.runtime.partitioner.BroadcastPartitioner
-
- copy() - Method in class org.apache.flink.streaming.runtime.partitioner.CustomPartitionerWrapper
-
- copy() - Method in class org.apache.flink.streaming.runtime.partitioner.ForwardPartitioner
-
- copy() - Method in class org.apache.flink.streaming.runtime.partitioner.GlobalPartitioner
-
- copy() - Method in class org.apache.flink.streaming.runtime.partitioner.KeyGroupStreamPartitioner
-
- copy() - Method in class org.apache.flink.streaming.runtime.partitioner.RebalancePartitioner
-
- copy() - Method in class org.apache.flink.streaming.runtime.partitioner.RescalePartitioner
-
- copy() - Method in class org.apache.flink.streaming.runtime.partitioner.ShufflePartitioner
-
- copy() - Method in class org.apache.flink.streaming.runtime.partitioner.StreamPartitioner
-
- copy(StreamElement) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
-
- copy(StreamElement, StreamElement) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
-
- copy(T) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecord
-
Creates a copy of this stream record.
- copy() - Method in class org.apache.flink.table.client.gateway.SessionContext
-
- copy() - Method in class org.apache.flink.types.BooleanValue
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.types.BooleanValue
-
- copy() - Method in class org.apache.flink.types.ByteValue
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.types.ByteValue
-
- copy() - Method in class org.apache.flink.types.CharValue
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.types.CharValue
-
- copy() - Method in interface org.apache.flink.types.CopyableValue
-
Performs a deep copy of this object into a new instance.
- copy(DataInputView, DataOutputView) - Method in interface org.apache.flink.types.CopyableValue
-
Copies the next serialized instance from source
to target
.
- copy() - Method in class org.apache.flink.types.DoubleValue
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.types.DoubleValue
-
- copy() - Method in class org.apache.flink.types.FloatValue
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.types.FloatValue
-
- copy() - Method in class org.apache.flink.types.IntValue
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.types.IntValue
-
- copy() - Method in class org.apache.flink.types.LongValue
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.types.LongValue
-
- copy() - Method in class org.apache.flink.types.NullValue
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.types.NullValue
-
- copy() - Method in class org.apache.flink.types.Record
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.types.Record
-
- copy(Row) - Static method in class org.apache.flink.types.Row
-
Creates a new Row which copied from another row.
- copy() - Method in class org.apache.flink.types.ShortValue
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.types.ShortValue
-
- copy() - Method in class org.apache.flink.types.StringValue
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.types.StringValue
-
- copy1 - Variable in class org.apache.flink.runtime.operators.sort.AbstractMergeIterator
-
- copy2 - Variable in class org.apache.flink.runtime.operators.sort.AbstractMergeIterator
-
- CopyableValue<T> - Interface in org.apache.flink.types
-
Interface to be implemented by basic types that support to be copied efficiently.
- CopyableValueComparator<T extends CopyableValue<T> & Comparable<T>> - Class in org.apache.flink.api.java.typeutils.runtime
-
Comparator for all Value types that extend Key
- CopyableValueComparator(boolean, Class<T>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.CopyableValueComparator
-
- CopyableValueSerializer<T extends CopyableValue<T>> - Class in org.apache.flink.api.java.typeutils.runtime
-
- CopyableValueSerializer(Class<T>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer
-
- CopyableValueSerializer.CopyableValueSerializerConfigSnapshot<T extends CopyableValue<T>> - Class in org.apache.flink.api.java.typeutils.runtime
-
- CopyableValueSerializerConfigSnapshot() - Constructor for class org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer.CopyableValueSerializerConfigSnapshot
-
This empty nullary constructor is required for deserializing the configuration.
- CopyableValueSerializerConfigSnapshot(Class<T>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer.CopyableValueSerializerConfigSnapshot
-
- copyBigInteger(DataInputView, DataOutputView) - Static method in class org.apache.flink.api.common.typeutils.base.BigIntSerializer
-
- copyBytes(InputStream, OutputStream, int, boolean) - Static method in class org.apache.flink.util.IOUtils
-
Copies from one stream to another.
- copyBytes(InputStream, OutputStream) - Static method in class org.apache.flink.util.IOUtils
-
Copies from one stream to another.
- copyBytes(InputStream, OutputStream, boolean) - Static method in class org.apache.flink.util.IOUtils
-
Copies from one stream to another.
- copyEstimates(OptimizerNode) - Method in class org.apache.flink.optimizer.dag.AbstractPartialSolutionNode
-
- copyFrom(CompilerHints) - Method in class org.apache.flink.api.common.operators.CompilerHints
-
- copyFrom(EnumTrianglesDataTypes.EdgeWithDegrees) - Method in class org.apache.flink.examples.java.graph.util.EnumTrianglesDataTypes.EdgeWithDegrees
-
- copyFrom(TriangleEnumerator.EdgeWithDegrees<K>) - Method in class org.apache.flink.graph.library.TriangleEnumerator.EdgeWithDegrees
-
- copyFrom(Record, int[], int[]) - Method in class org.apache.flink.types.Record
-
Bin-copies fields from a source record to this record.
- CopyingDirectedOutput<OUT> - Class in org.apache.flink.streaming.api.collector.selector
-
- CopyingDirectedOutput(List<OutputSelector<OUT>>, List<? extends Tuple2<? extends Output<StreamRecord<OUT>>, StreamEdge>>) - Constructor for class org.apache.flink.streaming.api.collector.selector.CopyingDirectedOutput
-
- CopyingIterator<E> - Class in org.apache.flink.api.common.functions.util
-
- CopyingIterator(Iterator<E>, TypeSerializer<E>) - Constructor for class org.apache.flink.api.common.functions.util.CopyingIterator
-
- CopyingListCollector<T> - Class in org.apache.flink.api.common.functions.util
-
- CopyingListCollector(List<T>, TypeSerializer<T>) - Constructor for class org.apache.flink.api.common.functions.util.CopyingListCollector
-
- copyInternal(DataInputView, DataOutputView) - Static method in class org.apache.flink.graph.types.valuearray.ByteValueArray
-
- copyInternal(DataInputView, DataOutputView) - Static method in class org.apache.flink.graph.types.valuearray.CharValueArray
-
- copyInternal(DataInputView, DataOutputView) - Static method in class org.apache.flink.graph.types.valuearray.DoubleValueArray
-
- copyInternal(DataInputView, DataOutputView) - Static method in class org.apache.flink.graph.types.valuearray.FloatValueArray
-
- copyInternal(DataInputView, DataOutputView) - Static method in class org.apache.flink.graph.types.valuearray.IntValueArray
-
- copyInternal(DataInputView, DataOutputView) - Static method in class org.apache.flink.graph.types.valuearray.LongValueArray
-
- copyInternal(DataInputView, DataOutputView) - Static method in class org.apache.flink.graph.types.valuearray.ShortValueArray
-
- copyInternal(DataInputView, DataOutputView) - Static method in class org.apache.flink.graph.types.valuearray.StringValueArray
-
- copyNormalizedKey(MemorySegment, int, int) - Method in class org.apache.flink.graph.types.valuearray.ByteValueArray
-
- copyNormalizedKey(MemorySegment, int, int) - Method in class org.apache.flink.graph.types.valuearray.CharValueArray
-
- copyNormalizedKey(MemorySegment, int, int) - Method in class org.apache.flink.graph.types.valuearray.DoubleValueArray
-
- copyNormalizedKey(MemorySegment, int, int) - Method in class org.apache.flink.graph.types.valuearray.FloatValueArray
-
- copyNormalizedKey(MemorySegment, int, int) - Method in class org.apache.flink.graph.types.valuearray.IntValueArray
-
- copyNormalizedKey(MemorySegment, int, int) - Method in class org.apache.flink.graph.types.valuearray.LongValueArray
-
- copyNormalizedKey(MemorySegment, int, int) - Method in class org.apache.flink.graph.types.valuearray.NullValueArray
-
- copyNormalizedKey(MemorySegment, int, int) - Method in class org.apache.flink.graph.types.valuearray.ShortValueArray
-
- copyNormalizedKey(MemorySegment, int, int) - Method in class org.apache.flink.graph.types.valuearray.StringValueArray
-
- copyNormalizedKey(MemorySegment, int, int) - Method in class org.apache.flink.types.BooleanValue
-
- copyNormalizedKey(MemorySegment, int, int) - Method in class org.apache.flink.types.ByteValue
-
- copyNormalizedKey(MemorySegment, int, int) - Method in class org.apache.flink.types.CharValue
-
- copyNormalizedKey(MemorySegment, int, int) - Method in class org.apache.flink.types.IntValue
-
- copyNormalizedKey(MemorySegment, int, int) - Method in class org.apache.flink.types.LongValue
-
- copyNormalizedKey(MemorySegment, int, int) - Method in interface org.apache.flink.types.NormalizableKey
-
Writes a normalized key for the given record into the target byte array, starting at the specified position
an writing exactly the given number of bytes.
- copyNormalizedKey(MemorySegment, int, int) - Method in class org.apache.flink.types.NullValue
-
- copyNormalizedKey(MemorySegment, int, int) - Method in class org.apache.flink.types.ShortValue
-
- copyNormalizedKey(MemorySegment, int, int) - Method in class org.apache.flink.types.StringValue
-
- CopyOnWriteStateTable<K,N,S> - Class in org.apache.flink.runtime.state.heap
-
Implementation of Flink's in-memory state tables with copy-on-write support.
- CopyOnWriteStateTableSnapshot<K,N,S> - Class in org.apache.flink.runtime.state.heap
-
This class represents the snapshot of a
CopyOnWriteStateTable
and has a role in operator state checkpointing.
- copyOperation(AbstractInsnNode, BasicValue) - Method in class org.apache.flink.api.java.sca.NestedMethodAnalyzer
-
- copyString(DataInput, DataOutput) - Static method in class org.apache.flink.types.StringValue
-
- copyTemplate() - Method in class org.apache.flink.runtime.metrics.scope.ScopeFormat
-
- copyTo(int, MemorySegment, int, int) - Method in class org.apache.flink.core.memory.MemorySegment
-
Bulk copy method.
- copyTo(ValueArray<ByteValue>) - Method in class org.apache.flink.graph.types.valuearray.ByteValueArray
-
- copyTo(ValueArray<CharValue>) - Method in class org.apache.flink.graph.types.valuearray.CharValueArray
-
- copyTo(ValueArray<DoubleValue>) - Method in class org.apache.flink.graph.types.valuearray.DoubleValueArray
-
- copyTo(ValueArray<FloatValue>) - Method in class org.apache.flink.graph.types.valuearray.FloatValueArray
-
- copyTo(ValueArray<IntValue>) - Method in class org.apache.flink.graph.types.valuearray.IntValueArray
-
- copyTo(ValueArray<LongValue>) - Method in class org.apache.flink.graph.types.valuearray.LongValueArray
-
- copyTo(ValueArray<NullValue>) - Method in class org.apache.flink.graph.types.valuearray.NullValueArray
-
- copyTo(ValueArray<ShortValue>) - Method in class org.apache.flink.graph.types.valuearray.ShortValueArray
-
- copyTo(ValueArray<StringValue>) - Method in class org.apache.flink.graph.types.valuearray.StringValueArray
-
- copyTo(T, StreamRecord<T>) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecord
-
Copies this record into the new stream record.
- copyTo(BooleanValue) - Method in class org.apache.flink.types.BooleanValue
-
- copyTo(ByteValue) - Method in class org.apache.flink.types.ByteValue
-
- copyTo(CharValue) - Method in class org.apache.flink.types.CharValue
-
- copyTo(T) - Method in interface org.apache.flink.types.CopyableValue
-
Performs a deep copy of this object into the target
instance.
- copyTo(DoubleValue) - Method in class org.apache.flink.types.DoubleValue
-
- copyTo(FloatValue) - Method in class org.apache.flink.types.FloatValue
-
- copyTo(IntValue) - Method in class org.apache.flink.types.IntValue
-
- copyTo(LongValue) - Method in class org.apache.flink.types.LongValue
-
- copyTo(NullValue) - Method in class org.apache.flink.types.NullValue
-
- copyTo(Record) - Method in class org.apache.flink.types.Record
-
- copyTo(ShortValue) - Method in class org.apache.flink.types.ShortValue
-
- copyTo(StringValue) - Method in class org.apache.flink.types.StringValue
-
- copyVerticesFromEdgeWithDegrees(EnumTrianglesDataTypes.EdgeWithDegrees) - Method in class org.apache.flink.examples.java.graph.util.EnumTrianglesDataTypes.Edge
-
- copyVerticesFromTuple2(Tuple2<Integer, Integer>) - Method in class org.apache.flink.examples.java.graph.util.EnumTrianglesDataTypes.Edge
-
- CoreOptions - Class in org.apache.flink.configuration
-
The set of configuration options for core parameters.
- CoreOptions() - Constructor for class org.apache.flink.configuration.CoreOptions
-
- CorruptConfigurationException - Exception in org.apache.flink.runtime.operators.util
-
Exception indicating that the parsed configuration was corrupt.
- CorruptConfigurationException(String) - Constructor for exception org.apache.flink.runtime.operators.util.CorruptConfigurationException
-
Creates a new exception with the given error message.
- CorruptConfigurationException(String, Throwable) - Constructor for exception org.apache.flink.runtime.operators.util.CorruptConfigurationException
-
- CosineDistance<DATA> - Class in org.apache.flink.streaming.api.functions.windowing.delta
-
This delta function calculates the cosine distance between two given vectors.
- CosineDistance() - Constructor for class org.apache.flink.streaming.api.functions.windowing.delta.CosineDistance
-
- CosineDistance(Extractor<DATA, double[]>) - Constructor for class org.apache.flink.streaming.api.functions.windowing.delta.CosineDistance
-
- CostEstimator - Class in org.apache.flink.optimizer.costs
-
Abstract base class for a cost estimator.
- CostEstimator() - Constructor for class org.apache.flink.optimizer.costs.CostEstimator
-
- costOperator(PlanNode) - Method in class org.apache.flink.optimizer.costs.CostEstimator
-
This method computes the cost of an operator.
- CoStreamFlatMap<IN1,IN2,OUT> - Class in org.apache.flink.streaming.api.operators.co
-
- CoStreamFlatMap(CoFlatMapFunction<IN1, IN2, OUT>) - Constructor for class org.apache.flink.streaming.api.operators.co.CoStreamFlatMap
-
- CoStreamMap<IN1,IN2,OUT> - Class in org.apache.flink.streaming.api.operators.co
-
- CoStreamMap(CoMapFunction<IN1, IN2, OUT>) - Constructor for class org.apache.flink.streaming.api.operators.co.CoStreamMap
-
- Costs - Class in org.apache.flink.optimizer.costs
-
Simple class to represent the costs of an operation.
- Costs() - Constructor for class org.apache.flink.optimizer.costs.Costs
-
Default constructor.
- Costs(double, double) - Constructor for class org.apache.flink.optimizer.costs.Costs
-
Creates a new costs object using the given values for the network and storage cost.
- Costs(double, double, double) - Constructor for class org.apache.flink.optimizer.costs.Costs
-
Creates a new costs object using the given values for the network and storage cost.
- costWeight - Variable in class org.apache.flink.optimizer.dag.OptimizerNode
-
- count() - Method in class org.apache.flink.api.java.DataSet
-
Convenience method to get the count (number of elements) of a DataSet.
- count - Variable in class org.apache.flink.core.memory.ByteArrayInputStreamWithPos
-
- count - Variable in class org.apache.flink.core.memory.ByteArrayOutputStreamWithPos
-
- Count<T> - Class in org.apache.flink.graph.asm.dataset
-
Count the number of elements in a
DataSet
.
- Count() - Constructor for class org.apache.flink.graph.asm.dataset.Count
-
- count(DataSet<T>) - Static method in class org.apache.flink.graph.utils.GraphUtils
-
Count the number of elements in a DataSet.
- count - Variable in class org.apache.flink.python.api.PythonOperationInfo
-
- count - Variable in class org.apache.flink.runtime.metrics.dump.MetricDump.CounterDump
-
- count - Variable in class org.apache.flink.streaming.examples.socket.SocketWindowWordCount.WordWithCount
-
- count_window(long, long) - Method in class org.apache.flink.streaming.python.api.datastream.PythonKeyedStream
-
- CountAppender() - Constructor for class org.apache.flink.examples.java.clustering.KMeans.CountAppender
-
- countBuffers() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
-
- countElementsPerPartition(DataSet<T>) - Static method in class org.apache.flink.api.java.utils.DataSetUtils
-
Method that goes over all the elements in each partition in order to retrieve
the total number of elements.
- Counter - Interface in org.apache.flink.metrics
-
A Counter is a
Metric
that measures a count.
- counter(int) - Method in class org.apache.flink.metrics.groups.UnregisteredMetricsGroup
-
- counter(String) - Method in class org.apache.flink.metrics.groups.UnregisteredMetricsGroup
-
- counter(int, C) - Method in class org.apache.flink.metrics.groups.UnregisteredMetricsGroup
-
- counter(String, C) - Method in class org.apache.flink.metrics.groups.UnregisteredMetricsGroup
-
- counter(int) - Method in interface org.apache.flink.metrics.MetricGroup
-
Creates and registers a new
Counter
with Flink.
- counter(String) - Method in interface org.apache.flink.metrics.MetricGroup
-
Creates and registers a new
Counter
with Flink.
- counter(int, C) - Method in interface org.apache.flink.metrics.MetricGroup
-
- counter(String, C) - Method in interface org.apache.flink.metrics.MetricGroup
-
- counter(int) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
-
- counter(String) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
-
- counter(int, C) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
-
- counter(String, C) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
-
- counter(int) - Method in class org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
-
- counter(String) - Method in class org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
-
- counter(int, C) - Method in class org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
-
- counter(String, C) - Method in class org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
-
- counter - Variable in class org.apache.flink.storm.util.InMemorySpout
-
- CounterDump(QueryScopeInfo, String, long) - Constructor for class org.apache.flink.runtime.metrics.dump.MetricDump.CounterDump
-
- counters - Variable in class org.apache.flink.metrics.reporter.AbstractReporter
-
- CountEvictor<W extends Window> - Class in org.apache.flink.streaming.api.windowing.evictors
-
An
Evictor
that keeps up to a certain amount of elements.
- CountHelper(String) - Constructor for class org.apache.flink.api.java.Utils.CountHelper
-
- CountingCollector<OUT> - Class in org.apache.flink.runtime.operators.util.metrics
-
- CountingCollector(Collector<OUT>, Counter) - Constructor for class org.apache.flink.runtime.operators.util.metrics.CountingCollector
-
- CountingIterable<IN> - Class in org.apache.flink.runtime.operators.util.metrics
-
- CountingIterable(Iterable<IN>, Counter) - Constructor for class org.apache.flink.runtime.operators.util.metrics.CountingIterable
-
- CountingIterator<IN> - Class in org.apache.flink.runtime.operators.util.metrics
-
- CountingIterator(Iterator<IN>, Counter) - Constructor for class org.apache.flink.runtime.operators.util.metrics.CountingIterator
-
- CountingMutableObjectIterator<IN> - Class in org.apache.flink.runtime.operators.util.metrics
-
- CountingMutableObjectIterator(MutableObjectIterator<IN>, Counter) - Constructor for class org.apache.flink.runtime.operators.util.metrics.CountingMutableObjectIterator
-
- CountingOutput(Output<StreamRecord<OUT>>, Counter) - Constructor for class org.apache.flink.streaming.api.operators.AbstractStreamOperator.CountingOutput
-
- Counts(long, long, int, long, long) - Constructor for class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.Counts
-
- COUNTS - Static variable in class org.apache.flink.test.testdata.WordCountData
-
- COUNTS_AS_TUPLES - Static variable in class org.apache.flink.test.testdata.WordCountData
-
- CountTrigger<W extends Window> - Class in org.apache.flink.streaming.api.windowing.triggers
-
A
Trigger
that fires once the count of elements in a pane reaches the given count.
- countWindow(long) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Windows this KeyedStream
into tumbling count windows.
- countWindow(long, long) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Windows this KeyedStream
into sliding count windows.
- countWindowAll(long) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Windows this DataStream
into tumbling count windows.
- countWindowAll(long, long) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Windows this DataStream
into sliding count windows.
- cover(TimeWindow) - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow
-
Returns the minimal window covers both this window and the given window.
- cpuCores() - Method in class org.apache.flink.mesos.scheduler.Offer
-
- cpus() - Method in class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManagerParameters
-
Get the CPU units to use for the TaskManager process.
- cpus(double) - Static method in class org.apache.flink.mesos.Utils
-
Construct a cpu resource.
- cpus(String, double) - Static method in class org.apache.flink.mesos.Utils
-
Construct a cpu resource.
- create(InputStream) - Method in class org.apache.flink.api.common.io.compression.Bzip2InputStreamFactory
-
- create(InputStream) - Method in class org.apache.flink.api.common.io.compression.DeflateInflaterInputStreamFactory
-
- create(InputStream) - Method in class org.apache.flink.api.common.io.compression.GzipInflaterInputStreamFactory
-
- create(InputStream) - Method in interface org.apache.flink.api.common.io.compression.InflaterInputStreamFactory
-
- create(InputStream) - Method in class org.apache.flink.api.common.io.compression.XZInputStreamFactory
-
- create(double, Resource.ResourceAggregateType) - Method in class org.apache.flink.api.common.resources.GPUResource
-
- create(double, Resource.ResourceAggregateType) - Method in class org.apache.flink.api.common.resources.Resource
-
Create a resource of the same resource resourceAggregateType.
- create(TupleTypeInfoBase<?>) - Static method in class org.apache.flink.api.java.summarize.aggregation.SummaryAggregatorFactory
-
- create(Class<T>) - Static method in class org.apache.flink.api.java.summarize.aggregation.SummaryAggregatorFactory
-
Create a SummaryAggregator for the supplied type.
- create(Kryo, Input, Class<Collection>) - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.Serializers.SpecificInstanceCollectionSerializer
-
- create(URI) - Method in class org.apache.flink.core.fs.ConnectionLimitingFactory
-
- create(Path, boolean, int, short, long) - Method in class org.apache.flink.core.fs.FileSystem
-
- create(Path, boolean) - Method in class org.apache.flink.core.fs.FileSystem
-
- create(Path, FileSystem.WriteMode) - Method in class org.apache.flink.core.fs.FileSystem
-
Opens an FSDataOutputStream to a new file at the given path.
- create(URI) - Method in interface org.apache.flink.core.fs.FileSystemFactory
-
Creates a new file system for the given file system URI.
- create(Path, FileSystem.WriteMode) - Method in class org.apache.flink.core.fs.LimitedConnectionsFileSystem
-
- create(Path, boolean, int, short, long) - Method in class org.apache.flink.core.fs.LimitedConnectionsFileSystem
-
Deprecated.
- create(Path, FileSystem.WriteMode) - Method in class org.apache.flink.core.fs.local.LocalFileSystem
-
- create(URI) - Method in class org.apache.flink.core.fs.local.LocalFileSystemFactory
-
- create(Path, boolean, int, short, long) - Method in class org.apache.flink.core.fs.SafetyNetWrapperFileSystem
-
- create(Path, FileSystem.WriteMode) - Method in class org.apache.flink.core.fs.SafetyNetWrapperFileSystem
-
- create(URI) - Method in class org.apache.flink.fs.openstackhadoop.SwiftFileSystemFactory
-
- create(URI) - Method in class org.apache.flink.fs.s3hadoop.S3FileSystemFactory
-
- create(URI) - Method in class org.apache.flink.fs.s3presto.S3FileSystemFactory
-
- create(ExecutionEnvironment) - Method in class org.apache.flink.graph.drivers.input.CirculantGraph
-
- create(ExecutionEnvironment) - Method in class org.apache.flink.graph.drivers.input.CompleteGraph
-
- create(ExecutionEnvironment) - Method in class org.apache.flink.graph.drivers.input.CSV
-
- create(ExecutionEnvironment) - Method in class org.apache.flink.graph.drivers.input.CycleGraph
-
- create(ExecutionEnvironment) - Method in class org.apache.flink.graph.drivers.input.EchoGraph
-
- create(ExecutionEnvironment) - Method in class org.apache.flink.graph.drivers.input.EmptyGraph
-
- create(ExecutionEnvironment) - Method in class org.apache.flink.graph.drivers.input.GeneratedMultiGraph
-
- create(ExecutionEnvironment) - Method in class org.apache.flink.graph.drivers.input.GridGraph
-
- create(ExecutionEnvironment) - Method in class org.apache.flink.graph.drivers.input.HypercubeGraph
-
- create(ExecutionEnvironment) - Method in interface org.apache.flink.graph.drivers.input.Input
-
- create(ExecutionEnvironment) - Method in class org.apache.flink.graph.drivers.input.PathGraph
-
- create(ExecutionEnvironment) - Method in class org.apache.flink.graph.drivers.input.SingletonEdgeGraph
-
- create(ExecutionEnvironment) - Method in class org.apache.flink.graph.drivers.input.StarGraph
-
- create(Configuration) - Static method in class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManagerParameters
-
Create the Mesos TaskManager parameters.
- create() - Method in class org.apache.flink.runtime.akka.StoppingSupervisorWithoutLoggingActorKilledExceptionStrategy
-
- create() - Method in interface org.apache.flink.runtime.checkpoint.MasterTriggerRestoreHook.Factory
-
Instantiates the MasterTriggerRestoreHook
.
- create(Configuration, long, int) - Static method in class org.apache.flink.runtime.clusterframework.ContaineredTaskManagerParameters
-
Computes the parameters to be used to start a TaskManager Java process.
- create(FlinkUserCodeClassLoaders.ResolveOrder, URL[], ClassLoader, String[]) - Static method in class org.apache.flink.runtime.execution.librarycache.FlinkUserCodeClassLoaders
-
- create(ExecutionGraph) - Method in interface org.apache.flink.runtime.executiongraph.failover.FailoverStrategy.Factory
-
Instantiates the FailoverStrategy
.
- create(ExecutionGraph) - Method in class org.apache.flink.runtime.executiongraph.failover.RestartAllStrategy.Factory
-
- create(ExecutionGraph) - Method in class org.apache.flink.runtime.executiongraph.failover.RestartIndividualStrategy.Factory
-
- create(ExecutionGraph) - Method in class org.apache.flink.runtime.executiongraph.failover.RestartPipelinedRegionStrategy.Factory
-
- create(Path, boolean, int, short, long) - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileSystem
-
- create(Path, FileSystem.WriteMode) - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileSystem
-
- create(URI) - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFsFactory
-
- create(URI) - Method in class org.apache.flink.runtime.fs.maprfs.MapRFsFactory
-
- create(String, JobID, ExecutionAttemptID, InputGateDeploymentDescriptor, NetworkEnvironment, TaskActions, TaskIOMetricGroup) - Static method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
-
Creates an input gate and all of its input channels.
- create(JobGraph) - Method in class org.apache.flink.runtime.jobmaster.factories.DefaultJobManagerJobMetricGroupFactory
-
- create(JobGraph) - Method in interface org.apache.flink.runtime.jobmaster.factories.JobManagerJobMetricGroupFactory
-
- create(Collection<JobStatus>) - Static method in class org.apache.flink.runtime.messages.webmonitor.JobsOverview
-
- create(List<MemorySegment>) - Method in class org.apache.flink.runtime.operators.sort.DefaultInMemorySorterFactory
-
- create(List<MemorySegment>) - Method in interface org.apache.flink.runtime.operators.sort.InMemorySorterFactory
-
- create(AccessExecution, MutableIOMetrics) - Static method in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsInfo
-
- create(Executor) - Method in interface org.apache.flink.runtime.state.SharedStateRegistryFactory
-
- create() - Static method in class org.apache.flink.streaming.api.windowing.assigners.GlobalWindows
-
- create() - Static method in class org.apache.flink.streaming.api.windowing.triggers.EventTimeTrigger
-
Creates an event-time trigger that fires once the watermark passes the end of the window.
- create() - Static method in class org.apache.flink.streaming.api.windowing.triggers.ProcessingTimeTrigger
-
Creates a new trigger that fires once system time passes the end of the window.
- create(Map<String, String>) - Method in class org.apache.flink.streaming.connectors.kafka.KafkaJsonTableSourceFactory
-
- create() - Method in interface org.apache.flink.streaming.runtime.operators.windowing.KeyMap.LazyFactory
-
The factory method; creates the value.
- create(Map<String, Object>) - Static method in class org.apache.flink.table.client.config.Deployment
-
- create(Map<String, Object>) - Static method in class org.apache.flink.table.client.config.Execution
-
- create(Map<String, Object>) - Static method in class org.apache.flink.table.client.config.Source
-
- create(String[], Class<? extends YarnTaskManager>, Map<String, String>) - Static method in class org.apache.flink.yarn.YarnTaskManagerRunnerFactory
-
- create_local_execution_environment(Configuration) - Method in class org.apache.flink.streaming.python.api.environment.PythonEnvironmentFactory
-
- create_local_execution_environment(int, Configuration) - Method in class org.apache.flink.streaming.python.api.environment.PythonEnvironmentFactory
-
- create_python_source(SourceFunction<Object>) - Method in class org.apache.flink.streaming.python.api.environment.PythonStreamExecutionEnvironment
-
- create_remote_execution_environment(String, int, String...) - Method in class org.apache.flink.streaming.python.api.environment.PythonEnvironmentFactory
-
- create_remote_execution_environment(String, int, Configuration, String...) - Method in class org.apache.flink.streaming.python.api.environment.PythonEnvironmentFactory
-
- create_remote_execution_environment(String, int, int, String...) - Method in class org.apache.flink.streaming.python.api.environment.PythonEnvironmentFactory
-
- createAccumulator() - Method in interface org.apache.flink.api.common.functions.AggregateFunction
-
Creates a new accumulator, starting a new aggregate.
- createAccumulator() - Method in class org.apache.flink.api.common.functions.RichAggregateFunction
-
- createActivatorDeactivator() - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
- createActorProps(Class<? extends MesosFlinkResourceManager>, Configuration, MesosConfiguration, MesosWorkerStore, LeaderRetrievalService, MesosTaskManagerParameters, ContainerSpecification, MesosArtifactResolver, Logger) - Static method in class org.apache.flink.mesos.runtime.clusterframework.MesosFlinkResourceManager
-
Creates the props needed to instantiate this actor.
- createActorProps(LeaderRetrievalService, FiniteDuration, boolean) - Static method in class org.apache.flink.runtime.client.JobAttachmentClientActor
-
- createActorProps(LeaderRetrievalService, FiniteDuration, boolean, Configuration) - Static method in class org.apache.flink.runtime.client.JobSubmissionClientActor
-
- createActorProps(Class<? extends YarnFlinkResourceManager>, Configuration, YarnConfiguration, LeaderRetrievalService, String, String, ContaineredTaskManagerParameters, ContainerLaunchContext, int, Logger) - Static method in class org.apache.flink.yarn.YarnFlinkResourceManager
-
Creates the props needed to instantiate this actor.
- createAggregatingState(AggregatingStateDescriptor<IN, ACC, OUT>) - Method in interface org.apache.flink.api.common.state.StateBinder
-
- createAggregatingState(TypeSerializer<N>, AggregatingStateDescriptor<T, ACC, R>) - Method in class org.apache.flink.contrib.streaming.state.RocksDBKeyedStateBackend
-
- createAggregatingState(AggregatingStateDescriptor<IN, ACC, OUT>) - Method in class org.apache.flink.queryablestate.client.state.ImmutableStateBinder
-
- createAggregatingState(TypeSerializer<N>, AggregatingStateDescriptor<T, ACC, R>) - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
-
- createAggregatingState(TypeSerializer<N>, AggregatingStateDescriptor<T, ACC, R>) - Method in class org.apache.flink.runtime.state.heap.HeapKeyedStateBackend
-
- createAggregationFunction(Class<T>) - Method in interface org.apache.flink.api.java.aggregation.AggregationFunctionFactory
-
- createAggregationFunction(Class<T>) - Method in class org.apache.flink.api.java.aggregation.MaxAggregationFunction.MaxAggregationFunctionFactory
-
- createAggregationFunction(Class<T>) - Method in class org.apache.flink.api.java.aggregation.MinAggregationFunction.MinAggregationFunctionFactory
-
- createAggregationFunction(Class<T>) - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.SumAggregationFunctionFactory
-
- createAndAddResultDataSet(ResultPartitionType) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
- createAndAddResultDataSet(IntermediateDataSetID, ResultPartitionType) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
- createAndRegisterTempFile(String) - Method in class org.apache.flink.test.util.AbstractTestBase
-
- createAndRestore(List<? extends Collection<S>>) - Method in class org.apache.flink.streaming.api.operators.BackendRestorerProcedure
-
Creates a new state backend and restores it from the provided set of state snapshot alternatives.
- createAndStartNodeManagerClient(YarnConfiguration) - Method in class org.apache.flink.yarn.YarnResourceManager
-
- createAndStartResourceManagerClient(YarnConfiguration, int, String) - Method in class org.apache.flink.yarn.YarnResourceManager
-
- createAttemptAccumulatorsJson(AccessExecution) - Static method in class org.apache.flink.runtime.rest.handler.legacy.SubtaskExecutionAttemptAccumulatorsHandler
-
- createAttemptDetailsJson(AccessExecution, String, String, MetricFetcher) - Static method in class org.apache.flink.runtime.rest.handler.legacy.SubtaskExecutionAttemptDetailsHandler
-
- createAvailableOrEmbeddedServices(Configuration, Executor) - Static method in class org.apache.flink.runtime.highavailability.HighAvailabilityServicesUtils
-
- createAvroSerializer(Class<T>) - Method in class org.apache.flink.api.java.typeutils.AvroUtils
-
Creates an AvroSerializer
if flink-avro is present, otherwise throws an exception.
- createAvroSerializer(Class<T>) - Method in class org.apache.flink.formats.avro.utils.AvroKryoSerializerUtils
-
- createAvroTypeInfo(Class<T>) - Method in class org.apache.flink.api.java.typeutils.AvroUtils
-
Creates an AvroTypeInfo
if flink-avro is present, otherwise throws an exception.
- createAvroTypeInfo(Class<T>) - Method in class org.apache.flink.formats.avro.utils.AvroKryoSerializerUtils
-
- createBlobStore() - Method in interface org.apache.flink.runtime.highavailability.HighAvailabilityServices
-
Creates the BLOB store in which BLOBs are stored in a highly-available fashion.
- createBlobStore() - Method in class org.apache.flink.runtime.highavailability.nonha.AbstractNonHaServices
-
- createBlobStore() - Method in class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperHaServices
-
- createBlobStore() - Method in class org.apache.flink.yarn.highavailability.YarnHighAvailabilityServices
-
- createBlobStoreFromConfig(Configuration) - Static method in class org.apache.flink.runtime.blob.BlobUtils
-
Creates a BlobStore based on the parameters set in the configuration.
- createBlockChannelReader(FileIOChannel.ID) - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManager
-
Creates a block channel reader that reads blocks from the given channel.
- createBlockChannelReader(FileIOChannel.ID, LinkedBlockingQueue<MemorySegment>) - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManager
-
Creates a block channel reader that reads blocks from the given channel.
- createBlockChannelReader(FileIOChannel.ID, LinkedBlockingQueue<MemorySegment>) - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManagerAsync
-
Creates a block channel reader that reads blocks from the given channel.
- createBlockChannelWriter(FileIOChannel.ID) - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManager
-
Creates a block channel writer that writes to the given channel.
- createBlockChannelWriter(FileIOChannel.ID, LinkedBlockingQueue<MemorySegment>) - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManager
-
Creates a block channel writer that writes to the given channel.
- createBlockChannelWriter(FileIOChannel.ID, RequestDoneCallback<MemorySegment>) - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManager
-
Creates a block channel writer that writes to the given channel.
- createBlockChannelWriter(FileIOChannel.ID, LinkedBlockingQueue<MemorySegment>) - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManagerAsync
-
- createBlockChannelWriter(FileIOChannel.ID, RequestDoneCallback<MemorySegment>) - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManagerAsync
-
- createBlockInfo() - Method in class org.apache.flink.api.common.io.BinaryInputFormat
-
- createBlockInfo() - Method in class org.apache.flink.api.common.io.BinaryOutputFormat
-
- createBrokerIdString(JobID, String, int) - Static method in class org.apache.flink.streaming.runtime.tasks.StreamIterationHead
-
Creates the identification string with which head and tail task find the shared blocking
queue for the back channel.
- createBufferConsumer() - Method in class org.apache.flink.runtime.io.network.buffer.BufferBuilder
-
- createBufferFileReader(FileIOChannel.ID, RequestDoneCallback<Buffer>) - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManager
-
- createBufferFileReader(FileIOChannel.ID, RequestDoneCallback<Buffer>) - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManagerAsync
-
- createBufferFileSegmentReader(FileIOChannel.ID, RequestDoneCallback<FileSegment>) - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManager
-
- createBufferFileSegmentReader(FileIOChannel.ID, RequestDoneCallback<FileSegment>) - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManagerAsync
-
- createBufferFileWriter(FileIOChannel.ID) - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManager
-
- createBufferFileWriter(FileIOChannel.ID) - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManagerAsync
-
- createBufferPool(int, int) - Method in interface org.apache.flink.runtime.io.network.buffer.BufferPoolFactory
-
Tries to create a buffer pool, which is guaranteed to provide at least the number of required
buffers.
- createBufferPool(int, int, Optional<BufferPoolOwner>) - Method in interface org.apache.flink.runtime.io.network.buffer.BufferPoolFactory
-
Tries to create a buffer pool with an optional owner, which is guaranteed to provide at least the
number of required buffers.
- createBufferPool(int, int) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
-
- createBufferPool(int, int, Optional<BufferPoolOwner>) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
-
- createBuilder() - Method in class org.apache.flink.streaming.connectors.kafka.Kafka010JsonTableSourceFactory
-
- createBuilder() - Method in class org.apache.flink.streaming.connectors.kafka.Kafka011JsonTableSourceFactory
-
- createBuilder() - Method in class org.apache.flink.streaming.connectors.kafka.Kafka08JsonTableSourceFactory
-
- createBuilder() - Method in class org.apache.flink.streaming.connectors.kafka.Kafka09JsonTableSourceFactory
-
- createBuilder() - Method in class org.apache.flink.streaming.connectors.kafka.KafkaJsonTableSourceFactory
-
- createBulkBlockChannelReader(FileIOChannel.ID, List<MemorySegment>, int) - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManager
-
Creates a block channel reader that reads all blocks from the given channel directly in one bulk.
- createBulkBlockChannelReader(FileIOChannel.ID, List<MemorySegment>, int) - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManagerAsync
-
Creates a block channel reader that reads all blocks from the given channel directly in one bulk.
- createCallBridge() - Method in class org.apache.flink.streaming.connectors.kafka.internal.Kafka010Fetcher
-
This method needs to be overridden because Kafka broke binary compatibility between 0.9 and 0.10,
changing binary signatures.
- createCallBridge() - Method in class org.apache.flink.streaming.connectors.kafka.internal.Kafka09Fetcher
-
- createChannel() - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManager
-
- createChannelEnumerator() - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManager
-
Creates a new
FileIOChannel.Enumerator
, spreading the channels in a round-robin fashion
across the temporary file directories.
- createCheckpointBarrierHandler(StreamTask<?, ?>, CheckpointingMode, IOManager, InputGate, Configuration) - Static method in class org.apache.flink.streaming.runtime.io.InputProcessorUtil
-
- createCheckpointDataSerializer() - Method in interface org.apache.flink.runtime.checkpoint.MasterTriggerRestoreHook
-
Creates a the serializer to (de)serializes the data stored by this hook.
- createCheckpointDetailsJson(AbstractCheckpointStats) - Static method in class org.apache.flink.runtime.rest.handler.legacy.checkpoints.CheckpointStatsDetailsHandler
-
- createCheckpointDirectory(Path, long) - Static method in class org.apache.flink.runtime.state.filesystem.AbstractFsCheckpointStorage
-
Creates the directory path for the data exclusive to a specific checkpoint.
- createCheckpointExceptionHandler(boolean, Environment) - Method in class org.apache.flink.streaming.runtime.tasks.CheckpointExceptionHandlerFactory
-
Returns a
CheckpointExceptionHandler
that either causes a task to fail completely or to just declines
checkpoint on exception, depending on the parameter flag.
- createCheckpointExceptionHandlerFactory() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- createCheckpointIDCounter(JobID) - Method in interface org.apache.flink.runtime.checkpoint.CheckpointRecoveryFactory
-
- createCheckpointIDCounter(JobID) - Method in class org.apache.flink.runtime.checkpoint.StandaloneCheckpointRecoveryFactory
-
- createCheckpointIDCounter(JobID) - Method in class org.apache.flink.runtime.checkpoint.ZooKeeperCheckpointRecoveryFactory
-
- createCheckpointIDCounter(CuratorFramework, Configuration, JobID) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
-
- createCheckpointStateOutputStream(CheckpointedStateScope) - Method in interface org.apache.flink.runtime.state.CheckpointStreamFactory
-
- createCheckpointStateOutputStream(CheckpointedStateScope) - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStreamFactory
-
- createCheckpointStateOutputStream(CheckpointedStateScope) - Method in class org.apache.flink.runtime.state.memory.MemCheckpointStreamFactory
-
- createCheckpointStorage(JobID) - Method in class org.apache.flink.contrib.streaming.state.RocksDBStateBackend
-
- createCheckpointStorage(JobID) - Method in class org.apache.flink.runtime.state.filesystem.FsStateBackend
-
- createCheckpointStorage(JobID) - Method in class org.apache.flink.runtime.state.memory.MemoryStateBackend
-
- createCheckpointStorage(JobID) - Method in interface org.apache.flink.runtime.state.StateBackend
-
Creates a storage for checkpoints for the given job.
- createCheckpointStore(JobID, int, ClassLoader) - Method in interface org.apache.flink.runtime.checkpoint.CheckpointRecoveryFactory
-
- createCheckpointStore(JobID, int, ClassLoader) - Method in class org.apache.flink.runtime.checkpoint.StandaloneCheckpointRecoveryFactory
-
- createCheckpointStore(JobID, int, ClassLoader) - Method in class org.apache.flink.runtime.checkpoint.ZooKeeperCheckpointRecoveryFactory
-
- createChildGroup(String, AbstractMetricGroup.ChildType) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
-
- createChildGroup(String, AbstractMetricGroup.ChildType) - Method in class org.apache.flink.runtime.metrics.groups.GenericKeyMetricGroup
-
- createClassNotInClassPath(ClassLoader) - Static method in class org.apache.flink.core.testutils.CommonTestUtils
-
Creates a new class that is not part of the classpath that the current JVM uses.
- createClient() - Method in class org.apache.flink.runtime.blob.BlobServer
-
- createClient(Map<String, String>) - Method in class org.apache.flink.streaming.connectors.elasticsearch.Elasticsearch1ApiCallBridge
-
- createClient(Map<String, String>) - Method in interface org.apache.flink.streaming.connectors.elasticsearch.ElasticsearchApiCallBridge
-
Creates an Elasticsearch Client
.
- createClient(Map<String, String>) - Method in class org.apache.flink.streaming.connectors.elasticsearch2.Elasticsearch2ApiCallBridge
-
- createClient(Map<String, String>) - Method in class org.apache.flink.streaming.connectors.elasticsearch5.Elasticsearch5ApiCallBridge
-
- createClientSSLContext() - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
-
- createClientSSLEngineFactory(Configuration) - Static method in class org.apache.flink.runtime.net.SSLUtils
-
- createClusterDescriptor(CommandLine) - Method in interface org.apache.flink.client.cli.CustomCommandLine
-
Create a
ClusterDescriptor
from the given configuration, configuration directory
and the command line.
- createClusterDescriptor(CommandLine) - Method in class org.apache.flink.client.cli.DefaultCLI
-
- createClusterDescriptor(CommandLine) - Method in class org.apache.flink.client.cli.LegacyCLI
-
- createClusterDescriptor() - Method in class org.apache.flink.table.client.gateway.local.ExecutionContext
-
- createClusterDescriptor(CommandLine) - Method in class org.apache.flink.yarn.cli.FlinkYarnSessionCli
-
- createClusterSpecification() - Method in class org.apache.flink.client.deployment.ClusterSpecification.ClusterSpecificationBuilder
-
- createCollectionsEnvironment() - Static method in class org.apache.flink.api.java.ExecutionEnvironment
-
- createColumnOptions(ColumnFamilyOptions) - Method in interface org.apache.flink.contrib.streaming.state.OptionsFactory
-
This method should set the additional options on top of the current options object.
- createColumnOptions() - Method in enum org.apache.flink.contrib.streaming.state.PredefinedOptions
-
Creates the ColumnFamilyOptions
for this pre-defined setting.
- createComparator(boolean, ExecutionConfig) - Method in interface org.apache.flink.api.common.typeinfo.AtomicType
-
Creates a comparator for this type.
- createComparator(boolean, ExecutionConfig) - Method in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
-
- createComparator(boolean, ExecutionConfig) - Method in class org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
-
- createComparator(boolean, ExecutionConfig) - Method in class org.apache.flink.api.common.typeinfo.SqlTimeTypeInfo
-
- createComparator(int[], boolean[], int, ExecutionConfig) - Method in class org.apache.flink.api.common.typeutils.CompositeType
-
Generic implementation of the comparator creation.
- createComparator() - Method in interface org.apache.flink.api.common.typeutils.TypeComparatorFactory
-
- createComparator(boolean, ExecutionConfig) - Method in class org.apache.flink.api.java.typeutils.EnumTypeInfo
-
- createComparator(boolean, ExecutionConfig) - Method in class org.apache.flink.api.java.typeutils.GenericTypeInfo
-
- createComparator(int[], boolean[], int, ExecutionConfig) - Method in class org.apache.flink.api.java.typeutils.RowTypeInfo
-
- createComparator() - Method in class org.apache.flink.api.java.typeutils.runtime.RuntimeComparatorFactory
-
- createComparator(boolean, ExecutionConfig) - Method in class org.apache.flink.api.java.typeutils.ValueTypeInfo
-
- createComparator(boolean, ExecutionConfig) - Method in class org.apache.flink.api.java.typeutils.WritableTypeInfo
-
- createComparator(boolean, ExecutionConfig) - Method in class org.apache.flink.graph.drivers.transform.LongValueWithProperHashCode.LongValueWithProperHashCodeTypeInfo
-
- createComparator(boolean, ExecutionConfig) - Method in class org.apache.flink.graph.types.valuearray.ValueArrayTypeInfo
-
- createComparator12(TypeComparator<T1>, TypeComparator<T2>) - Method in interface org.apache.flink.api.common.typeutils.TypePairComparatorFactory
-
- createComparator12(TypeComparator<T1>, TypeComparator<T2>) - Method in class org.apache.flink.api.java.typeutils.runtime.RuntimePairComparatorFactory
-
- createComparator21(TypeComparator<T1>, TypeComparator<T2>) - Method in interface org.apache.flink.api.common.typeutils.TypePairComparatorFactory
-
- createComparator21(TypeComparator<T1>, TypeComparator<T2>) - Method in class org.apache.flink.api.java.typeutils.runtime.RuntimePairComparatorFactory
-
- createCompletedCheckpoints(CuratorFramework, Configuration, JobID, int, Executor) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
-
- createConfigJson(DashboardConfiguration) - Static method in class org.apache.flink.runtime.rest.handler.legacy.DashboardConfigHandler
-
- createConnectionMonitor() - Method in class org.apache.flink.mesos.runtime.clusterframework.MesosFlinkResourceManager
-
- createConnectionMonitor() - Method in class org.apache.flink.mesos.runtime.clusterframework.MesosResourceManager
-
- createContainerSpec(Configuration, Configuration) - Static method in class org.apache.flink.mesos.entrypoint.MesosEntrypointUtils
-
- createCopy(Kryo, Collection) - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.Serializers.SpecificInstanceCollectionSerializer
-
- createCopy(TypeSerializer<T>, T, T) - Method in class org.apache.flink.runtime.operators.sort.AbstractMergeIterator
-
Copies an instance of the given type, potentially reusing the object passed as the reuse parameter, which may be null.
- createCopy(TypeSerializer<T>, T, T) - Method in class org.apache.flink.runtime.operators.sort.NonReusingMergeInnerJoinIterator
-
- createCopy(TypeSerializer<T>, T, T) - Method in class org.apache.flink.runtime.operators.sort.NonReusingMergeOuterJoinIterator
-
- createCopy(TypeSerializer<T>, T, T) - Method in class org.apache.flink.runtime.operators.sort.ReusingMergeInnerJoinIterator
-
- createCopy(TypeSerializer<T>, T, T) - Method in class org.apache.flink.runtime.operators.sort.ReusingMergeOuterJoinIterator
-
- createCopy() - Method in class org.apache.flink.streaming.connectors.kafka.Kafka010JsonTableSink
-
- createCopy() - Method in class org.apache.flink.streaming.connectors.kafka.Kafka08JsonTableSink
-
- createCopy() - Method in class org.apache.flink.streaming.connectors.kafka.Kafka09JsonTableSink
-
- createCopy() - Method in class org.apache.flink.streaming.connectors.kafka.KafkaTableSink
-
Create a deep copy of this sink.
- createCopy() - Method in class org.apache.flink.types.Record
-
Creates an exact copy of this record.
- createCopySerializable(T) - Static method in class org.apache.flink.core.testutils.CommonTestUtils
-
Creates a copy of an object via Java Serialization.
- createCopyWritable(T) - Static method in class org.apache.flink.util.InstantiationUtil
-
- created(JobResult) - Static method in class org.apache.flink.runtime.rest.messages.job.JobExecutionResultResponseBody
-
- createDBOptions(DBOptions) - Method in interface org.apache.flink.contrib.streaming.state.OptionsFactory
-
This method should set the additional options on top of the current options object.
- createDBOptions() - Method in enum org.apache.flink.contrib.streaming.state.PredefinedOptions
-
Creates the DBOptions
for this pre-defined setting.
- createDefaultFilter() - Static method in class org.apache.flink.api.common.io.FilePathFilter
-
Returns the default filter, which excludes the following files:
Files starting with "_"
Files starting with "."
Files containing the string "_COPYING_"
- createDefaultJoin(Keys<I2>) - Method in class org.apache.flink.api.java.operators.join.JoinOperatorSetsBase.JoinOperatorSetsPredicateBase
-
- createDefaultMask(int) - Static method in class org.apache.flink.api.java.io.CsvInputFormat
-
- createDetailsForJob(AccessExecutionGraph) - Static method in class org.apache.flink.runtime.webmonitor.WebMonitorUtils
-
- createDispatcher(Configuration, RpcService, HighAvailabilityServices, ResourceManagerGateway, BlobServer, HeartbeatServices, JobManagerMetricGroup, String, ArchivedExecutionGraphStore, FatalErrorHandler, String, HistoryServerArchivist) - Method in class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
-
- createDispatcher(Configuration, RpcService, HighAvailabilityServices, ResourceManagerGateway, BlobServer, HeartbeatServices, JobManagerMetricGroup, String, ArchivedExecutionGraphStore, FatalErrorHandler, String, HistoryServerArchivist) - Method in class org.apache.flink.runtime.entrypoint.JobClusterEntrypoint
-
- createDispatcher(Configuration, RpcService, HighAvailabilityServices, ResourceManagerGateway, BlobServer, HeartbeatServices, JobManagerMetricGroup, String, ArchivedExecutionGraphStore, FatalErrorHandler, String, HistoryServerArchivist) - Method in class org.apache.flink.runtime.entrypoint.SessionClusterEntrypoint
-
- createDriver(Scheduler, boolean) - Method in class org.apache.flink.mesos.util.MesosConfiguration
-
Create the Mesos scheduler driver based on this configuration.
- createDuplicatingStream(long, CheckpointedStateScope, CheckpointStreamFactory, LocalRecoveryDirectoryProvider) - Static method in interface org.apache.flink.runtime.state.CheckpointStreamWithResultProvider
-
- createEndpoint() - Method in interface org.apache.flink.streaming.connectors.twitter.TwitterSource.EndpointInitializer
-
- createEnvironmentInstance() - Method in class org.apache.flink.table.client.gateway.local.ExecutionContext
-
- createExecutionEnvironment() - Method in interface org.apache.flink.api.java.ExecutionEnvironmentFactory
-
Creates an ExecutionEnvironment from this factory.
- createExecutionEnvironment() - Method in class org.apache.flink.client.program.ContextEnvironmentFactory
-
- createExecutionEnvironment() - Method in interface org.apache.flink.streaming.api.environment.StreamExecutionEnvironmentFactory
-
Creates a StreamExecutionEnvironment from this factory.
- createExecutorService(int, int, String) - Static method in class org.apache.flink.runtime.webmonitor.WebMonitorEndpoint
-
- createFactory(Configuration) - Static method in class org.apache.flink.runtime.executiongraph.restart.FailureRateRestartStrategy
-
- createFactory(Configuration) - Static method in class org.apache.flink.runtime.executiongraph.restart.FixedDelayRestartStrategy
-
Creates a FixedDelayRestartStrategy from the given Configuration.
- createFactory(Configuration) - Static method in class org.apache.flink.runtime.executiongraph.restart.NoRestartStrategy
-
Creates a NoRestartStrategy instance.
- createFetcher(SourceFunction.SourceContext<T>, Map<KafkaTopicPartition, Long>, SerializedValue<AssignerWithPeriodicWatermarks<T>>, SerializedValue<AssignerWithPunctuatedWatermarks<T>>, StreamingRuntimeContext, OffsetCommitMode, MetricGroup, boolean) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer010
-
- createFetcher(SourceFunction.SourceContext<T>, Map<KafkaTopicPartition, Long>, SerializedValue<AssignerWithPeriodicWatermarks<T>>, SerializedValue<AssignerWithPunctuatedWatermarks<T>>, StreamingRuntimeContext, OffsetCommitMode, MetricGroup, boolean) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer08
-
- createFetcher(SourceFunction.SourceContext<T>, Map<KafkaTopicPartition, Long>, SerializedValue<AssignerWithPeriodicWatermarks<T>>, SerializedValue<AssignerWithPunctuatedWatermarks<T>>, StreamingRuntimeContext, OffsetCommitMode, MetricGroup, boolean) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer09
-
- createFetcher(SourceFunction.SourceContext<T>, Map<KafkaTopicPartition, Long>, SerializedValue<AssignerWithPeriodicWatermarks<T>>, SerializedValue<AssignerWithPunctuatedWatermarks<T>>, StreamingRuntimeContext, OffsetCommitMode, MetricGroup, boolean) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumerBase
-
Creates the fetcher that connect to the Kafka brokers, pulls data, deserialized the
data, and emits it into the data streams.
- createFileSystemStateStorage(Configuration, String) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
-
- createFinalPlan(List<SinkPlanNode>, String, Plan) - Method in class org.apache.flink.optimizer.traversals.PlanFinalizer
-
- createFoldingState(FoldingStateDescriptor<T, ACC>) - Method in interface org.apache.flink.api.common.state.StateBinder
-
- createFoldingState(TypeSerializer<N>, FoldingStateDescriptor<T, ACC>) - Method in class org.apache.flink.contrib.streaming.state.RocksDBKeyedStateBackend
-
- createFoldingState(FoldingStateDescriptor<T, ACC>) - Method in class org.apache.flink.queryablestate.client.state.ImmutableStateBinder
-
- createFoldingState(TypeSerializer<N>, FoldingStateDescriptor<T, ACC>) - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
-
- createFoldingState(TypeSerializer<N>, FoldingStateDescriptor<T, ACC>) - Method in class org.apache.flink.runtime.state.heap.HeapKeyedStateBackend
-
- createFrom(ExecutionGraph) - Static method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
-
- createFrom(AccessExecutionGraph) - Static method in class org.apache.flink.runtime.jobmaster.JobResult
-
- createFrom(CheckedSupplier<T>) - Static method in class org.apache.flink.util.OptionalFailure
-
- createFromConfig(Configuration) - Method in class org.apache.flink.contrib.streaming.state.RocksDBStateBackendFactory
-
- createFromConfig(Configuration) - Method in class org.apache.flink.runtime.state.filesystem.FsStateBackendFactory
-
- createFromConfig(Configuration) - Method in class org.apache.flink.runtime.state.memory.MemoryStateBackendFactory
-
- createFromConfig(Configuration) - Method in interface org.apache.flink.runtime.state.StateBackendFactory
-
Creates the state backend, optionally using the given configuration.
- createGateway(CompletableFuture<Tuple2<String, UUID>>) - Method in class org.apache.flink.runtime.webmonitor.retriever.impl.AkkaJobManagerRetriever
-
- createGateway(CompletableFuture<Tuple2<String, UUID>>) - Method in class org.apache.flink.runtime.webmonitor.retriever.impl.RpcGatewayRetriever
-
- createGateway(CompletableFuture<Tuple2<String, UUID>>) - Method in class org.apache.flink.runtime.webmonitor.retriever.LeaderGatewayRetriever
-
- createHadoopFileSystem(Path, Configuration) - Static method in class org.apache.flink.streaming.connectors.fs.bucketing.BucketingSink
-
- createHadoopInput(InputFormat<K, V>, Class<K>, Class<V>, JobConf) - Static method in class org.apache.flink.hadoopcompatibility.HadoopInputs
-
Creates a Flink
InputFormat
that wraps the given Hadoop
InputFormat
.
- createHadoopInput(InputFormat<K, V>, Class<K>, Class<V>, Job) - Static method in class org.apache.flink.hadoopcompatibility.HadoopInputs
-
Creates a Flink
InputFormat
that wraps the given Hadoop
InputFormat
.
- createHadoopWritableTypeInfo(Class<T>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
- createHaServices(Configuration, Executor) - Method in class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
-
- createHeartbeatManager(ResourceID, HeartbeatListener<I, O>, ScheduledExecutor, Logger) - Method in class org.apache.flink.runtime.heartbeat.HeartbeatServices
-
Creates a heartbeat manager which does not actively send heartbeats.
- createHeartbeatManagerSender(ResourceID, HeartbeatListener<I, O>, ScheduledExecutor, Logger) - Method in class org.apache.flink.runtime.heartbeat.HeartbeatServices
-
Creates a heartbeat manager which actively sends heartbeats to monitoring targets.
- createHeartbeatServices(Configuration) - Method in class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
-
- createHighAvailabilityServices(Configuration, Executor, HighAvailabilityServicesUtils.AddressResolution) - Static method in class org.apache.flink.runtime.highavailability.HighAvailabilityServicesUtils
-
- createHistoryServerArchivist(Configuration, JsonArchivist) - Static method in interface org.apache.flink.runtime.dispatcher.HistoryServerArchivist
-
- createIndexRequest(T, RuntimeContext) - Method in interface org.apache.flink.streaming.connectors.elasticsearch.IndexRequestBuilder
-
Deprecated.
Creates an IndexRequest
from an element.
- createInput(InputFormat<X, ?>) - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
- createInput(InputFormat<X, ?>, TypeInformation<X>) - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
Generic method to create an input DataSet with in
InputFormat
.
- createInput(InputFormat<OUT, ?>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Generic method to create an input data stream with
InputFormat
.
- createInput(InputFormat<OUT, ?>, TypeInformation<OUT>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Generic method to create an input data stream with
InputFormat
.
- createInputChannelDeploymentDescriptor(Execution) - Method in class org.apache.flink.runtime.deployment.PartialInputChannelDeploymentDescriptor
-
Creates a channel deployment descriptor by completing the partition location.
- createInputGate(Collection<InputGate>, Collection<InputGate>) - Static method in class org.apache.flink.streaming.runtime.io.InputGateUtil
-
- createInputGate(InputGate[]) - Static method in class org.apache.flink.streaming.runtime.io.InputGateUtil
-
- createInputIterator(MutableReader<?>, TypeSerializerFactory<?>) - Method in class org.apache.flink.runtime.operators.BatchTask
-
- createInputSplits(int) - Method in class org.apache.flink.addons.hbase.AbstractTableInputFormat
-
- createInputSplits(int) - Method in class org.apache.flink.api.common.io.BinaryInputFormat
-
- createInputSplits(int) - Method in class org.apache.flink.api.common.io.FileInputFormat
-
Computes the input splits for the file.
- createInputSplits(int) - Method in class org.apache.flink.api.common.io.GenericInputFormat
-
- createInputSplits(int) - Method in interface org.apache.flink.api.common.io.InputFormat
-
Creates the different splits of the input that can be processed in parallel.
- createInputSplits(int) - Method in class org.apache.flink.api.common.io.ReplicatingInputFormat
-
- createInputSplits(int) - Method in class org.apache.flink.api.java.hadoop.mapred.HadoopInputFormatBase
-
- createInputSplits(int) - Method in class org.apache.flink.api.java.hadoop.mapreduce.HadoopInputFormatBase
-
- createInputSplits(int) - Method in class org.apache.flink.api.java.io.jdbc.JDBCInputFormat
-
- createInputSplits(int) - Method in class org.apache.flink.batch.connectors.cassandra.CassandraInputFormat
-
- createInputSplits(int) - Method in class org.apache.flink.batch.tests.DataSetAllroundTestProgram.Generator
-
- createInputSplits(int) - Method in interface org.apache.flink.core.io.InputSplitSource
-
Computes the input splits.
- createInputSplits(int) - Method in class org.apache.flink.examples.java.distcp.FileCopyTaskInputFormat
-
- createInputSplits(int) - Method in class org.apache.flink.hcatalog.HCatInputFormatBase
-
- createInstance() - Method in class org.apache.flink.api.common.typeutils.base.array.BooleanPrimitiveArraySerializer
-
- createInstance() - Method in class org.apache.flink.api.common.typeutils.base.array.BytePrimitiveArraySerializer
-
- createInstance() - Method in class org.apache.flink.api.common.typeutils.base.array.CharPrimitiveArraySerializer
-
- createInstance() - Method in class org.apache.flink.api.common.typeutils.base.array.DoublePrimitiveArraySerializer
-
- createInstance() - Method in class org.apache.flink.api.common.typeutils.base.array.FloatPrimitiveArraySerializer
-
- createInstance() - Method in class org.apache.flink.api.common.typeutils.base.array.IntPrimitiveArraySerializer
-
- createInstance() - Method in class org.apache.flink.api.common.typeutils.base.array.LongPrimitiveArraySerializer
-
- createInstance() - Method in class org.apache.flink.api.common.typeutils.base.array.ShortPrimitiveArraySerializer
-
- createInstance() - Method in class org.apache.flink.api.common.typeutils.base.array.StringArraySerializer
-
- createInstance() - Method in class org.apache.flink.api.common.typeutils.base.BigDecSerializer
-
- createInstance() - Method in class org.apache.flink.api.common.typeutils.base.BigIntSerializer
-
- createInstance() - Method in class org.apache.flink.api.common.typeutils.base.BooleanSerializer
-
- createInstance() - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueSerializer
-
- createInstance() - Method in class org.apache.flink.api.common.typeutils.base.ByteSerializer
-
- createInstance() - Method in class org.apache.flink.api.common.typeutils.base.ByteValueSerializer
-
- createInstance() - Method in class org.apache.flink.api.common.typeutils.base.CharSerializer
-
- createInstance() - Method in class org.apache.flink.api.common.typeutils.base.CharValueSerializer
-
- createInstance() - Method in class org.apache.flink.api.common.typeutils.base.DateSerializer
-
- createInstance() - Method in class org.apache.flink.api.common.typeutils.base.DoubleSerializer
-
- createInstance() - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueSerializer
-
- createInstance() - Method in class org.apache.flink.api.common.typeutils.base.EnumSerializer
-
- createInstance() - Method in class org.apache.flink.api.common.typeutils.base.FloatSerializer
-
- createInstance() - Method in class org.apache.flink.api.common.typeutils.base.FloatValueSerializer
-
- createInstance() - Method in class org.apache.flink.api.common.typeutils.base.GenericArraySerializer
-
- createInstance() - Method in class org.apache.flink.api.common.typeutils.base.IntSerializer
-
- createInstance() - Method in class org.apache.flink.api.common.typeutils.base.IntValueSerializer
-
- createInstance() - Method in class org.apache.flink.api.common.typeutils.base.ListSerializer
-
- createInstance() - Method in class org.apache.flink.api.common.typeutils.base.LongSerializer
-
- createInstance() - Method in class org.apache.flink.api.common.typeutils.base.LongValueSerializer
-
- createInstance() - Method in class org.apache.flink.api.common.typeutils.base.MapSerializer
-
- createInstance() - Method in class org.apache.flink.api.common.typeutils.base.NullValueSerializer
-
- createInstance() - Method in class org.apache.flink.api.common.typeutils.base.ShortSerializer
-
- createInstance() - Method in class org.apache.flink.api.common.typeutils.base.ShortValueSerializer
-
- createInstance() - Method in class org.apache.flink.api.common.typeutils.base.SqlDateSerializer
-
- createInstance() - Method in class org.apache.flink.api.common.typeutils.base.SqlTimeSerializer
-
- createInstance() - Method in class org.apache.flink.api.common.typeutils.base.SqlTimestampSerializer
-
- createInstance() - Method in class org.apache.flink.api.common.typeutils.base.StringSerializer
-
- createInstance() - Method in class org.apache.flink.api.common.typeutils.base.StringValueSerializer
-
- createInstance() - Method in class org.apache.flink.api.common.typeutils.base.VoidSerializer
-
- createInstance() - Method in class org.apache.flink.api.common.typeutils.TypeDeserializerAdapter
-
- createInstance() - Method in class org.apache.flink.api.common.typeutils.TypeSerializer
-
Creates a new instance of the data type.
- createInstance() - Method in class org.apache.flink.api.common.typeutils.UnloadableDummyTypeSerializer
-
- createInstance() - Method in class org.apache.flink.api.java.typeutils.runtime.AvroSerializer
-
Deprecated.
- createInstance() - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer
-
- createInstance() - Method in class org.apache.flink.api.java.typeutils.runtime.EitherSerializer
-
- createInstance() - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer
-
- createInstance() - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer
-
- createInstance() - Method in class org.apache.flink.api.java.typeutils.runtime.RowSerializer
-
- createInstance() - Method in class org.apache.flink.api.java.typeutils.runtime.Tuple0Serializer
-
- createInstance(Object[]) - Method in class org.apache.flink.api.java.typeutils.runtime.Tuple0Serializer
-
- createInstance() - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializer
-
- createInstance(Object[]) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializer
-
- createInstance(Object[]) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializerBase
-
- createInstance() - Method in class org.apache.flink.api.java.typeutils.runtime.ValueSerializer
-
- createInstance() - Method in class org.apache.flink.api.java.typeutils.runtime.WritableSerializer
-
- createInstance() - Method in class org.apache.flink.cep.nfa.DeweyNumber.DeweyNumberSerializer
-
- createInstance() - Method in class org.apache.flink.cep.nfa.NFA.NFASerializer
-
- createInstance() - Method in class org.apache.flink.cep.nfa.SharedBuffer.SharedBufferSerializer
-
- createInstance() - Method in class org.apache.flink.formats.avro.typeutils.AvroSerializer
-
- createInstance() - Method in class org.apache.flink.formats.avro.typeutils.BackwardsCompatibleAvroSerializer
-
- createInstance() - Method in class org.apache.flink.graph.drivers.transform.LongValueWithProperHashCode.LongValueWithProperHashCodeSerializer
-
- createInstance() - Method in class org.apache.flink.graph.types.valuearray.ByteValueArraySerializer
-
- createInstance() - Method in class org.apache.flink.graph.types.valuearray.CharValueArraySerializer
-
- createInstance() - Method in class org.apache.flink.graph.types.valuearray.DoubleValueArraySerializer
-
- createInstance() - Method in class org.apache.flink.graph.types.valuearray.FloatValueArraySerializer
-
- createInstance() - Method in class org.apache.flink.graph.types.valuearray.IntValueArraySerializer
-
- createInstance() - Method in class org.apache.flink.graph.types.valuearray.LongValueArraySerializer
-
- createInstance() - Method in class org.apache.flink.graph.types.valuearray.NullValueArraySerializer
-
- createInstance() - Method in class org.apache.flink.graph.types.valuearray.ShortValueArraySerializer
-
- createInstance() - Method in class org.apache.flink.graph.types.valuearray.StringValueArraySerializer
-
- createInstance() - Method in class org.apache.flink.queryablestate.client.VoidNamespaceSerializer
-
- createInstance() - Method in class org.apache.flink.runtime.state.ArrayListSerializer
-
- createInstance() - Method in class org.apache.flink.runtime.state.VoidNamespaceSerializer
-
- createInstance() - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.StateSerializer
-
- createInstance() - Method in class org.apache.flink.streaming.api.operators.InternalTimer.TimerSerializer
-
- createInstance() - Method in class org.apache.flink.streaming.api.windowing.windows.GlobalWindow.Serializer
-
- createInstance() - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow.Serializer
-
- createInstance() - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer011.ContextStateSerializer
-
- createInstance() - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer011.TransactionStateSerializer
-
- createInstance() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
-
- createIterationSourceAndSink(int, int, int, long, int, int, ResourceSpec, ResourceSpec) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- createJarFile() - Method in class org.apache.flink.runtime.util.JarFileCreator
-
Creates a jar file which contains the previously added class.
- createJobAccumulatorsJson(AccessExecutionGraph) - Static method in class org.apache.flink.runtime.rest.handler.legacy.JobAccumulatorsHandler
-
- createJobConfigJson(AccessExecutionGraph) - Static method in class org.apache.flink.runtime.rest.handler.legacy.JobConfigHandler
-
- createJobDetailsJson(AccessExecutionGraph, MetricFetcher) - Static method in class org.apache.flink.runtime.rest.handler.legacy.JobDetailsHandler
-
- createJobExceptionsJson(AccessExecutionGraph) - Static method in class org.apache.flink.runtime.rest.handler.legacy.JobExceptionsHandler
-
- createJobGraph(PackagedProgram, Configuration, int) - Static method in class org.apache.flink.client.program.PackagedProgramUtils
-
- createJobGraph(StreamGraph) - Static method in class org.apache.flink.streaming.api.graph.StreamingJobGraphGenerator
-
- createJobGraph(String) - Method in class org.apache.flink.table.client.gateway.local.ExecutionContext.EnvironmentInstance
-
- createJobManagerRunner(ResourceID, JobGraph, Configuration, RpcService, HighAvailabilityServices, HeartbeatServices, BlobServer, JobManagerSharedServices, JobManagerJobMetricGroupFactory, FatalErrorHandler) - Method in enum org.apache.flink.runtime.dispatcher.Dispatcher.DefaultJobManagerRunnerFactory
-
- createJobManagerRunner(ResourceID, JobGraph, Configuration, RpcService, HighAvailabilityServices, HeartbeatServices, BlobServer, JobManagerSharedServices, JobManagerJobMetricGroupFactory, FatalErrorHandler) - Method in interface org.apache.flink.runtime.dispatcher.Dispatcher.JobManagerRunnerFactory
-
- createJoinFunctionAssigner(Keys<I2>) - Method in class org.apache.flink.api.java.operators.join.JoinOperatorSetsBase.JoinOperatorSetsPredicateBase
-
- createKafkaConsumer(String, Properties, DeserializationSchema<Row>) - Method in class org.apache.flink.streaming.connectors.kafka.Kafka010AvroTableSource
-
- createKafkaConsumer(String, Properties, DeserializationSchema<Row>) - Method in class org.apache.flink.streaming.connectors.kafka.Kafka010JsonTableSource
-
- createKafkaConsumer(String, Properties, DeserializationSchema<Row>) - Method in class org.apache.flink.streaming.connectors.kafka.Kafka010TableSource
-
- createKafkaConsumer(String, Properties, DeserializationSchema<Row>) - Method in class org.apache.flink.streaming.connectors.kafka.Kafka011AvroTableSource
-
- createKafkaConsumer(String, Properties, DeserializationSchema<Row>) - Method in class org.apache.flink.streaming.connectors.kafka.Kafka011JsonTableSource
-
- createKafkaConsumer(String, Properties, DeserializationSchema<Row>) - Method in class org.apache.flink.streaming.connectors.kafka.Kafka011TableSource
-
- createKafkaConsumer(String, Properties, DeserializationSchema<Row>) - Method in class org.apache.flink.streaming.connectors.kafka.Kafka08AvroTableSource
-
- createKafkaConsumer(String, Properties, DeserializationSchema<Row>) - Method in class org.apache.flink.streaming.connectors.kafka.Kafka08JsonTableSource
-
- createKafkaConsumer(String, Properties, DeserializationSchema<Row>) - Method in class org.apache.flink.streaming.connectors.kafka.Kafka08TableSource
-
- createKafkaConsumer(String, Properties, DeserializationSchema<Row>) - Method in class org.apache.flink.streaming.connectors.kafka.Kafka09AvroTableSource
-
- createKafkaConsumer(String, Properties, DeserializationSchema<Row>) - Method in class org.apache.flink.streaming.connectors.kafka.Kafka09JsonTableSource
-
- createKafkaConsumer(String, Properties, DeserializationSchema<Row>) - Method in class org.apache.flink.streaming.connectors.kafka.Kafka09TableSource
-
- createKafkaConsumer(String, Properties, DeserializationSchema<Row>) - Method in class org.apache.flink.streaming.connectors.kafka.KafkaTableSource
-
Creates a version-specific Kafka consumer.
- createKafkaPartitionHandle(KafkaTopicPartition) - Method in class org.apache.flink.streaming.connectors.kafka.internal.Kafka09Fetcher
-
- createKafkaPartitionHandle(KafkaTopicPartition) - Method in class org.apache.flink.streaming.connectors.kafka.internals.AbstractFetcher
-
Creates the Kafka version specific representation of the given
topic partition.
- createKafkaPartitionHandle(KafkaTopicPartition) - Method in class org.apache.flink.streaming.connectors.kafka.internals.Kafka08Fetcher
-
- createKafkaProducer(String, Properties, SerializationSchema<Row>, FlinkKafkaPartitioner<Row>) - Method in class org.apache.flink.streaming.connectors.kafka.Kafka010JsonTableSink
-
- createKafkaProducer(String, Properties, SerializationSchema<Row>, FlinkKafkaPartitioner<Row>) - Method in class org.apache.flink.streaming.connectors.kafka.Kafka08JsonTableSink
-
- createKafkaProducer(String, Properties, SerializationSchema<Row>, FlinkKafkaPartitioner<Row>) - Method in class org.apache.flink.streaming.connectors.kafka.Kafka09JsonTableSink
-
- createKafkaProducer(String, Properties, SerializationSchema<Row>, FlinkKafkaPartitioner<Row>) - Method in class org.apache.flink.streaming.connectors.kafka.KafkaTableSink
-
Returns the version-specific Kafka producer.
- createKeyedStateBackend(Environment, JobID, String, TypeSerializer<K>, int, KeyGroupRange, TaskKvStateRegistry) - Method in class org.apache.flink.contrib.streaming.state.RocksDBStateBackend
-
- createKeyedStateBackend(Environment, JobID, String, TypeSerializer<K>, int, KeyGroupRange, TaskKvStateRegistry) - Method in class org.apache.flink.runtime.state.AbstractStateBackend
-
- createKeyedStateBackend(Environment, JobID, String, TypeSerializer<K>, int, KeyGroupRange, TaskKvStateRegistry) - Method in class org.apache.flink.runtime.state.filesystem.FsStateBackend
-
- createKeyedStateBackend(Environment, JobID, String, TypeSerializer<K>, int, KeyGroupRange, TaskKvStateRegistry) - Method in class org.apache.flink.runtime.state.memory.MemoryStateBackend
-
- createKeyedStateBackend(Environment, JobID, String, TypeSerializer<K>, int, KeyGroupRange, TaskKvStateRegistry) - Method in interface org.apache.flink.runtime.state.StateBackend
-
- createKeyGroupedIterator(MutableObjectIterator<T>, TypeSerializer<T>, TypeComparator<T>) - Method in class org.apache.flink.runtime.operators.sort.AbstractMergeIterator
-
- createKeyGroupedIterator(MutableObjectIterator<T>, TypeSerializer<T>, TypeComparator<T>) - Method in class org.apache.flink.runtime.operators.sort.NonReusingMergeInnerJoinIterator
-
- createKeyGroupedIterator(MutableObjectIterator<T>, TypeSerializer<T>, TypeComparator<T>) - Method in class org.apache.flink.runtime.operators.sort.NonReusingMergeOuterJoinIterator
-
- createKeyGroupedIterator(MutableObjectIterator<T>, TypeSerializer<T>, TypeComparator<T>) - Method in class org.apache.flink.runtime.operators.sort.ReusingMergeInnerJoinIterator
-
- createKeyGroupedIterator(MutableObjectIterator<T>, TypeSerializer<T>, TypeComparator<T>) - Method in class org.apache.flink.runtime.operators.sort.ReusingMergeOuterJoinIterator
-
- createKeyGroupPartitions(int, int) - Static method in class org.apache.flink.runtime.checkpoint.StateAssignmentOperation
-
Groups the available set of key groups into key group partitions.
- createKvStateClientProxy(InetAddress, Iterator<Integer>, int, int, KvStateRequestStats) - Static method in class org.apache.flink.runtime.query.QueryableStateUtils
-
Initializes the
client proxy
responsible for
receiving requests from the external (to the cluster) client and forwarding them internally.
- createKvStateServer(InetAddress, Iterator<Integer>, int, int, KvStateRegistry, KvStateRequestStats) - Static method in class org.apache.flink.runtime.query.QueryableStateUtils
-
Initializes the
server
responsible for sending the
requested internal state to the
client proxy
.
- createKvStateTaskRegistry(JobID, JobVertexID) - Method in class org.apache.flink.runtime.io.network.NetworkEnvironment
-
- createLaunchCoordinator() - Method in class org.apache.flink.mesos.runtime.clusterframework.MesosFlinkResourceManager
-
- createLaunchCoordinator(SchedulerDriver, ActorRef) - Method in class org.apache.flink.mesos.runtime.clusterframework.MesosResourceManager
-
- createLeaderElectionService() - Method in class org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedLeaderService
-
- createLeaderElectionService(CuratorFramework, Configuration) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
-
- createLeaderElectionService(CuratorFramework, Configuration, String) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
-
- createLeaderRetrievalService() - Method in class org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedLeaderService
-
- createLeaderRetrievalService() - Method in class org.apache.flink.runtime.highavailability.nonha.leaderelection.SingleLeaderElectionService
-
- createLeaderRetrievalService(Configuration) - Static method in class org.apache.flink.runtime.util.StandaloneUtils
-
- createLeaderRetrievalService(Configuration, boolean, String) - Static method in class org.apache.flink.runtime.util.StandaloneUtils
-
- createLeaderRetrievalService(CuratorFramework, Configuration) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
-
- createLeaderRetrievalService(CuratorFramework, Configuration, String) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
-
- createListState(ListStateDescriptor<T>) - Method in interface org.apache.flink.api.common.state.StateBinder
-
- createListState(TypeSerializer<N>, ListStateDescriptor<T>) - Method in class org.apache.flink.contrib.streaming.state.RocksDBKeyedStateBackend
-
- createListState(ListStateDescriptor<T>) - Method in class org.apache.flink.queryablestate.client.state.ImmutableStateBinder
-
- createListState(TypeSerializer<N>, ListStateDescriptor<T>) - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
-
- createListState(TypeSerializer<N>, ListStateDescriptor<T>) - Method in class org.apache.flink.runtime.state.heap.HeapKeyedStateBackend
-
- createLocal() - Static method in class org.apache.flink.runtime.deployment.ResultPartitionLocation
-
- createLocalCluster() - Method in class org.apache.flink.storm.api.FlinkLocalCluster.DefaultLocalClusterFactory
-
- createLocalCluster() - Method in interface org.apache.flink.storm.api.FlinkLocalCluster.LocalClusterFactory
-
Creates a local Flink cluster.
- createLocalEnvironment() - Static method in class org.apache.flink.api.java.ExecutionEnvironment
-
- createLocalEnvironment(int) - Static method in class org.apache.flink.api.java.ExecutionEnvironment
-
- createLocalEnvironment(Configuration) - Static method in class org.apache.flink.api.java.ExecutionEnvironment
-
- createLocalEnvironment() - Static method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- createLocalEnvironment(int) - Static method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- createLocalEnvironment(int, Configuration) - Static method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- createLocalEnvironmentWithWebUI(Configuration) - Static method in class org.apache.flink.api.java.ExecutionEnvironment
-
Creates a
LocalEnvironment
for local program execution that also starts the
web monitoring UI.
- createLocalEnvironmentWithWebUI(Configuration) - Static method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- createLocalExecutor(Configuration) - Static method in class org.apache.flink.api.common.PlanExecutor
-
Creates an executor that runs the plan locally in a multi-threaded environment.
- createLocalRecoveryConfig() - Method in interface org.apache.flink.runtime.state.TaskStateManager
-
Returns the configuration for local recovery, i.e.
- createLocalRecoveryConfig() - Method in class org.apache.flink.runtime.state.TaskStateManagerImpl
-
- createMapState(MapStateDescriptor<MK, MV>) - Method in interface org.apache.flink.api.common.state.StateBinder
-
- createMapState(TypeSerializer<N>, MapStateDescriptor<UK, UV>) - Method in class org.apache.flink.contrib.streaming.state.RocksDBKeyedStateBackend
-
- createMapState(MapStateDescriptor<MK, MV>) - Method in class org.apache.flink.queryablestate.client.state.ImmutableStateBinder
-
- createMapState(TypeSerializer<N>, MapStateDescriptor<UK, UV>) - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
-
- createMapState(TypeSerializer<N>, MapStateDescriptor<UK, UV>) - Method in class org.apache.flink.runtime.state.heap.HeapKeyedStateBackend
-
- createMasterTriggerRestoreHook() - Method in interface org.apache.flink.streaming.api.checkpoint.WithMasterCheckpointHook
-
Creates the hook that should be called by the checkpoint coordinator.
- createMesosSchedulerConfiguration(Configuration, String) - Static method in class org.apache.flink.mesos.entrypoint.MesosEntrypointUtils
-
Loads and validates the Mesos scheduler configuration.
- createMesosServices(Configuration, String) - Static method in class org.apache.flink.mesos.runtime.clusterframework.services.MesosServicesUtils
-
Creates a
MesosServices
instance depending on the high availability settings.
- createMesosWorkerStore(Configuration, Executor) - Method in interface org.apache.flink.mesos.runtime.clusterframework.services.MesosServices
-
Creates a
MesosWorkerStore
which is used to persist mesos worker in high availability
mode.
- createMesosWorkerStore(Configuration, Executor) - Method in class org.apache.flink.mesos.runtime.clusterframework.services.StandaloneMesosServices
-
- createMesosWorkerStore(Configuration, Executor) - Method in class org.apache.flink.mesos.runtime.clusterframework.services.ZooKeeperMesosServices
-
- createMetadataOutputStream() - Method in interface org.apache.flink.runtime.state.CheckpointStorageLocation
-
Creates the output stream to persist the checkpoint metadata to.
- createMetadataOutputStream() - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStorageLocation
-
- createMetadataOutputStream() - Method in class org.apache.flink.runtime.state.memory.NonPersistentMetadataCheckpointStorageLocation
-
- createMetadataOutputStream() - Method in class org.apache.flink.runtime.state.memory.PersistentMetadataCheckpointStorageLocation
-
- createMetricRegistry(Configuration) - Method in class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
-
- createMetricRegistry(Configuration) - Method in class org.apache.flink.runtime.minicluster.MiniCluster
-
Factory method to create the metric registry for the mini cluster.
- createModule(SecurityConfiguration) - Method in class org.apache.flink.runtime.security.modules.HadoopModuleFactory
-
- createModule(SecurityConfiguration) - Method in class org.apache.flink.runtime.security.modules.JaasModuleFactory
-
- createModule(SecurityConfiguration) - Method in interface org.apache.flink.runtime.security.modules.SecurityModuleFactory
-
- createModule(SecurityConfiguration) - Method in class org.apache.flink.runtime.security.modules.ZookeeperModuleFactory
-
- createNewOrderingUpToIndex(int) - Method in class org.apache.flink.api.common.operators.Ordering
-
Creates a new ordering the represents an ordering on a prefix of the fields.
- createNFA() - Method in interface org.apache.flink.cep.nfa.compiler.NFACompiler.NFAFactory
-
- createNiFiDataPacket(T, RuntimeContext) - Method in interface org.apache.flink.streaming.connectors.nifi.NiFiDataPacketBuilder
-
- createObjectForClassNotInClassPath(ClassLoader) - Static method in class org.apache.flink.core.testutils.CommonTestUtils
-
Creates a new class that is not part of the classpath that the current JVM uses, and
instantiates it.
- createOperationKey(HandlerRequest<B, M>) - Method in class org.apache.flink.runtime.rest.handler.async.AbstractAsynchronousOperationHandlers.TriggerHandler
-
Create the operation key under which the result future of the asynchronous operation will
be stored.
- createOperationKey(HandlerRequest<EmptyRequestBody, RescalingTriggerMessageParameters>) - Method in class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingHandlers.RescalingTriggerHandler
-
- createOperationKey(HandlerRequest<SavepointDisposalRequest, EmptyMessageParameters>) - Method in class org.apache.flink.runtime.rest.handler.job.savepoints.SavepointDisposalHandlers.SavepointDisposalTriggerHandler
-
- createOperationKey(HandlerRequest<SavepointTriggerRequestBody, SavepointTriggerMessageParameters>) - Method in class org.apache.flink.runtime.rest.handler.job.savepoints.SavepointHandlers.SavepointTriggerHandler
-
- createOperatorStateBackend(Environment, String) - Method in class org.apache.flink.contrib.streaming.state.RocksDBStateBackend
-
- createOperatorStateBackend(Environment, String) - Method in class org.apache.flink.runtime.state.AbstractStateBackend
-
- createOperatorStateBackend(Environment, String) - Method in class org.apache.flink.runtime.state.filesystem.FsStateBackend
-
- createOperatorStateBackend(Environment, String) - Method in class org.apache.flink.runtime.state.memory.MemoryStateBackend
-
- createOperatorStateBackend(Environment, String) - Method in interface org.apache.flink.runtime.state.StateBackend
-
- createOrderedFromSet(FieldSet) - Static method in class org.apache.flink.optimizer.util.Utils
-
- createOrdering(FieldList, boolean[]) - Static method in class org.apache.flink.optimizer.util.Utils
-
- createOrdering(FieldList) - Static method in class org.apache.flink.optimizer.util.Utils
-
- createOrReuseInstance(Object[], T) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializer
-
- createOrReuseInstance(Object[], T) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializerBase
-
- createPartitionDiscoverer(KafkaTopicsDescriptor, int, int) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer010
-
- createPartitionDiscoverer(KafkaTopicsDescriptor, int, int) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer08
-
- createPartitionDiscoverer(KafkaTopicsDescriptor, int, int) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer09
-
- createPartitionDiscoverer(KafkaTopicsDescriptor, int, int) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumerBase
-
Creates the partition discoverer that is used to find new partitions for this subtask.
- createPartitionRequestClient(ConnectionID) - Method in interface org.apache.flink.runtime.io.network.ConnectionManager
-
- createPartitionRequestClient(ConnectionID) - Method in class org.apache.flink.runtime.io.network.LocalConnectionManager
-
- createPartitionRequestClient(ConnectionID) - Method in class org.apache.flink.runtime.io.network.netty.NettyConnectionManager
-
- createPartitions(int, int) - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
-
- createPatternStream(DataStream<IN>, Pattern<IN, ?>, EventComparator<IN>, PatternSelectFunction<IN, OUT>, TypeInformation<OUT>) - Static method in class org.apache.flink.cep.operator.CEPOperatorUtils
-
- createPatternStream(DataStream<IN>, Pattern<IN, ?>, EventComparator<IN>, PatternFlatSelectFunction<IN, OUT>, TypeInformation<OUT>) - Static method in class org.apache.flink.cep.operator.CEPOperatorUtils
-
- createPojoSerializer(ExecutionConfig) - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo
-
- createPossibleGlobalProperties() - Method in class org.apache.flink.optimizer.dag.PartitionNode.PartitionDescriptor
-
- createPossibleGlobalProperties() - Method in class org.apache.flink.optimizer.dag.SortPartitionNode.SortPartitionDescriptor
-
- createPossibleGlobalProperties() - Method in class org.apache.flink.optimizer.operators.AbstractJoinDescriptor
-
- createPossibleGlobalProperties() - Method in class org.apache.flink.optimizer.operators.AllGroupCombineProperties
-
- createPossibleGlobalProperties() - Method in class org.apache.flink.optimizer.operators.AllGroupReduceProperties
-
- createPossibleGlobalProperties() - Method in class org.apache.flink.optimizer.operators.AllGroupWithPartialPreGroupProperties
-
- createPossibleGlobalProperties() - Method in class org.apache.flink.optimizer.operators.AllReduceProperties
-
- createPossibleGlobalProperties() - Method in class org.apache.flink.optimizer.operators.BinaryUnionOpDescriptor
-
- createPossibleGlobalProperties() - Method in class org.apache.flink.optimizer.operators.CartesianProductDescriptor
-
- createPossibleGlobalProperties() - Method in class org.apache.flink.optimizer.operators.CoGroupDescriptor
-
- createPossibleGlobalProperties() - Method in class org.apache.flink.optimizer.operators.CoGroupRawDescriptor
-
- createPossibleGlobalProperties() - Method in class org.apache.flink.optimizer.operators.FilterDescriptor
-
- createPossibleGlobalProperties() - Method in class org.apache.flink.optimizer.operators.FlatMapDescriptor
-
- createPossibleGlobalProperties() - Method in class org.apache.flink.optimizer.operators.GroupCombineProperties
-
- createPossibleGlobalProperties() - Method in class org.apache.flink.optimizer.operators.GroupReduceProperties
-
- createPossibleGlobalProperties() - Method in class org.apache.flink.optimizer.operators.GroupReduceWithCombineProperties
-
- createPossibleGlobalProperties() - Method in class org.apache.flink.optimizer.operators.MapDescriptor
-
- createPossibleGlobalProperties() - Method in class org.apache.flink.optimizer.operators.MapPartitionDescriptor
-
- createPossibleGlobalProperties() - Method in class org.apache.flink.optimizer.operators.NoOpDescriptor
-
- createPossibleGlobalProperties() - Method in class org.apache.flink.optimizer.operators.OperatorDescriptorDual
-
- createPossibleGlobalProperties() - Method in class org.apache.flink.optimizer.operators.OperatorDescriptorSingle
-
Returns a list of global properties that are required by this operator descriptor.
- createPossibleGlobalProperties() - Method in class org.apache.flink.optimizer.operators.PartialGroupProperties
-
- createPossibleGlobalProperties() - Method in class org.apache.flink.optimizer.operators.ReduceProperties
-
- createPossibleGlobalProperties() - Method in class org.apache.flink.optimizer.operators.SolutionSetDeltaOperator
-
- createPossibleGlobalProperties() - Method in class org.apache.flink.optimizer.operators.UtilSinkJoinOpDescriptor
-
- createPossibleLocalProperties() - Method in class org.apache.flink.optimizer.dag.PartitionNode.PartitionDescriptor
-
- createPossibleLocalProperties() - Method in class org.apache.flink.optimizer.dag.SortPartitionNode.SortPartitionDescriptor
-
- createPossibleLocalProperties() - Method in class org.apache.flink.optimizer.operators.AbstractSortMergeJoinDescriptor
-
- createPossibleLocalProperties() - Method in class org.apache.flink.optimizer.operators.AllGroupCombineProperties
-
- createPossibleLocalProperties() - Method in class org.apache.flink.optimizer.operators.AllGroupReduceProperties
-
- createPossibleLocalProperties() - Method in class org.apache.flink.optimizer.operators.AllGroupWithPartialPreGroupProperties
-
- createPossibleLocalProperties() - Method in class org.apache.flink.optimizer.operators.AllReduceProperties
-
- createPossibleLocalProperties() - Method in class org.apache.flink.optimizer.operators.BinaryUnionOpDescriptor
-
- createPossibleLocalProperties() - Method in class org.apache.flink.optimizer.operators.CartesianProductDescriptor
-
- createPossibleLocalProperties() - Method in class org.apache.flink.optimizer.operators.CoGroupDescriptor
-
- createPossibleLocalProperties() - Method in class org.apache.flink.optimizer.operators.CoGroupRawDescriptor
-
- createPossibleLocalProperties() - Method in class org.apache.flink.optimizer.operators.CoGroupWithSolutionSetFirstDescriptor
-
- createPossibleLocalProperties() - Method in class org.apache.flink.optimizer.operators.CoGroupWithSolutionSetSecondDescriptor
-
- createPossibleLocalProperties() - Method in class org.apache.flink.optimizer.operators.FilterDescriptor
-
- createPossibleLocalProperties() - Method in class org.apache.flink.optimizer.operators.FlatMapDescriptor
-
- createPossibleLocalProperties() - Method in class org.apache.flink.optimizer.operators.GroupCombineProperties
-
- createPossibleLocalProperties() - Method in class org.apache.flink.optimizer.operators.GroupReduceProperties
-
- createPossibleLocalProperties() - Method in class org.apache.flink.optimizer.operators.GroupReduceWithCombineProperties
-
- createPossibleLocalProperties() - Method in class org.apache.flink.optimizer.operators.HashFullOuterJoinBuildFirstDescriptor
-
- createPossibleLocalProperties() - Method in class org.apache.flink.optimizer.operators.HashFullOuterJoinBuildSecondDescriptor
-
- createPossibleLocalProperties() - Method in class org.apache.flink.optimizer.operators.HashJoinBuildFirstProperties
-
- createPossibleLocalProperties() - Method in class org.apache.flink.optimizer.operators.HashJoinBuildSecondProperties
-
- createPossibleLocalProperties() - Method in class org.apache.flink.optimizer.operators.HashLeftOuterJoinBuildFirstDescriptor
-
- createPossibleLocalProperties() - Method in class org.apache.flink.optimizer.operators.HashLeftOuterJoinBuildSecondDescriptor
-
- createPossibleLocalProperties() - Method in class org.apache.flink.optimizer.operators.HashRightOuterJoinBuildFirstDescriptor
-
- createPossibleLocalProperties() - Method in class org.apache.flink.optimizer.operators.HashRightOuterJoinBuildSecondDescriptor
-
- createPossibleLocalProperties() - Method in class org.apache.flink.optimizer.operators.MapDescriptor
-
- createPossibleLocalProperties() - Method in class org.apache.flink.optimizer.operators.MapPartitionDescriptor
-
- createPossibleLocalProperties() - Method in class org.apache.flink.optimizer.operators.NoOpDescriptor
-
- createPossibleLocalProperties() - Method in class org.apache.flink.optimizer.operators.OperatorDescriptorDual
-
- createPossibleLocalProperties() - Method in class org.apache.flink.optimizer.operators.OperatorDescriptorSingle
-
Returns a list of local properties that are required by this operator descriptor.
- createPossibleLocalProperties() - Method in class org.apache.flink.optimizer.operators.PartialGroupProperties
-
- createPossibleLocalProperties() - Method in class org.apache.flink.optimizer.operators.ReduceProperties
-
- createPossibleLocalProperties() - Method in class org.apache.flink.optimizer.operators.SolutionSetDeltaOperator
-
- createPossibleLocalProperties() - Method in class org.apache.flink.optimizer.operators.UtilSinkJoinOpDescriptor
-
- createPreOptimizedPlan(Plan) - Static method in class org.apache.flink.optimizer.Optimizer
-
This function performs only the first step to the compilation process - the creation of the optimizer
representation of the plan.
- createProber(TypeComparator<PT>, TypePairComparator<PT, BT>) - Method in class org.apache.flink.api.common.operators.util.JoinHashMap
-
- createProgramPlan() - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
Creates the program's
Plan
.
- createProgramPlan(String) - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
Creates the program's
Plan
.
- createProgramPlan(String, boolean) - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
Creates the program's
Plan
.
- createProjectionPropertiesDual(int[], boolean[], TypeInformation<?>, TypeInformation<?>) - Static method in class org.apache.flink.api.java.functions.SemanticPropUtil
-
- createProjectionPropertiesSingle(int[], CompositeType<?>) - Static method in class org.apache.flink.api.java.functions.SemanticPropUtil
-
- createPropertiesFile(String) - Method in class org.apache.flink.api.java.utils.ParameterTool
-
Create a properties file with all the known parameters (call after the last get*() call).
- createPropertiesFile(String, boolean) - Method in class org.apache.flink.api.java.utils.ParameterTool
-
Create a properties file with all the known parameters (call after the last get*() call).
- createQueryServiceMetricInfo(CharacterFilter) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
-
Creates the metric query service scope for this group.
- createQueryServiceMetricInfo(CharacterFilter) - Method in class org.apache.flink.runtime.metrics.groups.GenericMetricGroup
-
- createQueryServiceMetricInfo(CharacterFilter) - Method in class org.apache.flink.runtime.metrics.groups.JobManagerMetricGroup
-
- createQueryServiceMetricInfo(CharacterFilter) - Method in class org.apache.flink.runtime.metrics.groups.JobMetricGroup
-
- createQueryServiceMetricInfo(CharacterFilter) - Method in class org.apache.flink.runtime.metrics.groups.OperatorMetricGroup
-
- createQueryServiceMetricInfo(CharacterFilter) - Method in class org.apache.flink.runtime.metrics.groups.TaskManagerMetricGroup
-
- createQueryServiceMetricInfo(CharacterFilter) - Method in class org.apache.flink.runtime.metrics.groups.TaskMetricGroup
-
- createRandomName(String) - Static method in class org.apache.flink.runtime.rpc.akka.AkkaRpcServiceUtils
-
Creates a random name of the form prefix_X, where X is an increasing number.
- createReadView(BufferAvailabilityListener) - Method in class org.apache.flink.runtime.io.network.partition.ResultSubpartition
-
- createReconciliationCoordinator() - Method in class org.apache.flink.mesos.runtime.clusterframework.MesosFlinkResourceManager
-
- createReconciliationCoordinator(SchedulerDriver) - Method in class org.apache.flink.mesos.runtime.clusterframework.MesosResourceManager
-
- createReducingState(ReducingStateDescriptor<T>) - Method in interface org.apache.flink.api.common.state.StateBinder
-
- createReducingState(TypeSerializer<N>, ReducingStateDescriptor<T>) - Method in class org.apache.flink.contrib.streaming.state.RocksDBKeyedStateBackend
-
- createReducingState(ReducingStateDescriptor<T>) - Method in class org.apache.flink.queryablestate.client.state.ImmutableStateBinder
-
- createReducingState(TypeSerializer<N>, ReducingStateDescriptor<T>) - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
-
- createReducingState(TypeSerializer<N>, ReducingStateDescriptor<T>) - Method in class org.apache.flink.runtime.state.heap.HeapKeyedStateBackend
-
- createRemote(ConnectionID) - Static method in class org.apache.flink.runtime.deployment.ResultPartitionLocation
-
- createRemoteEnvironment(String, int, String...) - Static method in class org.apache.flink.api.java.ExecutionEnvironment
-
- createRemoteEnvironment(String, int, Configuration, String...) - Static method in class org.apache.flink.api.java.ExecutionEnvironment
-
- createRemoteEnvironment(String, int, int, String...) - Static method in class org.apache.flink.api.java.ExecutionEnvironment
-
- createRemoteEnvironment(String, int, String...) - Static method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- createRemoteEnvironment(String, int, int, String...) - Static method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- createRemoteEnvironment(String, int, Configuration, String...) - Static method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- createRemoteExecutor(String, int, Configuration, List<URL>, List<URL>) - Static method in class org.apache.flink.api.common.PlanExecutor
-
Creates an executor that runs the plan on a remote environment.
- createResource() - Method in class org.apache.flink.streaming.connectors.cassandra.CassandraCommitter
-
Generates the necessary tables to store information.
- createResource() - Method in class org.apache.flink.streaming.runtime.operators.CheckpointCommitter
-
Creates/opens/connects to the resource that is used to store information.
- createResourceManager(Configuration, ResourceID, RpcService, HighAvailabilityServices, HeartbeatServices, MetricRegistry, FatalErrorHandler, ClusterInformation, String, JobManagerMetricGroup) - Method in class org.apache.flink.mesos.entrypoint.MesosJobClusterEntrypoint
-
- createResourceManager(Configuration, ResourceID, RpcService, HighAvailabilityServices, HeartbeatServices, MetricRegistry, FatalErrorHandler, ClusterInformation, String, JobManagerMetricGroup) - Method in class org.apache.flink.mesos.entrypoint.MesosSessionClusterEntrypoint
-
- createResourceManager(Configuration, ResourceID, RpcService, HighAvailabilityServices, HeartbeatServices, MetricRegistry, FatalErrorHandler, ClusterInformation, String, JobManagerMetricGroup) - Method in class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
-
- createResourceManager(Configuration, ResourceID, RpcService, HighAvailabilityServices, HeartbeatServices, MetricRegistry, FatalErrorHandler, ClusterInformation, String, JobManagerMetricGroup) - Method in class org.apache.flink.runtime.entrypoint.StandaloneSessionClusterEntrypoint
-
- createResourceManager(Configuration, ResourceID, RpcService, HighAvailabilityServices, HeartbeatServices, MetricRegistry, FatalErrorHandler, ClusterInformation, String, JobManagerMetricGroup) - Method in class org.apache.flink.yarn.entrypoint.YarnJobClusterEntrypoint
-
- createResourceManager(Configuration, ResourceID, RpcService, HighAvailabilityServices, HeartbeatServices, MetricRegistry, FatalErrorHandler, ClusterInformation, String, JobManagerMetricGroup) - Method in class org.apache.flink.yarn.entrypoint.YarnSessionClusterEntrypoint
-
- createRestartStrategy() - Method in class org.apache.flink.runtime.executiongraph.restart.FailureRateRestartStrategy.FailureRateRestartStrategyFactory
-
- createRestartStrategy() - Method in class org.apache.flink.runtime.executiongraph.restart.FixedDelayRestartStrategy.FixedDelayRestartStrategyFactory
-
- createRestartStrategy() - Method in class org.apache.flink.runtime.executiongraph.restart.NoRestartStrategy.NoRestartStrategyFactory
-
- createRestartStrategy() - Method in class org.apache.flink.runtime.executiongraph.restart.RestartStrategyFactory
-
Factory method to create a restart strategy
- createRestartStrategy(RestartStrategies.RestartStrategyConfiguration) - Static method in class org.apache.flink.runtime.executiongraph.restart.RestartStrategyFactory
-
- createRestartStrategyFactory(Configuration) - Static method in class org.apache.flink.runtime.executiongraph.restart.RestartStrategyFactory
-
- createRestEndpoint(Configuration, LeaderGatewayRetriever<DispatcherGateway>, LeaderGatewayRetriever<ResourceManagerGateway>, TransientBlobService, ExecutorService, MetricQueryServiceRetriever, LeaderElectionService) - Method in class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
-
- createRestEndpoint(Configuration, LeaderGatewayRetriever<DispatcherGateway>, LeaderGatewayRetriever<ResourceManagerGateway>, TransientBlobService, ExecutorService, MetricQueryServiceRetriever, LeaderElectionService) - Method in class org.apache.flink.runtime.entrypoint.JobClusterEntrypoint
-
- createRestEndpoint(Configuration, LeaderGatewayRetriever<DispatcherGateway>, LeaderGatewayRetriever<ResourceManagerGateway>, TransientBlobService, ExecutorService, MetricQueryServiceRetriever, LeaderElectionService) - Method in class org.apache.flink.runtime.entrypoint.SessionClusterEntrypoint
-
- createResult() - Method in interface org.apache.flink.api.java.operators.CustomUnaryOperation
-
- createResult() - Method in class org.apache.flink.graph.gsa.GatherSumApplyIteration
-
Computes the results of the gather-sum-apply iteration.
- createResult() - Method in class org.apache.flink.graph.pregel.VertexCentricIteration
-
Creates the operator that represents this vertex-centric graph computation.
- createResult() - Method in class org.apache.flink.graph.spargel.ScatterGatherIteration
-
Creates the operator that represents this scatter-gather graph computation.
- createResult(Environment, TableSchema, ExecutionConfig) - Method in class org.apache.flink.table.client.gateway.local.ResultStore
-
Creates a result.
- createRpcService(Configuration, String, String) - Method in class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
-
- createRpcService(Configuration, Time, boolean, String) - Method in class org.apache.flink.runtime.minicluster.MiniCluster
-
Factory method to instantiate the RPC service.
- createRpcService(String, int, Configuration) - Static method in class org.apache.flink.runtime.rpc.akka.AkkaRpcServiceUtils
-
Utility method to create RPC service from configuration and hostname, port.
- createRpcService(Configuration, HighAvailabilityServices) - Static method in class org.apache.flink.runtime.taskexecutor.TaskManagerRunner
-
Create a RPC service for the task manager.
- createRuntimeContext(MetricGroup) - Method in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
-
- createRuntimeContext(MetricGroup) - Method in class org.apache.flink.runtime.operators.BatchTask
-
- createRuntimeContext() - Method in class org.apache.flink.runtime.operators.DataSinkTask
-
- createRuntimeContext() - Method in class org.apache.flink.runtime.operators.DataSourceTask
-
- createSavepointLocation(FileSystem, Path) - Method in class org.apache.flink.runtime.state.filesystem.AbstractFsCheckpointStorage
-
- createSavepointLocation(FileSystem, Path) - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStorage
-
- createSavepointLocation(FileSystem, Path) - Method in class org.apache.flink.runtime.state.memory.MemoryBackendCheckpointStorage
-
- createSelfActor() - Method in class org.apache.flink.mesos.runtime.clusterframework.MesosResourceManager
-
- createSerializableExecutionGraphStore(Configuration, ScheduledExecutor) - Method in class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
-
- createSerializableExecutionGraphStore(Configuration, ScheduledExecutor) - Method in class org.apache.flink.runtime.entrypoint.JobClusterEntrypoint
-
- createSerializableExecutionGraphStore(Configuration, ScheduledExecutor) - Method in class org.apache.flink.runtime.entrypoint.SessionClusterEntrypoint
-
- createSerializationSchema(RowTypeInfo) - Method in class org.apache.flink.streaming.connectors.kafka.KafkaJsonTableSink
-
- createSerializationSchema(RowTypeInfo) - Method in class org.apache.flink.streaming.connectors.kafka.KafkaTableSink
-
Create serialization schema for converting table rows into bytes.
- createSerializer(ExecutionConfig) - Method in class org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
-
- createSerializer(ExecutionConfig) - Method in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
-
- createSerializer(ExecutionConfig) - Method in class org.apache.flink.api.common.typeinfo.NothingTypeInfo
-
- createSerializer(ExecutionConfig) - Method in class org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
-
- createSerializer(ExecutionConfig) - Method in class org.apache.flink.api.common.typeinfo.SqlTimeTypeInfo
-
- createSerializer(ExecutionConfig) - Method in class org.apache.flink.api.common.typeinfo.TypeInformation
-
Creates a serializer for the type.
- createSerializer(ExecutionConfig) - Method in class org.apache.flink.api.java.typeutils.EitherTypeInfo
-
- createSerializer(ExecutionConfig) - Method in class org.apache.flink.api.java.typeutils.EnumTypeInfo
-
- createSerializer(ExecutionConfig) - Method in class org.apache.flink.api.java.typeutils.GenericTypeInfo
-
- createSerializer(ExecutionConfig) - Method in class org.apache.flink.api.java.typeutils.ListTypeInfo
-
- createSerializer(ExecutionConfig) - Method in class org.apache.flink.api.java.typeutils.MapTypeInfo
-
- createSerializer(ExecutionConfig) - Method in class org.apache.flink.api.java.typeutils.MissingTypeInfo
-
- createSerializer(ExecutionConfig) - Method in class org.apache.flink.api.java.typeutils.ObjectArrayTypeInfo
-
- createSerializer(ExecutionConfig) - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo
-
- createSerializer(ExecutionConfig) - Method in class org.apache.flink.api.java.typeutils.RowTypeInfo
-
- createSerializer(ExecutionConfig) - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfo
-
- createSerializer(ExecutionConfig) - Method in class org.apache.flink.api.java.typeutils.ValueTypeInfo
-
- createSerializer(ExecutionConfig) - Method in class org.apache.flink.api.java.typeutils.WritableTypeInfo
-
- createSerializer(ExecutionConfig) - Method in class org.apache.flink.formats.avro.typeutils.AvroTypeInfo
-
- createSerializer(ExecutionConfig) - Method in class org.apache.flink.graph.drivers.transform.LongValueWithProperHashCode.LongValueWithProperHashCodeTypeInfo
-
- createSerializer(ExecutionConfig) - Method in class org.apache.flink.graph.types.valuearray.ValueArrayTypeInfo
-
- createSerializer(ExecutionConfig) - Method in class org.apache.flink.queryablestate.client.VoidNamespaceTypeInfo
-
- createSerializer(ExecutionConfig) - Method in class org.apache.flink.runtime.state.VoidNamespaceTypeInfo
-
- createSerializerInstance(Class<T>, TypeSerializer<?>[]) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializer
-
- createSerializerInstance(Class<T>, TypeSerializer<?>[]) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializerBase
-
- createServerSSLContext() - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
-
- createServerSSLEngineFactory(Configuration) - Static method in class org.apache.flink.runtime.net.SSLUtils
-
- createSharedCount(String, int) - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperUtilityFactory
-
- createSharedStateRegistryKeyFromFileName(StateHandleID) - Method in class org.apache.flink.runtime.state.IncrementalKeyedStateHandle
-
Create a unique key to register one of our shared state handles.
- createSharedValue(String, byte[]) - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperUtilityFactory
-
- createSimpleStream(CheckpointedStateScope, CheckpointStreamFactory) - Static method in interface org.apache.flink.runtime.state.CheckpointStreamWithResultProvider
-
- createSink() - Method in class org.apache.flink.streaming.connectors.cassandra.CassandraSink.CassandraPojoSinkBuilder
-
- createSink() - Method in class org.apache.flink.streaming.connectors.cassandra.CassandraSink.CassandraRowSinkBuilder
-
- createSink() - Method in class org.apache.flink.streaming.connectors.cassandra.CassandraSink.CassandraScalaProductSinkBuilder
-
- createSink() - Method in class org.apache.flink.streaming.connectors.cassandra.CassandraSink.CassandraSinkBuilder
-
- createSink() - Method in class org.apache.flink.streaming.connectors.cassandra.CassandraSink.CassandraTupleSinkBuilder
-
- createSlotPool(JobID) - Method in class org.apache.flink.runtime.jobmaster.slotpool.DefaultSlotPoolFactory
-
- createSlotPool(JobID) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.SlotPoolFactory
-
- createSlotReport(ResourceID) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
-
- createSnapshot() - Method in class org.apache.flink.runtime.checkpoint.CheckpointStatsTracker
-
Creates a new snapshot of the available stats.
- createSnapshot() - Method in class org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
-
- createSnapshot() - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateTable
-
- createSnapshot() - Method in class org.apache.flink.runtime.state.heap.NestedMapsStateTable
-
- createSocket(int) - Method in interface org.apache.flink.util.NetUtils.SocketFactory
-
- createSocketFromPorts(Iterator<Integer>, NetUtils.SocketFactory) - Static method in class org.apache.flink.util.NetUtils
-
Tries to allocate a socket from the given sets of ports.
- createSolutionSetUpdateOutputCollector(Collector<OT>) - Method in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
-
Creates a new solution set update output collector.
- createSSLClientContext(Configuration) - Static method in class org.apache.flink.runtime.net.SSLUtils
-
Creates the SSL Context for the client if SSL is configured.
- createSSLEngine() - Method in class org.apache.flink.runtime.net.SSLEngineFactory
-
- createSSLServerContext(Configuration) - Static method in class org.apache.flink.runtime.net.SSLUtils
-
Creates the SSL Context for the server if SSL is configured.
- createStartState(NFA<T>, State<T>) - Static method in class org.apache.flink.cep.nfa.ComputationState
-
- createStartState(NFA<T>, State<T>, DeweyNumber) - Static method in class org.apache.flink.cep.nfa.ComputationState
-
- createState(NFA<T>, State<T>, State<T>, T, int, long, DeweyNumber, long) - Static method in class org.apache.flink.cep.nfa.ComputationState
-
- createState(AggregatingStateDescriptor<IN, ACC, OUT>, byte[]) - Static method in class org.apache.flink.queryablestate.client.state.ImmutableAggregatingState
-
- createState(FoldingStateDescriptor<IN, ACC>, byte[]) - Static method in class org.apache.flink.queryablestate.client.state.ImmutableFoldingState
-
Deprecated.
- createState(ListStateDescriptor<V>, byte[]) - Static method in class org.apache.flink.queryablestate.client.state.ImmutableListState
-
- createState(MapStateDescriptor<K, V>, byte[]) - Static method in class org.apache.flink.queryablestate.client.state.ImmutableMapState
-
- createState(ReducingStateDescriptor<V>, byte[]) - Static method in class org.apache.flink.queryablestate.client.state.ImmutableReducingState
-
- createState(ValueStateDescriptor<V>, byte[]) - Static method in class org.apache.flink.queryablestate.client.state.ImmutableValueState
-
- createStatistics(List<FileStatus>, FileInputFormat.FileBaseStatistics) - Method in class org.apache.flink.api.common.io.BinaryInputFormat
-
Fill in the statistics.
- createStreamRecordWriters(StreamConfig, Environment) - Static method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- createStreamTaskStateInitializer() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- createSubmittedJobGraphs(CuratorFramework, Configuration) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
-
- createSubpartitionView(int, BufferAvailabilityListener) - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
-
Returns the requested subpartition.
- createSubpartitionView(ResultPartitionID, int, BufferAvailabilityListener) - Method in class org.apache.flink.runtime.io.network.partition.ResultPartitionManager
-
- createSubpartitionView(ResultPartitionID, int, BufferAvailabilityListener) - Method in interface org.apache.flink.runtime.io.network.partition.ResultPartitionProvider
-
Returns the requested intermediate result partition input view.
- createSubtasksAccumulatorsJson(AccessExecutionJobVertex) - Static method in class org.apache.flink.runtime.rest.handler.legacy.SubtasksAllAccumulatorsHandler
-
- createSubtaskTimesJson(AccessExecutionJobVertex) - Static method in class org.apache.flink.runtime.rest.handler.legacy.SubtasksTimesHandler
-
- createTaskMonitor(SchedulerDriver) - Method in class org.apache.flink.mesos.runtime.clusterframework.MesosResourceManager
-
- createTaskOwnedStateStream() - Method in interface org.apache.flink.runtime.state.CheckpointStorage
-
Opens a stream to persist checkpoint state data that is owned strictly by tasks and
not attached to the life cycle of a specific checkpoint.
- createTaskOwnedStateStream() - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStorage
-
- createTaskOwnedStateStream() - Method in class org.apache.flink.runtime.state.memory.MemoryBackendCheckpointStorage
-
- createTaskRegistry(JobID, JobVertexID) - Method in class org.apache.flink.runtime.query.KvStateRegistry
-
- createTaskRouter() - Method in class org.apache.flink.mesos.runtime.clusterframework.MesosFlinkResourceManager
-
- createTempFile(String) - Static method in class org.apache.flink.core.testutils.CommonTestUtils
-
Creates a temporary file that contains the given string.
- createTempFile(String, String) - Method in class org.apache.flink.test.util.AbstractTestBase
-
- createTimeoutPatternStream(DataStream<IN>, Pattern<IN, ?>, EventComparator<IN>, PatternFlatSelectFunction<IN, OUT1>, TypeInformation<OUT1>, OutputTag<OUT2>, PatternFlatTimeoutFunction<IN, OUT2>) - Static method in class org.apache.flink.cep.operator.CEPOperatorUtils
-
- createTimeoutPatternStream(DataStream<IN>, Pattern<IN, ?>, EventComparator<IN>, PatternSelectFunction<IN, OUT1>, TypeInformation<OUT1>, OutputTag<OUT2>, PatternTimeoutFunction<IN, OUT2>) - Static method in class org.apache.flink.cep.operator.CEPOperatorUtils
-
- createTmParameters(Configuration, Logger) - Static method in class org.apache.flink.mesos.entrypoint.MesosEntrypointUtils
-
- createTmpFile(String, DistributedCache.DistributedCacheEntry, JobID) - Method in class org.apache.flink.runtime.filecache.FileCache
-
If the file doesn't exists locally, it will copy the file to the temp directory.
- createTopology(TopologyBuilder) - Static method in class org.apache.flink.storm.api.FlinkTopology
-
Creates a Flink program that uses the specified spouts and bolts.
- createTuple(int) - Static method in class org.apache.flink.python.api.streaming.data.PythonReceiver
-
- createTypeComparator(ExecutionConfig) - Method in interface org.apache.flink.api.common.typeutils.CompositeType.TypeComparatorBuilder
-
- createTypeComparatorBuilder() - Method in class org.apache.flink.api.common.typeutils.CompositeType
-
- createTypeComparatorBuilder() - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo
-
- createTypeComparatorBuilder() - Method in class org.apache.flink.api.java.typeutils.RowTypeInfo
-
- createTypeComparatorBuilder() - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfo
-
- createTypeInfo(Type, Map<String, TypeInformation<?>>) - Method in class org.apache.flink.api.common.typeinfo.TypeInfoFactory
-
Creates type information for the type the factory is targeted for.
- createTypeInfo(Type, Map<String, TypeInformation<?>>) - Method in class org.apache.flink.api.java.typeutils.EitherTypeInfoFactory
-
- createTypeInfo(Class<T>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
- createTypeInfo(Type) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
- createTypeInfo(Object, Class<?>, Class<?>, int) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
- createTypeInfo(Class<?>, Class<?>, int, TypeInformation<IN1>, TypeInformation<IN2>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
- createTypeInfo(Type, Map<String, TypeInformation<?>>) - Method in class org.apache.flink.graph.drivers.transform.LongValueWithProperHashCode.LongValueWithProperHashCodeTypeInfoFactory
-
- createTypeInfo(Type, Map<String, TypeInformation<?>>) - Method in class org.apache.flink.graph.types.valuearray.ValueArrayTypeInfoFactory
-
- createTypeWithKey(Keys.SelectorFunctionKeys<T, K>) - Static method in class org.apache.flink.api.java.operators.KeyFunctions
-
- createTypeWithKey(Keys.SelectorFunctionKeys<T, K1>, Keys.SelectorFunctionKeys<T, K2>) - Static method in class org.apache.flink.api.java.operators.KeyFunctions
-
- createUnionCascade(List<? extends Operator<T>>) - Static method in class org.apache.flink.api.common.operators.Operator
-
Takes a list of operators and creates a cascade of unions of this inputs, if needed.
- createUnionCascade(Operator<T>...) - Static method in class org.apache.flink.api.common.operators.Operator
-
Takes a list of operators and creates a cascade of unions of this inputs, if needed.
- createUnionCascade(Operator<T>, Operator<T>...) - Static method in class org.apache.flink.api.common.operators.Operator
-
Takes a single Operator and a list of operators and creates a cascade of unions of this inputs, if needed.
- createUnknown() - Static method in class org.apache.flink.runtime.deployment.ResultPartitionLocation
-
- createUnregisteredJobManagerJobMetricGroup() - Static method in class org.apache.flink.runtime.metrics.groups.UnregisteredMetricGroups
-
- createUnregisteredJobManagerMetricGroup() - Static method in class org.apache.flink.runtime.metrics.groups.UnregisteredMetricGroups
-
- createUnregisteredOperatorMetricGroup() - Static method in class org.apache.flink.runtime.metrics.groups.UnregisteredMetricGroups
-
- createUnregisteredTaskManagerJobMetricGroup() - Static method in class org.apache.flink.runtime.metrics.groups.UnregisteredMetricGroups
-
- createUnregisteredTaskManagerMetricGroup() - Static method in class org.apache.flink.runtime.metrics.groups.UnregisteredMetricGroups
-
- createUnregisteredTaskMetricGroup() - Static method in class org.apache.flink.runtime.metrics.groups.UnregisteredMetricGroups
-
- createValue() - Method in class org.apache.flink.types.parser.BigDecParser
-
- createValue() - Method in class org.apache.flink.types.parser.BigIntParser
-
- createValue() - Method in class org.apache.flink.types.parser.BooleanParser
-
- createValue() - Method in class org.apache.flink.types.parser.BooleanValueParser
-
- createValue() - Method in class org.apache.flink.types.parser.ByteParser
-
- createValue() - Method in class org.apache.flink.types.parser.ByteValueParser
-
- createValue() - Method in class org.apache.flink.types.parser.DoubleParser
-
- createValue() - Method in class org.apache.flink.types.parser.DoubleValueParser
-
- createValue() - Method in class org.apache.flink.types.parser.FieldParser
-
Returns an instance of the parsed value type.
- createValue() - Method in class org.apache.flink.types.parser.FloatParser
-
- createValue() - Method in class org.apache.flink.types.parser.FloatValueParser
-
- createValue() - Method in class org.apache.flink.types.parser.IntParser
-
- createValue() - Method in class org.apache.flink.types.parser.IntValueParser
-
- createValue() - Method in class org.apache.flink.types.parser.LongParser
-
- createValue() - Method in class org.apache.flink.types.parser.LongValueParser
-
- createValue() - Method in class org.apache.flink.types.parser.ShortParser
-
- createValue() - Method in class org.apache.flink.types.parser.ShortValueParser
-
- createValue() - Method in class org.apache.flink.types.parser.SqlDateParser
-
- createValue() - Method in class org.apache.flink.types.parser.SqlTimeParser
-
- createValue() - Method in class org.apache.flink.types.parser.SqlTimestampParser
-
- createValue() - Method in class org.apache.flink.types.parser.StringParser
-
- createValue() - Method in class org.apache.flink.types.parser.StringValueParser
-
- createValueArray(Class<? extends Value>) - Static method in class org.apache.flink.graph.types.valuearray.ValueArrayFactory
-
Produce a ValueArray
for the given Value
type.
- createValueArray(Class<? extends Value>, int) - Static method in class org.apache.flink.graph.types.valuearray.ValueArrayFactory
-
Produce a ValueArray
for the given Value
type with the
given bounded size.
- createValueState(ValueStateDescriptor<T>) - Method in interface org.apache.flink.api.common.state.StateBinder
-
- createValueState(TypeSerializer<N>, ValueStateDescriptor<T>) - Method in class org.apache.flink.contrib.streaming.state.RocksDBKeyedStateBackend
-
- createValueState(ValueStateDescriptor<T>) - Method in class org.apache.flink.queryablestate.client.state.ImmutableStateBinder
-
- createValueState(TypeSerializer<N>, ValueStateDescriptor<T>) - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
-
- createValueState(TypeSerializer<N>, ValueStateDescriptor<V>) - Method in class org.apache.flink.runtime.state.heap.HeapKeyedStateBackend
-
- createVertexAccumulatorsJson(AccessExecutionJobVertex) - Static method in class org.apache.flink.runtime.rest.handler.legacy.JobVertexAccumulatorsHandler
-
- createVertexDetailsByTaskManagerJson(AccessExecutionJobVertex, String, MetricFetcher) - Static method in class org.apache.flink.runtime.rest.handler.legacy.JobVertexTaskManagersHandler
-
- createVertexDetailsJson(AccessExecutionJobVertex, String, MetricFetcher) - Static method in class org.apache.flink.runtime.rest.handler.legacy.JobVertexDetailsHandler
-
- createWorksetUpdateOutputCollector(Collector<OT>) - Method in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
-
- createWorksetUpdateOutputCollector() - Method in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
-
- createWriteAheadSink() - Method in class org.apache.flink.streaming.connectors.cassandra.CassandraSink.CassandraPojoSinkBuilder
-
- createWriteAheadSink() - Method in class org.apache.flink.streaming.connectors.cassandra.CassandraSink.CassandraRowSinkBuilder
-
- createWriteAheadSink() - Method in class org.apache.flink.streaming.connectors.cassandra.CassandraSink.CassandraScalaProductSinkBuilder
-
- createWriteAheadSink() - Method in class org.apache.flink.streaming.connectors.cassandra.CassandraSink.CassandraSinkBuilder
-
- createWriteAheadSink() - Method in class org.apache.flink.streaming.connectors.cassandra.CassandraSink.CassandraTupleSinkBuilder
-
- createYarnClusterClient(AbstractYarnClusterDescriptor, int, int, ApplicationReport, Configuration, boolean) - Method in class org.apache.flink.yarn.AbstractYarnClusterDescriptor
-
Creates a YarnClusterClient; may be overriden in tests.
- createYarnClusterClient(AbstractYarnClusterDescriptor, int, int, ApplicationReport, Configuration, boolean) - Method in class org.apache.flink.yarn.LegacyYarnClusterDescriptor
-
- createYarnClusterClient(AbstractYarnClusterDescriptor, int, int, ApplicationReport, Configuration, boolean) - Method in class org.apache.flink.yarn.YarnClusterDescriptor
-
- createZooKeeperStateHandleStore(String, RetrievableStateStorageHelper<T>) - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperUtilityFactory
-
- credential() - Method in class org.apache.flink.mesos.util.MesosConfiguration
-
The credential to authenticate the framework principal.
- credentials - Variable in class org.apache.flink.api.java.hadoop.common.HadoopInputFormatCommonBase
-
- credentials - Variable in class org.apache.flink.api.java.hadoop.common.HadoopOutputFormatCommonBase
-
- cross(IN1, IN2) - Method in interface org.apache.flink.api.common.functions.CrossFunction
-
Cross UDF method.
- cross(IN1, IN2) - Method in class org.apache.flink.api.common.functions.RichCrossFunction
-
- cross(DataSet<R>) - Method in class org.apache.flink.api.java.DataSet
-
Initiates a Cross transformation.
- cross(T1, T2) - Method in class org.apache.flink.api.java.operators.CrossOperator.ProjectCrossFunction
-
- CrossBlockOuterFirstDescriptor - Class in org.apache.flink.optimizer.operators
-
- CrossBlockOuterFirstDescriptor() - Constructor for class org.apache.flink.optimizer.operators.CrossBlockOuterFirstDescriptor
-
- CrossBlockOuterFirstDescriptor(boolean, boolean) - Constructor for class org.apache.flink.optimizer.operators.CrossBlockOuterFirstDescriptor
-
- CrossBlockOuterSecondDescriptor - Class in org.apache.flink.optimizer.operators
-
- CrossBlockOuterSecondDescriptor() - Constructor for class org.apache.flink.optimizer.operators.CrossBlockOuterSecondDescriptor
-
- CrossBlockOuterSecondDescriptor(boolean, boolean) - Constructor for class org.apache.flink.optimizer.operators.CrossBlockOuterSecondDescriptor
-
- CrossDriver<T1,T2,OT> - Class in org.apache.flink.runtime.operators
-
Cross task which is executed by a Task Manager.
- CrossDriver() - Constructor for class org.apache.flink.runtime.operators.CrossDriver
-
- CrossFunction<IN1,IN2,OUT> - Interface in org.apache.flink.api.common.functions
-
Interface for Cross functions.
- crossMatchingGroup(Iterator<T1>, Iterator<T2>, FlatJoinFunction<T1, T2, O>, Collector<O>) - Method in class org.apache.flink.runtime.operators.sort.AbstractMergeIterator
-
- CrossNode - Class in org.apache.flink.optimizer.dag
-
The Optimizer representation of a Cross (Cartesian product) operator.
- CrossNode(CrossOperatorBase<?, ?, ?, ?>) - Constructor for class org.apache.flink.optimizer.dag.CrossNode
-
Creates a new CrossNode for the given operator.
- CrossOperator<I1,I2,OUT> - Class in org.apache.flink.api.java.operators
-
A
DataSet
that is the result of a Cross transformation.
- CrossOperator(DataSet<I1>, DataSet<I2>, CrossFunction<I1, I2, OUT>, TypeInformation<OUT>, CrossOperatorBase.CrossHint, String) - Constructor for class org.apache.flink.api.java.operators.CrossOperator
-
- CrossOperator.CrossProjection<I1,I2> - Class in org.apache.flink.api.java.operators
-
- CrossOperator.DefaultCross<I1,I2> - Class in org.apache.flink.api.java.operators
-
A Cross transformation that wraps pairs of crossed elements into
Tuple2
.
- CrossOperator.ProjectCross<I1,I2,OUT extends Tuple> - Class in org.apache.flink.api.java.operators
-
A Cross transformation that projects crossing elements or fields of crossing
Tuples
into result
Tuples
.
- CrossOperator.ProjectCrossFunction<T1,T2,R extends Tuple> - Class in org.apache.flink.api.java.operators
-
- CrossOperatorBase<IN1,IN2,OUT,FT extends CrossFunction<IN1,IN2,OUT>> - Class in org.apache.flink.api.common.operators.base
-
- CrossOperatorBase(UserCodeWrapper<FT>, BinaryOperatorInformation<IN1, IN2, OUT>, String) - Constructor for class org.apache.flink.api.common.operators.base.CrossOperatorBase
-
- CrossOperatorBase(FT, BinaryOperatorInformation<IN1, IN2, OUT>, String) - Constructor for class org.apache.flink.api.common.operators.base.CrossOperatorBase
-
- CrossOperatorBase(Class<? extends FT>, BinaryOperatorInformation<IN1, IN2, OUT>, String) - Constructor for class org.apache.flink.api.common.operators.base.CrossOperatorBase
-
- CrossOperatorBase.CrossHint - Enum in org.apache.flink.api.common.operators.base
-
The cross hint tells the system which sizes to expect from the data sets
- CrossOperatorBase.CrossWithLarge - Interface in org.apache.flink.api.common.operators.base
-
Marker interface to declare the second input as the larger one.
- CrossOperatorBase.CrossWithSmall - Interface in org.apache.flink.api.common.operators.base
-
Marker interface to declare the second input as the smaller one.
- CrossProjection(DataSet<I1>, DataSet<I2>, int[], int[], CrossOperatorBase.CrossHint) - Constructor for class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
-
- CrossStreamOuterFirstDescriptor - Class in org.apache.flink.optimizer.operators
-
- CrossStreamOuterFirstDescriptor() - Constructor for class org.apache.flink.optimizer.operators.CrossStreamOuterFirstDescriptor
-
- CrossStreamOuterFirstDescriptor(boolean, boolean) - Constructor for class org.apache.flink.optimizer.operators.CrossStreamOuterFirstDescriptor
-
- CrossStreamOuterSecondDescriptor - Class in org.apache.flink.optimizer.operators
-
- CrossStreamOuterSecondDescriptor() - Constructor for class org.apache.flink.optimizer.operators.CrossStreamOuterSecondDescriptor
-
- CrossStreamOuterSecondDescriptor(boolean, boolean) - Constructor for class org.apache.flink.optimizer.operators.CrossStreamOuterSecondDescriptor
-
- crossWithHuge(DataSet<R>) - Method in class org.apache.flink.api.java.DataSet
-
Initiates a Cross transformation.
- crossWithTiny(DataSet<R>) - Method in class org.apache.flink.api.java.DataSet
-
Initiates a Cross transformation.
- CSV<K extends Comparable<K>> - Class in org.apache.flink.graph.drivers.input
-
- CSV() - Constructor for class org.apache.flink.graph.drivers.input.CSV
-
- CSV<T> - Class in org.apache.flink.graph.drivers.output
-
Write algorithm output to file using CSV format.
- CSV() - Constructor for class org.apache.flink.graph.drivers.output.CSV
-
- CsvInputFormat<OUT> - Class in org.apache.flink.api.java.io
-
InputFormat that reads csv files.
- CsvInputFormat(Path) - Constructor for class org.apache.flink.api.java.io.CsvInputFormat
-
- CsvOutputFormat<T extends Tuple> - Class in org.apache.flink.api.java.io
-
This is an OutputFormat to serialize
Tuple
s to text.
- CsvOutputFormat(Path) - Constructor for class org.apache.flink.api.java.io.CsvOutputFormat
-
Creates an instance of CsvOutputFormat.
- CsvOutputFormat(Path, String) - Constructor for class org.apache.flink.api.java.io.CsvOutputFormat
-
Creates an instance of CsvOutputFormat.
- CsvOutputFormat(Path, String, String) - Constructor for class org.apache.flink.api.java.io.CsvOutputFormat
-
Creates an instance of CsvOutputFormat.
- CsvReader - Class in org.apache.flink.api.java.io
-
A builder class to instantiate a CSV parsing data source.
- CsvReader(Path, ExecutionEnvironment) - Constructor for class org.apache.flink.api.java.io.CsvReader
-
- CsvReader(String, ExecutionEnvironment) - Constructor for class org.apache.flink.api.java.io.CsvReader
-
- cumulativeCosts - Variable in class org.apache.flink.optimizer.plan.PlanNode
-
- CUR_DIR - Static variable in class org.apache.flink.core.fs.Path
-
Character denoting the current directory.
- CURRENT_JOB_IDS_REST_PATH - Static variable in class org.apache.flink.runtime.rest.messages.JobIdsWithStatusesOverviewHeaders
-
- CURRENT_OFFSETS_METRICS_GAUGE - Static variable in class org.apache.flink.streaming.connectors.kafka.internals.metrics.KafkaConsumerMetricConstants
-
- currentEnumerator - Variable in class org.apache.flink.runtime.operators.hash.MutableHashTable
-
The channel enumerator that is used while processing the current partition to create
channels for the spill partitions it requires.
- currentFile - Variable in class org.apache.flink.streaming.connectors.fs.RollingSink.BucketState
-
Deprecated.
The file that was in-progress when the last checkpoint occurred.
- currentFileValidLength - Variable in class org.apache.flink.streaming.connectors.fs.RollingSink.BucketState
-
Deprecated.
The valid length of the in-progress file at the time of the last checkpoint.
- currentIteration() - Method in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
-
- CurrentJobIdsHandler - Class in org.apache.flink.runtime.rest.handler.legacy
-
Responder that returns with a list of all JobIDs of jobs found at the target actor.
- CurrentJobIdsHandler(Executor, Time) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.CurrentJobIdsHandler
-
- CurrentJobsOverviewJsonArchivist() - Constructor for class org.apache.flink.runtime.rest.handler.legacy.JobsOverviewHandler.CurrentJobsOverviewJsonArchivist
-
- currentKey - Variable in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
-
The currently active key.
- currentlyRegisteredTaskManagers() - Method in class org.apache.flink.runtime.clusterframework.messages.RegisterResourceManagerSuccessful
-
- currentNamespace - Variable in class org.apache.flink.runtime.state.heap.AbstractHeapState
-
The current namespace, which the access methods will refer to.
- currentProcessingTime() - Method in interface org.apache.flink.streaming.api.functions.sink.SinkFunction.Context
-
Returns the current processing time.
- currentProcessingTime() - Method in class org.apache.flink.streaming.api.functions.windowing.InternalProcessApplyWindowContext
-
- currentProcessingTime() - Method in class org.apache.flink.streaming.api.functions.windowing.ProcessWindowFunction.Context
-
Returns the current processing time.
- currentProcessingTime() - Method in class org.apache.flink.streaming.api.operators.HeapInternalTimerService
-
- currentProcessingTime() - Method in interface org.apache.flink.streaming.api.operators.InternalTimerService
-
Returns the current processing time.
- currentProcessingTime() - Method in class org.apache.flink.streaming.api.SimpleTimerService
-
- currentProcessingTime() - Method in interface org.apache.flink.streaming.api.TimerService
-
Returns the current processing time.
- currentProcessingTime() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalProcessWindowContext
-
- currentProcessingTime() - Method in interface org.apache.flink.streaming.runtime.operators.windowing.functions.InternalWindowFunction.InternalWindowContext
-
- currentProcessingTime() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.WindowContext
-
- currentRecursionDepth - Variable in class org.apache.flink.runtime.operators.hash.MutableHashTable
-
The recursion depth of the partition that is currently processed.
- currentRow - Variable in class org.apache.flink.addons.hbase.AbstractTableInputFormat
-
- currentSplit - Variable in class org.apache.flink.api.common.io.FileInputFormat
-
The current split that this parallel instance must consume.
- currentTimeMillis() - Method in interface org.apache.flink.streaming.connectors.fs.Clock
-
Return the current system time in milliseconds.
- currentTimeMillis() - Method in class org.apache.flink.streaming.connectors.fs.SystemClock
-
- currentTransaction() - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
-
- currentWatermark() - Method in interface org.apache.flink.streaming.api.functions.sink.SinkFunction.Context
-
Returns the current event-time watermark.
- currentWatermark() - Method in class org.apache.flink.streaming.api.functions.windowing.InternalProcessApplyWindowContext
-
- currentWatermark() - Method in class org.apache.flink.streaming.api.functions.windowing.ProcessWindowFunction.Context
-
Returns the current event-time watermark.
- currentWatermark() - Method in class org.apache.flink.streaming.api.operators.HeapInternalTimerService
-
- currentWatermark() - Method in interface org.apache.flink.streaming.api.operators.InternalTimerService
-
Returns the current event-time watermark.
- currentWatermark() - Method in class org.apache.flink.streaming.api.SimpleTimerService
-
- currentWatermark() - Method in interface org.apache.flink.streaming.api.TimerService
-
Returns the current event-time watermark.
- currentWatermark() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalProcessWindowContext
-
- currentWatermark() - Method in interface org.apache.flink.streaming.runtime.operators.windowing.functions.InternalWindowFunction.InternalWindowContext
-
- currentWatermark() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.WindowContext
-
- CustomCommandLine<T> - Interface in org.apache.flink.client.cli
-
Custom command-line interface to load hooks for the command-line interface.
- Customer() - Constructor for class org.apache.flink.examples.java.relational.TPCHQuery3.Customer
-
- customPartitioner - Variable in class org.apache.flink.api.java.operators.Grouping
-
- CustomPartitionerWrapper<K,T> - Class in org.apache.flink.streaming.runtime.partitioner
-
Partitioner that selects the channel with a user defined partitioner function on a key.
- CustomPartitionerWrapper(Partitioner<K>, KeySelector<T, K>) - Constructor for class org.apache.flink.streaming.runtime.partitioner.CustomPartitionerWrapper
-
- CustomTypeWrapper - Class in org.apache.flink.python.api.types
-
Container for serialized python objects, generally assumed to be custom objects.
- CustomTypeWrapper(byte, byte[]) - Constructor for class org.apache.flink.python.api.types.CustomTypeWrapper
-
- CustomTypeWrapperSerializer(CustomTypeWrapper) - Constructor for class org.apache.flink.python.api.streaming.util.SerializationUtils.CustomTypeWrapperSerializer
-
- CustomUnaryOperation<IN,OUT> - Interface in org.apache.flink.api.java.operators
-
- CycleGraph - Class in org.apache.flink.graph.drivers.input
-
- CycleGraph() - Constructor for class org.apache.flink.graph.drivers.input.CycleGraph
-
- CycleGraph - Class in org.apache.flink.graph.generator
-
- CycleGraph(ExecutionEnvironment, long) - Constructor for class org.apache.flink.graph.generator.CycleGraph
-
An undirected
Graph
with
n
vertices where each vertex
v
i is connected to adjacent vertices v
(i+1)%n and
v
(i-1)%n.
- f0 - Variable in class org.apache.flink.api.java.tuple.Tuple1
-
Field 0 of the tuple.
- f0 - Variable in class org.apache.flink.api.java.tuple.Tuple10
-
Field 0 of the tuple.
- f0 - Variable in class org.apache.flink.api.java.tuple.Tuple11
-
Field 0 of the tuple.
- f0 - Variable in class org.apache.flink.api.java.tuple.Tuple12
-
Field 0 of the tuple.
- f0 - Variable in class org.apache.flink.api.java.tuple.Tuple13
-
Field 0 of the tuple.
- f0 - Variable in class org.apache.flink.api.java.tuple.Tuple14
-
Field 0 of the tuple.
- f0 - Variable in class org.apache.flink.api.java.tuple.Tuple15
-
Field 0 of the tuple.
- f0 - Variable in class org.apache.flink.api.java.tuple.Tuple16
-
Field 0 of the tuple.
- f0 - Variable in class org.apache.flink.api.java.tuple.Tuple17
-
Field 0 of the tuple.
- f0 - Variable in class org.apache.flink.api.java.tuple.Tuple18
-
Field 0 of the tuple.
- f0 - Variable in class org.apache.flink.api.java.tuple.Tuple19
-
Field 0 of the tuple.
- f0 - Variable in class org.apache.flink.api.java.tuple.Tuple2
-
Field 0 of the tuple.
- f0 - Variable in class org.apache.flink.api.java.tuple.Tuple20
-
Field 0 of the tuple.
- f0 - Variable in class org.apache.flink.api.java.tuple.Tuple21
-
Field 0 of the tuple.
- f0 - Variable in class org.apache.flink.api.java.tuple.Tuple22
-
Field 0 of the tuple.
- f0 - Variable in class org.apache.flink.api.java.tuple.Tuple23
-
Field 0 of the tuple.
- f0 - Variable in class org.apache.flink.api.java.tuple.Tuple24
-
Field 0 of the tuple.
- f0 - Variable in class org.apache.flink.api.java.tuple.Tuple25
-
Field 0 of the tuple.
- f0 - Variable in class org.apache.flink.api.java.tuple.Tuple3
-
Field 0 of the tuple.
- f0 - Variable in class org.apache.flink.api.java.tuple.Tuple4
-
Field 0 of the tuple.
- f0 - Variable in class org.apache.flink.api.java.tuple.Tuple5
-
Field 0 of the tuple.
- f0 - Variable in class org.apache.flink.api.java.tuple.Tuple6
-
Field 0 of the tuple.
- f0 - Variable in class org.apache.flink.api.java.tuple.Tuple7
-
Field 0 of the tuple.
- f0 - Variable in class org.apache.flink.api.java.tuple.Tuple8
-
Field 0 of the tuple.
- f0 - Variable in class org.apache.flink.api.java.tuple.Tuple9
-
Field 0 of the tuple.
- f1 - Variable in class org.apache.flink.api.java.tuple.Tuple10
-
Field 1 of the tuple.
- f1 - Variable in class org.apache.flink.api.java.tuple.Tuple11
-
Field 1 of the tuple.
- f1 - Variable in class org.apache.flink.api.java.tuple.Tuple12
-
Field 1 of the tuple.
- f1 - Variable in class org.apache.flink.api.java.tuple.Tuple13
-
Field 1 of the tuple.
- f1 - Variable in class org.apache.flink.api.java.tuple.Tuple14
-
Field 1 of the tuple.
- f1 - Variable in class org.apache.flink.api.java.tuple.Tuple15
-
Field 1 of the tuple.
- f1 - Variable in class org.apache.flink.api.java.tuple.Tuple16
-
Field 1 of the tuple.
- f1 - Variable in class org.apache.flink.api.java.tuple.Tuple17
-
Field 1 of the tuple.
- f1 - Variable in class org.apache.flink.api.java.tuple.Tuple18
-
Field 1 of the tuple.
- f1 - Variable in class org.apache.flink.api.java.tuple.Tuple19
-
Field 1 of the tuple.
- f1 - Variable in class org.apache.flink.api.java.tuple.Tuple2
-
Field 1 of the tuple.
- f1 - Variable in class org.apache.flink.api.java.tuple.Tuple20
-
Field 1 of the tuple.
- f1 - Variable in class org.apache.flink.api.java.tuple.Tuple21
-
Field 1 of the tuple.
- f1 - Variable in class org.apache.flink.api.java.tuple.Tuple22
-
Field 1 of the tuple.
- f1 - Variable in class org.apache.flink.api.java.tuple.Tuple23
-
Field 1 of the tuple.
- f1 - Variable in class org.apache.flink.api.java.tuple.Tuple24
-
Field 1 of the tuple.
- f1 - Variable in class org.apache.flink.api.java.tuple.Tuple25
-
Field 1 of the tuple.
- f1 - Variable in class org.apache.flink.api.java.tuple.Tuple3
-
Field 1 of the tuple.
- f1 - Variable in class org.apache.flink.api.java.tuple.Tuple4
-
Field 1 of the tuple.
- f1 - Variable in class org.apache.flink.api.java.tuple.Tuple5
-
Field 1 of the tuple.
- f1 - Variable in class org.apache.flink.api.java.tuple.Tuple6
-
Field 1 of the tuple.
- f1 - Variable in class org.apache.flink.api.java.tuple.Tuple7
-
Field 1 of the tuple.
- f1 - Variable in class org.apache.flink.api.java.tuple.Tuple8
-
Field 1 of the tuple.
- f1 - Variable in class org.apache.flink.api.java.tuple.Tuple9
-
Field 1 of the tuple.
- f10 - Variable in class org.apache.flink.api.java.tuple.Tuple11
-
Field 10 of the tuple.
- f10 - Variable in class org.apache.flink.api.java.tuple.Tuple12
-
Field 10 of the tuple.
- f10 - Variable in class org.apache.flink.api.java.tuple.Tuple13
-
Field 10 of the tuple.
- f10 - Variable in class org.apache.flink.api.java.tuple.Tuple14
-
Field 10 of the tuple.
- f10 - Variable in class org.apache.flink.api.java.tuple.Tuple15
-
Field 10 of the tuple.
- f10 - Variable in class org.apache.flink.api.java.tuple.Tuple16
-
Field 10 of the tuple.
- f10 - Variable in class org.apache.flink.api.java.tuple.Tuple17
-
Field 10 of the tuple.
- f10 - Variable in class org.apache.flink.api.java.tuple.Tuple18
-
Field 10 of the tuple.
- f10 - Variable in class org.apache.flink.api.java.tuple.Tuple19
-
Field 10 of the tuple.
- f10 - Variable in class org.apache.flink.api.java.tuple.Tuple20
-
Field 10 of the tuple.
- f10 - Variable in class org.apache.flink.api.java.tuple.Tuple21
-
Field 10 of the tuple.
- f10 - Variable in class org.apache.flink.api.java.tuple.Tuple22
-
Field 10 of the tuple.
- f10 - Variable in class org.apache.flink.api.java.tuple.Tuple23
-
Field 10 of the tuple.
- f10 - Variable in class org.apache.flink.api.java.tuple.Tuple24
-
Field 10 of the tuple.
- f10 - Variable in class org.apache.flink.api.java.tuple.Tuple25
-
Field 10 of the tuple.
- f11 - Variable in class org.apache.flink.api.java.tuple.Tuple12
-
Field 11 of the tuple.
- f11 - Variable in class org.apache.flink.api.java.tuple.Tuple13
-
Field 11 of the tuple.
- f11 - Variable in class org.apache.flink.api.java.tuple.Tuple14
-
Field 11 of the tuple.
- f11 - Variable in class org.apache.flink.api.java.tuple.Tuple15
-
Field 11 of the tuple.
- f11 - Variable in class org.apache.flink.api.java.tuple.Tuple16
-
Field 11 of the tuple.
- f11 - Variable in class org.apache.flink.api.java.tuple.Tuple17
-
Field 11 of the tuple.
- f11 - Variable in class org.apache.flink.api.java.tuple.Tuple18
-
Field 11 of the tuple.
- f11 - Variable in class org.apache.flink.api.java.tuple.Tuple19
-
Field 11 of the tuple.
- f11 - Variable in class org.apache.flink.api.java.tuple.Tuple20
-
Field 11 of the tuple.
- f11 - Variable in class org.apache.flink.api.java.tuple.Tuple21
-
Field 11 of the tuple.
- f11 - Variable in class org.apache.flink.api.java.tuple.Tuple22
-
Field 11 of the tuple.
- f11 - Variable in class org.apache.flink.api.java.tuple.Tuple23
-
Field 11 of the tuple.
- f11 - Variable in class org.apache.flink.api.java.tuple.Tuple24
-
Field 11 of the tuple.
- f11 - Variable in class org.apache.flink.api.java.tuple.Tuple25
-
Field 11 of the tuple.
- f12 - Variable in class org.apache.flink.api.java.tuple.Tuple13
-
Field 12 of the tuple.
- f12 - Variable in class org.apache.flink.api.java.tuple.Tuple14
-
Field 12 of the tuple.
- f12 - Variable in class org.apache.flink.api.java.tuple.Tuple15
-
Field 12 of the tuple.
- f12 - Variable in class org.apache.flink.api.java.tuple.Tuple16
-
Field 12 of the tuple.
- f12 - Variable in class org.apache.flink.api.java.tuple.Tuple17
-
Field 12 of the tuple.
- f12 - Variable in class org.apache.flink.api.java.tuple.Tuple18
-
Field 12 of the tuple.
- f12 - Variable in class org.apache.flink.api.java.tuple.Tuple19
-
Field 12 of the tuple.
- f12 - Variable in class org.apache.flink.api.java.tuple.Tuple20
-
Field 12 of the tuple.
- f12 - Variable in class org.apache.flink.api.java.tuple.Tuple21
-
Field 12 of the tuple.
- f12 - Variable in class org.apache.flink.api.java.tuple.Tuple22
-
Field 12 of the tuple.
- f12 - Variable in class org.apache.flink.api.java.tuple.Tuple23
-
Field 12 of the tuple.
- f12 - Variable in class org.apache.flink.api.java.tuple.Tuple24
-
Field 12 of the tuple.
- f12 - Variable in class org.apache.flink.api.java.tuple.Tuple25
-
Field 12 of the tuple.
- f13 - Variable in class org.apache.flink.api.java.tuple.Tuple14
-
Field 13 of the tuple.
- f13 - Variable in class org.apache.flink.api.java.tuple.Tuple15
-
Field 13 of the tuple.
- f13 - Variable in class org.apache.flink.api.java.tuple.Tuple16
-
Field 13 of the tuple.
- f13 - Variable in class org.apache.flink.api.java.tuple.Tuple17
-
Field 13 of the tuple.
- f13 - Variable in class org.apache.flink.api.java.tuple.Tuple18
-
Field 13 of the tuple.
- f13 - Variable in class org.apache.flink.api.java.tuple.Tuple19
-
Field 13 of the tuple.
- f13 - Variable in class org.apache.flink.api.java.tuple.Tuple20
-
Field 13 of the tuple.
- f13 - Variable in class org.apache.flink.api.java.tuple.Tuple21
-
Field 13 of the tuple.
- f13 - Variable in class org.apache.flink.api.java.tuple.Tuple22
-
Field 13 of the tuple.
- f13 - Variable in class org.apache.flink.api.java.tuple.Tuple23
-
Field 13 of the tuple.
- f13 - Variable in class org.apache.flink.api.java.tuple.Tuple24
-
Field 13 of the tuple.
- f13 - Variable in class org.apache.flink.api.java.tuple.Tuple25
-
Field 13 of the tuple.
- f14 - Variable in class org.apache.flink.api.java.tuple.Tuple15
-
Field 14 of the tuple.
- f14 - Variable in class org.apache.flink.api.java.tuple.Tuple16
-
Field 14 of the tuple.
- f14 - Variable in class org.apache.flink.api.java.tuple.Tuple17
-
Field 14 of the tuple.
- f14 - Variable in class org.apache.flink.api.java.tuple.Tuple18
-
Field 14 of the tuple.
- f14 - Variable in class org.apache.flink.api.java.tuple.Tuple19
-
Field 14 of the tuple.
- f14 - Variable in class org.apache.flink.api.java.tuple.Tuple20
-
Field 14 of the tuple.
- f14 - Variable in class org.apache.flink.api.java.tuple.Tuple21
-
Field 14 of the tuple.
- f14 - Variable in class org.apache.flink.api.java.tuple.Tuple22
-
Field 14 of the tuple.
- f14 - Variable in class org.apache.flink.api.java.tuple.Tuple23
-
Field 14 of the tuple.
- f14 - Variable in class org.apache.flink.api.java.tuple.Tuple24
-
Field 14 of the tuple.
- f14 - Variable in class org.apache.flink.api.java.tuple.Tuple25
-
Field 14 of the tuple.
- f15 - Variable in class org.apache.flink.api.java.tuple.Tuple16
-
Field 15 of the tuple.
- f15 - Variable in class org.apache.flink.api.java.tuple.Tuple17
-
Field 15 of the tuple.
- f15 - Variable in class org.apache.flink.api.java.tuple.Tuple18
-
Field 15 of the tuple.
- f15 - Variable in class org.apache.flink.api.java.tuple.Tuple19
-
Field 15 of the tuple.
- f15 - Variable in class org.apache.flink.api.java.tuple.Tuple20
-
Field 15 of the tuple.
- f15 - Variable in class org.apache.flink.api.java.tuple.Tuple21
-
Field 15 of the tuple.
- f15 - Variable in class org.apache.flink.api.java.tuple.Tuple22
-
Field 15 of the tuple.
- f15 - Variable in class org.apache.flink.api.java.tuple.Tuple23
-
Field 15 of the tuple.
- f15 - Variable in class org.apache.flink.api.java.tuple.Tuple24
-
Field 15 of the tuple.
- f15 - Variable in class org.apache.flink.api.java.tuple.Tuple25
-
Field 15 of the tuple.
- f16 - Variable in class org.apache.flink.api.java.tuple.Tuple17
-
Field 16 of the tuple.
- f16 - Variable in class org.apache.flink.api.java.tuple.Tuple18
-
Field 16 of the tuple.
- f16 - Variable in class org.apache.flink.api.java.tuple.Tuple19
-
Field 16 of the tuple.
- f16 - Variable in class org.apache.flink.api.java.tuple.Tuple20
-
Field 16 of the tuple.
- f16 - Variable in class org.apache.flink.api.java.tuple.Tuple21
-
Field 16 of the tuple.
- f16 - Variable in class org.apache.flink.api.java.tuple.Tuple22
-
Field 16 of the tuple.
- f16 - Variable in class org.apache.flink.api.java.tuple.Tuple23
-
Field 16 of the tuple.
- f16 - Variable in class org.apache.flink.api.java.tuple.Tuple24
-
Field 16 of the tuple.
- f16 - Variable in class org.apache.flink.api.java.tuple.Tuple25
-
Field 16 of the tuple.
- f17 - Variable in class org.apache.flink.api.java.tuple.Tuple18
-
Field 17 of the tuple.
- f17 - Variable in class org.apache.flink.api.java.tuple.Tuple19
-
Field 17 of the tuple.
- f17 - Variable in class org.apache.flink.api.java.tuple.Tuple20
-
Field 17 of the tuple.
- f17 - Variable in class org.apache.flink.api.java.tuple.Tuple21
-
Field 17 of the tuple.
- f17 - Variable in class org.apache.flink.api.java.tuple.Tuple22
-
Field 17 of the tuple.
- f17 - Variable in class org.apache.flink.api.java.tuple.Tuple23
-
Field 17 of the tuple.
- f17 - Variable in class org.apache.flink.api.java.tuple.Tuple24
-
Field 17 of the tuple.
- f17 - Variable in class org.apache.flink.api.java.tuple.Tuple25
-
Field 17 of the tuple.
- f18 - Variable in class org.apache.flink.api.java.tuple.Tuple19
-
Field 18 of the tuple.
- f18 - Variable in class org.apache.flink.api.java.tuple.Tuple20
-
Field 18 of the tuple.
- f18 - Variable in class org.apache.flink.api.java.tuple.Tuple21
-
Field 18 of the tuple.
- f18 - Variable in class org.apache.flink.api.java.tuple.Tuple22
-
Field 18 of the tuple.
- f18 - Variable in class org.apache.flink.api.java.tuple.Tuple23
-
Field 18 of the tuple.
- f18 - Variable in class org.apache.flink.api.java.tuple.Tuple24
-
Field 18 of the tuple.
- f18 - Variable in class org.apache.flink.api.java.tuple.Tuple25
-
Field 18 of the tuple.
- f19 - Variable in class org.apache.flink.api.java.tuple.Tuple20
-
Field 19 of the tuple.
- f19 - Variable in class org.apache.flink.api.java.tuple.Tuple21
-
Field 19 of the tuple.
- f19 - Variable in class org.apache.flink.api.java.tuple.Tuple22
-
Field 19 of the tuple.
- f19 - Variable in class org.apache.flink.api.java.tuple.Tuple23
-
Field 19 of the tuple.
- f19 - Variable in class org.apache.flink.api.java.tuple.Tuple24
-
Field 19 of the tuple.
- f19 - Variable in class org.apache.flink.api.java.tuple.Tuple25
-
Field 19 of the tuple.
- f2 - Variable in class org.apache.flink.api.java.tuple.Tuple10
-
Field 2 of the tuple.
- f2 - Variable in class org.apache.flink.api.java.tuple.Tuple11
-
Field 2 of the tuple.
- f2 - Variable in class org.apache.flink.api.java.tuple.Tuple12
-
Field 2 of the tuple.
- f2 - Variable in class org.apache.flink.api.java.tuple.Tuple13
-
Field 2 of the tuple.
- f2 - Variable in class org.apache.flink.api.java.tuple.Tuple14
-
Field 2 of the tuple.
- f2 - Variable in class org.apache.flink.api.java.tuple.Tuple15
-
Field 2 of the tuple.
- f2 - Variable in class org.apache.flink.api.java.tuple.Tuple16
-
Field 2 of the tuple.
- f2 - Variable in class org.apache.flink.api.java.tuple.Tuple17
-
Field 2 of the tuple.
- f2 - Variable in class org.apache.flink.api.java.tuple.Tuple18
-
Field 2 of the tuple.
- f2 - Variable in class org.apache.flink.api.java.tuple.Tuple19
-
Field 2 of the tuple.
- f2 - Variable in class org.apache.flink.api.java.tuple.Tuple20
-
Field 2 of the tuple.
- f2 - Variable in class org.apache.flink.api.java.tuple.Tuple21
-
Field 2 of the tuple.
- f2 - Variable in class org.apache.flink.api.java.tuple.Tuple22
-
Field 2 of the tuple.
- f2 - Variable in class org.apache.flink.api.java.tuple.Tuple23
-
Field 2 of the tuple.
- f2 - Variable in class org.apache.flink.api.java.tuple.Tuple24
-
Field 2 of the tuple.
- f2 - Variable in class org.apache.flink.api.java.tuple.Tuple25
-
Field 2 of the tuple.
- f2 - Variable in class org.apache.flink.api.java.tuple.Tuple3
-
Field 2 of the tuple.
- f2 - Variable in class org.apache.flink.api.java.tuple.Tuple4
-
Field 2 of the tuple.
- f2 - Variable in class org.apache.flink.api.java.tuple.Tuple5
-
Field 2 of the tuple.
- f2 - Variable in class org.apache.flink.api.java.tuple.Tuple6
-
Field 2 of the tuple.
- f2 - Variable in class org.apache.flink.api.java.tuple.Tuple7
-
Field 2 of the tuple.
- f2 - Variable in class org.apache.flink.api.java.tuple.Tuple8
-
Field 2 of the tuple.
- f2 - Variable in class org.apache.flink.api.java.tuple.Tuple9
-
Field 2 of the tuple.
- f20 - Variable in class org.apache.flink.api.java.tuple.Tuple21
-
Field 20 of the tuple.
- f20 - Variable in class org.apache.flink.api.java.tuple.Tuple22
-
Field 20 of the tuple.
- f20 - Variable in class org.apache.flink.api.java.tuple.Tuple23
-
Field 20 of the tuple.
- f20 - Variable in class org.apache.flink.api.java.tuple.Tuple24
-
Field 20 of the tuple.
- f20 - Variable in class org.apache.flink.api.java.tuple.Tuple25
-
Field 20 of the tuple.
- f21 - Variable in class org.apache.flink.api.java.tuple.Tuple22
-
Field 21 of the tuple.
- f21 - Variable in class org.apache.flink.api.java.tuple.Tuple23
-
Field 21 of the tuple.
- f21 - Variable in class org.apache.flink.api.java.tuple.Tuple24
-
Field 21 of the tuple.
- f21 - Variable in class org.apache.flink.api.java.tuple.Tuple25
-
Field 21 of the tuple.
- f22 - Variable in class org.apache.flink.api.java.tuple.Tuple23
-
Field 22 of the tuple.
- f22 - Variable in class org.apache.flink.api.java.tuple.Tuple24
-
Field 22 of the tuple.
- f22 - Variable in class org.apache.flink.api.java.tuple.Tuple25
-
Field 22 of the tuple.
- f23 - Variable in class org.apache.flink.api.java.tuple.Tuple24
-
Field 23 of the tuple.
- f23 - Variable in class org.apache.flink.api.java.tuple.Tuple25
-
Field 23 of the tuple.
- f24 - Variable in class org.apache.flink.api.java.tuple.Tuple25
-
Field 24 of the tuple.
- f3 - Variable in class org.apache.flink.api.java.tuple.Tuple10
-
Field 3 of the tuple.
- f3 - Variable in class org.apache.flink.api.java.tuple.Tuple11
-
Field 3 of the tuple.
- f3 - Variable in class org.apache.flink.api.java.tuple.Tuple12
-
Field 3 of the tuple.
- f3 - Variable in class org.apache.flink.api.java.tuple.Tuple13
-
Field 3 of the tuple.
- f3 - Variable in class org.apache.flink.api.java.tuple.Tuple14
-
Field 3 of the tuple.
- f3 - Variable in class org.apache.flink.api.java.tuple.Tuple15
-
Field 3 of the tuple.
- f3 - Variable in class org.apache.flink.api.java.tuple.Tuple16
-
Field 3 of the tuple.
- f3 - Variable in class org.apache.flink.api.java.tuple.Tuple17
-
Field 3 of the tuple.
- f3 - Variable in class org.apache.flink.api.java.tuple.Tuple18
-
Field 3 of the tuple.
- f3 - Variable in class org.apache.flink.api.java.tuple.Tuple19
-
Field 3 of the tuple.
- f3 - Variable in class org.apache.flink.api.java.tuple.Tuple20
-
Field 3 of the tuple.
- f3 - Variable in class org.apache.flink.api.java.tuple.Tuple21
-
Field 3 of the tuple.
- f3 - Variable in class org.apache.flink.api.java.tuple.Tuple22
-
Field 3 of the tuple.
- f3 - Variable in class org.apache.flink.api.java.tuple.Tuple23
-
Field 3 of the tuple.
- f3 - Variable in class org.apache.flink.api.java.tuple.Tuple24
-
Field 3 of the tuple.
- f3 - Variable in class org.apache.flink.api.java.tuple.Tuple25
-
Field 3 of the tuple.
- f3 - Variable in class org.apache.flink.api.java.tuple.Tuple4
-
Field 3 of the tuple.
- f3 - Variable in class org.apache.flink.api.java.tuple.Tuple5
-
Field 3 of the tuple.
- f3 - Variable in class org.apache.flink.api.java.tuple.Tuple6
-
Field 3 of the tuple.
- f3 - Variable in class org.apache.flink.api.java.tuple.Tuple7
-
Field 3 of the tuple.
- f3 - Variable in class org.apache.flink.api.java.tuple.Tuple8
-
Field 3 of the tuple.
- f3 - Variable in class org.apache.flink.api.java.tuple.Tuple9
-
Field 3 of the tuple.
- f4 - Variable in class org.apache.flink.api.java.tuple.Tuple10
-
Field 4 of the tuple.
- f4 - Variable in class org.apache.flink.api.java.tuple.Tuple11
-
Field 4 of the tuple.
- f4 - Variable in class org.apache.flink.api.java.tuple.Tuple12
-
Field 4 of the tuple.
- f4 - Variable in class org.apache.flink.api.java.tuple.Tuple13
-
Field 4 of the tuple.
- f4 - Variable in class org.apache.flink.api.java.tuple.Tuple14
-
Field 4 of the tuple.
- f4 - Variable in class org.apache.flink.api.java.tuple.Tuple15
-
Field 4 of the tuple.
- f4 - Variable in class org.apache.flink.api.java.tuple.Tuple16
-
Field 4 of the tuple.
- f4 - Variable in class org.apache.flink.api.java.tuple.Tuple17
-
Field 4 of the tuple.
- f4 - Variable in class org.apache.flink.api.java.tuple.Tuple18
-
Field 4 of the tuple.
- f4 - Variable in class org.apache.flink.api.java.tuple.Tuple19
-
Field 4 of the tuple.
- f4 - Variable in class org.apache.flink.api.java.tuple.Tuple20
-
Field 4 of the tuple.
- f4 - Variable in class org.apache.flink.api.java.tuple.Tuple21
-
Field 4 of the tuple.
- f4 - Variable in class org.apache.flink.api.java.tuple.Tuple22
-
Field 4 of the tuple.
- f4 - Variable in class org.apache.flink.api.java.tuple.Tuple23
-
Field 4 of the tuple.
- f4 - Variable in class org.apache.flink.api.java.tuple.Tuple24
-
Field 4 of the tuple.
- f4 - Variable in class org.apache.flink.api.java.tuple.Tuple25
-
Field 4 of the tuple.
- f4 - Variable in class org.apache.flink.api.java.tuple.Tuple5
-
Field 4 of the tuple.
- f4 - Variable in class org.apache.flink.api.java.tuple.Tuple6
-
Field 4 of the tuple.
- f4 - Variable in class org.apache.flink.api.java.tuple.Tuple7
-
Field 4 of the tuple.
- f4 - Variable in class org.apache.flink.api.java.tuple.Tuple8
-
Field 4 of the tuple.
- f4 - Variable in class org.apache.flink.api.java.tuple.Tuple9
-
Field 4 of the tuple.
- f5 - Variable in class org.apache.flink.api.java.tuple.Tuple10
-
Field 5 of the tuple.
- f5 - Variable in class org.apache.flink.api.java.tuple.Tuple11
-
Field 5 of the tuple.
- f5 - Variable in class org.apache.flink.api.java.tuple.Tuple12
-
Field 5 of the tuple.
- f5 - Variable in class org.apache.flink.api.java.tuple.Tuple13
-
Field 5 of the tuple.
- f5 - Variable in class org.apache.flink.api.java.tuple.Tuple14
-
Field 5 of the tuple.
- f5 - Variable in class org.apache.flink.api.java.tuple.Tuple15
-
Field 5 of the tuple.
- f5 - Variable in class org.apache.flink.api.java.tuple.Tuple16
-
Field 5 of the tuple.
- f5 - Variable in class org.apache.flink.api.java.tuple.Tuple17
-
Field 5 of the tuple.
- f5 - Variable in class org.apache.flink.api.java.tuple.Tuple18
-
Field 5 of the tuple.
- f5 - Variable in class org.apache.flink.api.java.tuple.Tuple19
-
Field 5 of the tuple.
- f5 - Variable in class org.apache.flink.api.java.tuple.Tuple20
-
Field 5 of the tuple.
- f5 - Variable in class org.apache.flink.api.java.tuple.Tuple21
-
Field 5 of the tuple.
- f5 - Variable in class org.apache.flink.api.java.tuple.Tuple22
-
Field 5 of the tuple.
- f5 - Variable in class org.apache.flink.api.java.tuple.Tuple23
-
Field 5 of the tuple.
- f5 - Variable in class org.apache.flink.api.java.tuple.Tuple24
-
Field 5 of the tuple.
- f5 - Variable in class org.apache.flink.api.java.tuple.Tuple25
-
Field 5 of the tuple.
- f5 - Variable in class org.apache.flink.api.java.tuple.Tuple6
-
Field 5 of the tuple.
- f5 - Variable in class org.apache.flink.api.java.tuple.Tuple7
-
Field 5 of the tuple.
- f5 - Variable in class org.apache.flink.api.java.tuple.Tuple8
-
Field 5 of the tuple.
- f5 - Variable in class org.apache.flink.api.java.tuple.Tuple9
-
Field 5 of the tuple.
- f6 - Variable in class org.apache.flink.api.java.tuple.Tuple10
-
Field 6 of the tuple.
- f6 - Variable in class org.apache.flink.api.java.tuple.Tuple11
-
Field 6 of the tuple.
- f6 - Variable in class org.apache.flink.api.java.tuple.Tuple12
-
Field 6 of the tuple.
- f6 - Variable in class org.apache.flink.api.java.tuple.Tuple13
-
Field 6 of the tuple.
- f6 - Variable in class org.apache.flink.api.java.tuple.Tuple14
-
Field 6 of the tuple.
- f6 - Variable in class org.apache.flink.api.java.tuple.Tuple15
-
Field 6 of the tuple.
- f6 - Variable in class org.apache.flink.api.java.tuple.Tuple16
-
Field 6 of the tuple.
- f6 - Variable in class org.apache.flink.api.java.tuple.Tuple17
-
Field 6 of the tuple.
- f6 - Variable in class org.apache.flink.api.java.tuple.Tuple18
-
Field 6 of the tuple.
- f6 - Variable in class org.apache.flink.api.java.tuple.Tuple19
-
Field 6 of the tuple.
- f6 - Variable in class org.apache.flink.api.java.tuple.Tuple20
-
Field 6 of the tuple.
- f6 - Variable in class org.apache.flink.api.java.tuple.Tuple21
-
Field 6 of the tuple.
- f6 - Variable in class org.apache.flink.api.java.tuple.Tuple22
-
Field 6 of the tuple.
- f6 - Variable in class org.apache.flink.api.java.tuple.Tuple23
-
Field 6 of the tuple.
- f6 - Variable in class org.apache.flink.api.java.tuple.Tuple24
-
Field 6 of the tuple.
- f6 - Variable in class org.apache.flink.api.java.tuple.Tuple25
-
Field 6 of the tuple.
- f6 - Variable in class org.apache.flink.api.java.tuple.Tuple7
-
Field 6 of the tuple.
- f6 - Variable in class org.apache.flink.api.java.tuple.Tuple8
-
Field 6 of the tuple.
- f6 - Variable in class org.apache.flink.api.java.tuple.Tuple9
-
Field 6 of the tuple.
- f7 - Variable in class org.apache.flink.api.java.tuple.Tuple10
-
Field 7 of the tuple.
- f7 - Variable in class org.apache.flink.api.java.tuple.Tuple11
-
Field 7 of the tuple.
- f7 - Variable in class org.apache.flink.api.java.tuple.Tuple12
-
Field 7 of the tuple.
- f7 - Variable in class org.apache.flink.api.java.tuple.Tuple13
-
Field 7 of the tuple.
- f7 - Variable in class org.apache.flink.api.java.tuple.Tuple14
-
Field 7 of the tuple.
- f7 - Variable in class org.apache.flink.api.java.tuple.Tuple15
-
Field 7 of the tuple.
- f7 - Variable in class org.apache.flink.api.java.tuple.Tuple16
-
Field 7 of the tuple.
- f7 - Variable in class org.apache.flink.api.java.tuple.Tuple17
-
Field 7 of the tuple.
- f7 - Variable in class org.apache.flink.api.java.tuple.Tuple18
-
Field 7 of the tuple.
- f7 - Variable in class org.apache.flink.api.java.tuple.Tuple19
-
Field 7 of the tuple.
- f7 - Variable in class org.apache.flink.api.java.tuple.Tuple20
-
Field 7 of the tuple.
- f7 - Variable in class org.apache.flink.api.java.tuple.Tuple21
-
Field 7 of the tuple.
- f7 - Variable in class org.apache.flink.api.java.tuple.Tuple22
-
Field 7 of the tuple.
- f7 - Variable in class org.apache.flink.api.java.tuple.Tuple23
-
Field 7 of the tuple.
- f7 - Variable in class org.apache.flink.api.java.tuple.Tuple24
-
Field 7 of the tuple.
- f7 - Variable in class org.apache.flink.api.java.tuple.Tuple25
-
Field 7 of the tuple.
- f7 - Variable in class org.apache.flink.api.java.tuple.Tuple8
-
Field 7 of the tuple.
- f7 - Variable in class org.apache.flink.api.java.tuple.Tuple9
-
Field 7 of the tuple.
- f8 - Variable in class org.apache.flink.api.java.tuple.Tuple10
-
Field 8 of the tuple.
- f8 - Variable in class org.apache.flink.api.java.tuple.Tuple11
-
Field 8 of the tuple.
- f8 - Variable in class org.apache.flink.api.java.tuple.Tuple12
-
Field 8 of the tuple.
- f8 - Variable in class org.apache.flink.api.java.tuple.Tuple13
-
Field 8 of the tuple.
- f8 - Variable in class org.apache.flink.api.java.tuple.Tuple14
-
Field 8 of the tuple.
- f8 - Variable in class org.apache.flink.api.java.tuple.Tuple15
-
Field 8 of the tuple.
- f8 - Variable in class org.apache.flink.api.java.tuple.Tuple16
-
Field 8 of the tuple.
- f8 - Variable in class org.apache.flink.api.java.tuple.Tuple17
-
Field 8 of the tuple.
- f8 - Variable in class org.apache.flink.api.java.tuple.Tuple18
-
Field 8 of the tuple.
- f8 - Variable in class org.apache.flink.api.java.tuple.Tuple19
-
Field 8 of the tuple.
- f8 - Variable in class org.apache.flink.api.java.tuple.Tuple20
-
Field 8 of the tuple.
- f8 - Variable in class org.apache.flink.api.java.tuple.Tuple21
-
Field 8 of the tuple.
- f8 - Variable in class org.apache.flink.api.java.tuple.Tuple22
-
Field 8 of the tuple.
- f8 - Variable in class org.apache.flink.api.java.tuple.Tuple23
-
Field 8 of the tuple.
- f8 - Variable in class org.apache.flink.api.java.tuple.Tuple24
-
Field 8 of the tuple.
- f8 - Variable in class org.apache.flink.api.java.tuple.Tuple25
-
Field 8 of the tuple.
- f8 - Variable in class org.apache.flink.api.java.tuple.Tuple9
-
Field 8 of the tuple.
- f9 - Variable in class org.apache.flink.api.java.tuple.Tuple10
-
Field 9 of the tuple.
- f9 - Variable in class org.apache.flink.api.java.tuple.Tuple11
-
Field 9 of the tuple.
- f9 - Variable in class org.apache.flink.api.java.tuple.Tuple12
-
Field 9 of the tuple.
- f9 - Variable in class org.apache.flink.api.java.tuple.Tuple13
-
Field 9 of the tuple.
- f9 - Variable in class org.apache.flink.api.java.tuple.Tuple14
-
Field 9 of the tuple.
- f9 - Variable in class org.apache.flink.api.java.tuple.Tuple15
-
Field 9 of the tuple.
- f9 - Variable in class org.apache.flink.api.java.tuple.Tuple16
-
Field 9 of the tuple.
- f9 - Variable in class org.apache.flink.api.java.tuple.Tuple17
-
Field 9 of the tuple.
- f9 - Variable in class org.apache.flink.api.java.tuple.Tuple18
-
Field 9 of the tuple.
- f9 - Variable in class org.apache.flink.api.java.tuple.Tuple19
-
Field 9 of the tuple.
- f9 - Variable in class org.apache.flink.api.java.tuple.Tuple20
-
Field 9 of the tuple.
- f9 - Variable in class org.apache.flink.api.java.tuple.Tuple21
-
Field 9 of the tuple.
- f9 - Variable in class org.apache.flink.api.java.tuple.Tuple22
-
Field 9 of the tuple.
- f9 - Variable in class org.apache.flink.api.java.tuple.Tuple23
-
Field 9 of the tuple.
- f9 - Variable in class org.apache.flink.api.java.tuple.Tuple24
-
Field 9 of the tuple.
- f9 - Variable in class org.apache.flink.api.java.tuple.Tuple25
-
Field 9 of the tuple.
- FACTORY - Static variable in class org.apache.flink.core.memory.HeapMemorySegment
-
- Factory() - Constructor for class org.apache.flink.runtime.executiongraph.failover.RestartAllStrategy.Factory
-
- Factory() - Constructor for class org.apache.flink.runtime.executiongraph.failover.RestartIndividualStrategy.Factory
-
- Factory() - Constructor for class org.apache.flink.runtime.executiongraph.failover.RestartPipelinedRegionStrategy.Factory
-
- fail(Throwable) - Method in class org.apache.flink.runtime.executiongraph.Execution
-
This method fails the vertex due to an external condition.
- fail(Throwable) - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
- fail(Throwable) - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- fail(Throwable) - Method in interface org.apache.flink.runtime.jobmaster.LogicalSlot.Payload
-
Fail the payload with the given cause.
- fail(Object) - Method in class org.apache.flink.storm.util.AbstractLineSpout
-
- fail(Object) - Method in class org.apache.flink.storm.util.NullTerminatingSpout
-
- failAllocation(AllocationID, Exception) - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotPool
-
Fail the specified allocation and release the corresponding slot if we have one.
- failAllocation(AllocationID, Exception) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.SlotPoolGateway
-
Fails the slot with the given allocation id.
- FailedCheckpointStatistics(long, CheckpointStatsStatus, boolean, long, long, long, long, long, int, int, Map<JobVertexID, TaskCheckpointStatistics>, long, String) - Constructor for class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics.FailedCheckpointStatistics
-
- FailedCheckpointStats - Class in org.apache.flink.runtime.checkpoint
-
Statistics for a failed checkpoint.
- failExternally(Throwable) - Method in interface org.apache.flink.runtime.execution.Environment
-
Marks task execution failed for an external reason (a reason other than the task code itself
throwing an exception).
- failExternally(Throwable) - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
-
- failExternally(Throwable) - Method in class org.apache.flink.runtime.taskmanager.Task
-
Marks task execution failed for an external reason (a reason other than the task code itself
throwing an exception).
- failExternally(Throwable) - Method in interface org.apache.flink.runtime.taskmanager.TaskActions
-
Fail the owning task with the given throwable.
- failGlobal(Throwable) - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
Fails the execution graph globally.
- FailingHandler() - Constructor for class org.apache.flink.streaming.api.functions.timestamps.AscendingTimestampExtractor.FailingHandler
-
- failOnMissingField(boolean) - Method in class org.apache.flink.streaming.connectors.kafka.KafkaJsonTableSource.Builder
-
Sets flag whether to fail if a field is missing or not.
- failOnMissingField(boolean) - Method in class org.apache.flink.table.descriptors.Json
-
Sets flag whether to fail if a field is missing or not.
- failOperator(Throwable) - Method in class org.apache.flink.streaming.api.operators.async.AsyncWaitOperator
-
- failOperator(Throwable) - Method in interface org.apache.flink.streaming.api.operators.async.OperatorActions
-
Fail the respective stream operator with the given throwable.
- FAILOVER_TIMEOUT_SECONDS - Static variable in class org.apache.flink.mesos.configuration.MesosOptions
-
The failover timeout for the Mesos scheduler, after which running tasks are automatically shut down.
- FailoverRegion - Class in org.apache.flink.runtime.executiongraph.failover
-
FailoverRegion manages the failover of a minimal pipeline connected sub graph.
- FailoverRegion(ExecutionGraph, Executor, List<ExecutionVertex>) - Constructor for class org.apache.flink.runtime.executiongraph.failover.FailoverRegion
-
- FailoverStrategy - Class in org.apache.flink.runtime.executiongraph.failover
-
A FailoverStrategy
describes how the job computation recovers from task
failures.
- FailoverStrategy() - Constructor for class org.apache.flink.runtime.executiongraph.failover.FailoverStrategy
-
- FailoverStrategy.Factory - Interface in org.apache.flink.runtime.executiongraph.failover
-
This factory is a necessary indirection when creating the FailoverStrategy to that
we can have both the FailoverStrategy final in the ExecutionGraph, and the
ExecutionGraph final in the FailOverStrategy.
- FailoverStrategyLoader - Class in org.apache.flink.runtime.executiongraph.failover
-
A utility class to load failover strategies from the configuration.
- FailoverStrategyLoader() - Constructor for class org.apache.flink.runtime.executiongraph.failover.FailoverStrategyLoader
-
- failPartition(ExecutionAttemptID) - Method in class org.apache.flink.runtime.jobmanager.slots.ActorTaskManagerGateway
-
- failPartition(ExecutionAttemptID) - Method in interface org.apache.flink.runtime.jobmanager.slots.TaskManagerGateway
-
Fail all intermediate result partitions of the given task.
- failPartition(ExecutionAttemptID) - Method in class org.apache.flink.runtime.jobmaster.RpcTaskManagerGateway
-
- failPartition(ExecutionAttemptID) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutor
-
- failPartition(ExecutionAttemptID) - Method in interface org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
-
Fail all intermediate result partitions of the given task.
- failSlot(ResourceID, AllocationID, Exception) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
-
- failSlot(ResourceID, AllocationID, Exception) - Method in interface org.apache.flink.runtime.jobmaster.JobMasterGateway
-
Fails the slot with the given allocation id and cause.
- failTask(ExecutionAttemptID, Throwable) - Method in class org.apache.flink.runtime.taskmanager.ActorGatewayTaskManagerActions
-
- failTask(ExecutionAttemptID, Throwable) - Method in interface org.apache.flink.runtime.taskmanager.TaskManagerActions
-
Tells the task manager to fail the given task.
- failUnacknowledgedPendingCheckpointsFor(ExecutionAttemptID, Throwable) - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
Fails all pending checkpoints which have not been acknowledged by the given execution
attempt id.
- FailureMapper<T> - Class in org.apache.flink.streaming.tests
-
This mapper simulates failure by throwing exceptions.
- FailureMapper(long, long, int) - Constructor for class org.apache.flink.streaming.tests.FailureMapper
-
- failureRateRestart(int, Time, Time) - Static method in class org.apache.flink.api.common.restartstrategy.RestartStrategies
-
Generates a FailureRateRestartStrategyConfiguration.
- FailureRateRestartStrategy - Class in org.apache.flink.runtime.executiongraph.restart
-
Restart strategy which tries to restart the given
ExecutionGraph
when failure rate exceeded
with a fixed time delay in between.
- FailureRateRestartStrategy(int, Time, Time) - Constructor for class org.apache.flink.runtime.executiongraph.restart.FailureRateRestartStrategy
-
- FailureRateRestartStrategy.FailureRateRestartStrategyFactory - Class in org.apache.flink.runtime.executiongraph.restart
-
- FailureRateRestartStrategyConfiguration(int, Time, Time) - Constructor for class org.apache.flink.api.common.restartstrategy.RestartStrategies.FailureRateRestartStrategyConfiguration
-
- FailureRateRestartStrategyFactory(int, Time, Time) - Constructor for class org.apache.flink.runtime.executiongraph.restart.FailureRateRestartStrategy.FailureRateRestartStrategyFactory
-
- FailureTolerantObjectInputStream(InputStream, ClassLoader) - Constructor for class org.apache.flink.util.InstantiationUtil.FailureTolerantObjectInputStream
-
- fallBackRestart() - Static method in class org.apache.flink.api.common.restartstrategy.RestartStrategies
-
- FallbackRestartStrategyConfiguration() - Constructor for class org.apache.flink.api.common.restartstrategy.RestartStrategies.FallbackRestartStrategyConfiguration
-
- FALSE - Static variable in class org.apache.flink.types.BooleanValue
-
- falseFunction() - Static method in class org.apache.flink.cep.pattern.conditions.BooleanConditions
-
- fatalError(String, Throwable) - Method in class org.apache.flink.mesos.runtime.clusterframework.MesosFlinkResourceManager
-
- fatalError(String, Throwable) - Method in class org.apache.flink.runtime.clusterframework.FlinkResourceManager
-
Notifies the resource master of a fatal error.
- fatalError(String, Throwable) - Method in class org.apache.flink.runtime.clusterframework.standalone.StandaloneResourceManager
-
- fatalError(String, Throwable) - Method in class org.apache.flink.yarn.YarnFlinkResourceManager
-
- FatalErrorHandler - Interface in org.apache.flink.runtime.rpc
-
Handler for fatal errors.
- FatalErrorOccurred - Class in org.apache.flink.runtime.clusterframework.messages
-
Message sent to the Flink's resource manager in case of a fatal error that
cannot be recovered in the running process.
- FatalErrorOccurred(String, Throwable) - Constructor for class org.apache.flink.runtime.clusterframework.messages.FatalErrorOccurred
-
- FatalExitExceptionHandler - Class in org.apache.flink.runtime.util
-
Handler for uncaught exceptions that will log the exception and kill the process afterwards.
- FatalExitExceptionHandler() - Constructor for class org.apache.flink.runtime.util.FatalExitExceptionHandler
-
- FeedbackTransformation<T> - Class in org.apache.flink.streaming.api.transformations
-
This represents a feedback point in a topology.
- FeedbackTransformation(StreamTransformation<T>, Long) - Constructor for class org.apache.flink.streaming.api.transformations.FeedbackTransformation
-
Creates a new FeedbackTransformation
from the given input.
- FencedAkkaInvocationHandler<F extends Serializable> - Class in org.apache.flink.runtime.rpc.akka
-
Fenced extension of the AkkaInvocationHandler
.
- FencedAkkaInvocationHandler(String, String, ActorRef, Time, long, CompletableFuture<Void>, Supplier<F>) - Constructor for class org.apache.flink.runtime.rpc.akka.FencedAkkaInvocationHandler
-
- FencedAkkaRpcActor<F extends Serializable,T extends FencedRpcEndpoint<F> & RpcGateway> - Class in org.apache.flink.runtime.rpc.akka
-
Fenced extension of the AkkaRpcActor
.
- FencedAkkaRpcActor(T, CompletableFuture<Boolean>, int) - Constructor for class org.apache.flink.runtime.rpc.akka.FencedAkkaRpcActor
-
- FencedMainThreadExecutable - Interface in org.apache.flink.runtime.rpc
-
- FencedMessage<F extends Serializable,P> - Interface in org.apache.flink.runtime.rpc.messages
-
Interface for fenced messages.
- FencedRpcEndpoint<F extends Serializable> - Class in org.apache.flink.runtime.rpc
-
- FencedRpcEndpoint(RpcService, String) - Constructor for class org.apache.flink.runtime.rpc.FencedRpcEndpoint
-
- FencedRpcEndpoint(RpcService) - Constructor for class org.apache.flink.runtime.rpc.FencedRpcEndpoint
-
- FencedRpcGateway<F extends Serializable> - Interface in org.apache.flink.runtime.rpc
-
- fenceRpcServer(RpcServer, F) - Method in class org.apache.flink.runtime.rpc.akka.AkkaRpcService
-
- fenceRpcServer(RpcServer, F) - Method in interface org.apache.flink.runtime.rpc.RpcService
-
Fence the given RpcServer with the given fencing token.
- FencingTokenException - Exception in org.apache.flink.runtime.rpc.exceptions
-
- FencingTokenException(String) - Constructor for exception org.apache.flink.runtime.rpc.exceptions.FencingTokenException
-
- FencingTokenException(String, Throwable) - Constructor for exception org.apache.flink.runtime.rpc.exceptions.FencingTokenException
-
- FencingTokenException(Throwable) - Constructor for exception org.apache.flink.runtime.rpc.exceptions.FencingTokenException
-
- FETCH_BACKLOG - Static variable in class org.apache.flink.configuration.BlobServerOptions
-
The config parameter defining the backlog of BLOB fetches on the JobManager.
- FETCH_CONCURRENT - Static variable in class org.apache.flink.configuration.BlobServerOptions
-
The config parameter defining the maximum number of concurrent BLOB fetches that the JobManager serves.
- FETCH_RETRIES - Static variable in class org.apache.flink.configuration.BlobServerOptions
-
The config parameter defining number of retires for failed BLOB fetches.
- fetched - Variable in class org.apache.flink.api.java.hadoop.mapred.HadoopInputFormatBase
-
- fetched - Variable in class org.apache.flink.api.java.hadoop.mapreduce.HadoopInputFormatBase
-
- fetchNext() - Method in class org.apache.flink.api.java.hadoop.mapred.HadoopInputFormatBase
-
- fetchNext() - Method in class org.apache.flink.api.java.hadoop.mapreduce.HadoopInputFormatBase
-
- fetchOffsetsWithTimestamp(Collection<KafkaTopicPartition>, long) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer010
-
- fetchOffsetsWithTimestamp(Collection<KafkaTopicPartition>, long) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer08
-
- fetchOffsetsWithTimestamp(Collection<KafkaTopicPartition>, long) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer09
-
- fetchOffsetsWithTimestamp(Collection<KafkaTopicPartition>, long) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumerBase
-
- field - Variable in class org.apache.flink.python.api.PythonOperationInfo
-
- FIELD_NAME_ACC_NAME - Static variable in class org.apache.flink.runtime.rest.messages.job.UserAccumulator
-
- FIELD_NAME_ACC_NAME - Static variable in class org.apache.flink.runtime.rest.messages.JobAccumulatorsInfo.UserTaskAccumulator
-
- FIELD_NAME_ACC_TYPE - Static variable in class org.apache.flink.runtime.rest.messages.job.UserAccumulator
-
- FIELD_NAME_ACC_TYPE - Static variable in class org.apache.flink.runtime.rest.messages.JobAccumulatorsInfo.UserTaskAccumulator
-
- FIELD_NAME_ACC_VALUE - Static variable in class org.apache.flink.runtime.rest.messages.job.UserAccumulator
-
- FIELD_NAME_ACC_VALUE - Static variable in class org.apache.flink.runtime.rest.messages.JobAccumulatorsInfo.UserTaskAccumulator
-
- FIELD_NAME_ACK_TIMESTAMP - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics
-
- FIELD_NAME_ADDRESS - Static variable in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerInfo
-
- FIELD_NAME_ALIGNMENT - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics
-
- FIELD_NAME_ALIGNMENT - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.Summary
-
- FIELD_NAME_ALIGNMENT_BUFFERED - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.Summary
-
- FIELD_NAME_ALIGNMENT_BUFFERED - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
-
- FIELD_NAME_ALIGNMENT_BUFFERED - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics.CheckpointAlignment
-
- FIELD_NAME_ALIGNMENT_BUFFERED - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatistics
-
- FIELD_NAME_ALIGNMENT_DURATION - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics.CheckpointAlignment
-
- FIELD_NAME_ALL_EXCEPTIONS - Static variable in class org.apache.flink.runtime.rest.messages.JobExceptionsInfo
-
- FIELD_NAME_ASYNC_DURATION - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics.CheckpointDuration
-
- FIELD_NAME_ASYNCHRONOUS_DURATION - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.CheckpointDuration
-
- FIELD_NAME_ATTEMPT - Static variable in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsInfo
-
- FIELD_NAME_ATTEMPT - Static variable in class org.apache.flink.runtime.rest.messages.JobVertexDetailsInfo.VertexTaskDetail
-
- FIELD_NAME_ATTEMPT_NUM - Static variable in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptAccumulatorsInfo
-
- FIELD_NAME_ATTEMPT_NUM - Static variable in class org.apache.flink.runtime.rest.messages.job.SubtasksAllAccumulatorsInfo.SubtaskAccumulatorsInfo
-
- FIELD_NAME_AVERAGE - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.MinMaxAvgStatistics
-
- FIELD_NAME_BACKPRESSURE_LEVEL - Static variable in class org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo
-
- FIELD_NAME_BACKPRESSURE_LEVEL - Static variable in class org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo.SubtaskBackPressureInfo
-
- FIELD_NAME_BUFFERED_DATA - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.CheckpointAlignment
-
- FIELD_NAME_CHECKPOINT_DURATION - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics
-
- FIELD_NAME_CHECKPOINT_DURATION - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.Summary
-
- FIELD_NAME_CHECKPOINT_INTERVAL - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigInfo
-
- FIELD_NAME_CHECKPOINT_MAX_CONCURRENT - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigInfo
-
- FIELD_NAME_CHECKPOINT_MIN_PAUSE - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigInfo
-
- FIELD_NAME_CHECKPOINT_STATUS - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics
-
- FIELD_NAME_CHECKPOINT_STATUS - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatistics
-
- FIELD_NAME_CHECKPOINT_TIMEOUT - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigInfo
-
- FIELD_NAME_COMMIT - Static variable in class org.apache.flink.runtime.rest.handler.legacy.messages.ClusterOverviewWithVersion
-
- FIELD_NAME_COMPLETED - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.LatestCheckpoints
-
- FIELD_NAME_COMPLETED_CHECKPOINTS - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.Counts
-
- FIELD_NAME_CONFIG_KEY - Static variable in class org.apache.flink.runtime.rest.messages.ClusterConfigurationInfoEntry
-
- FIELD_NAME_CONFIG_VALUE - Static variable in class org.apache.flink.runtime.rest.messages.ClusterConfigurationInfoEntry
-
- FIELD_NAME_COUNT - Static variable in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMetricsInfo.GarbageCollectorInfo
-
- FIELD_NAME_COUNTS - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics
-
- FIELD_NAME_CPU_CORES - Static variable in class org.apache.flink.runtime.instance.HardwareDescription
-
- FIELD_NAME_DATA_PORT - Static variable in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerInfo
-
- FIELD_NAME_DELETE_ON_CANCELLATION - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigInfo.ExternalizedCheckpointInfo
-
- FIELD_NAME_DIRECT_COUNT - Static variable in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMetricsInfo
-
- FIELD_NAME_DIRECT_MAX - Static variable in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMetricsInfo
-
- FIELD_NAME_DIRECT_USED - Static variable in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMetricsInfo
-
- FIELD_NAME_DISCARDED - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics.CompletedCheckpointStatistics
-
- FIELD_NAME_DURATION - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.Summary
-
- FIELD_NAME_DURATION - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
-
- FIELD_NAME_DURATION - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics
-
- FIELD_NAME_DURATION - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatistics
-
- FIELD_NAME_DURATION - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.CheckpointAlignment
-
- FIELD_NAME_DURATION - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.Summary
-
- FIELD_NAME_DURATION - Static variable in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
-
- FIELD_NAME_DURATION - Static variable in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsInfo
-
- FIELD_NAME_DURATION - Static variable in class org.apache.flink.runtime.rest.messages.JobVertexDetailsInfo.VertexTaskDetail
-
- FIELD_NAME_DURATION - Static variable in class org.apache.flink.runtime.rest.messages.SubtasksTimesInfo.SubtaskTimeInfo
-
- FIELD_NAME_ENABLED - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigInfo.ExternalizedCheckpointInfo
-
- FIELD_NAME_END_TIME - Static variable in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
-
- FIELD_NAME_END_TIME - Static variable in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsInfo
-
- FIELD_NAME_END_TIME - Static variable in class org.apache.flink.runtime.rest.messages.JobVertexDetailsInfo.VertexTaskDetail
-
- FIELD_NAME_END_TIMESTAMP - Static variable in class org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo
-
- FIELD_NAME_EXCEPTION - Static variable in class org.apache.flink.runtime.rest.messages.JobExceptionsInfo.ExecutionExceptionInfo
-
- FIELD_NAME_EXECUTION_CONFIG - Static variable in class org.apache.flink.runtime.rest.messages.JobConfigInfo
-
- FIELD_NAME_EXECUTION_MODE - Static variable in class org.apache.flink.runtime.rest.messages.JobConfigInfo.ExecutionConfigInfo
-
- FIELD_NAME_EXTERNAL_PATH - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.RestoredCheckpointStatistics
-
- FIELD_NAME_EXTERNAL_PATH - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics.CompletedCheckpointStatistics
-
- FIELD_NAME_EXTERNALIZED_CHECKPOINT_CONFIG - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigInfo
-
- FIELD_NAME_FAILED - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.LatestCheckpoints
-
- FIELD_NAME_FAILED_CHECKPOINTS - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.Counts
-
- FIELD_NAME_FAILURE_MESSAGE - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics.FailedCheckpointStatistics
-
- FIELD_NAME_FAILURE_TIMESTAMP - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics.FailedCheckpointStatistics
-
- FIELD_NAME_FLINK_REVISION - Static variable in class org.apache.flink.runtime.rest.messages.DashboardConfiguration
-
- FIELD_NAME_FLINK_VERSION - Static variable in class org.apache.flink.runtime.rest.messages.DashboardConfiguration
-
- FIELD_NAME_GARBAGE_COLLECTORS - Static variable in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMetricsInfo
-
- FIELD_NAME_GLOBAL_JOB_PARAMETERS - Static variable in class org.apache.flink.runtime.rest.messages.JobConfigInfo.ExecutionConfigInfo
-
- FIELD_NAME_HARDWARE - Static variable in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerInfo
-
- FIELD_NAME_HEAP_COMMITTED - Static variable in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMetricsInfo
-
- FIELD_NAME_HEAP_MAX - Static variable in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMetricsInfo
-
- FIELD_NAME_HEAP_USED - Static variable in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMetricsInfo
-
- FIELD_NAME_HISTORY - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics
-
- FIELD_NAME_HOST - Static variable in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsInfo
-
- FIELD_NAME_HOST - Static variable in class org.apache.flink.runtime.rest.messages.job.SubtasksAllAccumulatorsInfo.SubtaskAccumulatorsInfo
-
- FIELD_NAME_HOST - Static variable in class org.apache.flink.runtime.rest.messages.JobVertexDetailsInfo.VertexTaskDetail
-
- FIELD_NAME_HOST - Static variable in class org.apache.flink.runtime.rest.messages.SubtasksTimesInfo.SubtaskTimeInfo
-
- FIELD_NAME_ID - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.RestoredCheckpointStatistics
-
- FIELD_NAME_ID - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
-
- FIELD_NAME_ID - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatistics
-
- FIELD_NAME_ID - Static variable in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptAccumulatorsInfo
-
- FIELD_NAME_ID - Static variable in class org.apache.flink.runtime.rest.messages.JobVertexAccumulatorsInfo
-
- FIELD_NAME_ID - Static variable in class org.apache.flink.runtime.rest.messages.SubtasksTimesInfo
-
- FIELD_NAME_IN_PROGRESS_CHECKPOINTS - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.Counts
-
- FIELD_NAME_INDEX - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics
-
- FIELD_NAME_IS_SAVEPOINT - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.RestoredCheckpointStatistics
-
- FIELD_NAME_IS_SAVEPOINT - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
-
- FIELD_NAME_IS_STOPPABLE - Static variable in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
-
- FIELD_NAME_JOB_ACCUMULATORS - Static variable in class org.apache.flink.runtime.rest.messages.JobAccumulatorsInfo
-
- FIELD_NAME_JOB_GRAPH - Static variable in class org.apache.flink.runtime.rest.messages.job.JobSubmitRequestBody
-
- FIELD_NAME_JOB_ID - Static variable in class org.apache.flink.runtime.messages.webmonitor.JobIdsWithStatusOverview.JobIdWithStatus
-
- FIELD_NAME_JOB_ID - Static variable in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
-
- FIELD_NAME_JOB_ID - Static variable in class org.apache.flink.runtime.rest.messages.JobConfigInfo
-
- FIELD_NAME_JOB_NAME - Static variable in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
-
- FIELD_NAME_JOB_NAME - Static variable in class org.apache.flink.runtime.rest.messages.JobConfigInfo
-
- FIELD_NAME_JOB_STATUS - Static variable in class org.apache.flink.runtime.messages.webmonitor.JobIdsWithStatusOverview.JobIdWithStatus
-
- FIELD_NAME_JOB_STATUS - Static variable in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
-
- FIELD_NAME_JOB_URL - Static variable in class org.apache.flink.runtime.rest.messages.job.JobSubmitResponseBody
-
- FIELD_NAME_JOB_VERTEX_DURATION - Static variable in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
-
- FIELD_NAME_JOB_VERTEX_END_TIME - Static variable in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
-
- FIELD_NAME_JOB_VERTEX_ID - Static variable in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
-
- FIELD_NAME_JOB_VERTEX_ID - Static variable in class org.apache.flink.runtime.rest.messages.job.SubtasksAllAccumulatorsInfo
-
- FIELD_NAME_JOB_VERTEX_INFOS - Static variable in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
-
- FIELD_NAME_JOB_VERTEX_METRICS - Static variable in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
-
- FIELD_NAME_JOB_VERTEX_NAME - Static variable in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
-
- FIELD_NAME_JOB_VERTEX_START_TIME - Static variable in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
-
- FIELD_NAME_JOB_VERTEX_STATE - Static variable in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
-
- FIELD_NAME_JOB_VERTICES_PER_STATE - Static variable in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
-
- FIELD_NAME_JOBS - Static variable in class org.apache.flink.runtime.messages.webmonitor.JobIdsWithStatusOverview
-
- FIELD_NAME_JOBS - Static variable in class org.apache.flink.runtime.messages.webmonitor.MultipleJobsDetails
-
- FIELD_NAME_JOBS_CANCELLED - Static variable in class org.apache.flink.runtime.messages.webmonitor.JobsOverview
-
- FIELD_NAME_JOBS_FAILED - Static variable in class org.apache.flink.runtime.messages.webmonitor.JobsOverview
-
- FIELD_NAME_JOBS_FINISHED - Static variable in class org.apache.flink.runtime.messages.webmonitor.JobsOverview
-
- FIELD_NAME_JOBS_RUNNING - Static variable in class org.apache.flink.runtime.messages.webmonitor.JobsOverview
-
- FIELD_NAME_JSON_PLAN - Static variable in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
-
- FIELD_NAME_LAST_HEARTBEAT - Static variable in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerInfo
-
- FIELD_NAME_LATEST_ACK_TIMESTAMP - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
-
- FIELD_NAME_LATEST_ACK_TIMESTAMP - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatistics
-
- FIELD_NAME_LATEST_CHECKPOINTS - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics
-
- FIELD_NAME_LOCATION - Static variable in class org.apache.flink.runtime.rest.messages.JobExceptionsInfo.ExecutionExceptionInfo
-
- FIELD_NAME_MAPPED_COUNT - Static variable in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMetricsInfo
-
- FIELD_NAME_MAPPED_MAX - Static variable in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMetricsInfo
-
- FIELD_NAME_MAPPED_USED - Static variable in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMetricsInfo
-
- FIELD_NAME_MAXIMUM - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.MinMaxAvgStatistics
-
- FIELD_NAME_METRICS - Static variable in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsInfo
-
- FIELD_NAME_METRICS - Static variable in class org.apache.flink.runtime.rest.messages.JobVertexDetailsInfo.VertexTaskDetail
-
- FIELD_NAME_METRICS - Static variable in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerDetailsInfo
-
- FIELD_NAME_MINIMUM - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.MinMaxAvgStatistics
-
- FIELD_NAME_NAME - Static variable in class org.apache.flink.runtime.rest.messages.SubtasksTimesInfo
-
- FIELD_NAME_NAME - Static variable in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMetricsInfo.GarbageCollectorInfo
-
- FIELD_NAME_NETWORK_MEMORY_SEGMENTS_AVAILABLE - Static variable in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMetricsInfo
-
- FIELD_NAME_NETWORK_MEMROY_SEGMENTS_TOTAL - Static variable in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMetricsInfo
-
- FIELD_NAME_NON_HEAP_COMMITTED - Static variable in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMetricsInfo
-
- FIELD_NAME_NON_HEAP_MAX - Static variable in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMetricsInfo
-
- FIELD_NAME_NON_HEAP_USED - Static variable in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMetricsInfo
-
- FIELD_NAME_NOW - Static variable in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
-
- FIELD_NAME_NOW - Static variable in class org.apache.flink.runtime.rest.messages.JobVertexDetailsInfo
-
- FIELD_NAME_NOW - Static variable in class org.apache.flink.runtime.rest.messages.SubtasksTimesInfo
-
- FIELD_NAME_NUM_ACK_SUBTASKS - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
-
- FIELD_NAME_NUM_ACK_SUBTASKS - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatistics
-
- FIELD_NAME_NUM_SUBTASKS - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
-
- FIELD_NAME_NUM_SUBTASKS - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatistics
-
- FIELD_NAME_NUMBER_AVAILABLE_SLOTS - Static variable in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerInfo
-
- FIELD_NAME_NUMBER_SLOTS - Static variable in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerInfo
-
- FIELD_NAME_OBJECT_REUSE_MODE - Static variable in class org.apache.flink.runtime.rest.messages.JobConfigInfo.ExecutionConfigInfo
-
- FIELD_NAME_PARALLELISM - Static variable in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
-
- FIELD_NAME_PARALLELISM - Static variable in class org.apache.flink.runtime.rest.messages.job.SubtasksAllAccumulatorsInfo
-
- FIELD_NAME_PARALLELISM - Static variable in class org.apache.flink.runtime.rest.messages.JobConfigInfo.ExecutionConfigInfo
-
- FIELD_NAME_PARALLELISM - Static variable in class org.apache.flink.runtime.rest.messages.JobVertexDetailsInfo
-
- FIELD_NAME_PROCESSING_MODE - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigInfo
-
- FIELD_NAME_RATIO - Static variable in class org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo.SubtaskBackPressureInfo
-
- FIELD_NAME_REFRESH_INTERVAL - Static variable in class org.apache.flink.runtime.rest.messages.DashboardConfiguration
-
- FIELD_NAME_RESOURCE_ID - Static variable in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerInfo
-
- FIELD_NAME_RESTART_STRATEGY - Static variable in class org.apache.flink.runtime.rest.messages.JobConfigInfo.ExecutionConfigInfo
-
- FIELD_NAME_RESTORE_TIMESTAMP - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.RestoredCheckpointStatistics
-
- FIELD_NAME_RESTORED - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.LatestCheckpoints
-
- FIELD_NAME_RESTORED_CHECKPOINTS - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.Counts
-
- FIELD_NAME_ROOT_EXCEPTION - Static variable in class org.apache.flink.runtime.rest.messages.JobExceptionsInfo
-
- FIELD_NAME_SAVEPOINT - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.LatestCheckpoints
-
- FIELD_NAME_SAVEPOINT_PATH - Static variable in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalRequest
-
- FIELD_NAME_SERIALIZED_USER_TASK_ACCUMULATORS - Static variable in class org.apache.flink.runtime.rest.messages.JobAccumulatorsInfo
-
- FIELD_NAME_SIZE_JVM_HEAP - Static variable in class org.apache.flink.runtime.instance.HardwareDescription
-
- FIELD_NAME_SIZE_MANAGED_MEMORY - Static variable in class org.apache.flink.runtime.instance.HardwareDescription
-
- FIELD_NAME_SIZE_PHYSICAL_MEMORY - Static variable in class org.apache.flink.runtime.instance.HardwareDescription
-
- FIELD_NAME_SLOTS_AVAILABLE - Static variable in class org.apache.flink.runtime.messages.webmonitor.ClusterOverview
-
- FIELD_NAME_SLOTS_TOTAL - Static variable in class org.apache.flink.runtime.messages.webmonitor.ClusterOverview
-
- FIELD_NAME_START_TIME - Static variable in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
-
- FIELD_NAME_START_TIME - Static variable in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsInfo
-
- FIELD_NAME_START_TIME - Static variable in class org.apache.flink.runtime.rest.messages.JobVertexDetailsInfo.VertexTaskDetail
-
- FIELD_NAME_STATE_SIZE - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.Summary
-
- FIELD_NAME_STATE_SIZE - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
-
- FIELD_NAME_STATE_SIZE - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics
-
- FIELD_NAME_STATE_SIZE - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatistics
-
- FIELD_NAME_STATE_SIZE - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.Summary
-
- FIELD_NAME_STATUS - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
-
- FIELD_NAME_STATUS - Static variable in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsInfo
-
- FIELD_NAME_STATUS - Static variable in class org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo
-
- FIELD_NAME_STATUS - Static variable in class org.apache.flink.runtime.rest.messages.JobVertexDetailsInfo.VertexTaskDetail
-
- FIELD_NAME_SUBTASK - Static variable in class org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo.SubtaskBackPressureInfo
-
- FIELD_NAME_SUBTASK - Static variable in class org.apache.flink.runtime.rest.messages.JobVertexDetailsInfo.VertexTaskDetail
-
- FIELD_NAME_SUBTASK - Static variable in class org.apache.flink.runtime.rest.messages.SubtasksTimesInfo.SubtaskTimeInfo
-
- FIELD_NAME_SUBTASK_INDEX - Static variable in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptAccumulatorsInfo
-
- FIELD_NAME_SUBTASK_INDEX - Static variable in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsInfo
-
- FIELD_NAME_SUBTASK_INDEX - Static variable in class org.apache.flink.runtime.rest.messages.job.SubtasksAllAccumulatorsInfo.SubtaskAccumulatorsInfo
-
- FIELD_NAME_SUBTASKS - Static variable in class org.apache.flink.runtime.rest.messages.job.SubtasksAllAccumulatorsInfo
-
- FIELD_NAME_SUBTASKS - Static variable in class org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo
-
- FIELD_NAME_SUBTASKS - Static variable in class org.apache.flink.runtime.rest.messages.JobVertexDetailsInfo
-
- FIELD_NAME_SUBTASKS - Static variable in class org.apache.flink.runtime.rest.messages.SubtasksTimesInfo
-
- FIELD_NAME_SUBTASKS_CHECKPOINT_STATISTICS - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails
-
- FIELD_NAME_SUMMARY - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics
-
- FIELD_NAME_SUMMARY - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails
-
- FIELD_NAME_SYNC_DURATION - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics.CheckpointDuration
-
- FIELD_NAME_SYNCHRONOUS_DURATION - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.CheckpointDuration
-
- FIELD_NAME_TARGET_DIRECTORY - Static variable in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointTriggerRequestBody
-
- FIELD_NAME_TASK - Static variable in class org.apache.flink.runtime.rest.messages.JobExceptionsInfo.ExecutionExceptionInfo
-
- FIELD_NAME_TASK_MANAGERS - Static variable in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagersInfo
-
- FIELD_NAME_TASKMANAGERS - Static variable in class org.apache.flink.runtime.messages.webmonitor.ClusterOverview
-
- FIELD_NAME_TASKS - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
-
- FIELD_NAME_TASKS_PER_STATE - Static variable in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
-
- FIELD_NAME_TIME - Static variable in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMetricsInfo.GarbageCollectorInfo
-
- FIELD_NAME_TIMESTAMP - Static variable in class org.apache.flink.runtime.rest.messages.JobExceptionsInfo.ExecutionExceptionInfo
-
- FIELD_NAME_TIMESTAMP - Static variable in class org.apache.flink.runtime.rest.messages.JobExceptionsInfo
-
- FIELD_NAME_TIMESTAMPS - Static variable in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
-
- FIELD_NAME_TIMESTAMPS - Static variable in class org.apache.flink.runtime.rest.messages.SubtasksTimesInfo.SubtaskTimeInfo
-
- FIELD_NAME_TIMEZONE_NAME - Static variable in class org.apache.flink.runtime.rest.messages.DashboardConfiguration
-
- FIELD_NAME_TIMEZONE_OFFSET - Static variable in class org.apache.flink.runtime.rest.messages.DashboardConfiguration
-
- FIELD_NAME_TOTAL_CHECKPOINTS - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.Counts
-
- FIELD_NAME_TRIGGER_TIMESTAMP - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
-
- FIELD_NAME_TRUNCATED - Static variable in class org.apache.flink.runtime.rest.messages.JobExceptionsInfo
-
- FIELD_NAME_USER_ACCUMULATORS - Static variable in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptAccumulatorsInfo
-
- FIELD_NAME_USER_ACCUMULATORS - Static variable in class org.apache.flink.runtime.rest.messages.job.SubtasksAllAccumulatorsInfo.SubtaskAccumulatorsInfo
-
- FIELD_NAME_USER_ACCUMULATORS - Static variable in class org.apache.flink.runtime.rest.messages.JobVertexAccumulatorsInfo
-
- FIELD_NAME_USER_TASK_ACCUMULATORS - Static variable in class org.apache.flink.runtime.rest.messages.JobAccumulatorsInfo
-
- FIELD_NAME_VERSION - Static variable in class org.apache.flink.runtime.rest.handler.legacy.messages.ClusterOverviewWithVersion
-
- FIELD_NAME_VERTEX_ID - Static variable in class org.apache.flink.runtime.rest.messages.JobVertexDetailsInfo
-
- FIELD_NAME_VERTEX_NAME - Static variable in class org.apache.flink.runtime.rest.messages.JobVertexDetailsInfo
-
- FieldAccessor<T,F> - Class in org.apache.flink.streaming.util.typeutils
-
These classes encapsulate the logic of accessing a field specified by the user as either an index
or a field expression string.
- FieldAccessor() - Constructor for class org.apache.flink.streaming.util.typeutils.FieldAccessor
-
- FieldAccessorFactory - Class in org.apache.flink.streaming.util.typeutils
-
- FieldAccessorFactory() - Constructor for class org.apache.flink.streaming.util.typeutils.FieldAccessorFactory
-
- fieldDelimiter - Variable in class org.apache.flink.api.java.io.CsvReader
-
- fieldDelimiter(char) - Method in class org.apache.flink.api.java.io.CsvReader
-
- fieldDelimiter(String) - Method in class org.apache.flink.api.java.io.CsvReader
-
Configures the delimiter that separates the fields within a row.
- fieldDelimiter - Variable in class org.apache.flink.python.api.PythonOperationInfo
-
- fieldDelimiterEdges(String) - Method in class org.apache.flink.graph.GraphCsvReader
-
Configures the Delimiter that separates fields in a row for the CSV reader used to read the edges
(','
) is used by default.
- fieldDelimiterVertices(String) - Method in class org.apache.flink.graph.GraphCsvReader
-
Configures the Delimiter that separates fields in a row for the CSV reader used to read the vertices
(','
) is used by default.
- FieldFromArray<OUT> - Class in org.apache.flink.streaming.api.functions.windowing.delta.extractor
-
Extracts a single field out of an array.
- FieldFromArray() - Constructor for class org.apache.flink.streaming.api.functions.windowing.delta.extractor.FieldFromArray
-
Extracts the first field (id 0) from the array.
- FieldFromArray(int) - Constructor for class org.apache.flink.streaming.api.functions.windowing.delta.extractor.FieldFromArray
-
Extracts the field with the given id from the array.
- FieldFromTuple<OUT> - Class in org.apache.flink.streaming.api.functions.windowing.delta.extractor
-
Extracts a single field out of a tuple.
- FieldFromTuple(int) - Constructor for class org.apache.flink.streaming.api.functions.windowing.delta.extractor.FieldFromTuple
-
Extracts the field with the given id from the tuple.
- fieldIncluded - Variable in class org.apache.flink.api.common.io.GenericCsvInputFormat
-
- fieldIndex(String) - Method in class org.apache.flink.storm.wrappers.StormTuple
-
- FieldList - Class in org.apache.flink.api.common.operators.util
-
Immutable ordered list of fields IDs.
- FieldList() - Constructor for class org.apache.flink.api.common.operators.util.FieldList
-
- FieldList(int) - Constructor for class org.apache.flink.api.common.operators.util.FieldList
-
- FieldList(Integer) - Constructor for class org.apache.flink.api.common.operators.util.FieldList
-
- FieldList(int...) - Constructor for class org.apache.flink.api.common.operators.util.FieldList
-
- fieldNames - Variable in class org.apache.flink.api.java.typeutils.RowTypeInfo
-
- fieldNames - Variable in class org.apache.flink.api.java.typeutils.TupleTypeInfo
-
- fieldNames - Variable in class org.apache.flink.hcatalog.HCatInputFormatBase
-
- fieldNames - Variable in class org.apache.flink.streaming.connectors.kafka.KafkaTableSink
-
- FieldParser<T> - Class in org.apache.flink.types.parser
-
A FieldParser is used parse a field from a sequence of bytes.
- FieldParser() - Constructor for class org.apache.flink.types.parser.FieldParser
-
- FieldParser.ParseErrorState - Enum in org.apache.flink.types.parser
-
An enumeration of different types of errors that may occur.
- fields - Variable in class org.apache.flink.api.java.operators.ProjectOperator
-
- FieldSerializer - Class in 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() - Constructor for class org.apache.flink.api.java.typeutils.runtime.FieldSerializer
-
- fieldSerializers - Variable in class org.apache.flink.api.java.typeutils.runtime.TupleSerializerBase
-
- FieldSet - Class in org.apache.flink.api.common.operators.util
-
Immutable unordered collection of fields IDs.
- FieldSet() - Constructor for class org.apache.flink.api.common.operators.util.FieldSet
-
Creates a new empty set of fields.
- FieldSet(Integer) - Constructor for class org.apache.flink.api.common.operators.util.FieldSet
-
Creates a set with one field.
- FieldSet(int...) - Constructor for class org.apache.flink.api.common.operators.util.FieldSet
-
Creates a set with the given fields.
- FieldSet(int[], boolean) - Constructor for class org.apache.flink.api.common.operators.util.FieldSet
-
Creates a set with the given fields.
- FieldSet(Collection<Integer>) - Constructor for class org.apache.flink.api.common.operators.util.FieldSet
-
- FieldsFromArray<OUT> - Class in org.apache.flink.streaming.api.functions.windowing.delta.extractor
-
Extracts multiple fields from an array and puts them into a new array of the
specified type.
- FieldsFromArray(Class<OUT>, int...) - Constructor for class org.apache.flink.streaming.api.functions.windowing.delta.extractor.FieldsFromArray
-
Extracts multiple fields from an array and puts them in the given order
into a new array of the specified type.
- FieldsFromTuple - Class in org.apache.flink.streaming.api.functions.windowing.delta.extractor
-
Extracts one or more fields of the type Double from a tuple and puts them into a new double[].
- FieldsFromTuple(int...) - Constructor for class org.apache.flink.streaming.api.functions.windowing.delta.extractor.FieldsFromTuple
-
Extracts one or more fields of the type Double from a tuple and puts
them into a new double[] (in the specified order).
- fieldType - Variable in class org.apache.flink.streaming.util.typeutils.FieldAccessor
-
- fieldTypes - Variable in class org.apache.flink.streaming.connectors.kafka.KafkaTableSink
-
- FieldVisitorImpl(int) - Constructor for class org.apache.flink.runtime.util.DependencyVisitor.FieldVisitorImpl
-
- FILE_PARAMETER_KEY - Static variable in class org.apache.flink.api.common.io.FileOutputFormat
-
The key under which the name of the target path is stored in the configuration.
- FileArchivedExecutionGraphStore - Class in org.apache.flink.runtime.dispatcher
-
- FileArchivedExecutionGraphStore(File, Time, long, ScheduledExecutor, Ticker) - Constructor for class org.apache.flink.runtime.dispatcher.FileArchivedExecutionGraphStore
-
- FileBasedStateOutputStream - Class in org.apache.flink.runtime.state.filesystem
-
- FileBasedStateOutputStream(FileSystem, Path) - Constructor for class org.apache.flink.runtime.state.filesystem.FileBasedStateOutputStream
-
- FileBaseStatistics(long, long, float) - Constructor for class org.apache.flink.api.common.io.FileInputFormat.FileBaseStatistics
-
Creates a new statistics object.
- FileCache - Class in org.apache.flink.runtime.filecache
-
The FileCache is used to create the local files for the registered cache files when a task is deployed.
- FileCache(String[]) - Constructor for class org.apache.flink.runtime.filecache.FileCache
-
- fileChannel - Variable in class org.apache.flink.runtime.io.disk.iomanager.AbstractFileIOChannel
-
A file channel for NIO access to the file.
- FileChannelInputView - Class in org.apache.flink.runtime.io.disk
-
- FileChannelInputView(BlockChannelReader<MemorySegment>, MemoryManager, List<MemorySegment>, int) - Constructor for class org.apache.flink.runtime.io.disk.FileChannelInputView
-
- FileChannelOutputView - Class in org.apache.flink.runtime.io.disk
-
- FileChannelOutputView(BlockChannelWriter<MemorySegment>, MemoryManager, List<MemorySegment>, int) - Constructor for class org.apache.flink.runtime.io.disk.FileChannelOutputView
-
- FileCopyTask - Class in org.apache.flink.examples.java.distcp
-
A Java POJO that represents a task for copying a single file.
- FileCopyTask(Path, String) - Constructor for class org.apache.flink.examples.java.distcp.FileCopyTask
-
- FileCopyTaskInputFormat - Class in org.apache.flink.examples.java.distcp
-
An implementation of an input format that dynamically assigns FileCopyTask
to the mappers
that have finished previously assigned tasks.
- FileCopyTaskInputFormat(List<FileCopyTask>) - Constructor for class org.apache.flink.examples.java.distcp.FileCopyTaskInputFormat
-
- FileCopyTaskInputSplit - Class in org.apache.flink.examples.java.distcp
-
Implementation of InputSplit
for copying files.
- FileCopyTaskInputSplit(FileCopyTask, int) - Constructor for class org.apache.flink.examples.java.distcp.FileCopyTaskInputSplit
-
- FileInputFormat<OT> - Class in org.apache.flink.api.common.io
-
- FileInputFormat() - Constructor for class org.apache.flink.api.common.io.FileInputFormat
-
- FileInputFormat(Path) - Constructor for class org.apache.flink.api.common.io.FileInputFormat
-
- FileInputFormat.FileBaseStatistics - Class in org.apache.flink.api.common.io
-
Encapsulation of the basic statistics the optimizer obtains about a file.
- FileInputFormat.InputSplitOpenThread - Class in org.apache.flink.api.common.io
-
Obtains a DataInputStream in an thread that is not interrupted.
- FileInputSplit - Class in org.apache.flink.core.fs
-
A file input split provides information on a particular part of a file, possibly
hosted on a distributed file system and replicated among several hosts.
- FileInputSplit(int, Path, long, long, String[]) - Constructor for class org.apache.flink.core.fs.FileInputSplit
-
Constructs a split with host information.
- FileIOChannel - Interface in org.apache.flink.runtime.io.disk.iomanager
-
A Channel represents a collection of files that belong logically to the same resource.
- FileIOChannel.Enumerator - Class in org.apache.flink.runtime.io.disk.iomanager
-
An enumerator for channels that logically belong together.
- FileIOChannel.ID - Class in org.apache.flink.runtime.io.disk.iomanager
-
An ID identifying an underlying file channel.
- fileModTime - Variable in class org.apache.flink.api.common.io.FileInputFormat.FileBaseStatistics
-
- FileMonitoringFunction - Class in org.apache.flink.streaming.api.functions.source
-
- FileMonitoringFunction(String, long, FileMonitoringFunction.WatchType) - Constructor for class org.apache.flink.streaming.api.functions.source.FileMonitoringFunction
-
Deprecated.
- FileMonitoringFunction.WatchType - Enum in org.apache.flink.streaming.api.functions.source
-
Deprecated.
The watch type of the FileMonitoringFunction
.
- FileOutputFormat<IT> - Class in org.apache.flink.api.common.io
-
The abstract base class for all Rich output formats that are file based.
- FileOutputFormat() - Constructor for class org.apache.flink.api.common.io.FileOutputFormat
-
- FileOutputFormat(Path) - Constructor for class org.apache.flink.api.common.io.FileOutputFormat
-
- FileOutputFormat.OutputDirectoryMode - Enum in org.apache.flink.api.common.io
-
Behavior for creating output directories.
- filePath - Variable in class org.apache.flink.api.common.cache.DistributedCache.DistributedCacheEntry
-
- filePath - Variable in class org.apache.flink.api.common.io.FileInputFormat
-
- FilePathFilter - Class in org.apache.flink.api.common.io
-
- FilePathFilter() - Constructor for class org.apache.flink.api.common.io.FilePathFilter
-
- FilePathFilter.DefaultFilter - Class in org.apache.flink.api.common.io
-
The default file path filtering method and is used
if no other such function is provided.
- FileProcessingMode - Enum in org.apache.flink.streaming.api.functions.source
-
- FileReadFunction - Class in org.apache.flink.streaming.api.functions.source
-
- FileReadFunction() - Constructor for class org.apache.flink.streaming.api.functions.source.FileReadFunction
-
Deprecated.
- FILES_COPIED_CNT_NAME - Static variable in class org.apache.flink.examples.java.distcp.DistCp
-
- FileSegment - Class in org.apache.flink.runtime.io.disk.iomanager
-
- FileSegment(FileChannel, long, int, boolean) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.FileSegment
-
- fileSize - Variable in class org.apache.flink.api.common.io.FileInputFormat.FileBaseStatistics
-
- FileSpout - Class in org.apache.flink.storm.util
-
Implements a Spout that reads data from a given local file.
- FileSpout() - Constructor for class org.apache.flink.storm.util.FileSpout
-
- FileSpout(String) - Constructor for class org.apache.flink.storm.util.FileSpout
-
- FileStateHandle - Class in org.apache.flink.runtime.state.filesystem
-
- FileStateHandle(Path, long) - Constructor for class org.apache.flink.runtime.state.filesystem.FileStateHandle
-
Creates a new file state for the given file path.
- FileStatus - Interface in org.apache.flink.core.fs
-
Interface that represents the client side information for a file
independent of the file system.
- FileSystem - Class in org.apache.flink.core.fs
-
Abstract base class of all file systems used by Flink.
- FileSystem() - Constructor for class org.apache.flink.core.fs.FileSystem
-
- fileSystem - Variable in class org.apache.flink.runtime.state.SnapshotDirectory
-
The filesystem that contains the snapshot directory.
- FileSystem.WriteMode - Enum in org.apache.flink.core.fs
-
The possible write modes.
- FILESYSTEM_DEFAULT_OVERWRITE_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- FILESYSTEM_OUTPUT_ALWAYS_CREATE_DIRECTORY - Static variable in class 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 - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- FILESYSTEM_SCHEME - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- FileSystemBlobStore - Class in org.apache.flink.runtime.blob
-
- FileSystemBlobStore(FileSystem, String) - Constructor for class org.apache.flink.runtime.blob.FileSystemBlobStore
-
- fileSystemConnectionLimit(String) - Static method in class 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) - Static method in class org.apache.flink.configuration.CoreOptions
-
The total number of input connections that a file system for the given scheme may open.
- fileSystemConnectionLimitOut(String) - Static method in class org.apache.flink.configuration.CoreOptions
-
The total number of output connections that a file system for the given scheme may open.
- fileSystemConnectionLimitStreamInactivityTimeout(String) - Static method in class 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) - Static method in class 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 - Interface in org.apache.flink.core.fs
-
A factory to create file systems.
- FileSystemKind - Enum in org.apache.flink.core.fs
-
An enumeration defining the kind and characteristics of a
FileSystem
.
- FileSystemSafetyNet - Class in org.apache.flink.core.fs
-
The FileSystemSafetyNet can be used to guard a thread against
FileSystem
stream resource leaks.
- FileSystemSafetyNet() - Constructor for class org.apache.flink.core.fs.FileSystemSafetyNet
-
- FileSystemStateStorageHelper<T extends Serializable> - Class in org.apache.flink.runtime.zookeeper.filesystem
-
- FileSystemStateStorageHelper(String, String) - Constructor for class org.apache.flink.runtime.zookeeper.filesystem.FileSystemStateStorageHelper
-
- FileSystemStateStorageHelper(Path, String) - Constructor for class org.apache.flink.runtime.zookeeper.filesystem.FileSystemStateStorageHelper
-
- FILESYTEM_DEFAULT_OVERRIDE - Static variable in class org.apache.flink.configuration.CoreOptions
-
Specifies whether file output writers should overwrite existing files by default.
- FileType - Enum in org.apache.flink.runtime.taskexecutor
-
- FileUpload - Class in org.apache.flink.runtime.rest
-
Client uploading a file.
- FileUpload(Path, String) - Constructor for class org.apache.flink.runtime.rest.FileUpload
-
- FileUploadHandler - Class in org.apache.flink.runtime.rest
-
Writes multipart/form-data to disk.
- FileUploadHandler(Path) - Constructor for class org.apache.flink.runtime.rest.FileUploadHandler
-
- FileUploads - Class in org.apache.flink.runtime.rest.handler
-
A container for uploaded files.
- FileUploads(Path) - Constructor for class org.apache.flink.runtime.rest.handler.FileUploads
-
- FileUtils - Class in org.apache.flink.util
-
This is a utility class to deal files and directories.
- fillInType(TypeInformation<T>) - Method in class org.apache.flink.api.java.DataSet
-
Tries to fill in the type information.
- fillRecord(OUT, Object[]) - Method in class org.apache.flink.api.java.io.CsvInputFormat
-
- fillRecord(OUT, Object[]) - Method in class org.apache.flink.api.java.io.PojoCsvInputFormat
-
- fillRecord(Row, Object[]) - Method in class org.apache.flink.api.java.io.RowCsvInputFormat
-
- fillRecord(OUT, Object[]) - Method in class org.apache.flink.api.java.io.TupleCsvInputFormat
-
- filter(T) - Method in interface org.apache.flink.api.common.functions.FilterFunction
-
The filter function that evaluates the predicate.
- filter(T) - Method in class org.apache.flink.api.common.functions.RichFilterFunction
-
- filter(FilterFunction<T>) - Method in class org.apache.flink.api.java.DataSet
-
Applies a Filter transformation on a
DataSet
.
- filter(T, IterativeCondition.Context<T>) - Method in class org.apache.flink.cep.pattern.conditions.AndCondition
-
- filter(T, IterativeCondition.Context<T>) - Method in class org.apache.flink.cep.pattern.conditions.IterativeCondition
-
The filter function that evaluates the predicate.
- filter(T, IterativeCondition.Context<T>) - Method in class org.apache.flink.cep.pattern.conditions.NotCondition
-
- filter(T, IterativeCondition.Context<T>) - Method in class org.apache.flink.cep.pattern.conditions.OrCondition
-
- filter(T, IterativeCondition.Context<T>) - Method in class org.apache.flink.cep.pattern.conditions.SimpleCondition
-
- filter(T) - Method in class org.apache.flink.cep.pattern.conditions.SubtypeCondition
-
- filter(Tuple2<Tuple2<Long, Double>, Tuple2<Long, Double>>) - Method in class org.apache.flink.examples.java.graph.PageRank.EpsilonFilter
-
- filter(EmptyFieldsCountAccumulator.StringTriple) - Method in class org.apache.flink.examples.java.relational.EmptyFieldsCountAccumulator.EmptyFieldFilter
-
- filter(Tuple3<Integer, String, Integer>) - Method in class org.apache.flink.examples.java.relational.WebLogAnalysis.FilterByRank
-
Filters for records of the rank relation where the rank is greater
than the given threshold.
- filter(Tuple2<String, String>) - Method in class org.apache.flink.examples.java.relational.WebLogAnalysis.FilterDocByKeyWords
-
Filters for documents that contain all of the given keywords and projects the records on the URL field.
- filter(Tuple2<String, String>) - Method in class org.apache.flink.examples.java.relational.WebLogAnalysis.FilterVisitsByDate
-
Filters for records of the visits relation where the year of visit is equal to a
specified value.
- filter(FilterFunction<T>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
- filter(FilterFunction<PyObject>) - Method in class org.apache.flink.streaming.python.api.datastream.PythonDataStream
-
- filter(PyObject) - Method in class org.apache.flink.streaming.python.api.functions.PythonFilterFunction
-
- filterByCodeAnnotations(OptimizerNode, int) - Method in class org.apache.flink.optimizer.dataproperties.InterestingProperties
-
- FilterByRank() - Constructor for class org.apache.flink.examples.java.relational.WebLogAnalysis.FilterByRank
-
- filterBySemanticProperties(SemanticProperties, int) - Method in class org.apache.flink.optimizer.dataproperties.GlobalProperties
-
Filters these GlobalProperties by the fields that are forwarded to the output
as described by the SemanticProperties.
- filterBySemanticProperties(SemanticProperties, int) - Method in class org.apache.flink.optimizer.dataproperties.LocalProperties
-
Filters these LocalProperties by the fields that are forwarded to the output
as described by the SemanticProperties.
- filterBySemanticProperties(SemanticProperties, int) - Method in class org.apache.flink.optimizer.dataproperties.RequestedGlobalProperties
-
Filters these properties by what can be preserved by the given SemanticProperties when propagated down
to the given input.
- filterBySemanticProperties(SemanticProperties, int) - Method in class org.apache.flink.optimizer.dataproperties.RequestedLocalProperties
-
Filters these properties by what can be preserved by the given SemanticProperties when propagated down
to the given input.
- filterCharacters(String) - Method in class org.apache.flink.dropwizard.ScheduledDropwizardReporter
-
- filterCharacters(String) - Method in interface org.apache.flink.metrics.CharacterFilter
-
Filter the given string and generate a resulting string from it.
- filterCharacters(String) - Method in class org.apache.flink.metrics.slf4j.Slf4jReporter
-
- filterCharacters(String) - Method in class org.apache.flink.metrics.statsd.StatsDReporter
-
- FilterDescriptor - Class in org.apache.flink.optimizer.operators
-
- FilterDescriptor() - Constructor for class org.apache.flink.optimizer.operators.FilterDescriptor
-
- FilterDocByKeyWords() - Constructor for class org.apache.flink.examples.java.relational.WebLogAnalysis.FilterDocByKeyWords
-
- FilteredClassLoader - Class in org.apache.flink.core.testutils
-
A ClassLoader that filters out certain classes (by name) and throws a ClassNotFoundException
when they should be loaded.
- FilteredClassLoader(ClassLoader, String...) - Constructor for class org.apache.flink.core.testutils.FilteredClassLoader
-
Creates a new filtered classloader.
- FilterFunction<T> - Interface in org.apache.flink.api.common.functions
-
A filter function is a predicate applied individually to each record.
- FilterNode - Class in org.apache.flink.optimizer.dag
-
The optimizer's internal representation of a Filter operator node.
- FilterNode(FilterOperatorBase<?, ?>) - Constructor for class org.apache.flink.optimizer.dag.FilterNode
-
- filterOnEdges(FilterFunction<Edge<K, EV>>) - Method in class org.apache.flink.graph.Graph
-
Apply a filtering function to the graph and return a sub-graph that
satisfies the predicates only for the edges.
- filterOnVertices(FilterFunction<Vertex<K, VV>>) - Method in class org.apache.flink.graph.Graph
-
Apply a filtering function to the graph and return a sub-graph that
satisfies the predicates only for the vertices.
- FilterOperator<T> - Class in org.apache.flink.api.java.operators
-
This operator represents the application of a "filter" function on a data set, and the
result data set produced by the function.
- FilterOperator(DataSet<T>, FilterFunction<T>, String) - Constructor for class org.apache.flink.api.java.operators.FilterOperator
-
- FilterOperatorBase<T,FT extends FlatMapFunction<T,T>> - Class in org.apache.flink.api.common.operators.base
-
- FilterOperatorBase(UserCodeWrapper<FT>, UnaryOperatorInformation<T, T>, String) - Constructor for class org.apache.flink.api.common.operators.base.FilterOperatorBase
-
- FilterOperatorBase(FT, UnaryOperatorInformation<T, T>, String) - Constructor for class org.apache.flink.api.common.operators.base.FilterOperatorBase
-
- FilterOperatorBase(Class<? extends FT>, UnaryOperatorInformation<T, T>, String) - Constructor for class org.apache.flink.api.common.operators.base.FilterOperatorBase
-
- filterPath(Path) - Method in class org.apache.flink.api.common.io.FilePathFilter.DefaultFilter
-
- filterPath(Path) - Method in class 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) - Method in class org.apache.flink.api.common.io.GlobFilePathFilter
-
- filters() - Method in class org.apache.flink.mesos.scheduler.messages.AcceptOffers
-
- FilterVisitsByDate() - Constructor for class org.apache.flink.examples.java.relational.WebLogAnalysis.FilterVisitsByDate
-
- finalize() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
The finalize method shuts down the timer.
- finalize() - Method in class org.apache.flink.streaming.runtime.tasks.SystemProcessingTimeService
-
- finalizeBuildPhase(IOManager, FileIOChannel.Enumerator, LinkedBlockingQueue<MemorySegment>) - Method in class org.apache.flink.runtime.operators.hash.HashPartition
-
- finalizeCheckpoint() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
-
- finalizeGlobal(int) - Method in interface org.apache.flink.api.common.io.FinalizeOnMaster
-
The method is invoked on the master (JobManager) after all (parallel) instances of an OutputFormat finished.
- finalizeGlobal(int) - Method in class org.apache.flink.api.java.hadoop.mapred.HadoopOutputFormatBase
-
- finalizeGlobal(int) - Method in class org.apache.flink.api.java.hadoop.mapreduce.HadoopOutputFormatBase
-
- FinalizeOnMaster - Interface in org.apache.flink.api.common.io
-
This interface may be implemented by
OutputFormat
s to have the master finalize them globally.
- finalizeOnMaster(ClassLoader) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
A hook that can be overwritten by sub classes to implement logic that is called by the
master after the job completed.
- finalizeOnMaster(ClassLoader) - Method in class org.apache.flink.runtime.jobgraph.OutputFormatVertex
-
- finalizeProbePhase(List<MemorySegment>, List<HashPartition<BT, PT>>, boolean) - Method in class org.apache.flink.runtime.operators.hash.HashPartition
-
- finalizeProbePhase(List<MemorySegment>, List<HashPartition<BT, PT>>, boolean) - Method in class org.apache.flink.runtime.operators.hash.ReOpenableHashPartition
-
- finalStatus() - Method in class org.apache.flink.runtime.clusterframework.messages.StopCluster
-
- find(Configuration) - Static method in class org.apache.flink.runtime.webmonitor.WebMonitorUtils.LogFileLocation
-
Finds the Flink log directory using log.file Java property that is set during startup.
- find(CharSequence) - Method in class org.apache.flink.types.StringValue
-
Finds any occurrence of the str
character sequence in this StringValue.
- find(CharSequence, int) - Method in class org.apache.flink.types.StringValue
-
Finds any occurrence of the str
character sequence in this StringValue.
- findConnectingAddress(InetSocketAddress, long, long) - Static method in class org.apache.flink.runtime.net.ConnectionUtils
-
Finds the local network address from which this machine can connect to the target
address.
- findConnectingAddress(FiniteDuration) - Method in class org.apache.flink.runtime.net.ConnectionUtils.LeaderConnectingAddressListener
-
- findConnectingAddress(FiniteDuration, FiniteDuration) - Method in class org.apache.flink.runtime.net.ConnectionUtils.LeaderConnectingAddressListener
-
- findConnectingAddress(LeaderRetrievalService, Time) - Static method in class org.apache.flink.runtime.util.LeaderRetrievalUtils
-
- findConnectingAddress(LeaderRetrievalService, FiniteDuration) - Static method in class org.apache.flink.runtime.util.LeaderRetrievalUtils
-
- findMatchingRequest(ResourceProfile) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
-
Finds a matching slot request for a given resource profile.
- findMatchingSlot(ResourceProfile) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
-
Finds a matching slot for a given resource profile.
- findMatchWithLocality(SlotProfile, Stream<IN>, Function<IN, SlotContext>, Predicate<IN>, BiFunction<IN, Locality, OUT>) - Method in class org.apache.flink.runtime.jobmaster.slotpool.LocationPreferenceSchedulingStrategy
-
- findMatchWithLocality(SlotProfile, Stream<IN>, Function<IN, SlotContext>, Predicate<IN>, BiFunction<IN, Locality, OUT>) - Method in class org.apache.flink.runtime.jobmaster.slotpool.PreviousAllocationSchedulingStrategy
-
- findMatchWithLocality(SlotProfile, Stream<IN>, Function<IN, SlotContext>, Predicate<IN>, BiFunction<IN, Locality, OUT>) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.SchedulingStrategy
-
This method takes the candidate slots, extracts slot contexts from them, filters them by the profile
requirements and potentially by additional requirements, and produces a result from a match.
- findMethodNode(String, Method) - Static method in class org.apache.flink.api.java.sca.UdfAnalyzerUtils
-
- findMethodNode(String, String, String) - Static method in class org.apache.flink.api.java.sca.UdfAnalyzerUtils
-
- findThrowable(Throwable, Class<T>) - Static method in class org.apache.flink.util.ExceptionUtils
-
Checks whether a throwable chain contains a specific type of exception and returns it.
- findThrowable(Throwable, Predicate<Throwable>) - Static method in class org.apache.flink.util.ExceptionUtils
-
Checks whether a throwable chain contains an exception matching a predicate and returns it.
- findThrowableWithMessage(Throwable, String) - Static method in class org.apache.flink.util.ExceptionUtils
-
Checks whether a throwable chain contains a specific error message and returns the corresponding throwable.
- findVertexByID(JobVertexID) - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
Searches for a vertex with a matching ID and returns it.
- finish() - Method in class org.apache.flink.api.java.io.jdbc.JDBCInputFormat.JDBCInputFormatBuilder
-
- finish() - Method in class org.apache.flink.api.java.io.jdbc.JDBCOutputFormat.JDBCOutputFormatBuilder
-
Finalizes the configuration and checks validity.
- finish() - Method in class org.apache.flink.runtime.io.network.buffer.BufferBuilder
-
- finish() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
-
Finishes the result partition.
- finish() - Method in class org.apache.flink.runtime.io.network.partition.ResultSubpartition
-
- finishPlanMode() - Method in class org.apache.flink.python.api.streaming.plan.PythonPlanStreamer
-
- finishRecoveringContext() - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
-
- finishRecoveringContext() - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer011
-
- finishWriteAndSortKeys(List<MemorySegment>) - Method in class org.apache.flink.runtime.operators.sort.LargeRecordHandler
-
- FiniteFileSpout - Class in org.apache.flink.storm.util
-
Implements a Spout that reads data from a given local file.
- FiniteFileSpout() - Constructor for class org.apache.flink.storm.util.FiniteFileSpout
-
- FiniteFileSpout(String) - Constructor for class org.apache.flink.storm.util.FiniteFileSpout
-
- FiniteInMemorySpout - Class in org.apache.flink.storm.util
-
Implements a Spout that reads String[] data stored in memory.
- FiniteInMemorySpout(String[]) - Constructor for class org.apache.flink.storm.util.FiniteInMemorySpout
-
- FiniteNewDataSource() - Constructor for class org.apache.flink.streaming.examples.ml.IncrementalLearningSkeleton.FiniteNewDataSource
-
- FiniteSpout - Interface in org.apache.flink.storm.util
-
This interface represents a spout that emits a finite number of records.
- FiniteTrainingDataSource() - Constructor for class org.apache.flink.streaming.examples.ml.IncrementalLearningSkeleton.FiniteTrainingDataSource
-
- first(int) - Method in class org.apache.flink.api.java.DataSet
-
Returns a new set containing the first n elements in this
DataSet
.
- first(int) - Method in class org.apache.flink.api.java.operators.SortedGrouping
-
Returns a new set containing the first n elements in this grouped and sorted
DataSet
.
- first(int) - Method in class org.apache.flink.api.java.operators.UnsortedGrouping
-
Returns a new set containing the first n elements in this grouped
DataSet
.
- firstDam() - Method in enum org.apache.flink.runtime.operators.DriverStrategy
-
- firstOrSuppressed(T, T) - Static method in class 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.
- FirstReducer<T> - Class in org.apache.flink.api.java.functions
-
Reducer that only emits the first N elements in a group.
- FirstReducer(int) - Constructor for class org.apache.flink.api.java.functions.FirstReducer
-
- fixedDelayRestart(int, long) - Static method in class org.apache.flink.api.common.restartstrategy.RestartStrategies
-
Generates a FixedDelayRestartStrategyConfiguration.
- fixedDelayRestart(int, Time) - Static method in class org.apache.flink.api.common.restartstrategy.RestartStrategies
-
Generates a FixedDelayRestartStrategyConfiguration.
- FixedDelayRestartStrategy - Class in org.apache.flink.runtime.executiongraph.restart
-
Restart strategy which tries to restart the given
ExecutionGraph
a fixed number of times
with a fixed time delay in between.
- FixedDelayRestartStrategy(int, long) - Constructor for class org.apache.flink.runtime.executiongraph.restart.FixedDelayRestartStrategy
-
- FixedDelayRestartStrategy.FixedDelayRestartStrategyFactory - Class in org.apache.flink.runtime.executiongraph.restart
-
- FixedDelayRestartStrategyFactory(int, long) - Constructor for class org.apache.flink.runtime.executiongraph.restart.FixedDelayRestartStrategy.FixedDelayRestartStrategyFactory
-
- FixedLengthRecordSorter<T> - Class in org.apache.flink.runtime.operators.sort
-
- FixedLengthRecordSorter(TypeSerializer<T>, TypeComparator<T>, List<MemorySegment>) - Constructor for class org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
-
- FLAG_LAST_BLOCK - Static variable in class org.apache.flink.runtime.io.disk.iomanager.ChannelWriterOutputView
-
The flag marking a block as the last block.
- flat_map(FlatMapFunction<PyObject, Object>) - Method in class org.apache.flink.streaming.python.api.datastream.PythonDataStream
-
- FlatFieldDescriptor(int, TypeInformation<?>) - Constructor for class org.apache.flink.api.common.typeutils.CompositeType.FlatFieldDescriptor
-
- FlatJoinFunction<IN1,IN2,OUT> - Interface in org.apache.flink.api.common.functions
-
Interface for Join functions.
- flatMap(T, Collector<O>) - Method in interface org.apache.flink.api.common.functions.FlatMapFunction
-
The core method of the FlatMapFunction.
- flatMap(IN, Collector<OUT>) - Method in class org.apache.flink.api.common.functions.RichFlatMapFunction
-
- flatMap(X, Collector<X>) - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase.TerminationCriterionMapper
-
- flatMap(FlatMapFunction<T, R>) - Method in class org.apache.flink.api.java.DataSet
-
Applies a FlatMap transformation on a
DataSet
.
- flatMap(IN) - Method in class org.apache.flink.api.java.functions.FlatMapIterator
-
The core method of the function.
- flatMap(IN, Collector<OUT>) - Method in class org.apache.flink.api.java.functions.FlatMapIterator
-
- flatMap(T, Collector<T>) - Method in class org.apache.flink.api.java.operators.translation.PlanFilterOperator.FlatMapFilter
-
- flatMap(Tuple2<Long, Long>, Collector<Tuple2<Long, Long>>) - Method in class org.apache.flink.examples.java.graph.ConnectedComponents.UndirectEdge
-
- flatMap(Tuple2<Tuple2<Long, Double>, Tuple2<Long, Long[]>>, Collector<Tuple2<Long, Double>>) - Method in class org.apache.flink.examples.java.graph.PageRank.JoinVertexWithEdgesMatch
-
- flatMap(String, Collector<Tuple2<String, Integer>>) - Method in class org.apache.flink.examples.java.wordcount.WordCount.Tokenizer
-
- flatMap(String, Collector<WordCountPojo.Word>) - Method in class org.apache.flink.examples.java.wordcount.WordCountPojo.Tokenizer
-
- flatMap(RT, Collector<RT>) - Method in class org.apache.flink.graph.asm.result.BinaryResult.MirrorResult
-
- flatMap(Tuple2<KEYIN, VALUEIN>, Collector<Tuple2<KEYOUT, VALUEOUT>>) - Method in class org.apache.flink.hadoopcompatibility.mapred.HadoopMapFunction
-
- flatMap(String, Collector<Tuple2<String, Integer>>) - Method in class org.apache.flink.storm.wordcount.SpoutSourceWordCount.Tokenizer
-
- flatMap(CoFlatMapFunction<IN1, IN2, R>) - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
-
Applies a CoFlatMap transformation on a
ConnectedStreams
and
maps the output to a common type.
- flatMap(FlatMapFunction<T, R>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
- flatMap(Tuple3<String, Long, Long>, Collector<String>) - Method in class org.apache.flink.streaming.api.functions.source.FileReadFunction
-
Deprecated.
- flatMap(String, Collector<Tuple2<String, Integer>>) - Method in class org.apache.flink.streaming.examples.twitter.TwitterExample.SelectEnglishAndTokenizeFlatMap
-
Select the language from the incoming JSON text.
- flatMap(String, Collector<Tuple2<String, Integer>>) - Method in class org.apache.flink.streaming.examples.wordcount.WordCount.Tokenizer
-
- flatMap(PyObject, Collector<PyObject>) - Method in class org.apache.flink.streaming.python.api.functions.PythonFlatMapFunction
-
- flatMap(Event, Collector<String>) - Method in class org.apache.flink.streaming.tests.SemanticsCheckMapper
-
- flatMap1(IN1, Collector<OUT>) - Method in interface org.apache.flink.streaming.api.functions.co.CoFlatMapFunction
-
This method is called for each element in the first of the connected streams.
- flatMap2(IN2, Collector<OUT>) - Method in interface org.apache.flink.streaming.api.functions.co.CoFlatMapFunction
-
This method is called for each element in the second of the connected streams.
- FlatMapDescriptor - Class in org.apache.flink.optimizer.operators
-
- FlatMapDescriptor() - Constructor for class org.apache.flink.optimizer.operators.FlatMapDescriptor
-
- FlatMapDriver<IT,OT> - Class in org.apache.flink.runtime.operators
-
Map task which is executed by a Task Manager.
- FlatMapDriver() - Constructor for class org.apache.flink.runtime.operators.FlatMapDriver
-
- FlatMapFunction<T,O> - Interface in org.apache.flink.api.common.functions
-
Base interface for flatMap functions.
- FlatMapIterator<IN,OUT> - Class in org.apache.flink.api.java.functions
-
A convenience variant of the
RichFlatMapFunction
that returns elements through an iterator, rather then
through a collector.
- FlatMapIterator() - Constructor for class org.apache.flink.api.java.functions.FlatMapIterator
-
- FlatMapNode - Class in org.apache.flink.optimizer.dag
-
The optimizer's internal representation of a FlatMap operator node.
- FlatMapNode(FlatMapOperatorBase<?, ?, ?>) - Constructor for class org.apache.flink.optimizer.dag.FlatMapNode
-
- FlatMapOperator<IN,OUT> - Class in org.apache.flink.api.java.operators
-
This operator represents the application of a "flatMap" function on a data set, and the
result data set produced by the function.
- FlatMapOperator(DataSet<IN>, TypeInformation<OUT>, FlatMapFunction<IN, OUT>, String) - Constructor for class org.apache.flink.api.java.operators.FlatMapOperator
-
- FlatMapOperatorBase<IN,OUT,FT extends FlatMapFunction<IN,OUT>> - Class in org.apache.flink.api.common.operators.base
-
- FlatMapOperatorBase(UserCodeWrapper<FT>, UnaryOperatorInformation<IN, OUT>, String) - Constructor for class org.apache.flink.api.common.operators.base.FlatMapOperatorBase
-
- FlatMapOperatorBase(FT, UnaryOperatorInformation<IN, OUT>, String) - Constructor for class org.apache.flink.api.common.operators.base.FlatMapOperatorBase
-
- FlatMapOperatorBase(Class<? extends FT>, UnaryOperatorInformation<IN, OUT>, String) - Constructor for class org.apache.flink.api.common.operators.base.FlatMapOperatorBase
-
- flatSelect(Map<String, List<IN>>, Collector<OUT>) - Method in interface org.apache.flink.cep.PatternFlatSelectFunction
-
Generates zero or more resulting elements given a map of detected pattern events.
- flatSelect(PatternFlatSelectFunction<T, R>) - Method in class org.apache.flink.cep.PatternStream
-
Applies a flat select function to the detected pattern sequence.
- flatSelect(PatternFlatSelectFunction<T, R>, TypeInformation<R>) - Method in class org.apache.flink.cep.PatternStream
-
Applies a flat select function to the detected pattern sequence.
- flatSelect(OutputTag<L>, PatternFlatTimeoutFunction<T, L>, PatternFlatSelectFunction<T, R>) - Method in class org.apache.flink.cep.PatternStream
-
Applies a flat select function to the detected pattern sequence.
- flatSelect(OutputTag<L>, PatternFlatTimeoutFunction<T, L>, TypeInformation<R>, PatternFlatSelectFunction<T, R>) - Method in class org.apache.flink.cep.PatternStream
-
Applies a flat select function to the detected pattern sequence.
- flatSelect(PatternFlatTimeoutFunction<T, L>, PatternFlatSelectFunction<T, R>) - Method in class org.apache.flink.cep.PatternStream
-
- FlatSelectCepOperator<IN,KEY,OUT> - Class in org.apache.flink.cep.operator
-
- FlatSelectCepOperator(TypeSerializer<IN>, boolean, NFACompiler.NFAFactory<IN>, EventComparator<IN>, AfterMatchSkipStrategy, PatternFlatSelectFunction<IN, OUT>) - Constructor for class org.apache.flink.cep.operator.FlatSelectCepOperator
-
- FlatSelectTimeoutCepOperator<IN,OUT1,OUT2,KEY> - Class in org.apache.flink.cep.operator
-
- FlatSelectTimeoutCepOperator(TypeSerializer<IN>, boolean, NFACompiler.NFAFactory<IN>, EventComparator<IN>, AfterMatchSkipStrategy, PatternFlatSelectFunction<IN, OUT1>, PatternFlatTimeoutFunction<IN, OUT2>, OutputTag<OUT2>) - Constructor for class org.apache.flink.cep.operator.FlatSelectTimeoutCepOperator
-
- FlatSelectTimeoutCepOperator.FlatSelectWrapper<IN,OUT1,OUT2> - Class in org.apache.flink.cep.operator
-
- FlatSelectWrapper(PatternFlatSelectFunction<IN, OUT1>, PatternFlatTimeoutFunction<IN, OUT2>) - Constructor for class org.apache.flink.cep.operator.FlatSelectTimeoutCepOperator.FlatSelectWrapper
-
- FLINK_BASE_DIR_PATH_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- FLINK_CONF_FILENAME - Static variable in class org.apache.flink.configuration.GlobalConfiguration
-
- FLINK_JAR_PATH - Static variable in class org.apache.flink.yarn.YarnConfigKeys
-
- FLINK_JM_JVM_OPTIONS - Static variable in class org.apache.flink.configuration.CoreOptions
-
- FLINK_JVM_OPTIONS - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- FLINK_JVM_OPTIONS - Static variable in class org.apache.flink.configuration.CoreOptions
-
- FLINK_LOG_DIR - Static variable in class org.apache.flink.configuration.CoreOptions
-
This options is here only for documentation generation, it is only
evaluated in the shell scripts.
- FLINK_LOG_MAX - Static variable in class org.apache.flink.configuration.CoreOptions
-
This options is here only for documentation generation, it is only
evaluated in the shell scripts.
- FLINK_PYTHON_DC_ID - Static variable in class org.apache.flink.python.api.PythonPlanBinder
-
- FLINK_PYTHON_DC_ID - Static variable in class org.apache.flink.streaming.python.api.environment.PythonConstants
-
- FLINK_PYTHON_PLAN_NAME - Static variable in class org.apache.flink.python.api.PythonPlanBinder
-
- FLINK_RECOVERY_DATA_DIR - Static variable in class org.apache.flink.yarn.highavailability.YarnHighAvailabilityServices
-
The name of the sub directory in which Flink stores the recovery data.
- FLINK_SSH_OPTIONS - Static variable in class 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 - Static variable in class org.apache.flink.configuration.CoreOptions
-
- FLINK_YARN_FILES - Static variable in class org.apache.flink.yarn.YarnConfigKeys
-
- FlinkClient - Class in org.apache.flink.storm.api
-
FlinkClient
mimics a Storm
NimbusClient
and
Nimbus
.Client
at once, to interact with
Flink's JobManager instead of Storm's Nimbus.
- FlinkClient(Map, String, int) - Constructor for class org.apache.flink.storm.api.FlinkClient
-
Instantiates a new
FlinkClient
for the given configuration, host name, and port.
- FlinkClient(Map, String, int, Integer) - Constructor for class org.apache.flink.storm.api.FlinkClient
-
Instantiates a new
FlinkClient
for the given configuration, host name, and port.
- flinkCollector - Variable in class org.apache.flink.storm.wrappers.BoltWrapper
-
We have to use this because Operators must output
StreamRecord
.
- flinkConfig - Variable in class org.apache.flink.client.program.ClusterClient
-
Configuration of the client.
- FlinkCounterWrapper - Class in org.apache.flink.dropwizard.metrics
-
A wrapper that allows a Flink counter to be used as a DropWizard counter.
- FlinkCounterWrapper(Counter) - Constructor for class org.apache.flink.dropwizard.metrics.FlinkCounterWrapper
-
- FlinkDistributionOverlay - Class in org.apache.flink.runtime.clusterframework.overlays
-
Overlays Flink into a container, based on supplied bin/conf/lib directories.
- FlinkDistributionOverlay(File, File, File) - Constructor for class org.apache.flink.runtime.clusterframework.overlays.FlinkDistributionOverlay
-
- FlinkDistributionOverlay.Builder - Class in org.apache.flink.runtime.clusterframework.overlays
-
- FlinkException - Exception in org.apache.flink.util
-
Base class of all Flink-specific checked exceptions.
- FlinkException(String) - Constructor for exception org.apache.flink.util.FlinkException
-
Creates a new Exception with the given message and null as the cause.
- FlinkException(Throwable) - Constructor for exception org.apache.flink.util.FlinkException
-
Creates a new exception with a null message and the given cause.
- FlinkException(String, Throwable) - Constructor for exception org.apache.flink.util.FlinkException
-
Creates a new exception with the given message and cause.
- flinkFileSystem - Variable in class org.apache.flink.yarn.highavailability.YarnHighAvailabilityServices
-
The Flink FileSystem object that represent the HDFS used by YARN.
- FlinkFixedPartitioner<T> - Class in org.apache.flink.streaming.connectors.kafka.partitioner
-
A partitioner ensuring that each internal Flink partition ends up in one Kafka partition.
- FlinkFixedPartitioner() - Constructor for class org.apache.flink.streaming.connectors.kafka.partitioner.FlinkFixedPartitioner
-
- FlinkGaugeWrapper<T> - Class in org.apache.flink.dropwizard.metrics
-
A wrapper that allows a Flink gauge to be used as a DropWizard gauge.
- FlinkGaugeWrapper(Gauge<T>) - Constructor for class org.apache.flink.dropwizard.metrics.FlinkGaugeWrapper
-
- FlinkHistogramWrapper - Class in org.apache.flink.dropwizard.metrics
-
Wrapper to use a Flink
Histogram
as a Dropwizard
Histogram
.
- FlinkHistogramWrapper(Histogram) - Constructor for class org.apache.flink.dropwizard.metrics.FlinkHistogramWrapper
-
- FlinkHttpObjectAggregator - Class in org.apache.flink.runtime.rest
-
Same as HttpObjectDecoder
but returns HTTP 413 to the client if the payload exceeds HttpObjectAggregator.maxContentLength
.
- FlinkHttpObjectAggregator(int, Map<String, String>) - Constructor for class org.apache.flink.runtime.rest.FlinkHttpObjectAggregator
-
- FlinkJobNotFoundException - Exception in org.apache.flink.runtime.messages
-
Exception indicating that we could not find a Flink job with the given job ID.
- FlinkJobNotFoundException(JobID) - Constructor for exception org.apache.flink.runtime.messages.FlinkJobNotFoundException
-
- FlinkKafka011ErrorCode - Enum in org.apache.flink.streaming.connectors.kafka
-
- FlinkKafka011Exception - Exception in org.apache.flink.streaming.connectors.kafka
-
- FlinkKafka011Exception(FlinkKafka011ErrorCode, String) - Constructor for exception org.apache.flink.streaming.connectors.kafka.FlinkKafka011Exception
-
- FlinkKafka011Exception(FlinkKafka011ErrorCode, String, Throwable) - Constructor for exception org.apache.flink.streaming.connectors.kafka.FlinkKafka011Exception
-
- FlinkKafkaConsumer010<T> - Class in org.apache.flink.streaming.connectors.kafka
-
The Flink Kafka Consumer is a streaming data source that pulls a parallel data stream from
Apache Kafka 0.10.x.
- FlinkKafkaConsumer010(String, DeserializationSchema<T>, Properties) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer010
-
Creates a new Kafka streaming source consumer for Kafka 0.10.x.
- FlinkKafkaConsumer010(String, KeyedDeserializationSchema<T>, Properties) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer010
-
Creates a new Kafka streaming source consumer for Kafka 0.10.x
- FlinkKafkaConsumer010(List<String>, DeserializationSchema<T>, Properties) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer010
-
Creates a new Kafka streaming source consumer for Kafka 0.10.x
- FlinkKafkaConsumer010(List<String>, KeyedDeserializationSchema<T>, Properties) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer010
-
Creates a new Kafka streaming source consumer for Kafka 0.10.x
- FlinkKafkaConsumer010(Pattern, DeserializationSchema<T>, Properties) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer010
-
Creates a new Kafka streaming source consumer for Kafka 0.10.x.
- FlinkKafkaConsumer010(Pattern, KeyedDeserializationSchema<T>, Properties) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer010
-
Creates a new Kafka streaming source consumer for Kafka 0.10.x.
- FlinkKafkaConsumer011<T> - Class in org.apache.flink.streaming.connectors.kafka
-
The Flink Kafka Consumer is a streaming data source that pulls a parallel data stream from
Apache Kafka 0.11.x.
- FlinkKafkaConsumer011(String, DeserializationSchema<T>, Properties) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer011
-
Creates a new Kafka streaming source consumer for Kafka 0.11.x.
- FlinkKafkaConsumer011(String, KeyedDeserializationSchema<T>, Properties) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer011
-
Creates a new Kafka streaming source consumer for Kafka 0.11.x
- FlinkKafkaConsumer011(List<String>, DeserializationSchema<T>, Properties) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer011
-
Creates a new Kafka streaming source consumer for Kafka 0.11.x
- FlinkKafkaConsumer011(List<String>, KeyedDeserializationSchema<T>, Properties) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer011
-
Creates a new Kafka streaming source consumer for Kafka 0.11.x
- FlinkKafkaConsumer011(Pattern, DeserializationSchema<T>, Properties) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer011
-
Creates a new Kafka streaming source consumer for Kafka 0.11.x.
- FlinkKafkaConsumer011(Pattern, KeyedDeserializationSchema<T>, Properties) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer011
-
Creates a new Kafka streaming source consumer for Kafka 0.11.x.
- FlinkKafkaConsumer08<T> - Class in org.apache.flink.streaming.connectors.kafka
-
The Flink Kafka Consumer is a streaming data source that pulls a parallel data stream from
Apache Kafka 0.8.x.
- FlinkKafkaConsumer08(String, DeserializationSchema<T>, Properties) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer08
-
Creates a new Kafka streaming source consumer for Kafka 0.8.x.
- FlinkKafkaConsumer08(String, KeyedDeserializationSchema<T>, Properties) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer08
-
Creates a new Kafka streaming source consumer for Kafka 0.8.x
- FlinkKafkaConsumer08(List<String>, DeserializationSchema<T>, Properties) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer08
-
Creates a new Kafka streaming source consumer for Kafka 0.8.x
- FlinkKafkaConsumer08(List<String>, KeyedDeserializationSchema<T>, Properties) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer08
-
Creates a new Kafka streaming source consumer for Kafka 0.8.x
- FlinkKafkaConsumer08(Pattern, DeserializationSchema<T>, Properties) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer08
-
Creates a new Kafka streaming source consumer for Kafka 0.8.x.
- FlinkKafkaConsumer08(Pattern, KeyedDeserializationSchema<T>, Properties) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer08
-
Creates a new Kafka streaming source consumer for Kafka 0.8.x.
- FlinkKafkaConsumer081<T> - Class in org.apache.flink.streaming.connectors.kafka
-
- FlinkKafkaConsumer081(String, DeserializationSchema<T>, Properties) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer081
-
- FlinkKafkaConsumer082<T> - Class in org.apache.flink.streaming.connectors.kafka
-
- FlinkKafkaConsumer082(String, DeserializationSchema<T>, Properties) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer082
-
- FlinkKafkaConsumer09<T> - Class in org.apache.flink.streaming.connectors.kafka
-
The Flink Kafka Consumer is a streaming data source that pulls a parallel data stream from
Apache Kafka 0.9.x.
- FlinkKafkaConsumer09(String, DeserializationSchema<T>, Properties) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer09
-
Creates a new Kafka streaming source consumer for Kafka 0.9.x .
- FlinkKafkaConsumer09(String, KeyedDeserializationSchema<T>, Properties) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer09
-
Creates a new Kafka streaming source consumer for Kafka 0.9.x
- FlinkKafkaConsumer09(List<String>, DeserializationSchema<T>, Properties) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer09
-
Creates a new Kafka streaming source consumer for Kafka 0.9.x
- FlinkKafkaConsumer09(List<String>, KeyedDeserializationSchema<T>, Properties) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer09
-
Creates a new Kafka streaming source consumer for Kafka 0.9.x
- FlinkKafkaConsumer09(Pattern, DeserializationSchema<T>, Properties) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer09
-
Creates a new Kafka streaming source consumer for Kafka 0.9.x.
- FlinkKafkaConsumer09(Pattern, KeyedDeserializationSchema<T>, Properties) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer09
-
Creates a new Kafka streaming source consumer for Kafka 0.9.x.
- FlinkKafkaConsumerBase<T> - Class in org.apache.flink.streaming.connectors.kafka
-
Base class of all Flink Kafka Consumer data sources.
- FlinkKafkaConsumerBase(List<String>, Pattern, KeyedDeserializationSchema<T>, long, boolean) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumerBase
-
Base constructor.
- FlinkKafkaDelegatePartitioner<T> - Class in org.apache.flink.streaming.connectors.kafka.partitioner
-
- FlinkKafkaDelegatePartitioner(KafkaPartitioner<T>) - Constructor for class org.apache.flink.streaming.connectors.kafka.partitioner.FlinkKafkaDelegatePartitioner
-
Deprecated.
- flinkKafkaPartitioner - Variable in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducerBase
-
User-provided partitioner for assigning an object to a Kafka partition for each topic.
- FlinkKafkaPartitioner<T> - Class in org.apache.flink.streaming.connectors.kafka.partitioner
-
A
FlinkKafkaPartitioner
wraps logic on how to partition records
across partitions of multiple Kafka topics.
- FlinkKafkaPartitioner() - Constructor for class org.apache.flink.streaming.connectors.kafka.partitioner.FlinkKafkaPartitioner
-
- FlinkKafkaProducer<IN> - Class in org.apache.flink.streaming.connectors.kafka
-
- FlinkKafkaProducer(String, String, SerializationSchema<IN>) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer
-
- FlinkKafkaProducer(String, SerializationSchema<IN>, Properties) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer
-
- FlinkKafkaProducer(String, SerializationSchema<IN>, Properties, KafkaPartitioner) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer
-
- FlinkKafkaProducer(String, String, KeyedSerializationSchema<IN>) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer
-
- FlinkKafkaProducer(String, KeyedSerializationSchema<IN>, Properties) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer
-
- FlinkKafkaProducer(String, KeyedSerializationSchema<IN>, Properties, KafkaPartitioner) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer
-
- FlinkKafkaProducer<K,V> - Class in org.apache.flink.streaming.connectors.kafka.internal
-
Wrapper around KafkaProducer that allows to resume transactions in case of node failure, which allows to implement
two phase commit algorithm for exactly-once semantic FlinkKafkaProducer.
- FlinkKafkaProducer(Properties) - Constructor for class org.apache.flink.streaming.connectors.kafka.internal.FlinkKafkaProducer
-
- FlinkKafkaProducer010<T> - Class in org.apache.flink.streaming.connectors.kafka
-
Flink Sink to produce data into a Kafka topic.
- FlinkKafkaProducer010(String, String, SerializationSchema<T>) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer010
-
Creates a FlinkKafkaProducer for a given topic.
- FlinkKafkaProducer010(String, SerializationSchema<T>, Properties) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer010
-
Creates a FlinkKafkaProducer for a given topic.
- FlinkKafkaProducer010(String, SerializationSchema<T>, Properties, FlinkKafkaPartitioner<T>) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer010
-
Creates a FlinkKafkaProducer for a given topic.
- FlinkKafkaProducer010(String, String, KeyedSerializationSchema<T>) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer010
-
Creates a FlinkKafkaProducer for a given topic.
- FlinkKafkaProducer010(String, KeyedSerializationSchema<T>, Properties) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer010
-
Creates a FlinkKafkaProducer for a given topic.
- FlinkKafkaProducer010(String, KeyedSerializationSchema<T>, Properties, FlinkKafkaPartitioner<T>) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer010
-
Creates a FlinkKafkaProducer for a given topic.
- FlinkKafkaProducer010(String, SerializationSchema<T>, Properties, KafkaPartitioner<T>) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer010
-
- FlinkKafkaProducer010(String, KeyedSerializationSchema<T>, Properties, KafkaPartitioner<T>) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer010
-
- FlinkKafkaProducer010.FlinkKafkaProducer010Configuration<T> - Class in org.apache.flink.streaming.connectors.kafka
-
- FlinkKafkaProducer011<IN> - Class in org.apache.flink.streaming.connectors.kafka
-
Flink Sink to produce data into a Kafka topic.
- FlinkKafkaProducer011(String, String, SerializationSchema<IN>) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer011
-
Creates a FlinkKafkaProducer for a given topic.
- FlinkKafkaProducer011(String, SerializationSchema<IN>, Properties) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer011
-
Creates a FlinkKafkaProducer for a given topic.
- FlinkKafkaProducer011(String, SerializationSchema<IN>, Properties, Optional<FlinkKafkaPartitioner<IN>>) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer011
-
Creates a FlinkKafkaProducer for a given topic.
- FlinkKafkaProducer011(String, String, KeyedSerializationSchema<IN>) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer011
-
Creates a FlinkKafkaProducer for a given topic.
- FlinkKafkaProducer011(String, KeyedSerializationSchema<IN>, Properties) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer011
-
Creates a FlinkKafkaProducer for a given topic.
- FlinkKafkaProducer011(String, KeyedSerializationSchema<IN>, Properties, FlinkKafkaProducer011.Semantic) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer011
-
Creates a FlinkKafkaProducer for a given topic.
- FlinkKafkaProducer011(String, KeyedSerializationSchema<IN>, Properties, Optional<FlinkKafkaPartitioner<IN>>) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer011
-
Creates a FlinkKafkaProducer for a given topic.
- FlinkKafkaProducer011(String, KeyedSerializationSchema<IN>, Properties, Optional<FlinkKafkaPartitioner<IN>>, FlinkKafkaProducer011.Semantic, int) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer011
-
Creates a FlinkKafkaProducer for a given topic.
- FlinkKafkaProducer011.ContextStateSerializer - Class in org.apache.flink.streaming.connectors.kafka
-
- FlinkKafkaProducer011.KafkaTransactionContext - Class in org.apache.flink.streaming.connectors.kafka
-
- FlinkKafkaProducer011.NextTransactionalIdHint - Class in org.apache.flink.streaming.connectors.kafka
-
Keep information required to deduce next safe to use transactional id.
- FlinkKafkaProducer011.Semantic - Enum in org.apache.flink.streaming.connectors.kafka
-
Semantics that can be chosen.
- FlinkKafkaProducer011.TransactionStateSerializer - Class in org.apache.flink.streaming.connectors.kafka
-
- FlinkKafkaProducer08<IN> - Class in org.apache.flink.streaming.connectors.kafka
-
Flink Sink to produce data into a Kafka topic.
- FlinkKafkaProducer08(String, String, SerializationSchema<IN>) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer08
-
Creates a FlinkKafkaProducer for a given topic.
- FlinkKafkaProducer08(String, SerializationSchema<IN>, Properties) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer08
-
Creates a FlinkKafkaProducer for a given topic.
- FlinkKafkaProducer08(String, SerializationSchema<IN>, Properties, FlinkKafkaPartitioner<IN>) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer08
-
Creates a FlinkKafkaProducer for a given topic.
- FlinkKafkaProducer08(String, String, KeyedSerializationSchema<IN>) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer08
-
Creates a FlinkKafkaProducer for a given topic.
- FlinkKafkaProducer08(String, KeyedSerializationSchema<IN>, Properties) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer08
-
Creates a FlinkKafkaProducer for a given topic.
- FlinkKafkaProducer08(String, KeyedSerializationSchema<IN>, Properties, FlinkKafkaPartitioner<IN>) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer08
-
Creates a FlinkKafkaProducer for a given topic.
- FlinkKafkaProducer08(String, SerializationSchema<IN>, Properties, KafkaPartitioner<IN>) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer08
-
- FlinkKafkaProducer08(String, KeyedSerializationSchema<IN>, Properties, KafkaPartitioner<IN>) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer08
-
- FlinkKafkaProducer09<IN> - Class in org.apache.flink.streaming.connectors.kafka
-
Flink Sink to produce data into a Kafka topic.
- FlinkKafkaProducer09(String, String, SerializationSchema<IN>) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer09
-
Creates a FlinkKafkaProducer for a given topic.
- FlinkKafkaProducer09(String, SerializationSchema<IN>, Properties) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer09
-
Creates a FlinkKafkaProducer for a given topic.
- FlinkKafkaProducer09(String, SerializationSchema<IN>, Properties, FlinkKafkaPartitioner<IN>) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer09
-
Creates a FlinkKafkaProducer for a given topic.
- FlinkKafkaProducer09(String, String, KeyedSerializationSchema<IN>) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer09
-
Creates a FlinkKafkaProducer for a given topic.
- FlinkKafkaProducer09(String, KeyedSerializationSchema<IN>, Properties) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer09
-
Creates a FlinkKafkaProducer for a given topic.
- FlinkKafkaProducer09(String, KeyedSerializationSchema<IN>, Properties, FlinkKafkaPartitioner<IN>) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer09
-
Creates a FlinkKafkaProducer for a given topic.
- FlinkKafkaProducer09(String, SerializationSchema<IN>, Properties, KafkaPartitioner<IN>) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer09
-
- FlinkKafkaProducer09(String, KeyedSerializationSchema<IN>, Properties, KafkaPartitioner<IN>) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer09
-
- FlinkKafkaProducerBase<IN> - Class in org.apache.flink.streaming.connectors.kafka
-
Flink Sink to produce data into a Kafka topic.
- FlinkKafkaProducerBase(String, KeyedSerializationSchema<IN>, Properties, FlinkKafkaPartitioner<IN>) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducerBase
-
The main constructor for creating a FlinkKafkaProducer.
- FlinkLocalCluster - Class in org.apache.flink.storm.api
-
- FlinkLocalCluster() - Constructor for class org.apache.flink.storm.api.FlinkLocalCluster
-
- FlinkLocalCluster(FlinkMiniCluster) - Constructor for class org.apache.flink.storm.api.FlinkLocalCluster
-
- FlinkLocalCluster.DefaultLocalClusterFactory - Class in org.apache.flink.storm.api
-
A factory that instantiates a FlinkLocalCluster.
- FlinkLocalCluster.LocalClusterFactory - Interface in org.apache.flink.storm.api
-
A factory that creates local clusters.
- FlinkMeterWrapper - Class in org.apache.flink.dropwizard.metrics
-
Wrapper to use a Flink
Meter
as a Dropwizard
Meter
.
- FlinkMeterWrapper(Meter) - Constructor for class org.apache.flink.dropwizard.metrics.FlinkMeterWrapper
-
- FlinkMeterWrapper(Meter, Clock) - Constructor for class org.apache.flink.dropwizard.metrics.FlinkMeterWrapper
-
- FlinkPlan - Interface in org.apache.flink.optimizer.plan
-
A common interface for compiled Flink plans for both batch and streaming
processing programs.
- FlinkResourceManager<WorkerType extends ResourceIDRetrievable> - Class in org.apache.flink.runtime.clusterframework
-
Worker allocation steps
- FlinkResourceManager(int, Configuration, LeaderRetrievalService) - Constructor for class org.apache.flink.runtime.clusterframework.FlinkResourceManager
-
Creates a AbstractFrameworkMaster actor.
- FlinkRuntimeException - Exception in org.apache.flink.util
-
Base class of all Flink-specific unchecked exceptions.
- FlinkRuntimeException(String) - Constructor for exception org.apache.flink.util.FlinkRuntimeException
-
Creates a new Exception with the given message and null as the cause.
- FlinkRuntimeException(Throwable) - Constructor for exception org.apache.flink.util.FlinkRuntimeException
-
Creates a new exception with a null message and the given cause.
- FlinkRuntimeException(String, Throwable) - Constructor for exception org.apache.flink.util.FlinkRuntimeException
-
Creates a new exception with the given message and cause.
- FlinkSubmitter - Class in org.apache.flink.storm.api
-
FlinkSubmitter
mimics a
StormSubmitter
to submit Storm topologies to a Flink cluster.
- FlinkSubmitter() - Constructor for class org.apache.flink.storm.api.FlinkSubmitter
-
- FlinkSubmitter.FlinkProgressListener - Interface in org.apache.flink.storm.api
-
Dummy interface use to track progress of file upload.
- FlinkTopology - Class in org.apache.flink.storm.api
-
- FlinkUntypedActor - Class in org.apache.flink.runtime.akka
-
Base class for Flink's actors implemented with Java.
- FlinkUntypedActor() - Constructor for class org.apache.flink.runtime.akka.FlinkUntypedActor
-
- FlinkUserCodeClassLoaders - Class in org.apache.flink.runtime.execution.librarycache
-
Gives the URLClassLoader a nicer name for debugging purposes.
- FlinkUserCodeClassLoaders() - Constructor for class org.apache.flink.runtime.execution.librarycache.FlinkUserCodeClassLoaders
-
- FlinkUserCodeClassLoaders.ResolveOrder - Enum in org.apache.flink.runtime.execution.librarycache
-
- FlinkYarnSessionCli - Class in org.apache.flink.yarn.cli
-
Class handling the command line interface to the YARN session.
- FlinkYarnSessionCli(Configuration, String, String, String) - Constructor for class org.apache.flink.yarn.cli.FlinkYarnSessionCli
-
- FlinkYarnSessionCli(Configuration, String, String, String, boolean) - Constructor for class org.apache.flink.yarn.cli.FlinkYarnSessionCli
-
- FlinkZooKeeperQuorumPeer - Class in org.apache.flink.runtime.zookeeper
-
Simple wrapper for ZooKeeper's QuorumPeer
, which reads a ZooKeeper config file and writes
the required 'myid' file before starting the peer.
- FlinkZooKeeperQuorumPeer() - Constructor for class org.apache.flink.runtime.zookeeper.FlinkZooKeeperQuorumPeer
-
- flip() - Method in class org.apache.flink.runtime.io.disk.SpillingBuffer
-
- flipVertices() - Method in class org.apache.flink.examples.java.graph.util.EnumTrianglesDataTypes.Edge
-
- FLOAT - Static variable in class org.apache.flink.api.common.typeinfo.Types
-
Returns type information for both a primitive
float
and
Float
.
- FLOAT_ARRAY_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
-
- FLOAT_PRIMITIVE_ARRAY_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
-
- FLOAT_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
-
- FLOAT_VALUE_TYPE_INFO - Static variable in class org.apache.flink.api.java.typeutils.ValueTypeInfo
-
- FloatComparator - Class in org.apache.flink.api.common.typeutils.base
-
- FloatComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.FloatComparator
-
- floatingNetworkBuffersPerGate() - Method in class org.apache.flink.runtime.taskmanager.NetworkEnvironmentConfiguration
-
- FloatParser - Class in org.apache.flink.types.parser
-
Parses a text field into a
Float
.
- FloatParser() - Constructor for class org.apache.flink.types.parser.FloatParser
-
- FloatPrimitiveArrayComparator - Class in org.apache.flink.api.common.typeutils.base.array
-
- FloatPrimitiveArrayComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.array.FloatPrimitiveArrayComparator
-
- FloatPrimitiveArraySerializer - Class in org.apache.flink.api.common.typeutils.base.array
-
A serializer for float arrays.
- FloatPrimitiveArraySerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.array.FloatPrimitiveArraySerializer
-
- FloatSerializer - Class in org.apache.flink.api.common.typeutils.base
-
- FloatSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.FloatSerializer
-
- FloatSerializer() - Constructor for class org.apache.flink.python.api.streaming.util.SerializationUtils.FloatSerializer
-
- FloatSummaryAggregator - Class in org.apache.flink.api.java.summarize.aggregation
-
Aggregator that can handle Float types.
- FloatSummaryAggregator() - Constructor for class org.apache.flink.api.java.summarize.aggregation.FloatSummaryAggregator
-
- FloatSummaryAggregator.MaxFloatAggregator - Class in org.apache.flink.api.java.summarize.aggregation
-
Aggregator for max operation.
- FloatSummaryAggregator.MinFloatAggregator - Class in org.apache.flink.api.java.summarize.aggregation
-
Aggregator for min operation.
- FloatSummaryAggregator.SumFloatAggregator - Class in org.apache.flink.api.java.summarize.aggregation
-
Aggregator for sum operation.
- FloatValue - Class in org.apache.flink.types
-
Boxed serializable and comparable single precision floating point type, representing the primitive
type float
.
- FloatValue() - Constructor for class org.apache.flink.types.FloatValue
-
Initializes the encapsulated float with 0.0.
- FloatValue(float) - Constructor for class org.apache.flink.types.FloatValue
-
Initializes the encapsulated float with the provided value.
- FloatValueArray - Class in org.apache.flink.graph.types.valuearray
-
- FloatValueArray() - Constructor for class org.apache.flink.graph.types.valuearray.FloatValueArray
-
Initializes an expandable array with default capacity.
- FloatValueArray(int) - Constructor for class org.apache.flink.graph.types.valuearray.FloatValueArray
-
Initializes a fixed-size array with the provided number of floats.
- FloatValueArrayComparator - Class in org.apache.flink.graph.types.valuearray
-
Specialized comparator for FloatValueArray based on CopyableValueComparator.
- FloatValueArrayComparator(boolean) - Constructor for class org.apache.flink.graph.types.valuearray.FloatValueArrayComparator
-
- FloatValueArraySerializer - Class in org.apache.flink.graph.types.valuearray
-
Specialized serializer for FloatValueArray
.
- FloatValueArraySerializer() - Constructor for class org.apache.flink.graph.types.valuearray.FloatValueArraySerializer
-
- FloatValueComparator - Class in org.apache.flink.api.common.typeutils.base
-
Specialized comparator for FloatValue based on CopyableValueComparator.
- FloatValueComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.FloatValueComparator
-
- FloatValueParser - Class in org.apache.flink.types.parser
-
- FloatValueParser() - Constructor for class org.apache.flink.types.parser.FloatValueParser
-
- FloatValueSerializer - Class in org.apache.flink.api.common.typeutils.base
-
- FloatValueSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.FloatValueSerializer
-
- FloatValueSummaryAggregator() - Constructor for class org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator.FloatValueSummaryAggregator
-
- floorDiv(long, long) - Static method in class org.apache.calcite.avatica.util.DateTimeUtils
-
Divide, rounding towards negative infinity.
- floorMod(long, long) - Static method in class org.apache.calcite.avatica.util.DateTimeUtils
-
Modulo, always returning a non-negative result.
- flush() - Method in class org.apache.flink.contrib.streaming.state.RocksDBWriteBatchWrapper
-
- flush() - Method in class org.apache.flink.core.fs.FSDataOutputStream
-
Flushes the stream, writing any data currently buffered in stream implementation
to the proper output stream.
- flush() - Method in class org.apache.flink.core.fs.FSDataOutputStreamWrapper
-
- flush() - Method in class org.apache.flink.core.fs.local.LocalDataOutputStream
-
- flush() - Method in class org.apache.flink.formats.avro.utils.DataOutputEncoder
-
- flush() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopDataOutputStream
-
- flush(int) - Method in interface org.apache.flink.runtime.io.network.api.writer.ResultPartitionWriter
-
Manually trigger consumption from enqueued
BufferConsumers
in one specified subpartition.
- flush(int) - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
-
- flush() - Method in class org.apache.flink.runtime.io.network.partition.ResultSubpartition
-
- flush() - Method in class org.apache.flink.runtime.iterative.io.SerializedUpdateBuffer
-
- flush() - Method in class org.apache.flink.runtime.state.DuplicatingCheckpointOutputStream
-
- flush() - Method in class org.apache.flink.runtime.state.filesystem.FileBasedStateOutputStream
-
- flush() - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointMetadataOutputStream
-
- flush() - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStreamFactory.FsCheckpointStateOutputStream
-
- flush() - Method in class org.apache.flink.runtime.state.memory.MemCheckpointStreamFactory.MemoryCheckpointOutputStream
-
- flush() - Method in class org.apache.flink.runtime.state.NonClosingCheckpointOutputStream
-
- flush() - Method in class org.apache.flink.runtime.util.ForwardingOutputStream
-
- flush() - Method in class org.apache.flink.streaming.connectors.fs.AvroKeyValueSinkWriter
-
- flush() - Method in class org.apache.flink.streaming.connectors.fs.StreamWriterBase
-
- flush() - Method in interface org.apache.flink.streaming.connectors.fs.Writer
-
Flushes out any internally held data, and returns the offset that the file
must be truncated to at recovery.
- flush() - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer08
-
- flush() - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer09
-
- flush() - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducerBase
-
Flush pending records.
- flush() - Method in class org.apache.flink.streaming.connectors.kafka.internal.FlinkKafkaProducer
-
- flush() - Method in class org.apache.flink.streaming.runtime.io.RecordWriterOutput
-
- flushAll() - Method in class org.apache.flink.runtime.io.network.api.writer.RecordWriter
-
- flushAll() - Method in interface org.apache.flink.runtime.io.network.api.writer.ResultPartitionWriter
-
Manually trigger consumption from enqueued
BufferConsumers
in all subpartitions.
- flushAll() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
-
- flushOnCheckpoint - Variable in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducerBase
-
If true, the producer will wait until all outstanding records have been send to the broker.
- flushOutputs() - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
-
This method should be called before finishing the record emission, to make sure any data
that is still buffered will be sent.
- fold(T, O) - Method in interface org.apache.flink.api.common.functions.FoldFunction
-
Deprecated.
The core method of FoldFunction, combining two values into one value of the same type.
- fold(T, O) - Method in class org.apache.flink.api.common.functions.RichFoldFunction
-
Deprecated.
- fold(R, FoldFunction<T, R>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
- fold(R, FoldFunction<T, R>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
- fold(ACC, FoldFunction<T, ACC>, AllWindowFunction<ACC, R, W>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
- fold(ACC, FoldFunction<T, ACC>, AllWindowFunction<ACC, R, W>, TypeInformation<ACC>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
- fold(ACC, FoldFunction<T, ACC>, ProcessAllWindowFunction<ACC, R, W>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
- fold(ACC, FoldFunction<T, ACC>, ProcessAllWindowFunction<ACC, R, W>, TypeInformation<ACC>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
- fold(R, FoldFunction<T, R>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
- fold(R, FoldFunction<T, R>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
- fold(R, FoldFunction<T, R>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
- fold(ACC, FoldFunction<T, ACC>, WindowFunction<ACC, R, K, W>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
- fold(ACC, FoldFunction<T, ACC>, WindowFunction<ACC, R, K, W>, TypeInformation<ACC>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
- fold(ACC, FoldFunction<T, ACC>, ProcessWindowFunction<ACC, R, K, W>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
- fold(ACC, FoldFunction<T, ACC>, ProcessWindowFunction<ACC, R, K, W>, TypeInformation<ACC>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
- FoldApplyAllWindowFunction<W extends Window,T,ACC,R> - Class in org.apache.flink.streaming.api.functions.windowing
-
- FoldApplyAllWindowFunction(ACC, FoldFunction<T, ACC>, AllWindowFunction<ACC, R, W>, TypeInformation<ACC>) - Constructor for class org.apache.flink.streaming.api.functions.windowing.FoldApplyAllWindowFunction
-
Deprecated.
- FoldApplyProcessAllWindowFunction<W extends Window,T,ACC,R> - Class in org.apache.flink.streaming.api.functions.windowing
-
- FoldApplyProcessAllWindowFunction(ACC, FoldFunction<T, ACC>, ProcessAllWindowFunction<ACC, R, W>, TypeInformation<ACC>) - Constructor for class org.apache.flink.streaming.api.functions.windowing.FoldApplyProcessAllWindowFunction
-
Deprecated.
- FoldApplyProcessWindowFunction<K,W extends Window,T,ACC,R> - Class in org.apache.flink.streaming.api.functions.windowing
-
- FoldApplyProcessWindowFunction(ACC, FoldFunction<T, ACC>, ProcessWindowFunction<ACC, R, K, W>, TypeInformation<ACC>) - Constructor for class org.apache.flink.streaming.api.functions.windowing.FoldApplyProcessWindowFunction
-
Deprecated.
- FoldApplyWindowFunction<K,W extends Window,T,ACC,R> - Class in org.apache.flink.streaming.api.functions.windowing
-
- FoldApplyWindowFunction(ACC, FoldFunction<T, ACC>, WindowFunction<ACC, R, K, W>, TypeInformation<ACC>) - Constructor for class org.apache.flink.streaming.api.functions.windowing.FoldApplyWindowFunction
-
Deprecated.
- FoldFunction<O,T> - Interface in org.apache.flink.api.common.functions
-
- FoldingState<T,ACC> - Interface in org.apache.flink.api.common.state
-
- FoldingStateDescriptor<T,ACC> - Class in org.apache.flink.api.common.state
-
- FoldingStateDescriptor(String, ACC, FoldFunction<T, ACC>, Class<ACC>) - Constructor for class org.apache.flink.api.common.state.FoldingStateDescriptor
-
Deprecated.
Creates a new FoldingStateDescriptor
with the given name, type, and initial value.
- FoldingStateDescriptor(String, ACC, FoldFunction<T, ACC>, TypeInformation<ACC>) - Constructor for class org.apache.flink.api.common.state.FoldingStateDescriptor
-
Deprecated.
Creates a new FoldingStateDescriptor
with the given name and default value.
- FoldingStateDescriptor(String, ACC, FoldFunction<T, ACC>, TypeSerializer<ACC>) - Constructor for class org.apache.flink.api.common.state.FoldingStateDescriptor
-
Deprecated.
Creates a new ValueStateDescriptor
with the given name and default value.
- followedBy(String) - Method in class org.apache.flink.cep.pattern.Pattern
-
Appends a new pattern to the existing one.
- followedBy(Pattern<T, F>) - Method in class org.apache.flink.cep.pattern.Pattern
-
Appends a new group pattern to the existing one.
- followedByAny(String) - Method in class org.apache.flink.cep.pattern.Pattern
-
Appends a new pattern to the existing one.
- followedByAny(Pattern<T, F>) - Method in class org.apache.flink.cep.pattern.Pattern
-
Appends a new group pattern to the existing one.
- forAvroRecordClass(Class<? extends SpecificRecordBase>) - Method in class org.apache.flink.streaming.connectors.kafka.KafkaAvroTableSource.Builder
-
Sets the class of the Avro records that are read from the Kafka topic.
- forceNonParallel() - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
-
Sets the parallelism and maximum parallelism of this operator to one.
- forceSeek(long) - Method in class org.apache.flink.runtime.fs.hdfs.HadoopDataInputStream
-
Positions the stream to the given location.
- forCheckpoint(CheckpointRetentionPolicy) - Static method in class org.apache.flink.runtime.checkpoint.CheckpointProperties
-
Creates the checkpoint properties for a checkpoint.
- forCheckpointWithDefaultLocation() - Static method in class org.apache.flink.runtime.checkpoint.CheckpointOptions
-
- forGrouping(FieldList) - Static method in class org.apache.flink.optimizer.dataproperties.LocalProperties
-
- forJsonSchema(TableSchema) - Method in class org.apache.flink.streaming.connectors.kafka.KafkaJsonTableSource.Builder
-
Sets the schema of the JSON-encoded Kafka messages.
- FORK_JOIN_EXECUTOR_PARALLELISM_FACTOR - Static variable in class org.apache.flink.configuration.AkkaOptions
-
- FORK_JOIN_EXECUTOR_PARALLELISM_MAX - Static variable in class org.apache.flink.configuration.AkkaOptions
-
- FORK_JOIN_EXECUTOR_PARALLELISM_MIN - Static variable in class org.apache.flink.configuration.AkkaOptions
-
- format(IN) - Method in interface org.apache.flink.api.java.io.TextOutputFormat.TextFormatter
-
- format() - Method in class org.apache.flink.runtime.metrics.scope.ScopeFormat
-
- format(Tuple) - Method in interface org.apache.flink.storm.util.OutputFormatter
-
Converts a Storm Tuple
to a string.
- format(Tuple) - Method in class org.apache.flink.storm.util.SimpleOutputFormatter
-
Converts a Storm Tuple
with 1 field to a string by retrieving the value of that field.
- format(Tuple) - Method in class org.apache.flink.storm.util.TupleOutputFormatter
-
- format - Variable in class org.apache.flink.streaming.api.functions.sink.WriteSinkFunction
-
Deprecated.
- FORMAT_FAIL_ON_MISSING_FIELD - Static variable in class org.apache.flink.table.descriptors.JsonValidator
-
- FORMAT_JSON_SCHEMA - Static variable in class org.apache.flink.table.descriptors.JsonValidator
-
- FORMAT_SCHEMA - Static variable in class org.apache.flink.table.descriptors.JsonValidator
-
- FORMAT_TYPE_VALUE - Static variable in class org.apache.flink.table.descriptors.JsonValidator
-
- formatAddress(int) - Static method in class org.apache.flink.streaming.examples.statemachine.event.Event
-
Util method to create a string representation of a 32 bit integer representing
an IPv4 address.
- formatLogString(String) - Method in class org.apache.flink.runtime.operators.BatchTask
-
- formatLogString(String) - Method in interface org.apache.flink.runtime.operators.TaskContext
-
- formatNumber(double) - Static method in class org.apache.flink.optimizer.plandump.PlanJSONDumpGenerator
-
- formatNumber(double, String) - Static method in class org.apache.flink.optimizer.plandump.PlanJSONDumpGenerator
-
- formatScope(JobManagerMetricGroup, JobID, String) - Method in class org.apache.flink.runtime.metrics.scope.JobManagerJobScopeFormat
-
- formatScope(String) - Method in class org.apache.flink.runtime.metrics.scope.JobManagerScopeFormat
-
- formatScope(TaskMetricGroup, OperatorID, String) - Method in class org.apache.flink.runtime.metrics.scope.OperatorScopeFormat
-
- formatScope(TaskManagerMetricGroup, JobID, String) - Method in class org.apache.flink.runtime.metrics.scope.TaskManagerJobScopeFormat
-
- formatScope(String, String) - Method in class org.apache.flink.runtime.metrics.scope.TaskManagerScopeFormat
-
- formatScope(TaskManagerJobMetricGroup, AbstractID, AbstractID, String, int, int) - Method in class org.apache.flink.runtime.metrics.scope.TaskScopeFormat
-
- formatSystemProperties(Configuration) - Static method in class org.apache.flink.runtime.clusterframework.ContainerSpecification
-
Format the system properties as a shell-compatible command-line argument.
- FormattingMapper<T> - Class in org.apache.flink.api.java.functions
-
- FormattingMapper(TextOutputFormat.TextFormatter<T>) - Constructor for class org.apache.flink.api.java.functions.FormattingMapper
-
- formatTwoLineHelpOptions(int, List<Tuple2<String, String>>) - Static method in class org.apache.flink.table.client.cli.CliUtils
-
- formatWrapper - Variable in class org.apache.flink.api.common.operators.GenericDataSinkBase
-
- formatWrapper - Variable in class org.apache.flink.api.common.operators.GenericDataSourceBase
-
- forOrcSchema(String) - Method in class org.apache.flink.orc.OrcTableSource.Builder
-
Sets the ORC schema of the files to read as a String.
- forOrcSchema(TypeDescription) - Method in class org.apache.flink.orc.OrcTableSource.Builder
-
Sets the ORC schema of the files to read as a TypeDescription
.
- forOrdering(Ordering) - Static method in class org.apache.flink.optimizer.dataproperties.LocalProperties
-
- forPath(String) - Static method in class org.apache.flink.runtime.jobgraph.SavepointRestoreSettings
-
- forPath(String, boolean) - Static method in class org.apache.flink.runtime.jobgraph.SavepointRestoreSettings
-
- forSavepoint() - Static method in class org.apache.flink.runtime.checkpoint.CheckpointProperties
-
Creates the checkpoint properties for a (manually triggered) savepoint.
- forSingleJobAppMaster(Configuration, Configuration) - Static method in class org.apache.flink.yarn.highavailability.YarnHighAvailabilityServices
-
Creates the high-availability services for a single-job Flink YARN application, to be
used in the Application Master that runs both ResourceManager and JobManager.
- forTimestamp(long) - Static method in class org.apache.flink.streaming.api.functions.sink.SinkContextUtil
-
Creates a
SinkFunction.Context
that
throws an exception when trying to access the current watermark or processing time.
- forTopic(String) - Method in class org.apache.flink.streaming.connectors.kafka.KafkaTableSource.Builder
-
Sets the topic from which the table is read.
- forward(Object, ActorGateway) - Method in interface org.apache.flink.runtime.instance.ActorGateway
-
Forwards a message.
- forward(Object, ActorGateway) - Method in class org.apache.flink.runtime.instance.AkkaActorGateway
-
Forwards a message.
- forward() - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Sets the partitioning of the
DataStream
so that the output elements
are forwarded to the local subtask of the next operation.
- ForwardingInputStream - Class in org.apache.flink.runtime.util
-
Input stream, that wraps another input stream and forwards all method calls to the wrapped stream.
- ForwardingInputStream(InputStream) - Constructor for class org.apache.flink.runtime.util.ForwardingInputStream
-
- ForwardingOutputStream - Class in org.apache.flink.runtime.util
-
Output stream, that wraps another input stream and forwards all method calls to the wrapped stream.
- ForwardingOutputStream(OutputStream) - Constructor for class org.apache.flink.runtime.util.ForwardingOutputStream
-
- ForwardPartitioner<T> - Class in org.apache.flink.streaming.runtime.partitioner
-
Partitioner that forwards elements only to the locally running downstream operation.
- ForwardPartitioner() - Constructor for class org.apache.flink.streaming.runtime.partitioner.ForwardPartitioner
-
- forYarnTaskManager(Configuration, Configuration) - Static method in class org.apache.flink.yarn.highavailability.YarnHighAvailabilityServices
-
Creates the high-availability services for the TaskManagers participating in
a Flink YARN application.
- FractionalTypeInfo<T> - Class in org.apache.flink.api.common.typeinfo
-
Type information for numeric fractional primitive types (double, float).
- FractionalTypeInfo(Class<T>, Class<?>[], TypeSerializer<T>, Class<? extends TypeComparator<T>>) - Constructor for class org.apache.flink.api.common.typeinfo.FractionalTypeInfo
-
- FRAMESIZE - Static variable in class org.apache.flink.configuration.AkkaOptions
-
Maximum framesize of akka messages.
- frameworkId() - Method in class org.apache.flink.mesos.scheduler.messages.Registered
-
- frameworkInfo() - Method in class org.apache.flink.mesos.util.MesosConfiguration
-
The framework registration info.
- frameworkMessage(FrameworkMessage) - Method in class org.apache.flink.mesos.runtime.clusterframework.MesosResourceManager
-
- FrameworkMessage - Class in org.apache.flink.mesos.scheduler.messages
-
Message sent when an executor sends a message.
- FrameworkMessage(Protos.ExecutorID, Protos.SlaveID, byte[]) - Constructor for class org.apache.flink.mesos.scheduler.messages.FrameworkMessage
-
- frameworkMessage(SchedulerDriver, Protos.ExecutorID, Protos.SlaveID, byte[]) - Method in class org.apache.flink.mesos.scheduler.SchedulerProxy
-
- free() - Method in class org.apache.flink.core.memory.HeapMemorySegment
-
- free() - Method in class org.apache.flink.core.memory.MemorySegment
-
Frees this memory segment.
- FreeingBufferRecycler - Class in org.apache.flink.runtime.io.network.buffer
-
A simple buffer recycler that frees the memory segments.
- freeSlot() - Method in class org.apache.flink.runtime.clusterframework.types.TaskManagerSlot
-
- freeSlot(AllocationID, Throwable, Time) - Method in class org.apache.flink.runtime.jobmanager.slots.ActorTaskManagerGateway
-
- freeSlot(AllocationID, Throwable, Time) - Method in interface org.apache.flink.runtime.jobmanager.slots.TaskManagerGateway
-
Frees the slot with the given allocation ID.
- freeSlot(AllocationID, Throwable, Time) - Method in class org.apache.flink.runtime.jobmaster.RpcTaskManagerGateway
-
- freeSlot(SlotID, AllocationID) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
-
Free the given slot from the given allocation.
- freeSlot() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerRegistration
-
- freeSlot(AllocationID) - Method in interface org.apache.flink.runtime.taskexecutor.slot.SlotActions
-
Free the task slot with the given allocation id.
- freeSlot(AllocationID) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
-
Try to free the slot.
- freeSlot(AllocationID, Throwable) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
-
Tries to free the slot.
- freeSlot(AllocationID, Throwable, Time) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutor
-
- freeSlot(AllocationID, Throwable, Time) - Method in interface org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
-
Frees the slot with the given allocation ID.
- frequency - Variable in class org.apache.flink.table.examples.java.WordCountSQL.WC
-
- frequency - Variable in class org.apache.flink.table.examples.java.WordCountTable.WC
-
- frm - Variable in class org.apache.flink.python.api.PythonOperationInfo
-
- from(IntermediateResultPartition, int, boolean) - Static method in class org.apache.flink.runtime.deployment.ResultPartitionDeploymentDescriptor
-
- from(StoppableCallbackCallable<V>) - Static method in class org.apache.flink.runtime.io.async.AsyncStoppableTaskWithCallback
-
- from(Configuration) - Static method in class org.apache.flink.runtime.rest.messages.ClusterConfigurationInfo
-
- from(long, ZonedDateTime) - Static method in class org.apache.flink.runtime.rest.messages.DashboardConfiguration
-
- from(StreamRecord<T>) - Static method in class org.apache.flink.streaming.runtime.operators.windowing.TimestampedValue
-
- from_collection(Collection<Object>) - Method in class org.apache.flink.streaming.python.api.environment.PythonStreamExecutionEnvironment
-
- from_collection(Iterator<Object>) - Method in class org.apache.flink.streaming.python.api.environment.PythonStreamExecutionEnvironment
-
Creates a python data stream from the given iterator.
- from_elements(PyObject...) - Method in class org.apache.flink.streaming.python.api.environment.PythonStreamExecutionEnvironment
-
- fromApplicationOrConfigOrDefault(StateBackend, Configuration, ClassLoader, Logger) - Static method in class org.apache.flink.runtime.state.StateBackendLoader
-
Checks if an application-defined state backend is given, and if not, loads the state
backend from the configuration, from the parameter 'state.backend', as defined
in
CheckpointingOptions.STATE_BACKEND
.
- fromArgs(String[]) - Static method in class org.apache.flink.api.java.utils.ParameterTool
-
- fromBoolean(boolean) - Static method in enum org.apache.flink.util.TernaryBoolean
-
- fromBoxedBoolean(Boolean) - Static method in enum org.apache.flink.util.TernaryBoolean
-
Converts the given boxed Boolean to a TernaryBoolean.
- fromBuffer(Buffer, ClassLoader) - Static method in class org.apache.flink.runtime.io.network.api.serialization.EventSerializer
-
- fromByteArray(byte[]) - Static method in class org.apache.flink.api.common.JobID
-
Creates a new JobID from the given byte sequence.
- fromByteBuf(ByteBuf) - Static method in class org.apache.flink.runtime.executiongraph.ExecutionAttemptID
-
- fromByteBuf(ByteBuf) - Static method in class org.apache.flink.runtime.io.network.partition.consumer.InputChannelID
-
- fromByteBuf(ByteBuf) - Static method in class org.apache.flink.runtime.jobgraph.IntermediateResultPartitionID
-
- fromByteBuffer(ByteBuffer) - Static method in class org.apache.flink.api.common.JobID
-
- fromBytes(byte[]) - Static method in class org.apache.flink.util.SerializedValue
-
- fromCollection(Collection<X>) - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
Creates a DataSet from the given non-empty collection.
- fromCollection(Collection<X>, TypeInformation<X>) - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
Creates a DataSet from the given non-empty collection.
- fromCollection(Iterator<X>, Class<X>) - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
Creates a DataSet from the given iterator.
- fromCollection(Iterator<X>, TypeInformation<X>) - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
Creates a DataSet from the given iterator.
- fromCollection(Collection<Vertex<K, VV>>, Collection<Edge<K, EV>>, ExecutionEnvironment) - Static method in class org.apache.flink.graph.Graph
-
Creates a graph from a Collection of vertices and a Collection of edges.
- fromCollection(Collection<Edge<K, EV>>, ExecutionEnvironment) - Static method in class org.apache.flink.graph.Graph
-
Creates a graph from a Collection of edges.
- fromCollection(Collection<Edge<K, EV>>, MapFunction<K, VV>, ExecutionEnvironment) - Static method in class org.apache.flink.graph.Graph
-
Creates a graph from a Collection of edges.
- fromCollection(Collection<OUT>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Creates a data stream from the given non-empty collection.
- fromCollection(Collection<OUT>, TypeInformation<OUT>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Creates a data stream from the given non-empty collection.
- fromCollection(Iterator<OUT>, Class<OUT>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Creates a data stream from the given iterator.
- fromCollection(Iterator<OUT>, TypeInformation<OUT>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Creates a data stream from the given iterator.
- fromConfig(Configuration, String) - Static method in class 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.
- fromConfig(Configuration) - Static method in enum org.apache.flink.runtime.jobmanager.HighAvailabilityMode
-
- fromConfig(Configuration) - Static method in class org.apache.flink.runtime.metrics.scope.ScopeFormats
-
Creates the scope formats as defined in the given configuration.
- fromConfig(Configuration) - Static method in enum org.apache.flink.runtime.util.ZooKeeperUtils.ZkClientACLMode
-
- fromConfiguration(Configuration) - Static method in class org.apache.flink.client.deployment.ClusterSpecification
-
- fromConfiguration(Configuration) - Static method in class org.apache.flink.client.program.rest.RestClusterClientConfiguration
-
- fromConfiguration(Configuration) - Static method in class org.apache.flink.runtime.heartbeat.HeartbeatServices
-
- fromConfiguration(Configuration, BlobServer) - Static method in class org.apache.flink.runtime.jobmaster.JobManagerSharedServices
-
- fromConfiguration(Configuration) - Static method in class org.apache.flink.runtime.jobmaster.JobMasterConfiguration
-
- fromConfiguration(Configuration, RpcService) - Static method in class org.apache.flink.runtime.jobmaster.slotpool.DefaultSlotPoolFactory
-
- fromConfiguration(Configuration) - Static method in class org.apache.flink.runtime.metrics.MetricRegistryConfiguration
-
Create a metric registry configuration object from the given
Configuration
.
- fromConfiguration(Configuration) - Static method in class org.apache.flink.runtime.resourcemanager.ResourceManagerConfiguration
-
- fromConfiguration(ResourceManagerRuntimeServicesConfiguration, HighAvailabilityServices, ScheduledExecutor) - Static method in class org.apache.flink.runtime.resourcemanager.ResourceManagerRuntimeServices
-
- fromConfiguration(Configuration) - Static method in class org.apache.flink.runtime.resourcemanager.ResourceManagerRuntimeServicesConfiguration
-
- fromConfiguration(Configuration) - Static method in class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerConfiguration
-
- fromConfiguration(Configuration) - Static method in class org.apache.flink.runtime.rest.handler.RestHandlerConfiguration
-
- fromConfiguration(Configuration) - Static method in class org.apache.flink.runtime.rest.RestClientConfiguration
-
- fromConfiguration(Configuration) - Static method in class org.apache.flink.runtime.rest.RestServerEndpointConfiguration
-
- fromConfiguration(Configuration) - Static method in class org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
-
- fromConfiguration(TaskManagerServicesConfiguration, ResourceID, Executor, long, long) - Static method in class org.apache.flink.runtime.taskexecutor.TaskManagerServices
-
Creates and returns the task manager services.
- fromConfiguration(Configuration, InetAddress, boolean) - Static method in class org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
-
Utility method to extract TaskManager config parameters from the configuration and to
sanity check them.
- fromConfiguration(boolean, boolean, boolean) - Static method in class org.apache.flink.streaming.connectors.kafka.config.OffsetCommitModes
-
Determine the offset commit mode using several configuration values.
- fromCsvReader(String, String, ExecutionEnvironment) - Static method in class org.apache.flink.graph.Graph
-
Creates a Graph from a CSV file of vertices and a CSV file of edges.
- fromCsvReader(String, ExecutionEnvironment) - Static method in class org.apache.flink.graph.Graph
-
Creates a graph from a CSV file of edges.
- fromCsvReader(String, MapFunction<K, VV>, ExecutionEnvironment) - Static method in class org.apache.flink.graph.Graph
-
Creates a graph from a CSV file of edges.
- fromDataSet(DataSet<Vertex<KT, VVT>>, DataSet<Vertex<KB, VVB>>, DataSet<BipartiteEdge<KT, KB, EV>>, ExecutionEnvironment) - Static method in class org.apache.flink.graph.bipartite.BipartiteGraph
-
Create bipartite graph from datasets.
- fromDataSet(DataSet<Vertex<K, VV>>, DataSet<Edge<K, EV>>, ExecutionEnvironment) - Static method in class org.apache.flink.graph.Graph
-
Creates a graph from a DataSet of vertices and a DataSet of edges.
- fromDataSet(DataSet<Edge<K, EV>>, ExecutionEnvironment) - Static method in class org.apache.flink.graph.Graph
-
Creates a graph from a DataSet of edges.
- fromDataSet(DataSet<Edge<K, EV>>, MapFunction<K, VV>, ExecutionEnvironment) - Static method in class org.apache.flink.graph.Graph
-
Creates a graph from a DataSet of edges.
- fromEarliest() - Method in class org.apache.flink.streaming.connectors.kafka.KafkaTableSource.Builder
-
Configures the TableSource to start reading from the earliest offset for all partitions.
- fromEdge(IntermediateResultPartition, Execution) - Static method in class org.apache.flink.runtime.deployment.PartialInputChannelDeploymentDescriptor
-
Creates a partial input channel for the given partition and producing task.
- fromEdges(ExecutionEdge[], ResourceID, boolean) - Static method in class org.apache.flink.runtime.deployment.InputChannelDeploymentDescriptor
-
Creates an input channel deployment descriptor for each partition.
- fromElements(X...) - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
Creates a new data set that contains the given elements.
- fromElements(Class<X>, X...) - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
Creates a new data set that contains the given elements.
- fromElements(OUT...) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Creates a new data stream that contains the given elements.
- fromElements(Class<OUT>, OUT...) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Creates a new data set that contains the given elements.
- FromElementsFunction<T> - Class in org.apache.flink.streaming.api.functions.source
-
A stream source function that returns a sequence of elements.
- FromElementsFunction(TypeSerializer<T>, T...) - Constructor for class org.apache.flink.streaming.api.functions.source.FromElementsFunction
-
- FromElementsFunction(TypeSerializer<T>, Iterable<T>) - Constructor for class org.apache.flink.streaming.api.functions.source.FromElementsFunction
-
- fromEnvironment(Configuration) - Method in class org.apache.flink.runtime.clusterframework.overlays.FlinkDistributionOverlay.Builder
-
Configures the overlay using the current environment.
- fromEnvironment(Configuration) - Method in class org.apache.flink.runtime.clusterframework.overlays.HadoopConfOverlay.Builder
-
Configures the overlay using the current environment's Hadoop configuration.
- fromEnvironment(Configuration) - Method in class org.apache.flink.runtime.clusterframework.overlays.HadoopUserOverlay.Builder
-
Configures the overlay using the current Hadoop user information (from UserGroupInformation
).
- fromEnvironment(Configuration) - Method in class org.apache.flink.runtime.clusterframework.overlays.KeytabOverlay.Builder
-
Configures the overlay using the current environment (and global configuration).
- fromEnvironment(Configuration) - Method in class org.apache.flink.runtime.clusterframework.overlays.Krb5ConfOverlay.Builder
-
Configures the overlay using the current environment.
- fromEnvironment(Configuration) - Method in class org.apache.flink.runtime.clusterframework.overlays.SSLStoreOverlay.Builder
-
Configures the overlay using the current environment (and global configuration).
- fromGauge(Gauge<?>) - Static method in class org.apache.flink.dropwizard.metrics.FlinkGaugeWrapper
-
- fromGroupOffsets() - Method in class org.apache.flink.streaming.connectors.kafka.KafkaTableSource.Builder
-
Configures the TableSource to start reading from any committed group offsets found in Zookeeper / Kafka brokers.
- fromHexString(String) - Static method in class org.apache.flink.api.common.JobID
-
Parses a JobID from the given string.
- fromHexString(String) - Static method in class org.apache.flink.runtime.jobgraph.JobVertexID
-
- fromHexString(String) - Static method in class org.apache.flink.runtime.rest.messages.TriggerId
-
- FromIteratorFunction<T> - Class in org.apache.flink.streaming.api.functions.source
-
- FromIteratorFunction(Iterator<T>) - Constructor for class org.apache.flink.streaming.api.functions.source.FromIteratorFunction
-
- fromJobStatus(JobStatus) - Static method in enum org.apache.flink.runtime.clusterframework.ApplicationStatus
-
Derives the ApplicationStatus that should be used for a job that resulted in the given
job status.
- fromJobSubmissionResult(JobSubmissionResult) - Static method in class org.apache.flink.api.common.JobExecutionResult
-
- fromJobVertexID(JobVertexID) - Static method in class org.apache.flink.runtime.jobgraph.OperatorID
-
- fromKeyValueJsonArray(String) - Static method in class org.apache.flink.runtime.webmonitor.WebMonitorUtils
-
- fromLatest() - Method in class org.apache.flink.streaming.connectors.kafka.KafkaTableSource.Builder
-
Configures the TableSource to start reading from the latest offset for all partitions.
- fromLocalFile(File) - Static method in class org.apache.flink.core.fs.Path
-
Creates a path for the given local file.
- fromMap(Map<String, String>) - Static method in class org.apache.flink.api.java.utils.ParameterTool
-
- fromNow(Duration) - Static method in class org.apache.flink.api.common.time.Deadline
-
Constructs a Deadline that is a given duration after now.
- fromParallelCollection(SplittableIterator<X>, Class<X>) - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
Creates a new data set that contains elements in the iterator.
- fromParallelCollection(SplittableIterator<X>, TypeInformation<X>) - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
Creates a new data set that contains elements in the iterator.
- fromParallelCollection(SplittableIterator<OUT>, Class<OUT>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Creates a new data stream that contains elements in the iterator.
- fromParallelCollection(SplittableIterator<OUT>, TypeInformation<OUT>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Creates a new data stream that contains elements in the iterator.
- fromPropertiesFile(String) - Static method in class org.apache.flink.api.java.utils.ParameterTool
-
- fromPropertiesFile(File) - Static method in class org.apache.flink.api.java.utils.ParameterTool
-
- fromPropertiesFile(InputStream) - Static method in class org.apache.flink.api.java.utils.ParameterTool
-
- fromRawEvent(long, String, String) - Static method in class org.apache.flink.streaming.connectors.wikiedits.WikipediaEditEvent
-
- fromSerializedEvent(ByteBuffer, ClassLoader) - Static method in class org.apache.flink.runtime.io.network.api.serialization.EventSerializer
-
- fromSpecificOffsets(Map<KafkaTopicPartition, Long>) - Method in class org.apache.flink.streaming.connectors.kafka.KafkaTableSource.Builder
-
Configures the TableSource to start reading partitions from specific offsets, set independently for each partition.
- FromSplittableIteratorFunction<T> - Class in org.apache.flink.streaming.api.functions.source
-
- FromSplittableIteratorFunction(SplittableIterator<T>) - Constructor for class org.apache.flink.streaming.api.functions.source.FromSplittableIteratorFunction
-
- fromStatusOverview(ClusterOverview, String, String) - Static method in class org.apache.flink.runtime.rest.handler.legacy.messages.ClusterOverviewWithVersion
-
- fromString(String) - Static method in class org.apache.flink.cep.nfa.DeweyNumber
-
Creates a dewey number from a string representation.
- fromString(String) - Static method in enum org.apache.flink.runtime.execution.librarycache.FlinkUserCodeClassLoaders.ResolveOrder
-
- fromString(String) - Static method in class org.apache.flink.streaming.examples.kafka.KafkaEvent
-
- fromSystemProperties() - Static method in class org.apache.flink.api.java.utils.ParameterTool
-
- fromTuple2DataSet(DataSet<Tuple2<K, K>>, ExecutionEnvironment) - Static method in class org.apache.flink.graph.Graph
-
Creates a graph from a DataSet of Tuple2 objects for edges.
- fromTuple2DataSet(DataSet<Tuple2<K, K>>, MapFunction<K, VV>, ExecutionEnvironment) - Static method in class org.apache.flink.graph.Graph
-
Creates a graph from a DataSet of Tuple2 objects for edges.
- fromTupleDataSet(DataSet<Tuple2<K, VV>>, DataSet<Tuple3<K, K, EV>>, ExecutionEnvironment) - Static method in class org.apache.flink.graph.Graph
-
Creates a graph from a DataSet of Tuple2 objects for vertices and
Tuple3 objects for edges.
- fromTupleDataSet(DataSet<Tuple3<K, K, EV>>, ExecutionEnvironment) - Static method in class org.apache.flink.graph.Graph
-
Creates a graph from a DataSet of Tuple3 objects for edges.
- fromTupleDataSet(DataSet<Tuple3<K, K, EV>>, MapFunction<K, VV>, ExecutionEnvironment) - Static method in class org.apache.flink.graph.Graph
-
Creates a graph from a DataSet of Tuple3 objects for edges.
- fromUuid(UUID) - Static method in class org.apache.flink.runtime.dispatcher.DispatcherId
-
Creates a new DispatcherId that corresponds to the UUID.
- fromUuid(UUID) - Static method in class org.apache.flink.runtime.resourcemanager.ResourceManagerId
-
Creates a ResourceManagerId that corresponds to the given UUID.
- fromUuidOrNull(UUID) - Static method in class org.apache.flink.runtime.jobmaster.JobMasterId
-
- fromUuidOrNull(UUID) - Static method in class org.apache.flink.runtime.resourcemanager.ResourceManagerId
-
- FrontMetricGroup<P extends AbstractMetricGroup<?>> - Class in org.apache.flink.runtime.metrics.groups
-
- FrontMetricGroup(int, P) - Constructor for class org.apache.flink.runtime.metrics.groups.FrontMetricGroup
-
- FS_SMALL_FILE_THRESHOLD - Static variable in class org.apache.flink.configuration.CheckpointingOptions
-
The minimum size of state data files.
- FS_STATE_BACKEND_NAME - Static variable in class org.apache.flink.runtime.state.StateBackendLoader
-
The shortcut configuration name for the FileSystem State backend
- FS_STREAM_OPENING_TIMEOUT_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
-
The config parameter defining the timeout for filesystem stream opening.
- FsCheckpointMetadataOutputStream - Class in org.apache.flink.runtime.state.filesystem
-
- FsCheckpointMetadataOutputStream(FileSystem, Path, Path) - Constructor for class org.apache.flink.runtime.state.filesystem.FsCheckpointMetadataOutputStream
-
- FsCheckpointStateOutputStream(Path, FileSystem, int, int) - Constructor for class org.apache.flink.runtime.state.filesystem.FsCheckpointStreamFactory.FsCheckpointStateOutputStream
-
- FsCheckpointStorage - Class in org.apache.flink.runtime.state.filesystem
-
An implementation of durable checkpoint storage to file systems.
- FsCheckpointStorage(Path, Path, JobID, int) - Constructor for class org.apache.flink.runtime.state.filesystem.FsCheckpointStorage
-
- FsCheckpointStorageLocation - Class in org.apache.flink.runtime.state.filesystem
-
A storage location for checkpoints on a file system.
- FsCheckpointStorageLocation(FileSystem, Path, Path, Path, CheckpointStorageLocationReference, int) - Constructor for class org.apache.flink.runtime.state.filesystem.FsCheckpointStorageLocation
-
- FsCheckpointStreamFactory - Class in org.apache.flink.runtime.state.filesystem
-
- FsCheckpointStreamFactory(FileSystem, Path, Path, int) - Constructor for class org.apache.flink.runtime.state.filesystem.FsCheckpointStreamFactory
-
Creates a new stream factory that stores its checkpoint data in the file system and location
defined by the given Path.
- FsCheckpointStreamFactory.FsCheckpointStateOutputStream - Class in org.apache.flink.runtime.state.filesystem
-
A
CheckpointStreamFactory.CheckpointStateOutputStream
that writes into a file and
returns a
StreamStateHandle
upon closing.
- FsCompletedCheckpointStorageLocation - Class in org.apache.flink.runtime.state.filesystem
-
- FsCompletedCheckpointStorageLocation(FileSystem, Path, FileStateHandle, String) - Constructor for class org.apache.flink.runtime.state.filesystem.FsCompletedCheckpointStorageLocation
-
- FSDataInputStream - Class in org.apache.flink.core.fs
-
Interface for a data input stream to a file on a
FileSystem
.
- FSDataInputStream() - Constructor for class org.apache.flink.core.fs.FSDataInputStream
-
- FSDataInputStreamWrapper - Class in org.apache.flink.core.fs
-
- FSDataInputStreamWrapper(FSDataInputStream) - Constructor for class org.apache.flink.core.fs.FSDataInputStreamWrapper
-
- FSDataInputStreamWrapper - Class in org.apache.flink.formats.avro.utils
-
Code copy pasted from org.apache.avro.mapred.FSInput (which is Apache licensed as well).
- FSDataInputStreamWrapper(FSDataInputStream, long) - Constructor for class org.apache.flink.formats.avro.utils.FSDataInputStreamWrapper
-
- FSDataOutputStream - Class in org.apache.flink.core.fs
-
An output stream to a file that is created via a
FileSystem
.
- FSDataOutputStream() - Constructor for class org.apache.flink.core.fs.FSDataOutputStream
-
- FSDataOutputStreamWrapper - Class in org.apache.flink.core.fs
-
- FSDataOutputStreamWrapper(FSDataOutputStream) - Constructor for class org.apache.flink.core.fs.FSDataOutputStreamWrapper
-
- FsJobArchivist - Class in org.apache.flink.runtime.history
-
Utility class for writing an archive file to a
FileSystem
and reading it back.
- FsNegativeRunningJobsRegistry - Class in org.apache.flink.runtime.highavailability
-
This
RunningJobsRegistry
tracks the status jobs via marker files,
marking running jobs via running marker files, marking finished jobs via finished marker files.
- FsNegativeRunningJobsRegistry(Path) - Constructor for class org.apache.flink.runtime.highavailability.FsNegativeRunningJobsRegistry
-
Creates a new registry that writes to the FileSystem and working directory
denoted by the given path.
- FsNegativeRunningJobsRegistry(FileSystem, Path) - Constructor for class org.apache.flink.runtime.highavailability.FsNegativeRunningJobsRegistry
-
Creates a new registry that writes its files to the given FileSystem at
the given working directory path.
- FsStateBackend - Class in org.apache.flink.runtime.state.filesystem
-
This state backend holds the working state in the memory (JVM heap) of the TaskManagers.
- FsStateBackend(String) - Constructor for class org.apache.flink.runtime.state.filesystem.FsStateBackend
-
Creates a new state backend that stores its checkpoint data in the file system and location
defined by the given URI.
- FsStateBackend(String, boolean) - Constructor for class org.apache.flink.runtime.state.filesystem.FsStateBackend
-
Creates a new state backend that stores its checkpoint data in the file system and location
defined by the given URI.
- FsStateBackend(Path) - Constructor for class org.apache.flink.runtime.state.filesystem.FsStateBackend
-
Creates a new state backend that stores its checkpoint data in the file system and location
defined by the given URI.
- FsStateBackend(Path, boolean) - Constructor for class org.apache.flink.runtime.state.filesystem.FsStateBackend
-
Creates a new state backend that stores its checkpoint data in the file system and location
defined by the given URI.
- FsStateBackend(URI) - Constructor for class org.apache.flink.runtime.state.filesystem.FsStateBackend
-
Creates a new state backend that stores its checkpoint data in the file system and location
defined by the given URI.
- FsStateBackend(URI, URI) - Constructor for class org.apache.flink.runtime.state.filesystem.FsStateBackend
-
Creates a new state backend that stores its checkpoint data in the file system and location
defined by the given URI.
- FsStateBackend(URI, boolean) - Constructor for class org.apache.flink.runtime.state.filesystem.FsStateBackend
-
Creates a new state backend that stores its checkpoint data in the file system and location
defined by the given URI.
- FsStateBackend(URI, int) - Constructor for class org.apache.flink.runtime.state.filesystem.FsStateBackend
-
Creates a new state backend that stores its checkpoint data in the file system and location
defined by the given URI.
- FsStateBackend(URI, int, boolean) - Constructor for class org.apache.flink.runtime.state.filesystem.FsStateBackend
-
Creates a new state backend that stores its checkpoint data in the file system and location
defined by the given URI.
- FsStateBackend(URI, URI, int, TernaryBoolean) - Constructor for class org.apache.flink.runtime.state.filesystem.FsStateBackend
-
Creates a new state backend that stores its checkpoint data in the file system and location
defined by the given URI.
- FsStateBackendFactory - Class in org.apache.flink.runtime.state.filesystem
-
- FsStateBackendFactory() - Constructor for class org.apache.flink.runtime.state.filesystem.FsStateBackendFactory
-
- FULL_RESTART_STRATEGY_NAME - Static variable in class org.apache.flink.runtime.executiongraph.failover.FailoverStrategyLoader
-
- fullOuterJoin(DataSet<R>) - Method in class org.apache.flink.api.java.DataSet
-
Initiates a Full Outer Join transformation.
- fullOuterJoin(DataSet<R>, JoinOperatorBase.JoinHint) - Method in class org.apache.flink.api.java.DataSet
-
Initiates a Full Outer Join transformation.
- FullOuterJoinDriver<IT1,IT2,OT> - Class in org.apache.flink.runtime.operators
-
The full outer join driver implements the logic of an outer join operator at runtime.
- FullOuterJoinDriver() - Constructor for class org.apache.flink.runtime.operators.FullOuterJoinDriver
-
- FullTypeInfo(Class<?>, ReflectionUtil.FullTypeInfo[]) - Constructor for class org.apache.flink.util.ReflectionUtil.FullTypeInfo
-
- fun - Variable in class org.apache.flink.streaming.python.api.functions.AbstractPythonUDF
-
- Function - Interface in org.apache.flink.api.common.functions
-
The base interface for all user-defined functions.
- function - Variable in class org.apache.flink.api.java.operators.FilterOperator
-
- function - Variable in class org.apache.flink.api.java.operators.FlatMapOperator
-
- function - Variable in class org.apache.flink.api.java.operators.MapOperator
-
- function - Variable in class org.apache.flink.api.java.operators.MapPartitionOperator
-
- function - Variable in class org.apache.flink.python.api.streaming.data.PythonStreamer
-
- FunctionAnnotation - Class in org.apache.flink.api.java.functions
-
This class defines Java annotations for semantic assertions that can be added to Flink functions.
- FunctionAnnotation.ForwardedFields - Annotation Type in org.apache.flink.api.java.functions
-
The ForwardedFields annotation declares fields which are never modified by the annotated function and
which are forwarded at the same position to the output or unchanged copied to another position in the output.
- FunctionAnnotation.ForwardedFieldsFirst - Annotation Type in org.apache.flink.api.java.functions
-
The ForwardedFieldsFirst annotation declares fields of the first input of a function which are
never modified by the annotated function and which are forwarded at the same position to the
output or unchanged copied to another position in the output.
- FunctionAnnotation.ForwardedFieldsSecond - Annotation Type in org.apache.flink.api.java.functions
-
The ForwardedFieldsSecond annotation declares fields of the second input of a function which are
never modified by the annotated function and which are forwarded at the same position to the
output or unchanged copied to another position in the output.
- FunctionAnnotation.NonForwardedFields - Annotation Type in org.apache.flink.api.java.functions
-
The NonForwardedFields annotation declares ALL fields which not preserved on the same position in a functions output.
- FunctionAnnotation.NonForwardedFieldsFirst - Annotation Type in org.apache.flink.api.java.functions
-
The NonForwardedFieldsFirst annotation declares for a function ALL fields of its first input
which are not preserved on the same position in its output.
- FunctionAnnotation.NonForwardedFieldsSecond - Annotation Type in org.apache.flink.api.java.functions
-
The NonForwardedFieldsSecond annotation declares for a function ALL fields of its second input
which are not preserved on the same position in its output.
- FunctionAnnotation.ReadFields - Annotation Type in org.apache.flink.api.java.functions
-
The ReadFields annotation declares for a function all fields which it accesses and evaluates, i.e.,
all fields that are used by the function to compute its result.
- FunctionAnnotation.ReadFieldsFirst - Annotation Type in org.apache.flink.api.java.functions
-
The ReadFieldsFirst annotation declares for a function all fields of the first input which it accesses and evaluates, i.e.,
all fields of the first input that are used by the function to compute its result.
- FunctionAnnotation.ReadFieldsSecond - Annotation Type in org.apache.flink.api.java.functions
-
The ReadFieldsSecond annotation declares for a function all fields of the second input which it accesses and evaluates, i.e.,
all fields of the second input that are used by the function to compute its result.
- FunctionAnnotation.SkipCodeAnalysis - Annotation Type in org.apache.flink.api.java.functions
-
The SkipCodeAnalysis annotation declares that a function will not be analyzed by Flink's
code analysis capabilities independent of the configured
CodeAnalysisMode
.
- FunctionInitializationContext - Interface in org.apache.flink.runtime.state
-
This interface provides a context in which user functions can initialize by registering to managed state (i.e.
- FunctionSnapshotContext - Interface in org.apache.flink.runtime.state
-
This interface provides a context in which user functions that use managed state (i.e.
- FunctionUtils - Class in org.apache.flink.api.common.functions.util
-
Utility class that contains helper methods to work with Flink
Function
class.
- FunctionUtils - Class in org.apache.flink.util.function
-
Utility class for Flink's functions.
- FunctionWithException<T,R,E extends Throwable> - Interface in org.apache.flink.util.function
-
A functional interface for a
Function
that may
throw exceptions.
- furtherPartitioning - Variable in class org.apache.flink.runtime.operators.hash.HashPartition
-
- furtherPartitioning - Variable in class org.apache.flink.runtime.operators.hash.MutableHashTable
-
- future() - Method in class org.apache.flink.runtime.minicluster.OneTimeLeaderListenerFuture
-
Gets the future that is completed with the leader address and ID.
- FutureConsumerWithException<T,E extends Throwable> - Interface in org.apache.flink.util.concurrent
-
- FutureUtil - Class in org.apache.flink.util
-
Simple utility class to work with Java's Futures.
- FutureUtils - Class in org.apache.flink.queryablestate
-
- FutureUtils() - Constructor for class org.apache.flink.queryablestate.FutureUtils
-
- FutureUtils - Class in org.apache.flink.runtime.concurrent
-
- FutureUtils() - Constructor for class org.apache.flink.runtime.concurrent.FutureUtils
-
- FutureUtils.ConjunctFuture<T> - Class in org.apache.flink.runtime.concurrent
-
A future that is complete once multiple other futures completed.
- FutureUtils.RetryException - Exception in org.apache.flink.runtime.concurrent
-
- GarbageCollectorInfo(String, long, long) - Constructor for class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMetricsInfo.GarbageCollectorInfo
-
- garbageCollectorNames - Variable in class org.apache.flink.runtime.rest.handler.legacy.metrics.MetricStore.TaskManagerMetricStore
-
- GatewayRetriever<T extends RpcGateway> - Interface in org.apache.flink.runtime.webmonitor.retriever
-
- gather(Neighbor<VV, EV>) - Method in class org.apache.flink.graph.gsa.GatherFunction
-
- GatherFunction<VV,EV,M> - Class in org.apache.flink.graph.gsa
-
- GatherFunction() - Constructor for class org.apache.flink.graph.gsa.GatherFunction
-
- GatherFunction<K,VV,Message> - Class in org.apache.flink.graph.spargel
-
This class must be extended by functions that compute the state of the vertex depending on the old state and the
incoming messages.
- GatherFunction() - Constructor for class org.apache.flink.graph.spargel.GatherFunction
-
- GatherSumApplyIteration<K,VV,EV,M> - Class in org.apache.flink.graph.gsa
-
This class represents iterative graph computations, programmed in a gather-sum-apply perspective.
- Gauge<T> - Interface in org.apache.flink.metrics
-
A Gauge is a
Metric
that calculates a specific value at a point in time.
- gauge(int, G) - Method in class org.apache.flink.metrics.groups.UnregisteredMetricsGroup
-
- gauge(String, G) - Method in class org.apache.flink.metrics.groups.UnregisteredMetricsGroup
-
- gauge(int, G) - Method in interface org.apache.flink.metrics.MetricGroup
-
Registers a new
Gauge
with Flink.
- gauge(String, G) - Method in interface org.apache.flink.metrics.MetricGroup
-
Registers a new
Gauge
with Flink.
- gauge(int, G) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
-
- gauge(String, G) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
-
- gauge(int, G) - Method in class org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
-
- gauge(String, G) - Method in class org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
-
- GaugeDump(QueryScopeInfo, String, String) - Constructor for class org.apache.flink.runtime.metrics.dump.MetricDump.GaugeDump
-
- gauges - Variable in class org.apache.flink.metrics.reporter.AbstractReporter
-
- generate() - Static method in class org.apache.flink.api.common.JobID
-
Creates a new (statistically) random JobID.
- generate(ExecutionEnvironment) - Method in class org.apache.flink.graph.drivers.input.GeneratedMultiGraph
-
- generate(ExecutionEnvironment) - Method in class org.apache.flink.graph.drivers.input.RMatGraph
-
- generate() - Method in class org.apache.flink.graph.generator.CirculantGraph
-
- generate() - Method in class org.apache.flink.graph.generator.CompleteGraph
-
- generate() - Method in class org.apache.flink.graph.generator.CycleGraph
-
- generate() - Method in class org.apache.flink.graph.generator.EchoGraph
-
- generate() - Method in class org.apache.flink.graph.generator.EmptyGraph
-
- generate() - Method in interface org.apache.flink.graph.generator.GraphGenerator
-
Generates the configured graph.
- generate() - Method in class org.apache.flink.graph.generator.GridGraph
-
- generate() - Method in class org.apache.flink.graph.generator.HypercubeGraph
-
- generate() - Method in class org.apache.flink.graph.generator.PathGraph
-
- generate() - Method in class org.apache.flink.graph.generator.RMatGraph
-
- generate() - Method in class org.apache.flink.graph.generator.SingletonEdgeGraph
-
- generate() - Method in class org.apache.flink.graph.generator.StarGraph
-
- generate() - Static method in class org.apache.flink.runtime.clusterframework.types.ResourceID
-
Generate a random resource id.
- generate() - Static method in class org.apache.flink.runtime.dispatcher.DispatcherId
-
Generates a new random DispatcherId.
- generate() - Static method in class org.apache.flink.runtime.jobmaster.JobMasterId
-
Generates a new random JobMasterId.
- generate() - Static method in class org.apache.flink.runtime.resourcemanager.ResourceManagerId
-
Generates a new random ResourceManagerId.
- generate(StreamExecutionEnvironment, List<StreamTransformation<?>>) - Static method in class org.apache.flink.streaming.api.graph.StreamGraphGenerator
-
Generates a StreamGraph
by traversing the graph of StreamTransformations
starting from the given transformations.
- generate_sequence(long, long) - Method in class org.apache.flink.streaming.python.api.environment.PythonStreamExecutionEnvironment
-
- generateCheckpointStatistics(AbstractCheckpointStats, boolean) - Static method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
-
- GeneratedGraph<K> - Class in org.apache.flink.graph.drivers.input
-
Base class for generated graphs.
- GeneratedGraph() - Constructor for class org.apache.flink.graph.drivers.input.GeneratedGraph
-
- GeneratedMultiGraph<K extends Comparable<K>> - Class in org.apache.flink.graph.drivers.input
-
Base class for graph generators which may create duplicate edges.
- GeneratedMultiGraph() - Constructor for class org.apache.flink.graph.drivers.input.GeneratedMultiGraph
-
- generateFieldsFromAvroSchema(Class<T>, boolean) - Static method in class org.apache.flink.formats.avro.typeutils.AvroTypeInfo
-
- generateIdsToAbort() - Method in class org.apache.flink.streaming.connectors.kafka.internal.TransactionalIdsGenerator
-
If we have to abort previous transactional id in case of restart after a failure BEFORE first checkpoint
completed, we don't know what was the parallelism used in previous attempt.
- generateIdsToUse(long) - Method in class org.apache.flink.streaming.connectors.kafka.internal.TransactionalIdsGenerator
-
Range of available transactional ids to use is:
[nextFreeTransactionalId, nextFreeTransactionalId + parallelism * kafkaProducersPoolSize)
loop below picks in a deterministic way a subrange of those available transactional ids based on index of
this subtask.
- generatePlan(JobGraph) - Static method in class org.apache.flink.runtime.jobgraph.jsonplan.JsonPlanGenerator
-
- generateRegistration() - Method in class org.apache.flink.runtime.registration.RegisteredRpcConnection
-
This method generate a specific Registration, for example TaskExecutor Registration at the ResourceManager.
- generateRegistration() - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorToResourceManagerConnection
-
- generateSequence(long, long) - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
Creates a new data set that contains a sequence of numbers.
- generateSequence(long, long) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Creates a new data stream that contains a sequence of numbers.
- generateSlotOffer() - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlot
-
Generate the slot offer from this TaskSlot.
- generateTaskManagerConfiguration(Configuration, String, int, int, FiniteDuration) - Static method in class org.apache.flink.runtime.clusterframework.BootstrapTools
-
Generate a task manager configuration.
- generateZookeeperPath(String, String) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
-
- Generator(long, int) - Constructor for class org.apache.flink.batch.tests.DataSetAllroundTestProgram.Generator
-
- generator() - Method in interface org.apache.flink.graph.generator.random.RandomGenerable
-
Returns an initialized RandomGenerator
.
- Generator(int, float, int, int) - Constructor for class org.apache.flink.sql.tests.StreamSQLTestProgram.Generator
-
- Generator(int, int, int) - Constructor for class org.apache.flink.streaming.tests.BucketingSinkTestProgram.Generator
-
- GeneratorFactoryBase<T extends org.apache.commons.math3.random.RandomGenerator> - Class in org.apache.flink.graph.generator.random
-
This base class handles the task of dividing the requested work into the
appropriate number of blocks of near-equal size.
- GeneratorFactoryBase() - Constructor for class org.apache.flink.graph.generator.random.GeneratorFactoryBase
-
- GeneratorTableSource(int, float, int, int) - Constructor for class org.apache.flink.sql.tests.StreamSQLTestProgram.GeneratorTableSource
-
- GENERIC(Class<T>) - Static method in class org.apache.flink.api.common.typeinfo.Types
-
Returns generic type information for any Java object.
- GenericArraySerializer<C> - Class in org.apache.flink.api.common.typeutils.base
-
A serializer for arrays of objects.
- GenericArraySerializer(Class<C>, TypeSerializer<C>) - Constructor for class org.apache.flink.api.common.typeutils.base.GenericArraySerializer
-
- GenericArraySerializerConfigSnapshot<C> - Class in org.apache.flink.api.common.typeutils.base
-
- GenericArraySerializerConfigSnapshot() - Constructor for class org.apache.flink.api.common.typeutils.base.GenericArraySerializerConfigSnapshot
-
This empty nullary constructor is required for deserializing the configuration.
- GenericArraySerializerConfigSnapshot(Class<C>, TypeSerializer<C>) - Constructor for class org.apache.flink.api.common.typeutils.base.GenericArraySerializerConfigSnapshot
-
- GenericCsvInputFormat<OT> - Class in org.apache.flink.api.common.io
-
- GenericCsvInputFormat() - Constructor for class org.apache.flink.api.common.io.GenericCsvInputFormat
-
- GenericCsvInputFormat(Path) - Constructor for class org.apache.flink.api.common.io.GenericCsvInputFormat
-
- GenericDataSinkBase<IN> - Class in org.apache.flink.api.common.operators
-
Operator for nodes that act as data sinks, storing the data they receive.
- GenericDataSinkBase(OutputFormat<IN>, UnaryOperatorInformation<IN, Nothing>, String) - Constructor for class org.apache.flink.api.common.operators.GenericDataSinkBase
-
Creates a GenericDataSink with the provided
OutputFormat
implementation
and the given name.
- GenericDataSinkBase(UserCodeWrapper<? extends OutputFormat<IN>>, UnaryOperatorInformation<IN, Nothing>, String) - Constructor for class org.apache.flink.api.common.operators.GenericDataSinkBase
-
Creates a GenericDataSink with the provided
OutputFormat
implementation
and the given name.
- GenericDataSourceBase<OUT,T extends InputFormat<OUT,?>> - Class in org.apache.flink.api.common.operators
-
Abstract superclass for data sources in a Pact plan.
- GenericDataSourceBase(T, OperatorInformation<OUT>, String) - Constructor for class org.apache.flink.api.common.operators.GenericDataSourceBase
-
Creates a new instance for the given file using the given input format.
- GenericDataSourceBase(T, OperatorInformation<OUT>) - Constructor for class org.apache.flink.api.common.operators.GenericDataSourceBase
-
Creates a new instance for the given file using the given input format, using the default name.
- GenericDataSourceBase(Class<? extends T>, OperatorInformation<OUT>, String) - Constructor for class org.apache.flink.api.common.operators.GenericDataSourceBase
-
Creates a new instance for the given file using the given input format.
- GenericDataSourceBase(Class<? extends T>, OperatorInformation<OUT>) - Constructor for class org.apache.flink.api.common.operators.GenericDataSourceBase
-
Creates a new instance for the given file using the given input format, using the default name.
- GenericDataSourceBase.SplitDataProperties<T> - Interface in org.apache.flink.api.common.operators
-
- GenericInputFormat<OT> - Class in org.apache.flink.api.common.io
-
Generic base class for all Rich inputs that are not based on files.
- GenericInputFormat() - Constructor for class org.apache.flink.api.common.io.GenericInputFormat
-
- GenericInputSplit - Class in org.apache.flink.core.io
-
A generic input split that has only a partition number.
- GenericInputSplit(int, int) - Constructor for class org.apache.flink.core.io.GenericInputSplit
-
Creates a generic input split with the given split number.
- GenericKeyMetricGroup - Class in org.apache.flink.runtime.metrics.groups
-
- GenericMetricGroup - Class in org.apache.flink.runtime.metrics.groups
-
A simple named
MetricGroup
that is used to hold
subgroups of metrics.
- GenericMetricGroup(MetricRegistry, AbstractMetricGroup, String) - Constructor for class org.apache.flink.runtime.metrics.groups.GenericMetricGroup
-
- GenericPairComparator<T1,T2> - Class in org.apache.flink.api.common.typeutils
-
- GenericPairComparator(TypeComparator<T1>, TypeComparator<T2>) - Constructor for class org.apache.flink.api.common.typeutils.GenericPairComparator
-
- GenericParameterValuesProvider - Class in org.apache.flink.api.java.io.jdbc.split
-
This splits generator actually does nothing but wrapping the query parameters
computed by the user before creating the
JDBCInputFormat
instance.
- GenericParameterValuesProvider(Serializable[][]) - Constructor for class org.apache.flink.api.java.io.jdbc.split.GenericParameterValuesProvider
-
- GenericTypeComparator<T extends Comparable<T>> - Class in org.apache.flink.api.java.typeutils.runtime
-
TypeComparator for all types that extend Comparable.
- GenericTypeComparator(boolean, TypeSerializer<T>, Class<T>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.GenericTypeComparator
-
- GenericTypeInfo<T> - Class in org.apache.flink.api.java.typeutils
-
- GenericTypeInfo(Class<T>) - Constructor for class org.apache.flink.api.java.typeutils.GenericTypeInfo
-
- GenericTypeSerializerConfigSnapshot<T> - Class in org.apache.flink.api.common.typeutils
-
Configuration snapshot for serializers for generic types.
- GenericTypeSerializerConfigSnapshot() - Constructor for class org.apache.flink.api.common.typeutils.GenericTypeSerializerConfigSnapshot
-
This empty nullary constructor is required for deserializing the configuration.
- GenericTypeSerializerConfigSnapshot(Class<T>) - Constructor for class org.apache.flink.api.common.typeutils.GenericTypeSerializerConfigSnapshot
-
- GenericValueMetricGroup - Class in org.apache.flink.runtime.metrics.groups
-
- GenericWriteAheadSink<IN> - Class in org.apache.flink.streaming.runtime.operators
-
Generic Sink that emits its input elements into an arbitrary backend.
- GenericWriteAheadSink(CheckpointCommitter, TypeSerializer<IN>, String) - Constructor for class org.apache.flink.streaming.runtime.operators.GenericWriteAheadSink
-
- get(int) - Method in class org.apache.flink.api.common.operators.util.FieldList
-
- get() - Method in interface org.apache.flink.api.common.state.AppendingState
-
Returns the current value for the state.
- get(UK) - Method in interface org.apache.flink.api.common.state.MapState
-
Returns the current value associated with the given key.
- get(K) - Method in interface org.apache.flink.api.common.state.ReadOnlyBroadcastState
-
Returns the current value associated with the given key.
- get(String) - Method in class org.apache.flink.api.java.utils.ParameterTool
-
Returns the String value for the given key.
- get(String, String) - Method in class org.apache.flink.api.java.utils.ParameterTool
-
Returns the String value for the given key.
- get() - Method in class org.apache.flink.client.program.ClusterClient.LazyActorSystemLoader
-
Creates a new ActorSystem or returns an existing one.
- get() - Method in class org.apache.flink.contrib.streaming.state.RocksDBAggregatingState
-
- get() - Method in class org.apache.flink.contrib.streaming.state.RocksDBFoldingState
-
Deprecated.
- get() - Method in class org.apache.flink.contrib.streaming.state.RocksDBListState
-
- get(UK) - Method in class org.apache.flink.contrib.streaming.state.RocksDBMapState
-
- get() - Method in class org.apache.flink.contrib.streaming.state.RocksDBReducingState
-
- get(URI) - Static method in class org.apache.flink.core.fs.FileSystem
-
Returns a reference to the
FileSystem
instance for accessing the
file system identified by the given
URI
.
- get(int) - Method in class org.apache.flink.core.memory.HeapMemorySegment
-
- get(int, byte[]) - Method in class org.apache.flink.core.memory.HeapMemorySegment
-
- get(int, byte[], int, int) - Method in class org.apache.flink.core.memory.HeapMemorySegment
-
- get(DataOutput, int, int) - Method in class org.apache.flink.core.memory.HeapMemorySegment
-
- get(int, ByteBuffer, int) - Method in class org.apache.flink.core.memory.HeapMemorySegment
-
- get(int) - Method in class org.apache.flink.core.memory.HybridMemorySegment
-
- get(int, byte[]) - Method in class org.apache.flink.core.memory.HybridMemorySegment
-
- get(int, byte[], int, int) - Method in class org.apache.flink.core.memory.HybridMemorySegment
-
- get(DataOutput, int, int) - Method in class org.apache.flink.core.memory.HybridMemorySegment
-
- get(int, ByteBuffer, int) - Method in class org.apache.flink.core.memory.HybridMemorySegment
-
- get(int) - Method in class org.apache.flink.core.memory.MemorySegment
-
Reads the byte at the given position.
- get(int, byte[]) - Method in class org.apache.flink.core.memory.MemorySegment
-
Bulk get method.
- get(int, byte[], int, int) - Method in class org.apache.flink.core.memory.MemorySegment
-
Bulk get method.
- get(DataOutput, int, int) - Method in class org.apache.flink.core.memory.MemorySegment
-
- get(int, ByteBuffer, int) - Method in class org.apache.flink.core.memory.MemorySegment
-
Bulk get method.
- get() - Method in class org.apache.flink.graph.utils.proxy.OptionalBoolean
-
Get the boolean state.
- get() - Method in class org.apache.flink.queryablestate.client.state.ImmutableAggregatingState
-
- get() - Method in class org.apache.flink.queryablestate.client.state.ImmutableFoldingState
-
Deprecated.
- get() - Method in class org.apache.flink.queryablestate.client.state.ImmutableListState
-
- get(K) - Method in class org.apache.flink.queryablestate.client.state.ImmutableMapState
-
- get() - Method in class org.apache.flink.queryablestate.client.state.ImmutableReducingState
-
- get() - Static method in class org.apache.flink.queryablestate.client.VoidNamespace
-
Getter for the singleton instance.
- get(JobID, BlobKey, File) - Method in interface org.apache.flink.runtime.blob.BlobView
-
Copies a blob to a local file.
- get(JobID, BlobKey, File) - Method in class org.apache.flink.runtime.blob.FileSystemBlobStore
-
- get(JobID, BlobKey, File) - Method in class org.apache.flink.runtime.blob.VoidBlobStore
-
- get() - Static method in class org.apache.flink.runtime.clusterframework.messages.CheckAndAllocateContainers
-
Gets the singleton instance.
- get() - Static method in class org.apache.flink.runtime.clusterframework.messages.RegisterInfoMessageListenerSuccessful
-
Gets the singleton instance.
- get() - Static method in class org.apache.flink.runtime.clusterframework.messages.UnRegisterInfoMessageListener
-
Gets the singleton instance.
- get(JobID) - Method in interface org.apache.flink.runtime.dispatcher.ArchivedExecutionGraphStore
-
- get(JobID) - Method in class org.apache.flink.runtime.dispatcher.FileArchivedExecutionGraphStore
-
- get(JobID) - Method in class org.apache.flink.runtime.dispatcher.MemoryArchivedExecutionGraphStore
-
- get(String) - Method in class org.apache.flink.runtime.iterative.concurrent.Broker
-
Blocking retrieval and removal of the object to share.
- get() - Static method in class org.apache.flink.runtime.messages.Acknowledge
-
Gets the singleton instance.
- get(int) - Method in class org.apache.flink.runtime.operators.util.BitSet
-
Returns true if the bit is set in the specified index.
- get(int) - Method in class org.apache.flink.runtime.operators.util.BloomFilter.BitSet
-
Returns true if the bit is set in the specified index.
- get(int) - Method in class org.apache.flink.runtime.state.ChainedStateHandle
-
Get the state handle for a single operator in the operator chain by it's index.
- get() - Method in class org.apache.flink.runtime.state.DoneFuture
-
- get(long, TimeUnit) - Method in class org.apache.flink.runtime.state.DoneFuture
-
- get(K, N) - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateTable
-
- get(N) - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateTable
-
- get() - Method in class org.apache.flink.runtime.state.heap.HeapAggregatingState
-
- get() - Method in class org.apache.flink.runtime.state.heap.HeapFoldingState
-
Deprecated.
- get() - Method in class org.apache.flink.runtime.state.heap.HeapListState
-
- get(UK) - Method in class org.apache.flink.runtime.state.heap.HeapMapState
-
- get() - Method in class org.apache.flink.runtime.state.heap.HeapReducingState
-
- get(N) - Method in class org.apache.flink.runtime.state.heap.NestedMapsStateTable
-
- get(K, N) - Method in class org.apache.flink.runtime.state.heap.NestedMapsStateTable
-
- get(N) - Method in class org.apache.flink.runtime.state.heap.StateTable
-
Returns the state of the mapping for the composite of active key and given namespace.
- get(K, N) - Method in class org.apache.flink.runtime.state.heap.StateTable
-
Returns the state for the composite of active key and given namespace.
- get(K) - Method in class org.apache.flink.runtime.state.HeapBroadcastState
-
- get() - Static method in class org.apache.flink.runtime.state.VoidNamespace
-
Getter for the singleton instance
- get(JobID) - Method in class org.apache.flink.runtime.taskexecutor.JobManagerTable
-
- get() - Method in class org.apache.flink.runtime.util.AtomicDisposableReferenceCounter
-
- get() - Static method in class org.apache.flink.runtime.util.EmptyIterator
-
Gets a singleton instance of the empty iterator.
- get() - Static method in class org.apache.flink.runtime.util.EmptyMutableObjectIterator
-
Gets a singleton instance of the empty iterator.
- get(int) - Method in class org.apache.flink.runtime.util.EvictingBoundedList
-
- get(Object) - Method in class org.apache.flink.storm.util.StormConfig
-
- get() - Method in interface org.apache.flink.streaming.api.operators.async.queue.AsyncCollectionResult
-
Return the asynchronous result collection.
- get() - Method in class org.apache.flink.streaming.api.operators.async.queue.StreamRecordQueueEntry
-
- get() - Static method in class org.apache.flink.streaming.api.windowing.windows.GlobalWindow
-
- get() - Method in class org.apache.flink.streaming.connectors.fs.AvroKeyValueSinkWriter.AvroKeyValue
-
- get(K) - Method in class org.apache.flink.streaming.runtime.operators.windowing.KeyMap
-
Looks up the value mapped under the given key.
- get(T) - Method in class org.apache.flink.streaming.util.typeutils.FieldAccessor
-
Gets the value of the field (specified in the constructor) of the given record.
- get() - Method in class org.apache.flink.types.BooleanValue
-
- get(int) - Method in class org.apache.flink.types.ListValue
-
- get(Object) - Method in class org.apache.flink.types.MapValue
-
- get() - Method in interface org.apache.flink.util.function.SupplierWithException
-
Gets the result of this supplier.
- get() - Method in class org.apache.flink.util.OptionalFailure
-
- get(Throwable, ClassLoader) - Static method in exception org.apache.flink.util.SerializedThrowable
-
- get(String) - Method in class org.apache.hadoop.conf.Configuration
-
Get the value of the name
property, null
if
no such property exists.
- get(String, String) - Method in class org.apache.hadoop.conf.Configuration
-
Get the value of the name
.
- get75thPercentile() - Method in interface org.apache.flink.metrics.jmx.JMXReporter.JmxHistogramMBean
-
- get95thPercentile() - Method in interface org.apache.flink.metrics.jmx.JMXReporter.JmxHistogramMBean
-
- get98thPercentile() - Method in interface org.apache.flink.metrics.jmx.JMXReporter.JmxHistogramMBean
-
- get999thPercentile() - Method in interface org.apache.flink.metrics.jmx.JMXReporter.JmxHistogramMBean
-
- get99thPercentile() - Method in interface org.apache.flink.metrics.jmx.JMXReporter.JmxHistogramMBean
-
- get_execution_environment() - Method in class org.apache.flink.streaming.python.api.environment.PythonEnvironmentFactory
-
- GET_PARTITIONS_RETRIES_KEY - Static variable in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer08
-
Configuration key for the number of retries for getting the partition info.
- getAccessor(TypeInformation<T>, int, ExecutionConfig) - Static method in class org.apache.flink.streaming.util.typeutils.FieldAccessorFactory
-
Creates a
FieldAccessor
for the given field position, which can be used to get and set
the specified field on instances of this type.
- getAccessor(TypeInformation<T>, String, ExecutionConfig) - Static method in class org.apache.flink.streaming.util.typeutils.FieldAccessorFactory
-
Creates a
FieldAccessor
for the field that is given by a field expression,
which can be used to get and set the specified field on instances of this type.
- getAccessTime() - Method in interface org.apache.flink.core.fs.FileStatus
-
Get the access time of the file.
- getAccessTime() - Method in class org.apache.flink.core.fs.local.LocalFileStatus
-
- getAccessTime() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileStatus
-
- getAccumulatedRecordCount() - Method in class org.apache.flink.api.common.io.BlockInfo
-
Returns the accumulated record count.
- getAccumulator(String) - Method in interface org.apache.flink.api.common.functions.RuntimeContext
-
Get an existing accumulator object.
- getAccumulator(String) - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
-
- getAccumulator(ExecutionEnvironment, String) - Method in class org.apache.flink.graph.AnalyticHelper
-
Gets the accumulator with the given name.
- getAccumulatorMap() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- getAccumulatorRegistry() - Method in interface org.apache.flink.runtime.execution.Environment
-
Return the registry for accumulators which are periodically sent to the job manager.
- getAccumulatorRegistry() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
-
- getAccumulatorRegistry() - Method in class org.apache.flink.runtime.taskmanager.Task
-
- getAccumulatorResult(String) - Method in class org.apache.flink.api.common.JobExecutionResult
-
Gets the accumulator with the given name.
- getAccumulatorResult(String) - Method in class org.apache.flink.client.program.DetachedEnvironment.DetachedJobExecutionResult
-
- getAccumulatorResults() - Method in class org.apache.flink.runtime.jobmaster.JobResult
-
- getAccumulatorResultsStringified() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionGraph
-
Returns the aggregated user-defined accumulators as strings.
- getAccumulatorResultsStringified() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
-
- getAccumulatorResultsStringified() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
Returns the a stringified version of the user-defined accumulators.
- getAccumulators(JobID) - Method in class org.apache.flink.client.program.ClusterClient
-
Requests and returns the accumulators for the given job identifier.
- getAccumulators(JobID, ClassLoader) - Method in class org.apache.flink.client.program.ClusterClient
-
Requests and returns the accumulators for the given job identifier.
- getAccumulators(JobID) - Method in class org.apache.flink.client.program.MiniClusterClient
-
- getAccumulators(JobID, ClassLoader) - Method in class org.apache.flink.client.program.MiniClusterClient
-
- getAccumulators(JobID, ClassLoader) - Method in class org.apache.flink.client.program.rest.RestClusterClient
-
- getAccumulators() - Method in class org.apache.flink.runtime.taskmanager.TaskExecutionState
-
Gets flink and user-defined accumulators in serialized form.
- getAccumulatorSnapshots() - Method in class org.apache.flink.runtime.taskexecutor.AccumulatorReport
-
- getAccumulatorsSerialized() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionGraph
-
Returns a map containing the serialized values of user-defined accumulators.
- getAccumulatorsSerialized() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
-
- getAccumulatorsSerialized() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
Gets a serialized accumulator map.
- getAckTimestamp() - Method in class org.apache.flink.runtime.checkpoint.SubtaskStateStats
-
Returns the timestamp when the acknowledgement of this subtask was
received at the coordinator.
- getAckTimestamp() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics
-
- getAckTimestampStats() - Method in class org.apache.flink.runtime.checkpoint.TaskStateStats.TaskStateStatsSummary
-
Returns the summary stats for the ACK timestamps.
- getAclForPath(String) - Method in class org.apache.flink.runtime.util.ZooKeeperUtils.SecureAclProvider
-
- getAction() - Method in class org.apache.flink.cep.nfa.StateTransition
-
- getActiveCustomCommandLine(CommandLine) - Method in class org.apache.flink.client.cli.CliFrontend
-
Gets the custom command-line for the arguments.
- getActiveSlots(JobID) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
-
Return an iterator of active slots (their application ids) for the given job id.
- getActiveTimerTimestamps() - Method in class org.apache.flink.streaming.runtime.tasks.TestProcessingTimeService
-
- getActorGateway() - Method in class org.apache.flink.runtime.jobmanager.slots.ActorTaskManagerGateway
-
- getActorGatewayFuture() - Method in class org.apache.flink.runtime.util.LeaderRetrievalUtils.LeaderGatewayListener
-
- getActorSystem() - Method in class org.apache.flink.runtime.rpc.akka.AkkaRpcService
-
- getActual() - Method in exception org.apache.flink.runtime.highavailability.LeaderIdMismatchException
-
- getActualBytes() - Method in class org.apache.flink.api.common.typeutils.UnloadableDummyTypeSerializer
-
- getAdamicAdarScore() - Method in class org.apache.flink.graph.library.similarity.AdamicAdar.Result
-
Get the Adamic-Adar score, equal to the sum over common neighbors of
the inverse logarithm of degree.
- getAddress() - Method in class org.apache.flink.core.memory.MemorySegment
-
Returns the memory address of off-heap memory segments.
- getAddress() - Method in class org.apache.flink.runtime.akka.AkkaJobManagerGateway
-
- getAddress() - Method in class org.apache.flink.runtime.io.network.ConnectionID
-
- getAddress() - Method in exception org.apache.flink.runtime.io.network.netty.exception.TransportException
-
- getAddress() - Method in class org.apache.flink.runtime.jobmanager.slots.ActorTaskManagerGateway
-
- getAddress() - Method in interface org.apache.flink.runtime.jobmanager.slots.TaskManagerGateway
-
Return the address of the task manager with which the gateway is associated.
- getAddress() - Method in class org.apache.flink.runtime.jobmaster.JobManagerRunner
-
- getAddress() - Method in class org.apache.flink.runtime.jobmaster.ResourceManagerAddress
-
- getAddress() - Method in class org.apache.flink.runtime.jobmaster.RpcTaskManagerGateway
-
- getAddress() - Method in interface org.apache.flink.runtime.leaderelection.LeaderContender
-
Returns the address of the
LeaderContender
under which other instances can connect
to it.
- getAddress() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerInfo
-
- getAddress() - Method in class org.apache.flink.runtime.rpc.akka.AkkaRpcService
-
- getAddress() - Method in class org.apache.flink.runtime.rpc.RpcEndpoint
-
Gets the address of the underlying RPC endpoint.
- getAddress() - Method in interface org.apache.flink.runtime.rpc.RpcGateway
-
Returns the fully qualified address under which the associated rpc endpoint is reachable.
- getAddress() - Method in interface org.apache.flink.runtime.rpc.RpcService
-
Return the hostname or host address under which the rpc service can be reached.
- getAddress() - Method in class org.apache.flink.runtime.util.LeaderConnectionInfo
-
- getAddress() - Method in class org.apache.flink.runtime.webmonitor.retriever.impl.AkkaQueryServiceGateway
-
- getAddress() - Method in interface org.apache.flink.runtime.webmonitor.retriever.MetricQueryServiceGateway
-
- getAddress() - Method in class org.apache.flink.runtime.webmonitor.WebMonitorEndpoint
-
- getAfterMatchSkipStrategy() - Method in class org.apache.flink.cep.pattern.Pattern
-
- getAggregate() - Method in interface org.apache.flink.api.common.aggregators.Aggregator
-
Gets the aggregator's current aggregate.
- getAggregate() - Method in class org.apache.flink.api.common.aggregators.DoubleSumAggregator
-
- getAggregate() - Method in class org.apache.flink.api.common.aggregators.LongSumAggregator
-
- getAggregate() - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase.TerminationCriterionAggregator
-
- getAggregate() - Method in class org.apache.flink.api.java.aggregation.AggregationFunction
-
- getAggregatedUserAccumulatorsStringified() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionJobVertex
-
Returns the aggregated user-defined accumulators as strings.
- getAggregatedUserAccumulatorsStringified() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionJobVertex
-
- getAggregatedUserAccumulatorsStringified() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
- getAggregateFunction() - Method in class 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) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
- getAggregateFunctionReturnType(AggregateFunction<IN, ?, OUT>, TypeInformation<IN>, String, boolean) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
- getAggregateJobVertexState(int[], int) - Static method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
A utility function that computes an "aggregated" state for the vertex.
- getAggregates() - Method in class org.apache.flink.runtime.iterative.concurrent.SuperstepBarrier
-
- getAggregates(ClassLoader) - Method in class org.apache.flink.runtime.iterative.event.IterationEventWithAggregators
-
- getAggregateState() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionJobVertex
-
- getAggregateState() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionJobVertex
-
- getAggregateState() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
- getAggregatingState(AggregatingStateDescriptor<IN, ACC, OUT>) - Method in interface org.apache.flink.api.common.functions.RuntimeContext
-
Gets a handle to the system's key/value aggregating state.
- getAggregatingState(AggregatingStateDescriptor<IN, ACC, OUT>) - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
-
- getAggregatingState(AggregatingStateDescriptor<IN, ACC, OUT>) - Method in interface org.apache.flink.api.common.state.KeyedStateStore
-
Gets a handle to the system's key/value folding state.
- getAggregatingState(AggregatingStateDescriptor<IN, ACC, OUT>) - Method in class org.apache.flink.runtime.state.DefaultKeyedStateStore
-
- getAggregatingState(AggregatingStateDescriptor<IN, ACC, OUT>) - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
-
- getAggregatingState(AggregatingStateDescriptor<IN, ACC, OUT>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.MergingWindowStateStore
-
- getAggregator() - Method in class org.apache.flink.api.common.aggregators.AggregatorWithName
-
Gets the aggregator.
- getAggregator(String) - Method in class org.apache.flink.runtime.iterative.task.RuntimeAggregatorRegistry
-
- getAggregatorNames() - Method in class org.apache.flink.runtime.iterative.concurrent.SuperstepBarrier
-
- getAggregatorNames() - Method in class org.apache.flink.runtime.iterative.event.IterationEventWithAggregators
-
- getAggregators() - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase
-
- getAggregators() - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase
-
- getAggregators() - Method in interface org.apache.flink.api.common.operators.IterationOperator
-
- getAggregators() - Method in class org.apache.flink.api.java.operators.DeltaIteration
-
Gets the registry for aggregators for the iteration.
- getAggregators() - Method in class org.apache.flink.api.java.operators.IterativeDataSet
-
Gets the registry for aggregators.
- getAggregators() - Method in class org.apache.flink.graph.IterationConfiguration
-
Gets the set of aggregators that are registered for this vertex-centric iteration.
- getAlgorithmName() - Method in class org.apache.flink.graph.utils.proxy.GraphAlgorithmWrappingBase
-
Algorithms are identified by name rather than by class to allow subclassing.
- getAlignment() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics
-
- getAlignmentBuffered() - Method in class org.apache.flink.runtime.checkpoint.AbstractCheckpointStats
-
Returns the total buffered bytes during alignment over all subtasks.
- getAlignmentBuffered() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpointStats
-
- getAlignmentBuffered() - Method in class org.apache.flink.runtime.checkpoint.FailedCheckpointStats
-
- getAlignmentBuffered() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpointStats
-
- getAlignmentBuffered() - Method in class org.apache.flink.runtime.checkpoint.SubtaskStateStats
-
Returns the number of bytes buffered during stream alignment (for
exactly-once only).
- getAlignmentBuffered() - Method in class org.apache.flink.runtime.checkpoint.TaskStateStats
-
Returns the total buffered bytes during alignment over all subtasks.
- getAlignmentBuffered() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.Summary
-
- getAlignmentBuffered() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
-
- getAlignmentBuffered() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics.CheckpointAlignment
-
- getAlignmentBuffered() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatistics
-
- getAlignmentBufferedStats() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpointStatsSummary
-
Returns the summary stats for the bytes buffered during alignment.
- getAlignmentBufferedStats() - Method in class org.apache.flink.runtime.checkpoint.TaskStateStats.TaskStateStatsSummary
-
Returns the summary stats for the buffered bytes during alignments.
- getAlignmentDuration() - Method in class org.apache.flink.runtime.checkpoint.SubtaskStateStats
-
Returns the duration of the stream alignment (for exactly-once only).
- getAlignmentDuration() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics.CheckpointAlignment
-
- getAlignmentDurationNanos() - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetrics
-
- getAlignmentDurationNanos() - Method in class org.apache.flink.streaming.runtime.io.BarrierBuffer
-
- getAlignmentDurationNanos() - Method in class org.apache.flink.streaming.runtime.io.BarrierTracker
-
- getAlignmentDurationNanos() - Method in interface org.apache.flink.streaming.runtime.io.CheckpointBarrierHandler
-
Gets the time that the latest alignment took, in nanoseconds.
- getAlignmentDurationStats() - Method in class org.apache.flink.runtime.checkpoint.TaskStateStats.TaskStateStatsSummary
-
Returns the summary stats for the alignment duration.
- getAllAccumulatorResults() - Method in class org.apache.flink.api.common.JobExecutionResult
-
Gets all accumulators produced by the job.
- getAllAccumulatorResults() - Method in class org.apache.flink.client.program.DetachedEnvironment.DetachedJobExecutionResult
-
- getAllAccumulators() - Method in interface org.apache.flink.api.common.functions.RuntimeContext
-
- getAllAccumulators() - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
-
- getAllAggregators() - Method in class org.apache.flink.runtime.iterative.task.RuntimeAggregatorRegistry
-
- getAllAndLock() - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
-
Gets all available state handles from ZooKeeper and locks the respective state nodes.
- getAllCheckpoints() - Method in interface org.apache.flink.runtime.checkpoint.CompletedCheckpointStore
-
- getAllCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.StandaloneCompletedCheckpointStore
-
- getAllCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.ZooKeeperCompletedCheckpointStore
-
- getAllDeclaredFields(Class<?>, boolean) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
Recursively determine all declared fields
This is required because class.getFields() is not returning fields defined
in parent classes.
- getAllDeclaredMethods(Class<?>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractionUtils
-
Returns all declared methods of a class including methods of superclasses.
- getAllExecutionVertexes() - Method in class org.apache.flink.runtime.executiongraph.failover.FailoverRegion
-
get all execution vertexes contained in this region
- getAllExecutionVertices() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionGraph
-
Returns an iterable containing all execution vertices for this execution graph.
- getAllExecutionVertices() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
-
- getAllExecutionVertices() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- getAllInputGates() - Method in interface org.apache.flink.runtime.execution.Environment
-
- getAllInputGates() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
-
- getAllInputGates() - Method in class org.apache.flink.runtime.taskmanager.Task
-
- getAllIntermediateResults() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- getAllLibraries() - Method in class org.apache.flink.client.program.PackagedProgram
-
Returns all provided libraries needed to run the program.
- getAllNodes() - Method in class org.apache.flink.optimizer.plan.OptimizedPlan
-
Gets all the nodes from this OptimizedPlan.
- getAllocatedSlots() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotPool
-
- getAllocatedSlots(JobID) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
-
Return an iterator of allocated slots for the given job id.
- getAllocationId() - Method in class org.apache.flink.runtime.clusterframework.types.TaskManagerSlot
-
- getAllocationId() - Method in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
-
- getAllocationId() - Method in class org.apache.flink.runtime.instance.SharedSlot
-
- getAllocationId() - Method in class org.apache.flink.runtime.instance.SimpleSlot
-
- getAllocationId() - Method in class org.apache.flink.runtime.instance.SimpleSlotContext
-
- getAllocationId() - Method in interface org.apache.flink.runtime.jobmaster.LogicalSlot
-
Gets the allocation id of this slot.
- getAllocationId() - Method in interface org.apache.flink.runtime.jobmaster.SlotContext
-
Gets the id under which the slot has been allocated on the TaskManager.
- getAllocationId() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SingleLogicalSlot
-
- getAllocationId() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.PendingSlotRequest
-
- getAllocationId() - Method in class org.apache.flink.runtime.resourcemanager.SlotRequest
-
Get the unique identification of this request
- getAllocationId() - Method in exception org.apache.flink.runtime.taskexecutor.exceptions.SlotOccupiedException
-
- getAllocationId() - Method in class org.apache.flink.runtime.taskexecutor.slot.SlotOffer
-
- getAllocationId() - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlot
-
- getAllocationID() - Method in class org.apache.flink.runtime.taskexecutor.SlotStatus
-
Get the allocation id of this slot
- getAllocationId() - Method in class org.apache.flink.runtime.taskmanager.Task
-
- getAllocationIDAsString() - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
-
- getAllocationIDAsString() - Method in class org.apache.flink.api.common.TaskInfo
-
Returns the allocation id for where this task is executed.
- getAllocationIdsPerJob(JobID) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
-
- getAllocationTimeout() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- getAllOperators() - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
-
- getAllowNonRestoredState() - Method in class org.apache.flink.runtime.webmonitor.handlers.JarRunRequestBody
-
- getAllowOrigin() - Method in class org.apache.flink.runtime.webmonitor.WebMonitorConfig
-
- getAllowQueuedScheduling() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
- getAllPartitionsForTopics(List<String>) - Method in class org.apache.flink.streaming.connectors.kafka.internal.Kafka09PartitionDiscoverer
-
- getAllPartitionsForTopics(List<String>) - Method in class org.apache.flink.streaming.connectors.kafka.internals.AbstractPartitionDiscoverer
-
Fetch the list of all partitions for a specific topics list from Kafka.
- getAllPartitionsForTopics(List<String>) - Method in class org.apache.flink.streaming.connectors.kafka.internals.Kafka08PartitionDiscoverer
-
- getAllPaths() - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
-
Return a list of all valid paths for state handles.
- getAllRegisteredAggregators() - Method in class org.apache.flink.api.common.aggregators.AggregatorRegistry
-
- getAllRegisteredInstances() - Method in class org.apache.flink.runtime.instance.InstanceManager
-
- getAllSortedByNameAndLock() - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
-
Gets all available state handles from ZooKeeper sorted by name (ascending) and locks the
respective state nodes.
- getAllSubtaskMetricStores() - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.MetricStore.TaskMetricStore
-
- getAllTaskStateStats() - Method in class org.apache.flink.runtime.checkpoint.AbstractCheckpointStats
-
Returns all task state stats instances.
- getAllTopics() - Method in class org.apache.flink.streaming.connectors.kafka.internal.Kafka09PartitionDiscoverer
-
- getAllTopics() - Method in class org.apache.flink.streaming.connectors.kafka.internals.AbstractPartitionDiscoverer
-
Fetch the list of all topics from Kafka.
- getAllTopics() - Method in class org.apache.flink.streaming.connectors.kafka.internals.Kafka08PartitionDiscoverer
-
- getAllVariables() - Method in class org.apache.flink.metrics.groups.UnregisteredMetricsGroup
-
- getAllVariables() - Method in interface org.apache.flink.metrics.MetricGroup
-
Returns a map of all variables and their associated value, for example
{"<host>"="host-7", "<tm_id>"="taskmanager-2"}
.
- getAllVariables() - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
-
- getAllVariables() - Method in class org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
-
- getAllVertices() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionGraph
-
Returns a map containing all job vertices for this execution graph.
- getAllVertices() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
-
- getAllVertices() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- getAllWriters() - Method in interface org.apache.flink.runtime.execution.Environment
-
- getAllWriters() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
-
- getAlt() - Method in class org.apache.flink.api.java.utils.Option
-
- getAlternativePlans(CostEstimator) - Method in class org.apache.flink.optimizer.dag.AbstractPartialSolutionNode
-
- getAlternativePlans(CostEstimator) - Method in class org.apache.flink.optimizer.dag.BinaryUnionNode
-
- getAlternativePlans(CostEstimator) - Method in class org.apache.flink.optimizer.dag.DataSinkNode
-
- getAlternativePlans(CostEstimator) - Method in class org.apache.flink.optimizer.dag.DataSourceNode
-
- getAlternativePlans(CostEstimator) - Method in class org.apache.flink.optimizer.dag.OptimizerNode
-
Computes the plan alternatives for this node, an implicitly for all nodes that are children of
this node.
- getAlternativePlans(CostEstimator) - Method in class org.apache.flink.optimizer.dag.SingleInputNode
-
- getAlternativePlans(CostEstimator) - Method in class org.apache.flink.optimizer.dag.TwoInputNode
-
- getAlwaysParentFirstLoaderPatterns() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
-
- getAnalyzedUdfSemanticsFlag() - Method in class org.apache.flink.api.java.operators.SingleInputUdfOperator
-
- getAnalyzedUdfSemanticsFlag() - Method in class org.apache.flink.api.java.operators.TwoInputUdfOperator
-
- getAndIncrement() - Method in interface org.apache.flink.runtime.checkpoint.CheckpointIDCounter
-
Atomically increments the current checkpoint ID.
- getAndIncrement() - Method in class org.apache.flink.runtime.checkpoint.StandaloneCheckpointIDCounter
-
- getAndIncrement() - Method in class org.apache.flink.runtime.checkpoint.ZooKeeperCheckpointIDCounter
-
- getAndLock(String) - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
-
- getAndRemove(String) - Method in class org.apache.flink.runtime.iterative.concurrent.Broker
-
Blocking retrieval and removal of the object to share.
- getAndResetUnannouncedCredit() - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
-
Gets the unannounced credit and resets it to 0 atomically.
- getAppConfigurationEntry(String) - Method in class org.apache.flink.runtime.security.DynamicConfiguration
-
Retrieve the AppConfigurationEntries for the specified name
from this Configuration.
- getApplicationId() - Method in class org.apache.flink.yarn.YarnClusterClient
-
- getApplicationStatus() - Method in class org.apache.flink.runtime.jobmaster.JobResult
-
- getApplicationStatusNow() - Method in class org.apache.flink.yarn.cli.YarnApplicationStatusMonitor
-
- getApplyBcastVars() - Method in class org.apache.flink.graph.gsa.GSAConfiguration
-
Get the broadcast variables of the ApplyFunction.
- getArchivedExecutionConfig() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionGraph
-
- getArchivedExecutionConfig() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
-
- getArchivedExecutionConfig() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- getArchivedJsons(Path) - Static method in class org.apache.flink.runtime.history.FsJobArchivist
-
- getArchivistClass() - Method in class org.apache.flink.mesos.runtime.clusterframework.MesosApplicationMasterRunner
-
- getArchivistClass() - Method in class org.apache.flink.yarn.YarnApplicationMasterRunner
-
- getArgs() - Method in class org.apache.flink.client.cli.CancelOptions
-
- getArgs() - Method in class org.apache.flink.client.cli.SavepointOptions
-
- getArgs() - Method in class org.apache.flink.client.cli.StopOptions
-
- getArgs() - Method in class org.apache.flink.runtime.rpc.messages.LocalRpcInvocation
-
- getArgs() - Method in class org.apache.flink.runtime.rpc.messages.RemoteRpcInvocation
-
- getArgs() - Method in interface org.apache.flink.runtime.rpc.messages.RpcInvocation
-
Returns the arguments of the remote procedure call
- getArguments() - Method in class org.apache.flink.client.program.PackagedProgram
-
- getArity() - Method in class org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
-
- getArity() - Method in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
-
- getArity() - Method in class org.apache.flink.api.common.typeinfo.NothingTypeInfo
-
- getArity() - Method in class org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
-
- getArity() - Method in class org.apache.flink.api.common.typeinfo.SqlTimeTypeInfo
-
- getArity() - Method in class org.apache.flink.api.common.typeinfo.TypeInformation
-
Gets the arity of this type - the number of fields without nesting.
- getArity() - Method in class org.apache.flink.api.java.tuple.Tuple
-
Gets the number of field in the tuple (the tuple arity).
- getArity() - Method in class org.apache.flink.api.java.tuple.Tuple0
-
- getArity() - Method in class org.apache.flink.api.java.tuple.Tuple1
-
- getArity() - Method in class org.apache.flink.api.java.tuple.Tuple10
-
- getArity() - Method in class org.apache.flink.api.java.tuple.Tuple11
-
- getArity() - Method in class org.apache.flink.api.java.tuple.Tuple12
-
- getArity() - Method in class org.apache.flink.api.java.tuple.Tuple13
-
- getArity() - Method in class org.apache.flink.api.java.tuple.Tuple14
-
- getArity() - Method in class org.apache.flink.api.java.tuple.Tuple15
-
- getArity() - Method in class org.apache.flink.api.java.tuple.Tuple16
-
- getArity() - Method in class org.apache.flink.api.java.tuple.Tuple17
-
- getArity() - Method in class org.apache.flink.api.java.tuple.Tuple18
-
- getArity() - Method in class org.apache.flink.api.java.tuple.Tuple19
-
- getArity() - Method in class org.apache.flink.api.java.tuple.Tuple2
-
- getArity() - Method in class org.apache.flink.api.java.tuple.Tuple20
-
- getArity() - Method in class org.apache.flink.api.java.tuple.Tuple21
-
- getArity() - Method in class org.apache.flink.api.java.tuple.Tuple22
-
- getArity() - Method in class org.apache.flink.api.java.tuple.Tuple23
-
- getArity() - Method in class org.apache.flink.api.java.tuple.Tuple24
-
- getArity() - Method in class org.apache.flink.api.java.tuple.Tuple25
-
- getArity() - Method in class org.apache.flink.api.java.tuple.Tuple3
-
- getArity() - Method in class org.apache.flink.api.java.tuple.Tuple4
-
- getArity() - Method in class org.apache.flink.api.java.tuple.Tuple5
-
- getArity() - Method in class org.apache.flink.api.java.tuple.Tuple6
-
- getArity() - Method in class org.apache.flink.api.java.tuple.Tuple7
-
- getArity() - Method in class org.apache.flink.api.java.tuple.Tuple8
-
- getArity() - Method in class org.apache.flink.api.java.tuple.Tuple9
-
- getArity() - Method in class org.apache.flink.api.java.typeutils.EitherTypeInfo
-
- getArity() - Method in class org.apache.flink.api.java.typeutils.EnumTypeInfo
-
- getArity() - Method in class org.apache.flink.api.java.typeutils.GenericTypeInfo
-
- getArity() - Method in class org.apache.flink.api.java.typeutils.ListTypeInfo
-
- getArity() - Method in class org.apache.flink.api.java.typeutils.MapTypeInfo
-
- getArity() - Method in class org.apache.flink.api.java.typeutils.MissingTypeInfo
-
- getArity() - Method in class org.apache.flink.api.java.typeutils.ObjectArrayTypeInfo
-
- getArity() - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo
-
- getArity() - Method in class org.apache.flink.api.java.typeutils.runtime.RowSerializer
-
- getArity() - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializerBase
-
- getArity() - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfoBase
-
- getArity() - Method in class org.apache.flink.api.java.typeutils.ValueTypeInfo
-
- getArity() - Method in class org.apache.flink.api.java.typeutils.WritableTypeInfo
-
- getArity() - Method in class org.apache.flink.graph.drivers.transform.LongValueWithProperHashCode.LongValueWithProperHashCodeTypeInfo
-
- getArity() - Method in class org.apache.flink.graph.types.valuearray.ValueArrayTypeInfo
-
- getArity() - Method in class org.apache.flink.queryablestate.client.VoidNamespaceTypeInfo
-
- getArity() - Method in class org.apache.flink.runtime.state.VoidNamespaceTypeInfo
-
- getArity() - Method in class org.apache.flink.types.Row
-
Get the number of fields in the Row.
- getArray() - Method in class org.apache.flink.core.memory.HeapMemorySegment
-
Gets the byte array that backs this memory segment.
- getArray() - Method in class org.apache.flink.core.memory.MemorySegment
-
Returns the byte array of on-heap memory segments.
- getArtifacts() - Method in class org.apache.flink.runtime.clusterframework.ContainerSpecification
-
Get the container artifacts.
- getArtifactServer() - Method in class org.apache.flink.mesos.runtime.clusterframework.services.AbstractMesosServices
-
- getArtifactServer() - Method in interface org.apache.flink.mesos.runtime.clusterframework.services.MesosServices
-
Gets the artifact server with which to serve essential resources to task managers.
- getAsBoolean() - Method in enum org.apache.flink.util.TernaryBoolean
-
Gets this ternary boolean as a boxed boolean.
- getAssignedAllocationID() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecution
-
- getAssignedAllocationID() - Method in class org.apache.flink.runtime.executiongraph.Execution
-
- getAssignedResource() - Method in class org.apache.flink.runtime.executiongraph.Execution
-
- getAssignedResourceLocation() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecution
-
- getAssignedResourceLocation() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecution
-
- getAssignedResourceLocation() - Method in class org.apache.flink.runtime.executiongraph.Execution
-
- getAssignedSlotRequest() - Method in class org.apache.flink.runtime.clusterframework.types.TaskManagerSlot
-
- getAssignmentMode() - Method in class org.apache.flink.runtime.state.RegisteredBroadcastBackendStateMetaInfo
-
- getAssignmentMode() - Method in class org.apache.flink.runtime.state.RegisteredBroadcastBackendStateMetaInfo.Snapshot
-
- getAssignmentMode() - Method in class org.apache.flink.runtime.state.RegisteredOperatorBackendStateMetaInfo
-
- getAssignmentMode() - Method in class org.apache.flink.runtime.state.RegisteredOperatorBackendStateMetaInfo.Snapshot
-
- getAsyncCheckpointDuration() - Method in class org.apache.flink.runtime.checkpoint.SubtaskStateStats
-
Returns the duration of the asynchronous part of the checkpoint.
- getAsyncCheckpointDurationStats() - Method in class org.apache.flink.runtime.checkpoint.TaskStateStats.TaskStateStatsSummary
-
Returns the summary stats for the async checkpoint duration.
- getAsyncDuration() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics.CheckpointDuration
-
- getAsyncDurationMillis() - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetrics
-
- getAsyncExecutor() - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerServices
-
Gets the async executor which executes outside of the main thread of the ResourceManager
- getAsynchronousDuration() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.CheckpointDuration
-
- getAsyncOperationsThreadPool() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- getAttempt() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsInfo
-
- getAttemptId() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecution
-
- getAttemptId() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecution
-
- getAttemptId() - Method in class org.apache.flink.runtime.executiongraph.Execution
-
- getAttemptNumber() - Method in interface org.apache.flink.api.common.functions.RuntimeContext
-
Gets the attempt number of this parallel subtask.
- getAttemptNumber() - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
-
- getAttemptNumber() - Method in class org.apache.flink.api.common.TaskInfo
-
Gets the attempt number of this parallel subtask.
- getAttemptNumber() - Method in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
-
Returns the attempt number of the subtask.
- getAttemptNumber() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecution
-
Returns the attempt number for this execution.
- getAttemptNumber() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecution
-
- getAttemptNumber() - Method in class org.apache.flink.runtime.executiongraph.Execution
-
- getAttributeMap() - Method in class org.apache.flink.mesos.scheduler.Offer
-
- getAttributes() - Method in interface org.apache.flink.streaming.connectors.nifi.NiFiDataPacket
-
- getAttributes() - Method in class org.apache.flink.streaming.connectors.nifi.StandardNiFiDataPacket
-
- getAuthorityScore() - Method in class org.apache.flink.graph.library.linkanalysis.HITS.Result
-
Get the authority score.
- getAutoWatermarkInterval() - Method in class org.apache.flink.api.common.ExecutionConfig
-
Returns the interval of the automatic watermark emission.
- getAvailableJobDetails() - Method in interface org.apache.flink.runtime.dispatcher.ArchivedExecutionGraphStore
-
Return the collection of
JobDetails
of all currently stored jobs.
- getAvailableJobDetails(JobID) - Method in interface org.apache.flink.runtime.dispatcher.ArchivedExecutionGraphStore
-
- getAvailableJobDetails() - Method in class org.apache.flink.runtime.dispatcher.FileArchivedExecutionGraphStore
-
- getAvailableJobDetails(JobID) - Method in class org.apache.flink.runtime.dispatcher.FileArchivedExecutionGraphStore
-
- getAvailableJobDetails() - Method in class org.apache.flink.runtime.dispatcher.MemoryArchivedExecutionGraphStore
-
- getAvailableJobDetails(JobID) - Method in class org.apache.flink.runtime.dispatcher.MemoryArchivedExecutionGraphStore
-
- getAvailablePort() - Static method in class org.apache.flink.util.NetUtils
-
Find a non-occupied port.
- getAvailableSlots() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotPool
-
- getAverage() - Method in class org.apache.flink.runtime.checkpoint.MinMaxAvgStats
-
Calculates the average over all seen values.
- getAverage() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.MinMaxAvgStatistics
-
- getAverageClusteringCoefficient() - Method in class org.apache.flink.graph.library.clustering.directed.AverageClusteringCoefficient.Result
-
Get the average clustering coefficient.
- getAverageClusteringCoefficient() - Method in class org.apache.flink.graph.library.clustering.undirected.AverageClusteringCoefficient.Result
-
Get the average clustering coefficient.
- getAverageDegree() - Method in class org.apache.flink.graph.library.metric.directed.VertexMetrics.Result
-
Get the average degree, the average number of in- plus out-edges per vertex.
- getAverageDegree() - Method in class org.apache.flink.graph.library.metric.undirected.VertexMetrics.Result
-
Get the average degree, the average number of edges per vertex.
- getAverageRecordWidth() - Method in class org.apache.flink.api.common.io.FileInputFormat.FileBaseStatistics
-
Gets the estimated average number of bytes per record.
- getAverageRecordWidth() - Method in interface org.apache.flink.api.common.io.statistics.BaseStatistics
-
Gets the average width of a record, in bytes.
- getAvg() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedMetric
-
- getAvgOutputRecordSize() - Method in class org.apache.flink.api.common.operators.CompilerHints
-
- getAvroRecordClass() - Method in class org.apache.flink.streaming.connectors.kafka.KafkaAvroTableSource.Builder
-
Returns the configured Avro class.
- getAvroUtils() - Static method in class 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.
- getAwaitLeaderTimeout() - Method in class org.apache.flink.client.program.rest.RestClusterClientConfiguration
-
- getBackendIdentifier() - Method in class org.apache.flink.runtime.state.IncrementalKeyedStateHandle
-
- getBackendIdentifier() - Method in class org.apache.flink.runtime.state.IncrementalLocalKeyedStateHandle
-
- getBackoffType() - Method in class org.apache.flink.streaming.connectors.elasticsearch.ElasticsearchSinkBase.BulkFlushBackoffPolicy
-
- getBackpressureLevel() - Method in class org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo
-
- getBackpressureLevel() - Method in class org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo.SubtaskBackPressureInfo
-
- getBackPressureRatio(int) - Method in class org.apache.flink.runtime.rest.handler.legacy.backpressure.OperatorBackPressureStats
-
Returns the ratio of stack traces indicating back pressure to total
number of sampled stack traces.
- getBackPressureStatsTracker() - Method in class org.apache.flink.runtime.jobmaster.JobManagerSharedServices
-
- getBasePath() - Method in class org.apache.flink.runtime.state.filesystem.FsStateBackend
-
- getBaseStatistics(String) - Method in class org.apache.flink.optimizer.DataStatistics
-
Gets the base statistics for the input identified by the given identifier.
- getBasicAndBasicValueTupleTypeInfo(Class<?>...) - Static method in class org.apache.flink.api.java.typeutils.TupleTypeInfo
-
- getBasicTupleTypeInfo(Class<?>...) - Static method in class org.apache.flink.api.java.typeutils.TupleTypeInfo
-
- getBatchBlocking() - Method in class org.apache.flink.streaming.connectors.kafka.internals.ClosableBlockingQueue
-
Gets all the elements found in the list, or blocks until at least one element
was added.
- getBatchBlocking(long) - Method in class org.apache.flink.streaming.connectors.kafka.internals.ClosableBlockingQueue
-
Gets all the elements found in the list, or blocks until at least one element
was added.
- getBatchModel() - Method in class org.apache.flink.streaming.examples.ml.IncrementalLearningSkeleton.Predictor
-
- getBcastVars() - Method in class org.apache.flink.graph.pregel.VertexCentricConfiguration
-
Get the broadcast variables of the compute function.
- getBinary(int) - Method in class org.apache.flink.storm.wrappers.StormTuple
-
- getBinaryByField(String) - Method in class org.apache.flink.storm.wrappers.StormTuple
-
- getBinaryLength() - Method in class org.apache.flink.graph.types.valuearray.ByteValueArray
-
- getBinaryLength() - Method in class org.apache.flink.graph.types.valuearray.CharValueArray
-
- getBinaryLength() - Method in class org.apache.flink.graph.types.valuearray.DoubleValueArray
-
- getBinaryLength() - Method in class org.apache.flink.graph.types.valuearray.FloatValueArray
-
- getBinaryLength() - Method in class org.apache.flink.graph.types.valuearray.IntValueArray
-
- getBinaryLength() - Method in class org.apache.flink.graph.types.valuearray.LongValueArray
-
- getBinaryLength() - Method in class org.apache.flink.graph.types.valuearray.NullValueArray
-
- getBinaryLength() - Method in class org.apache.flink.graph.types.valuearray.ShortValueArray
-
- getBinaryLength() - Method in class org.apache.flink.graph.types.valuearray.StringValueArray
-
- getBinaryLength() - Method in class org.apache.flink.types.BooleanValue
-
- getBinaryLength() - Method in class org.apache.flink.types.ByteValue
-
- getBinaryLength() - Method in class org.apache.flink.types.CharValue
-
- getBinaryLength() - Method in interface org.apache.flink.types.CopyableValue
-
Gets the length of the data type when it is serialized, in bytes.
- getBinaryLength() - Method in class org.apache.flink.types.DoubleValue
-
- getBinaryLength() - Method in class org.apache.flink.types.FloatValue
-
- getBinaryLength() - Method in class org.apache.flink.types.IntValue
-
- getBinaryLength() - Method in class org.apache.flink.types.LongValue
-
- getBinaryLength() - Method in class org.apache.flink.types.NullValue
-
- getBinaryLength() - Method in class org.apache.flink.types.Record
-
- getBinaryLength() - Method in class org.apache.flink.types.ShortValue
-
- getBinaryLength() - Method in class org.apache.flink.types.StringValue
-
- getBinaryOperatorReturnType(Function, Class<?>, int, int, int, int[], int[], int[], TypeInformation<IN1>, TypeInformation<IN2>, String, boolean) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
Returns the binary operator's return type.
- getBindAddress() - Method in class org.apache.flink.streaming.experimental.SocketStreamIterator
-
- getBitmask() - Method in enum org.apache.flink.graph.EdgeOrder
-
Returns a bitmask used for marking whether an edge is in the same
direction as in the original edge set (FORWARD), is flipped relative
to the original edge set (REVERSE), or both (MUTUAL).
- getBitmask() - Method in class org.apache.flink.graph.library.clustering.directed.TriangleListing.Result
-
Get the bitmask indicating the presence of the six potential
connecting edges.
- getBitSize(long) - Static method in class org.apache.flink.api.java.utils.DataSetUtils
-
- getBlobManagerPort() - Method in class org.apache.flink.runtime.jobmaster.message.ClassloadingProps
-
- getBlobServerHostname() - Method in class org.apache.flink.runtime.entrypoint.ClusterInformation
-
- getBlobServerPort(Time) - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
-
- getBlobServerPort(Time) - Method in interface org.apache.flink.runtime.dispatcher.DispatcherGateway
-
Returns the port of the blob server.
- getBlobServerPort() - Method in class org.apache.flink.runtime.entrypoint.ClusterInformation
-
- getBlobWriter() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- getBlockCount() - Method in class org.apache.flink.graph.generator.random.BlockInfo
-
- getBlockCount() - Method in class org.apache.flink.runtime.io.disk.FileChannelOutputView
-
Gets the number of blocks written by this output view.
- getBlockCount() - Method in class org.apache.flink.runtime.io.disk.iomanager.ChannelWriterOutputView
-
Gets the number of blocks used by this view.
- getBlockCount() - Method in class org.apache.flink.runtime.operators.hash.InMemoryPartition
-
- getBlockCount() - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.ChannelWithBlockCount
-
- getBlockIndex() - Method in class org.apache.flink.graph.generator.random.BlockInfo
-
- getBlockSize() - Method in class org.apache.flink.api.common.io.BinaryInputFormat
-
- getBlockSize() - Method in interface org.apache.flink.core.fs.FileStatus
-
Get the block size of the file.
- getBlockSize() - Method in class org.apache.flink.core.fs.local.LocalFileStatus
-
- getBlockSize() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileStatus
-
- getBoolean(String) - Method in class org.apache.flink.api.java.utils.ParameterTool
-
Returns the Boolean value for the given key.
- getBoolean(String, boolean) - Method in class org.apache.flink.api.java.utils.ParameterTool
-
Returns the Boolean value for the given key.
- getBoolean(String, boolean) - Method in class org.apache.flink.configuration.Configuration
-
Returns the value associated with the given key as a boolean.
- getBoolean(ConfigOption<Boolean>) - Method in class org.apache.flink.configuration.Configuration
-
Returns the value associated with the given config option as a boolean.
- getBoolean(ConfigOption<Boolean>, boolean) - Method in class org.apache.flink.configuration.Configuration
-
Returns the value associated with the given config option as a boolean.
- getBoolean(String, boolean) - Method in class org.apache.flink.configuration.DelegatingConfiguration
-
- getBoolean(ConfigOption<Boolean>) - Method in class org.apache.flink.configuration.DelegatingConfiguration
-
- getBoolean(ConfigOption<Boolean>, boolean) - Method in class org.apache.flink.configuration.DelegatingConfiguration
-
- getBoolean(int) - Method in class org.apache.flink.core.memory.HeapMemorySegment
-
- getBoolean(int) - Method in class org.apache.flink.core.memory.HybridMemorySegment
-
- getBoolean(int) - Method in class org.apache.flink.core.memory.MemorySegment
-
Reads one byte at the given position and returns its boolean
representation.
- getBoolean(String, boolean) - Method in class org.apache.flink.metrics.MetricConfig
-
Searches for the property with the specified key in this property list.
- getBoolean(int) - Method in class org.apache.flink.storm.wrappers.StormTuple
-
- getBoolean(Properties, String, boolean) - Static method in class org.apache.flink.util.PropertiesUtil
-
Get boolean from properties.
- getBoolean(String, boolean) - Method in class org.apache.hadoop.conf.Configuration
-
Get the value of the name
property as a boolean
.
- getBooleanByField(String) - Method in class org.apache.flink.storm.wrappers.StormTuple
-
- getBootstrap() - Method in class org.apache.flink.runtime.webmonitor.utils.WebFrontendBootstrap
-
- getBottomId() - Method in class org.apache.flink.graph.bipartite.BipartiteEdge
-
- getBottomVertices() - Method in class org.apache.flink.graph.bipartite.BipartiteGraph
-
Get dataset with bottom vertices.
- getBranchesForParent(DagConnection) - Method in class org.apache.flink.optimizer.dag.DataSinkNode
-
- getBranchesForParent(DagConnection) - Method in class org.apache.flink.optimizer.dag.OptimizerNode
-
- getBranchingNode() - Method in class org.apache.flink.optimizer.dag.OptimizerNode.UnclosedBranchDescriptor
-
- getBranchPlan() - Method in class org.apache.flink.optimizer.plan.PlanNode
-
- getBroadcastConnectionNames() - Method in class org.apache.flink.optimizer.dag.OptimizerNode
-
Return the list of names associated with broadcast inputs for this node.
- getBroadcastConnections() - Method in class org.apache.flink.optimizer.dag.OptimizerNode
-
Return the list of inputs associated with broadcast variables for this node.
- getBroadcastGroupSize(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getBroadcastInputName(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getBroadcastInputs() - Method in class org.apache.flink.api.common.operators.AbstractUdfOperator
-
Returns the input, or null, if none is set.
- getBroadcastInputs() - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase
-
The BulkIteration meta operator cannot have broadcast inputs.
- getBroadcastInputs() - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase
-
DeltaIteration meta operator cannot have broadcast inputs.
- getBroadcastInputs() - Method in class org.apache.flink.optimizer.plan.PlanNode
-
Gets a list of all broadcast inputs attached to this node.
- getBroadcastInputSerializer(int, ClassLoader) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getBroadcastSet(String) - Method in class org.apache.flink.graph.gsa.ApplyFunction
-
Gets the broadcast data set registered under the given name.
- getBroadcastSet(String) - Method in class org.apache.flink.graph.gsa.GatherFunction
-
Gets the broadcast data set registered under the given name.
- getBroadcastSet(String) - Method in class org.apache.flink.graph.gsa.SumFunction
-
Gets the broadcast data set registered under the given name.
- getBroadcastSet(String) - Method in class org.apache.flink.graph.pregel.ComputeFunction
-
Gets the broadcast data set registered under the given name.
- getBroadcastSet(String) - Method in class org.apache.flink.graph.spargel.GatherFunction
-
Gets the broadcast data set registered under the given name.
- getBroadcastSet(String) - Method in class org.apache.flink.graph.spargel.ScatterFunction
-
Gets the broadcast data set registered under the given name.
- getBroadcastSets() - Method in class org.apache.flink.api.java.operators.SingleInputUdfOperator
-
- getBroadcastSets() - Method in class org.apache.flink.api.java.operators.TwoInputUdfOperator
-
- getBroadcastSets() - Method in interface org.apache.flink.api.java.operators.UdfOperator
-
Gets the broadcast sets (name and data set) that have been added to context of the UDF.
- getBroadcastState(MapStateDescriptor<K, V>) - Method in interface org.apache.flink.api.common.state.OperatorStateStore
-
- getBroadcastState(MapStateDescriptor<K, V>) - Method in class org.apache.flink.runtime.state.DefaultOperatorStateBackend
-
- getBroadcastState(MapStateDescriptor<K, V>) - Method in class org.apache.flink.streaming.api.functions.co.BaseBroadcastProcessFunction.Context
-
- getBroadcastState(MapStateDescriptor<K, V>) - Method in class org.apache.flink.streaming.api.functions.co.BaseBroadcastProcessFunction.ReadOnlyContext
-
Fetches a read-only view of the broadcast state with the specified name.
- getBroadcastStateDescriptor() - Method in class org.apache.flink.streaming.api.datastream.BroadcastStream
-
- getBroadcastStateMetaInfoSnapshots() - Method in class org.apache.flink.runtime.state.OperatorBackendSerializationProxy
-
- getBroadcastStateReaderForVersion(int, ClassLoader) - Static method in class org.apache.flink.runtime.state.OperatorBackendStateMetaInfoSnapshotReaderWriters
-
- getBroadcastStateWriterForVersion(int, RegisteredBroadcastBackendStateMetaInfo.Snapshot<K, V>) - Static method in class org.apache.flink.runtime.state.OperatorBackendStateMetaInfoSnapshotReaderWriters
-
- getBroadcastVariable(String) - Method in interface org.apache.flink.api.common.functions.RuntimeContext
-
Returns the result bound to the broadcast variable identified by the
given name
.
- getBroadcastVariable(String) - Method in class org.apache.flink.api.common.functions.util.RuntimeUDFContext
-
- getBroadcastVariable(String) - Method in class org.apache.flink.runtime.operators.util.DistributedRuntimeUDFContext
-
- getBroadcastVariable(String) - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
-
- getBroadcastVariableManager() - Method in interface org.apache.flink.runtime.execution.Environment
-
- getBroadcastVariableManager() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServices
-
- getBroadcastVariableManager() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
-
- getBroadcastVariableWithInitializer(String, BroadcastVariableInitializer<T, C>) - Method in interface org.apache.flink.api.common.functions.RuntimeContext
-
Returns the result bound to the broadcast variable identified by the
given name
.
- getBroadcastVariableWithInitializer(String, BroadcastVariableInitializer<T, C>) - Method in class org.apache.flink.api.common.functions.util.RuntimeUDFContext
-
- getBroadcastVariableWithInitializer(String, BroadcastVariableInitializer<T, C>) - Method in class org.apache.flink.runtime.operators.util.DistributedRuntimeUDFContext
-
- getBroadcastVariableWithInitializer(String, BroadcastVariableInitializer<T, C>) - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
-
- getBrokerID(Integer) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- getBucketBoundary(int, int) - Method in interface org.apache.flink.api.common.distributions.DataDistribution
-
Returns the i'th bucket's upper bound, given that the distribution is to be
split into totalBuckets
buckets.
- getBucketPath(Clock, Path, T) - Method in class org.apache.flink.streaming.connectors.fs.bucketing.BasePathBucketer
-
- getBucketPath(Clock, Path, T) - Method in interface org.apache.flink.streaming.connectors.fs.bucketing.Bucketer
-
Returns the Path
of a bucket file.
- getBucketPath(Clock, Path, T) - Method in class org.apache.flink.streaming.connectors.fs.bucketing.DateTimeBucketer
-
- getBucketPath(Clock, Path, Tuple4<Integer, Long, Integer, String>) - Method in class org.apache.flink.streaming.tests.BucketingSinkTestProgram.KeyBucketer
-
- getBuf() - Method in class org.apache.flink.core.memory.ByteArrayOutputStreamWithPos
-
- getBuffer() - Method in class org.apache.flink.runtime.io.network.partition.consumer.BufferOrEvent
-
- getBufferedData() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.CheckpointAlignment
-
- getBufferPool() - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
-
- getBufferPool() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
-
- getBufferProvider() - Method in interface org.apache.flink.runtime.io.network.api.writer.ResultPartitionWriter
-
- getBufferProvider() - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
-
- getBufferProvider() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
-
- getBuffersInBacklog() - Method in class org.apache.flink.runtime.io.network.partition.ResultSubpartition
-
Gets the number of non-event buffers in this subpartition.
- getBufferSize() - Method in class org.apache.flink.api.common.io.DelimitedInputFormat
-
- getBufferTimeout() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Gets the maximum time frequency (milliseconds) for the flushing of the
output buffers.
- getBufferTimeout() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getBufferTimeout() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getBufferTimeout() - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
-
Returns the buffer timeout of the job.
- getBufferTimeout() - Method in class org.apache.flink.streaming.api.transformations.StreamTransformation
-
Returns the buffer timeout of this StreamTransformation
.
- getBuildComparator() - Method in class org.apache.flink.api.common.operators.util.JoinHashMap
-
- getBuildSerializer() - Method in class org.apache.flink.api.common.operators.util.JoinHashMap
-
- getBuildSideBlockCount() - Method in class org.apache.flink.runtime.operators.hash.HashPartition
-
- getBuildSideChannel() - Method in class org.apache.flink.runtime.operators.hash.HashPartition
-
- getBuildSideComparator() - Method in class org.apache.flink.runtime.operators.hash.AbstractMutableHashTable
-
- getBuildSideIterator() - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
-
- getBuildSideRecordCount() - Method in class org.apache.flink.runtime.operators.hash.HashPartition
-
- getBuildSideSerializer() - Method in class org.apache.flink.runtime.operators.hash.AbstractMutableHashTable
-
- getByte(String) - Method in class org.apache.flink.api.java.utils.ParameterTool
-
Returns the Byte value for the given key.
- getByte(String, byte) - Method in class org.apache.flink.api.java.utils.ParameterTool
-
Returns the Byte value for the given key.
- getByte(int) - Method in class org.apache.flink.storm.wrappers.StormTuple
-
- getByteArray() - Method in class org.apache.flink.core.memory.DataOutputSerializer
-
- getByteArray() - Method in class org.apache.flink.util.SerializedValue
-
Returns the serialized value or null
if no value is set.
- getByteByField(String) - Method in class org.apache.flink.storm.wrappers.StormTuple
-
- getByteDiff() - Method in class org.apache.flink.streaming.connectors.wikiedits.WikipediaEditEvent
-
- getBytes(String, byte[]) - Method in class org.apache.flink.configuration.Configuration
-
Returns the value associated with the given key as a byte array.
- getBytes(String, byte[]) - Method in class org.apache.flink.configuration.DelegatingConfiguration
-
- getBytes() - Method in class org.apache.flink.configuration.MemorySize
-
Gets the memory size in bytes.
- getBytes(int, ByteBuf, int, int) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
-
- getBytes(int, byte[], int, int) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
-
- getBytes(int, ByteBuffer) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
-
- getBytes(int, OutputStream, int) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
-
- getBytes(int, GatheringByteChannel, int) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
-
- getBytes() - Method in class org.apache.flink.util.AbstractID
-
Gets the bytes underlying this ID.
- getBytesBlocked() - Method in interface org.apache.flink.streaming.runtime.io.BufferBlocker
-
Gets the number of bytes blocked in the current sequence.
- getBytesBlocked() - Method in class org.apache.flink.streaming.runtime.io.BufferSpiller
-
Deprecated.
Gets the number of bytes written in the current spill file.
- getBytesBlocked() - Method in class org.apache.flink.streaming.runtime.io.CachedBufferBlocker
-
- getBytesBufferedInAlignment() - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetrics
-
- getBytesInLatestSegment() - Method in class org.apache.flink.runtime.io.disk.FileChannelOutputView
-
Gets the number of bytes written in the latest memory segment.
- getBytesMemoryUsed() - Method in class org.apache.flink.runtime.io.disk.iomanager.ChannelWriterOutputView
-
Gets the number of bytes used by this output view, including written bytes and header bytes.
- getBytesRead() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.IOMetricsInfo
-
- getBytesWritten() - Method in class org.apache.flink.runtime.io.disk.iomanager.ChannelWriterOutputView
-
Gets the number of pay-load bytes already written.
- getBytesWritten() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.IOMetricsInfo
-
- getCachedFiles() - Method in class org.apache.flink.api.common.Plan
-
return the registered caches files
- getCachedFiles() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Get the list of cached files that were registered for distribution among the task managers.
- getCacheSize() - Method in class org.apache.flink.runtime.query.KvStateEntry
-
- getCalendar() - Method in class org.apache.calcite.avatica.util.DateTimeUtils.PrecisionTime
-
- getCallable() - Method in class org.apache.flink.runtime.rpc.messages.CallAsync
-
- getCallLocationName() - Static method in class org.apache.flink.api.java.Utils
-
- getCallLocationName(int) - Static method in class org.apache.flink.api.java.Utils
-
- getCancelables() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- getCandidateAtBranchPoint(OptimizerNode) - Method in class org.apache.flink.optimizer.plan.PlanNode
-
- getCapacity() - Method in class org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable
-
Gets the total capacity of this hash table, in bytes.
- getCapacity() - Method in class org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
-
- getCapacity() - Method in interface org.apache.flink.runtime.operators.sort.InMemorySorter
-
Gets the total capacity of this sorter, in bytes.
- getCapacity() - Method in class org.apache.flink.runtime.operators.sort.NormalizedKeySorter
-
- getCategory() - Method in class org.apache.flink.runtime.metrics.dump.MetricDump.CounterDump
-
- getCategory() - Method in class org.apache.flink.runtime.metrics.dump.MetricDump.GaugeDump
-
- getCategory() - Method in class org.apache.flink.runtime.metrics.dump.MetricDump
-
Returns the category for this MetricDump.
- getCategory() - Method in class org.apache.flink.runtime.metrics.dump.MetricDump.HistogramDump
-
- getCategory() - Method in class org.apache.flink.runtime.metrics.dump.MetricDump.MeterDump
-
- getCategory() - Method in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo
-
Returns the category for this QueryScopeInfo.
- getCategory() - Method in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.JobManagerQueryScopeInfo
-
- getCategory() - Method in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.JobQueryScopeInfo
-
- getCategory() - Method in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.OperatorQueryScopeInfo
-
- getCategory() - Method in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.TaskManagerQueryScopeInfo
-
- getCategory() - Method in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.TaskQueryScopeInfo
-
- getCause() - Method in class org.apache.flink.queryablestate.network.messages.RequestFailure
-
Returns the failure cause.
- getChainedOutputs(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getChainedStubConfig(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getChainedTask(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getChainedTaskName(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getChainEntryPoint() - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
-
- getChainIndex() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getChainingStrategy() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- getChainingStrategy() - Method in interface org.apache.flink.streaming.api.operators.StreamOperator
-
- getChainLength() - Method in class org.apache.flink.runtime.checkpoint.TaskState
-
Deprecated.
- getChainLength() - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
-
- getChannel() - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.ChannelWithBlockCount
-
- getChannel() - Method in class org.apache.flink.streaming.connectors.wikiedits.WikipediaEditEvent
-
- getChannelID() - Method in class org.apache.flink.runtime.io.disk.iomanager.AbstractFileIOChannel
-
- getChannelID() - Method in interface org.apache.flink.runtime.io.disk.iomanager.FileIOChannel
-
Gets the channel ID of this I/O channel.
- getChannelIndex() - Method in class org.apache.flink.runtime.io.network.partition.consumer.BufferOrEvent
-
- getChar(int) - Method in class org.apache.flink.core.memory.MemorySegment
-
Reads a char value from the given position, in the system's native byte order.
- getCharArray() - Method in class org.apache.flink.types.StringValue
-
Returns this StringValue's internal character data.
- getCharBigEndian(int) - Method in class org.apache.flink.core.memory.MemorySegment
-
Reads a character value (16 bit, 2 bytes) from the given position, in big-endian byte order.
- getCharLittleEndian(int) - Method in class org.apache.flink.core.memory.MemorySegment
-
Reads a character value (16 bit, 2 bytes) from the given position, in little-endian byte order.
- getCharset() - Method in class org.apache.flink.api.common.io.DelimitedInputFormat
-
Get the character set used for the row delimiter.
- getCharset() - Method in class org.apache.flink.api.common.serialization.SimpleStringSchema
-
Gets the charset used by this schema for serialization.
- getCharset() - Method in class org.apache.flink.api.java.io.CsvReader
-
Gets the character set for the reader.
- getCharset() - Method in class org.apache.flink.types.parser.FieldParser
-
Gets the character set used for this parser.
- getCharsetName() - Method in class org.apache.flink.api.java.io.TextInputFormat
-
- getCharsetName() - Method in class org.apache.flink.api.java.io.TextOutputFormat
-
- getCharsetName() - Method in class org.apache.flink.api.java.io.TextValueInputFormat
-
- getCheckpointAlignment() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.Summary
-
- getCheckpointBackend() - Method in class org.apache.flink.contrib.streaming.state.RocksDBStateBackend
-
Gets the state backend that this RocksDB state backend uses to persist
its bytes to.
- getCheckpointById(long) - Method in class org.apache.flink.runtime.checkpoint.CheckpointStatsHistory
-
- getCheckpointConfig() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Gets the checkpoint config, which defines values like checkpoint interval, delay between
checkpoints, etc.
- getCheckpointConfig() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- getCheckpointCoordinator() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- getCheckpointCoordinatorConfiguration() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionGraph
-
- getCheckpointCoordinatorConfiguration() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
-
- getCheckpointCoordinatorConfiguration() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- getCheckpointCoordinatorConfiguration() - Method in class org.apache.flink.runtime.jobgraph.tasks.JobCheckpointingSettings
-
- getCheckpointDeclineReason() - Method in exception org.apache.flink.runtime.checkpoint.CheckpointTriggerException
-
- getCheckpointDirectory() - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStorageLocation
-
- getCheckpointDirectoryForJob(Path, JobID) - Static method in class org.apache.flink.runtime.state.filesystem.AbstractFsCheckpointStorage
-
Builds directory into which a specific job checkpoints, meaning the directory inside which
it creates the checkpoint-specific subdirectories.
- getCheckpointDuration() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics
-
- getCheckpointDuration() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.Summary
-
- getCheckpointId() - Method in class org.apache.flink.runtime.checkpoint.AbstractCheckpointStats
-
Returns the ID of this checkpoint.
- getCheckpointId() - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetaData
-
- getCheckpointID() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
-
- getCheckpointId() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
-
- getCheckpointId() - Method in class org.apache.flink.runtime.checkpoint.RestoredCheckpointStats
-
Returns the ID of this checkpoint.
- getCheckpointId() - Method in interface org.apache.flink.runtime.checkpoint.savepoint.Savepoint
-
Returns the checkpoint ID of the savepoint.
- getCheckpointId() - Method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV1
-
- getCheckpointId() - Method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV2
-
- getCheckpointId() - Method in class org.apache.flink.runtime.io.network.api.CancelCheckpointMarker
-
- getCheckpointId() - Method in class org.apache.flink.runtime.messages.checkpoint.AbstractCheckpointMessage
-
- getCheckpointId() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatistics
-
- getCheckpointId() - Method in class org.apache.flink.runtime.state.IncrementalKeyedStateHandle
-
- getCheckpointId() - Method in class org.apache.flink.runtime.state.IncrementalLocalKeyedStateHandle
-
- getCheckpointId() - Method in interface org.apache.flink.runtime.state.ManagedSnapshotContext
-
Returns the ID of the checkpoint for which the snapshot is taken.
- getCheckpointId() - Method in class org.apache.flink.runtime.state.StateSnapshotContextSynchronousImpl
-
- getCheckpointIdCounter() - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
- getCheckpointingMode() - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Gets the checkpointing mode (exactly-once vs.
- getCheckpointingMode() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Returns the checkpointing mode (exactly-once vs.
- getCheckpointingSettings() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
Gets the settings for asynchronous snapshots.
- getCheckpointInterval() - Method in class org.apache.flink.runtime.jobgraph.tasks.CheckpointCoordinatorConfiguration
-
- getCheckpointInterval() - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Gets the interval in which checkpoints are periodically scheduled.
- getCheckpointInterval() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Returns the checkpointing interval or -1 if checkpointing is disabled.
- getCheckpointLock() - Method in interface org.apache.flink.streaming.api.functions.source.SourceFunction.SourceContext
-
Returns the checkpoint lock.
- getCheckpointLock() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
Gets the lock object on which all operations that involve data and state mutation have to lock.
- getCheckpointMetrics() - Method in class org.apache.flink.runtime.messages.checkpoint.AcknowledgeCheckpoint
-
- getCheckpointMode() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getCheckpointMode() - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
-
Returns the checkpointing mode.
- getCheckpointOptions() - Method in class org.apache.flink.runtime.io.network.api.CheckpointBarrier
-
- getCheckpointOptions() - Method in class org.apache.flink.runtime.messages.checkpoint.TriggerCheckpoint
-
- getCheckpointOutputStream() - Method in interface org.apache.flink.runtime.state.CheckpointStreamWithResultProvider
-
Returns the encapsulated output stream.
- getCheckpointOutputStream() - Method in class org.apache.flink.runtime.state.CheckpointStreamWithResultProvider.PrimaryAndSecondaryStream
-
- getCheckpointOutputStream() - Method in class org.apache.flink.runtime.state.CheckpointStreamWithResultProvider.PrimaryStreamOnly
-
- getCheckpointPath() - Method in class org.apache.flink.runtime.state.filesystem.AbstractFileStateBackend
-
Gets the checkpoint base directory.
- getCheckpointPath() - Method in class org.apache.flink.runtime.state.filesystem.FsStateBackend
-
Gets the base directory where all the checkpoints are stored.
- getCheckpointRecoveryFactory() - Method in interface org.apache.flink.runtime.highavailability.HighAvailabilityServices
-
Gets the checkpoint recovery factory for the job manager
- getCheckpointRecoveryFactory() - Method in class org.apache.flink.runtime.highavailability.nonha.AbstractNonHaServices
-
- getCheckpointRecoveryFactory() - Method in class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperHaServices
-
- getCheckpointRecoveryFactory() - Method in class org.apache.flink.yarn.highavailability.AbstractYarnNonHaServices
-
- getCheckpointResponder() - Method in class org.apache.flink.runtime.taskexecutor.JobManagerConnection
-
- getCheckpointRetentionPolicy() - Method in class org.apache.flink.runtime.jobgraph.tasks.CheckpointCoordinatorConfiguration
-
- getCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.CheckpointStatsHistory
-
- getCheckpointsDirectory() - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStorage
-
- getCheckpointStatisticsPerTask() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
-
- getCheckpointStatsSnapshot() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionGraph
-
Returns a snapshot of the checkpoint statistics or null
if
checkpointing is disabled.
- getCheckpointStatsSnapshot() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
-
- getCheckpointStatsSnapshot() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- getCheckpointStatus() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics
-
- getCheckpointStatus() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatistics
-
- getCheckpointStorage() - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
- getCheckpointStorage() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- getCheckpointStore() - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
- getCheckpointTimeout() - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
- getCheckpointTimeout() - Method in class org.apache.flink.runtime.jobgraph.tasks.CheckpointCoordinatorConfiguration
-
- getCheckpointTimeout() - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Gets the maximum time that a checkpoint may take before being discarded.
- getCheckpointTimestamp() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
-
- getCheckpointTimestamp() - Method in interface org.apache.flink.runtime.state.ManagedSnapshotContext
-
Returns timestamp (wall clock time) when the master node triggered the checkpoint for which
the state snapshot is taken.
- getCheckpointTimestamp() - Method in class org.apache.flink.runtime.state.StateSnapshotContextSynchronousImpl
-
- getCheckpointType() - Method in class org.apache.flink.runtime.checkpoint.CheckpointOptions
-
Returns the type of checkpoint to perform.
- getCheckpointType() - Method in class org.apache.flink.runtime.checkpoint.CheckpointProperties
-
Gets the type of the checkpoint (checkpoint / savepoint).
- getChecksum() - Method in class org.apache.flink.api.java.Utils.ChecksumHashCode
-
- getChecksum() - Method in class org.apache.flink.graph.asm.dataset.ChecksumHashCode.Checksum
-
Get the checksum over the hash() of elements.
- getChoices() - Method in class org.apache.flink.api.java.utils.Option
-
- getClass(String, Class<? extends T>, ClassLoader) - Method in class org.apache.flink.configuration.Configuration
-
Returns the class associated with the given key as a string.
- getClass(String, Class<? extends T>, ClassLoader) - Method in class org.apache.flink.configuration.DelegatingConfiguration
-
- getClass(String, Class<?>) - Method in class org.apache.hadoop.conf.Configuration
-
Get the value of the name
property as a Class
.
- getClass(String, Class<? extends U>, Class<U>) - Method in class org.apache.hadoop.conf.Configuration
-
Get the value of the name
property as a Class
implementing the interface specified by xface
.
- getClassByName(String) - Method in class org.apache.hadoop.conf.Configuration
-
Load a class by name.
- getClassByNameOrNull(String) - Method in class org.apache.hadoop.conf.Configuration
-
Load a class by name, returning null rather than throwing an exception
if it couldn't be loaded.
- getClasses(String, Class<?>...) - Method in class org.apache.hadoop.conf.Configuration
-
Get the value of the name
property
as an array of Class
.
- getClassLoader() - Method in class org.apache.flink.runtime.client.JobListeningContext
-
The class loader necessary to deserialize the result of a job execution,
i.e.
- getClassLoader(JobID) - Method in class org.apache.flink.runtime.execution.librarycache.BlobLibraryCacheManager
-
- getClassLoader(JobID) - Method in interface org.apache.flink.runtime.execution.librarycache.LibraryCacheManager
-
Returns the user code class loader associated with id.
- getClassLoader() - Method in class org.apache.flink.table.client.gateway.local.ExecutionContext
-
- getClassLoader() - Method in class org.apache.hadoop.conf.Configuration
-
- getClassLoaderResolveOrder() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
-
- getClasspaths() - Method in class org.apache.flink.client.cli.ProgramOptions
-
- getClasspaths() - Method in class org.apache.flink.client.program.ContextEnvironment
-
- getClasspaths() - Method in class org.apache.flink.client.program.JobWithJars
-
Returns list of classpaths that need to be submitted with the plan.
- getClasspaths() - Method in class org.apache.flink.client.program.PackagedProgram
-
Returns the classpaths that are required by the program.
- getClasspaths() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
- getClazz() - Method in class org.apache.flink.util.ReflectionUtil.FullTypeInfo
-
- getClazzIterator() - Method in class org.apache.flink.util.ReflectionUtil.FullTypeInfo
-
- getCleanUpInterval() - Method in class org.apache.flink.runtime.rest.handler.legacy.backpressure.BackPressureStatsTrackerImpl
-
Cleanup interval for completed stats cache.
- getClient() - Method in class org.apache.flink.client.program.ContextEnvironment
-
- getClient() - Method in class org.apache.flink.storm.api.FlinkClient
-
Return a reference to itself.
- getClientChannelHandlers() - Method in class org.apache.flink.runtime.io.network.netty.NettyProtocol
-
Returns the client channel handlers.
- getClientConfiguration() - Method in class org.apache.flink.streaming.api.environment.RemoteStreamEnvironment
-
- getClientConfiguration() - Method in class org.apache.flink.test.util.MiniClusterResource
-
- getClientConnectTimeoutSeconds() - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
-
- getClientMessageClass() - Method in class org.apache.flink.runtime.client.JobAttachmentClientActor
-
- getClientMessageClass() - Method in class org.apache.flink.runtime.client.JobClientActor
-
Hook to let the client know about messages that should start a timer for a timeout
- getClientMessageClass() - Method in class org.apache.flink.runtime.client.JobSubmissionClientActor
-
- getClientName() - Method in class org.apache.flink.queryablestate.network.Client
-
- getClientNumThreads() - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
-
- getClientSecurityConfigurationMap() - Static method in class org.apache.flink.test.util.SecureTestEnvironment
-
- getClosedBranchingNodes() - Method in class org.apache.flink.optimizer.dag.OptimizerNode
-
- getCloseNotifyFlushTimeoutMs() - Method in class org.apache.flink.runtime.net.SSLUtils.SSLContext
-
- getCluster() - Method in class org.apache.flink.streaming.connectors.cassandra.ClusterBuilder
-
- getClusterClient() - Method in class org.apache.flink.test.util.MiniClusterResource
-
- getClusterConnectionInfo() - Method in class org.apache.flink.client.program.ClusterClient
-
Gets the current cluster connection info (may change in case of a HA setup).
- getClusterConnectionInfo() - Method in class org.apache.flink.client.program.MiniClusterClient
-
- getClusterConnectionInfo() - Method in class org.apache.flink.client.program.rest.RestClusterClient
-
- getClusterDescription() - Method in interface org.apache.flink.client.deployment.ClusterDescriptor
-
Returns a String containing details about the cluster (NodeManagers, available memory, ...).
- getClusterDescription() - Method in class org.apache.flink.client.deployment.LegacyStandaloneClusterDescriptor
-
- getClusterDescription() - Method in class org.apache.flink.client.deployment.StandaloneClusterDescriptor
-
- getClusterDescription() - Method in class org.apache.flink.yarn.AbstractYarnClusterDescriptor
-
- getClusterId(CommandLine) - Method in interface org.apache.flink.client.cli.CustomCommandLine
-
Returns the cluster id if a cluster id was specified on the command line, otherwise it
returns null.
- getClusterId(CommandLine) - Method in class org.apache.flink.client.cli.DefaultCLI
-
- getClusterId(CommandLine) - Method in class org.apache.flink.client.cli.LegacyCLI
-
- getClusterId() - Method in class org.apache.flink.client.program.ClusterClient
-
Returns the cluster id identifying the cluster to which the client is connected.
- getClusterId() - Method in class org.apache.flink.client.program.MiniClusterClient
-
- getClusterId() - Method in class org.apache.flink.client.program.rest.RestClusterClient
-
- getClusterId() - Method in class org.apache.flink.client.program.StandaloneClusterClient
-
- getClusterId() - Method in class org.apache.flink.table.client.gateway.local.ExecutionContext
-
- getClusterId(CommandLine) - Method in class org.apache.flink.yarn.cli.FlinkYarnSessionCli
-
- getClusterId() - Method in class org.apache.flink.yarn.YarnClusterClient
-
- getClusterInfo() - Method in class org.apache.flink.storm.api.FlinkLocalCluster
-
- getClusterInformation() - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorRegistrationSuccess
-
Gets the cluster information.
- getClusterSpec() - Method in class org.apache.flink.table.client.gateway.local.ExecutionContext
-
- getClusterSpecification(CommandLine) - Method in interface org.apache.flink.client.cli.CustomCommandLine
-
- getClusterSpecification(CommandLine) - Method in class org.apache.flink.client.cli.DefaultCLI
-
- getClusterSpecification(CommandLine) - Method in class org.apache.flink.client.cli.LegacyCLI
-
- getClusterSpecification(CommandLine) - Method in class org.apache.flink.yarn.cli.FlinkYarnSessionCli
-
- getClusterStatus() - Method in class org.apache.flink.client.program.ClusterClient
-
Returns the latest cluster status, with number of Taskmanagers and slots.
- getClusterStatus() - Method in class org.apache.flink.client.program.MiniClusterClient
-
- getClusterStatus() - Method in class org.apache.flink.client.program.rest.RestClusterClient
-
- getClusterStatus() - Method in class org.apache.flink.client.program.StandaloneClusterClient
-
- GetClusterStatus - Class in org.apache.flink.runtime.clusterframework.messages
-
Message sent to the resource manager to request a GetClusterStatusResponse
which contains
the current number of task managers and the total number of task slots.
- getClusterStatus() - Method in class org.apache.flink.yarn.YarnClusterClient
-
This method is only available if the cluster hasn't been started in detached mode.
- GetClusterStatusResponse - Class in org.apache.flink.runtime.clusterframework.messages
-
The reply to a GetClusterStatus
message sent by the job manager.
- GetClusterStatusResponse(int, int) - Constructor for class org.apache.flink.runtime.clusterframework.messages.GetClusterStatusResponse
-
- getCodeAnalysisMode() - Method in class org.apache.flink.api.common.ExecutionConfig
-
- getCoGroupReturnTypes(CoGroupFunction<IN1, IN2, OUT>, TypeInformation<IN1>, TypeInformation<IN2>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
- getCoGroupReturnTypes(CoGroupFunction<IN1, IN2, OUT>, TypeInformation<IN1>, TypeInformation<IN2>, String, boolean) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
- getCollector() - Method in class org.apache.flink.streaming.api.operators.co.CoStreamFlatMap
-
- getCollector() - Method in class org.apache.flink.streaming.api.operators.co.KeyedCoProcessOperator
-
- getCollectorValues() - Method in class org.apache.flink.api.java.sca.UdfAnalyzer
-
- getCoLocationConstraint() - Method in class org.apache.flink.runtime.jobmanager.scheduler.ScheduledUnit
-
- getCoLocationGroup() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
- getCoLocationGroup() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
- getColumnOptions() - Method in class org.apache.flink.contrib.streaming.state.RocksDBStateBackend
-
Gets the RocksDB ColumnFamilyOptions
to be used for all RocksDB instances.
- getCombineHint() - Method in class org.apache.flink.api.common.operators.base.ReduceOperatorBase
-
- getCombinerUtilityNode() - Method in class org.apache.flink.optimizer.dag.GroupReduceNode
-
- getCombinerUtilityNode() - Method in class org.apache.flink.optimizer.dag.ReduceNode
-
- getCommandLine(Options) - Method in class org.apache.flink.table.client.config.Deployment
-
Parses the given command line options from the deployment properties.
- getCommentPrefix() - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
-
- getCommitId() - Method in class org.apache.flink.runtime.rest.handler.legacy.messages.ClusterOverviewWithVersion
-
- getCommittedOffset() - Method in class org.apache.flink.streaming.connectors.kafka.internals.KafkaTopicPartitionState
-
- getCommittedOffset(KafkaTopicPartition) - Method in class org.apache.flink.streaming.connectors.kafka.internals.ZookeeperOffsetHandler
-
- getCommonFileExtensions() - Method in class org.apache.flink.api.common.io.compression.Bzip2InputStreamFactory
-
- getCommonFileExtensions() - Method in class org.apache.flink.api.common.io.compression.DeflateInflaterInputStreamFactory
-
- getCommonFileExtensions() - Method in class org.apache.flink.api.common.io.compression.GzipInflaterInputStreamFactory
-
- getCommonFileExtensions() - Method in interface org.apache.flink.api.common.io.compression.InflaterInputStreamFactory
-
Lists a collection of typical file extensions (e.g., "gz", "gzip") that are associated with the compression
algorithm in the
InflaterInputStream
T
.
- getCommonFileExtensions() - Method in class org.apache.flink.api.common.io.compression.XZInputStreamFactory
-
- getComparator() - Method in class org.apache.flink.cep.PatternStream
-
- getComparator(int) - Method in class org.apache.flink.optimizer.plan.SingleInputPlanNode
-
Gets the specified comparator from this PlanNode.
- getComparator1() - Method in class org.apache.flink.optimizer.plan.DualInputPlanNode
-
- getComparator2() - Method in class org.apache.flink.optimizer.plan.DualInputPlanNode
-
- getComparatorWithCurrentReference() - Method in class org.apache.flink.runtime.util.NonReusingKeyGroupedIterator
-
- getComparatorWithCurrentReference() - Method in class org.apache.flink.runtime.util.ReusingKeyGroupedIterator
-
- getCompatibleVersions() - Method in class org.apache.flink.api.common.typeutils.base.EnumSerializer.EnumSerializerConfigSnapshot
-
- getCompatibleVersions() - Method in class org.apache.flink.core.io.VersionedIOReadableWritable
-
Returns the compatible version values.
- getCompatibleVersions() - Method in class org.apache.flink.runtime.state.KeyedBackendSerializationProxy
-
- getCompatibleVersions() - Method in class org.apache.flink.runtime.state.OperatorBackendSerializationProxy
-
- getCompilerHints() - Method in class org.apache.flink.api.common.operators.Operator
-
Gets the compiler hints for this contract instance.
- getCompilerHints() - Method in class org.apache.flink.table.explain.Node
-
- getCompletedCheckpointStatistics() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.LatestCheckpoints
-
- getCompletionFuture() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
-
Returns the completion future.
- getComponentClass() - Method in class org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
-
Gets the class that represents the component type.
- getComponentClass() - Method in class org.apache.flink.api.common.typeutils.base.GenericArraySerializerConfigSnapshot
-
- getComponentConfiguration() - Method in class org.apache.flink.storm.exclamation.operators.ExclamationBolt
-
- getComponentConfiguration() - Method in class org.apache.flink.storm.util.AbstractBoltSink
-
- getComponentConfiguration() - Method in class org.apache.flink.storm.util.AbstractLineSpout
-
- getComponentConfiguration() - Method in class org.apache.flink.storm.util.NullTerminatingSpout
-
- getComponentConfiguration() - Method in class org.apache.flink.storm.wordcount.operators.BoltCounter
-
- getComponentConfiguration() - Method in class org.apache.flink.storm.wordcount.operators.BoltCounterByName
-
- getComponentConfiguration() - Method in class org.apache.flink.storm.wordcount.operators.BoltTokenizer
-
- getComponentConfiguration() - Method in class org.apache.flink.storm.wordcount.operators.BoltTokenizerByName
-
- getComponentInfo() - Method in class org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
-
- getComponentInfo() - Method in class org.apache.flink.api.java.typeutils.ObjectArrayTypeInfo
-
- getComponentMetricStore(HandlerRequest<EmptyRequestBody, M>, MetricStore) - Method in class org.apache.flink.runtime.rest.handler.job.metrics.AbstractMetricsHandler
-
Returns the MetricStore.ComponentMetricStore
that should be queried for metrics.
- getComponentMetricStore(HandlerRequest<EmptyRequestBody, JobManagerMetricsMessageParameters>, MetricStore) - Method in class org.apache.flink.runtime.rest.handler.job.metrics.JobManagerMetricsHandler
-
- getComponentMetricStore(HandlerRequest<EmptyRequestBody, JobMetricsMessageParameters>, MetricStore) - Method in class org.apache.flink.runtime.rest.handler.job.metrics.JobMetricsHandler
-
- getComponentMetricStore(HandlerRequest<EmptyRequestBody, JobVertexMetricsMessageParameters>, MetricStore) - Method in class org.apache.flink.runtime.rest.handler.job.metrics.JobVertexMetricsHandler
-
Deprecated.
- getComponentMetricStore(HandlerRequest<EmptyRequestBody, SubtaskMetricsMessageParameters>, MetricStore) - Method in class org.apache.flink.runtime.rest.handler.job.metrics.SubtaskMetricsHandler
-
- getComponentMetricStore(HandlerRequest<EmptyRequestBody, TaskManagerMetricsMessageParameters>, MetricStore) - Method in class org.apache.flink.runtime.rest.handler.job.metrics.TaskManagerMetricsHandler
-
- getComponentType() - Method in class org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
-
Gets the type information of the component type.
- getComponentTypeClass() - Method in class org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
-
- getCondition() - Method in class org.apache.flink.cep.nfa.StateTransition
-
- getCondition() - Method in class org.apache.flink.cep.pattern.Pattern
-
- getConditionContext() - Method in class org.apache.flink.cep.nfa.ComputationState
-
- getConfig() - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
Gets the config object that defines execution parameters.
- getConfig() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Gets the config object.
- getConfigDir() - Method in class org.apache.flink.runtime.entrypoint.ClusterConfiguration
-
- getConfigDir() - Method in class org.apache.flink.runtime.jobmanager.JobManagerCliOptions
-
- getConfigDir() - Method in class org.apache.flink.runtime.taskmanager.TaskManagerCliOptions
-
- getConfiguration() - Method in class org.apache.flink.api.java.hadoop.mapreduce.HadoopInputFormatBase
-
- getConfiguration() - Method in class org.apache.flink.api.java.hadoop.mapreduce.HadoopOutputFormatBase
-
- getConfiguration() - Method in class org.apache.flink.api.java.utils.ParameterTool
-
- getConfiguration() - Method in class org.apache.flink.client.cli.AbstractCustomCommandLine
-
- getConfiguration() - Method in class org.apache.flink.client.cli.CliFrontend
-
Getter which returns a copy of the associated configuration.
- getConfiguration() - Method in class org.apache.flink.hcatalog.HCatInputFormatBase
-
- getConfiguration() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
Returns the vertex's configuration object which can be used to pass custom settings to the task at runtime.
- getConfiguration() - Method in class org.apache.flink.runtime.jobmaster.JobMasterConfiguration
-
- getConfiguration() - Method in class org.apache.flink.runtime.minicluster.MiniClusterConfiguration
-
- getConfiguration() - Method in class org.apache.flink.runtime.minicluster.StandaloneMiniCluster
-
- getConfiguration() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
Gets the configuration that holds the actual values encoded.
- getConfiguration() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
-
- getConfiguration() - Method in interface org.apache.flink.runtime.taskmanager.TaskManagerRuntimeInfo
-
Gets the configuration that the TaskManager was started with.
- getConfiguration() - Method in class org.apache.flink.streaming.api.environment.LocalStreamEnvironment
-
- getConfiguration() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getConfiguration() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- getConfiguration() - Method in class org.apache.flink.test.util.MiniClusterResource.MiniClusterResourceConfiguration
-
- getConfigurationDirectoryFromEnv() - Static method in class org.apache.flink.client.cli.CliFrontend
-
- getConfiguredClient(Map) - Static method in class org.apache.flink.storm.api.FlinkClient
-
Returns a
FlinkClient
that uses the configured
Config.NIMBUS_HOST
and
Config.NIMBUS_THRIFT_PORT
as JobManager address.
- getConfiguredMemory() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
-
Returns the size of the managed memory (in megabytes), if configured.
- getConfResourceAsInputStream(String) - Method in class org.apache.hadoop.conf.Configuration
-
Get an input stream attached to the configuration resource with the
given name
.
- getConfResourceAsReader(String) - Method in class org.apache.hadoop.conf.Configuration
-
Get a
Reader
attached to the configuration resource with the
given
name
.
- getConnectionFactory() - Method in class org.apache.flink.streaming.connectors.rabbitmq.common.RMQConnectionConfig
-
- getConnectionId() - Method in class org.apache.flink.runtime.clusterframework.messages.ReconnectResourceManager
-
- getConnectionId() - Method in class org.apache.flink.runtime.deployment.ResultPartitionLocation
-
- getConnectionIndex() - Method in class org.apache.flink.runtime.executiongraph.IntermediateResult
-
- getConnectionIndex() - Method in class org.apache.flink.runtime.io.network.ConnectionID
-
- getConnectionManager() - Method in class org.apache.flink.runtime.io.network.NetworkEnvironment
-
- getConnectionTimeout() - Method in class org.apache.flink.runtime.rest.RestClientConfiguration
-
- getConnectionTimeout() - Method in class org.apache.flink.streaming.connectors.rabbitmq.common.RMQConnectionConfig
-
Retrieve the connection timeout.
- getConsumedPartitionId() - Method in class org.apache.flink.runtime.deployment.InputChannelDeploymentDescriptor
-
- getConsumedPartitionLocation() - Method in class org.apache.flink.runtime.deployment.InputChannelDeploymentDescriptor
-
- getConsumedPartitionType() - Method in class org.apache.flink.runtime.deployment.InputGateDeploymentDescriptor
-
Returns the type of this input channel's consumed result partition.
- getConsumedPartitionType() - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
-
Returns the type of this input channel's consumed result partition.
- getConsumedResultId() - Method in class org.apache.flink.runtime.deployment.InputGateDeploymentDescriptor
-
- getConsumedResultId() - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
-
- getConsumedSubpartitionIndex() - Method in class org.apache.flink.runtime.deployment.InputGateDeploymentDescriptor
-
- getConsumers() - Method in class org.apache.flink.runtime.executiongraph.IntermediateResultPartition
-
- getConsumers() - Method in class org.apache.flink.runtime.jobgraph.IntermediateDataSet
-
- getConsumingStrategy() - Method in class org.apache.flink.cep.pattern.Quantifier
-
- getContainedTypeSerializer() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
-
- getContainer() - Method in class org.apache.flink.yarn.YarnWorkerNode
-
- getContainerMapping() - Method in class org.apache.flink.api.java.sca.TaggedValue
-
- getContainingBulkIteration() - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase.PartialSolutionPlaceHolder
-
- getContainingIterationNode() - Method in class org.apache.flink.optimizer.plan.BulkPartialSolutionPlanNode
-
- getContainingIterationNode() - Method in class org.apache.flink.optimizer.plan.SolutionSetPlanNode
-
- getContainingIterationNode() - Method in class org.apache.flink.optimizer.plan.WorksetPlanNode
-
- getContainingTask() - Method in class org.apache.flink.runtime.operators.BatchTask
-
- getContainingTask() - Method in interface org.apache.flink.runtime.operators.TaskContext
-
- getContainingTask() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- getContainingWorksetIteration() - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase.SolutionSetPlaceHolder
-
- getContainingWorksetIteration() - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase.WorksetPlaceHolder
-
- getContent() - Method in class org.apache.flink.queryablestate.messages.KvStateResponse
-
- getContent() - Method in interface org.apache.flink.streaming.connectors.nifi.NiFiDataPacket
-
- getContent() - Method in class org.apache.flink.streaming.connectors.nifi.StandardNiFiDataPacket
-
- getContents() - Method in class org.apache.flink.table.explain.Node
-
- getContentType() - Method in class org.apache.flink.runtime.rest.FileUpload
-
- getContext() - Method in class org.apache.flink.graph.Graph
-
- getContext() - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.State
-
- getContext() - Method in class org.apache.flink.table.client.cli.CliClient
-
- getConvergenceCriterion() - Method in class org.apache.flink.api.common.aggregators.AggregatorRegistry
-
- getConvergenceCriterion(ClassLoader) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getConvergenceCriterionAggregatorName() - Method in class org.apache.flink.api.common.aggregators.AggregatorRegistry
-
- getConvergenceCriterionAggregatorName() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getConvertDeserializer() - Method in class org.apache.flink.api.common.typeutils.CompatibilityResult
-
- getCopyOfBuffer() - Method in class 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) - Static method in class org.apache.flink.util.NetUtils
-
Method to validate if the given String represents a hostname:port.
- getCosts() - Method in class org.apache.flink.table.explain.Node
-
- getCostWeight() - Method in class org.apache.flink.optimizer.dag.BulkIterationNode
-
- getCostWeight() - Method in class org.apache.flink.optimizer.dag.DagConnection
-
- getCostWeight() - Method in class org.apache.flink.optimizer.dag.OptimizerNode
-
- getCostWeight() - Method in class org.apache.flink.optimizer.dag.WorksetIterationNode
-
- getCostWeight() - Method in class org.apache.flink.optimizer.plan.Channel
-
- getCostWeight() - Method in class org.apache.flink.optimizer.plan.PlanNode
-
- getCount() - Method in class org.apache.flink.api.java.Utils.ChecksumHashCode
-
- getCount() - Method in class org.apache.flink.dropwizard.metrics.DropwizardHistogramWrapper
-
- getCount() - Method in class org.apache.flink.dropwizard.metrics.DropwizardMeterWrapper
-
- getCount() - Method in class org.apache.flink.dropwizard.metrics.FlinkCounterWrapper
-
- getCount() - Method in class org.apache.flink.dropwizard.metrics.FlinkHistogramWrapper
-
- getCount() - Method in class org.apache.flink.dropwizard.metrics.FlinkMeterWrapper
-
- getCount() - Method in class org.apache.flink.graph.asm.dataset.ChecksumHashCode.Checksum
-
Get the number of elements.
- getCount() - Method in interface org.apache.flink.metrics.Counter
-
Returns the current count.
- getCount() - Method in interface org.apache.flink.metrics.Histogram
-
Get the count of seen elements.
- getCount() - Method in interface org.apache.flink.metrics.jmx.JMXReporter.JmxCounterMBean
-
- getCount() - Method in interface org.apache.flink.metrics.jmx.JMXReporter.JmxHistogramMBean
-
- getCount() - Method in interface org.apache.flink.metrics.jmx.JMXReporter.JmxMeterMBean
-
- getCount() - Method in interface org.apache.flink.metrics.Meter
-
Get number of events marked on the meter.
- getCount() - Method in class org.apache.flink.metrics.MeterView
-
- getCount() - Method in class org.apache.flink.metrics.SimpleCounter
-
Returns the current count.
- getCount() - Method in class org.apache.flink.runtime.checkpoint.MinMaxAvgStats
-
Returns the count of all seen values.
- getCount() - Method in class org.apache.flink.runtime.metrics.DescriptiveStatisticsHistogram
-
- getCount003() - Method in class org.apache.flink.graph.library.clustering.directed.TriadicCensus.Result
-
Get the count of "003" triads which have zero connecting vertices.
- getCount012() - Method in class org.apache.flink.graph.library.clustering.directed.TriadicCensus.Result
-
Get the count of "012" triads which have one unidirectional edge among the vertices.
- getCount021c() - Method in class org.apache.flink.graph.library.clustering.directed.TriadicCensus.Result
-
Get the count of "021c" triads which have two unidirectional edges among the vertices,
forming an open triplet; one edge sources and one edge targets the center vertex.
- getCount021d() - Method in class org.apache.flink.graph.library.clustering.directed.TriadicCensus.Result
-
Get the count of "021d" triads which have two unidirectional edges among the vertices,
forming an open triplet; both edges source the center vertex.
- getCount021u() - Method in class org.apache.flink.graph.library.clustering.directed.TriadicCensus.Result
-
Get the count of "021u" triads which have two unidirectional edges among the vertices,
forming an open triplet; both edges target the center vertex.
- getCount03() - Method in class org.apache.flink.graph.library.clustering.undirected.TriadicCensus.Result
-
Get the count of "03" triads which have zero connecting vertices.
- getCount030c() - Method in class org.apache.flink.graph.library.clustering.directed.TriadicCensus.Result
-
Get the count of "030c" triads which have three unidirectional edges among the vertices,
forming a closed triplet, a triangle; the three unidirectional edges both source and target
different vertices.
- getCount030t() - Method in class org.apache.flink.graph.library.clustering.directed.TriadicCensus.Result
-
Get the count of "030t" triads which have three unidirectional edges among the vertices,
forming a closed triplet, a triangle; two of the unidirectional edges source/target the
same vertex.
- getCount102() - Method in class org.apache.flink.graph.library.clustering.directed.TriadicCensus.Result
-
Get the count of "102" triads which have one bidirectional edge among the vertices.
- getCount111d() - Method in class org.apache.flink.graph.library.clustering.directed.TriadicCensus.Result
-
Get the count of "111d" triads which have one unidirectional and one bidirectional edge
among the vertices, forming an open triplet; the unidirectional edge targets the center vertex.
- getCount111u() - Method in class org.apache.flink.graph.library.clustering.directed.TriadicCensus.Result
-
Get the count of "111u" triads which have one unidirectional and one bidirectional edge
among the vertices, forming an open triplet; the unidirectional edge sources the center vertex.
- getCount12() - Method in class org.apache.flink.graph.library.clustering.undirected.TriadicCensus.Result
-
Get the count of "12" triads which have one edge among the vertices.
- getCount120c() - Method in class org.apache.flink.graph.library.clustering.directed.TriadicCensus.Result
-
Get the count of "120c" triads which have two unidirectional edges and one bidirectional edge
among the vertices, forming a closed triplet, a triangle; one vertex is sourced by and targeted
by the unidirectional edges.
- getCount120d() - Method in class org.apache.flink.graph.library.clustering.directed.TriadicCensus.Result
-
Get the count of "120d" triads which have two unidirectional edges and one bidirectional edge
among the vertices, forming a closed triplet, a triangle; both unidirectional edges source
the same vertex.
- getCount120u() - Method in class org.apache.flink.graph.library.clustering.directed.TriadicCensus.Result
-
Get the count of "120u" triads which have two unidirectional and one bidirectional edges
among the vertices, forming a closed triplet, a triangle; both unidirectional edges target
the same vertex.
- getCount201() - Method in class org.apache.flink.graph.library.clustering.directed.TriadicCensus.Result
-
Get the count of "201" triads which have two unidirectional edges among the vertices,
forming an open triplet.
- getCount21() - Method in class org.apache.flink.graph.library.clustering.undirected.TriadicCensus.Result
-
Get the count of "21" triads which have two edges among the vertices
and form a open triplet.
- getCount210() - Method in class org.apache.flink.graph.library.clustering.directed.TriadicCensus.Result
-
Get the count of "210" triads which have one unidirectional edge and two bidirectional edges
among the vertices, forming a closed triplet, a triangle.
- getCount30() - Method in class org.apache.flink.graph.library.clustering.undirected.TriadicCensus.Result
-
Get the count of "30" triads which have three edges among the vertices
and form a closed triplet, a triangle.
- getCount300() - Method in class org.apache.flink.graph.library.clustering.directed.TriadicCensus.Result
-
Get the count of "300" triads which have three bidirectional edges among the vertices,
forming a closed triplet, a triangle.
- getCounter(Enum<?>) - Method in class org.apache.flink.api.java.hadoop.mapred.wrapper.HadoopDummyReporter
-
- getCounter(String, String) - Method in class org.apache.flink.api.java.hadoop.mapred.wrapper.HadoopDummyReporter
-
- getCounter() - Method in class org.apache.flink.cep.nfa.ComputationState
-
- getCounts() - Method in class org.apache.flink.graph.library.clustering.directed.TriadicCensus.Result
-
Get the array of counts.
- getCounts() - Method in class org.apache.flink.graph.library.clustering.undirected.TriadicCensus.Result
-
Get the array of counts.
- getCounts() - Method in class org.apache.flink.runtime.checkpoint.CheckpointStatsSnapshot
-
Returns the snapshotted checkpoint counts.
- getCounts() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics
-
- getCpuCores() - Method in class org.apache.flink.api.common.operators.ResourceSpec
-
- getCpuCores() - Method in class org.apache.flink.runtime.clusterframework.types.ResourceProfile
-
Get the cpu cores needed.
- getCpuCost() - Method in class org.apache.flink.optimizer.costs.Costs
-
Gets the cost for the CPU.
- getCreateDump() - Static method in class org.apache.flink.runtime.metrics.dump.MetricQueryService
-
- getCreationTimestamp() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.PendingSlotRequest
-
- getCredentialsFromUGI(UserGroupInformation) - Static method in class org.apache.flink.api.java.hadoop.common.HadoopInputFormatCommonBase
-
This method only exists because there is no UserGroupInformation.getCredentials() method
in Hadoop 1.x
- getCrossHint() - Method in class org.apache.flink.api.common.operators.base.CrossOperatorBase
-
- getCrossHint() - Method in class org.apache.flink.api.java.operators.CrossOperator
-
- getCrossReturnTypes(CrossFunction<IN1, IN2, OUT>, TypeInformation<IN1>, TypeInformation<IN2>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
- getCrossReturnTypes(CrossFunction<IN1, IN2, OUT>, TypeInformation<IN1>, TypeInformation<IN2>, String, boolean) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
- getCumulativeCosts() - Method in class org.apache.flink.optimizer.plan.PlanNode
-
Gets the cumulative costs of this nose.
- getCumulativeCostsShare() - Method in class org.apache.flink.optimizer.plan.PlanNode
-
- getCurrent() - Method in class org.apache.flink.api.common.operators.util.ListKeyGroupedIterator.ValuesIterator
-
- getCurrent() - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable.ProbeIterator
-
- getCurrent() - Method in interface org.apache.flink.runtime.util.KeyGroupedIterator
-
- getCurrent() - Method in class org.apache.flink.runtime.util.NonReusingKeyGroupedIterator
-
- getCurrent() - Method in class org.apache.flink.runtime.util.ReusingKeyGroupedIterator
-
- getCurrent() - Method in class org.apache.flink.util.LongValueSequenceIterator
-
- getCurrent() - Method in class org.apache.flink.util.NumberSequenceIterator
-
- getCurrentAllocation(int) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
-
Get the current allocation for the task slot with the given index.
- getCurrentAssignedResource() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- getCurrentAssignedResourceLocation() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionVertex
-
- getCurrentAssignedResourceLocation() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionVertex
-
- getCurrentAssignedResourceLocation() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- getCurrentBackoff() - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputChannel
-
Returns the current backoff in ms.
- getCurrentBuffer() - Method in interface org.apache.flink.runtime.io.network.api.serialization.RecordDeserializer
-
- getCurrentBuffer() - Method in class org.apache.flink.runtime.io.network.api.serialization.SpillingAdaptiveSpanningRecordDeserializer
-
- getCurrentCheckpointId() - Method in class org.apache.flink.streaming.runtime.io.BarrierBuffer
-
Gets the ID defining the current pending, or just completed, checkpoint.
- getCurrentConfiguration() - Method in class org.apache.flink.runtime.security.modules.JaasModule
-
- getCurrentExecutionAttempt() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionVertex
-
Returns the current execution for this execution vertex.
- getCurrentExecutionAttempt() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionVertex
-
- getCurrentExecutionAttempt() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- getCurrentKey() - Method in class org.apache.flink.hadoopcompatibility.mapred.wrapper.HadoopTupleUnwrappingIterator
-
- getCurrentKey() - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
-
- getCurrentKey() - Method in interface org.apache.flink.runtime.state.heap.InternalKeyContext
-
Used by states to access the current key.
- getCurrentKey() - Method in class org.apache.flink.streaming.api.functions.co.KeyedBroadcastProcessFunction.OnTimerContext
-
Get the key of the firing timer.
- getCurrentKey() - Method in class org.apache.flink.streaming.api.functions.KeyedProcessFunction.OnTimerContext
-
Get key of the firing timer.
- getCurrentKey() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- getCurrentKey() - Method in interface org.apache.flink.streaming.api.operators.KeyContext
-
- getCurrentKeyGroup() - Method in class org.apache.flink.runtime.state.KeyedStateCheckpointOutputStream
-
Returns the key group that is currently being written.
- getCurrentKeyGroupIndex() - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
-
- getCurrentKeyGroupIndex() - Method in interface org.apache.flink.runtime.state.heap.InternalKeyContext
-
Returns the key-group to which the current key belongs.
- getCurrentNumberOfSubtasks() - Method in class org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
-
Returns the current number of subtasks the respective task is split into.
- getCurrentOffset() - Method in class org.apache.flink.runtime.io.disk.SimpleCollectingOutputView
-
- getCurrentOperatingSystem() - Static method in enum org.apache.flink.util.OperatingSystem
-
Gets the operating system that the JVM runs on from the java system properties.
- getCurrentPartialSolutionPlanNode() - Method in class org.apache.flink.optimizer.dag.BulkPartialSolutionNode
-
- getCurrentPartitionWatermark() - Method in class org.apache.flink.streaming.connectors.kafka.internals.KafkaTopicPartitionStateWithPunctuatedWatermarks
-
- getCurrentPositionInSegment() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
-
Gets the position from which the next byte will be read.
- getCurrentPositionInSegment() - Method in class org.apache.flink.runtime.memory.AbstractPagedOutputView
-
Gets the current write position (the position where the next bytes will be written)
in the current memory segment.
- getCurrentProbeRecord() - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
-
- getCurrentProcessingTime() - Method in class org.apache.flink.streaming.api.windowing.assigners.WindowAssigner.WindowAssignerContext
-
Returns the current processing time.
- getCurrentProcessingTime() - Method in interface org.apache.flink.streaming.api.windowing.evictors.Evictor.EvictorContext
-
Returns the current processing time.
- getCurrentProcessingTime() - Method in interface org.apache.flink.streaming.api.windowing.triggers.Trigger.TriggerContext
-
Returns the current processing time.
- getCurrentProcessingTime() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
-
- getCurrentProcessingTime() - Method in class org.apache.flink.streaming.runtime.tasks.ProcessingTimeService
-
Returns the current processing time.
- getCurrentProcessingTime() - Method in class org.apache.flink.streaming.runtime.tasks.SystemProcessingTimeService
-
- getCurrentProcessingTime() - Method in class org.apache.flink.streaming.runtime.tasks.TestProcessingTimeService
-
- getCurrentRestartAttempt() - Method in class org.apache.flink.runtime.executiongraph.restart.FixedDelayRestartStrategy
-
- getCurrentSegment() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
-
Gets the memory segment that will be used to read the next bytes from.
- getCurrentSegment() - Method in class org.apache.flink.runtime.memory.AbstractPagedOutputView
-
Gets the segment that the view currently writes to.
- getCurrentSegmentLimit() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
-
Gets the current limit in the memory segment.
- getCurrentSolutionSetPlanNode() - Method in class org.apache.flink.optimizer.dag.SolutionSetNode
-
- getCurrentState() - Method in class org.apache.flink.api.common.io.BinaryInputFormat
-
- getCurrentState() - Method in interface org.apache.flink.api.common.io.CheckpointableInputFormat
-
Returns the split currently being read, along with its current state.
- getCurrentState() - Method in class org.apache.flink.api.common.io.DelimitedInputFormat
-
- getCurrentState() - Method in class org.apache.flink.formats.avro.AvroInputFormat
-
- getCurrentTableCapacity() - Method in class org.apache.flink.streaming.runtime.operators.windowing.KeyMap
-
Gets the current table capacity, i.e., the number of slots in the hash table, without
and overflow chaining.
- getCurrentTaskManagerLocationFuture() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- getCurrentWatermark() - Method in interface org.apache.flink.streaming.api.functions.AssignerWithPeriodicWatermarks
-
Returns the current watermark.
- getCurrentWatermark() - Method in class org.apache.flink.streaming.api.functions.IngestionTimeExtractor
-
- getCurrentWatermark() - Method in interface org.apache.flink.streaming.api.functions.TimestampExtractor
-
Deprecated.
Returns the current watermark.
- getCurrentWatermark() - Method in class org.apache.flink.streaming.api.functions.timestamps.AscendingTimestampExtractor
-
- getCurrentWatermark() - Method in class org.apache.flink.streaming.api.functions.timestamps.BoundedOutOfOrdernessTimestampExtractor
-
- getCurrentWatermark() - Method in interface org.apache.flink.streaming.api.windowing.evictors.Evictor.EvictorContext
-
Returns the current watermark time.
- getCurrentWatermark() - Method in interface org.apache.flink.streaming.api.windowing.triggers.Trigger.TriggerContext
-
Returns the current watermark time.
- getCurrentWatermark() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
-
- getCurrentWatermarkTimestamp() - Method in class org.apache.flink.streaming.connectors.kafka.internals.KafkaTopicPartitionStateWithPeriodicWatermarks
-
- getCurrentWorksetPlanNode() - Method in class org.apache.flink.optimizer.dag.WorksetNode
-
- getCustKey() - Method in class org.apache.flink.examples.java.relational.TPCHQuery3.Customer
-
- getCustKey() - Method in class org.apache.flink.examples.java.relational.TPCHQuery3.Order
-
- getCustomCommandLineOptions() - Method in class org.apache.flink.client.cli.CliFrontend
-
- getCustomMessage() - Method in class org.apache.hadoop.conf.Configuration.DeprecationDelta
-
- getCustomPartitioner() - Method in class org.apache.flink.api.common.operators.base.CoGroupOperatorBase
-
- getCustomPartitioner() - Method in class org.apache.flink.api.common.operators.base.GroupReduceOperatorBase
-
- getCustomPartitioner() - Method in class org.apache.flink.api.common.operators.base.JoinOperatorBase
-
- getCustomPartitioner() - Method in class org.apache.flink.api.common.operators.base.PartitionOperatorBase
-
- getCustomPartitioner() - Method in class org.apache.flink.api.common.operators.base.ReduceOperatorBase
-
- getCustomPartitioner() - Method in class org.apache.flink.api.java.operators.Grouping
-
Gets the custom partitioner to be used for this grouping, or null
, if
none was defined.
- getCustomPartitioner() - Method in class org.apache.flink.api.java.operators.PartitionOperator
-
Gets the custom partitioner from this partitioning.
- getCustomPartitioner() - Method in class org.apache.flink.optimizer.dataproperties.GlobalProperties
-
- getCustomPartitioner() - Method in class org.apache.flink.optimizer.dataproperties.RequestedGlobalProperties
-
Gets the custom partitioner associated with these properties.
- getData() - Method in class org.apache.flink.python.api.types.CustomTypeWrapper
-
- getData() - Method in class org.apache.flink.runtime.state.memory.ByteStreamStateHandle
-
- getData() - Method in class org.apache.flink.streaming.python.api.functions.PyKey
-
- getDataDistribution() - Method in class org.apache.flink.optimizer.dataproperties.GlobalProperties
-
- getDataDistribution() - Method in class org.apache.flink.optimizer.dataproperties.RequestedGlobalProperties
-
Gets the data distribution.
- getDataDistribution() - Method in class org.apache.flink.optimizer.plan.Channel
-
- getDataExchangeMode() - Method in class org.apache.flink.optimizer.dag.DagConnection
-
Gets the data exchange mode to use for this connection.
- getDataExchangeMode() - Method in class org.apache.flink.optimizer.plan.Channel
-
Gets the data exchange mode (batch / pipelined) to use for the data
exchange of this channel.
- getDataPort() - Method in interface org.apache.flink.runtime.io.network.ConnectionManager
-
- getDataPort() - Method in class org.apache.flink.runtime.io.network.LocalConnectionManager
-
- getDataPort() - Method in class org.apache.flink.runtime.io.network.netty.NettyConnectionManager
-
- getDataPort() - Method in class org.apache.flink.runtime.resourcemanager.registration.WorkerRegistration
-
- getDataPort() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerInfo
-
- getDataSet(ExecutionEnvironment) - Method in class org.apache.flink.addons.hbase.HBaseTableSource
-
- getDataSet() - Method in class org.apache.flink.api.java.operators.DataSink
-
- getDataSet(ExecutionEnvironment) - Method in class org.apache.flink.orc.OrcTableSource
-
- getDataSet(int) - Method in class org.apache.flink.python.api.util.SetCache
-
Returns the cached
DataSet
for the given ID.
- getDataSinks() - Method in class org.apache.flink.api.common.Plan
-
Gets all the data sinks of this job.
- getDataSinks() - Method in class org.apache.flink.optimizer.plan.OptimizedPlan
-
Gets the data sinks from this OptimizedPlan.
- getDataSinks(List<SinkPlanNode>) - Method in class org.apache.flink.optimizer.plan.SinkJoinerPlanNode
-
- getDataSourceNode() - Method in class org.apache.flink.optimizer.plan.SourcePlanNode
-
- getDataSources() - Method in class org.apache.flink.optimizer.plan.OptimizedPlan
-
Gets the data sources from this OptimizedPlan.
- getDataStream(StreamExecutionEnvironment) - Method in class org.apache.flink.sql.tests.StreamSQLTestProgram.GeneratorTableSource
-
- getDataStream(StreamExecutionEnvironment) - Method in class org.apache.flink.streaming.connectors.kafka.KafkaTableSource
-
NOTE: This method is for internal use only for defining a TableSource.
- getDataType() - Method in interface org.apache.flink.api.common.typeutils.TypeSerializerFactory
-
- getDataType() - Method in class org.apache.flink.api.java.typeutils.runtime.RuntimeSerializerFactory
-
- getDbOptions() - Method in class org.apache.flink.contrib.streaming.state.RocksDBStateBackend
-
Gets the RocksDB DBOptions
to be used for all RocksDB instances.
- getDbStoragePaths() - Method in class org.apache.flink.contrib.streaming.state.RocksDBStateBackend
-
Gets the configured local DB storage paths, or null, if none were configured.
- getDeclaredField(Class<?>, String) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
- getDefault() - Static method in class org.apache.flink.runtime.state.CheckpointStorageLocationReference
-
- getDefaultAcl() - Method in class org.apache.flink.runtime.util.ZooKeeperUtils.SecureAclProvider
-
- getDefaultBlockSize() - Method in class org.apache.flink.core.fs.FileSystem
-
- getDefaultBlockSize() - Method in class org.apache.flink.core.fs.LimitedConnectionsFileSystem
-
Deprecated.
- getDefaultBlockSize() - Method in class org.apache.flink.core.fs.SafetyNetWrapperFileSystem
-
- getDefaultBlockSize() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileSystem
-
- getDefaultCentroidDataSet(ExecutionEnvironment) - Static method in class org.apache.flink.examples.java.clustering.util.KMeansData
-
- getDefaultDataDataSet(ExecutionEnvironment) - Static method in class org.apache.flink.examples.java.ml.util.LinearRegressionData
-
- getDefaultEdgeDataSet(ExecutionEnvironment) - Static method in class org.apache.flink.examples.java.graph.util.ConnectedComponentsData
-
- getDefaultEdgeDataSet(ExecutionEnvironment) - Static method in class org.apache.flink.examples.java.graph.util.EnumTrianglesData
-
- getDefaultEdgeDataSet(ExecutionEnvironment) - Static method in class org.apache.flink.examples.java.graph.util.PageRankData
-
- getDefaultEdgeDataSet(ExecutionEnvironment) - Static method in class org.apache.flink.graph.examples.data.CommunityDetectionData
-
- getDefaultEdgeDataSet(ExecutionEnvironment) - Static method in class org.apache.flink.graph.examples.data.ConnectedComponentsDefaultData
-
- getDefaultEdgeDataSet(ExecutionEnvironment) - Static method in class org.apache.flink.graph.examples.data.EuclideanGraphData
-
- getDefaultEdgeDataSet(ExecutionEnvironment) - Static method in class org.apache.flink.graph.examples.data.IncrementalSSSPData
-
- getDefaultEdgeDataSet(ExecutionEnvironment) - Static method in class org.apache.flink.graph.examples.data.LabelPropagationData
-
- getDefaultEdgeDataSet(ExecutionEnvironment) - Static method in class org.apache.flink.graph.examples.data.PageRankData
-
- getDefaultEdgeDataSet(ExecutionEnvironment) - Static method in class org.apache.flink.graph.examples.data.SingleSourceShortestPathsData
-
- getDefaultEdgeDataSet(ExecutionEnvironment) - Static method in class org.apache.flink.graph.examples.data.TriangleCountData
-
- getDefaultEdgesInSSSP(ExecutionEnvironment) - Static method in class org.apache.flink.graph.examples.data.IncrementalSSSPData
-
- getDefaultEdgeToBeRemoved() - Static method in class org.apache.flink.graph.examples.data.IncrementalSSSPData
-
- getDefaultElement() - Method in class org.apache.flink.runtime.util.EvictingBoundedList
-
- getDefaultFsUri() - Static method in class 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.
- getDefaultIOMode() - Method in class org.apache.flink.runtime.io.network.NetworkEnvironment
-
- getDefaultKryoSerializerClasses() - Method in class org.apache.flink.api.common.ExecutionConfig
-
Returns the registered default Kryo Serializer classes.
- getDefaultKryoSerializers() - Method in class org.apache.flink.api.common.ExecutionConfig
-
Returns the registered default Kryo Serializers.
- getDefaultLocalParallelism() - Static method in class org.apache.flink.api.java.ExecutionEnvironment
-
- getDefaultLocalParallelism() - Static method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- getDefaultMimeType() - Static method in class org.apache.flink.runtime.rest.handler.util.MimeTypes
-
Gets the default MIME type, which is "application/octet-stream"
.
- getDefaultPagesDataSet(ExecutionEnvironment) - Static method in class org.apache.flink.examples.java.graph.util.PageRankData
-
- getDefaultParallelism() - Method in class org.apache.flink.api.common.Plan
-
Gets the default parallelism for this job.
- getDefaultParallelism() - Method in class org.apache.flink.client.RemoteExecutor
-
Gets the parallelism that will be used when neither the program does not define
any parallelism at all.
- getDefaultParallelism() - Method in class org.apache.flink.optimizer.Optimizer
-
- getDefaultParamsDataSet(ExecutionEnvironment) - Static method in class org.apache.flink.examples.java.ml.util.LinearRegressionData
-
- getDefaultPointDataSet(ExecutionEnvironment) - Static method in class org.apache.flink.examples.java.clustering.util.KMeansData
-
- getDefaults() - Method in class org.apache.flink.table.client.cli.CliOptions
-
- getDefaultSavepointDirectory() - Method in class org.apache.flink.runtime.state.filesystem.AbstractFsCheckpointStorage
-
Gets the default directory for savepoints.
- getDefaultStateBackend() - Method in class org.apache.flink.runtime.jobgraph.tasks.JobCheckpointingSettings
-
- getDefaultTextLineDataSet(ExecutionEnvironment) - Static method in class org.apache.flink.examples.java.wordcount.util.WordCountData
-
- getDefaultTrigger(StreamExecutionEnvironment) - Method in class org.apache.flink.streaming.api.windowing.assigners.BaseAlignedWindowAssigner
-
- getDefaultTrigger(StreamExecutionEnvironment) - Method in class org.apache.flink.streaming.api.windowing.assigners.DynamicEventTimeSessionWindows
-
- getDefaultTrigger(StreamExecutionEnvironment) - Method in class org.apache.flink.streaming.api.windowing.assigners.DynamicProcessingTimeSessionWindows
-
- getDefaultTrigger(StreamExecutionEnvironment) - Method in class org.apache.flink.streaming.api.windowing.assigners.EventTimeSessionWindows
-
- getDefaultTrigger(StreamExecutionEnvironment) - Method in class org.apache.flink.streaming.api.windowing.assigners.GlobalWindows
-
- getDefaultTrigger(StreamExecutionEnvironment) - Method in class org.apache.flink.streaming.api.windowing.assigners.ProcessingTimeSessionWindows
-
- getDefaultTrigger(StreamExecutionEnvironment) - Method in class org.apache.flink.streaming.api.windowing.assigners.SlidingEventTimeWindows
-
- getDefaultTrigger(StreamExecutionEnvironment) - Method in class org.apache.flink.streaming.api.windowing.assigners.SlidingProcessingTimeWindows
-
- getDefaultTrigger(StreamExecutionEnvironment) - Method in class org.apache.flink.streaming.api.windowing.assigners.TumblingEventTimeWindows
-
- getDefaultTrigger(StreamExecutionEnvironment) - Method in class org.apache.flink.streaming.api.windowing.assigners.TumblingProcessingTimeWindows
-
- getDefaultTrigger(StreamExecutionEnvironment) - Method in class org.apache.flink.streaming.api.windowing.assigners.WindowAssigner
-
Returns the default trigger associated with this WindowAssigner
.
- getDefaultValue() - Method in class org.apache.flink.api.common.state.StateDescriptor
-
Returns the default value.
- getDefaultValue() - Method in class org.apache.flink.api.java.utils.Option
-
- getDefaultValue() - Method in class org.apache.flink.contrib.streaming.state.AbstractRocksDBState
-
- getDefaultValue() - Method in class org.apache.flink.runtime.state.heap.AbstractHeapState
-
- getDefaultVertexDataSet(ExecutionEnvironment) - Static method in class org.apache.flink.examples.java.graph.util.ConnectedComponentsData
-
- getDefaultVertexDataSet(ExecutionEnvironment) - Static method in class org.apache.flink.graph.examples.data.EuclideanGraphData
-
- getDefaultVertexDataSet(ExecutionEnvironment) - Static method in class org.apache.flink.graph.examples.data.IncrementalSSSPData
-
- getDefaultVertexSet(ExecutionEnvironment) - Static method in class org.apache.flink.graph.examples.data.LabelPropagationData
-
- getDegree() - Method in class org.apache.flink.graph.asm.degree.annotate.directed.VertexDegrees.Degrees
-
- getDegree() - Method in class org.apache.flink.graph.library.clustering.directed.LocalClusteringCoefficient.Result
-
Get the vertex degree.
- getDegree() - Method in class org.apache.flink.graph.library.clustering.undirected.LocalClusteringCoefficient.Result
-
Get the vertex degree.
- getDegrees() - Method in class org.apache.flink.graph.Graph
-
Return the degree of all vertices in the graph.
- getDelayBetweenAttemptsInterval() - Method in class org.apache.flink.api.common.restartstrategy.RestartStrategies.FailureRateRestartStrategyConfiguration
-
- getDelayBetweenAttemptsInterval() - Method in class org.apache.flink.api.common.restartstrategy.RestartStrategies.FixedDelayRestartStrategyConfiguration
-
- getDelayMillis() - Method in class org.apache.flink.streaming.connectors.elasticsearch.ElasticsearchSinkBase.BulkFlushBackoffPolicy
-
- getDelegateStateHandle() - Method in class org.apache.flink.runtime.state.KeyGroupsStateHandle
-
- getDelegateStateHandle() - Method in interface org.apache.flink.runtime.state.OperatorStateHandle
-
Returns the underlying stream state handle that points to the state data.
- getDelegateStateHandle() - Method in class org.apache.flink.runtime.state.OperatorStreamStateHandle
-
- getDelimiter() - Method in class org.apache.flink.api.common.io.DelimitedInputFormat
-
- getDelimiter() - Method in interface org.apache.flink.runtime.metrics.MetricRegistry
-
Returns the global delimiter.
- getDelimiter(int) - Method in interface org.apache.flink.runtime.metrics.MetricRegistry
-
Returns the configured delimiter for the reporter with the given index.
- getDelimiter() - Method in class org.apache.flink.runtime.metrics.MetricRegistryConfiguration
-
- getDelimiter() - Method in class org.apache.flink.runtime.metrics.MetricRegistryImpl
-
- getDelimiter(int) - Method in class org.apache.flink.runtime.metrics.MetricRegistryImpl
-
- getDelimiter() - Method in class org.apache.flink.runtime.metrics.NoOpMetricRegistry
-
- getDelimiter(int) - Method in class org.apache.flink.runtime.metrics.NoOpMetricRegistry
-
- getDelta(DATA, DATA) - Method in interface org.apache.flink.streaming.api.functions.windowing.delta.DeltaFunction
-
Calculates the delta between two given data points.
- getDelta(DATA, DATA) - Method in class org.apache.flink.streaming.api.functions.windowing.delta.ExtractionAwareDeltaFunction
-
This method takes the two data point and runs the set extractor on it.
- getDensity() - Method in class org.apache.flink.graph.library.metric.directed.VertexMetrics.Result
-
Get the density, the ratio of actual to potential edges between vertices.
- getDensity() - Method in class org.apache.flink.graph.library.metric.undirected.VertexMetrics.Result
-
Get the density, the ratio of actual to potential edges between vertices.
- getDeployment() - Method in class org.apache.flink.table.client.config.Environment
-
- getDescription() - Method in interface org.apache.flink.api.common.ProgramDescription
-
Returns a description of the plan that is generated by the assembler and
also of the arguments if they are available.
- getDescription() - Method in class org.apache.flink.api.common.restartstrategy.RestartStrategies.FailureRateRestartStrategyConfiguration
-
- getDescription() - Method in class org.apache.flink.api.common.restartstrategy.RestartStrategies.FallbackRestartStrategyConfiguration
-
- getDescription() - Method in class org.apache.flink.api.common.restartstrategy.RestartStrategies.FixedDelayRestartStrategyConfiguration
-
- getDescription() - Method in class org.apache.flink.api.common.restartstrategy.RestartStrategies.NoRestartStrategyConfiguration
-
- getDescription() - Method in class org.apache.flink.api.common.restartstrategy.RestartStrategies.RestartStrategyConfiguration
-
Returns a description which is shown in the web interface
- getDescription() - Method in class org.apache.flink.client.program.PackagedProgram
-
Returns the description provided by the Program class.
- getDescription() - Method in class org.apache.flink.graph.examples.EuclideanGraphWeighing
-
- getDescription() - Method in class org.apache.flink.graph.examples.GSASingleSourceShortestPaths
-
- getDescription() - Method in class org.apache.flink.graph.examples.IncrementalSSSP
-
- getDescription() - Method in class org.apache.flink.graph.examples.MusicProfiles
-
- getDescription() - Method in class org.apache.flink.graph.examples.PregelSSSP
-
- getDescription() - Method in class org.apache.flink.graph.examples.SingleSourceShortestPaths
-
- getDescription() - Method in class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingStatusHeaders
-
- getDescription() - Method in class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingTriggerHeaders
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigHeaders
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatisticsHeaders
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatisticDetailsHeaders
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsHeaders
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.cluster.ShutdownHeaders
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.ClusterConfigurationInfoHeaders
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.ClusterOverviewHeaders
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.DashboardConfigurationHeaders
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsHeaders
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.job.JobExecutionResultHeaders
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.job.JobSubmitHeaders
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedJobMetricsHeaders
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedSubtaskMetricsHeaders
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedTaskManagerMetricsHeaders
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.JobManagerMetricsHeaders
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.JobMetricsHeaders
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.JobVertexMetricsHeaders
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.SubtaskMetricsHeaders
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.TaskManagerMetricsHeaders
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalStatusHeaders
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalTriggerHeaders
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointStatusHeaders
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointTriggerHeaders
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskCurrentAttemptDetailsHeaders
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptAccumulatorsHeaders
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsHeaders
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.JobAccumulatorsHeaders
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.JobConfigHeaders
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.JobExceptionsHeaders
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.JobIdsWithStatusesOverviewHeaders
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.JobPlanHeaders
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.JobsOverviewHeaders
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.JobTerminationHeaders
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.JobVertexAccumulatorsHeaders
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.JobVertexBackPressureHeaders
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.JobVertexDetailsHeaders
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.JobVertexTaskManagersHeaders
-
- getDescription() - Method in interface org.apache.flink.runtime.rest.messages.MessageHeaders
-
Returns the description for this header.
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.SubtasksAllAccumulatorsHeaders
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.SubtasksTimesHeaders
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerDetailsHeaders
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagersHeaders
-
- getDescription() - Method in class org.apache.flink.runtime.webmonitor.handlers.JarDeleteHeaders
-
- getDescription() - Method in class org.apache.flink.runtime.webmonitor.handlers.JarListHeaders
-
- getDescription() - Method in class org.apache.flink.runtime.webmonitor.handlers.JarPlanHeaders
-
- getDescription() - Method in class org.apache.flink.runtime.webmonitor.handlers.JarRunHeaders
-
- getDescription() - Method in class org.apache.flink.runtime.webmonitor.handlers.JarUploadHeaders
-
- getDescriptionPrefix() - Method in class org.apache.flink.api.common.operators.util.FieldList
-
- getDescriptionPrefix() - Method in class org.apache.flink.api.common.operators.util.FieldSet
-
- getDescriptionSuffix() - Method in class org.apache.flink.api.common.operators.util.FieldList
-
- getDescriptionSuffix() - Method in class org.apache.flink.api.common.operators.util.FieldSet
-
- getDeserializationSchema() - Method in class org.apache.flink.streaming.connectors.kafka.Kafka010TableSource
-
- getDeserializationSchema() - Method in class org.apache.flink.streaming.connectors.kafka.Kafka011TableSource
-
- getDeserializationSchema() - Method in class org.apache.flink.streaming.connectors.kafka.Kafka08TableSource
-
- getDeserializationSchema() - Method in class org.apache.flink.streaming.connectors.kafka.Kafka09TableSource
-
- getDeserializationSchema() - Method in class org.apache.flink.streaming.connectors.kafka.KafkaAvroTableSource
-
- getDeserializationSchema() - Method in class org.apache.flink.streaming.connectors.kafka.KafkaJsonTableSource
-
- getDeserializationSchema() - Method in class org.apache.flink.streaming.connectors.kafka.KafkaTableSource
-
Returns the deserialization schema.
- getDesignatedWorkerPoolSize() - Method in class org.apache.flink.runtime.clusterframework.FlinkResourceManager
-
Gets the current designated worker pool size, meaning the number of workers
that the resource master strives to maintain.
- getDetachedMode() - Method in class org.apache.flink.client.cli.ProgramOptions
-
- getDiffUrl() - Method in class org.apache.flink.streaming.connectors.wikiedits.WikipediaEditEvent
-
- getDirection() - Method in class org.apache.flink.graph.gsa.GSAConfiguration
-
Gets the direction from which the neighbors are to be selected
By default the neighbors who are target of the edges are selected.
- getDirection() - Method in class org.apache.flink.graph.spargel.ScatterFunction
-
Retrieves the edge direction in which messages are propagated in the scatter-gather iteration.
- getDirection() - Method in class org.apache.flink.graph.spargel.ScatterGatherConfiguration
-
Gets the direction in which messages are sent in the ScatterFunction.
- getDirections(Ordering, int) - Static method in class org.apache.flink.optimizer.util.Utils
-
- getDirectMemory() - Method in class org.apache.flink.api.common.operators.ResourceSpec
-
- getDirectMemoryInMB() - Method in class org.apache.flink.runtime.clusterframework.types.ResourceProfile
-
Get the direct memory needed in MB.
- getDirectMemoryStatsAsString(BufferPoolMXBean) - Static method in class org.apache.flink.runtime.taskmanager.MemoryLogger
-
Returns a String with the direct memory footprint.
- getDirectory() - Method in class org.apache.flink.runtime.state.DirectoryStateHandle
-
- getDirectory() - Method in class org.apache.flink.runtime.state.SnapshotDirectory
-
- getDirectoryFileName(int) - Method in class org.apache.flink.api.common.io.FileOutputFormat
-
- getDirectoryFileName(int) - Method in class org.apache.flink.formats.avro.AvroOutputFormat
-
- getDirectoryStateHandle() - Method in class org.apache.flink.runtime.state.DirectoryKeyedStateHandle
-
- getDiscount() - Method in class org.apache.flink.examples.java.relational.TPCHQuery3.Lineitem
-
- getDiskCost() - Method in class org.apache.flink.optimizer.costs.Costs
-
Gets the costs for disk.
- getDispatcherLeaderElectionService() - Method in interface org.apache.flink.runtime.highavailability.HighAvailabilityServices
-
Gets the leader election service for the cluster's dispatcher.
- getDispatcherLeaderElectionService() - Method in class org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedHaServices
-
- getDispatcherLeaderElectionService() - Method in class org.apache.flink.runtime.highavailability.nonha.standalone.StandaloneHaServices
-
- getDispatcherLeaderElectionService() - Method in class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperHaServices
-
- getDispatcherLeaderElectionService() - Method in class org.apache.flink.yarn.highavailability.YarnIntraNonHaMasterServices
-
- getDispatcherLeaderElectionService() - Method in class org.apache.flink.yarn.highavailability.YarnPreConfiguredMasterNonHaServices
-
- getDispatcherLeaderRetriever() - Method in interface org.apache.flink.runtime.highavailability.HighAvailabilityServices
-
Gets the leader retriever for the dispatcher.
- getDispatcherLeaderRetriever() - Method in class org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedHaServices
-
- getDispatcherLeaderRetriever() - Method in class org.apache.flink.runtime.highavailability.nonha.standalone.StandaloneHaServices
-
- getDispatcherLeaderRetriever() - Method in class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperHaServices
-
- getDispatcherLeaderRetriever() - Method in class org.apache.flink.yarn.highavailability.YarnIntraNonHaMasterServices
-
- getDispatcherLeaderRetriever() - Method in class org.apache.flink.yarn.highavailability.YarnPreConfiguredMasterNonHaServices
-
- getDistinctNeighborCount() - Method in class org.apache.flink.graph.library.similarity.JaccardIndex.Result
-
Get the distinct neighbor count.
- getDistributedCache() - Method in interface org.apache.flink.api.common.functions.RuntimeContext
-
Returns the
DistributedCache
to get the local temporary file copies of files otherwise not
locally accessible.
- getDistributedCache() - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
-
- getDistributedCacheEntries() - Method in interface org.apache.flink.runtime.execution.Environment
-
- getDistributedCacheEntries() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
-
- getDistribution() - Method in class org.apache.flink.api.common.operators.base.PartitionOperatorBase
-
- getDistributionMode() - Method in class org.apache.flink.runtime.state.OperatorStateHandle.StateMetaInfo
-
- getDistributionPattern() - Method in class org.apache.flink.runtime.jobgraph.JobEdge
-
Returns the distribution pattern used for this edge.
- getDocumentDataSet(ExecutionEnvironment) - Static method in class org.apache.flink.examples.java.relational.util.WebLogData
-
- getDouble(String) - Method in class org.apache.flink.api.java.utils.ParameterTool
-
Returns the Double value for the given key.
- getDouble(String, double) - Method in class org.apache.flink.api.java.utils.ParameterTool
-
Returns the Double value for the given key.
- getDouble(String, double) - Method in class org.apache.flink.configuration.Configuration
-
Returns the value associated with the given key as a double.
- getDouble(ConfigOption<Double>) - Method in class org.apache.flink.configuration.Configuration
-
Returns the value associated with the given config option as a double
.
- getDouble(ConfigOption<Double>, double) - Method in class org.apache.flink.configuration.Configuration
-
Returns the value associated with the given config option as a double
.
- getDouble(String, double) - Method in class org.apache.flink.configuration.DelegatingConfiguration
-
- getDouble(ConfigOption<Double>) - Method in class org.apache.flink.configuration.DelegatingConfiguration
-
- getDouble(ConfigOption<Double>, double) - Method in class org.apache.flink.configuration.DelegatingConfiguration
-
- getDouble(int) - Method in class org.apache.flink.core.memory.MemorySegment
-
Reads a double-precision floating point value (64bit, 8 bytes) from the given position, in the system's
native byte order.
- getDouble(String, double) - Method in class org.apache.flink.metrics.MetricConfig
-
Searches for the property with the specified key in this property list.
- getDouble(int) - Method in class org.apache.flink.storm.wrappers.StormTuple
-
- getDouble(String, double) - Method in class org.apache.hadoop.conf.Configuration
-
Get the value of the name
property as a double
.
- getDoubleBigEndian(int) - Method in class org.apache.flink.core.memory.MemorySegment
-
Reads a double-precision floating point value (64bit, 8 bytes) from the given position, in big endian
byte order.
- getDoubleByField(String) - Method in class org.apache.flink.storm.wrappers.StormTuple
-
- getDoubleCounter(String) - Method in interface org.apache.flink.api.common.functions.RuntimeContext
-
Convenience function to create a counter object for doubles.
- getDoubleCounter(String) - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
-
- getDoubleLittleEndian(int) - Method in class org.apache.flink.core.memory.MemorySegment
-
Reads a double-precision floating point value (64bit, 8 bytes) from the given position, in little endian
byte order.
- getDriver() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getDriverClass() - Method in enum org.apache.flink.runtime.operators.DriverStrategy
-
- getDriverComparator(int) - Method in class org.apache.flink.runtime.operators.BatchTask
-
- getDriverComparator(int) - Method in interface org.apache.flink.runtime.operators.TaskContext
-
- getDriverComparator(int, ClassLoader) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getDriverStrategy() - Method in class org.apache.flink.optimizer.plan.PlanNode
-
Gets the driver strategy from this node.
- getDriverStrategy() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getDriverStrategy() - Method in class org.apache.flink.table.explain.Node
-
- getDropwizardHistogram() - Method in class org.apache.flink.dropwizard.metrics.DropwizardHistogramWrapper
-
- getDropwizardMeter() - Method in class org.apache.flink.dropwizard.metrics.DropwizardMeterWrapper
-
- getDumpableInputs() - Method in class org.apache.flink.optimizer.dag.OptimizerNode
-
- getDumpableInputs() - Method in class org.apache.flink.optimizer.plan.PlanNode
-
- getDumpableInputs() - Method in interface org.apache.flink.optimizer.plandump.DumpableNode
-
- getDuration() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
-
- getDuration() - Method in class org.apache.flink.runtime.messages.webmonitor.JobDetails
-
- getDuration() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.Summary
-
- getDuration() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
-
- getDuration() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics
-
- getDuration() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatistics
-
- getDuration() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.CheckpointAlignment
-
- getDuration() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.Summary
-
- getDuration() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
-
- getDuration() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
-
- getDuration() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsInfo
-
- getDynamicConfiguration() - Method in class org.apache.flink.runtime.clusterframework.ContainerSpecification
-
Get the dynamic configuration.
- getDynamicProperties(String) - Static method in class org.apache.flink.yarn.cli.FlinkYarnSessionCli
-
- getDynamicPropertiesEncoded() - Method in class org.apache.flink.yarn.AbstractYarnClusterDescriptor
-
- getEdge() - Method in class org.apache.flink.graph.Triplet
-
- getEdgeGroupCount() - Method in class org.apache.flink.graph.library.Summarization.EdgeValue
-
- getEdgeGroupValue() - Method in class org.apache.flink.graph.library.Summarization.EdgeValue
-
- getEdgeIds() - Method in class org.apache.flink.graph.Graph
-
- getEdges() - Method in class org.apache.flink.graph.bipartite.BipartiteGraph
-
Get dataset with graph edges.
- getEdges(ExecutionEnvironment) - Static method in class org.apache.flink.graph.examples.data.SummarizationData
-
Creates a set of edges with attached
String
values.
- getEdges() - Method in class org.apache.flink.graph.Graph
-
- getEdges() - Method in class org.apache.flink.graph.pregel.ComputeFunction
-
Gets an
Iterable
with all out-going edges.
- getEdges() - Method in class org.apache.flink.graph.spargel.ScatterFunction
-
- getEdgesAsTuple3() - Method in class org.apache.flink.graph.Graph
-
- getEdgeValue() - Method in class org.apache.flink.graph.gsa.Neighbor
-
- getElement() - Method in class org.apache.flink.api.java.sampling.IntermediateSampleData
-
- getElementBlocking() - Method in class org.apache.flink.streaming.connectors.kafka.internals.ClosableBlockingQueue
-
Returns the next element in the queue.
- getElementBlocking(long) - Method in class org.apache.flink.streaming.connectors.kafka.internals.ClosableBlockingQueue
-
Returns the next element in the queue.
- getElementCount() - Method in class org.apache.flink.graph.generator.random.BlockInfo
-
- getElementsCollectedAndReset() - Method in class org.apache.flink.runtime.iterative.io.WorksetUpdateOutputCollector
-
- getElementSerializer() - Method in class org.apache.flink.api.common.state.ListStateDescriptor
-
Gets the serializer for the elements contained in the list.
- getElementSerializer() - Method in class org.apache.flink.api.common.typeutils.base.ListSerializer
-
Gets the serializer for the elements of the list.
- getElementSerializer() - Method in class org.apache.flink.runtime.state.ArrayListSerializer
-
- getElementTypeInfo() - Method in class org.apache.flink.api.java.typeutils.ListTypeInfo
-
Gets the type information for the elements contained in the list
- getElementTypeInfo() - Method in class org.apache.flink.api.java.typeutils.MultisetTypeInfo
-
Gets the type information for the elements contained in the Multiset
- getEmbeddedModeClientOptions(Options) - Static method in class org.apache.flink.table.client.cli.CliOptionsParser
-
- getEmptyCount() - Method in class org.apache.flink.api.java.summarize.StringColumnSummary
-
Number of empty strings e.g.
- getEnd() - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow
-
Gets the end timestamp of this window.
- getEndKeyGroup() - Method in class org.apache.flink.runtime.state.KeyGroupRange
-
- getEndOffsetExclusive() - Method in class org.apache.flink.runtime.state.BoundedInputStream
-
- getEndpointId() - Method in class org.apache.flink.runtime.rpc.RpcEndpoint
-
Returns the rpc endpoint's identifier.
- getEndRow() - Method in class org.apache.flink.addons.hbase.TableInputSplit
-
Returns the end row.
- getEndTime() - Method in class org.apache.flink.runtime.messages.webmonitor.JobDetails
-
- getEndTime() - Method in class org.apache.flink.runtime.rest.handler.legacy.backpressure.StackTraceSample
-
Returns the time stamp, when all stack traces were collected at the
JobManager.
- getEndTime() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
-
- getEndTime() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
-
- getEndTime() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsInfo
-
- getEndTimestamp() - Method in class org.apache.flink.runtime.rest.handler.legacy.backpressure.OperatorBackPressureStats
-
Returns the time stamp, when all stack traces were collected at the
JobManager.
- getEndTimestamp() - Method in class org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo
-
- getEndToEndDuration() - Method in class org.apache.flink.runtime.checkpoint.AbstractCheckpointStats
-
Returns the duration of this checkpoint calculated as the time since
triggering until the latest acknowledged subtask or -1
if
no subtask was acknowledged yet.
- getEndToEndDuration() - Method in class org.apache.flink.runtime.checkpoint.FailedCheckpointStats
-
Returns the end to end duration until the checkpoint failure.
- getEndToEndDuration(long) - Method in class org.apache.flink.runtime.checkpoint.SubtaskStateStats
-
Computes the duration since the given trigger timestamp.
- getEndToEndDuration(long) - Method in class org.apache.flink.runtime.checkpoint.TaskStateStats
-
Returns the duration of this checkpoint at the task/operator calculated
as the time since triggering until the latest acknowledged subtask
or -1
if no subtask was acknowledged yet.
- getEndToEndDurationStats() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpointStatsSummary
-
Returns the summary stats for the duration of completed checkpoints.
- getEntryClassName() - Method in class org.apache.flink.runtime.webmonitor.handlers.JarRunRequestBody
-
- getEntryIterator() - Method in class org.apache.flink.runtime.operators.hash.AbstractMutableHashTable
-
- getEntryIterator() - Method in class org.apache.flink.runtime.operators.hash.CompactingHashTable
-
- getEntryIterator() - Method in class org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable
-
Returns an iterator that can be used to iterate over all the elements in the table.
- getEntryPointClassName() - Method in class org.apache.flink.client.cli.ProgramOptions
-
- getEnum(String, T) - Method in class org.apache.hadoop.conf.Configuration
-
Return value matching this enumerated type.
- getEnumConstants() - Method in class org.apache.flink.api.common.typeutils.base.EnumSerializer.EnumSerializerConfigSnapshot
-
- getEnumeratingVertices(int) - Static method in class org.apache.flink.test.testdata.ConnectedComponentsData
-
- getEnvironment() - Method in class org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
-
Returns the environment of this task.
- getEnvironment() - Method in class org.apache.flink.streaming.api.datastream.BroadcastStream
-
- getEnvironment() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- getEnvironment() - Method in class org.apache.flink.table.client.cli.CliOptions
-
- getEnvironment() - Method in class org.apache.flink.table.client.gateway.SessionContext
-
- getEnvironmentVariables() - Method in class org.apache.flink.runtime.clusterframework.ContainerSpecification
-
Get the environment variables.
- getEnvironmentVariables(String, Configuration) - Static method in class org.apache.flink.yarn.Utils
-
Method to extract environment variables from the flinkConfiguration based on the given prefix String.
- getEpoch() - Method in class org.apache.flink.streaming.connectors.kafka.internal.FlinkKafkaProducer
-
- getError(ClassLoader) - Method in class org.apache.flink.runtime.taskmanager.TaskExecutionState
-
Gets the attached exception, which is in serialized form.
- getErrorCode() - Method in exception org.apache.flink.streaming.connectors.kafka.FlinkKafka011Exception
-
- getErrorResponse(Throwable) - Static method in class org.apache.flink.runtime.rest.handler.util.HandlerRedirectUtils
-
- getErrorResponse(Throwable, HttpResponseStatus) - Static method in class org.apache.flink.runtime.rest.handler.util.HandlerRedirectUtils
-
- getErrorState() - Method in class org.apache.flink.types.parser.FieldParser
-
- getEstimatedAvgWidthPerOutputRecord() - Method in class org.apache.flink.optimizer.dag.DagConnection
-
- getEstimatedAvgWidthPerOutputRecord() - Method in interface org.apache.flink.optimizer.dag.EstimateProvider
-
Gets the estimated number of bytes per record.
- getEstimatedAvgWidthPerOutputRecord() - Method in class org.apache.flink.optimizer.dag.OptimizerNode
-
- getEstimatedAvgWidthPerOutputRecord() - Method in class org.apache.flink.optimizer.plan.Channel
-
- getEstimatedNumRecords() - Method in class org.apache.flink.optimizer.dag.DagConnection
-
- getEstimatedNumRecords() - Method in interface org.apache.flink.optimizer.dag.EstimateProvider
-
Gets the estimated number of records in the output of this node.
- getEstimatedNumRecords() - Method in class org.apache.flink.optimizer.dag.OptimizerNode
-
- getEstimatedNumRecords() - Method in class org.apache.flink.optimizer.plan.Channel
-
- getEstimatedOutputSize() - Method in class org.apache.flink.optimizer.dag.DagConnection
-
- getEstimatedOutputSize() - Method in interface org.apache.flink.optimizer.dag.EstimateProvider
-
Gets the estimated output size from this node.
- getEstimatedOutputSize() - Method in class org.apache.flink.optimizer.dag.OptimizerNode
-
- getEstimatedOutputSize() - Method in class org.apache.flink.optimizer.plan.Channel
-
- getEstimates() - Method in class org.apache.flink.table.explain.Node
-
- getEvent() - Method in class org.apache.flink.cep.nfa.ComputationState
-
- getEvent() - Method in class org.apache.flink.runtime.io.network.partition.consumer.BufferOrEvent
-
- getEventsForPattern(String) - Method in class org.apache.flink.cep.nfa.ComputationState.ConditionContext
-
- getEventsForPattern(String) - Method in interface org.apache.flink.cep.pattern.conditions.IterativeCondition.Context
-
- getEventTime() - Method in class org.apache.flink.streaming.tests.artificialstate.ComplexPayload
-
- getEventTime() - Method in class org.apache.flink.streaming.tests.Event
-
- getEventTimeTimers() - Method in class org.apache.flink.streaming.api.operators.InternalTimersSnapshot
-
- getEventTimeTimersPerKeyGroup() - Method in class org.apache.flink.streaming.api.operators.HeapInternalTimerService
-
- getEvictor() - Method in class org.apache.flink.streaming.runtime.operators.windowing.EvictingWindowOperator
-
- getException() - Method in class org.apache.flink.runtime.executiongraph.ErrorInfo
-
Returns the serialized form of the original exception.
- getExceptionAsString() - Method in class org.apache.flink.runtime.executiongraph.ErrorInfo
-
Returns the contained exception as a string.
- getExecutingThread() - Method in class org.apache.flink.runtime.taskmanager.Task
-
- getExecution() - Method in class org.apache.flink.table.client.config.Environment
-
- getExecutionAttemptID() - Method in class org.apache.flink.runtime.accumulators.AccumulatorSnapshot
-
- getExecutionAttemptId() - Method in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
-
- getExecutionAttemptID() - Method in class org.apache.flink.runtime.messages.StackTraceSampleResponse
-
- getExecutionConfig() - Method in interface org.apache.flink.api.common.functions.RuntimeContext
-
- getExecutionConfig() - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
-
- getExecutionConfig() - Method in class org.apache.flink.api.common.Plan
-
Gets the execution config object.
- getExecutionConfig() - Method in class org.apache.flink.queryablestate.client.QueryableStateClient
-
- getExecutionConfig() - Method in interface org.apache.flink.runtime.execution.Environment
-
- getExecutionConfig() - Method in class org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
-
Returns the global ExecutionConfig.
- getExecutionConfig() - Method in interface org.apache.flink.runtime.operators.TaskContext
-
- getExecutionConfig() - Method in class org.apache.flink.runtime.state.DefaultOperatorStateBackend
-
- getExecutionConfig() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
-
- getExecutionConfig() - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
- getExecutionConfig() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- getExecutionConfig() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
Gets the execution config defined on the execution environment of the job to which this
operator belongs.
- getExecutionConfig() - Method in class org.apache.flink.table.client.gateway.local.ExecutionContext.EnvironmentInstance
-
- getExecutionConfigInfo() - Method in class org.apache.flink.runtime.rest.messages.JobConfigInfo
-
- getExecutionEnvironment() - Method in class org.apache.flink.api.java.DataSet
-
- getExecutionEnvironment() - Static method in class org.apache.flink.api.java.ExecutionEnvironment
-
Creates an execution environment that represents the context in which the program is currently executed.
- getExecutionEnvironment() - Method in class org.apache.flink.graph.Runner
-
Get the ExecutionEnvironment.
- getExecutionEnvironment() - Method in class org.apache.flink.storm.api.FlinkTopology
-
- getExecutionEnvironment() - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
- getExecutionEnvironment() - Method in class org.apache.flink.streaming.api.datastream.BroadcastConnectedStream
-
- getExecutionEnvironment() - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
-
- getExecutionEnvironment() - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
- getExecutionEnvironment() - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
- getExecutionEnvironment() - Static method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Creates an execution environment that represents the context in which the
program is currently executed.
- getExecutionEnvironment() - Method in class org.apache.flink.table.client.gateway.local.ExecutionContext.EnvironmentInstance
-
- getExecutionGraph() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- getExecutionGraph(JobID) - Method in class org.apache.flink.runtime.minicluster.MiniCluster
-
- getExecutionGraph(JobID, RestfulGateway) - Method in class org.apache.flink.runtime.rest.handler.legacy.ExecutionGraphCache
-
- getExecutionId() - Method in interface org.apache.flink.runtime.execution.Environment
-
Gets the ID of the task execution attempt.
- getExecutionId() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
-
- getExecutionId() - Method in class org.apache.flink.runtime.taskmanager.Task
-
- getExecutionMode() - Method in class org.apache.flink.api.common.ArchivedExecutionConfig
-
- getExecutionMode() - Method in class org.apache.flink.api.common.ExecutionConfig
-
Gets the execution mode used to execute the program.
- getExecutionPlan() - Method in class org.apache.flink.api.java.CollectionEnvironment
-
- getExecutionPlan() - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
Creates the plan with which the system will execute the program, and returns it as
a String using a JSON representation of the execution data flow graph.
- getExecutionPlan() - Method in class org.apache.flink.api.java.LocalEnvironment
-
- getExecutionPlan() - Method in class org.apache.flink.api.java.RemoteEnvironment
-
- getExecutionPlan() - Method in class org.apache.flink.client.program.ContextEnvironment
-
- getExecutionPlan() - Method in class org.apache.flink.client.program.OptimizerPlanEnvironment
-
- getExecutionPlan() - Method in class org.apache.flink.client.program.PreviewPlanEnvironment
-
- getExecutionPlan() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Creates the plan with which the system will execute the program, and
returns it as a String using a JSON representation of the execution data
flow graph.
- getExecutionPlan() - Method in class org.apache.flink.test.util.TestEnvironment
-
- getExecutionRetryDelay() - Method in class org.apache.flink.api.common.ExecutionConfig
-
- getExecutionState() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionVertex
-
- getExecutionState() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionVertex
-
- getExecutionState() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- getExecutionState() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
-
- getExecutionState() - Method in class org.apache.flink.runtime.taskmanager.Task
-
Returns the current execution state of the task.
- getExecutionState() - Method in class org.apache.flink.runtime.taskmanager.TaskExecutionState
-
Returns the new execution state of the task.
- getExecutor() - Method in class org.apache.flink.api.java.RemoteEnvironment
-
- getExecutor() - Method in class org.apache.flink.api.java.ScalaShellRemoteEnvironment
-
- getExecutor() - Method in class org.apache.flink.runtime.rpc.akka.AkkaRpcService
-
- getExecutor() - Method in interface org.apache.flink.runtime.rpc.RpcService
-
Gets the executor, provided by this RPC service.
- getExecutor() - Method in class org.apache.flink.table.client.cli.CliClient
-
- getExpected() - Method in exception org.apache.flink.runtime.highavailability.LeaderIdMismatchException
-
- getExtendedprice() - Method in class org.apache.flink.examples.java.relational.TPCHQuery3.Lineitem
-
- getExtendedResources() - Method in class org.apache.flink.api.common.operators.ResourceSpec
-
- getExtendedResources() - Method in class org.apache.flink.runtime.clusterframework.types.ResourceProfile
-
Get the extended resources.
- getExternalizedCheckpointCleanup() - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Returns the cleanup behaviour for externalized checkpoints.
- getExternalPath() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpointStats
-
Returns the external pointer of this checkpoint.
- getExternalPath() - Method in class org.apache.flink.runtime.checkpoint.RestoredCheckpointStats
-
Returns the external path if this checkpoint was persisted externally.
- getExternalPath() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.RestoredCheckpointStatistics
-
- getExternalPath() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics.CompletedCheckpointStatistics
-
- getExternalPointer() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
-
- getExternalPointer() - Method in interface org.apache.flink.runtime.state.CompletedCheckpointStorageLocation
-
Gets the external pointer to the checkpoint.
- getExternalPointer() - Method in class org.apache.flink.runtime.state.filesystem.FsCompletedCheckpointStorageLocation
-
- getFactory() - Method in enum org.apache.flink.api.java.aggregation.Aggregations
-
- getFailedCheckpointStatistics() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.LatestCheckpoints
-
- getFailedFuture(Throwable) - Static method in class org.apache.flink.queryablestate.FutureUtils
-
- getFailoverRegion(ExecutionVertex) - Method in class org.apache.flink.runtime.executiongraph.failover.RestartPipelinedRegionStrategy
-
Finds the failover region that contains the given execution vertex.
- getFailoverStrategy() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
Gets the failover strategy used by the execution graph to recover from failures of tasks.
- getFailureCause() - Method in class org.apache.flink.runtime.executiongraph.Execution
-
- getFailureCause() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- getFailureCause() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- getFailureCause() - Method in interface org.apache.flink.runtime.io.network.NetworkSequenceViewReader
-
- getFailureCause() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
-
- getFailureCause() - Method in class org.apache.flink.runtime.io.network.partition.ResultSubpartition
-
- getFailureCause() - Method in interface org.apache.flink.runtime.io.network.partition.ResultSubpartitionView
-
- getFailureCause() - Method in class org.apache.flink.runtime.rest.handler.async.AsynchronousOperationInfo
-
- getFailureCause() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointInfo
-
- getFailureCause() - Method in class org.apache.flink.runtime.taskmanager.Task
-
If the task has failed, this method gets the exception that caused this task to fail.
- getFailureCause() - Method in class org.apache.flink.util.OptionalFailure
-
- getFailureCauseAsString() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecution
-
Returns the exception that caused the job to fail.
- getFailureCauseAsString() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionVertex
-
Returns the exception that caused the job to fail.
- getFailureCauseAsString() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecution
-
- getFailureCauseAsString() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionVertex
-
- getFailureCauseAsString() - Method in class org.apache.flink.runtime.executiongraph.Execution
-
- getFailureCauseAsString() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- getFailureInfo() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionGraph
-
Returns the exception that caused the job to fail.
- getFailureInfo() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
-
- getFailureInfo() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- getFailureInterval() - Method in class org.apache.flink.api.common.restartstrategy.RestartStrategies.FailureRateRestartStrategyConfiguration
-
- getFailureMessage() - Method in class org.apache.flink.runtime.checkpoint.FailedCheckpointStats
-
Returns the failure message or null
if no cause was provided.
- getFailureMessage() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics.FailedCheckpointStatistics
-
- getFailureReason() - Method in class org.apache.flink.runtime.checkpoint.CheckpointTriggerResult
-
- getFailureTimestamp() - Method in class org.apache.flink.runtime.checkpoint.FailedCheckpointStats
-
Returns the timestamp when this checkpoint failed.
- getFailureTimestamp() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics.FailedCheckpointStatistics
-
- getFalseCount() - Method in class org.apache.flink.api.java.summarize.BooleanColumnSummary
-
- getFeedbackEdges() - Method in class org.apache.flink.streaming.api.transformations.CoFeedbackTransformation
-
Returns the list of feedback StreamTransformations
.
- getFeedbackEdges() - Method in class org.apache.flink.streaming.api.transformations.FeedbackTransformation
-
Returns the list of feedback StreamTransformations
.
- getFencingToken() - Method in class org.apache.flink.runtime.rpc.akka.FencedAkkaInvocationHandler
-
- getFencingToken() - Method in class org.apache.flink.runtime.rpc.FencedRpcEndpoint
-
- getFencingToken() - Method in interface org.apache.flink.runtime.rpc.FencedRpcGateway
-
Get the current fencing token.
- getFencingToken() - Method in interface org.apache.flink.runtime.rpc.messages.FencedMessage
-
- getFencingToken() - Method in class org.apache.flink.runtime.rpc.messages.LocalFencedMessage
-
- getFencingToken() - Method in class org.apache.flink.runtime.rpc.messages.RemoteFencedMessage
-
- getFetcherName() - Method in class org.apache.flink.streaming.connectors.kafka.internal.Kafka010Fetcher
-
- getFetcherName() - Method in class org.apache.flink.streaming.connectors.kafka.internal.Kafka09Fetcher
-
Gets the name of this fetcher, for thread naming and logging purposes.
- getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple
-
Gets the field at the specified position.
- getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple0
-
- getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple1
-
- getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple10
-
- getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple11
-
- getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple12
-
- getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple13
-
- getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple14
-
- getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple15
-
- getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple16
-
- getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple17
-
- getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple18
-
- getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple19
-
- getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple2
-
- getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple20
-
- getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple21
-
- getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple22
-
- getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple23
-
- getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple24
-
- getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple25
-
- getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple3
-
- getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple4
-
- getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple5
-
- getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple6
-
- getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple7
-
- getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple8
-
- getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple9
-
- getField() - Method in class org.apache.flink.api.java.typeutils.PojoField
-
- getField(int, Class<T>) - Method in class org.apache.flink.types.Record
-
Gets the field at the given position from the record.
- getField(int, T) - Method in class org.apache.flink.types.Record
-
Gets the field at the given position.
- getField(int) - Method in class org.apache.flink.types.Row
-
Gets the field at the specified position.
- getFieldDelimiter() - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
-
- getFieldIndex(String) - Method in class org.apache.flink.api.common.typeutils.CompositeType
-
Returns the field index of the composite field of the given name.
- getFieldIndex(String) - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo
-
- getFieldIndex(String) - Method in class org.apache.flink.api.java.typeutils.RowTypeInfo
-
- getFieldIndex(String) - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfo
-
- getFieldInto(int, Value) - Method in class org.apache.flink.types.Record
-
Gets the field at the given position.
- getFieldMapping() - Method in class org.apache.flink.sql.tests.StreamSQLTestProgram.GeneratorTableSource
-
- getFieldMapping() - Method in class org.apache.flink.streaming.connectors.kafka.KafkaAvroTableSource
-
- getFieldMapping() - Method in class org.apache.flink.streaming.connectors.kafka.KafkaJsonTableSource
-
- getFieldName() - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo.NamedFlatFieldDescriptor
-
- getFieldNames() - Method in class org.apache.flink.api.common.typeutils.CompositeType
-
Returns the names of the composite fields of this type.
- getFieldNames() - Method in class org.apache.flink.api.java.io.jdbc.JDBCAppendTableSink
-
- getFieldNames() - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo
-
- getFieldNames() - Method in class org.apache.flink.api.java.typeutils.RowTypeInfo
-
- getFieldNames() - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfo
-
- getFieldNames() - Method in class org.apache.flink.streaming.connectors.cassandra.CassandraAppendTableSink
-
- getFieldNames() - Method in class org.apache.flink.streaming.connectors.kafka.KafkaTableSink
-
- getFieldNames() - Method in class org.apache.flink.table.client.gateway.local.CollectStreamTableSink
-
- getFieldNotNull(int) - Method in class org.apache.flink.api.java.tuple.Tuple
-
Gets the field at the specified position, throws NullFieldException if the field is null.
- getFieldNumber(int) - Method in class org.apache.flink.api.common.operators.Ordering
-
- getFieldNumber() - Method in exception org.apache.flink.optimizer.postpass.ConflictingFieldTypeInfoException
-
- getFieldNumber() - Method in exception org.apache.flink.optimizer.postpass.MissingFieldTypeInfoException
-
- getFieldNumber() - Method in exception org.apache.flink.types.KeyFieldOutOfBoundsException
-
Gets the field number that was attempted to access.
- getFieldNumber() - Method in exception org.apache.flink.types.NullKeyFieldException
-
Gets the field number that was attempted to access.
- getFieldOrders() - Method in class org.apache.flink.api.common.operators.Ordering
-
- getFieldParsers() - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
-
- getFieldPos() - Method in exception org.apache.flink.types.NullFieldException
-
Gets the field number that was attempted to access.
- getFieldPositions() - Method in class org.apache.flink.api.common.operators.Ordering
-
- getFields() - Method in class org.apache.flink.api.java.operators.CrossOperator.ProjectCrossFunction
-
- getFields(String...) - Method in class org.apache.flink.hcatalog.HCatInputFormatBase
-
Specifies the fields which are returned by the InputFormat and their order.
- getFields() - Method in class org.apache.flink.storm.wrappers.StormTuple
-
- getFieldSerializers() - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializerBase
-
- getFieldsInto(int[], Value[]) - Method in class org.apache.flink.types.Record
-
Gets the fields at the given positions into an array.
- getFieldsIntoCheckingNull(int[], Value[]) - Method in class org.apache.flink.types.Record
-
Gets the fields at the given positions into an array.
- getFieldSortDirections() - Method in class org.apache.flink.api.common.operators.Ordering
-
- getFieldToSerializerConfigSnapshot() - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer.PojoSerializerConfigSnapshot
-
- getFieldType() - Method in class org.apache.flink.streaming.util.typeutils.FieldAccessor
-
Gets the TypeInformation for the type of the field.
- getFieldTypes() - Method in class org.apache.flink.api.java.io.CsvInputFormat
-
- getFieldTypes() - Method in class org.apache.flink.api.java.io.jdbc.JDBCAppendTableSink
-
- getFieldTypes() - Method in class org.apache.flink.api.java.typeutils.RowTypeInfo
-
Returns the field types of the row.
- getFieldTypes() - Method in class org.apache.flink.streaming.connectors.cassandra.CassandraAppendTableSink
-
- getFieldTypes() - Method in class org.apache.flink.streaming.connectors.kafka.KafkaTableSink
-
- getFieldTypes() - Method in class org.apache.flink.table.client.gateway.local.CollectStreamTableSink
-
- getFifteenMinuteRate() - Method in class org.apache.flink.dropwizard.metrics.FlinkMeterWrapper
-
- getFile(String) - Method in class org.apache.flink.api.common.cache.DistributedCache
-
- getFile() - Method in class org.apache.flink.core.fs.local.LocalFileStatus
-
- getFile(TransientBlobKey) - Method in class org.apache.flink.runtime.blob.BlobServer
-
Retrieves the local path of a (job-unrelated) file associated with a job and a blob key.
- getFile(JobID, TransientBlobKey) - Method in class org.apache.flink.runtime.blob.BlobServer
-
Retrieves the local path of a file associated with a job and a blob key.
- getFile(JobID, PermanentBlobKey) - Method in class org.apache.flink.runtime.blob.BlobServer
-
Returns the path to a local copy of the file associated with the provided job ID and blob
key.
- getFile(JobID, PermanentBlobKey) - Method in class org.apache.flink.runtime.blob.PermanentBlobCache
-
Returns the path to a local copy of the file associated with the provided job ID and blob
key.
- getFile(JobID, PermanentBlobKey) - Method in interface org.apache.flink.runtime.blob.PermanentBlobService
-
Returns the path to a local copy of the file associated with the provided job ID and blob
key.
- getFile(TransientBlobKey) - Method in class org.apache.flink.runtime.blob.TransientBlobCache
-
- getFile(JobID, TransientBlobKey) - Method in class org.apache.flink.runtime.blob.TransientBlobCache
-
- getFile(TransientBlobKey) - Method in interface org.apache.flink.runtime.blob.TransientBlobService
-
Returns the path to a local copy of the (job-unrelated) file associated with the provided
blob key.
- getFile(JobID, TransientBlobKey) - Method in interface org.apache.flink.runtime.blob.TransientBlobService
-
Returns the path to a local copy of the file associated with the provided job ID and blob
key.
- getFile() - Method in class org.apache.flink.runtime.rest.FileUpload
-
- getFile(String, String) - Method in class org.apache.hadoop.conf.Configuration
-
Get a local file name under a directory named in dirsProp with
the given path.
- getFileBlockLocations(FileStatus, long, long) - Method in class org.apache.flink.core.fs.FileSystem
-
Return an array containing hostnames, offset and size of
portions of the given file.
- getFileBlockLocations(FileStatus, long, long) - Method in class org.apache.flink.core.fs.LimitedConnectionsFileSystem
-
- getFileBlockLocations(FileStatus, long, long) - Method in class org.apache.flink.core.fs.local.LocalFileSystem
-
- getFileBlockLocations(FileStatus, long, long) - Method in class org.apache.flink.core.fs.SafetyNetWrapperFileSystem
-
- getFileBlockLocations(FileStatus, long, long) - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileSystem
-
- getFileCache() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServices
-
- getFileChannel() - Method in class org.apache.flink.runtime.io.disk.iomanager.FileSegment
-
- getFilehandlesDriver() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getFilehandlesInput(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getFileInternal(JobID, BlobKey) - Method in class org.apache.flink.runtime.blob.AbstractBlobCache
-
Returns local copy of the file for the BLOB with the given key.
- getFileInternal(JobID, BlobKey) - Method in class org.apache.flink.runtime.blob.TransientBlobCache
-
- getFilename() - Method in class org.apache.flink.runtime.webmonitor.handlers.JarUploadResponseBody
-
- getFilePath() - Method in class org.apache.flink.api.common.io.FileInputFormat
-
- getFilePath() - Method in class org.apache.flink.api.java.io.CsvReader
-
- getFilePath() - Method in class org.apache.flink.runtime.state.filesystem.FileStateHandle
-
Gets the path where this handle's state is stored.
- getFilePaths() - Method in class org.apache.flink.api.common.io.FileInputFormat
-
Returns the paths of all files to be read by the FileInputFormat.
- getFiles() - Method in class org.apache.flink.api.common.io.BinaryInputFormat
-
- getFileStats(FileInputFormat.FileBaseStatistics, Path[], ArrayList<FileStatus>) - Method in class org.apache.flink.api.common.io.FileInputFormat
-
- getFileStats(FileInputFormat.FileBaseStatistics, Path, FileSystem, ArrayList<FileStatus>) - Method in class org.apache.flink.api.common.io.FileInputFormat
-
- getFileStatus(Path) - Method in class org.apache.flink.core.fs.FileSystem
-
Return a file status object that represents the path.
- getFileStatus(Path) - Method in class org.apache.flink.core.fs.LimitedConnectionsFileSystem
-
- getFileStatus(Path) - Method in class org.apache.flink.core.fs.local.LocalFileSystem
-
- getFileStatus(Path) - Method in class org.apache.flink.core.fs.SafetyNetWrapperFileSystem
-
- getFileStatus(Path) - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileSystem
-
- getFileSystem() - Method in class org.apache.flink.core.fs.Path
-
Returns the FileSystem that owns this Path.
- getFileSystem() - Method in class org.apache.flink.runtime.state.SnapshotDirectory
-
- getFilterFactor() - Method in class org.apache.flink.api.common.operators.CompilerHints
-
- getFinalParameters() - Method in class org.apache.hadoop.conf.Configuration
-
Get the set of parameters marked final.
- getFirstDegree() - Method in class org.apache.flink.examples.java.graph.util.EnumTrianglesDataTypes.EdgeWithDegrees
-
- getFirstDegree() - Method in class org.apache.flink.graph.library.TriangleEnumerator.EdgeWithDegrees
-
- getFirstElement() - Method in class org.apache.flink.graph.generator.random.BlockInfo
-
- getFirstIncomingConnection() - Method in class org.apache.flink.optimizer.dag.TwoInputNode
-
Gets the DagConnection through which this node receives its first input.
- getFirstInput() - Method in class org.apache.flink.api.common.operators.DualInputOperator
-
Returns the first input, or null, if none is set.
- getFirstInput() - Method in class org.apache.flink.streaming.api.datastream.BroadcastConnectedStream
-
- getFirstInput() - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
-
- getFirstInputType() - Method in class org.apache.flink.api.common.operators.BinaryOperatorInformation
-
- getFirstPredecessorNode() - Method in class org.apache.flink.optimizer.dag.TwoInputNode
-
- getFirstRecordStart() - Method in class org.apache.flink.api.common.io.BlockInfo
-
Returns the firstRecordStart.
- getFirstVertex() - Method in class org.apache.flink.examples.java.graph.util.EnumTrianglesDataTypes.Edge
-
- getFirstVertex() - Method in class org.apache.flink.examples.java.graph.util.EnumTrianglesDataTypes.EdgeWithDegrees
-
- getFirstVertex() - Method in class org.apache.flink.graph.library.TriangleEnumerator.EdgeWithDegrees
-
- getFirstVertex() - Method in class org.apache.flink.graph.library.TriangleEnumerator.Triad
-
- getFiveMinuteRate() - Method in class org.apache.flink.dropwizard.metrics.FlinkMeterWrapper
-
- getFixedTopics() - Method in class org.apache.flink.streaming.connectors.kafka.internals.KafkaTopicsDescriptor
-
- getFlatComparator(List<TypeComparator>) - Method in class org.apache.flink.api.common.typeutils.CompositeTypeComparator
-
- getFlatComparator(List<TypeComparator>) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoComparator
-
- getFlatComparator(List<TypeComparator>) - Method in class org.apache.flink.api.java.typeutils.runtime.RowComparator
-
- getFlatComparator(List<TypeComparator>) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
-
- getFlatComparators() - Method in class org.apache.flink.api.common.typeutils.base.array.PrimitiveArrayComparator
-
- getFlatComparators() - Method in class org.apache.flink.api.common.typeutils.base.BasicTypeComparator
-
- getFlatComparators() - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueComparator
-
- getFlatComparators() - Method in class org.apache.flink.api.common.typeutils.base.ByteValueComparator
-
- getFlatComparators() - Method in class org.apache.flink.api.common.typeutils.base.CharValueComparator
-
- getFlatComparators() - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueComparator
-
- getFlatComparators() - Method in class org.apache.flink.api.common.typeutils.base.FloatValueComparator
-
- getFlatComparators() - Method in class org.apache.flink.api.common.typeutils.base.IntValueComparator
-
- getFlatComparators() - Method in class org.apache.flink.api.common.typeutils.base.LongValueComparator
-
- getFlatComparators() - Method in class org.apache.flink.api.common.typeutils.base.NullValueComparator
-
- getFlatComparators() - Method in class org.apache.flink.api.common.typeutils.base.ShortValueComparator
-
- getFlatComparators() - Method in class org.apache.flink.api.common.typeutils.base.StringValueComparator
-
- getFlatComparators() - Method in class org.apache.flink.api.common.typeutils.CompositeTypeComparator
-
- getFlatComparators() - Method in class org.apache.flink.api.common.typeutils.TypeComparator
-
Get the field comparators.
- getFlatComparators() - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueComparator
-
- getFlatComparators() - Method in class org.apache.flink.api.java.typeutils.runtime.GenericTypeComparator
-
- getFlatComparators() - Method in class org.apache.flink.api.java.typeutils.runtime.NullAwareComparator
-
- getFlatComparators() - Method in class org.apache.flink.api.java.typeutils.runtime.ValueComparator
-
- getFlatComparators() - Method in class org.apache.flink.api.java.typeutils.runtime.WritableComparator
-
- getFlatComparators() - Method in class org.apache.flink.graph.types.valuearray.ByteValueArrayComparator
-
- getFlatComparators() - Method in class org.apache.flink.graph.types.valuearray.CharValueArrayComparator
-
- getFlatComparators() - Method in class org.apache.flink.graph.types.valuearray.DoubleValueArrayComparator
-
- getFlatComparators() - Method in class org.apache.flink.graph.types.valuearray.FloatValueArrayComparator
-
- getFlatComparators() - Method in class org.apache.flink.graph.types.valuearray.IntValueArrayComparator
-
- getFlatComparators() - Method in class org.apache.flink.graph.types.valuearray.LongValueArrayComparator
-
- getFlatComparators() - Method in class org.apache.flink.graph.types.valuearray.NullValueArrayComparator
-
- getFlatComparators() - Method in class org.apache.flink.graph.types.valuearray.ShortValueArrayComparator
-
- getFlatComparators() - Method in class org.apache.flink.graph.types.valuearray.StringValueArrayComparator
-
- getFlatFieldExpr() - Method in class org.apache.flink.api.java.sca.TaggedValue
-
- getFlatFields(String) - Method in class org.apache.flink.api.common.typeutils.CompositeType
-
Returns the flat field descriptors for the given field expression.
- getFlatFields(String, int, List<CompositeType.FlatFieldDescriptor>) - Method in class org.apache.flink.api.common.typeutils.CompositeType
-
Computes the flat field descriptors for the given field expression with the given offset.
- getFlatFields(String, int, List<CompositeType.FlatFieldDescriptor>) - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo
-
- getFlatFields(String, int, List<CompositeType.FlatFieldDescriptor>) - Method in class org.apache.flink.api.java.typeutils.RowTypeInfo
-
- getFlatFields(String, int, List<CompositeType.FlatFieldDescriptor>) - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfoBase
-
- getFlatJoinReturnTypes(FlatJoinFunction<IN1, IN2, OUT>, TypeInformation<IN1>, TypeInformation<IN2>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
- getFlatJoinReturnTypes(FlatJoinFunction<IN1, IN2, OUT>, TypeInformation<IN1>, TypeInformation<IN2>, String, boolean) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
- getFlatMapReturnTypes(FlatMapFunction<IN, OUT>, TypeInformation<IN>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
- getFlatMapReturnTypes(FlatMapFunction<IN, OUT>, TypeInformation<IN>, String, boolean) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
- getFlatSelectFunction() - Method in class org.apache.flink.cep.operator.FlatSelectTimeoutCepOperator.FlatSelectWrapper
-
- getFlatTimeoutFunction() - Method in class org.apache.flink.cep.operator.FlatSelectTimeoutCepOperator.FlatSelectWrapper
-
- getFlinkConfig() - Method in class org.apache.flink.runtime.security.SecurityConfiguration
-
- getFlinkConfiguration() - Method in class org.apache.flink.client.program.ClusterClient
-
Return the Flink configuration object.
- getFlinkConfiguration() - Method in class org.apache.flink.yarn.AbstractYarnClusterDescriptor
-
- getFlinkConfiguration() - Method in class org.apache.flink.yarn.YarnClusterClient
-
- getFlinkRevision() - Method in class org.apache.flink.runtime.rest.messages.DashboardConfiguration
-
- getFlinkVersion() - Method in class org.apache.flink.runtime.rest.messages.DashboardConfiguration
-
- getFloat(String) - Method in class org.apache.flink.api.java.utils.ParameterTool
-
Returns the Float value for the given key.
- getFloat(String, float) - Method in class org.apache.flink.api.java.utils.ParameterTool
-
Returns the Float value for the given key.
- getFloat(String, float) - Method in class org.apache.flink.configuration.Configuration
-
Returns the value associated with the given key as a float.
- getFloat(ConfigOption<Float>) - Method in class org.apache.flink.configuration.Configuration
-
Returns the value associated with the given config option as a float.
- getFloat(ConfigOption<Float>, float) - Method in class org.apache.flink.configuration.Configuration
-
Returns the value associated with the given config option as a float.
- getFloat(String, float) - Method in class org.apache.flink.configuration.DelegatingConfiguration
-
- getFloat(ConfigOption<Float>) - Method in class org.apache.flink.configuration.DelegatingConfiguration
-
- getFloat(ConfigOption<Float>, float) - Method in class org.apache.flink.configuration.DelegatingConfiguration
-
- getFloat(int) - Method in class org.apache.flink.core.memory.MemorySegment
-
Reads a single-precision floating point value (32bit, 4 bytes) from the given position, in the system's
native byte order.
- getFloat(String, float) - Method in class org.apache.flink.metrics.MetricConfig
-
Searches for the property with the specified key in this property list.
- getFloat(int) - Method in class org.apache.flink.storm.wrappers.StormTuple
-
- getFloat(String, float) - Method in class org.apache.hadoop.conf.Configuration
-
Get the value of the name
property as a float
.
- getFloatBigEndian(int) - Method in class org.apache.flink.core.memory.MemorySegment
-
Reads a single-precision floating point value (32bit, 4 bytes) from the given position, in big endian
byte order.
- getFloatByField(String) - Method in class org.apache.flink.storm.wrappers.StormTuple
-
- getFloatLittleEndian(int) - Method in class org.apache.flink.core.memory.MemorySegment
-
Reads a single-precision floating point value (32bit, 4 bytes) from the given position, in little endian
byte order.
- getFoldFunction() - Method in class org.apache.flink.api.common.state.FoldingStateDescriptor
-
Deprecated.
Returns the fold function to be used for the folding state.
- getFoldingState(FoldingStateDescriptor<T, ACC>) - Method in interface org.apache.flink.api.common.functions.RuntimeContext
-
- getFoldingState(FoldingStateDescriptor<T, ACC>) - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
-
Deprecated.
- getFoldingState(FoldingStateDescriptor<T, ACC>) - Method in interface org.apache.flink.api.common.state.KeyedStateStore
-
- getFoldingState(FoldingStateDescriptor<T, ACC>) - Method in class org.apache.flink.runtime.state.DefaultKeyedStateStore
-
- getFoldingState(FoldingStateDescriptor<T, ACC>) - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
-
- getFoldingState(FoldingStateDescriptor<T, A>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.MergingWindowStateStore
-
- getFoldReturnTypes(FoldFunction<IN, OUT>, TypeInformation<IN>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
- getFoldReturnTypes(FoldFunction<IN, OUT>, TypeInformation<IN>, String, boolean) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
- getFooterLines() - Method in class org.apache.flink.table.client.cli.CliView
-
- getForAggregation(AggregationFunction.AggregationType) - Static method in class org.apache.flink.streaming.api.functions.aggregation.Comparator
-
- getForClass(Class<X>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
Creates type information from a given Class such as Integer, String[] or POJOs.
- getForClass(Class<?>) - Static method in class org.apache.flink.streaming.api.functions.aggregation.SumFunction
-
- getForForwardExchange(ExecutionMode) - Static method in enum org.apache.flink.runtime.io.network.DataExchangeMode
-
- getFormat() - Method in class org.apache.flink.api.java.operators.DataSink
-
- getFormat() - Method in class org.apache.flink.streaming.api.functions.source.InputFormatSourceFunction
-
Returns the InputFormat
.
- getFormatDescription() - Method in class org.apache.flink.runtime.jobgraph.InputFormatVertex
-
- getFormatDescription() - Method in class org.apache.flink.runtime.jobgraph.OutputFormatVertex
-
- getFormatWrapper() - Method in class org.apache.flink.api.common.operators.GenericDataSinkBase
-
Gets the class describing this sinks output format.
- getFormatWrapper() - Method in class org.apache.flink.api.common.operators.GenericDataSourceBase
-
Gets the class describing the input format.
- getForObject(X) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
- getForShuffleOrBroadcast(ExecutionMode) - Static method in enum org.apache.flink.runtime.io.network.DataExchangeMode
-
- getForwardingSourceField(int, int) - Method in class org.apache.flink.api.common.operators.DualInputSemanticProperties
-
- getForwardingSourceField(int, int) - Method in class org.apache.flink.api.common.operators.SemanticProperties.EmptySemanticProperties
-
- getForwardingSourceField(int, int) - Method in interface org.apache.flink.api.common.operators.SemanticProperties
-
Returns the index of the source field on the given input from which the target field
has been unmodified copied by a function.
- getForwardingSourceField(int, int) - Method in class org.apache.flink.api.common.operators.SingleInputSemanticProperties.AllFieldsForwardedProperties
-
- getForwardingSourceField(int, int) - Method in class org.apache.flink.api.common.operators.SingleInputSemanticProperties
-
- getForwardingSourceField(int, int) - Method in class org.apache.flink.optimizer.dag.BinaryUnionNode.UnionSemanticProperties
-
- getForwardingTargetFields(int, int) - Method in class org.apache.flink.api.common.operators.DualInputSemanticProperties
-
- getForwardingTargetFields(int, int) - Method in class org.apache.flink.api.common.operators.SemanticProperties.EmptySemanticProperties
-
- getForwardingTargetFields(int, int) - Method in interface org.apache.flink.api.common.operators.SemanticProperties
-
Returns the indexes of all target fields to which a source field has been
unmodified copied by a function.
- getForwardingTargetFields(int, int) - Method in class org.apache.flink.api.common.operators.SingleInputSemanticProperties.AllFieldsForwardedProperties
-
- getForwardingTargetFields(int, int) - Method in class org.apache.flink.api.common.operators.SingleInputSemanticProperties
-
- getForwardingTargetFields(int, int) - Method in class org.apache.flink.optimizer.dag.BinaryUnionNode.UnionSemanticProperties
-
- getFQDNHostname() - Method in class org.apache.flink.runtime.taskmanager.TaskManagerLocation
-
Returns the fully-qualified domain name the TaskManager.
- getFraction() - Method in class org.apache.calcite.avatica.util.DateTimeUtils.PrecisionTime
-
- getFrameworkID() - Method in interface org.apache.flink.mesos.runtime.clusterframework.store.MesosWorkerStore
-
Get the stored Mesos framework ID.
- getFrameworkID() - Method in class org.apache.flink.mesos.runtime.clusterframework.store.StandaloneMesosWorkerStore
-
- getFrameworkID() - Method in class org.apache.flink.mesos.runtime.clusterframework.store.ZooKeeperMesosWorkerStore
-
Get the persisted framework ID.
- getFreedMemory() - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
-
- getFreeMemory() - Method in class org.apache.flink.runtime.operators.hash.AbstractMutableHashTable
-
- getFreeMemory() - Method in class org.apache.flink.runtime.operators.hash.CompactingHashTable
-
- getFreeMemory() - Method in class org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable
-
- getFreeSlotForTask(ExecutionVertex, Iterable<TaskManagerLocation>, boolean) - Method in class org.apache.flink.runtime.jobmanager.scheduler.Scheduler
-
Gets a suitable instance to schedule the vertex execution to.
- getFrequency() - Method in class org.apache.flink.examples.java.wordcount.WordCountPojo.Word
-
- getFrequency() - Method in class org.apache.flink.streaming.examples.kafka.KafkaEvent
-
- getFrom() - Method in class org.apache.flink.cep.pattern.Quantifier.Times
-
- getFromHTTP(String) - Static method in class org.apache.flink.test.util.TestBaseUtils
-
- getFromHTTP(String, Time) - Static method in class org.apache.flink.test.util.TestBaseUtils
-
- getFullSegments() - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBulkBlockReader
-
- getFullSegments() - Method in interface org.apache.flink.runtime.io.disk.iomanager.BulkBlockChannelReader
-
- getFullStringifiedStackTrace() - Method in exception org.apache.flink.util.SerializedThrowable
-
- getFullTemplateType(Type, int) - Static method in class org.apache.flink.util.ReflectionUtil
-
Extract the full template type information from the given type's template parameter at the
given position.
- getFullTemplateType(Type) - Static method in class org.apache.flink.util.ReflectionUtil
-
Extract the full type information from the given type.
- getFunction() - Method in class org.apache.flink.api.java.operators.CoGroupOperator
-
- getFunction() - Method in class org.apache.flink.api.java.operators.CoGroupRawOperator
-
- getFunction() - Method in class org.apache.flink.api.java.operators.CrossOperator
-
- getFunction() - Method in class org.apache.flink.api.java.operators.CrossOperator.ProjectCross
-
- getFunction() - Method in class org.apache.flink.api.java.operators.FilterOperator
-
- getFunction() - Method in class org.apache.flink.api.java.operators.FlatMapOperator
-
- getFunction() - Method in class org.apache.flink.api.java.operators.GroupCombineOperator
-
- getFunction() - Method in class org.apache.flink.api.java.operators.GroupReduceOperator
-
- getFunction() - Method in class org.apache.flink.api.java.operators.JoinOperator.EquiJoin
-
- getFunction() - Method in class org.apache.flink.api.java.operators.JoinOperator.ProjectJoin
-
- getFunction() - Method in class org.apache.flink.api.java.operators.MapOperator
-
- getFunction() - Method in class org.apache.flink.api.java.operators.MapPartitionOperator
-
- getFunction() - Method in class org.apache.flink.api.java.operators.ReduceOperator
-
- getFunction() - Method in class org.apache.flink.api.java.operators.SingleInputUdfOperator
-
- getFunction() - Method in class org.apache.flink.api.java.operators.TwoInputUdfOperator
-
- getFunctionName() - Method in class org.apache.flink.api.java.typeutils.MissingTypeInfo
-
- getFunctionRuntimeContext(Function, RuntimeContext) - Static method in class org.apache.flink.api.common.functions.util.FunctionUtils
-
- getFuture() - Method in class org.apache.flink.runtime.registration.RetryingRegistration
-
- getFuture() - Method in interface org.apache.flink.runtime.webmonitor.retriever.GatewayRetriever
-
Get future of object to retrieve.
- getFuture() - Method in class org.apache.flink.runtime.webmonitor.retriever.LeaderGatewayRetriever
-
- getFuture() - Method in class org.apache.flink.streaming.api.operators.async.queue.StreamElementQueueEntry
-
- getFuture() - Method in class org.apache.flink.streaming.api.operators.async.queue.StreamRecordQueueEntry
-
- getFuture() - Method in class org.apache.flink.streaming.api.operators.async.queue.WatermarkQueueEntry
-
- getFutureExecutor() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
Returns the ExecutionContext associated with this ExecutionGraph.
- getGarbageCollectorStatsAsString(List<GarbageCollectorMXBean>) - Static method in class org.apache.flink.runtime.taskmanager.MemoryLogger
-
Gets the garbage collection statistics from the JVM.
- getGatewayAddress() - Method in class org.apache.flink.table.client.config.Deployment
-
- getGatewayModeClientOptions(Options) - Static method in class org.apache.flink.table.client.cli.CliOptionsParser
-
- getGatewayModeGatewayOptions(Options) - Static method in class org.apache.flink.table.client.cli.CliOptionsParser
-
- getGatewayPort() - Method in class org.apache.flink.table.client.config.Deployment
-
- getGatherBcastVars() - Method in class org.apache.flink.graph.gsa.GSAConfiguration
-
Get the broadcast variables of the GatherFunction.
- getGatherBcastVars() - Method in class org.apache.flink.graph.spargel.ScatterGatherConfiguration
-
Get the broadcast variables of the GatherFunction.
- getGenericFieldTypes() - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
-
- getGenericParameters() - Method in class 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() - Method in class org.apache.flink.api.java.typeutils.EitherTypeInfo
-
- getGenericParameters() - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfo
-
- getGenericParameters() - Method in class org.apache.flink.graph.drivers.transform.LongValueWithProperHashCode.LongValueWithProperHashCodeTypeInfo
-
- getGenericParameters() - Method in class org.apache.flink.graph.types.valuearray.ValueArrayTypeInfo
-
- getGibiBytes() - Method in class org.apache.flink.configuration.MemorySize
-
Gets the memory size in Gibibytes (= 1024 Mebibytes).
- getGlobalClusteringCoefficientScore() - Method in class org.apache.flink.graph.library.clustering.directed.GlobalClusteringCoefficient.Result
-
Get the global clustering coefficient score.
- getGlobalClusteringCoefficientScore() - Method in class org.apache.flink.graph.library.clustering.undirected.GlobalClusteringCoefficient.Result
-
Get the global clustering coefficient score.
- getGlobalJobParameters() - Method in class org.apache.flink.api.common.ArchivedExecutionConfig
-
- getGlobalJobParameters() - Method in class org.apache.flink.api.common.ExecutionConfig
-
- getGlobalModificationTime() - Method in class org.apache.flink.streaming.api.functions.source.ContinuousFileMonitoringFunction
-
- getGlobalModVersion() - Method in class org.apache.flink.runtime.executiongraph.Execution
-
Gets the global modification version of the execution graph when this execution was created.
- getGlobalProperties() - Method in class org.apache.flink.optimizer.dataproperties.InterestingProperties
-
Gets the interesting global properties.
- getGlobalProperties() - Method in class org.apache.flink.optimizer.plan.Channel
-
- getGlobalProperties() - Method in class org.apache.flink.optimizer.plan.PlanNode
-
Gets the global properties from this PlanNode.
- getGlobalProperties() - Method in class org.apache.flink.table.explain.Node
-
- getGPUResource() - Method in class org.apache.flink.api.common.operators.ResourceSpec
-
- getGraph() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
- getGroupCombineReturnTypes(GroupCombineFunction<IN, OUT>, TypeInformation<IN>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
- getGroupCombineReturnTypes(GroupCombineFunction<IN, OUT>, TypeInformation<IN>, String, boolean) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
- getGroupedFields() - Method in class org.apache.flink.optimizer.dataproperties.LocalProperties
-
Gets the grouped fields.
- getGroupedFields() - Method in class org.apache.flink.optimizer.dataproperties.RequestedLocalProperties
-
Gets the grouped fields.
- getGroupID() - Method in class org.apache.flink.runtime.instance.Slot
-
Gets the ID that identifies the logical group to which this slot belongs:
If the slot does not belong to any group in particular, this field is null.
If this slot was allocated as a sub-slot of a
SlotSharingGroupAssignment
,
then this ID will be the JobVertexID of the vertex whose task the slot
holds in its shared slot.
In case that the slot represents the shared slot of a co-location constraint, this ID will be the
ID of the co-location constraint.
- getGroupId() - Method in class org.apache.flink.runtime.jobmanager.scheduler.CoLocationConstraint
-
Gets the ID that identifies the co-location group.
- getGroupId() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotSharingManager.TaskSlot
-
- getGroupName(CharacterFilter) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
-
Returns the name for this group, meaning what kind of entity it represents, for example "taskmanager".
- getGroupName(CharacterFilter) - Method in class org.apache.flink.runtime.metrics.groups.GenericMetricGroup
-
- getGroupName(CharacterFilter) - Method in class org.apache.flink.runtime.metrics.groups.JobManagerMetricGroup
-
- getGroupName(CharacterFilter) - Method in class org.apache.flink.runtime.metrics.groups.JobMetricGroup
-
- getGroupName(CharacterFilter) - Method in class org.apache.flink.runtime.metrics.groups.OperatorMetricGroup
-
- getGroupName(CharacterFilter) - Method in class org.apache.flink.runtime.metrics.groups.TaskManagerMetricGroup
-
- getGroupName(CharacterFilter) - Method in class org.apache.flink.runtime.metrics.groups.TaskMetricGroup
-
- getGroupOrder(int) - Method in class org.apache.flink.api.common.operators.base.CoGroupOperatorBase
-
Gets the value order for an input, i.e.
- getGroupOrder(int) - Method in class org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase
-
Gets the value order for an input, i.e.
- getGroupOrder() - Method in class org.apache.flink.api.common.operators.base.GroupCombineOperatorBase
-
Gets the order of elements within a reduce group.
- getGroupOrder() - Method in class org.apache.flink.api.common.operators.base.GroupReduceOperatorBase
-
Gets the order of elements within a reduce group.
- getGroupOrderForInputOne() - Method in class org.apache.flink.api.common.operators.base.CoGroupOperatorBase
-
Gets the order of elements within a group for the first input.
- getGroupOrderForInputOne() - Method in class org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase
-
Gets the order of elements within a group for the first input.
- getGroupOrderForInputTwo() - Method in class org.apache.flink.api.common.operators.base.CoGroupOperatorBase
-
Gets the order of elements within a group for the second input.
- getGroupOrderForInputTwo() - Method in class org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase
-
Gets the order of elements within a group for the second input.
- getGroupOrdering() - Method in class org.apache.flink.api.java.operators.SortedGrouping
-
- getGroupRangeOffsets() - Method in class org.apache.flink.runtime.state.KeyGroupsStateHandle
-
- getGroupReduceReturnTypes(GroupReduceFunction<IN, OUT>, TypeInformation<IN>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
- getGroupReduceReturnTypes(GroupReduceFunction<IN, OUT>, TypeInformation<IN>, String, boolean) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
- getGroupRepresentativeId() - Method in class org.apache.flink.graph.library.Summarization.VertexGroupItem
-
- getGroupRepresentativeId() - Method in class org.apache.flink.graph.library.Summarization.VertexWithRepresentative
-
- getGroupSize(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getGroupSortKeyPositions() - Method in class org.apache.flink.api.java.operators.SortedGrouping
-
- getGroupSortOrders() - Method in class org.apache.flink.api.java.operators.SortedGrouping
-
- getGuaranteedAvailableMemory() - Method in class org.apache.flink.optimizer.plan.PlanNode
-
- getHadoopConfiguration(Configuration) - Static method in class org.apache.flink.api.java.hadoop.mapred.utils.HadoopUtils
-
Returns a new Hadoop Configuration object using the path to the hadoop conf configured
in the main configuration (flink-conf.yaml).
- getHadoopConfiguration(Configuration) - Static method in class org.apache.flink.runtime.util.HadoopUtils
-
- getHadoopFileSystem() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileSystem
-
Gets the underlying Hadoop FileSystem.
- getHadoopInputSplit() - Method in class org.apache.flink.api.java.hadoop.mapred.wrapper.HadoopInputSplit
-
- getHadoopInputSplit() - Method in class org.apache.flink.api.java.hadoop.mapreduce.wrapper.HadoopInputSplit
-
- getHadoopInputStream() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopDataInputStream
-
Gets the wrapped Hadoop input stream.
- getHadoopOutputStream() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopDataOutputStream
-
Gets the wrapped Hadoop output stream.
- getHadoopServicePrincipal() - Static method in class org.apache.flink.test.util.SecureTestEnvironment
-
- getHadoopUser() - Static method in class org.apache.flink.runtime.util.EnvironmentInformation
-
Gets the name of the user that is running the JVM.
- getHadoopVersionString() - Static method in class org.apache.flink.runtime.util.EnvironmentInformation
-
- getHandleName() - Method in class org.apache.flink.runtime.state.memory.ByteStreamStateHandle
-
- getHandlers() - Method in enum org.apache.flink.runtime.webmonitor.WebMonitorExtension.EmptyWebMonitorExtension
-
- getHandlers() - Method in interface org.apache.flink.runtime.webmonitor.WebMonitorExtension
-
- getHandlers() - Method in class org.apache.flink.runtime.webmonitor.WebSubmissionExtension
-
- getHandshakeTimeoutMs() - Method in class org.apache.flink.runtime.net.SSLUtils.SSLContext
-
- getHardwareDescription() - Method in class org.apache.flink.runtime.resourcemanager.registration.WorkerRegistration
-
- getHardwareDescription() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerInfo
-
- getHash() - Method in class org.apache.flink.runtime.blob.BlobKey
-
Returns the hash component of this key.
- getHashJoin(TypeSerializer<BT>, TypeComparator<BT>, TypeSerializer<PT>, TypeComparator<PT>, TypePairComparator<PT, BT>, MemoryManager, IOManager, AbstractInvokable, double, boolean) - Method in class org.apache.flink.runtime.operators.hash.HashJoinIteratorBase
-
- getHashJoin(TypeSerializer<BT>, TypeComparator<BT>, TypeSerializer<PT>, TypeComparator<PT>, TypePairComparator<PT, BT>, MemoryManager, IOManager, AbstractInvokable, double, boolean) - Method in class org.apache.flink.runtime.operators.hash.NonReusingBuildFirstReOpenableHashJoinIterator
-
- getHashJoin(TypeSerializer<BT>, TypeComparator<BT>, TypeSerializer<PT>, TypeComparator<PT>, TypePairComparator<PT, BT>, MemoryManager, IOManager, AbstractInvokable, double, boolean) - Method in class org.apache.flink.runtime.operators.hash.NonReusingBuildSecondReOpenableHashJoinIterator
-
- getHashJoin(TypeSerializer<BT>, TypeComparator<BT>, TypeSerializer<PT>, TypeComparator<PT>, TypePairComparator<PT, BT>, MemoryManager, IOManager, AbstractInvokable, double, boolean) - Method in class org.apache.flink.runtime.operators.hash.ReusingBuildFirstReOpenableHashJoinIterator
-
- getHashJoin(TypeSerializer<BT>, TypeComparator<BT>, TypeSerializer<PT>, TypeComparator<PT>, TypePairComparator<PT, BT>, MemoryManager, IOManager, AbstractInvokable, double, boolean) - Method in class org.apache.flink.runtime.operators.hash.ReusingBuildSecondReOpenableHashJoinIterator
-
- getHeaderLines() - Method in class org.apache.flink.table.client.cli.CliView
-
- getHeadOperator() - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
-
- getHeapMemory() - Method in class org.apache.flink.api.common.operators.ResourceSpec
-
- getHeapMemoryInMB() - Method in class org.apache.flink.runtime.clusterframework.types.ResourceProfile
-
Get the heap memory needed in MB.
- getHeartbeatInterval() - Method in class org.apache.flink.runtime.jobmaster.JobMasterRegistrationSuccess
-
Gets the interval in which the ResourceManager will heartbeat the JobMaster.
- getHeartbeatInterval() - Method in class org.apache.flink.runtime.resourcemanager.ResourceManagerConfiguration
-
- getHeartbeatInterval() - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorRegistrationSuccess
-
Gets the interval in which the ResourceManager will heartbeat the TaskExecutor.
- getHeight() - Method in class org.apache.flink.table.client.cli.CliClient
-
- getHeight() - Method in class org.apache.flink.table.client.cli.CliView
-
- getHelp() - Method in class org.apache.flink.api.java.utils.RequiredParameters
-
Build a help text for the defined parameters.
- getHelp(List<String>) - Method in class org.apache.flink.api.java.utils.RequiredParameters
-
Build a help text for the defined parameters and list the missing arguments at the end of the text.
- getHelpText() - Method in class org.apache.flink.api.java.utils.Option
-
- getHeuristicCpuCost() - Method in class org.apache.flink.optimizer.costs.Costs
-
Gets the heuristic cost for the CPU.
- getHeuristicDiskCost() - Method in class org.apache.flink.optimizer.costs.Costs
-
Gets the heuristic costs for disk.
- getHeuristicNetworkCost() - Method in class org.apache.flink.optimizer.costs.Costs
-
Gets the heuristic network cost.
- getHighAvailabilityServices() - Method in class org.apache.flink.runtime.minicluster.MiniCluster
-
- getHistogram(String) - Method in interface org.apache.flink.api.common.functions.RuntimeContext
-
Convenience function to create a counter object for histograms.
- getHistogram(String) - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
-
- getHistory() - Method in class org.apache.flink.runtime.checkpoint.CheckpointStatsSnapshot
-
Returns the snapshotted checkpoint history.
- getHistory() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics
-
- getHomeDirectory() - Method in class org.apache.flink.core.fs.FileSystem
-
Returns the path of the user's home directory in this file system.
- getHomeDirectory() - Method in class org.apache.flink.core.fs.LimitedConnectionsFileSystem
-
- getHomeDirectory() - Method in class org.apache.flink.core.fs.local.LocalFileSystem
-
- getHomeDirectory() - Method in class org.apache.flink.core.fs.SafetyNetWrapperFileSystem
-
- getHomeDirectory() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileSystem
-
- getHost() - Method in class org.apache.flink.metrics.datadog.DMetric
-
- getHost() - Method in class org.apache.flink.runtime.jobmanager.JobManagerCliOptions
-
- getHost() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsInfo
-
- getHost() - Method in class org.apache.flink.streaming.api.environment.RemoteStreamEnvironment
-
Gets the hostname of the master (JobManager), where the
program will be executed.
- getHost() - Method in class org.apache.flink.streaming.connectors.rabbitmq.common.RMQConnectionConfig
-
- getHostname() - Method in class org.apache.flink.runtime.akka.AkkaJobManagerGateway
-
- getHostname() - Method in class org.apache.flink.runtime.entrypoint.ClusterConfiguration
-
- getHostname() - Method in class org.apache.flink.runtime.minicluster.StandaloneMiniCluster
-
- getHostname() - Method in class org.apache.flink.runtime.rpc.RpcEndpoint
-
Gets the hostname of the underlying RPC endpoint.
- getHostname() - Method in interface org.apache.flink.runtime.rpc.RpcGateway
-
Returns the fully qualified hostname under which the associated rpc endpoint is reachable.
- getHostname() - Method in class org.apache.flink.runtime.taskmanager.TaskManagerLocation
-
Gets the hostname of the TaskManager.
- getHostname() - Method in class org.apache.flink.runtime.util.LeaderConnectionInfo
-
- getHostnameFromFQDN(String) - Static method in class org.apache.flink.util.NetUtils
-
Turn a fully qualified domain name (fqdn) into a hostname.
- getHostnames() - Method in class org.apache.flink.api.java.hadoop.mapred.wrapper.HadoopInputSplit
-
- getHostnames() - Method in class org.apache.flink.api.java.hadoop.mapreduce.wrapper.HadoopInputSplit
-
- getHostnames() - Method in class org.apache.flink.core.io.LocatableInputSplit
-
Returns the names of the hosts storing the data this input split refers to
- getHosts() - Method in interface org.apache.flink.core.fs.BlockLocation
-
Get the list of hosts (hostname) hosting this block.
- getHosts() - Method in class org.apache.flink.core.fs.local.LocalBlockLocation
-
- getHosts() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopBlockLocation
-
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingStatusHeaders
-
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingTriggerHeaders
-
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.handler.legacy.files.LogFileHandlerSpecification
-
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.handler.legacy.files.StdoutFileHandlerSpecification
-
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.handler.legacy.files.WebContentHandlerSpecification
-
- getHttpMethod() - Method in interface org.apache.flink.runtime.rest.handler.RestHandlerSpecification
-
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigHeaders
-
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatisticsHeaders
-
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatisticDetailsHeaders
-
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsHeaders
-
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.cluster.ShutdownHeaders
-
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.ClusterConfigurationInfoHeaders
-
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.ClusterOverviewHeaders
-
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.DashboardConfigurationHeaders
-
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsHeaders
-
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.job.JobExecutionResultHeaders
-
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.job.JobSubmitHeaders
-
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AbstractAggregatedMetricsHeaders
-
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AbstractMetricsHeaders
-
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalStatusHeaders
-
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalTriggerHeaders
-
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointStatusHeaders
-
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointTriggerHeaders
-
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskCurrentAttemptDetailsHeaders
-
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptAccumulatorsHeaders
-
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsHeaders
-
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.JobAccumulatorsHeaders
-
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.JobConfigHeaders
-
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.JobExceptionsHeaders
-
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.JobIdsWithStatusesOverviewHeaders
-
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.JobPlanHeaders
-
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.JobsOverviewHeaders
-
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.JobTerminationHeaders
-
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.JobVertexAccumulatorsHeaders
-
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.JobVertexBackPressureHeaders
-
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.JobVertexDetailsHeaders
-
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.JobVertexTaskManagersHeaders
-
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.SubtasksAllAccumulatorsHeaders
-
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.SubtasksTimesHeaders
-
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerDetailsHeaders
-
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerLogFileHeaders
-
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagersHeaders
-
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerStdoutFileHeaders
-
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.YarnCancelJobTerminationHeaders
-
Deprecated.
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.YarnStopJobTerminationHeaders
-
Deprecated.
- getHttpMethod() - Method in class org.apache.flink.runtime.webmonitor.handlers.JarDeleteHeaders
-
- getHttpMethod() - Method in class org.apache.flink.runtime.webmonitor.handlers.JarListHeaders
-
- getHttpMethod() - Method in class org.apache.flink.runtime.webmonitor.handlers.JarPlanHeaders
-
- getHttpMethod() - Method in class org.apache.flink.runtime.webmonitor.handlers.JarRunHeaders
-
- getHttpMethod() - Method in class org.apache.flink.runtime.webmonitor.handlers.JarUploadHeaders
-
- getHttpResponseStatus() - Method in exception org.apache.flink.runtime.rest.handler.RestHandlerException
-
- getHttpResponseStatus() - Method in exception org.apache.flink.runtime.rest.util.RestClientException
-
- getHubScore() - Method in class org.apache.flink.graph.library.linkanalysis.HITS.Result
-
Get the hub score.
- getId() - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
Gets the JobID by which this environment is identified.
- getId() - Method in enum org.apache.flink.api.java.sca.TaggedValue.Input
-
- getId() - Method in interface org.apache.flink.client.cli.CustomCommandLine
-
Gets the unique identifier of this CustomCommandLine.
- getId() - Method in class org.apache.flink.client.cli.DefaultCLI
-
- getId() - Method in class org.apache.flink.client.cli.LegacyCLI
-
- getId() - Method in class org.apache.flink.graph.Vertex
-
- getId() - Method in class org.apache.flink.mesos.scheduler.Offer
-
- getId() - Method in class org.apache.flink.optimizer.dag.OptimizerNode
-
Gets the ID of this node.
- getId() - Method in class org.apache.flink.runtime.executiongraph.IntermediateResult
-
- getId() - Method in class org.apache.flink.runtime.instance.Instance
-
- getId() - Method in class org.apache.flink.runtime.io.network.api.CheckpointBarrier
-
- getId() - Method in class org.apache.flink.runtime.jobgraph.IntermediateDataSet
-
- getID() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
Returns the ID of this job vertex.
- getId() - Method in class org.apache.flink.runtime.jobmanager.scheduler.CoLocationGroup
-
Gets the ID that identifies this co-location group.
- getId() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.RestoredCheckpointStatistics
-
- getId() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
-
- getId() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedMetric
-
- getId() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.Metric
-
- getId() - Method in class org.apache.flink.runtime.rest.messages.queue.QueueStatus
-
- getID() - Method in class org.apache.flink.runtime.taskmanager.TaskExecutionState
-
Returns the ID of the task this result belongs to
- getId() - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
- getId() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getId() - Method in class org.apache.flink.streaming.api.transformations.StreamTransformation
-
Returns the unique ID of this StreamTransformation
.
- getId() - Method in class org.apache.flink.table.explain.Node
-
- getId() - Method in class org.apache.flink.util.OutputTag
-
- getId() - Method in class org.apache.flink.yarn.cli.FlinkYarnSessionCli
-
- getIdAlternatives() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
Returns a list of all alternative IDs of this job vertex.
- getIdentifier() - Method in interface org.apache.flink.runtime.checkpoint.MasterTriggerRestoreHook
-
Gets the identifier of this hook.
- getIdentity() - Method in class org.apache.flink.graph.drivers.input.CirculantGraph
-
- getIdentity() - Method in class org.apache.flink.graph.drivers.input.CompleteGraph
-
- getIdentity() - Method in class org.apache.flink.graph.drivers.input.CSV
-
- getIdentity() - Method in class org.apache.flink.graph.drivers.input.CycleGraph
-
- getIdentity() - Method in class org.apache.flink.graph.drivers.input.EchoGraph
-
- getIdentity() - Method in class org.apache.flink.graph.drivers.input.EmptyGraph
-
- getIdentity() - Method in class org.apache.flink.graph.drivers.input.GridGraph
-
- getIdentity() - Method in class org.apache.flink.graph.drivers.input.HypercubeGraph
-
- getIdentity() - Method in interface org.apache.flink.graph.drivers.input.Input
-
A human-readable identifier summarizing the input and configuration.
- getIdentity() - Method in class org.apache.flink.graph.drivers.input.PathGraph
-
- getIdentity() - Method in class org.apache.flink.graph.drivers.input.RMatGraph
-
- getIdentity() - Method in class org.apache.flink.graph.drivers.input.SingletonEdgeGraph
-
- getIdentity() - Method in class org.apache.flink.graph.drivers.input.StarGraph
-
- getIdentity() - Method in class org.apache.flink.graph.drivers.transform.GraphKeyTypeTransform
-
- getIdentity() - Method in interface org.apache.flink.graph.drivers.transform.Transform
-
A human-readable identifier summarizing the transform and configuration.
- getIdlenessTimeout() - Method in class org.apache.flink.runtime.rest.RestClientConfiguration
-
- getIdleSince() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerRegistration
-
- getIdString() - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
Gets the JobID by which this environment is identified, as a string.
- getImplicitConvergenceCriterion(ClassLoader) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getImplicitConvergenceCriterionAggregatorName() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getIncomingConnection() - Method in class org.apache.flink.optimizer.dag.SingleInputNode
-
Gets the input of this operator.
- getIncomingConnections() - Method in class org.apache.flink.optimizer.dag.AbstractPartialSolutionNode
-
- getIncomingConnections() - Method in class org.apache.flink.optimizer.dag.DataSinkNode
-
- getIncomingConnections() - Method in class org.apache.flink.optimizer.dag.DataSourceNode
-
- getIncomingConnections() - Method in class org.apache.flink.optimizer.dag.OptimizerNode
-
Gets all incoming connections of this node.
- getIncomingConnections() - Method in class org.apache.flink.optimizer.dag.SingleInputNode
-
- getIncomingConnections() - Method in class org.apache.flink.optimizer.dag.TwoInputNode
-
- getInDegree() - Method in class org.apache.flink.graph.asm.degree.annotate.directed.VertexDegrees.Degrees
-
- getInDegree() - Method in class org.apache.flink.graph.spargel.GatherFunction
-
Retrieves the vertex in-degree (number of in-coming edges).
- getInDegree() - Method in class org.apache.flink.graph.spargel.ScatterFunction
-
Retrieves the vertex in-degree (number of in-coming edges).
- getIndex() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics
-
- getIndex() - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlot
-
- getIndexInSubtaskGroup() - Method in class org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
-
Returns the index of this subtask in the subtask group.
- getIndexOfThisSubtask() - Method in interface org.apache.flink.api.common.functions.RuntimeContext
-
Gets the number of this parallel subtask.
- getIndexOfThisSubtask() - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
-
- getIndexOfThisSubtask() - Method in class org.apache.flink.api.common.TaskInfo
-
Gets the number of this parallel subtask.
- getInEdgeIndices() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getInEdges() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getInfinityCount() - Method in class org.apache.flink.api.java.summarize.NumericColumnSummary
-
Number of values that are positive or negative infinity.
- getInflaterInputStreamFactory(String) - Static method in class org.apache.flink.api.common.io.FileInputFormat
-
- getInfoFor(Class<X>) - Static method in class org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
-
- getInfoFor(Class<X>) - Static method in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
-
- getInfoFor(Class<X>) - Static method in class org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
-
Tries to get the PrimitiveArrayTypeInfo for an array.
- getInfoFor(Class<X>) - Static method in class org.apache.flink.api.common.typeinfo.SqlTimeTypeInfo
-
- getInfoFor(TypeInformation<C>) - Static method in class org.apache.flink.api.java.typeutils.MultisetTypeInfo
-
- getInfoFor(Class<T>, TypeInformation<C>) - Static method in class org.apache.flink.api.java.typeutils.ObjectArrayTypeInfo
-
- getInfoFor(TypeInformation<C>) - Static method in class org.apache.flink.api.java.typeutils.ObjectArrayTypeInfo
-
- getInfoForCurrentThread() - Method in class org.apache.flink.runtime.query.KvStateEntry
-
- getInfoSize() - Method in class org.apache.flink.api.common.io.BlockInfo
-
- getInitialCredit() - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
-
- getInitialRegistrationPause() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
-
- getInitialSolutionSet() - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase
-
Returns the initial solution set input, or null, if none is set.
- getInitialSolutionSet() - Method in class org.apache.flink.api.java.operators.DeltaIteration
-
Gets the initial solution set.
- getInitialSolutionSetInput() - Method in class org.apache.flink.optimizer.plan.WorksetIterationPlanNode
-
- getInitialSolutionSetPredecessorNode() - Method in class org.apache.flink.optimizer.dag.WorksetIterationNode
-
- getInitialTableSize(int, int, int, int) - Static method in class org.apache.flink.runtime.operators.hash.MutableHashTable
-
- getInitialWorkset() - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase
-
Returns the initial workset input, or null, if none is set.
- getInitialWorkset() - Method in class org.apache.flink.api.java.operators.DeltaIteration
-
Gets the initial workset.
- getInitialWorksetInput() - Method in class org.apache.flink.optimizer.plan.WorksetIterationPlanNode
-
- getInitialWorksetPredecessorNode() - Method in class org.apache.flink.optimizer.dag.WorksetIterationNode
-
- getInnerConsumingStrategy() - Method in class org.apache.flink.cep.pattern.Quantifier
-
- getInnerPayLoad() - Method in class org.apache.flink.streaming.tests.artificialstate.ComplexPayload
-
- getInPhysicalEdges(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getInProgressHandler() - Method in class org.apache.flink.runtime.rest.handler.legacy.JobCancellationWithSavepointHandlers
-
- getInput() - Method in class org.apache.flink.api.common.operators.GenericDataSinkBase
-
Returns this operator's input operator.
- getInput() - Method in class org.apache.flink.api.common.operators.SingleInputOperator
-
Returns the input operator or data source, or null, if none is set.
- getInput() - Method in class org.apache.flink.api.java.operators.NoOpOperator
-
- getInput() - Method in class org.apache.flink.api.java.operators.SingleInputOperator
-
Gets the data set that this operation uses as its input.
- getInput() - Method in class org.apache.flink.api.java.sca.TaggedValue
-
- getInput() - Method in class org.apache.flink.optimizer.plan.SingleInputPlanNode
-
Gets the input channel to this node.
- getInput(int) - Method in class org.apache.flink.runtime.operators.BatchTask
-
- getInput(int) - Method in interface org.apache.flink.runtime.operators.TaskContext
-
- getInput() - Method in class org.apache.flink.streaming.api.transformations.FeedbackTransformation
-
Returns the input StreamTransformation
of this FeedbackTransformation
.
- getInput() - Method in class org.apache.flink.streaming.api.transformations.OneInputTransformation
-
Returns the input StreamTransformation
of this OneInputTransformation
.
- getInput() - Method in class org.apache.flink.streaming.api.transformations.PartitionTransformation
-
Returns the input StreamTransformation
of this SinkTransformation
.
- getInput() - Method in class org.apache.flink.streaming.api.transformations.SelectTransformation
-
Returns the input StreamTransformation
.
- getInput() - Method in class org.apache.flink.streaming.api.transformations.SideOutputTransformation
-
Returns the input StreamTransformation
.
- getInput() - Method in class org.apache.flink.streaming.api.transformations.SinkTransformation
-
Returns the input StreamTransformation
of this SinkTransformation
.
- getInput() - Method in class org.apache.flink.streaming.api.transformations.SplitTransformation
-
Returns the input StreamTransformation
.
- getInput1() - Method in class org.apache.flink.api.java.operators.TwoInputOperator
-
Gets the data set that this operation uses as its first input.
- getInput1() - Method in class org.apache.flink.optimizer.plan.DualInputPlanNode
-
Gets the first input channel to this node.
- getInput1() - Method in class org.apache.flink.streaming.api.transformations.TwoInputTransformation
-
Returns the first input StreamTransformation
of this TwoInputTransformation
.
- getInput1AsTaggedValue() - Method in class org.apache.flink.api.java.sca.UdfAnalyzer
-
- getInput1Type() - Method in class org.apache.flink.api.java.operators.TwoInputOperator
-
Gets the type information of the data type of the first input data set.
- getInput2() - Method in class org.apache.flink.api.java.operators.TwoInputOperator
-
Gets the data set that this operation uses as its second input.
- getInput2() - Method in class org.apache.flink.optimizer.plan.DualInputPlanNode
-
Gets the second input channel to this node.
- getInput2() - Method in class org.apache.flink.streaming.api.transformations.TwoInputTransformation
-
Returns the first input StreamTransformation
of this TwoInputTransformation
.
- getInput2AsTaggedValue() - Method in class org.apache.flink.api.java.sca.UdfAnalyzer
-
- getInput2Type() - Method in class org.apache.flink.api.java.operators.TwoInputOperator
-
Gets the type information of the data type of the second input data set.
- getInputChannelDeploymentDescriptor() - Method in class org.apache.flink.runtime.executiongraph.PartitionInfo
-
- getInputChannelDeploymentDescriptors() - Method in class org.apache.flink.runtime.deployment.InputGateDeploymentDescriptor
-
- getInputChannelId() - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
-
- getInputChannelStatus(int) - Method in class org.apache.flink.streaming.runtime.streamstatus.StatusWatermarkValve
-
- getInputComparator(int, ClassLoader) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getInputConnection() - Method in class org.apache.flink.optimizer.dag.DataSinkNode
-
Gets the input of the sink.
- getInputDataSet() - Method in class org.apache.flink.api.java.operators.Grouping
-
Returns the input DataSet of a grouping operation, that is the one before the grouping.
- getInputEdges(int) - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- getInputFormat() - Method in class org.apache.flink.api.java.operators.DataSource
-
Gets the input format that is executed by this data source.
- getInputFormat() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getInputFormatTypes(InputFormat<IN, ?>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
- getInputGate(int) - Method in interface org.apache.flink.runtime.execution.Environment
-
- getInputGate(int) - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
-
- getInputGateById(IntermediateDataSetID) - Method in class org.apache.flink.runtime.taskmanager.Task
-
- getInputGates() - Method in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
-
- getInputLocalStrategy(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getInputNum() - Method in class org.apache.flink.runtime.executiongraph.ExecutionEdge
-
- getInputs() - Method in class org.apache.flink.optimizer.plan.BulkPartialSolutionPlanNode
-
- getInputs() - Method in class org.apache.flink.optimizer.plan.DualInputPlanNode
-
- getInputs() - Method in class org.apache.flink.optimizer.plan.NAryUnionPlanNode
-
- getInputs() - Method in class org.apache.flink.optimizer.plan.PlanNode
-
- getInputs() - Method in class org.apache.flink.optimizer.plan.SingleInputPlanNode
-
- getInputs() - Method in class org.apache.flink.optimizer.plan.SolutionSetPlanNode
-
- getInputs() - Method in class org.apache.flink.optimizer.plan.SourcePlanNode
-
- getInputs() - Method in class org.apache.flink.optimizer.plan.WorksetPlanNode
-
- getInputs() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
- getInputs() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
- getInputs() - Method in class org.apache.flink.streaming.api.transformations.UnionTransformation
-
Returns the list of input StreamTransformations
.
- getInputSerializer(int) - Method in class org.apache.flink.runtime.operators.BatchTask
-
- getInputSerializer(int) - Method in interface org.apache.flink.runtime.operators.TaskContext
-
- getInputSerializer(int, ClassLoader) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getInputSplit() - Method in class org.apache.flink.api.java.hadoop.mapred.wrapper.HadoopDummyReporter
-
- getInputSplitAssigner(TableInputSplit[]) - Method in class org.apache.flink.addons.hbase.AbstractTableInputFormat
-
- getInputSplitAssigner(FileInputSplit[]) - Method in class org.apache.flink.api.common.io.FileInputFormat
-
- getInputSplitAssigner(GenericInputSplit[]) - Method in class org.apache.flink.api.common.io.GenericInputFormat
-
- getInputSplitAssigner(T[]) - Method in interface org.apache.flink.api.common.io.InputFormat
-
Gets the type of the input splits that are processed by this input format.
- getInputSplitAssigner(S[]) - Method in class org.apache.flink.api.common.io.ReplicatingInputFormat
-
- getInputSplitAssigner(HadoopInputSplit[]) - Method in class org.apache.flink.api.java.hadoop.mapred.HadoopInputFormatBase
-
- getInputSplitAssigner(HadoopInputSplit[]) - Method in class org.apache.flink.api.java.hadoop.mapreduce.HadoopInputFormatBase
-
- getInputSplitAssigner(InputSplit[]) - Method in class org.apache.flink.api.java.io.jdbc.JDBCInputFormat
-
- getInputSplitAssigner(InputSplit[]) - Method in class org.apache.flink.batch.connectors.cassandra.CassandraInputFormat
-
- getInputSplitAssigner(GenericInputSplit[]) - Method in class org.apache.flink.batch.tests.DataSetAllroundTestProgram.Generator
-
- getInputSplitAssigner(T[]) - Method in interface org.apache.flink.core.io.InputSplitSource
-
Returns the assigner for the input splits.
- getInputSplitAssigner(FileCopyTaskInputSplit[]) - Method in class org.apache.flink.examples.java.distcp.FileCopyTaskInputFormat
-
- getInputSplitAssigner(HadoopInputSplit[]) - Method in class org.apache.flink.hcatalog.HCatInputFormatBase
-
- getInputSplitData() - Method in class org.apache.flink.runtime.jobmaster.SerializedInputSplit
-
- getInputSplitProvider() - Method in interface org.apache.flink.runtime.execution.Environment
-
Returns the input split provider assigned to this environment.
- getInputSplitProvider() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
-
- getInputSplitProvider() - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
-
Returns the input split provider associated with the operator.
- getInputSplits() - Method in class org.apache.flink.api.common.io.BinaryInputFormat
-
- getInputSplitSource() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
- getInputStream() - Method in class org.apache.flink.cep.PatternStream
-
- getInputType() - Method in class org.apache.flink.api.common.operators.Keys.SelectorFunctionKeys
-
- getInputType() - Method in class org.apache.flink.api.common.operators.UnaryOperatorInformation
-
- getInputType() - Method in class org.apache.flink.api.java.operators.SingleInputOperator
-
Gets the type information of the data type of the input data set.
- getInputType() - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
- getInputType() - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
- getInputType() - Method in class org.apache.flink.streaming.api.transformations.OneInputTransformation
-
Returns the TypeInformation
for the elements of the input.
- getInputType1() - Method in class org.apache.flink.streaming.api.transformations.TwoInputTransformation
-
Returns the TypeInformation
for the elements from the first input.
- getInputType2() - Method in class org.apache.flink.streaming.api.transformations.TwoInputTransformation
-
Returns the TypeInformation
for the elements from the first input.
- getInputView() - Method in class org.apache.flink.api.java.typeutils.runtime.DataInputViewStream
-
- getInstalledContext() - Static method in class org.apache.flink.runtime.security.SecurityUtils
-
- getInstalledModules() - Static method in class org.apache.flink.runtime.security.SecurityUtils
-
- getInstance() - Static method in class org.apache.flink.api.common.io.compression.Bzip2InputStreamFactory
-
- getInstance() - Static method in class org.apache.flink.api.common.io.compression.DeflateInflaterInputStreamFactory
-
- getInstance() - Static method in class org.apache.flink.api.common.io.compression.GzipInflaterInputStreamFactory
-
- getInstance() - Static method in class org.apache.flink.api.common.io.compression.XZInputStreamFactory
-
- getInstance() - Static method in class org.apache.flink.api.common.typeutils.base.NullValueComparator
-
- getInstance() - Static method in class org.apache.flink.client.deployment.StandaloneClusterId
-
- getInstance() - Static method in class org.apache.flink.runtime.blob.VoidBlobWriter
-
- getInstance() - Static method in class org.apache.flink.runtime.clusterframework.messages.GetClusterStatus
-
Gets the singleton instance.
- getInstance() - Static method in class org.apache.flink.runtime.clusterframework.messages.RegisterInfoMessageListener
-
Gets the singleton instance.
- getInstance() - Static method in class org.apache.flink.runtime.clusterframework.messages.StopClusterSuccessful
-
- getInstance() - Method in exception org.apache.flink.runtime.instance.InstanceDiedException
-
- getInstance(ResourceID) - Method in class org.apache.flink.runtime.jobmanager.scheduler.Scheduler
-
- getInstance() - Static method in class org.apache.flink.runtime.jobmaster.slotpool.LocationPreferenceSchedulingStrategy
-
- getInstance() - Static method in class org.apache.flink.runtime.jobmaster.slotpool.PreviousAllocationSchedulingStrategy
-
- getInstance() - Static method in class org.apache.flink.runtime.messages.webmonitor.RequestJobsOverview
-
- getInstance() - Static method in class org.apache.flink.runtime.messages.webmonitor.RequestJobsWithIDsOverview
-
- getInstance() - Static method in class org.apache.flink.runtime.messages.webmonitor.RequestStatusOverview
-
- getInstance() - Method in interface org.apache.flink.runtime.plugable.DeserializationDelegate
-
- getInstance() - Method in class org.apache.flink.runtime.plugable.NonReusingDeserializationDelegate
-
- getInstance() - Method in class org.apache.flink.runtime.plugable.ReusingDeserializationDelegate
-
- getInstance() - Method in class org.apache.flink.runtime.plugable.SerializationDelegate
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingStatusHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingTriggerHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.handler.legacy.files.LogFileHandlerSpecification
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.handler.legacy.files.StdoutFileHandlerSpecification
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.handler.legacy.files.WebContentHandlerSpecification
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatisticsHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatisticDetailsHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.cluster.ShutdownHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.ClusterConfigurationInfoHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.ClusterOverviewHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.DashboardConfigurationHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.EmptyMessageParameters
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.EmptyRequestBody
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.EmptyResponseBody
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.job.JobDetailsHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.job.JobExecutionResultHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.job.JobSubmitHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedJobMetricsHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedSubtaskMetricsHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedTaskManagerMetricsHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.job.metrics.JobManagerMetricsHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.job.metrics.JobMetricsHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.job.metrics.JobVertexMetricsHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.job.metrics.SubtaskMetricsHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.job.metrics.TaskManagerMetricsHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalStatusHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalTriggerHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointStatusHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointTriggerHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.job.SubtaskCurrentAttemptDetailsHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptAccumulatorsHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.JobAccumulatorsHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.JobConfigHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.JobExceptionsHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.JobIdsWithStatusesOverviewHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.JobPlanHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.JobsOverviewHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.JobTerminationHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.JobVertexAccumulatorsHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.JobVertexBackPressureHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.JobVertexDetailsHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.JobVertexTaskManagersHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.SubtasksAllAccumulatorsHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.SubtasksTimesHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerDetailsHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerLogFileHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagersHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerStdoutFileHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.YarnCancelJobTerminationHeaders
-
Deprecated.
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.YarnStopJobTerminationHeaders
-
Deprecated.
- getInstance() - Static method in class org.apache.flink.runtime.util.clock.SystemClock
-
- getInstance() - Static method in class org.apache.flink.runtime.webmonitor.handlers.JarDeleteHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.webmonitor.handlers.JarListHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.webmonitor.handlers.JarPlanHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.webmonitor.handlers.JarRunHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.webmonitor.handlers.JarUploadHeaders
-
- getInstance() - Static method in class org.apache.flink.types.NullValue
-
Returns the NullValue singleton instance.
- getInstanceBasePath() - Method in class org.apache.flink.contrib.streaming.state.RocksDBKeyedStateBackend
-
Only visible for testing, DO NOT USE.
- getInstanceId() - Method in class org.apache.flink.runtime.clusterframework.types.TaskManagerSlot
-
- getInstanceId() - Method in class org.apache.flink.runtime.messages.StackTrace
-
- getInstanceID() - Method in class org.apache.flink.runtime.resourcemanager.registration.TaskExecutorConnection
-
- getInstanceId() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerRegistration
-
- getInstances(String, Class<U>) - Method in class org.apache.hadoop.conf.Configuration
-
Get the value of the name
property as a List
of objects implementing the interface specified by xface
.
- getInstancesByHost() - Method in class org.apache.flink.runtime.jobmanager.scheduler.Scheduler
-
- getInt(String) - Method in class org.apache.flink.api.java.utils.ParameterTool
-
Returns the Integer value for the given key.
- getInt(String, int) - Method in class org.apache.flink.api.java.utils.ParameterTool
-
Returns the Integer value for the given key.
- getInt(int) - Method in class org.apache.flink.core.memory.MemorySegment
-
Reads an int value (32bit, 4 bytes) from the given position, in the system's native byte order.
- getInt(Properties, String, int) - Static method in class org.apache.flink.util.PropertiesUtil
-
Get integer from properties.
- getInt(String, int) - Method in class org.apache.hadoop.conf.Configuration
-
Get the value of the name
property as an int
.
- getIntBigEndian(int) - Method in class org.apache.flink.core.memory.MemorySegment
-
Reads an int value (32bit, 4 bytes) from the given position, in big-endian byte order.
- getIntConstant() - Method in class org.apache.flink.api.java.sca.TaggedValue
-
- getIntCounter(String) - Method in interface org.apache.flink.api.common.functions.RuntimeContext
-
Convenience function to create a counter object for integers.
- getIntCounter(String) - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
-
- getIntCounterResult(String) - Method in class org.apache.flink.api.common.JobExecutionResult
-
- getIntCounterResult(String) - Method in class org.apache.flink.client.program.DetachedEnvironment.DetachedJobExecutionResult
-
- getInteger(String, int) - Method in class org.apache.flink.configuration.Configuration
-
Returns the value associated with the given key as an integer.
- getInteger(ConfigOption<Integer>) - Method in class org.apache.flink.configuration.Configuration
-
Returns the value associated with the given config option as an integer.
- getInteger(ConfigOption<Integer>, int) - Method in class org.apache.flink.configuration.Configuration
-
Returns the value associated with the given config option as an integer.
- getInteger(String, int) - Method in class org.apache.flink.configuration.DelegatingConfiguration
-
- getInteger(ConfigOption<Integer>) - Method in class org.apache.flink.configuration.DelegatingConfiguration
-
- getInteger(ConfigOption<Integer>, int) - Method in class org.apache.flink.configuration.DelegatingConfiguration
-
- getInteger(String, int) - Method in class org.apache.flink.metrics.MetricConfig
-
Searches for the property with the specified key in this property list.
- getInteger(int) - Method in class org.apache.flink.storm.wrappers.StormTuple
-
- getIntegerByField(String) - Method in class org.apache.flink.storm.wrappers.StormTuple
-
- getInterestingProperties() - Method in class org.apache.flink.optimizer.dag.DagConnection
-
Gets the interesting properties object for this pact connection.
- getInterestingProperties() - Method in class org.apache.flink.optimizer.dag.OptimizerNode
-
Gets the properties that are interesting for this node to produce.
- getIntermediateDataSetID() - Method in class org.apache.flink.runtime.executiongraph.PartitionInfo
-
- getIntermediateResult() - Method in class org.apache.flink.runtime.executiongraph.IntermediateResultPartition
-
- getIntermediateVertexId() - Method in class org.apache.flink.graph.bipartite.Projection
-
- getIntermediateVertexValue() - Method in class org.apache.flink.graph.bipartite.Projection
-
- getInternalFileStatus() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileStatus
-
- getInternalTimerService(String, TypeSerializer<N>, Triggerable<K, N>) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
Returns a
InternalTimerService
that can be used to query current processing time
and event time and to set timers.
- getInternalTimerService(String, TypeSerializer<K>, TypeSerializer<N>, Triggerable<K, N>) - Method in class org.apache.flink.streaming.api.operators.InternalTimeServiceManager
-
Returns a
InternalTimerService
that can be used to query current processing time
and event time and to set timers.
- getInternalUdfClassName() - Method in class org.apache.flink.api.java.sca.UdfAnalyzer
-
- getIntersection(KeyGroupRange) - Method in class org.apache.flink.runtime.state.DirectoryKeyedStateHandle
-
- getIntersection(KeyGroupRange) - Method in class org.apache.flink.runtime.state.IncrementalKeyedStateHandle
-
- getIntersection(KeyGroupRange) - Method in interface org.apache.flink.runtime.state.KeyedStateHandle
-
Returns a state over a range that is the intersection between this
handle's key-group range and the provided key-group range.
- getIntersection(KeyGroupRange) - Method in class org.apache.flink.runtime.state.KeyGroupRange
-
Create a range that represent the intersection between this range and the given range.
- getIntersection(KeyGroupRange) - Method in class org.apache.flink.runtime.state.KeyGroupRangeOffsets
-
Returns a key-group range with offsets which is the intersection of the internal key-group range with the given
key-group range.
- getIntersection(KeyGroupRange) - Method in class org.apache.flink.runtime.state.KeyGroupsStateHandle
-
- getInterval() - Method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousEventTimeTrigger
-
- getInterval() - Method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousProcessingTimeTrigger
-
- getIntLittleEndian(int) - Method in class org.apache.flink.core.memory.MemorySegment
-
Reads an int value (32bit, 4 bytes) from the given position, in little-endian byte order.
- getInts(String) - Method in class org.apache.hadoop.conf.Configuration
-
Get the value of the name
property as a set of comma-delimited
int
values.
- getInvokableClass(ClassLoader) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
Returns the invokable class which represents the task of this vertex
- getInvokableClassName() - Method in class org.apache.flink.runtime.executiongraph.TaskInformation
-
- getInvokableClassName() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
Returns the name of the invokable class which represents the task of this vertex.
- getInvolvedIndexes() - Method in class org.apache.flink.api.common.operators.Ordering
-
- getIOManager() - Method in interface org.apache.flink.runtime.execution.Environment
-
- getIOManager() - Method in class org.apache.flink.runtime.operators.BatchTask
-
- getIOManager() - Method in interface org.apache.flink.runtime.operators.TaskContext
-
- getIOManager() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServices
-
- getIOManager() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
-
- getIOMetricGroup() - Method in class org.apache.flink.runtime.metrics.groups.OperatorMetricGroup
-
Returns the OperatorIOMetricGroup for this operator.
- getIOMetricGroup() - Method in class org.apache.flink.runtime.metrics.groups.TaskMetricGroup
-
Returns the TaskIOMetricGroup for this task.
- getIOMetrics() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecution
-
- getIOMetrics() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecution
-
- getIOMetrics() - Method in class org.apache.flink.runtime.executiongraph.Execution
-
- getIOMetrics() - Method in class org.apache.flink.runtime.operators.chaining.ChainedDriver
-
- getIOMetrics() - Method in class org.apache.flink.runtime.taskmanager.TaskExecutionState
-
- getIoMetricsInfo() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsInfo
-
- getIsAutoCommitEnabled() - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer08
-
- getIsAutoCommitEnabled() - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer09
-
- getIsAutoCommitEnabled() - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumerBase
-
- getIsFromFirst() - Method in class org.apache.flink.api.java.operators.CrossOperator.ProjectCrossFunction
-
- getIsSolutionSetUpdate() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getIsSolutionSetUpdateWithoutReprobe() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getIsWorksetIteration() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getIsWorksetUpdate() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getIterationAggregator(String) - Method in interface org.apache.flink.api.common.functions.IterationRuntimeContext
-
- getIterationAggregator(String) - Method in class org.apache.flink.graph.gsa.ApplyFunction
-
Gets the iteration aggregator registered under the given name.
- getIterationAggregator(String) - Method in class org.apache.flink.graph.gsa.GatherFunction
-
Gets the iteration aggregator registered under the given name.
- getIterationAggregator(String) - Method in class org.apache.flink.graph.gsa.SumFunction
-
Gets the iteration aggregator registered under the given name.
- getIterationAggregator(String) - Method in class org.apache.flink.graph.pregel.ComputeFunction
-
Gets the iteration aggregator registered under the given name.
- getIterationAggregator(String) - Method in class org.apache.flink.graph.spargel.GatherFunction
-
Gets the iteration aggregator registered under the given name.
- getIterationAggregator(String) - Method in class org.apache.flink.graph.spargel.ScatterFunction
-
Gets the iteration aggregator registered under the given name.
- getIterationAggregators() - Method in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
-
- getIterationAggregators(ClassLoader) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getIterationConfiguration() - Method in class org.apache.flink.graph.gsa.GatherSumApplyIteration
-
- getIterationConfiguration() - Method in class org.apache.flink.graph.pregel.VertexCentricIteration
-
- getIterationConfiguration() - Method in class org.apache.flink.graph.spargel.ScatterGatherIteration
-
- getIterationContract() - Method in class org.apache.flink.optimizer.dag.BulkIterationNode
-
- getIterationContract() - Method in class org.apache.flink.optimizer.dag.WorksetIterationNode
-
- getIterationHead() - Method in class org.apache.flink.api.java.operators.BulkIterationResultSet
-
- getIterationHead() - Method in class org.apache.flink.api.java.operators.DeltaIterationResultSet
-
- getIterationHeadFinalOutputConfig() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getIterationHeadIndexOfSyncOutput() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getIterationHeadPartialSolutionOrWorksetInputIndex() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getIterationHeadSolutionSetInputIndex() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getIterationId() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getIterationId() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getIterationNode() - Method in class org.apache.flink.optimizer.dag.AbstractPartialSolutionNode
-
- getIterationNode() - Method in class org.apache.flink.optimizer.dag.BulkPartialSolutionNode
-
- getIterationNode() - Method in class org.apache.flink.optimizer.dag.SolutionSetNode
-
- getIterationNode() - Method in class org.apache.flink.optimizer.dag.WorksetNode
-
- getIterationNode() - Method in class org.apache.flink.optimizer.plan.BulkIterationPlanNode
-
- getIterationNode() - Method in interface org.apache.flink.optimizer.plan.IterationPlanNode
-
- getIterationNode() - Method in class org.apache.flink.optimizer.plan.WorksetIterationPlanNode
-
- getIterationRuntimeContext() - Method in class org.apache.flink.api.common.functions.AbstractRichFunction
-
- getIterationRuntimeContext() - Method in interface org.apache.flink.api.common.functions.RichFunction
-
Gets a specialized version of the
RuntimeContext
, which has additional information
about the iteration in which the function is executed.
- getIterationRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalAggregateProcessAllWindowFunction
-
- getIterationRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalAggregateProcessWindowFunction
-
- getIterationRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableAllWindowFunction
-
- getIterationRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableProcessAllWindowFunction
-
- getIterationRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableProcessWindowFunction
-
- getIterationRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableWindowFunction
-
- getIterationRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueAllWindowFunction
-
- getIterationRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueProcessAllWindowFunction
-
- getIterationRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueProcessWindowFunction
-
- getIterationRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueWindowFunction
-
- getIterationSourceSinkPairs() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- getIterationWaitTime() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getIterator() - Method in class org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
-
Gets an iterator over all records in this buffer in their logical order.
- getIterator() - Method in interface org.apache.flink.runtime.operators.sort.InMemorySorter
-
Gets an iterator over all records in this buffer in their logical order.
- getIterator() - Method in class org.apache.flink.runtime.operators.sort.NormalizedKeySorter
-
Gets an iterator over all records in this buffer in their logical order.
- getIterator() - Method in interface org.apache.flink.runtime.operators.sort.Sorter
-
- getIterator() - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger
-
- getIterator() - Method in class org.apache.flink.runtime.operators.TempBarrier
-
This method resets the input!
- getIterator() - Method in interface org.apache.flink.runtime.operators.util.CloseableInputProvider
-
Gets the iterator over this input.
- getIterator() - Method in class org.apache.flink.runtime.operators.util.SimpleCloseableInputProvider
-
- getJaccardIndexScore() - Method in class org.apache.flink.graph.library.similarity.JaccardIndex.Result
-
Get the Jaccard Index score, equal to the number of shared neighbors
of the source and target vertices divided by the number of distinct
neighbors.
- getJarFilePath() - Method in class org.apache.flink.client.cli.ProgramOptions
-
- getJarFilePath() - Method in class org.apache.flink.client.cli.SavepointOptions
-
- getJarFiles() - Method in class org.apache.flink.client.program.JobWithJars
-
Returns list of jar files that need to be submitted with the plan.
- getJars() - Method in class org.apache.flink.client.program.ContextEnvironment
-
- getJars() - Method in class org.apache.flink.table.client.cli.CliOptions
-
- getJob() - Method in class org.apache.flink.runtime.messages.checkpoint.AbstractCheckpointMessage
-
- getJobAccumulators() - Method in class org.apache.flink.runtime.rest.messages.JobAccumulatorsInfo
-
- getJobCheckpointingConfiguration() - Method in class org.apache.flink.runtime.checkpoint.CheckpointStatsTracker
-
Returns the job's checkpointing configuration which is derived from the
CheckpointConfig.
- getJobClientActor() - Method in class org.apache.flink.runtime.client.JobListeningContext
-
- getJobConf() - Method in class org.apache.flink.api.java.hadoop.mapred.HadoopInputFormatBase
-
- getJobConf() - Method in class org.apache.flink.api.java.hadoop.mapred.HadoopOutputFormatBase
-
- getJobConf() - Method in class org.apache.flink.api.java.hadoop.mapred.wrapper.HadoopInputSplit
-
- getJobConfiguration() - Method in interface org.apache.flink.runtime.execution.Environment
-
Returns the job-wide configuration object that was attached to the JobGraph.
- getJobConfiguration() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- getJobConfiguration() - Method in class org.apache.flink.runtime.executiongraph.JobInformation
-
- getJobConfiguration() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
Returns the configuration object for this job.
- getJobConfiguration() - Method in class org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
-
Returns the job configuration object which was attached to the original
JobGraph
.
- getJobConfiguration() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
-
- getJobConfiguration() - Method in class org.apache.flink.runtime.taskmanager.Task
-
- getJobExecutionResult() - Method in class org.apache.flink.api.common.JobSubmissionResult
-
Returns the JobExecutionResult if available.
- getJobExecutionResult() - Method in class org.apache.flink.runtime.rest.messages.job.JobExecutionResultResponseBody
-
- getJobGraph(Configuration, PackagedProgram, FlinkPlan, SavepointRestoreSettings) - Static method in class org.apache.flink.client.program.ClusterClient
-
- getJobGraph(Configuration, FlinkPlan, List<URL>, List<URL>, SavepointRestoreSettings) - Static method in class org.apache.flink.client.program.ClusterClient
-
- getJobGraph() - Method in class org.apache.flink.optimizer.plan.StreamingPlan
-
- getJobGraph() - Method in class org.apache.flink.runtime.jobmanager.SubmittedJobGraph
-
- getJobGraph() - Method in class org.apache.flink.runtime.jobmaster.JobManagerRunner
-
- getJobGraph() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- getJobGraphAndClassLoader(JarActionHandler.JarActionHandlerConfig) - Method in class org.apache.flink.runtime.webmonitor.handlers.legacy.JarActionHandler
-
- getJobID() - Method in class org.apache.flink.api.common.JobSubmissionResult
-
Returns the JobID assigned to the job by the Flink runtime.
- getJobId() - Method in class org.apache.flink.api.common.Plan
-
Gets the ID of the job that the dataflow plan belongs to.
- getJobID() - Method in class org.apache.flink.client.program.DetachedEnvironment.DetachedJobExecutionResult
-
- getJobId() - Method in class org.apache.flink.queryablestate.messages.KvStateRequest
-
- getJobID() - Method in class org.apache.flink.runtime.accumulators.AccumulatorSnapshot
-
- getJobId() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
-
- getJobId() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
-
- getJobID() - Method in exception org.apache.flink.runtime.client.JobExecutionException
-
- getJobID() - Method in class org.apache.flink.runtime.client.JobListeningContext
-
- getJobId() - Method in class org.apache.flink.runtime.client.JobStatusMessage
-
- getJobId() - Method in class org.apache.flink.runtime.client.SerializedJobExecutionResult
-
- getJobId() - Method in class org.apache.flink.runtime.clusterframework.types.TaskManagerSlot
-
- getJobId() - Method in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
-
Returns the task's job ID.
- getJobID() - Method in interface org.apache.flink.runtime.execution.Environment
-
Returns the ID of the job that the task belongs to.
- getJobID() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionGraph
-
Returns the
JobID
for this execution graph.
- getJobID() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
-
- getJobID() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- getJobId() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
- getJobId() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- getJobId() - Method in class org.apache.flink.runtime.executiongraph.JobInformation
-
- getJobId() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
-
- getJobID() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
Returns the ID of the job.
- getJobId() - Method in class org.apache.flink.runtime.jobmanager.SubmittedJobGraph
-
- getJobId() - Method in class org.apache.flink.runtime.jobmaster.JobResult
-
- getJobId() - Method in class org.apache.flink.runtime.messages.webmonitor.JobDetails
-
- getJobId() - Method in class org.apache.flink.runtime.messages.webmonitor.JobIdsWithStatusOverview.JobIdWithStatus
-
- getJobId() - Method in class org.apache.flink.runtime.query.KvStateLocation
-
Returns the JobID the KvState instances belong to.
- getJobId() - Method in class org.apache.flink.runtime.query.KvStateMessage.LookupKvStateLocation
-
Returns the JobID the KvState instance belongs to.
- getJobId() - Method in class org.apache.flink.runtime.query.KvStateMessage.NotifyKvStateRegistered
-
Returns the JobID the KvState instance belongs to.
- getJobId() - Method in class org.apache.flink.runtime.query.KvStateMessage.NotifyKvStateUnregistered
-
Returns the JobID the KvState instance belongs to.
- getJobID() - Method in class org.apache.flink.runtime.resourcemanager.registration.JobManagerRegistration
-
- getJobId() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.PendingSlotRequest
-
- getJobId() - Method in class org.apache.flink.runtime.resourcemanager.SlotRequest
-
Get the JobID of the slot requested for.
- getJobId() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
-
- getJobId() - Method in class org.apache.flink.runtime.rest.messages.JobConfigInfo
-
- getJobId() - Method in exception org.apache.flink.runtime.taskexecutor.exceptions.SlotOccupiedException
-
- getJobID() - Method in class org.apache.flink.runtime.taskexecutor.JobManagerConnection
-
- getJobId() - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlot
-
- getJobID() - Method in class org.apache.flink.runtime.taskexecutor.SlotStatus
-
Get the job id of the slot allocated for
- getJobID() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
-
- getJobID() - Method in class org.apache.flink.runtime.taskmanager.Task
-
- getJobID() - Method in class org.apache.flink.runtime.taskmanager.TaskExecutionState
-
The ID of the job the task belongs to
- getJobId() - Method in class org.apache.flink.runtime.webmonitor.handlers.JarRunResponseBody
-
- getJobIds() - Method in class org.apache.flink.runtime.dispatcher.SingleJobSubmittedJobGraphStore
-
- getJobIds() - Method in class org.apache.flink.runtime.jobmanager.StandaloneSubmittedJobGraphStore
-
- getJobIds() - Method in interface org.apache.flink.runtime.jobmanager.SubmittedJobGraphStore
-
Get all job ids of submitted job graphs to the submitted job graph store.
- getJobIds() - Method in class org.apache.flink.runtime.jobmanager.ZooKeeperSubmittedJobGraphStore
-
- getJobInfo() - Method in class org.apache.flink.runtime.jobmanager.SubmittedJobGraph
-
Returns the
JobInfo
of the client who submitted the
JobGraph
.
- getJobInformationOrBlobKey() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- getJobLeaderIdService() - Method in class org.apache.flink.runtime.resourcemanager.ResourceManagerRuntimeServices
-
- getJobLeaderService() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServices
-
- getJobManager() - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.MetricStore
-
- getJobManagerAddress(Configuration) - Static method in class org.apache.flink.runtime.highavailability.HighAvailabilityServicesUtils
-
Returns the JobManager's hostname and port extracted from the given
Configuration
.
- getJobManagerBindAddress() - Method in class org.apache.flink.runtime.minicluster.MiniClusterConfiguration
-
- getJobManagerClass() - Method in class org.apache.flink.mesos.runtime.clusterframework.MesosApplicationMasterRunner
-
- getJobManagerClass() - Method in class org.apache.flink.yarn.YarnApplicationMasterRunner
-
- getJobManagerFormat() - Method in class org.apache.flink.runtime.metrics.scope.ScopeFormats
-
- getJobManagerGateway() - Method in class org.apache.flink.client.program.ClusterClient
-
- getJobManagerGateway() - Method in class org.apache.flink.runtime.resourcemanager.registration.JobManagerRegistration
-
- getJobManagerGateway() - Method in class org.apache.flink.runtime.taskexecutor.JobManagerConnection
-
- getJobManagerJobFormat() - Method in class org.apache.flink.runtime.metrics.scope.ScopeFormats
-
- getJobManagerLeaderElectionService(JobID) - Method in interface org.apache.flink.runtime.highavailability.HighAvailabilityServices
-
Gets the leader election service for the given job.
- getJobManagerLeaderElectionService(JobID) - Method in class org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedHaServices
-
- getJobManagerLeaderElectionService(JobID) - Method in class org.apache.flink.runtime.highavailability.nonha.standalone.StandaloneHaServices
-
- getJobManagerLeaderElectionService(JobID) - Method in class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperHaServices
-
- getJobManagerLeaderElectionService(JobID) - Method in class org.apache.flink.yarn.highavailability.YarnIntraNonHaMasterServices
-
- getJobManagerLeaderElectionService(JobID) - Method in class org.apache.flink.yarn.highavailability.YarnPreConfiguredMasterNonHaServices
-
- getJobManagerLeaderRetriever(JobID) - Method in interface org.apache.flink.runtime.highavailability.HighAvailabilityServices
-
- getJobManagerLeaderRetriever(JobID, String) - Method in interface org.apache.flink.runtime.highavailability.HighAvailabilityServices
-
Gets the leader retriever for the job JobMaster which is responsible for the given job
- getJobManagerLeaderRetriever(JobID) - Method in class org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedHaServices
-
- getJobManagerLeaderRetriever(JobID, String) - Method in class org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedHaServices
-
- getJobManagerLeaderRetriever(JobID) - Method in class org.apache.flink.runtime.highavailability.nonha.standalone.StandaloneHaServices
-
- getJobManagerLeaderRetriever(JobID, String) - Method in class org.apache.flink.runtime.highavailability.nonha.standalone.StandaloneHaServices
-
- getJobManagerLeaderRetriever(JobID) - Method in class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperHaServices
-
- getJobManagerLeaderRetriever(JobID, String) - Method in class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperHaServices
-
- getJobManagerLeaderRetriever(JobID) - Method in class org.apache.flink.yarn.highavailability.YarnIntraNonHaMasterServices
-
- getJobManagerLeaderRetriever(JobID, String) - Method in class org.apache.flink.yarn.highavailability.YarnIntraNonHaMasterServices
-
- getJobManagerLeaderRetriever(JobID) - Method in class org.apache.flink.yarn.highavailability.YarnPreConfiguredMasterNonHaServices
-
- getJobManagerLeaderRetriever(JobID, String) - Method in class org.apache.flink.yarn.highavailability.YarnPreConfiguredMasterNonHaServices
-
- getJobManagerManagedKeyedState() - Method in class org.apache.flink.runtime.checkpoint.PrioritizedOperatorSubtaskState
-
Returns the managed keyed state from the job manager, which represents the ground truth about what this state
should represent.
- getJobManagerManagedOperatorState() - Method in class org.apache.flink.runtime.checkpoint.PrioritizedOperatorSubtaskState
-
Returns the managed operator state from the job manager, which represents the ground truth about what this state
should represent.
- getJobManagerMetricStore() - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.MetricStore
-
- getJobManagerMode() - Method in class org.apache.flink.runtime.jobmanager.JobManagerCliOptions
-
- getJobManagerOwnedSnapshot() - Method in class org.apache.flink.runtime.state.SnapshotResult
-
- getJobManagerOwnedState() - Method in class org.apache.flink.streaming.api.operators.OperatorSnapshotFinalizer
-
- getJobManagerRawKeyedState() - Method in class org.apache.flink.runtime.checkpoint.PrioritizedOperatorSubtaskState
-
Returns the raw keyed state from the job manager, which represents the ground truth about what this state
should represent.
- getJobManagerRawOperatorState() - Method in class org.apache.flink.runtime.checkpoint.PrioritizedOperatorSubtaskState
-
Returns the raw operator state from the job manager, which represents the ground truth about what this state
should represent.
- getJobManagerResourceID() - Method in class org.apache.flink.runtime.resourcemanager.registration.JobManagerRegistration
-
- getJobManagerTable() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServices
-
- getJobMasterId() - Method in class org.apache.flink.runtime.resourcemanager.registration.JobManagerRegistration
-
- getJobMasterId() - Method in class org.apache.flink.runtime.taskexecutor.JobManagerConnection
-
- getJobMetricStore(String) - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.MetricStore
-
- getJobName() - Method in class org.apache.flink.api.common.Plan
-
Gets the name of this job.
- getJobName() - Method in class org.apache.flink.optimizer.plan.OptimizedPlan
-
Returns the name of the program.
- getJobName() - Method in class org.apache.flink.runtime.client.JobStatusMessage
-
- getJobName() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionGraph
-
Returns the job name for the execution graph.
- getJobName() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
-
- getJobName() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- getJobName() - Method in class org.apache.flink.runtime.executiongraph.JobInformation
-
- getJobName() - Method in class org.apache.flink.runtime.messages.webmonitor.JobDetails
-
- getJobName() - Method in class org.apache.flink.runtime.rest.messages.JobConfigInfo
-
- getJobName() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- getJobResultFuture() - Method in class org.apache.flink.runtime.client.JobListeningContext
-
- getJobs() - Method in class org.apache.flink.runtime.messages.webmonitor.MultipleJobsDetails
-
- getJobs() - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.MetricStore
-
- getJobSchedulingStatus(JobID) - Method in class org.apache.flink.runtime.highavailability.FsNegativeRunningJobsRegistry
-
- getJobSchedulingStatus(JobID) - Method in class org.apache.flink.runtime.highavailability.nonha.standalone.StandaloneRunningJobsRegistry
-
- getJobSchedulingStatus(JobID) - Method in interface org.apache.flink.runtime.highavailability.RunningJobsRegistry
-
Gets the scheduling status of a job.
- getJobSchedulingStatus(JobID) - Method in class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperRunningJobsRegistry
-
- getJobState() - Method in class org.apache.flink.runtime.client.JobStatusMessage
-
- getJobStatus(JobID) - Method in class org.apache.flink.client.program.ClusterClient
-
- getJobStatus(JobID) - Method in class org.apache.flink.client.program.MiniClusterClient
-
- getJobStatus(JobID) - Method in class org.apache.flink.client.program.rest.RestClusterClient
-
- getJobStatus() - Method in class org.apache.flink.runtime.messages.webmonitor.JobIdsWithStatusOverview.JobIdWithStatus
-
- getJobStatus(JobID) - Method in class org.apache.flink.runtime.minicluster.MiniCluster
-
- getJobStatus() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
-
- getJobsWithStatus() - Method in class org.apache.flink.runtime.messages.webmonitor.JobIdsWithStatusOverview
-
- getJobTerminationFuture() - Method in class org.apache.flink.runtime.dispatcher.MiniDispatcher
-
- getJobTimeout() - Method in class org.apache.flink.runtime.resourcemanager.ResourceManagerRuntimeServicesConfiguration
-
- getJobVertex(JobVertexID) - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionGraph
-
- getJobVertex(JobVertexID) - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
-
- getJobVertex(JobVertexID) - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- getJobVertex() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
- getJobVertex() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- getJobVertexClass() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getJobVertexID() - Method in class org.apache.flink.runtime.checkpoint.TaskState
-
Deprecated.
- getJobVertexId() - Method in class org.apache.flink.runtime.checkpoint.TaskStateStats
-
Returns the ID of the operator the statistics belong to.
- getJobVertexId() - Method in interface org.apache.flink.runtime.execution.Environment
-
Gets the ID of the JobVertex for which this task executes a parallel subtask.
- getJobVertexId() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionJobVertex
-
- getJobVertexId() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionJobVertex
-
- getJobVertexId() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
- getJobvertexId() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- getJobVertexId() - Method in class org.apache.flink.runtime.executiongraph.TaskInformation
-
- getJobVertexId() - Method in class org.apache.flink.runtime.jobmanager.scheduler.ScheduledUnit
-
- getJobVertexId() - Method in class org.apache.flink.runtime.query.KvStateLocation
-
Returns the JobVertexID the KvState instances belong to.
- getJobVertexId() - Method in class org.apache.flink.runtime.query.KvStateMessage.NotifyKvStateRegistered
-
Returns the JobVertexID the KvState instance belongs to.
- getJobVertexId() - Method in class org.apache.flink.runtime.query.KvStateMessage.NotifyKvStateUnregistered
-
Returns the JobVertexID the KvState instance belongs to.
- getJobVertexID() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
-
- getJobVertexId() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
-
- getJobVertexId() - Method in class org.apache.flink.runtime.taskmanager.Task
-
- getJobVertexIds() - Method in class org.apache.flink.runtime.jobmanager.scheduler.SlotSharingGroup
-
- getJobVertexInfos() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
-
- getJobVertexMetrics() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
-
- getJobVerticesPerState() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
-
- getJoinedPathsVector() - Method in class org.apache.flink.optimizer.dag.OptimizerNode.UnclosedBranchDescriptor
-
- getJoinHint() - Method in class org.apache.flink.api.common.operators.base.JoinOperatorBase
-
- getJoinHint() - Method in class org.apache.flink.api.java.operators.JoinOperator
-
Gets the JoinHint that describes how the join is executed.
- getJoinReturnTypes(JoinFunction<IN1, IN2, OUT>, TypeInformation<IN1>, TypeInformation<IN2>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
- getJoinReturnTypes(JoinFunction<IN1, IN2, OUT>, TypeInformation<IN1>, TypeInformation<IN2>, String, boolean) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
- getJoinType() - Method in class org.apache.flink.api.java.operators.JoinOperator
-
Gets the JoinType that describes this join operation (e.g.
- getJson() - Method in class org.apache.flink.runtime.webmonitor.history.ArchivedJson
-
- getJSON() - Method in class org.apache.flink.streaming.api.graph.JSONGenerator
-
- getJsonArchivists() - Static method in class org.apache.flink.runtime.webmonitor.WebMonitorUtils
-
- getJsonArchivists() - Static method in class org.apache.flink.runtime.webmonitor.WebRuntimeMonitor
-
Returns an array of all
JsonArchivist
s that are relevant for the history server.
- getJsonPlan() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionGraph
-
Returns the job plan as a JSON string.
- getJsonPlan() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
-
- getJsonPlan() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- getJsonPlan() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
-
- getJsonPlan() - Method in class org.apache.flink.runtime.rest.messages.JobPlanInfo
-
- getJsonSchema() - Method in class org.apache.flink.streaming.connectors.kafka.KafkaJsonTableSource.Builder
-
Returns the configured JSON schema.
- getJvmStartupOptions() - Static method in class org.apache.flink.runtime.util.EnvironmentInformation
-
Gets the system parameters and environment parameters that were passed to the JVM on startup.
- getJvmStartupOptionsArray() - Static method in class org.apache.flink.runtime.util.EnvironmentInformation
-
Gets the system parameters and environment parameters that were passed to the JVM on startup.
- getJvmVersion() - Static method in class org.apache.flink.runtime.util.EnvironmentInformation
-
Gets the version of the JVM in the form "VM_Name - Vendor - Spec/Version".
- getKafkaConsumer(String, Properties, DeserializationSchema<Row>) - Method in class org.apache.flink.streaming.connectors.kafka.KafkaTableSource
-
Returns a version-specific Kafka consumer with the start position configured.
- getKafkaPartitionHandle() - Method in class org.apache.flink.streaming.connectors.kafka.internals.KafkaTopicPartitionState
-
Gets Kafka's descriptor for the Kafka Partition.
- getKafkaProducer(Properties) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducerBase
-
Used for testing only.
- getKafkaProps() - Method in class org.apache.flink.streaming.connectors.kafka.KafkaTableSource.Builder
-
Returns the configured Kafka properties.
- getKafkaTopicPartition() - Method in class org.apache.flink.streaming.connectors.kafka.internals.KafkaTopicPartitionState
-
Gets Flink's descriptor for the Kafka Partition.
- getKey(IN) - Method in interface org.apache.flink.api.java.functions.KeySelector
-
User-defined function that deterministically extracts the key from an object.
- getKey(T) - Method in class org.apache.flink.api.java.functions.NullByteKeySelector
-
- getKey() - Method in class org.apache.flink.runtime.rest.messages.ClusterConfigurationInfoEntry
-
- getKey() - Method in class org.apache.flink.runtime.rest.messages.MessageParameter
-
Returns the key of this parameter, e.g.
- getKey() - Method in interface org.apache.flink.runtime.state.heap.StateEntry
-
Returns the key of this entry.
- getKey() - Method in class org.apache.flink.streaming.api.operators.InternalTimer
-
- getKey() - Method in class org.apache.flink.streaming.connectors.fs.AvroKeyValueSinkWriter.AvroKeyValue
-
- getKey(PyObject) - Method in class org.apache.flink.streaming.python.api.functions.PythonKeySelector
-
- getKey() - Method in class org.apache.flink.streaming.runtime.operators.windowing.KeyMap.Entry
-
- getKey() - Method in class org.apache.flink.streaming.tests.Event
-
- getKey(IN) - Method in class org.apache.flink.streaming.util.keys.KeySelectorUtil.ArrayKeySelector
-
- getKey(IN) - Method in class org.apache.flink.streaming.util.keys.KeySelectorUtil.ComparableKeySelector
-
- getKey(IN) - Method in class org.apache.flink.streaming.util.keys.KeySelectorUtil.OneKeySelector
-
- getKey() - Method in class org.apache.hadoop.conf.Configuration.DeprecationDelta
-
- getKeyA(A) - Method in class org.apache.flink.runtime.jobmaster.slotpool.DualKeyMap
-
- getKeyB(B) - Method in class org.apache.flink.runtime.jobmaster.slotpool.DualKeyMap
-
- getKeyColumns(int) - Method in class org.apache.flink.api.common.operators.AbstractUdfOperator
-
Gets the column numbers of the key fields in the input records for the given input.
- getKeyColumns(int) - Method in class org.apache.flink.api.common.operators.DualInputOperator
-
- getKeyColumns(int) - Method in class org.apache.flink.api.common.operators.SingleInputOperator
-
- getKeyedStateBackend() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- getKeyedStateHandles(Collection<? extends KeyedStateHandle>, KeyGroupRange) - Static method in class org.apache.flink.runtime.checkpoint.StateAssignmentOperation
-
- getKeyedStateManagedFuture() - Method in class org.apache.flink.streaming.api.operators.OperatorSnapshotFutures
-
- getKeyedStateRawFuture() - Method in class org.apache.flink.streaming.api.operators.OperatorSnapshotFutures
-
- getKeyedStateStore() - Method in interface org.apache.flink.runtime.state.ManagedInitializationContext
-
Returns an interface that allows for registering keyed state with the backend.
- getKeyedStateStore() - Method in class org.apache.flink.runtime.state.StateInitializationContextImpl
-
- getKeyedStateStore() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- getKeyedStateStreamFuture() - Method in class org.apache.flink.runtime.state.StateSnapshotContextSynchronousImpl
-
- getKeyExtractor() - Method in class org.apache.flink.api.common.operators.Keys.SelectorFunctionKeys
-
- getKeyFields() - Method in class org.apache.flink.api.java.typeutils.runtime.PojoComparator
-
- getKeyFieldTypes() - Method in class org.apache.flink.api.common.operators.Keys.ExpressionKeys
-
- getKeyFieldTypes() - Method in class org.apache.flink.api.common.operators.Keys
-
- getKeyFieldTypes() - Method in class org.apache.flink.api.common.operators.Keys.SelectorFunctionKeys
-
- getKeyGroupCompressionDecorator() - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
-
- getKeyGroupId(int) - Method in class org.apache.flink.runtime.state.KeyGroupRange
-
- getKeyGroupId(int) - Method in interface org.apache.flink.runtime.state.KeyGroupsList
-
- getKeyGroupId() - Method in class org.apache.flink.runtime.state.KeyGroupStatePartitionStreamProvider
-
Returns the key group that corresponds to the data in the provided stream.
- getKeyGroupList() - Method in class org.apache.flink.runtime.state.KeyedStateCheckpointOutputStream
-
Returns a list of all key-groups which can be written to this stream.
- getKeyGroupOffset(int) - Method in class org.apache.flink.runtime.state.KeyGroupRangeOffsets
-
Returns the offset for the given key-group.
- getKeyGroupPrefixBytes() - Method in class org.apache.flink.contrib.streaming.state.RocksDBKeyedStateBackend
-
- getKeyGroupRange() - Method in class org.apache.flink.runtime.query.KvStateMessage.NotifyKvStateRegistered
-
Returns the key group index the KvState instance belongs to.
- getKeyGroupRange() - Method in class org.apache.flink.runtime.query.KvStateMessage.NotifyKvStateUnregistered
-
Returns the key group index the KvState instance belongs to.
- getKeyGroupRange() - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
-
- getKeyGroupRange() - Method in class org.apache.flink.runtime.state.DirectoryKeyedStateHandle
-
- getKeyGroupRange() - Method in interface org.apache.flink.runtime.state.heap.InternalKeyContext
-
Returns the key groups for this backend.
- getKeyGroupRange() - Method in class org.apache.flink.runtime.state.IncrementalKeyedStateHandle
-
- getKeyGroupRange() - Method in interface org.apache.flink.runtime.state.KeyedStateHandle
-
Returns the range of the key groups contained in the state.
- getKeyGroupRange() - Method in class org.apache.flink.runtime.state.KeyGroupRangeOffsets
-
- getKeyGroupRange() - Method in class org.apache.flink.runtime.state.KeyGroupsStateHandle
-
- getKeyHashCode() - Method in class org.apache.flink.queryablestate.messages.KvStateRequest
-
- getKeyPositions() - Method in class org.apache.flink.api.java.operators.DeltaIterationResultSet
-
- getKeyPositions() - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
-
- getKeys() - Method in class org.apache.flink.api.java.operators.Grouping
-
- getKeys(String, N) - Method in class org.apache.flink.contrib.streaming.state.RocksDBKeyedStateBackend
-
- getKeys(int) - Method in class org.apache.flink.optimizer.plan.SingleInputPlanNode
-
Gets the key field indexes for the specified driver comparator.
- getKeys(N) - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateTable
-
- getKeys(String, N) - Method in class org.apache.flink.runtime.state.heap.HeapKeyedStateBackend
-
- getKeys(N) - Method in class org.apache.flink.runtime.state.heap.NestedMapsStateTable
-
- getKeys(N) - Method in class org.apache.flink.runtime.state.heap.StateTable
-
- getKeys(String, N) - Method in interface org.apache.flink.runtime.state.KeyedStateBackend
-
- getKeys() - Method in class org.apache.flink.table.client.cli.CliChangelogResultView
-
- getKeys() - Method in class org.apache.flink.table.client.cli.CliInputView
-
- getKeys() - Method in class org.apache.flink.table.client.cli.CliRowView
-
- getKeys() - Method in class org.apache.flink.table.client.cli.CliTableResultView
-
- getKeys() - Method in class org.apache.flink.table.client.cli.CliView
-
- getKeys1() - Method in class org.apache.flink.api.java.operators.CoGroupOperator
-
- getKeys1() - Method in class org.apache.flink.api.java.operators.CoGroupRawOperator
-
- getKeys1() - Method in class org.apache.flink.api.java.operators.JoinOperator
-
- getKeys2() - Method in class org.apache.flink.api.java.operators.CoGroupOperator
-
- getKeys2() - Method in class org.apache.flink.api.java.operators.CoGroupRawOperator
-
- getKeys2() - Method in class org.apache.flink.api.java.operators.JoinOperator
-
- getKeySelector() - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Gets the key selector that can get the key by which the stream if partitioned from the elements.
- getKeySelector() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
- getKeySelectorTypes(KeySelector<IN, OUT>, TypeInformation<IN>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
- getKeySelectorTypes(KeySelector<IN, OUT>, TypeInformation<IN>, String, boolean) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
- getKeySerializer() - Method in class org.apache.flink.api.common.state.MapStateDescriptor
-
Gets the serializer for the keys in the state.
- getKeySerializer() - Method in class org.apache.flink.api.common.typeutils.base.MapSerializer
-
- getKeySerializer() - Method in class org.apache.flink.cep.nfa.SharedBuffer.SharedBufferSerializer
-
- getKeySerializer() - Method in class org.apache.flink.contrib.streaming.state.RocksDBAggregatingState
-
- getKeySerializer() - Method in class org.apache.flink.contrib.streaming.state.RocksDBFoldingState
-
Deprecated.
- getKeySerializer() - Method in class org.apache.flink.contrib.streaming.state.RocksDBListState
-
- getKeySerializer() - Method in class org.apache.flink.contrib.streaming.state.RocksDBMapState
-
- getKeySerializer() - Method in class org.apache.flink.contrib.streaming.state.RocksDBReducingState
-
- getKeySerializer() - Method in class org.apache.flink.contrib.streaming.state.RocksDBValueState
-
- getKeySerializer() - Method in class org.apache.flink.runtime.query.KvStateInfo
-
- getKeySerializer() - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
-
- getKeySerializer() - Method in class org.apache.flink.runtime.state.heap.HeapAggregatingState
-
- getKeySerializer() - Method in class org.apache.flink.runtime.state.heap.HeapFoldingState
-
Deprecated.
- getKeySerializer() - Method in class org.apache.flink.runtime.state.heap.HeapListState
-
- getKeySerializer() - Method in class org.apache.flink.runtime.state.heap.HeapMapState
-
- getKeySerializer() - Method in class org.apache.flink.runtime.state.heap.HeapReducingState
-
- getKeySerializer() - Method in class org.apache.flink.runtime.state.heap.HeapValueState
-
- getKeySerializer() - Method in interface org.apache.flink.runtime.state.heap.InternalKeyContext
-
- getKeySerializer() - Method in interface org.apache.flink.runtime.state.internal.InternalKvState
-
Returns the
TypeSerializer
for the type of key this state is associated to.
- getKeySerializer() - Method in class org.apache.flink.runtime.state.KeyedBackendSerializationProxy
-
- getKeySerializer() - Method in class org.apache.flink.runtime.state.RegisteredBroadcastBackendStateMetaInfo
-
- getKeySerializer() - Method in class org.apache.flink.runtime.state.RegisteredBroadcastBackendStateMetaInfo.Snapshot
-
- getKeySerializer() - Method in class org.apache.flink.streaming.api.datastream.QueryableStateStream
-
Returns the key serializer for the queryable state instance.
- getKeySerializer() - Method in class org.apache.flink.streaming.api.operators.InternalTimersSnapshot
-
- getKeySerializerConfigSnapshot() - Method in class org.apache.flink.runtime.state.KeyedBackendSerializationProxy
-
- getKeySerializerConfigSnapshot() - Method in class org.apache.flink.runtime.state.RegisteredBroadcastBackendStateMetaInfo.Snapshot
-
- getKeySerializerConfigSnapshot() - Method in class org.apache.flink.streaming.api.operators.InternalTimersSnapshot
-
- getKeysForInput1() - Method in class org.apache.flink.optimizer.plan.DualInputPlanNode
-
- getKeysForInput2() - Method in class org.apache.flink.optimizer.plan.DualInputPlanNode
-
- getKeyString() - Method in class org.apache.flink.util.StringBasedID
-
- getKeytab() - Method in class org.apache.flink.runtime.security.SecurityConfiguration
-
- getKeyType() - Method in class org.apache.flink.api.common.operators.Keys.SelectorFunctionKeys
-
- getKeyType() - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Gets the type of the key by which the stream is partitioned.
- getKeyTypeInfo() - Method in class org.apache.flink.api.java.typeutils.MapTypeInfo
-
Gets the type information for the keys in the map
- getKeyTypes() - Method in interface org.apache.flink.api.common.distributions.DataDistribution
-
Gets the type of the key by which the dataSet is partitioned.
- getKeyValueState(String, Class<S>, S) - Method in interface org.apache.flink.streaming.api.windowing.triggers.Trigger.TriggerContext
-
- getKeyValueState(String, TypeInformation<S>, S) - Method in interface org.apache.flink.streaming.api.windowing.triggers.Trigger.TriggerContext
-
- getKeyValueState(String, Class<S>, S) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
-
- getKeyValueState(String, TypeInformation<S>, S) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
-
- getKibiBytes() - Method in class org.apache.flink.configuration.MemorySize
-
Gets the memory size in Kibibytes (= 1024 bytes).
- getKind() - Method in class org.apache.flink.core.fs.FileSystem
-
Gets a description of the characteristics of this file system.
- getKind() - Method in class org.apache.flink.core.fs.LimitedConnectionsFileSystem
-
- getKind() - Method in class org.apache.flink.core.fs.local.LocalFileSystem
-
- getKind() - Method in class org.apache.flink.core.fs.SafetyNetWrapperFileSystem
-
- getKind() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileSystem
-
- getKind() - Method in class org.apache.flink.runtime.fs.maprfs.MapRFileSystem
-
- getKrb5LoginModuleName() - Static method in class org.apache.flink.runtime.security.KerberosUtils
-
- getKryo() - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer
-
- getKryoRegistrations() - Method in class org.apache.flink.api.java.typeutils.runtime.KryoRegistrationSerializerConfigSnapshot
-
- getKvState(JobID, String, K, TypeHint<K>, StateDescriptor<S, V>) - Method in class org.apache.flink.queryablestate.client.QueryableStateClient
-
Returns a future holding the request result.
- getKvState(JobID, String, K, TypeInformation<K>, StateDescriptor<S, V>) - Method in class org.apache.flink.queryablestate.client.QueryableStateClient
-
Returns a future holding the request result.
- getKvState(KvStateID) - Method in class org.apache.flink.runtime.query.KvStateRegistry
-
Returns the
KvStateEntry
containing the requested instance as identified by the
given KvStateID, along with its
KvStateInfo
or
null
if none is registered.
- getKvStateId() - Method in class org.apache.flink.queryablestate.messages.KvStateInternalRequest
-
- getKvStateID(int) - Method in class org.apache.flink.runtime.query.KvStateLocation
-
Returns the registered KvStateID for the key group index or
null
if none is registered yet.
- getKvStateId() - Method in class org.apache.flink.runtime.query.KvStateMessage.NotifyKvStateRegistered
-
Returns the ID of the registered KvState instance.
- getKvStateLocation(String) - Method in class org.apache.flink.runtime.query.KvStateLocationRegistry
-
Returns the
KvStateLocation
for the registered KvState instance
or
null
if no location information is available.
- getKvStateLocationOracle(JobID) - Method in class org.apache.flink.queryablestate.client.proxy.KvStateClientProxyImpl
-
- getKvStateLocationOracle(JobID) - Method in interface org.apache.flink.runtime.query.KvStateClientProxy
-
Retrieves a future containing the currently leading key-value state location oracle.
- getKvStateLocationRegistry() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- getKvStateProxy() - Method in class org.apache.flink.runtime.io.network.NetworkEnvironment
-
- getKvStateRegistry() - Method in class org.apache.flink.runtime.io.network.NetworkEnvironment
-
- getKvStateServer() - Method in class org.apache.flink.runtime.io.network.NetworkEnvironment
-
- getKvStateServerAddress(int) - Method in class org.apache.flink.runtime.query.KvStateLocation
-
Returns the registered server address for the key group index or
null
if none is registered yet.
- getKvStateServerAddress() - Method in class org.apache.flink.runtime.query.KvStateMessage.NotifyKvStateRegistered
-
Returns the server address where to find the KvState instance.
- getLast() - Method in class org.apache.flink.runtime.checkpoint.StandaloneCheckpointIDCounter
-
Returns the last checkpoint ID (current - 1).
- getLastEnvCreated() - Method in class org.apache.flink.client.program.ContextEnvironmentFactory
-
- getLastGroupKey() - Method in class org.apache.flink.api.java.operators.translation.Tuple3UnwrappingIterator
-
- getLastHeartBeat() - Method in class org.apache.flink.runtime.instance.Instance
-
Gets the timestamp of the last heartbeat.
- getLastHeartbeat() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerInfo
-
- getLastHeartbeatFrom(ResourceID) - Method in interface org.apache.flink.runtime.heartbeat.HeartbeatManager
-
Returns the last received heartbeat from the given target.
- getLastHeartbeatFrom(ResourceID) - Method in class org.apache.flink.runtime.heartbeat.HeartbeatManagerImpl
-
- getLastJobExecutionResult() - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
- getLastJobExecutionResult() - Method in class org.apache.flink.test.util.CollectionTestEnvironment
-
- getLastJobExecutionResult() - Method in class org.apache.flink.test.util.TestEnvironment
-
- getLastKey() - Method in class org.apache.flink.api.java.operators.translation.TupleUnwrappingIterator
-
- getLastModificationTime() - Method in class org.apache.flink.api.common.io.FileInputFormat.FileBaseStatistics
-
Gets the timestamp of the last modification.
- getLastOffset() - Method in class org.apache.flink.graph.generator.CirculantGraph.OffsetRange
-
Get the offset of the last index in the range.
- getLastOutputCollector() - Method in class org.apache.flink.runtime.operators.BatchTask
-
- getLastResult() - Method in class org.apache.flink.types.parser.BigDecParser
-
- getLastResult() - Method in class org.apache.flink.types.parser.BigIntParser
-
- getLastResult() - Method in class org.apache.flink.types.parser.BooleanParser
-
- getLastResult() - Method in class org.apache.flink.types.parser.BooleanValueParser
-
- getLastResult() - Method in class org.apache.flink.types.parser.ByteParser
-
- getLastResult() - Method in class org.apache.flink.types.parser.ByteValueParser
-
- getLastResult() - Method in class org.apache.flink.types.parser.DoubleParser
-
- getLastResult() - Method in class org.apache.flink.types.parser.DoubleValueParser
-
- getLastResult() - Method in class org.apache.flink.types.parser.FieldParser
-
Gets the parsed field.
- getLastResult() - Method in class org.apache.flink.types.parser.FloatParser
-
- getLastResult() - Method in class org.apache.flink.types.parser.FloatValueParser
-
- getLastResult() - Method in class org.apache.flink.types.parser.IntParser
-
- getLastResult() - Method in class org.apache.flink.types.parser.IntValueParser
-
- getLastResult() - Method in class org.apache.flink.types.parser.LongParser
-
- getLastResult() - Method in class org.apache.flink.types.parser.LongValueParser
-
- getLastResult() - Method in class org.apache.flink.types.parser.ShortParser
-
- getLastResult() - Method in class org.apache.flink.types.parser.ShortValueParser
-
- getLastResult() - Method in class org.apache.flink.types.parser.SqlDateParser
-
- getLastResult() - Method in class org.apache.flink.types.parser.SqlTimeParser
-
- getLastResult() - Method in class org.apache.flink.types.parser.SqlTimestampParser
-
- getLastResult() - Method in class org.apache.flink.types.parser.StringParser
-
- getLastResult() - Method in class org.apache.flink.types.parser.StringValueParser
-
- getLastSortKey() - Method in class org.apache.flink.api.java.operators.translation.Tuple3UnwrappingIterator
-
- getLastTasksConfig() - Method in class org.apache.flink.runtime.operators.BatchTask
-
- getLastUpdateTime() - Method in class org.apache.flink.runtime.messages.webmonitor.JobDetails
-
- getLatencyTrackingInterval() - Method in class org.apache.flink.api.common.ExecutionConfig
-
Returns the latency tracking interval.
- getLatestAcknowledgedSubtaskStats() - Method in class org.apache.flink.runtime.checkpoint.AbstractCheckpointStats
-
Returns the latest acknowledged subtask stats or null
if
none was acknowledged yet.
- getLatestAcknowledgedSubtaskStats() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpointStats
-
- getLatestAcknowledgedSubtaskStats() - Method in class org.apache.flink.runtime.checkpoint.FailedCheckpointStats
-
- getLatestAcknowledgedSubtaskStats() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpointStats
-
- getLatestAcknowledgedSubtaskStats() - Method in class org.apache.flink.runtime.checkpoint.TaskStateStats
-
Returns the latest acknowledged subtask stats or null
if none was acknowledged yet.
- getLatestAckTimestamp() - Method in class org.apache.flink.runtime.checkpoint.AbstractCheckpointStats
-
Returns the ack timestamp of the latest acknowledged subtask or
-1
if none was acknowledged yet.
- getLatestAckTimestamp() - Method in class org.apache.flink.runtime.checkpoint.TaskStateStats
-
Returns the ack timestamp of the latest acknowledged subtask or
-1
if none was acknowledged yet.
- getLatestAckTimestamp() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
-
- getLatestAckTimestamp() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatistics
-
- getLatestCheckpoint() - Method in interface org.apache.flink.runtime.checkpoint.CompletedCheckpointStore
-
- getLatestCheckpoint() - Method in class org.apache.flink.runtime.checkpoint.StandaloneCompletedCheckpointStore
-
- getLatestCheckpoint() - Method in class org.apache.flink.runtime.checkpoint.ZooKeeperCompletedCheckpointStore
-
- getLatestCheckpoints() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics
-
- getLatestCompletedCheckpoint() - Method in class org.apache.flink.runtime.checkpoint.CheckpointStatsHistory
-
- getLatestExecutionResult() - Method in class org.apache.flink.test.util.JavaProgramTestBase
-
- getLatestFailedCheckpoint() - Method in class org.apache.flink.runtime.checkpoint.CheckpointStatsHistory
-
- getLatestPriorAllocation() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- getLatestPriorExecution() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- getLatestPriorLocation() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
Gets the location where the latest completed/canceled/failed execution of the vertex's
task happened.
- getLatestRestoredCheckpoint() - Method in class org.apache.flink.runtime.checkpoint.CheckpointStatsSnapshot
-
Returns the latest restored checkpoint.
- getLatestSavepoint() - Method in class org.apache.flink.runtime.checkpoint.CheckpointStatsHistory
-
- getLeader() - Method in class org.apache.flink.streaming.connectors.kafka.internals.KafkaTopicPartitionLeader
-
- getLeaderConnectionInfoFuture() - Method in class org.apache.flink.runtime.util.LeaderRetrievalUtils.LeaderConnectionInfoListener
-
- getLeaderFuture() - Method in class org.apache.flink.runtime.webmonitor.retriever.LeaderRetriever
-
Returns the current JobManagerGateway future.
- getLeaderGatewayFuture() - Method in class org.apache.flink.runtime.jobmaster.JobManagerRunner
-
- getLeaderId(JobID) - Method in class org.apache.flink.runtime.resourcemanager.JobLeaderIdService
-
- getLeaderID() - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerServices
-
Gets the current leader id assigned at the ResourceManager.
- getLeaderNow() - Method in class org.apache.flink.runtime.webmonitor.retriever.LeaderRetriever
-
Returns the current leader information if available.
- getLeaderSessionID() - Method in class org.apache.flink.runtime.akka.FlinkUntypedActor
-
Returns the current leader session ID associated with this actor.
- getLeaderSessionID() - Method in class org.apache.flink.runtime.client.JobClientActor
-
- getLeaderSessionID() - Method in class org.apache.flink.runtime.clusterframework.FlinkResourceManager
-
- getLeaderSessionID() - Method in class org.apache.flink.runtime.leaderelection.ZooKeeperLeaderElectionService
-
Returns the current leader session ID or null, if the contender is not the leader.
- getLeaderSessionID() - Method in class org.apache.flink.runtime.util.LeaderConnectionInfo
-
- getLeaseCount() - Method in class org.apache.flink.util.ResourceGuard
-
Returns the current count of open leases.
- getLeft() - Method in class org.apache.flink.cep.pattern.conditions.AndCondition
-
- getLeft() - Method in class org.apache.flink.cep.pattern.conditions.OrCondition
-
- getLeftType() - Method in class org.apache.flink.api.java.typeutils.EitherTypeInfo
-
- getLen() - Method in interface org.apache.flink.core.fs.FileStatus
-
Return the length of this file.
- getLen() - Method in class org.apache.flink.core.fs.local.LocalFileStatus
-
- getLen() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileStatus
-
- getLength() - Method in class org.apache.flink.api.common.typeutils.base.array.BooleanPrimitiveArraySerializer
-
- getLength() - Method in class org.apache.flink.api.common.typeutils.base.array.BytePrimitiveArraySerializer
-
- getLength() - Method in class org.apache.flink.api.common.typeutils.base.array.CharPrimitiveArraySerializer
-
- getLength() - Method in class org.apache.flink.api.common.typeutils.base.array.DoublePrimitiveArraySerializer
-
- getLength() - Method in class org.apache.flink.api.common.typeutils.base.array.FloatPrimitiveArraySerializer
-
- getLength() - Method in class org.apache.flink.api.common.typeutils.base.array.IntPrimitiveArraySerializer
-
- getLength() - Method in class org.apache.flink.api.common.typeutils.base.array.LongPrimitiveArraySerializer
-
- getLength() - Method in class org.apache.flink.api.common.typeutils.base.array.ShortPrimitiveArraySerializer
-
- getLength() - Method in class org.apache.flink.api.common.typeutils.base.array.StringArraySerializer
-
- getLength() - Method in class org.apache.flink.api.common.typeutils.base.BigDecSerializer
-
- getLength() - Method in class org.apache.flink.api.common.typeutils.base.BigIntSerializer
-
- getLength() - Method in class org.apache.flink.api.common.typeutils.base.BooleanSerializer
-
- getLength() - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueSerializer
-
- getLength() - Method in class org.apache.flink.api.common.typeutils.base.ByteSerializer
-
- getLength() - Method in class org.apache.flink.api.common.typeutils.base.ByteValueSerializer
-
- getLength() - Method in class org.apache.flink.api.common.typeutils.base.CharSerializer
-
- getLength() - Method in class org.apache.flink.api.common.typeutils.base.CharValueSerializer
-
- getLength() - Method in class org.apache.flink.api.common.typeutils.base.DateSerializer
-
- getLength() - Method in class org.apache.flink.api.common.typeutils.base.DoubleSerializer
-
- getLength() - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueSerializer
-
- getLength() - Method in class org.apache.flink.api.common.typeutils.base.EnumSerializer
-
- getLength() - Method in class org.apache.flink.api.common.typeutils.base.FloatSerializer
-
- getLength() - Method in class org.apache.flink.api.common.typeutils.base.FloatValueSerializer
-
- getLength() - Method in class org.apache.flink.api.common.typeutils.base.GenericArraySerializer
-
- getLength() - Method in class org.apache.flink.api.common.typeutils.base.IntSerializer
-
- getLength() - Method in class org.apache.flink.api.common.typeutils.base.IntValueSerializer
-
- getLength() - Method in class org.apache.flink.api.common.typeutils.base.ListSerializer
-
- getLength() - Method in class org.apache.flink.api.common.typeutils.base.LongSerializer
-
- getLength() - Method in class org.apache.flink.api.common.typeutils.base.LongValueSerializer
-
- getLength() - Method in class org.apache.flink.api.common.typeutils.base.MapSerializer
-
- getLength() - Method in class org.apache.flink.api.common.typeutils.base.NullValueSerializer
-
- getLength() - Method in class org.apache.flink.api.common.typeutils.base.ShortSerializer
-
- getLength() - Method in class org.apache.flink.api.common.typeutils.base.ShortValueSerializer
-
- getLength() - Method in class org.apache.flink.api.common.typeutils.base.SqlDateSerializer
-
- getLength() - Method in class org.apache.flink.api.common.typeutils.base.SqlTimeSerializer
-
- getLength() - Method in class org.apache.flink.api.common.typeutils.base.SqlTimestampSerializer
-
- getLength() - Method in class org.apache.flink.api.common.typeutils.base.StringSerializer
-
- getLength() - Method in class org.apache.flink.api.common.typeutils.base.StringValueSerializer
-
- getLength() - Method in class org.apache.flink.api.common.typeutils.base.VoidSerializer
-
- getLength() - Method in interface org.apache.flink.api.common.typeutils.TypeDeserializer
-
Gets the length of the data type, if it is a fix length data type.
- getLength() - Method in class org.apache.flink.api.common.typeutils.TypeDeserializerAdapter
-
- getLength() - Method in class org.apache.flink.api.common.typeutils.TypeSerializer
-
Gets the length of the data type, if it is a fix length data type.
- getLength() - Method in class org.apache.flink.api.common.typeutils.UnloadableDummyTypeSerializer
-
- getLength() - Method in class org.apache.flink.api.java.typeutils.runtime.AvroSerializer
-
Deprecated.
- getLength() - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer
-
- getLength() - Method in class org.apache.flink.api.java.typeutils.runtime.EitherSerializer
-
- getLength() - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer
-
- getLength() - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer
-
- getLength() - Method in class org.apache.flink.api.java.typeutils.runtime.RowSerializer
-
- getLength() - Method in class org.apache.flink.api.java.typeutils.runtime.Tuple0Serializer
-
- getLength() - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializerBase
-
- getLength() - Method in class org.apache.flink.api.java.typeutils.runtime.ValueSerializer
-
- getLength() - Method in class org.apache.flink.api.java.typeutils.runtime.WritableSerializer
-
- getLength() - Method in class org.apache.flink.cep.nfa.DeweyNumber.DeweyNumberSerializer
-
- getLength() - Method in class org.apache.flink.cep.nfa.NFA.NFASerializer
-
- getLength() - Method in class org.apache.flink.cep.nfa.SharedBuffer.SharedBufferSerializer
-
- getLength() - Method in interface org.apache.flink.core.fs.BlockLocation
-
Get the length of the block.
- getLength() - Method in class org.apache.flink.core.fs.FileInputSplit
-
Returns the number of bytes in the file to process.
- getLength() - Method in class org.apache.flink.core.fs.local.LocalBlockLocation
-
- getLength() - Method in class org.apache.flink.formats.avro.typeutils.AvroSerializer
-
- getLength() - Method in class org.apache.flink.formats.avro.typeutils.BackwardsCompatibleAvroSerializer
-
- getLength() - Method in class org.apache.flink.graph.drivers.transform.LongValueWithProperHashCode.LongValueWithProperHashCodeSerializer
-
- getLength() - Method in class org.apache.flink.graph.generator.CirculantGraph.OffsetRange
-
Get the range length.
- getLength() - Method in class org.apache.flink.graph.types.valuearray.ByteValueArraySerializer
-
- getLength() - Method in class org.apache.flink.graph.types.valuearray.CharValueArraySerializer
-
- getLength() - Method in class org.apache.flink.graph.types.valuearray.DoubleValueArraySerializer
-
- getLength() - Method in class org.apache.flink.graph.types.valuearray.FloatValueArraySerializer
-
- getLength() - Method in class org.apache.flink.graph.types.valuearray.IntValueArraySerializer
-
- getLength() - Method in class org.apache.flink.graph.types.valuearray.LongValueArraySerializer
-
- getLength() - Method in class org.apache.flink.graph.types.valuearray.NullValueArraySerializer
-
- getLength() - Method in class org.apache.flink.graph.types.valuearray.ShortValueArraySerializer
-
- getLength() - Method in class org.apache.flink.graph.types.valuearray.StringValueArraySerializer
-
- getLength() - Method in class org.apache.flink.queryablestate.client.VoidNamespaceSerializer
-
- getLength() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopBlockLocation
-
- getLength() - Method in class org.apache.flink.runtime.io.disk.iomanager.FileSegment
-
- getLength() - Method in class org.apache.flink.runtime.state.ArrayListSerializer
-
- getLength() - Method in class org.apache.flink.runtime.state.ChainedStateHandle
-
Returns the length of the operator chain.
- getLength() - Method in class org.apache.flink.runtime.state.VoidNamespaceSerializer
-
- getLength() - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.StateSerializer
-
- getLength() - Method in class org.apache.flink.streaming.api.operators.InternalTimer.TimerSerializer
-
- getLength() - Method in class org.apache.flink.streaming.api.windowing.windows.GlobalWindow.Serializer
-
- getLength() - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow.Serializer
-
- getLength() - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer011.ContextStateSerializer
-
- getLength() - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer011.TransactionStateSerializer
-
- getLength() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
-
- getLibraryCacheManager() - Method in class org.apache.flink.runtime.jobmaster.JobManagerSharedServices
-
- getLibraryCacheManager() - Method in class org.apache.flink.runtime.taskexecutor.JobManagerConnection
-
- getLibraryDirs() - Method in class org.apache.flink.table.client.cli.CliOptions
-
- getLibraryName() - Static method in class org.apache.hadoop.util.NativeCodeLoader
-
- getLimitForSegment(MemorySegment) - Method in class org.apache.flink.runtime.io.disk.FileChannelInputView
-
- getLimitForSegment(MemorySegment) - Method in class org.apache.flink.runtime.io.disk.iomanager.ChannelReaderInputView
-
- getLimitForSegment(MemorySegment) - Method in class org.apache.flink.runtime.io.disk.iomanager.HeaderlessChannelReaderInputView
-
- getLimitForSegment(MemorySegment) - Method in class org.apache.flink.runtime.io.disk.RandomAccessInputView
-
- getLimitForSegment(MemorySegment) - Method in class org.apache.flink.runtime.io.disk.SeekableFileChannelInputView
-
- getLimitForSegment(MemorySegment) - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
-
Gets the limit for reading bytes from the given memory segment.
- getLimitForSegment(MemorySegment) - Method in class org.apache.flink.runtime.operators.hash.HashPartition
-
- getLineLengthLimit() - Method in class org.apache.flink.api.common.io.DelimitedInputFormat
-
- getListOfInputs() - Method in class org.apache.flink.optimizer.plan.NAryUnionPlanNode
-
- getListOfTriangles() - Static method in class org.apache.flink.graph.examples.data.TriangleCountData
-
- getListState(ListStateDescriptor<T>) - Method in interface org.apache.flink.api.common.functions.RuntimeContext
-
Gets a handle to the system's key/value list state.
- getListState(ListStateDescriptor<T>) - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
-
- getListState(ListStateDescriptor<T>) - Method in interface org.apache.flink.api.common.state.KeyedStateStore
-
Gets a handle to the system's key/value list state.
- getListState(ListStateDescriptor<S>) - Method in interface org.apache.flink.api.common.state.OperatorStateStore
-
Creates (or restores) a list state.
- getListState(ListStateDescriptor<T>) - Method in class org.apache.flink.runtime.state.DefaultKeyedStateStore
-
- getListState(ListStateDescriptor<S>) - Method in class org.apache.flink.runtime.state.DefaultOperatorStateBackend
-
- getListState(ListStateDescriptor<T>) - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
-
- getListState(ListStateDescriptor<T>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.MergingWindowStateStore
-
- getLoadNativeLibraries(Configuration) - Method in class org.apache.hadoop.util.NativeCodeLoader
-
Return if native hadoop libraries, if present, can be used for this job.
- getLocalActorSystem() - Method in class org.apache.flink.mesos.runtime.clusterframework.services.AbstractMesosServices
-
- getLocalActorSystem() - Method in interface org.apache.flink.mesos.runtime.clusterframework.services.MesosServices
-
- getLocalCluster() - Static method in class org.apache.flink.storm.api.FlinkLocalCluster
-
- getLocalClusteringCoefficientScore() - Method in class org.apache.flink.graph.library.clustering.directed.LocalClusteringCoefficient.Result
-
Get the local clustering coefficient score.
- getLocalClusteringCoefficientScore() - Method in class org.apache.flink.graph.library.clustering.undirected.LocalClusteringCoefficient.Result
-
Get the local clustering coefficient score.
- getLocalFileSystem() - Static method in class org.apache.flink.core.fs.FileSystem
-
Returns a reference to the
FileSystem
instance for accessing the local file system.
- getLocalFsURI() - Static method in class org.apache.flink.core.fs.local.LocalFileSystem
-
Gets the URI that represents the local file system.
- getLocality() - Method in class org.apache.flink.runtime.instance.SharedSlot
-
- getLocality() - Method in class org.apache.flink.runtime.instance.SimpleSlot
-
Gets the locality information attached to this slot.
- getLocality() - Method in interface org.apache.flink.runtime.jobmaster.LogicalSlot
-
Gets the locality of this slot.
- getLocality() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SingleLogicalSlot
-
- getLocality() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotAndLocality
-
- getLocalKeyGroupRangeStartIdx() - Method in class org.apache.flink.streaming.api.operators.HeapInternalTimerService
-
- getLocalOrder() - Method in class org.apache.flink.api.common.operators.GenericDataSinkBase
-
Gets the order, in which the data sink writes its data locally.
- getLocalPath(String, String) - Method in class org.apache.hadoop.conf.Configuration
-
Get a local file under a directory named by dirsProp with
the given path.
- getLocalPort() - Method in class org.apache.flink.networking.NetworkFailuresProxy
-
- getLocalProperties() - Method in class org.apache.flink.optimizer.dataproperties.InterestingProperties
-
Gets the interesting local properties.
- getLocalProperties() - Method in class org.apache.flink.optimizer.plan.Channel
-
- getLocalProperties() - Method in class org.apache.flink.optimizer.plan.PlanNode
-
Gets the local properties from this PlanNode.
- getLocalProperties() - Method in class org.apache.flink.table.explain.Node
-
- getLocalRecoveryConfig() - Method in class org.apache.flink.runtime.state.heap.HeapKeyedStateBackend
-
- getLocalRecoveryConfig() - Method in class org.apache.flink.runtime.state.NoOpTaskLocalStateStoreImpl
-
- getLocalRecoveryConfig() - Method in interface org.apache.flink.runtime.state.TaskLocalStateStore
-
- getLocalRecoveryConfig() - Method in class org.apache.flink.runtime.state.TaskLocalStateStoreImpl
-
- getLocalRecoveryStateRootDirectories() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
-
- getLocalStateDirectoryProvider() - Method in class org.apache.flink.runtime.state.LocalRecoveryConfig
-
- getLocalStrategy() - Method in class org.apache.flink.optimizer.plan.Channel
-
- getLocalStrategyComparator() - Method in class org.apache.flink.optimizer.plan.Channel
-
Gets the local strategy comparator from this Channel.
- getLocalStrategyKeys() - Method in class org.apache.flink.optimizer.plan.Channel
-
- getLocalStrategySortOrder() - Method in class org.apache.flink.optimizer.plan.Channel
-
- getLocalStrategyString(LocalStrategy) - Static method in class org.apache.flink.optimizer.plantranslate.JsonMapper
-
- getLocalValue() - Method in interface org.apache.flink.api.common.accumulators.Accumulator
-
- getLocalValue() - Method in class org.apache.flink.api.common.accumulators.AverageAccumulator
-
- getLocalValue() - Method in class org.apache.flink.api.common.accumulators.DoubleCounter
-
- getLocalValue() - Method in class org.apache.flink.api.common.accumulators.DoubleMaximum
-
- getLocalValue() - Method in class org.apache.flink.api.common.accumulators.DoubleMinimum
-
- getLocalValue() - Method in class org.apache.flink.api.common.accumulators.Histogram
-
- getLocalValue() - Method in class org.apache.flink.api.common.accumulators.IntCounter
-
- getLocalValue() - Method in class org.apache.flink.api.common.accumulators.IntMaximum
-
- getLocalValue() - Method in class org.apache.flink.api.common.accumulators.IntMinimum
-
- getLocalValue() - Method in class org.apache.flink.api.common.accumulators.ListAccumulator
-
- getLocalValue() - Method in class org.apache.flink.api.common.accumulators.LongCounter
-
- getLocalValue() - Method in class org.apache.flink.api.common.accumulators.LongMaximum
-
- getLocalValue() - Method in class org.apache.flink.api.common.accumulators.LongMinimum
-
- getLocalValue() - Method in class org.apache.flink.api.common.accumulators.SerializedListAccumulator
-
- getLocalValue() - Method in class org.apache.flink.api.java.Utils.ChecksumHashCode
-
- getLocalValue() - Method in class org.apache.flink.examples.java.relational.EmptyFieldsCountAccumulator.VectorAccumulator
-
- getLocalValue() - Method in class org.apache.flink.graph.asm.dataset.ChecksumHashCode.Checksum
-
- getLocalValuePrimitive() - Method in class org.apache.flink.api.common.accumulators.DoubleCounter
-
- getLocalValuePrimitive() - Method in class org.apache.flink.api.common.accumulators.DoubleMaximum
-
- getLocalValuePrimitive() - Method in class org.apache.flink.api.common.accumulators.DoubleMinimum
-
- getLocalValuePrimitive() - Method in class org.apache.flink.api.common.accumulators.IntCounter
-
- getLocalValuePrimitive() - Method in class org.apache.flink.api.common.accumulators.IntMaximum
-
- getLocalValuePrimitive() - Method in class org.apache.flink.api.common.accumulators.IntMinimum
-
- getLocalValuePrimitive() - Method in class org.apache.flink.api.common.accumulators.LongCounter
-
- getLocalValuePrimitive() - Method in class org.apache.flink.api.common.accumulators.LongMaximum
-
- getLocalValuePrimitive() - Method in class org.apache.flink.api.common.accumulators.LongMinimum
-
- getLocation() - Method in class org.apache.flink.runtime.jobmanager.scheduler.CoLocationConstraint
-
Gets the location assigned to this slot.
- getLocation() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointInfo
-
- getLocationConstraint() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- getLocationConstraint(int) - Method in class org.apache.flink.runtime.jobmanager.scheduler.CoLocationGroup
-
- getLocationReference() - Method in interface org.apache.flink.runtime.state.CheckpointStorageLocation
-
Gets a reference to the storage location.
- getLocationReference() - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStorageLocation
-
- getLocationReference() - Method in class org.apache.flink.runtime.state.memory.NonPersistentMetadataCheckpointStorageLocation
-
- getLocationReference() - Method in class org.apache.flink.runtime.state.memory.PersistentMetadataCheckpointStorageLocation
-
- getLockPath(String) - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
-
Returns the path for the lock node relative to the given path.
- getLog2TableCapacity() - Method in class org.apache.flink.streaming.runtime.operators.windowing.KeyMap
-
- getLogicalScope(CharacterFilter) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
-
Returns the logical scope of this group, for example
"taskmanager.job.task"
.
- getLogicalScope(CharacterFilter, char) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
-
Returns the logical scope of this group, for example
"taskmanager.job.task"
.
- getLogicalScope(CharacterFilter) - Method in class org.apache.flink.runtime.metrics.groups.FrontMetricGroup
-
- getLogicalScope(CharacterFilter, char) - Method in class org.apache.flink.runtime.metrics.groups.FrontMetricGroup
-
- getLogicalScope(CharacterFilter, char) - Method in class org.apache.flink.runtime.metrics.groups.GenericValueMetricGroup
-
- getLoginContextNames() - Method in class org.apache.flink.runtime.security.SecurityConfiguration
-
- getLong(String) - Method in class org.apache.flink.api.java.utils.ParameterTool
-
Returns the Long value for the given key.
- getLong(String, long) - Method in class org.apache.flink.api.java.utils.ParameterTool
-
Returns the Long value for the given key.
- getLong(String, long) - Method in class org.apache.flink.configuration.Configuration
-
Returns the value associated with the given key as a long.
- getLong(ConfigOption<Long>) - Method in class org.apache.flink.configuration.Configuration
-
Returns the value associated with the given config option as a long integer.
- getLong(ConfigOption<Long>, long) - Method in class org.apache.flink.configuration.Configuration
-
Returns the value associated with the given config option as a long integer.
- getLong(String, long) - Method in class org.apache.flink.configuration.DelegatingConfiguration
-
- getLong(ConfigOption<Long>) - Method in class org.apache.flink.configuration.DelegatingConfiguration
-
- getLong(ConfigOption<Long>, long) - Method in class org.apache.flink.configuration.DelegatingConfiguration
-
- getLong(int) - Method in class org.apache.flink.core.memory.MemorySegment
-
Reads a long value (64bit, 8 bytes) from the given position, in the system's native byte order.
- getLong(String, long) - Method in class org.apache.flink.metrics.MetricConfig
-
Searches for the property with the specified key in this property list.
- getLong(int) - Method in class org.apache.flink.storm.wrappers.StormTuple
-
- getLong(Properties, String, long) - Static method in class org.apache.flink.util.PropertiesUtil
-
Get long from properties.
- getLong(Properties, String, long, Logger) - Static method in class org.apache.flink.util.PropertiesUtil
-
Get long from properties.
- getLong(String, long) - Method in class org.apache.hadoop.conf.Configuration
-
Get the value of the name
property as a long
.
- getLongBigEndian(int) - Method in class org.apache.flink.core.memory.MemorySegment
-
Reads a long integer value (64bit, 8 bytes) from the given position, in big endian byte order.
- getLongByField(String) - Method in class org.apache.flink.storm.wrappers.StormTuple
-
- getLongBytes(String, long) - Method in class org.apache.hadoop.conf.Configuration
-
Get the value of the name
property as a long
or
human readable format.
- getLongCounter(String) - Method in interface org.apache.flink.api.common.functions.RuntimeContext
-
Convenience function to create a counter object for longs.
- getLongCounter(String) - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
-
- getLongDescription() - Method in class org.apache.flink.graph.drivers.AdamicAdar
-
- getLongDescription() - Method in class org.apache.flink.graph.drivers.ClusteringCoefficient
-
- getLongDescription() - Method in class org.apache.flink.graph.drivers.ConnectedComponents
-
- getLongDescription() - Method in interface org.apache.flink.graph.drivers.Driver
-
A multi-line description, presented in the algorithm usage.
- getLongDescription() - Method in class org.apache.flink.graph.drivers.EdgeList
-
- getLongDescription() - Method in class org.apache.flink.graph.drivers.GraphMetrics
-
- getLongDescription() - Method in class org.apache.flink.graph.drivers.HITS
-
- getLongDescription() - Method in class org.apache.flink.graph.drivers.JaccardIndex
-
- getLongDescription() - Method in class org.apache.flink.graph.drivers.PageRank
-
- getLongDescription() - Method in class org.apache.flink.graph.drivers.TriangleListing
-
- getLongLittleEndian(int) - Method in class org.apache.flink.core.memory.MemorySegment
-
Reads a long integer value (64bit, 8 bytes) from the given position, in little endian byte order.
- getLoopTimeout(Integer) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- getLowerPart() - Method in class org.apache.flink.util.AbstractID
-
Gets the lower 64 bits of the ID.
- getMainClassName() - Method in class org.apache.flink.client.program.PackagedProgram
-
- getMainHeaderLines() - Method in class org.apache.flink.table.client.cli.CliView
-
- getMainLines() - Method in class org.apache.flink.table.client.cli.CliView
-
- getMainThreadExecutor() - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerServices
-
Gets the executor which executes in the main thread of the ResourceManager
- getMainThreadExecutor() - Method in class org.apache.flink.runtime.rpc.FencedRpcEndpoint
-
Returns a main thread executor which is bound to the currently valid fencing token.
- getMainThreadExecutor() - Method in class org.apache.flink.runtime.rpc.RpcEndpoint
-
Gets the main thread execution context.
- getManagedKeyedState() - Method in class org.apache.flink.runtime.checkpoint.OperatorSubtaskState
-
Returns a handle to the managed keyed state.
- getManagedKeyedState() - Method in class org.apache.flink.runtime.checkpoint.SubtaskState
-
- getManagedKeyedStateHandles(OperatorState, KeyGroupRange) - Static method in class org.apache.flink.runtime.checkpoint.StateAssignmentOperation
-
- getManagedOperatorState() - Method in class org.apache.flink.runtime.checkpoint.OperatorSubtaskState
-
Returns a handle to the managed operator state.
- getManagedOperatorState() - Method in class org.apache.flink.runtime.checkpoint.SubtaskState
-
- getMapFor(Map<String, String>, MetricStore) - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.AbstractMetricsHandler
-
Returns a Map containing the metrics belonging to the entity pointed to by the path parameters.
- getMapFor(Map<String, String>, MetricStore) - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.JobManagerMetricsHandler
-
- getMapFor(Map<String, String>, MetricStore) - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.JobMetricsHandler
-
- getMapFor(Map<String, String>, MetricStore) - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.JobVertexMetricsHandler
-
Deprecated.
- getMapFor(Map<String, String>, MetricStore) - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.SubtaskMetricsHandler
-
- getMapFor(Map<String, String>, MetricStore) - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.TaskManagerMetricsHandler
-
- getMapPartitionReturnTypes(MapPartitionFunction<IN, OUT>, TypeInformation<IN>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
- getMapPartitionReturnTypes(MapPartitionFunction<IN, OUT>, TypeInformation<IN>, String, boolean) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
- getMapperOptions() - Method in interface org.apache.flink.streaming.connectors.cassandra.MapperOptions
-
Returns an array of Mapper.Option
that are used configure the mapper.
- getMapReturnTypes(MapFunction<IN, OUT>, TypeInformation<IN>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
- getMapReturnTypes(MapFunction<IN, OUT>, TypeInformation<IN>, String, boolean) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
- getMapState(MapStateDescriptor<UK, UV>) - Method in interface org.apache.flink.api.common.functions.RuntimeContext
-
Gets a handle to the system's key/value map state.
- getMapState(MapStateDescriptor<UK, UV>) - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
-
- getMapState(MapStateDescriptor<UK, UV>) - Method in interface org.apache.flink.api.common.state.KeyedStateStore
-
Gets a handle to the system's key/value map state.
- getMapState(MapStateDescriptor<UK, UV>) - Method in class org.apache.flink.runtime.state.DefaultKeyedStateStore
-
- getMapState(MapStateDescriptor<UK, UV>) - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
-
- getMapState(MapStateDescriptor<UK, UV>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.MergingWindowStateStore
-
- getMarkedTime() - Method in class org.apache.flink.streaming.runtime.streamrecord.LatencyMarker
-
Returns the timestamp marked by the LatencyMarker.
- getMasterHooks() - Method in class org.apache.flink.runtime.jobgraph.tasks.JobCheckpointingSettings
-
- getMasterHookStates() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
-
- getMasterMemoryMB() - Method in class org.apache.flink.client.deployment.ClusterSpecification
-
- getMasterStates() - Method in interface org.apache.flink.runtime.checkpoint.savepoint.Savepoint
-
Gets the checkpointed states generated by the master.
- getMasterStates() - Method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV1
-
- getMasterStates() - Method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV2
-
- getMatchesFor(PT) - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
-
- getMatchFor(PT, BT) - Method in class org.apache.flink.runtime.operators.hash.AbstractHashTableProber
-
- getMatchFor(PT) - Method in class org.apache.flink.runtime.operators.hash.AbstractHashTableProber
-
- getMatchFor(PT, T) - Method in class org.apache.flink.runtime.operators.hash.CompactingHashTable.HashTableProber
-
- getMatchFor(PT) - Method in class org.apache.flink.runtime.operators.hash.CompactingHashTable.HashTableProber
-
- getMatchFor(PT, T) - Method in class org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable.HashTableProber
-
Searches the hash table for the record with the given key.
- getMatchFor(PT) - Method in class org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable.HashTableProber
-
- getMaterializationMode() - Method in class org.apache.flink.optimizer.dag.DagConnection
-
- getMax() - Method in class org.apache.flink.api.java.summarize.NumericColumnSummary
-
- getMax() - Method in class org.apache.flink.metrics.HistogramStatistics
-
Returns the maximum value of the histogram.
- getMax() - Method in interface org.apache.flink.metrics.jmx.JMXReporter.JmxHistogramMBean
-
- getMax() - Method in class org.apache.flink.runtime.metrics.DescriptiveStatisticsHistogramStatistics
-
- getMax() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedMetric
-
- getMaxBackPressureRatio() - Method in class org.apache.flink.runtime.rest.handler.legacy.backpressure.OperatorBackPressureStats
-
Returns the maximum back pressure ratio of all sub tasks.
- getMaxCapacity() - Method in interface org.apache.flink.runtime.io.network.buffer.Buffer
-
Returns the maximum size of the buffer, i.e.
- getMaxCapacity() - Method in class org.apache.flink.runtime.io.network.buffer.BufferBuilder
-
- getMaxCapacity() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
-
- getMaxCapacity() - Method in class org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
-
- getMaxCheckpointStatisticCacheEntries() - Method in class org.apache.flink.runtime.rest.handler.RestHandlerConfiguration
-
- getMaxConcurrentCheckpoints() - Method in class org.apache.flink.runtime.jobgraph.tasks.CheckpointCoordinatorConfiguration
-
- getMaxConcurrentCheckpoints() - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Gets the maximum number of checkpoint attempts that may be in progress at the same time.
- getMaxContentLength() - Method in class org.apache.flink.runtime.rest.RestClientConfiguration
-
Returns the max content length that the REST client endpoint could handle.
- getMaxContentLength() - Method in class org.apache.flink.runtime.rest.RestServerEndpointConfiguration
-
Returns the max content length that the REST server endpoint could handle.
- getMaxDepth() - Method in class org.apache.flink.optimizer.dag.DagConnection
-
- getMaxDepth() - Method in class org.apache.flink.optimizer.dag.OptimizerNode
-
- getMaxDepth() - Method in class org.apache.flink.optimizer.plan.Channel
-
- getMaxDepth(int) - Static method in class org.apache.flink.runtime.operators.sort.QuickSort
-
Deepest recursion before giving up and doing a heapsort.
- getMaxFailureRate() - Method in class org.apache.flink.api.common.restartstrategy.RestartStrategies.FailureRateRestartStrategyConfiguration
-
- getMaxFlinkTupleSize() - Method in class org.apache.flink.hcatalog.HCatInputFormatBase
-
- getMaxFlinkTupleSize() - Method in class org.apache.flink.hcatalog.java.HCatInputFormat
-
- getMaximum() - Method in class org.apache.flink.runtime.checkpoint.MinMaxAvgStats
-
Returns the maximum seen value.
- getMaximum() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.MinMaxAvgStatistics
-
- getMaximumDegree() - Method in class org.apache.flink.graph.library.metric.directed.VertexMetrics.Result
-
Get the maximum degree.
- getMaximumDegree() - Method in class org.apache.flink.graph.library.metric.undirected.VertexMetrics.Result
-
Get the maximum degree.
- getMaximumInDegree() - Method in class org.apache.flink.graph.library.metric.directed.VertexMetrics.Result
-
Get the maximum in degree.
- getMaximumNumberOfIterations() - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase
-
- getMaximumNumberOfIterations() - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase
-
- getMaximumNumberOfSplits() - Method in class org.apache.flink.util.LongValueSequenceIterator
-
- getMaximumNumberOfSplits() - Method in class org.apache.flink.util.NumberSequenceIterator
-
- getMaximumNumberOfSplits() - Method in class org.apache.flink.util.SplittableIterator
-
The maximum number of splits into which this iterator can be split up.
- getMaximumOutDegree() - Method in class org.apache.flink.graph.library.metric.directed.VertexMetrics.Result
-
Get the maximum out degree.
- getMaximumParallelism() - Method in class org.apache.flink.api.common.Plan
-
- getMaximumParallelism() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
Gets the maximum parallelism of all operations in this job graph.
- getMaximumRectangleTriplets() - Method in class org.apache.flink.graph.library.metric.directed.EdgeMetrics.Result
-
Get the maximum rectangle triplets.
- getMaximumRectangleTriplets() - Method in class org.apache.flink.graph.library.metric.undirected.EdgeMetrics.Result
-
Get the maximum rectangle triplets.
- getMaximumTriangleTriplets() - Method in class org.apache.flink.graph.library.metric.directed.EdgeMetrics.Result
-
Get the maximum triangle triplets.
- getMaximumTriangleTriplets() - Method in class org.apache.flink.graph.library.metric.undirected.EdgeMetrics.Result
-
Get the maximum triangle triplets.
- getMaximumTriplets() - Method in class org.apache.flink.graph.library.metric.directed.VertexMetrics.Result
-
Get the maximum triplets.
- getMaximumTriplets() - Method in class org.apache.flink.graph.library.metric.undirected.VertexMetrics.Result
-
Get the maximum triplets.
- getMaxIterations() - Method in class org.apache.flink.api.java.operators.DeltaIterationResultSet
-
- getMaxIterations() - Method in class org.apache.flink.api.java.operators.IterativeDataSet
-
Gets the maximum number of iterations.
- getMaxJvmHeapMemory() - Static method in class org.apache.flink.runtime.util.EnvironmentInformation
-
The maximum JVM heap size, in bytes.
- getMaxLength() - Method in class org.apache.flink.api.java.summarize.StringColumnSummary
-
Longest String length.
- getMaxNormalizedKeyLen() - Method in class org.apache.flink.graph.types.valuearray.ByteValueArray
-
- getMaxNormalizedKeyLen() - Method in class org.apache.flink.graph.types.valuearray.CharValueArray
-
- getMaxNormalizedKeyLen() - Method in class org.apache.flink.graph.types.valuearray.DoubleValueArray
-
- getMaxNormalizedKeyLen() - Method in class org.apache.flink.graph.types.valuearray.FloatValueArray
-
- getMaxNormalizedKeyLen() - Method in class org.apache.flink.graph.types.valuearray.IntValueArray
-
- getMaxNormalizedKeyLen() - Method in class org.apache.flink.graph.types.valuearray.LongValueArray
-
- getMaxNormalizedKeyLen() - Method in class org.apache.flink.graph.types.valuearray.NullValueArray
-
- getMaxNormalizedKeyLen() - Method in class org.apache.flink.graph.types.valuearray.ShortValueArray
-
- getMaxNormalizedKeyLen() - Method in class org.apache.flink.graph.types.valuearray.StringValueArray
-
- getMaxNormalizedKeyLen() - Method in class org.apache.flink.types.BooleanValue
-
- getMaxNormalizedKeyLen() - Method in class org.apache.flink.types.ByteValue
-
- getMaxNormalizedKeyLen() - Method in class org.apache.flink.types.CharValue
-
- getMaxNormalizedKeyLen() - Method in class org.apache.flink.types.IntValue
-
- getMaxNormalizedKeyLen() - Method in class org.apache.flink.types.LongValue
-
- getMaxNormalizedKeyLen() - Method in interface org.apache.flink.types.NormalizableKey
-
Gets the maximal length of normalized keys that the data type would produce to determine
the order of instances solely by the normalized key.
- getMaxNormalizedKeyLen() - Method in class org.apache.flink.types.NullValue
-
- getMaxNormalizedKeyLen() - Method in class org.apache.flink.types.ShortValue
-
- getMaxNormalizedKeyLen() - Method in class org.apache.flink.types.StringValue
-
- getMaxNumberOfMemorySegments() - Method in interface org.apache.flink.runtime.io.network.buffer.BufferPool
-
Returns the maximum number of memory segments this buffer pool should use
- getMaxNumberOfParallelSubtasks() - Method in interface org.apache.flink.api.common.functions.RuntimeContext
-
Gets the number of max-parallelism with which the parallel task runs.
- getMaxNumberOfParallelSubtasks() - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
-
- getMaxNumberOfParallelSubtasks() - Method in class org.apache.flink.api.common.TaskInfo
-
Gets the max parallelism aka the max number of subtasks.
- getMaxNumberOfRetainedCheckpoints() - Method in interface org.apache.flink.runtime.checkpoint.CompletedCheckpointStore
-
Returns the max number of retained checkpoints.
- getMaxNumberOfRetainedCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.StandaloneCompletedCheckpointStore
-
- getMaxNumberOfRetainedCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.ZooKeeperCompletedCheckpointStore
-
- getMaxNumberOfSubtaks() - Method in class org.apache.flink.runtime.executiongraph.TaskInformation
-
- getMaxNumOpenInputStreams() - Method in class org.apache.flink.core.fs.LimitedConnectionsFileSystem
-
Gets the maximum number of concurrently open input streams.
- getMaxNumOpenOutputStreams() - Method in class org.apache.flink.core.fs.LimitedConnectionsFileSystem
-
Gets the maximum number of concurrently open output streams.
- getMaxNumOpenStreamsTotal() - Method in class org.apache.flink.core.fs.LimitedConnectionsFileSystem
-
Gets the maximum number of concurrently open streams (input + output).
- getMaxOutOfOrdernessInMillis() - Method in class org.apache.flink.streaming.api.functions.timestamps.BoundedOutOfOrdernessTimestampExtractor
-
- getMaxParallelism() - Method in class org.apache.flink.api.common.ExecutionConfig
-
Gets the maximum degree of parallelism defined for the program.
- getMaxParallelism() - Method in class org.apache.flink.runtime.checkpoint.OperatorState
-
- getMaxParallelism() - Method in class org.apache.flink.runtime.checkpoint.TaskState
-
Deprecated.
- getMaxParallelism() - Method in class org.apache.flink.runtime.deployment.ResultPartitionDeploymentDescriptor
-
- getMaxParallelism() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionJobVertex
-
Returns the max parallelism for this job vertex.
- getMaxParallelism() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionJobVertex
-
- getMaxParallelism() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
- getMaxParallelism() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- getMaxParallelism() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
Gets the maximum parallelism for the task.
- getMaxParallelism() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Gets the maximum degree of parallelism defined for the program.
- getMaxParallelism() - Method in class org.apache.flink.streaming.api.transformations.StreamTransformation
-
Gets the maximum parallelism for this stream transformation.
- getMaxParallelism() - Method in class org.apache.flink.streaming.runtime.partitioner.KeyGroupStreamPartitioner
-
- getMaxParallelism() - Method in class org.apache.flink.table.client.config.Execution
-
- getMaxRegistrationDuration() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
-
- getMaxRegistrationPause() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
-
- getMaxRetryCount() - Method in class org.apache.flink.streaming.connectors.elasticsearch.ElasticsearchSinkBase.BulkFlushBackoffPolicy
-
- getMaxSlots() - Method in class org.apache.flink.client.program.ClusterClient
-
The client may define an upper limit on the number of slots to use.
- getMaxSlots() - Method in class org.apache.flink.client.program.MiniClusterClient
-
- getMaxSlots() - Method in class org.apache.flink.client.program.rest.RestClusterClient
-
- getMaxSlots() - Method in class org.apache.flink.client.program.StandaloneClusterClient
-
- getMaxSlots() - Method in class org.apache.flink.yarn.YarnClusterClient
-
- getMaxStateRetention() - Method in class org.apache.flink.table.client.config.Execution
-
- getMaxStateSize() - Method in class org.apache.flink.runtime.state.memory.MemoryBackendCheckpointStorage
-
Gets the size (in bytes) that a individual chunk of state may have at most.
- getMaxStateSize() - Method in class org.apache.flink.runtime.state.memory.MemoryStateBackend
-
Gets the maximum size that an individual state can have, as configured in the
constructor (by default
5242880).
- getMean() - Method in class org.apache.flink.api.java.summarize.NumericColumnSummary
-
Null, NaN, and Infinite values are ignored in this calculation.
- getMean() - Method in class org.apache.flink.metrics.HistogramStatistics
-
Returns the mean of the histogram values.
- getMean() - Method in interface org.apache.flink.metrics.jmx.JMXReporter.JmxHistogramMBean
-
- getMean() - Method in class org.apache.flink.runtime.metrics.DescriptiveStatisticsHistogramStatistics
-
- getMeanLength() - Method in class org.apache.flink.api.java.summarize.StringColumnSummary
-
- getMeanRate() - Method in class org.apache.flink.dropwizard.metrics.FlinkMeterWrapper
-
- getMebiBytes() - Method in class org.apache.flink.configuration.MemorySize
-
Gets the memory size in Mebibytes (= 1024 Kibibytes).
- getMedian() - Method in interface org.apache.flink.metrics.jmx.JMXReporter.JmxHistogramMBean
-
- getMemoryConsumerWeight() - Method in class org.apache.flink.optimizer.plan.BinaryUnionPlanNode
-
- getMemoryConsumerWeight() - Method in class org.apache.flink.optimizer.plan.BulkIterationPlanNode
-
- getMemoryConsumerWeight() - Method in class org.apache.flink.optimizer.plan.PlanNode
-
- getMemoryConsumerWeight() - Method in class org.apache.flink.optimizer.plan.WorksetIterationPlanNode
-
- getMemoryFraction() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
-
- getMemoryInMB() - Method in class org.apache.flink.runtime.clusterframework.types.ResourceProfile
-
Get the total memory needed in MB.
- getMemoryManager() - Method in interface org.apache.flink.runtime.execution.Environment
-
- getMemoryManager() - Method in class org.apache.flink.runtime.operators.BatchTask
-
- getMemoryManager() - Method in interface org.apache.flink.runtime.operators.TaskContext
-
- getMemoryManager() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServices
-
- getMemoryManager() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
-
- getMemoryPoolStatsAsString(List<MemoryPoolMXBean>) - Static method in class org.apache.flink.runtime.taskmanager.MemoryLogger
-
Gets the memory pool statistics from the JVM.
- getMemorySegment() - Method in interface org.apache.flink.runtime.io.network.buffer.Buffer
-
Deprecated.
- getMemorySegment() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
-
- getMemorySegment() - Method in class org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
-
Returns the underlying memory segment.
- getMemorySegment() - Method in class org.apache.flink.runtime.operators.util.BloomFilter.BitSet
-
- getMemorySegmentOffset() - Method in interface org.apache.flink.runtime.io.network.buffer.Buffer
-
Deprecated.
- getMemorySegmentOffset() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
-
- getMemorySegmentOffset() - Method in class org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
-
- getMemorySegmentSize() - Method in interface org.apache.flink.runtime.io.network.buffer.BufferProvider
-
Returns the size of the underlying memory segments.
- getMemorySegmentSize() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
-
- getMemorySize() - Method in class org.apache.flink.runtime.memory.MemoryManager
-
Returns the total size of memory handled by this memory manager.
- getMemoryType() - Method in class org.apache.flink.runtime.memory.MemoryManager
-
Gets the type of memory (heap / off-heap) managed by this memory manager.
- getMemoryType() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
-
Returns the memory type to use.
- getMemoryUsageStatsAsString(MemoryMXBean) - Static method in class org.apache.flink.runtime.taskmanager.MemoryLogger
-
Gets the memory footprint of the JVM in a string representation.
- getMergedEnvironment() - Method in class org.apache.flink.table.client.gateway.local.ExecutionContext
-
- getMergingIterator(List<UnilateralSortMerger.ChannelWithBlockCount>, List<List<MemorySegment>>, List<FileIOChannel>, MutableObjectIterator<E>) - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SpillingThread
-
Returns an iterator that iterates over the merged result from all given channels.
- getMergingWindowSet() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
- getMessage() - Method in exception org.apache.flink.runtime.io.network.partition.PartitionNotFoundException
-
- getMessage() - Static method in class org.apache.flink.runtime.taskmanager.TaskManager
-
- getMessageHeaders() - Method in class org.apache.flink.runtime.rest.handler.AbstractRestHandler
-
- getMessageId() - Method in class org.apache.flink.storm.wrappers.StormTuple
-
- getMetadataFilePath() - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStorageLocation
-
- getMetadataHandle() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
-
- getMetadataHandle() - Method in interface org.apache.flink.runtime.state.CompletedCheckpointStorageLocation
-
Gets the state handle to the checkpoint's metadata.
- getMetadataHandle() - Method in class org.apache.flink.runtime.state.filesystem.FsCompletedCheckpointStorageLocation
-
- getMetaDataState() - Method in class org.apache.flink.runtime.state.IncrementalLocalKeyedStateHandle
-
- getMetaInfo() - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateTable
-
- getMetaInfo() - Method in class org.apache.flink.runtime.state.heap.StateTable
-
- getMetaStateHandle() - Method in class org.apache.flink.runtime.state.IncrementalKeyedStateHandle
-
- getMethodName() - Method in class org.apache.flink.runtime.rpc.messages.LocalRpcInvocation
-
- getMethodName() - Method in class org.apache.flink.runtime.rpc.messages.RemoteRpcInvocation
-
- getMethodName() - Method in interface org.apache.flink.runtime.rpc.messages.RpcInvocation
-
Returns the method's name.
- getMetric() - Method in class org.apache.flink.metrics.datadog.DMetric
-
- getMetric(String) - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.MetricStore.ComponentMetricStore
-
- getMetric(String, String) - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.MetricStore.ComponentMetricStore
-
- getMetricGroup() - Method in interface org.apache.flink.api.common.functions.RuntimeContext
-
Returns the metric group for this parallel subtask.
- getMetricGroup() - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
-
- getMetricGroup() - Method in interface org.apache.flink.runtime.execution.Environment
-
Returns the task specific metric group.
- getMetricGroup() - Method in class org.apache.flink.runtime.operators.BatchTask
-
- getMetricGroup() - Method in interface org.apache.flink.runtime.operators.TaskContext
-
- getMetricGroup() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
-
- getMetricGroup() - Method in class org.apache.flink.runtime.taskmanager.Task
-
- getMetricGroup() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- getMetricGroup() - Method in interface org.apache.flink.streaming.api.operators.StreamOperator
-
- getMetricGroup() - Method in interface org.apache.flink.streaming.api.windowing.evictors.Evictor.EvictorContext
-
Returns the metric group for this
Evictor
.
- getMetricGroup() - Method in interface org.apache.flink.streaming.api.windowing.triggers.Trigger.TriggerContext
-
Returns the metric group for this
Trigger
.
- getMetricGroup() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
-
- getMetricIdentifier(String) - Method in class org.apache.flink.metrics.groups.UnregisteredMetricsGroup
-
- getMetricIdentifier(String, CharacterFilter) - Method in class org.apache.flink.metrics.groups.UnregisteredMetricsGroup
-
- getMetricIdentifier(String) - Method in interface org.apache.flink.metrics.MetricGroup
-
Returns the fully qualified metric name, for example
"host-7.taskmanager-2.window_word_count.my-mapper.metricName"
.
- getMetricIdentifier(String, CharacterFilter) - Method in interface org.apache.flink.metrics.MetricGroup
-
Returns the fully qualified metric name, for example
"host-7.taskmanager-2.window_word_count.my-mapper.metricName"
.
- getMetricIdentifier(String) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
-
Returns the fully qualified metric name, for example
"host-7.taskmanager-2.window_word_count.my-mapper.metricName"
.
- getMetricIdentifier(String, CharacterFilter) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
-
Returns the fully qualified metric name, for example
"host-7.taskmanager-2.window_word_count.my-mapper.metricName"
.
- getMetricIdentifier(String, CharacterFilter, int) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
-
Returns the fully qualified metric name using the configured delimiter for the reporter with the given index, for example
"host-7.taskmanager-2.window_word_count.my-mapper.metricName"
.
- getMetricIdentifier(String) - Method in class org.apache.flink.runtime.metrics.groups.FrontMetricGroup
-
- getMetricIdentifier(String, CharacterFilter) - Method in class org.apache.flink.runtime.metrics.groups.FrontMetricGroup
-
- getMetricIdentifier(String) - Method in class org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
-
- getMetricIdentifier(String, CharacterFilter) - Method in class org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
-
- getMetricQueryServicePath() - Method in interface org.apache.flink.runtime.metrics.MetricRegistry
-
- getMetricQueryServicePath() - Method in class org.apache.flink.runtime.metrics.MetricRegistryImpl
-
- getMetricQueryServicePath() - Method in class org.apache.flink.runtime.metrics.NoOpMetricRegistry
-
- getMetrics() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedMetricsResponseBody
-
- getMetrics() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.MetricCollectionResponseBody
-
- getMetricStore() - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.MetricFetcher
-
Returns the MetricStore containing all stored metrics.
- getMetricValue() - Method in class org.apache.flink.metrics.datadog.DCounter
-
Visibility of this method must not be changed
since we deliberately not map it to json object in a Datadog-defined format.
- getMetricValue() - Method in class org.apache.flink.metrics.datadog.DGauge
-
Visibility of this method must not be changed
since we deliberately not map it to json object in a Datadog-defined format.
- getMetricValue() - Method in class org.apache.flink.metrics.datadog.DMeter
-
- getMetricValue() - Method in class org.apache.flink.metrics.datadog.DMetric
-
- getMimeTypeForExtension(String) - Static method in class org.apache.flink.runtime.rest.handler.util.MimeTypes
-
Gets the MIME type for the file with the given extension.
- getMimeTypeForFileName(String) - Static method in class org.apache.flink.runtime.rest.handler.util.MimeTypes
-
Gets the MIME type for the file with the given name, by extension.
- getMin() - Method in class org.apache.flink.api.java.summarize.NumericColumnSummary
-
- getMin() - Method in class org.apache.flink.metrics.HistogramStatistics
-
Returns the minimum value of the histogram.
- getMin() - Method in interface org.apache.flink.metrics.jmx.JMXReporter.JmxHistogramMBean
-
- getMin() - Method in class org.apache.flink.runtime.metrics.DescriptiveStatisticsHistogramStatistics
-
- getMin() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedMetric
-
- getMinFileSizeThreshold() - Method in class org.apache.flink.runtime.state.filesystem.FsStateBackend
-
Gets the threshold below which state is stored as part of the metadata, rather than in files.
- getMiniClusterType() - Method in class org.apache.flink.test.util.MiniClusterResource
-
- getMinimalMemoryAcrossAllSubTasks() - Method in class org.apache.flink.optimizer.dag.OptimizerNode
-
Gets the amount of memory that all subtasks of this task have jointly available.
- getMinimum() - Method in class org.apache.flink.runtime.checkpoint.MinMaxAvgStats
-
Returns the minimum seen value.
- getMinimum() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.MinMaxAvgStatistics
-
- getMinimumCyclesPerBlock() - Method in class org.apache.flink.graph.generator.random.GeneratorFactoryBase
-
- getMinimumCyclesPerBlock() - Method in class org.apache.flink.graph.generator.random.JDKRandomGeneratorFactory
-
- getMinimumCyclesPerBlock() - Method in class org.apache.flink.graph.generator.random.MersenneTwisterFactory
-
- getMinLength() - Method in class org.apache.flink.api.java.summarize.StringColumnSummary
-
Shortest String length.
- getMinOffloadingSize() - Method in class org.apache.flink.runtime.blob.BlobServer
-
Returns the configuration used by the BLOB server.
- getMinOffloadingSize() - Method in interface org.apache.flink.runtime.blob.BlobWriter
-
Returns the min size before data will be offloaded to the BLOB store.
- getMinOffloadingSize() - Method in class org.apache.flink.runtime.blob.VoidBlobWriter
-
- getMinPauseBetweenCheckpoints() - Method in class org.apache.flink.runtime.jobgraph.tasks.CheckpointCoordinatorConfiguration
-
- getMinPauseBetweenCheckpoints() - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Gets the minimal pause between checkpointing attempts.
- getMinResources() - Method in class org.apache.flink.api.common.operators.Operator
-
Gets the minimum resources for this operator.
- getMinResources() - Method in class org.apache.flink.api.java.operators.DataSink
-
Returns the minimum resources of this data sink.
- getMinResources() - Method in class org.apache.flink.api.java.operators.DeltaIteration
-
Gets the minimum resources from this iteration.
- getMinResources() - Method in class org.apache.flink.api.java.operators.Operator
-
Returns the minimum resource of this operator.
- getMinResources() - Method in class org.apache.flink.optimizer.plan.PlanNode
-
- getMinResources() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
Gets the minimum resource for the task.
- getMinResources() - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Gets the minimum resources for this operator.
- getMinResources() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getMinResources() - Method in class org.apache.flink.streaming.api.transformations.StreamTransformation
-
Gets the minimum resource of this stream transformation.
- getMinSplitSize() - Method in class org.apache.flink.api.common.io.FileInputFormat
-
- getMinStateRetention() - Method in class org.apache.flink.table.client.config.Execution
-
- getMismatches(ExecutionEnvironment) - Static method in class org.apache.flink.graph.examples.data.MusicProfilesData
-
- getMissingArguments() - Method in exception org.apache.flink.api.java.utils.RequiredParametersException
-
- getMissingCount() - Method in class org.apache.flink.api.java.summarize.NumericColumnSummary
-
The number of "missing" values where "missing" is defined as null, NaN, or Infinity.
- getMktsegment() - Method in class org.apache.flink.examples.java.relational.TPCHQuery3.Customer
-
- getModificationTime() - Method in interface org.apache.flink.core.fs.FileStatus
-
Get the modification time of the file.
- getModificationTime() - Method in class org.apache.flink.core.fs.local.LocalFileStatus
-
- getModificationTime() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileStatus
-
- getModificationTime() - Method in class org.apache.flink.streaming.api.functions.source.TimestampedFileInputSplit
-
- getMultipartFileUploads(ChannelHandlerContext) - Static method in class org.apache.flink.runtime.rest.FileUploadHandler
-
- getMutableObjectMode() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getName() - Method in class org.apache.flink.api.common.aggregators.AggregatorWithName
-
Gets the name that the aggregator is registered under.
- getName() - Method in class org.apache.flink.api.common.operators.Operator
-
Gets the name of the contract instance.
- getName() - Method in class org.apache.flink.api.common.resources.Resource
-
- getName() - Method in class org.apache.flink.api.common.state.StateDescriptor
-
Returns the name of this StateDescriptor
.
- getName() - Method in class org.apache.flink.api.java.operators.DeltaIteration
-
Gets the name from this iteration.
- getName() - Method in class org.apache.flink.api.java.operators.Operator
-
Returns the name of the operator.
- getName() - Method in class org.apache.flink.api.java.typeutils.TypeExtractionUtils.LambdaExecutable
-
- getName() - Method in class org.apache.flink.api.java.utils.Option
-
- getName() - Method in class org.apache.flink.cep.nfa.State
-
- getName() - Method in class org.apache.flink.cep.pattern.Pattern
-
- getName() - Method in class org.apache.flink.core.fs.Path
-
Returns the final component of this path, i.e., everything that follows the last separator.
- getName() - Method in class org.apache.flink.graph.drivers.input.InputBase
-
- getName() - Method in interface org.apache.flink.graph.drivers.parameter.Parameterized
-
A unique, human-readable identifier.
- getName() - Method in class org.apache.flink.graph.drivers.parameter.ParameterizedBase
-
- getName(String) - Method in class org.apache.flink.graph.IterationConfiguration
-
Gets the name of the iteration.
- getName() - Method in class org.apache.flink.graph.Runner
-
- getName() - Method in class org.apache.flink.optimizer.plan.NamedChannel
-
- getName() - Method in class org.apache.flink.runtime.accumulators.StringifiedAccumulatorResult
-
- getName() - Method in class org.apache.flink.runtime.broadcast.BroadcastVariableKey
-
- getName() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionJobVertex
-
Returns the name for this job vertex.
- getName() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionJobVertex
-
- getName() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
- getName() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
Returns the name assigned to the job graph.
- getName() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
Returns the name of the vertex.
- getName() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
-
- getName() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
-
- getName() - Method in class org.apache.flink.runtime.rest.messages.JobAccumulatorsInfo.UserTaskAccumulator
-
- getName() - Method in class org.apache.flink.runtime.state.RegisteredBroadcastBackendStateMetaInfo
-
- getName() - Method in class org.apache.flink.runtime.state.RegisteredBroadcastBackendStateMetaInfo.Snapshot
-
- getName() - Method in class org.apache.flink.runtime.state.RegisteredKeyedBackendStateMetaInfo
-
- getName() - Method in class org.apache.flink.runtime.state.RegisteredKeyedBackendStateMetaInfo.Snapshot
-
- getName() - Method in class org.apache.flink.runtime.state.RegisteredOperatorBackendStateMetaInfo
-
- getName() - Method in class org.apache.flink.runtime.state.RegisteredOperatorBackendStateMetaInfo.Snapshot
-
- getName() - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
-
Gets the name of the current data stream.
- getName() - Method in class org.apache.flink.streaming.api.transformations.StreamTransformation
-
Returns the name of this StreamTransformation
.
- getName() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
Gets the name of the task, in the form "taskname (2/5)".
- getName() - Method in class org.apache.flink.table.client.config.Source
-
- getName() - Method in class org.apache.flink.table.client.gateway.SessionContext
-
- getNamespace() - Method in interface org.apache.flink.runtime.state.heap.StateEntry
-
Returns the namespace of this entry.
- getNamespace() - Method in class org.apache.flink.streaming.api.operators.InternalTimer
-
- getNamespaceSerializer() - Method in class org.apache.flink.contrib.streaming.state.RocksDBAggregatingState
-
- getNamespaceSerializer() - Method in class org.apache.flink.contrib.streaming.state.RocksDBFoldingState
-
Deprecated.
- getNamespaceSerializer() - Method in class org.apache.flink.contrib.streaming.state.RocksDBListState
-
- getNamespaceSerializer() - Method in class org.apache.flink.contrib.streaming.state.RocksDBMapState
-
- getNamespaceSerializer() - Method in class org.apache.flink.contrib.streaming.state.RocksDBReducingState
-
- getNamespaceSerializer() - Method in class org.apache.flink.contrib.streaming.state.RocksDBValueState
-
- getNamespaceSerializer() - Method in class org.apache.flink.runtime.query.KvStateInfo
-
- getNamespaceSerializer() - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateTable
-
- getNamespaceSerializer() - Method in class org.apache.flink.runtime.state.heap.HeapAggregatingState
-
- getNamespaceSerializer() - Method in class org.apache.flink.runtime.state.heap.HeapFoldingState
-
Deprecated.
- getNamespaceSerializer() - Method in class org.apache.flink.runtime.state.heap.HeapListState
-
- getNamespaceSerializer() - Method in class org.apache.flink.runtime.state.heap.HeapMapState
-
- getNamespaceSerializer() - Method in class org.apache.flink.runtime.state.heap.HeapReducingState
-
- getNamespaceSerializer() - Method in class org.apache.flink.runtime.state.heap.HeapValueState
-
- getNamespaceSerializer() - Method in class org.apache.flink.runtime.state.heap.StateTable
-
- getNamespaceSerializer() - Method in interface org.apache.flink.runtime.state.internal.InternalKvState
-
Returns the
TypeSerializer
for the type of namespace this state is associated to.
- getNamespaceSerializer() - Method in class org.apache.flink.runtime.state.RegisteredKeyedBackendStateMetaInfo
-
- getNamespaceSerializer() - Method in class org.apache.flink.runtime.state.RegisteredKeyedBackendStateMetaInfo.Snapshot
-
- getNamespaceSerializer() - Method in class org.apache.flink.streaming.api.operators.InternalTimersSnapshot
-
- getNamespaceSerializerConfigSnapshot() - Method in class org.apache.flink.runtime.state.RegisteredKeyedBackendStateMetaInfo.Snapshot
-
- getNamespaceSerializerConfigSnapshot() - Method in class org.apache.flink.streaming.api.operators.InternalTimersSnapshot
-
- getNanCount() - Method in class org.apache.flink.api.java.summarize.NumericColumnSummary
-
Number of values that are NaN.
- getNativeMemory() - Method in class org.apache.flink.api.common.operators.ResourceSpec
-
- getNativeMemoryInMB() - Method in class org.apache.flink.runtime.clusterframework.types.ResourceProfile
-
Get the native memory needed in MB.
- getNeighborValue() - Method in class org.apache.flink.graph.gsa.Neighbor
-
- getNestedDelta(double[], double[]) - Method in class org.apache.flink.streaming.api.functions.windowing.delta.CosineDistance
-
- getNestedDelta(double[], double[]) - Method in class org.apache.flink.streaming.api.functions.windowing.delta.EuclideanDistance
-
- getNestedDelta(TO, TO) - Method in class org.apache.flink.streaming.api.functions.windowing.delta.ExtractionAwareDeltaFunction
-
- getNestedFileEnumeration() - Method in class org.apache.flink.api.common.io.FileInputFormat
-
- getNestedSerializersAndConfigs() - Method in class org.apache.flink.api.common.typeutils.CompositeTypeSerializerConfigSnapshot
-
- getNestedTrigger() - Method in class org.apache.flink.streaming.api.windowing.triggers.PurgingTrigger
-
- getNetRuntime() - Method in class org.apache.flink.api.common.JobExecutionResult
-
Gets the net execution time of the job, i.e., the execution time in the parallel system,
without the pre-flight steps like the optimizer.
- getNetRuntime(TimeUnit) - Method in class org.apache.flink.api.common.JobExecutionResult
-
Gets the net execution time of the job, i.e., the execution time in the parallel system,
without the pre-flight steps like the optimizer in a desired time unit.
- getNetRuntime() - Method in class org.apache.flink.client.program.DetachedEnvironment.DetachedJobExecutionResult
-
- getNetRuntime() - Method in class org.apache.flink.runtime.client.SerializedJobExecutionResult
-
- getNetRuntime(TimeUnit) - Method in class org.apache.flink.runtime.client.SerializedJobExecutionResult
-
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() - Method in class org.apache.flink.runtime.jobmaster.JobResult
-
- getNettyHttpMethod() - Method in enum org.apache.flink.runtime.rest.HttpMethodWrapper
-
- getNetworkBufferPool() - Method in class org.apache.flink.runtime.io.network.NetworkEnvironment
-
- getNetworkConfig() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
-
- getNetworkCost() - Method in class org.apache.flink.optimizer.costs.Costs
-
Gets the network cost.
- getNetworkEnvironment() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServices
-
- getNetworkMemoryInMB() - Method in class org.apache.flink.runtime.clusterframework.types.ResourceProfile
-
Get the memory needed for task to communicate with its upstreams and downstreams in MB.
- getNetworkRecoveryInterval() - Method in class org.apache.flink.streaming.connectors.rabbitmq.common.RMQConnectionConfig
-
Returns automatic connection recovery interval in milliseconds.
- getNewInMemoryPartition(int, int) - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
-
Returns a new inMemoryPartition object.
- getNewInMemoryPartition(int, int) - Method in class org.apache.flink.runtime.operators.hash.ReOpenableMutableHashTable
-
- getNewIterationNodeId() - Static method in class org.apache.flink.streaming.api.graph.StreamGraphGenerator
-
- getNewKeys() - Method in class org.apache.hadoop.conf.Configuration.DeprecationDelta
-
- getNewMessages() - Method in class org.apache.flink.client.program.ClusterClient
-
May return new messages from the cluster.
- getNewMessages() - Method in class org.apache.flink.client.program.MiniClusterClient
-
- getNewMessages() - Method in class org.apache.flink.client.program.rest.RestClusterClient
-
- getNewMessages() - Method in class org.apache.flink.client.program.StandaloneClusterClient
-
- getNewMessages() - Method in class org.apache.flink.yarn.YarnClusterClient
-
- getNewNodeId() - Static method in class org.apache.flink.streaming.api.transformations.StreamTransformation
-
- getNewSlotForSharingGroup(ExecutionVertex, Iterable<TaskManagerLocation>, SlotSharingGroupAssignment, CoLocationConstraint, boolean) - Method in class org.apache.flink.runtime.jobmanager.scheduler.Scheduler
-
Tries to allocate a new slot for a vertex that is part of a slot sharing group.
- getNewType() - Method in exception org.apache.flink.optimizer.postpass.ConflictingFieldTypeInfoException
-
- getNext() - Method in interface org.apache.flink.streaming.runtime.io.BufferOrEventSequence
-
Gets the next BufferOrEvent from the sequence, or null
, if the
sequence is exhausted.
- getNext() - Method in class org.apache.flink.streaming.runtime.io.BufferSpiller.SpilledBufferOrEventSequence
-
Deprecated.
- getNext() - Method in class org.apache.flink.streaming.runtime.io.CachedBufferBlocker.CachedBufferOrEventSequence
-
- getNextBucketPath(Path) - Method in interface org.apache.flink.streaming.connectors.fs.Bucketer
-
Deprecated.
Returns the Path
of a new bucket file.
- getNextBucketPath(Path) - Method in class org.apache.flink.streaming.connectors.fs.DateTimeBucketer
-
Deprecated.
- getNextBucketPath(Path) - Method in class org.apache.flink.streaming.connectors.fs.NonRollingBucketer
-
Deprecated.
- getNextBuffer() - Method in interface org.apache.flink.runtime.io.network.NetworkSequenceViewReader
-
- getNextBuffer() - Method in interface org.apache.flink.runtime.io.network.partition.ResultSubpartitionView
-
Returns the next
Buffer
instance of this queue iterator.
- getNextBufferOrEvent() - Method in interface org.apache.flink.runtime.io.network.partition.consumer.InputGate
-
- getNextBufferOrEvent() - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
-
- getNextBufferOrEvent() - Method in class org.apache.flink.runtime.io.network.partition.consumer.UnionInputGate
-
- getNextInputSplit(String, int) - Method in class org.apache.flink.api.common.io.DefaultInputSplitAssigner
-
- getNextInputSplit(String, int) - Method in class org.apache.flink.api.common.io.LocatableInputSplitAssigner
-
- getNextInputSplit(String, int) - Method in class org.apache.flink.api.common.io.ReplicatingInputSplitAssigner
-
- getNextInputSplit(String, int) - Method in interface org.apache.flink.core.io.InputSplitAssigner
-
Returns the next input split that shall be consumed.
- getNextInputSplit(ClassLoader) - Method in interface org.apache.flink.runtime.jobgraph.tasks.InputSplitProvider
-
Requests the next input split to be consumed by the calling task.
- getNextInputSplit(ClassLoader) - Method in class org.apache.flink.runtime.taskexecutor.rpc.RpcInputSplitProvider
-
- getNextInputSplit(ClassLoader) - Method in class org.apache.flink.runtime.taskmanager.TaskInputSplitProvider
-
- getNextNonBlocked() - Method in class org.apache.flink.streaming.runtime.io.BarrierBuffer
-
- getNextNonBlocked() - Method in class org.apache.flink.streaming.runtime.io.BarrierTracker
-
- getNextNonBlocked() - Method in interface org.apache.flink.streaming.runtime.io.CheckpointBarrierHandler
-
- getNextPartialSolution() - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase
-
- getNextPartialSolution() - Method in class org.apache.flink.api.java.operators.BulkIterationResultSet
-
- getNextPartialSolution() - Method in class org.apache.flink.optimizer.dag.BulkIterationNode
-
Gets the nextPartialSolution from this BulkIterationNode.
- getNextPathNum() - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManager
-
- getNextRecord(T) - Method in interface org.apache.flink.runtime.io.network.api.serialization.RecordDeserializer
-
- getNextRecord(T) - Method in class org.apache.flink.runtime.io.network.api.serialization.SpillingAdaptiveSpanningRecordDeserializer
-
- getNextReturnedBlock() - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBlockReader
-
Gets the next memory segment that has been filled with data by the reader.
- getNextReturnedBlock() - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBlockWriter
-
Gets the next memory segment that has been written and is available again.
- getNextReturnedBlock() - Method in interface org.apache.flink.runtime.io.disk.iomanager.BlockChannelReader
-
Gets the next memory segment that has been filled with data by the reader.
- getNextReturnedBlock() - Method in interface org.apache.flink.runtime.io.disk.iomanager.BlockChannelWriter
-
Gets the next memory segment that has been written and is available again.
- getNextSolutionSet() - Method in class org.apache.flink.api.java.operators.DeltaIterationResultSet
-
- getNextWorkset() - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase
-
Gets the contract that has been set as the next workset.
- getNextWorkset() - Method in class org.apache.flink.api.java.operators.DeltaIterationResultSet
-
- getNextWorkset() - Method in class org.apache.flink.optimizer.dag.WorksetIterationNode
-
- getNextWorkSetPlanNode() - Method in class org.apache.flink.optimizer.plan.WorksetIterationPlanNode
-
- getNioBuffer(int, int) - Method in interface org.apache.flink.runtime.io.network.buffer.Buffer
-
Gets a new
ByteBuffer
instance wrapping this buffer's bytes.
- getNioBuffer(int, int) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
-
- getNioBuffer(int, int) - Method in class org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
-
- getNioBufferReadable() - Method in interface org.apache.flink.runtime.io.network.buffer.Buffer
-
Gets a new
ByteBuffer
instance wrapping this buffer's readable bytes, i.e.
- getNioBufferReadable() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
-
- getNioBufferReadable() - Method in class org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
-
- getNioFileChannel() - Method in class org.apache.flink.runtime.io.disk.iomanager.AbstractFileIOChannel
-
- getNioFileChannel() - Method in interface org.apache.flink.runtime.io.disk.iomanager.FileIOChannel
-
- getNodeCosts() - Method in class org.apache.flink.optimizer.plan.PlanNode
-
Gets the costs incurred by this node.
- getNodeName() - Method in class org.apache.flink.optimizer.operators.AbstractSortMergeJoinDescriptor
-
- getNodeName() - Method in class org.apache.flink.optimizer.operators.SortMergeFullOuterJoinDescriptor
-
- getNodeName() - Method in class org.apache.flink.optimizer.operators.SortMergeInnerJoinDescriptor
-
- getNodeName() - Method in class org.apache.flink.optimizer.operators.SortMergeLeftOuterJoinDescriptor
-
- getNodeName() - Method in class org.apache.flink.optimizer.operators.SortMergeRightOuterJoinDescriptor
-
- getNodeName() - Method in class org.apache.flink.optimizer.plan.PlanNode
-
Gets the name of the plan node.
- getNonChainedOutputs(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getNonMissingCount() - Method in class org.apache.flink.api.java.summarize.NumericColumnSummary
-
The number of values that are not null, NaN, or Infinity.
- getNonNullCount() - Method in class org.apache.flink.api.java.summarize.BooleanColumnSummary
-
The number of non-null values in this column.
- getNonNullCount() - Method in class org.apache.flink.api.java.summarize.ColumnSummary
-
The number of non-null values in this column.
- getNonNullCount() - Method in class org.apache.flink.api.java.summarize.NumericColumnSummary
-
The number of non-null values in this column.
- getNonNullCount() - Method in class org.apache.flink.api.java.summarize.ObjectColumnSummary
-
The number of non-null values in this column.
- getNonNullCount() - Method in class org.apache.flink.api.java.summarize.StringColumnSummary
-
- getNonRegisteredSubclassesToSerializerConfigSnapshots() - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer.PojoSerializerConfigSnapshot
-
- getNonReusingOuterJoinIterator(DriverStrategy, MutableObjectIterator<IT1>, MutableObjectIterator<IT2>, TypeSerializer<IT1>, TypeComparator<IT1>, TypeSerializer<IT2>, TypeComparator<IT2>, TypePairComparatorFactory<IT1, IT2>, MemoryManager, IOManager, double) - Method in class org.apache.flink.runtime.operators.AbstractOuterJoinDriver
-
- getNonReusingOuterJoinIterator(DriverStrategy, MutableObjectIterator<IT1>, MutableObjectIterator<IT2>, TypeSerializer<IT1>, TypeComparator<IT1>, TypeSerializer<IT2>, TypeComparator<IT2>, TypePairComparatorFactory<IT1, IT2>, MemoryManager, IOManager, double) - Method in class org.apache.flink.runtime.operators.FullOuterJoinDriver
-
- getNonReusingOuterJoinIterator(DriverStrategy, MutableObjectIterator<IT1>, MutableObjectIterator<IT2>, TypeSerializer<IT1>, TypeComparator<IT1>, TypeSerializer<IT2>, TypeComparator<IT2>, TypePairComparatorFactory<IT1, IT2>, MemoryManager, IOManager, double) - Method in class org.apache.flink.runtime.operators.LeftOuterJoinDriver
-
- getNonReusingOuterJoinIterator(DriverStrategy, MutableObjectIterator<IT1>, MutableObjectIterator<IT2>, TypeSerializer<IT1>, TypeComparator<IT1>, TypeSerializer<IT2>, TypeComparator<IT2>, TypePairComparatorFactory<IT1, IT2>, MemoryManager, IOManager, double) - Method in class org.apache.flink.runtime.operators.RightOuterJoinDriver
-
- getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.array.PrimitiveArrayComparator
-
- getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.BigDecComparator
-
- getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.BigIntComparator
-
- getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.BooleanComparator
-
- getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueComparator
-
- getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.ByteComparator
-
- getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.ByteValueComparator
-
- getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.CharComparator
-
- getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.CharValueComparator
-
- getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.DateComparator
-
- getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.DoubleComparator
-
- getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueComparator
-
- getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.EnumComparator
-
- getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.FloatComparator
-
- getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.FloatValueComparator
-
- getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.IntComparator
-
- getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.IntValueComparator
-
- getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.LongComparator
-
- getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.LongValueComparator
-
- getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.NullValueComparator
-
- getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.ShortComparator
-
- getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.ShortValueComparator
-
- getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.SqlTimestampComparator
-
- getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.StringComparator
-
- getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.StringValueComparator
-
- getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.TypeComparator
-
Gets the number of bytes that the normalized key would maximally take.
- getNormalizeKeyLen() - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueComparator
-
- getNormalizeKeyLen() - Method in class org.apache.flink.api.java.typeutils.runtime.GenericTypeComparator
-
- getNormalizeKeyLen() - Method in class org.apache.flink.api.java.typeutils.runtime.NullAwareComparator
-
- getNormalizeKeyLen() - Method in class org.apache.flink.api.java.typeutils.runtime.PojoComparator
-
- getNormalizeKeyLen() - Method in class org.apache.flink.api.java.typeutils.runtime.RowComparator
-
- getNormalizeKeyLen() - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
-
- getNormalizeKeyLen() - Method in class org.apache.flink.api.java.typeutils.runtime.ValueComparator
-
- getNormalizeKeyLen() - Method in class org.apache.flink.api.java.typeutils.runtime.WritableComparator
-
- getNormalizeKeyLen() - Method in class org.apache.flink.graph.types.valuearray.ByteValueArrayComparator
-
- getNormalizeKeyLen() - Method in class org.apache.flink.graph.types.valuearray.CharValueArrayComparator
-
- getNormalizeKeyLen() - Method in class org.apache.flink.graph.types.valuearray.DoubleValueArrayComparator
-
- getNormalizeKeyLen() - Method in class org.apache.flink.graph.types.valuearray.FloatValueArrayComparator
-
- getNormalizeKeyLen() - Method in class org.apache.flink.graph.types.valuearray.IntValueArrayComparator
-
- getNormalizeKeyLen() - Method in class org.apache.flink.graph.types.valuearray.LongValueArrayComparator
-
- getNormalizeKeyLen() - Method in class org.apache.flink.graph.types.valuearray.NullValueArrayComparator
-
- getNormalizeKeyLen() - Method in class org.apache.flink.graph.types.valuearray.ShortValueArrayComparator
-
- getNormalizeKeyLen() - Method in class org.apache.flink.graph.types.valuearray.StringValueArrayComparator
-
- getNow() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
-
- getNow() - Method in interface org.apache.flink.runtime.webmonitor.retriever.GatewayRetriever
-
Returns the currently retrieved gateway if there is such an object.
- getNullCount() - Method in class org.apache.flink.api.java.summarize.BooleanColumnSummary
-
- getNullCount() - Method in class org.apache.flink.api.java.summarize.ColumnSummary
-
The number of null values in this column.
- getNullCount() - Method in class org.apache.flink.api.java.summarize.NumericColumnSummary
-
- getNullCount() - Method in class org.apache.flink.api.java.summarize.ObjectColumnSummary
-
- getNullCount() - Method in class org.apache.flink.api.java.summarize.StringColumnSummary
-
- getNumAckSubtasks() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
-
- getNumAckSubtasks() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatistics
-
- getNumActiveTimers() - Method in class org.apache.flink.streaming.runtime.tasks.TestProcessingTimeService
-
- getNumberAvailableSlots() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerInfo
-
- getNumberCollectedStates() - Method in class org.apache.flink.runtime.checkpoint.OperatorState
-
- getNumberCollectedStates() - Method in class org.apache.flink.runtime.checkpoint.TaskState
-
Deprecated.
- getNumberCompletedCheckpoints() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.Counts
-
- getNumberCPUCores() - Static method in class org.apache.flink.runtime.util.Hardware
-
Gets the number of CPU cores (hardware contexts) that the JVM has access to.
- getNumberFailedCheckpoints() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.Counts
-
- getNumberFreeSlots() - Method in class org.apache.flink.runtime.resourcemanager.ResourceOverview
-
- getNumberFreeSlots() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
-
- getNumberFreeSlots() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerRegistration
-
- getNumberFreeSlotsOf(InstanceID) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
-
- getNumberInProgressCheckpoints() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.Counts
-
- getNumberLeaves() - Method in class org.apache.flink.runtime.instance.SharedSlot
-
- getNumberLeaves() - Method in class org.apache.flink.runtime.instance.SimpleSlot
-
- getNumberLeaves() - Method in class org.apache.flink.runtime.instance.Slot
-
Gets the number of simple slots that are at the leaves of the tree of slots.
- getNumberOfAcknowledgedSubtasks() - Method in class org.apache.flink.runtime.checkpoint.AbstractCheckpointStats
-
Returns the number of acknowledged subtasks.
- getNumberOfAcknowledgedSubtasks() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpointStats
-
- getNumberOfAcknowledgedSubtasks() - Method in class org.apache.flink.runtime.checkpoint.FailedCheckpointStats
-
- getNumberOfAcknowledgedSubtasks() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpointStats
-
- getNumberOfAcknowledgedSubtasks() - Method in class org.apache.flink.runtime.checkpoint.TaskStateStats
-
Returns the number of acknowledged subtasks.
- getNumberOfAcknowledgedTasks() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
-
- getNumberOfActiveConnections() - Method in interface org.apache.flink.runtime.io.network.ConnectionManager
-
- getNumberOfActiveConnections() - Method in class org.apache.flink.runtime.io.network.LocalConnectionManager
-
- getNumberOfActiveConnections() - Method in class org.apache.flink.runtime.io.network.netty.NettyConnectionManager
-
- getNumberOfAllocatedBytes() - Method in class org.apache.flink.runtime.io.network.netty.NettyBufferPool
-
Returns the number of currently allocated bytes.
- getNumberOfAllocatedSlots() - Method in class org.apache.flink.runtime.instance.Instance
-
- getNumberOfArenas() - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
-
- getNumberOfAssignedPartitions() - Method in class org.apache.flink.runtime.executiongraph.IntermediateResult
-
- getNumberOfAvailableBuffers() - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
-
- getNumberOfAvailableInstances() - Method in class org.apache.flink.runtime.jobmanager.scheduler.Scheduler
-
- getNumberOfAvailableMemorySegments() - Method in interface org.apache.flink.runtime.io.network.buffer.BufferPool
-
Returns the number memory segments, which are currently held by this buffer pool.
- getNumberOfAvailableMemorySegments() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
-
- getNumberOfAvailableSlots() - Method in class org.apache.flink.runtime.instance.Instance
-
- getNumberOfAvailableSlots() - Method in class org.apache.flink.runtime.instance.InstanceManager
-
- getNumberOfAvailableSlots() - Method in class org.apache.flink.runtime.jobmanager.scheduler.Scheduler
-
NOTE: In the presence of multi-threaded operations, this number may be inexact.
- getNumberOfAvailableSlotsForGroup(AbstractID) - Method in class org.apache.flink.runtime.instance.SlotSharingGroupAssignment
-
Gets the number of shared slots into which the given group can place subtasks or
nested task groups.
- getNumberOfCachedJobs() - Method in class org.apache.flink.runtime.blob.PermanentBlobCache
-
- getNumberOfChainedStubs() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getNumberOfCompletedCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.CheckpointStatsCounts
-
Returns the number of completed checkpoints.
- getNumberOfCPUCores() - Method in class org.apache.flink.runtime.instance.HardwareDescription
-
Returns the number of CPU cores available to the JVM on the compute node.
- getNumberOfDirectedEdges() - Method in class org.apache.flink.graph.library.metric.directed.VertexMetrics.Result
-
Get the number of unidirectional edges.
- getNumberOfDriverComparators() - Method in class org.apache.flink.runtime.operators.AbstractOuterJoinDriver
-
- getNumberOfDriverComparators() - Method in class org.apache.flink.runtime.operators.AllGroupCombineDriver
-
- getNumberOfDriverComparators() - Method in class org.apache.flink.runtime.operators.AllGroupReduceDriver
-
- getNumberOfDriverComparators() - Method in class org.apache.flink.runtime.operators.AllReduceDriver
-
- getNumberOfDriverComparators() - Method in class org.apache.flink.runtime.operators.CoGroupDriver
-
- getNumberOfDriverComparators() - Method in class org.apache.flink.runtime.operators.CoGroupRawDriver
-
- getNumberOfDriverComparators() - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetFirstDriver
-
- getNumberOfDriverComparators() - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetSecondDriver
-
- getNumberOfDriverComparators() - Method in class org.apache.flink.runtime.operators.CrossDriver
-
- getNumberOfDriverComparators() - Method in interface org.apache.flink.runtime.operators.Driver
-
Gets the number of comparators required for this driver.
- getNumberOfDriverComparators() - Method in class org.apache.flink.runtime.operators.FlatMapDriver
-
- getNumberOfDriverComparators() - Method in class org.apache.flink.runtime.operators.GroupReduceCombineDriver
-
- getNumberOfDriverComparators() - Method in class org.apache.flink.runtime.operators.GroupReduceDriver
-
- getNumberOfDriverComparators() - Method in class org.apache.flink.runtime.operators.JoinDriver
-
- getNumberOfDriverComparators() - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetFirstDriver
-
- getNumberOfDriverComparators() - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetSecondDriver
-
- getNumberOfDriverComparators() - Method in class org.apache.flink.runtime.operators.MapDriver
-
- getNumberOfDriverComparators() - Method in class org.apache.flink.runtime.operators.MapPartitionDriver
-
- getNumberOfDriverComparators() - Method in class org.apache.flink.runtime.operators.NoOpDriver
-
- getNumberOfDriverComparators() - Method in class org.apache.flink.runtime.operators.ReduceCombineDriver
-
- getNumberOfDriverComparators() - Method in class org.apache.flink.runtime.operators.ReduceDriver
-
- getNumberOfDriverComparators() - Method in class org.apache.flink.runtime.operators.UnionWithTempOperator
-
- getNumberOfEdges() - Method in class org.apache.flink.graph.library.metric.directed.VertexMetrics.Result
-
Get the number of edges.
- getNumberOfEdges() - Method in class org.apache.flink.graph.library.metric.undirected.VertexMetrics.Result
-
Get the number of edges.
- getNumberOfEventsUntilInterruptInIterativeBroadcastGate(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getNumberOfEventsUntilInterruptInIterativeGate(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getNumberOfExecutionJobVertices() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
Gets the number of job vertices currently held by this execution graph.
- getNumberOfExecutionRetries() - Method in class org.apache.flink.api.common.ExecutionConfig
-
- getNumberOfExecutionRetries() - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
- getNumberOfExecutionRetries() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- getNumberOfFailedCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.CheckpointStatsCounts
-
Returns the number of failed checkpoints.
- getNumberOfFields() - Method in interface org.apache.flink.api.common.distributions.DataDistribution
-
The number of fields in the (composite) key.
- getNumberOfFields() - Method in class org.apache.flink.api.common.operators.Ordering
-
- getNumberOfFieldsTotal() - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
-
- getNumberOfFullRestarts() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
Gets the number of full restarts that the execution graph went through.
- getNumberOfInProgressCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.CheckpointStatsCounts
-
Returns the number of in progress checkpoints.
- getNumberOfInputChannels() - Method in interface org.apache.flink.runtime.io.network.partition.consumer.InputGate
-
- getNumberOfInputChannels() - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
-
- getNumberOfInputChannels() - Method in class org.apache.flink.runtime.io.network.partition.consumer.UnionInputGate
-
Returns the total number of input channels across all unioned input gates.
- getNumberOfInputs() - Method in class org.apache.flink.api.common.operators.AbstractUdfOperator
-
Gets the number of inputs for this operator.
- getNumberOfInputs() - Method in class org.apache.flink.api.common.operators.DualInputOperator
-
- getNumberOfInputs() - Method in class org.apache.flink.api.common.operators.SingleInputOperator
-
- getNumberOfInputs() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- getNumberOfInputs() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
Returns the number of inputs.
- getNumberOfInputs() - Method in class org.apache.flink.runtime.operators.AbstractOuterJoinDriver
-
- getNumberOfInputs() - Method in class org.apache.flink.runtime.operators.AllGroupCombineDriver
-
- getNumberOfInputs() - Method in class org.apache.flink.runtime.operators.AllGroupReduceDriver
-
- getNumberOfInputs() - Method in class org.apache.flink.runtime.operators.AllReduceDriver
-
- getNumberOfInputs() - Method in class org.apache.flink.runtime.operators.CoGroupDriver
-
- getNumberOfInputs() - Method in class org.apache.flink.runtime.operators.CoGroupRawDriver
-
- getNumberOfInputs() - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetFirstDriver
-
- getNumberOfInputs() - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetSecondDriver
-
- getNumberOfInputs() - Method in class org.apache.flink.runtime.operators.CrossDriver
-
- getNumberOfInputs() - Method in interface org.apache.flink.runtime.operators.Driver
-
Gets the number of inputs that the task has.
- getNumberOfInputs() - Method in class org.apache.flink.runtime.operators.FlatMapDriver
-
- getNumberOfInputs() - Method in class org.apache.flink.runtime.operators.GroupReduceCombineDriver
-
- getNumberOfInputs() - Method in class org.apache.flink.runtime.operators.GroupReduceDriver
-
- getNumberOfInputs() - Method in class org.apache.flink.runtime.operators.JoinDriver
-
- getNumberOfInputs() - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetFirstDriver
-
- getNumberOfInputs() - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetSecondDriver
-
- getNumberOfInputs() - Method in class org.apache.flink.runtime.operators.MapDriver
-
- getNumberOfInputs() - Method in class org.apache.flink.runtime.operators.MapPartitionDriver
-
- getNumberOfInputs() - Method in class org.apache.flink.runtime.operators.NoOpDriver
-
- getNumberOfInputs() - Method in class org.apache.flink.runtime.operators.ReduceCombineDriver
-
- getNumberOfInputs() - Method in class org.apache.flink.runtime.operators.ReduceDriver
-
- getNumberOfInputs() - Method in class org.apache.flink.runtime.operators.UnionWithTempOperator
-
- getNumberOfInputs() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getNumberOfInstancesWithAvailableSlots() - Method in class org.apache.flink.runtime.jobmanager.scheduler.Scheduler
-
- getNumberOfIterations() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getNumberOfKeyFields() - Method in class org.apache.flink.api.common.operators.Keys.ExpressionKeys
-
- getNumberOfKeyFields() - Method in class org.apache.flink.api.common.operators.Keys
-
- getNumberOfKeyFields() - Method in class org.apache.flink.api.common.operators.Keys.SelectorFunctionKeys
-
- getNumberOfKeyGroups() - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
-
- getNumberOfKeyGroups() - Method in interface org.apache.flink.runtime.state.heap.InternalKeyContext
-
Returns the number of key-groups aka max parallelism.
- getNumberOfKeyGroups() - Method in class org.apache.flink.runtime.state.KeyGroupRange
-
- getNumberOfKeyGroups() - Method in interface org.apache.flink.runtime.state.KeyGroupsList
-
Returns the number of key group ids in the list.
- getNumberOfLocalAssignments() - Method in class org.apache.flink.api.common.io.LocatableInputSplitAssigner
-
- getNumberOfLocalizedAssignments() - Method in class org.apache.flink.runtime.jobmanager.scheduler.Scheduler
-
- getNumberOfNonAcknowledgedTasks() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
-
- getNumberOfNonLocalizedAssignments() - Method in class org.apache.flink.runtime.jobmanager.scheduler.Scheduler
-
- getNumberOfNonNullFields() - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
-
- getNumberOfOpenInputStreams() - Method in class org.apache.flink.core.fs.LimitedConnectionsFileSystem
-
Gets the number of currently open input streams.
- getNumberOfOpenOutputStreams() - Method in class org.apache.flink.core.fs.LimitedConnectionsFileSystem
-
Gets the number of currently open output streams.
- getNumberOfOutputs() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getNumberOfOutstandingRequests() - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBufferFileWriter
-
- getNumberOfOutstandingRequests() - Method in interface org.apache.flink.runtime.io.disk.iomanager.BufferFileWriter
-
Returns the number of outstanding requests.
- getNumberOfPages() - Static method in class org.apache.flink.examples.java.graph.util.PageRankData
-
- getNumberOfParallelSubtasks() - Method in interface org.apache.flink.api.common.functions.RuntimeContext
-
Gets the parallelism with which the parallel task runs.
- getNumberOfParallelSubtasks() - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
-
- getNumberOfParallelSubtasks() - Method in class org.apache.flink.api.common.TaskInfo
-
Gets the parallelism with which the parallel task runs.
- getNumberOfParameters() - Method in class org.apache.flink.api.java.utils.ParameterTool
-
- getNumberOfPartitions() - Method in class org.apache.flink.runtime.state.OperatorStateCheckpointOutputStream
-
- getNumberOfPendingCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
- getNumberOfProducedIntermediateDataSets() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
Returns the number of produced intermediate data sets.
- getNumberOfQueuedBuffers() - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
-
Gets the current number of received buffers which have not been processed yet.
- getNumberOfQueuedBuffers() - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
-
- getNumberOfQueuedBuffers() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
-
- getNumberOfRecords() - Method in class org.apache.flink.api.common.io.FileInputFormat.FileBaseStatistics
-
Gets the estimates number of records in the file, computed as the file size divided by the
average record width, rounded up.
- getNumberOfRecords() - Method in interface org.apache.flink.api.common.io.statistics.BaseStatistics
-
Gets the number of records in the input (= base cardinality).
- getNumberOfRectangleTriplets() - Method in class org.apache.flink.graph.library.metric.directed.EdgeMetrics.Result
-
Get the number of rectangle triplets.
- getNumberOfRectangleTriplets() - Method in class org.apache.flink.graph.library.metric.undirected.EdgeMetrics.Result
-
Get the number of rectangle triplets.
- getNumberOfReferenceHolders(JobID) - Method in class org.apache.flink.runtime.blob.PermanentBlobCache
-
- getNumberOfRegisteredBufferPools() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
-
- getNumberOfRegisteredCloseables() - Method in class org.apache.flink.util.AbstractCloseableRegistry
-
- getNumberOfRegisteredMasterHooks() - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
Gets the number of currently register master hooks.
- getNumberOfRegisteredTaskManagers() - Method in class org.apache.flink.runtime.instance.InstanceManager
-
- getNumberOfRegisteredTaskManagers() - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
-
- getNumberOfRegisteredTaskManagers() - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
-
Gets the currently registered number of TaskManagers.
- getNumberOfRemoteAssignments() - Method in class org.apache.flink.api.common.io.LocatableInputSplitAssigner
-
- getNumberOfRequiredBuffers() - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
-
- getNumberOfRequiredMemorySegments() - Method in interface org.apache.flink.runtime.io.network.buffer.BufferPool
-
Returns the number of guaranteed (minimum number of) memory segments of this buffer pool.
- getNumberOfRestoredCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.CheckpointStatsCounts
-
Returns the number of restored checkpoints.
- getNumberOfRetainedCheckpoints() - Method in interface org.apache.flink.runtime.checkpoint.CompletedCheckpointStore
-
Returns the current number of retained checkpoints.
- getNumberOfRetainedCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.StandaloneCompletedCheckpointStore
-
- getNumberOfRetainedCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.ZooKeeperCompletedCheckpointStore
-
- getNumberOfRetainedSuccessfulCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
- getNumberOfSlots() - Method in class org.apache.flink.runtime.instance.SlotSharingGroupAssignment
-
Gets the number of slots that are currently governed by this assignment group.
- getNumberOfSlots() - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
-
- getNumberOfSlots() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
-
- getNumberOfSpillingDirectories() - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManager
-
Gets the number of directories across which the I/O manager rotates its files.
- getNumberOfStartedTaskManagers() - Method in class org.apache.flink.runtime.clusterframework.FlinkResourceManager
-
Gets the number of currently started TaskManagers.
- getNumberOfSubpartitions() - Method in class org.apache.flink.runtime.deployment.ResultPartitionDeploymentDescriptor
-
- getNumberOfSubpartitions() - Method in interface org.apache.flink.runtime.io.network.api.writer.ResultPartitionWriter
-
- getNumberOfSubpartitions() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
-
- getNumberOfSubtasks() - Method in class org.apache.flink.runtime.checkpoint.AbstractCheckpointStats
-
Returns the total number of subtasks involved in this checkpoint.
- getNumberOfSubtasks() - Method in class org.apache.flink.runtime.checkpoint.TaskStateStats
-
Returns the number of subtasks.
- getNumberOfSubtasks() - Method in class org.apache.flink.runtime.executiongraph.TaskInformation
-
- getNumberOfSubTasks() - Method in class org.apache.flink.runtime.rest.handler.legacy.backpressure.OperatorBackPressureStats
-
Returns the number of sub tasks.
- getNumberOfTriangles() - Method in class org.apache.flink.graph.library.clustering.directed.GlobalClusteringCoefficient.Result
-
Get the number of triangles.
- getNumberOfTriangles() - Method in class org.apache.flink.graph.library.clustering.undirected.GlobalClusteringCoefficient.Result
-
Get the number of triangles.
- getNumberOfTriangleTriplets() - Method in class org.apache.flink.graph.library.metric.directed.EdgeMetrics.Result
-
Get the number of triangle triplets.
- getNumberOfTriangleTriplets() - Method in class org.apache.flink.graph.library.metric.undirected.EdgeMetrics.Result
-
Get the number of triangle triplets.
- getNumberOfTriplets() - Method in class org.apache.flink.graph.library.clustering.directed.GlobalClusteringCoefficient.Result
-
Get the number of triplets.
- getNumberOfTriplets() - Method in class org.apache.flink.graph.library.clustering.undirected.GlobalClusteringCoefficient.Result
-
Get the number of triplets.
- getNumberOfTriplets() - Method in class org.apache.flink.graph.library.metric.directed.VertexMetrics.Result
-
Get the number of triplets.
- getNumberOfTriplets() - Method in class org.apache.flink.graph.library.metric.undirected.VertexMetrics.Result
-
Get the number of triplets.
- getNumberOfUnconstrainedAssignments() - Method in class org.apache.flink.runtime.jobmanager.scheduler.Scheduler
-
- getNumberOfUndirectedEdges() - Method in class org.apache.flink.graph.library.metric.directed.VertexMetrics.Result
-
Get the number of bidirectional edges.
- getNumberOfVariablesWithReferences() - Method in class org.apache.flink.runtime.broadcast.BroadcastVariableManager
-
- getNumberOfVertices() - Method in class org.apache.flink.graph.gsa.ApplyFunction
-
Retrieves the number of vertices in the graph.
- getNumberOfVertices() - Method in class org.apache.flink.graph.gsa.GatherFunction
-
Retrieves the number of vertices in the graph.
- getNumberOfVertices() - Method in class org.apache.flink.graph.gsa.SumFunction
-
Retrieves the number of vertices in the graph.
- getNumberOfVertices() - Method in class org.apache.flink.graph.library.clustering.directed.AverageClusteringCoefficient.Result
-
Get the number of vertices.
- getNumberOfVertices() - Method in class org.apache.flink.graph.library.clustering.undirected.AverageClusteringCoefficient.Result
-
Get the number of vertices.
- getNumberOfVertices() - Method in class org.apache.flink.graph.library.metric.directed.VertexMetrics.Result
-
Get the number of vertices.
- getNumberOfVertices() - Method in class org.apache.flink.graph.library.metric.undirected.VertexMetrics.Result
-
Get the number of vertices.
- getNumberOfVertices() - Method in class org.apache.flink.graph.spargel.GatherFunction
-
Retrieves the number of vertices in the graph.
- getNumberOfVertices() - Method in class org.apache.flink.graph.spargel.ScatterFunction
-
Retrieves the number of vertices in the graph.
- getNumberOfVertices() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
Returns the number of all vertices.
- getNumberPendingSlotRequests() - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
-
- getNumberPendingSlotRequests() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
-
- getNumberRegisteredSlots() - Method in class org.apache.flink.runtime.resourcemanager.ResourceOverview
-
- getNumberRegisteredSlots() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
-
- getNumberRegisteredSlots() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerRegistration
-
- getNumberRegisteredSlotsOf(InstanceID) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
-
- getNumberReporters() - Method in interface org.apache.flink.runtime.metrics.MetricRegistry
-
Returns the number of registered reporters.
- getNumberReporters() - Method in class org.apache.flink.runtime.metrics.MetricRegistryImpl
-
- getNumberReporters() - Method in class org.apache.flink.runtime.metrics.NoOpMetricRegistry
-
- getNumberRestoredCheckpoints() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.Counts
-
- getNumberSlots() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerInfo
-
- getNumberSlots() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
-
- getNumberSlots() - Method in class org.apache.flink.test.util.MiniClusterResource
-
- getNumberSlotsPerTaskManager() - Method in class org.apache.flink.test.util.MiniClusterResource.MiniClusterResourceConfiguration
-
- getNumberTaskManagers() - Method in class org.apache.flink.client.deployment.ClusterSpecification
-
- getNumberTaskManagers() - Method in class org.apache.flink.runtime.resourcemanager.ResourceOverview
-
- getNumberTaskManagers() - Method in class org.apache.flink.test.util.MiniClusterResource.MiniClusterResourceConfiguration
-
- getNumBroadcastInputs() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getNumBuffers() - Method in interface org.apache.flink.runtime.io.network.buffer.BufferPool
-
Returns the current size of this buffer pool.
- getNumBuffersInLocalCounter() - Method in class org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
-
- getNumBuffersInRemoteCounter() - Method in class org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
-
- getNumBuffersOutCounter() - Method in class org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
-
- getNumBytesInLocal() - Method in class org.apache.flink.runtime.executiongraph.IOMetrics
-
- getNumBytesInLocalCounter() - Method in class org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
-
- getNumBytesInLocalPerSecond() - Method in class org.apache.flink.runtime.executiongraph.IOMetrics
-
- getNumBytesInLocalRateMeter() - Method in class org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
-
- getNumBytesInRemote() - Method in class org.apache.flink.runtime.executiongraph.IOMetrics
-
- getNumBytesInRemoteCounter() - Method in class org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
-
- getNumBytesInRemotePerSecond() - Method in class org.apache.flink.runtime.executiongraph.IOMetrics
-
- getNumBytesInRemoteRateMeter() - Method in class org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
-
- getNumBytesInTotal() - Method in class org.apache.flink.runtime.executiongraph.IOMetrics
-
- getNumBytesOut() - Method in class org.apache.flink.runtime.executiongraph.IOMetrics
-
- getNumBytesOutCounter() - Method in class org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
-
- getNumBytesOutPerSecond() - Method in class org.apache.flink.runtime.executiongraph.IOMetrics
-
- getNumBytesOutRateMeter() - Method in class org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
-
- getNumConnections() - Method in class org.apache.flink.queryablestate.network.stats.AtomicKvStateRequestStats
-
- getNumElements() - Method in class org.apache.flink.streaming.api.functions.source.FromElementsFunction
-
Gets the number of elements produced in total by this function.
- getNumElementsEmitted() - Method in class org.apache.flink.streaming.api.functions.source.FromElementsFunction
-
Gets the number of elements emitted so far.
- getNumFailed() - Method in class org.apache.flink.queryablestate.network.stats.AtomicKvStateRequestStats
-
- getNumFields() - Method in class org.apache.flink.types.Record
-
Gets the number of fields currently in the record.
- getNumFuturesCompleted() - Method in class org.apache.flink.runtime.concurrent.FutureUtils.ConjunctFuture
-
Gets the number of Futures in the conjunction that are already complete.
- getNumFuturesTotal() - Method in class org.apache.flink.runtime.concurrent.FutureUtils.ConjunctFuture
-
Gets the total number of Futures in the conjunction.
- getNumInputs() - Method in enum org.apache.flink.runtime.operators.DriverStrategy
-
- getNumInputs() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getNumJobsCancelled() - Method in class org.apache.flink.runtime.messages.webmonitor.JobsOverview
-
- getNumJobsFailed() - Method in class org.apache.flink.runtime.messages.webmonitor.JobsOverview
-
- getNumJobsFinished() - Method in class org.apache.flink.runtime.messages.webmonitor.JobsOverview
-
- getNumJobsRunningOrPending() - Method in class org.apache.flink.runtime.messages.webmonitor.JobsOverview
-
- getNumKeyGroups() - Method in class org.apache.flink.runtime.query.KvStateLocation
-
Returns the number of key groups of the operator the KvState instances belong to.
- getNumLineSamples() - Method in class org.apache.flink.api.common.io.DelimitedInputFormat
-
- getNumOccupiedMemorySegments() - Method in class org.apache.flink.runtime.operators.hash.HashPartition
-
Gets the number of memory segments used by this partition, which includes build side
memory buffers and overflow memory segments.
- getNumOutputs() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getNumRecordsIn() - Method in class org.apache.flink.runtime.executiongraph.IOMetrics
-
- getNumRecordsInCounter() - Method in class org.apache.flink.runtime.metrics.groups.OperatorIOMetricGroup
-
- getNumRecordsInCounter() - Method in class org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
-
- getNumRecordsInPerSecond() - Method in class org.apache.flink.runtime.executiongraph.IOMetrics
-
- getNumRecordsInRateMeter() - Method in class org.apache.flink.runtime.metrics.groups.OperatorIOMetricGroup
-
- getNumRecordsOut() - Method in class org.apache.flink.runtime.executiongraph.IOMetrics
-
- getNumRecordsOutCounter() - Method in class org.apache.flink.runtime.metrics.groups.OperatorIOMetricGroup
-
- getNumRecordsOutCounter() - Method in class org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
-
- getNumRecordsOutPerSecond() - Method in class org.apache.flink.runtime.executiongraph.IOMetrics
-
- getNumRecordsOutRate() - Method in class org.apache.flink.runtime.metrics.groups.OperatorIOMetricGroup
-
- getNumRegisteredKeyGroups() - Method in class org.apache.flink.runtime.query.KvStateLocation
-
Returns the current number of registered key groups.
- getNumRequests() - Method in class org.apache.flink.queryablestate.network.stats.AtomicKvStateRequestStats
-
- getNumRequiredComparators() - Method in enum org.apache.flink.runtime.operators.DriverStrategy
-
- getNumSlotsAvailable() - Method in class org.apache.flink.runtime.messages.webmonitor.ClusterOverview
-
- getNumSlotsTotal() - Method in class org.apache.flink.runtime.messages.webmonitor.ClusterOverview
-
- getNumSplits() - Method in class org.apache.flink.api.common.io.FileInputFormat
-
- getNumSubtasks() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
-
- getNumSubtasks() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatistics
-
- getNumSuccessful() - Method in class org.apache.flink.queryablestate.network.stats.AtomicKvStateRequestStats
-
- getNumTargetKeyGroups() - Method in interface org.apache.flink.runtime.io.network.api.writer.ResultPartitionWriter
-
- getNumTargetKeyGroups() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
-
- getNumTaskInputs() - Method in class org.apache.flink.runtime.iterative.task.IterationHeadTask
-
- getNumTaskInputs() - Method in class org.apache.flink.runtime.operators.BatchTask
-
- getNumTaskManagers() - Method in class org.apache.flink.runtime.minicluster.MiniClusterConfiguration
-
- getNumTaskManagersConnected() - Method in class org.apache.flink.runtime.messages.webmonitor.ClusterOverview
-
- getNumTasks() - Method in class org.apache.flink.runtime.messages.webmonitor.JobDetails
-
- getNumWorkerRequestsPending() - Method in class org.apache.flink.mesos.runtime.clusterframework.MesosFlinkResourceManager
-
- getNumWorkerRequestsPending() - Method in class org.apache.flink.runtime.clusterframework.FlinkResourceManager
-
Gets the number of requested workers that have not yet been granted.
- getNumWorkerRequestsPending() - Method in class org.apache.flink.runtime.clusterframework.standalone.StandaloneResourceManager
-
- getNumWorkerRequestsPending() - Method in class org.apache.flink.yarn.YarnFlinkResourceManager
-
- getNumWorkersPendingRegistration() - Method in class org.apache.flink.mesos.runtime.clusterframework.MesosFlinkResourceManager
-
- getNumWorkersPendingRegistration() - Method in class org.apache.flink.runtime.clusterframework.FlinkResourceManager
-
Gets the number of containers that have been started, but where the TaskManager
has not yet registered at the job manager.
- getNumWorkersPendingRegistration() - Method in class org.apache.flink.runtime.clusterframework.standalone.StandaloneResourceManager
-
- getNumWorkersPendingRegistration() - Method in class org.apache.flink.yarn.YarnFlinkResourceManager
-
- getNumWriteBehindBuffers(int) - Static method in class org.apache.flink.runtime.operators.hash.MutableHashTable
-
Determines the number of buffers to be used for asynchronous write behind.
- getObjectReuseEnabled() - Method in class org.apache.flink.api.common.ArchivedExecutionConfig
-
- getOccupancy() - Method in class org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable
-
Gets the number of bytes currently occupied in this hash table.
- getOccupancy() - Method in class org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
-
- getOccupancy() - Method in interface org.apache.flink.runtime.operators.sort.InMemorySorter
-
Gets the number of bytes currently occupied in this sorter, records and sort index.
- getOccupancy() - Method in class org.apache.flink.runtime.operators.sort.NormalizedKeySorter
-
- getOffer() - Method in class org.apache.flink.mesos.scheduler.Offer
-
- getOfferedTime() - Method in class org.apache.flink.mesos.scheduler.Offer
-
- getOffHeapBuffer() - Method in class org.apache.flink.core.memory.HybridMemorySegment
-
Gets the buffer that owns the memory of this memory segment.
- getOffset() - Method in interface org.apache.flink.core.fs.BlockLocation
-
Get the start offset of the file associated with this block.
- getOffset() - Method in class org.apache.flink.core.fs.local.LocalBlockLocation
-
- getOffset() - Method in class org.apache.flink.graph.generator.CirculantGraph.OffsetRange
-
Get the range offset.
- getOffset() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopBlockLocation
-
- getOffset() - Method in class org.apache.flink.streaming.connectors.kafka.internals.KafkaTopicPartitionState
-
The current offset in the partition.
- getOffsetForKeyGroup(int) - Method in class org.apache.flink.runtime.state.KeyGroupsStateHandle
-
- getOffsetFromZooKeeper(CuratorFramework, String, String, int) - Static method in class org.apache.flink.streaming.connectors.kafka.internals.ZookeeperOffsetHandler
-
- getOffsets() - Method in class org.apache.flink.runtime.state.OperatorStateHandle.StateMetaInfo
-
- getOne() - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.TaggedUnion
-
- getOneMinuteRate() - Method in class org.apache.flink.dropwizard.metrics.FlinkMeterWrapper
-
- getOpenBranches() - Method in class org.apache.flink.optimizer.dag.OptimizerNode
-
- getOpenFileHandlesLimit() - Static method in class org.apache.flink.runtime.util.EnvironmentInformation
-
Tries to retrieve the maximum number of open file handles.
- getOpenTimeout() - Method in class org.apache.flink.api.common.io.FileInputFormat
-
- getOperationKey(HandlerRequest<EmptyRequestBody, M>) - Method in class org.apache.flink.runtime.rest.handler.async.AbstractAsynchronousOperationHandlers.StatusHandler
-
Extract the operation key under which the operation result future is stored.
- getOperationKey(HandlerRequest<EmptyRequestBody, RescalingStatusMessageParameters>) - Method in class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingHandlers.RescalingStatusHandler
-
- getOperationKey(HandlerRequest<EmptyRequestBody, SavepointDisposalStatusMessageParameters>) - Method in class org.apache.flink.runtime.rest.handler.job.savepoints.SavepointDisposalHandlers.SavepointDisposalStatusHandler
-
- getOperationKey(HandlerRequest<EmptyRequestBody, SavepointStatusMessageParameters>) - Method in class org.apache.flink.runtime.rest.handler.job.savepoints.SavepointHandlers.SavepointStatusHandler
-
- getOperator() - Method in class org.apache.flink.optimizer.dag.BulkPartialSolutionNode
-
- getOperator() - Method in class org.apache.flink.optimizer.dag.CoGroupNode
-
Gets the operator for this CoGroup node.
- getOperator() - Method in class org.apache.flink.optimizer.dag.CoGroupRawNode
-
Gets the operator for this CoGroup node.
- getOperator() - Method in class org.apache.flink.optimizer.dag.CrossNode
-
- getOperator() - Method in class org.apache.flink.optimizer.dag.DataSinkNode
-
Gets the operator for which this optimizer sink node was created.
- getOperator() - Method in class org.apache.flink.optimizer.dag.DataSourceNode
-
Gets the contract object for this data source node.
- getOperator() - Method in class org.apache.flink.optimizer.dag.FilterNode
-
- getOperator() - Method in class org.apache.flink.optimizer.dag.FlatMapNode
-
- getOperator() - Method in class org.apache.flink.optimizer.dag.GroupCombineNode
-
Gets the operator represented by this optimizer node.
- getOperator() - Method in class org.apache.flink.optimizer.dag.GroupReduceNode
-
Gets the operator represented by this optimizer node.
- getOperator() - Method in class org.apache.flink.optimizer.dag.JoinNode
-
Gets the contract object for this match node.
- getOperator() - Method in class org.apache.flink.optimizer.dag.OptimizerNode
-
Gets the operator represented by this optimizer node.
- getOperator() - Method in class org.apache.flink.optimizer.dag.OuterJoinNode
-
- getOperator() - Method in class org.apache.flink.optimizer.dag.PartitionNode
-
- getOperator() - Method in class org.apache.flink.optimizer.dag.ReduceNode
-
- getOperator() - Method in class org.apache.flink.optimizer.dag.SingleInputNode
-
- getOperator() - Method in class org.apache.flink.optimizer.dag.SolutionSetNode
-
Gets the contract object for this data source node.
- getOperator() - Method in class org.apache.flink.optimizer.dag.SortPartitionNode
-
- getOperator() - Method in class org.apache.flink.optimizer.dag.TwoInputNode
-
- getOperator() - Method in class org.apache.flink.optimizer.dag.WorksetNode
-
Gets the contract object for this data source node.
- getOperator() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getOperator() - Method in class org.apache.flink.streaming.api.transformations.OneInputTransformation
-
Returns the TwoInputStreamOperator
of this Transformation.
- getOperator() - Method in class org.apache.flink.streaming.api.transformations.SinkTransformation
-
Returns the
StreamSink
that is the operator of this
SinkTransformation
.
- getOperator() - Method in class org.apache.flink.streaming.api.transformations.SourceTransformation
-
Returns the StreamSource
, the operator of this SourceTransformation
.
- getOperator() - Method in class org.apache.flink.streaming.api.transformations.TwoInputTransformation
-
Returns the TwoInputStreamOperator
of this Transformation.
- getOperatorBackPressureStats(ExecutionJobVertex) - Method in interface org.apache.flink.runtime.rest.handler.legacy.backpressure.BackPressureStatsTracker
-
Returns back pressure statistics for a operator.
- getOperatorBackPressureStats(ExecutionJobVertex) - Method in class org.apache.flink.runtime.rest.handler.legacy.backpressure.BackPressureStatsTrackerImpl
-
Returns back pressure statistics for a operator.
- getOperatorBackPressureStats() - Method in class org.apache.flink.runtime.rest.handler.legacy.backpressure.OperatorBackPressureStatsResponse
-
- getOperatorConfig() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- getOperatorDescription() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
- getOperatorFormat() - Method in class org.apache.flink.runtime.metrics.scope.ScopeFormats
-
- getOperatorID() - Method in class org.apache.flink.runtime.checkpoint.OperatorState
-
- getOperatorId() - Method in class org.apache.flink.runtime.jobgraph.OperatorInstanceID
-
- getOperatorID() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getOperatorID() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- getOperatorID() - Method in interface org.apache.flink.streaming.api.operators.StreamOperator
-
- getOperatorId() - Method in class org.apache.flink.streaming.runtime.streamrecord.LatencyMarker
-
- getOperatorIDs() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
Returns a list containing the IDs of all operators contained in this execution job vertex.
- getOperatorIDs() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
- getOperatorInfo() - Method in class org.apache.flink.api.common.operators.DualInputOperator
-
Gets the information about the operators input/output types.
- getOperatorInfo() - Method in class org.apache.flink.api.common.operators.Operator
-
Gets the information about the operators input/output types.
- getOperatorInfo() - Method in class org.apache.flink.api.common.operators.SingleInputOperator
-
Gets the information about the operators input/output types.
- getOperatorInfo() - Method in class org.apache.flink.optimizer.util.NoOpUnaryUdfOp
-
- getOperatorLevelCachingDescription() - Method in class org.apache.flink.runtime.jobgraph.JobEdge
-
Gets the operator-level caching description for this input.
- getOperatorName() - Method in class org.apache.flink.optimizer.dag.BinaryUnionNode
-
- getOperatorName() - Method in class org.apache.flink.optimizer.dag.BulkIterationNode
-
- getOperatorName() - Method in class org.apache.flink.optimizer.dag.BulkPartialSolutionNode
-
- getOperatorName() - Method in class org.apache.flink.optimizer.dag.CoGroupNode
-
- getOperatorName() - Method in class org.apache.flink.optimizer.dag.CoGroupRawNode
-
- getOperatorName() - Method in class org.apache.flink.optimizer.dag.CrossNode
-
- getOperatorName() - Method in class org.apache.flink.optimizer.dag.DataSinkNode
-
- getOperatorName() - Method in class org.apache.flink.optimizer.dag.DataSourceNode
-
- getOperatorName() - Method in class org.apache.flink.optimizer.dag.FilterNode
-
- getOperatorName() - Method in class org.apache.flink.optimizer.dag.FlatMapNode
-
- getOperatorName() - Method in class org.apache.flink.optimizer.dag.GroupCombineNode
-
- getOperatorName() - Method in class org.apache.flink.optimizer.dag.GroupReduceNode
-
- getOperatorName() - Method in class org.apache.flink.optimizer.dag.JoinNode
-
- getOperatorName() - Method in class org.apache.flink.optimizer.dag.MapNode
-
- getOperatorName() - Method in class org.apache.flink.optimizer.dag.MapPartitionNode
-
- getOperatorName() - Method in class org.apache.flink.optimizer.dag.OptimizerNode
-
Gets the name of this node, which is the name of the function/operator, or
data source / data sink.
- getOperatorName() - Method in class org.apache.flink.optimizer.dag.OuterJoinNode
-
- getOperatorName() - Method in class org.apache.flink.optimizer.dag.PartitionNode
-
- getOperatorName() - Method in class org.apache.flink.optimizer.dag.ReduceNode
-
- getOperatorName() - Method in class org.apache.flink.optimizer.dag.SinkJoiner
-
- getOperatorName() - Method in class org.apache.flink.optimizer.dag.SolutionSetNode
-
- getOperatorName() - Method in class org.apache.flink.optimizer.dag.SortPartitionNode
-
- getOperatorName() - Method in class org.apache.flink.optimizer.dag.UnaryOperatorNode
-
- getOperatorName() - Method in class org.apache.flink.optimizer.dag.WorksetIterationNode
-
- getOperatorName() - Method in class org.apache.flink.optimizer.dag.WorksetIterationNode.SingleRootJoiner
-
- getOperatorName() - Method in class org.apache.flink.optimizer.dag.WorksetNode
-
- getOperatorName() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
- getOperatorName() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getOperatorName() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getOperatorName() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
Return the operator name.
- getOperatorPrettyName() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
- getOperators() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- getOperatorsMemoryInMB() - Method in class org.apache.flink.runtime.clusterframework.types.ResourceProfile
-
Get the memory the operators needed in MB.
- getOperatorState(ListStateDescriptor<S>) - Method in interface org.apache.flink.api.common.state.OperatorStateStore
-
- getOperatorState(ListStateDescriptor<S>) - Method in class org.apache.flink.runtime.state.DefaultOperatorStateBackend
-
- getOperatorStateBackend() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- getOperatorStateManagedFuture() - Method in class org.apache.flink.streaming.api.operators.OperatorSnapshotFutures
-
- getOperatorStateMetaInfoSnapshots() - Method in class org.apache.flink.runtime.state.OperatorBackendSerializationProxy
-
- getOperatorStateRawFuture() - Method in class org.apache.flink.streaming.api.operators.OperatorSnapshotFutures
-
- getOperatorStateReaderForVersion(int, ClassLoader) - Static method in class org.apache.flink.runtime.state.OperatorBackendStateMetaInfoSnapshotReaderWriters
-
- getOperatorStates() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
-
- getOperatorStates() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
-
- getOperatorStates() - Method in interface org.apache.flink.runtime.checkpoint.savepoint.Savepoint
-
Returns the snapshotted operator states.
- getOperatorStates() - Method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV1
-
- getOperatorStates() - Method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV2
-
- getOperatorStateStore() - Method in interface org.apache.flink.runtime.state.ManagedInitializationContext
-
Returns an interface that allows for registering operator state with the backend.
- getOperatorStateStore() - Method in class org.apache.flink.runtime.state.StateInitializationContextImpl
-
- getOperatorStateStreamFuture() - Method in class org.apache.flink.runtime.state.StateSnapshotContextSynchronousImpl
-
- getOperatorStateWriterForVersion(int, RegisteredOperatorBackendStateMetaInfo.Snapshot<S>) - Static method in class org.apache.flink.runtime.state.OperatorBackendStateMetaInfoSnapshotReaderWriters
-
- getOperatorStrategyString(DriverStrategy) - Static method in class org.apache.flink.optimizer.plantranslate.JsonMapper
-
- getOperatorStrategyString(DriverStrategy, String, String) - Static method in class org.apache.flink.optimizer.plantranslate.JsonMapper
-
- getOperatorUniqueID() - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
-
Returned value is guaranteed to be unique between operators within the same job and to be
stable and the same across job submissions.
- getOptimizedPlan(Optimizer, PackagedProgram, int) - Static method in class org.apache.flink.client.program.ClusterClient
-
- getOptimizedPlan(Optimizer, Plan, int) - Static method in class org.apache.flink.client.program.ClusterClient
-
- getOptimizedPlan(PackagedProgram) - Method in class org.apache.flink.client.program.OptimizerPlanEnvironment
-
- getOptimizedPlanAsJson(Optimizer, PackagedProgram, int) - Static method in class org.apache.flink.client.program.ClusterClient
-
- getOptimizerNode() - Method in class org.apache.flink.optimizer.dag.OptimizerNode
-
- getOptimizerNode() - Method in class org.apache.flink.optimizer.plan.BinaryUnionPlanNode
-
- getOptimizerNode() - Method in class org.apache.flink.optimizer.plan.PlanNode
-
- getOptimizerNode() - Method in interface org.apache.flink.optimizer.plandump.DumpableNode
-
- getOptimizerPlanAsJSON(Plan) - Method in class org.apache.flink.api.common.PlanExecutor
-
Gets the programs execution plan in a JSON format.
- getOptimizerPlanAsJSON(Plan) - Method in class org.apache.flink.client.LocalExecutor
-
Creates a JSON representation of the given dataflow's execution plan.
- getOptimizerPlanAsJSON(Plan) - Method in class org.apache.flink.client.RemoteExecutor
-
- getOptimizerPlanAsJSON(OptimizedPlan) - Method in class org.apache.flink.optimizer.plandump.PlanJSONDumpGenerator
-
- getOptimizerPropertiesJson(JsonFactory, PlanNode) - Static method in class org.apache.flink.optimizer.plantranslate.JsonMapper
-
- getOptions() - Method in class org.apache.flink.contrib.streaming.state.RocksDBStateBackend
-
Gets the options factory that lazily creates the RocksDB options.
- getOrCreateKeyedState(TypeSerializer<N>, StateDescriptor<S, V>) - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
-
- getOrCreateKeyedState(TypeSerializer<N>, StateDescriptor<S, T>) - Method in interface org.apache.flink.runtime.state.KeyedStateBackend
-
Creates or retrieves a keyed state backed by this state backend.
- getOrCreateKeyedState(TypeSerializer<N>, StateDescriptor<S, T>) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- getOrDefault(boolean) - Method in enum org.apache.flink.util.TernaryBoolean
-
Gets the boolean value corresponding to this value.
- getOrder(int) - Method in class org.apache.flink.api.common.operators.Ordering
-
- getOrderdate() - Method in class org.apache.flink.examples.java.relational.TPCHQuery3.Order
-
- getOrdering() - Method in class org.apache.flink.api.common.operators.base.PartitionOperatorBase
-
- getOrdering() - Method in class org.apache.flink.optimizer.dataproperties.LocalProperties
-
Gets the key order.
- getOrdering() - Method in class org.apache.flink.optimizer.dataproperties.RequestedGlobalProperties
-
Gets the key order.
- getOrdering() - Method in class org.apache.flink.optimizer.dataproperties.RequestedLocalProperties
-
Gets the key order.
- getOrderkey() - Method in class org.apache.flink.examples.java.relational.TPCHQuery3.Lineitem
-
- getOrderKey() - Method in class org.apache.flink.examples.java.relational.TPCHQuery3.Order
-
- getOriginalErrorClassName() - Method in exception org.apache.flink.util.SerializedThrowable
-
- getOriginalKeyFieldTypes() - Method in class org.apache.flink.api.common.operators.Keys.ExpressionKeys
-
- getOriginalKeyFieldTypes() - Method in class org.apache.flink.api.common.operators.Keys
-
- getOriginalKeyFieldTypes() - Method in class org.apache.flink.api.common.operators.Keys.SelectorFunctionKeys
-
- getOriginalNameFromInternal(String) - Static method in class org.apache.flink.cep.nfa.compiler.NFAStateNameHandler
-
- getOriginalOptimizerNode() - Method in class org.apache.flink.optimizer.plan.PlanNode
-
Gets the node from the optimizer DAG for which this plan candidate node was created.
- getOriginalPlan() - Method in class org.apache.flink.optimizer.plan.OptimizedPlan
-
Gets the original program's dataflow plan from which this optimized plan was created.
- getOutDegree() - Method in class org.apache.flink.graph.asm.degree.annotate.directed.VertexDegrees.Degrees
-
- getOutDegree() - Method in class org.apache.flink.graph.spargel.GatherFunction
-
Retrieve the vertex out-degree (number of out-going edges).
- getOutDegree() - Method in class org.apache.flink.graph.spargel.ScatterFunction
-
Retrieve the vertex out-degree (number of out-going edges).
- getOutEdgeIndices() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getOutEdges(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getOutEdges() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getOutEdgesInOrder(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getOuterJoinType() - Method in class org.apache.flink.api.common.operators.base.OuterJoinOperatorBase
-
- getOutgoingChannels() - Method in class org.apache.flink.optimizer.plan.PlanNode
-
Gets a list of all outgoing channels leading to successors.
- getOutgoingConnections() - Method in class org.apache.flink.optimizer.dag.DataSinkNode
-
Gets all outgoing connections, which is an empty set for the data sink.
- getOutgoingConnections() - Method in class org.apache.flink.optimizer.dag.OptimizerNode
-
The list of outgoing connections from this node to succeeding tasks.
- getOutgoingConnections() - Method in class org.apache.flink.optimizer.dag.SinkJoiner
-
- getOutputCardinality() - Method in class org.apache.flink.api.common.operators.CompilerHints
-
- getOutputCollector() - Method in class org.apache.flink.runtime.operators.BatchTask
-
- getOutputCollector(AbstractInvokable, TaskConfig, ClassLoader, List<RecordWriter<?>>, int, int) - Static method in class org.apache.flink.runtime.operators.BatchTask
-
Creates the
Collector
for the given task, as described by the given configuration.
- getOutputCollector() - Method in class org.apache.flink.runtime.operators.chaining.ChainedDriver
-
- getOutputCollector() - Method in interface org.apache.flink.runtime.operators.TaskContext
-
- getOutputComparator(int, ClassLoader) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getOutputDataDistribution(int, ClassLoader) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getOutputDirectoryMode() - Method in class org.apache.flink.api.common.io.FileOutputFormat
-
- getOutputFilePath() - Method in class org.apache.flink.api.common.io.FileOutputFormat
-
- getOutputPartitioner(int, ClassLoader) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getOutputSchema() - Method in class org.apache.flink.hcatalog.HCatInputFormatBase
-
Returns the HCatSchema
of the HCatRecord
returned by this InputFormat.
- getOutputSelector() - Method in class org.apache.flink.streaming.api.transformations.SplitTransformation
-
Returns the OutputSelector
.
- getOutputSelectors(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getOutputSelectors() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getOutputSerializer(ClassLoader) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getOutputShipStrategy(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getOutputSize() - Method in class org.apache.flink.api.common.operators.CompilerHints
-
- getOutputTag() - Method in class org.apache.flink.streaming.api.graph.StreamEdge
-
- getOutputTag() - Method in class org.apache.flink.streaming.api.transformations.SideOutputTransformation
-
- getOutputType() - Method in class org.apache.flink.api.common.operators.OperatorInformation
-
Gets the return type of the user code function.
- getOutputType() - Method in class org.apache.flink.api.java.io.jdbc.JDBCAppendTableSink
-
- getOutputType() - Method in class org.apache.flink.streaming.api.transformations.StreamTransformation
-
- getOutputType() - Method in class org.apache.flink.streaming.connectors.cassandra.CassandraAppendTableSink
-
- getOutputType() - Method in class org.apache.flink.streaming.connectors.kafka.KafkaTableSink
-
- getOutputType() - Method in class org.apache.flink.table.client.gateway.local.CollectStreamResult
-
- getOutputType() - Method in class org.apache.flink.table.client.gateway.local.CollectStreamTableSink
-
- getOutputType() - Method in interface org.apache.flink.table.client.gateway.local.DynamicResult
-
Returns the output type as defined by the query.
- getOversizedRecordCount() - Method in class org.apache.flink.runtime.operators.GroupReduceCombineDriver
-
Gets the number of oversized records handled by this combiner.
- getOwner() - Method in class org.apache.flink.core.memory.MemorySegment
-
Gets the owner of this memory segment.
- getOwner() - Method in class org.apache.flink.runtime.instance.Slot
-
Gets the owner of this slot.
- getOwningJob(AllocationID) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
-
- getOwningTaskName() - Method in interface org.apache.flink.runtime.io.network.partition.consumer.InputGate
-
- getOwningTaskName() - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
-
- getOwningTaskName() - Method in class org.apache.flink.runtime.io.network.partition.consumer.UnionInputGate
-
- getOwningTaskName() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
-
- getPackages() - Method in class org.apache.flink.runtime.util.DependencyVisitor
-
- getPact() - Method in class org.apache.flink.table.explain.Node
-
- getPactPlanAsJSON(List<DataSinkNode>) - Method in class org.apache.flink.optimizer.plandump.PlanJSONDumpGenerator
-
- getPageRankScore() - Method in class org.apache.flink.graph.library.linkanalysis.PageRank.Result
-
Get the PageRank score.
- getPageSize() - Method in interface org.apache.flink.runtime.io.network.partition.consumer.InputGate
-
- getPageSize() - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
-
- getPageSize() - Method in class org.apache.flink.runtime.io.network.partition.consumer.UnionInputGate
-
- getPageSize() - Method in class org.apache.flink.runtime.memory.MemoryManager
-
Gets the size of the pages handled by the memory manager.
- getPairComparator() - Method in class org.apache.flink.optimizer.plan.DualInputPlanNode
-
- getPairComparatorFactory(ClassLoader) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getParallelism() - Method in class org.apache.flink.api.common.ArchivedExecutionConfig
-
- getParallelism() - Method in class org.apache.flink.api.common.ExecutionConfig
-
Gets the parallelism with which operation are executed by default.
- getParallelism() - Method in class org.apache.flink.api.common.operators.Operator
-
Gets the parallelism for this contract instance.
- getParallelism() - Method in class org.apache.flink.api.java.CollectionEnvironment
-
- getParallelism() - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
Gets the parallelism with which operation are executed by default.
- getParallelism() - Method in class org.apache.flink.api.java.operators.DataSink
-
Returns the parallelism of this data sink.
- getParallelism() - Method in class org.apache.flink.api.java.operators.DeltaIteration
-
Gets the iteration's parallelism.
- getParallelism() - Method in class org.apache.flink.api.java.operators.Operator
-
Returns the parallelism of this operator.
- getParallelism() - Method in class org.apache.flink.client.cli.ProgramOptions
-
- getParallelism() - Method in class org.apache.flink.graph.IterationConfiguration
-
Gets the iteration's parallelism.
- getParallelism() - Method in class org.apache.flink.optimizer.dag.OptimizerNode
-
Gets the parallelism for the operator represented by this optimizer node.
- getParallelism() - Method in class org.apache.flink.optimizer.plan.PlanNode
-
- getParallelism() - Method in class org.apache.flink.runtime.checkpoint.OperatorState
-
- getParallelism() - Method in class org.apache.flink.runtime.checkpoint.TaskState
-
Deprecated.
- getParallelism() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionJobVertex
-
Returns the parallelism for this job vertex.
- getParallelism() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionJobVertex
-
- getParallelism() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
- getParallelism() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
Gets the parallelism of the task.
- getParallelism() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
-
- getParallelism() - Method in class org.apache.flink.runtime.webmonitor.handlers.JarRunRequestBody
-
- getParallelism() - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Gets the parallelism for this operator.
- getParallelism() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Gets the parallelism with which operation are executed by default.
- getParallelism() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getParallelism() - Method in class org.apache.flink.streaming.api.transformations.StreamTransformation
-
Returns the parallelism of this StreamTransformation
.
- getParallelism() - Method in class org.apache.flink.table.client.config.Execution
-
- getParallelism() - Method in class org.apache.flink.table.explain.Node
-
- getParallelism() - Method in class org.apache.flink.test.util.JavaProgramTestBase
-
- getParallelSubtaskIndex() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecution
-
Returns the subtask index of this execution.
- getParallelSubtaskIndex() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionVertex
-
Returns the subtask index of this execution vertex.
- getParallelSubtaskIndex() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecution
-
- getParallelSubtaskIndex() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionVertex
-
- getParallelSubtaskIndex() - Method in class org.apache.flink.runtime.executiongraph.Execution
-
- getParallelSubtaskIndex() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- getParameters() - Method in class org.apache.flink.api.common.operators.Operator
-
Gets the stub parameters of this contract.
- getParameters() - Method in class org.apache.flink.api.java.operators.DataSink
-
- getParameters() - Method in class org.apache.flink.api.java.operators.DataSource
-
- getParameters() - Method in class org.apache.flink.api.java.operators.SingleInputUdfOperator
-
- getParameters() - Method in class org.apache.flink.api.java.operators.TwoInputUdfOperator
-
- getParameters() - Method in interface org.apache.flink.api.java.operators.UdfOperator
-
- getParameterType(Class<?>, Class<?>, int) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
- getParameterTypes() - Method in class org.apache.flink.api.java.typeutils.TypeExtractionUtils.LambdaExecutable
-
- getParameterTypes() - Method in class org.apache.flink.runtime.rpc.messages.LocalRpcInvocation
-
- getParameterTypes() - Method in class org.apache.flink.runtime.rpc.messages.RemoteRpcInvocation
-
- getParameterTypes() - Method in interface org.apache.flink.runtime.rpc.messages.RpcInvocation
-
Returns the method's parameter types
- getParameterValues() - Method in class org.apache.flink.api.java.io.jdbc.split.GenericParameterValuesProvider
-
- getParameterValues() - Method in class org.apache.flink.api.java.io.jdbc.split.NumericBetweenParametersProvider
-
- getParameterValues() - Method in interface org.apache.flink.api.java.io.jdbc.split.ParameterValuesProvider
-
Returns the necessary parameters array to use for query in parallel a table.
- getParent() - Method in class org.apache.flink.core.fs.Path
-
Returns the parent of a path, i.e., everything that precedes the last separator
or null
if at root.
- getParent() - Method in class org.apache.flink.runtime.instance.Slot
-
Gets the parent slot of this slot.
- getParentFirstLoaderPatterns(Configuration) - Static method in class org.apache.flink.configuration.CoreOptions
-
- getParserForType(Class<T>) - Static method in class org.apache.flink.types.parser.FieldParser
-
Gets the parser for the type specified by the given class.
- getPartialSolution() - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase
-
- getPartialSolution() - Method in class org.apache.flink.optimizer.dag.BulkIterationNode
-
Gets the partialSolution from this BulkIterationNode.
- getPartialSolutionNode() - Method in class org.apache.flink.optimizer.plan.BulkPartialSolutionPlanNode
-
- getPartialSolutionPlanNode() - Method in class org.apache.flink.optimizer.plan.BulkIterationPlanNode
-
- getPartition() - Method in class org.apache.flink.streaming.connectors.kafka.internals.KafkaTopicPartition
-
- getPartition() - Method in class org.apache.flink.streaming.connectors.kafka.internals.KafkaTopicPartitionState
-
- getPartitionById(IntermediateResultPartitionID) - Method in class org.apache.flink.runtime.executiongraph.IntermediateResult
-
Returns the partition with the given ID.
- getPartitionedFields() - Method in class org.apache.flink.optimizer.dataproperties.RequestedGlobalProperties
-
Gets the fields on which the data is partitioned.
- getPartitionedState(N, TypeSerializer<N>, StateDescriptor<S, ?>) - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
-
TODO: NOTE: This method does a lot of work caching / retrieving states just to update the namespace.
- getPartitionedState(StateDescriptor<S, ?>) - Method in class org.apache.flink.runtime.state.DefaultKeyedStateStore
-
- getPartitionedState(N, TypeSerializer<N>, StateDescriptor<S, ?>) - Method in interface org.apache.flink.runtime.state.KeyedStateBackend
-
Creates or retrieves a partitioned state backed by this state backend.
- getPartitionedState(StateDescriptor<S, ?>) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
Creates a partitioned state handle, using the state backend configured for this task.
- getPartitionedState(N, TypeSerializer<N>, StateDescriptor<S, ?>) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
Creates a partitioned state handle, using the state backend configured for this task.
- getPartitionedState(StateDescriptor<S, ?>) - Method in interface org.apache.flink.streaming.api.windowing.triggers.Trigger.TriggerContext
-
Retrieves a
State
object that can be used to interact with
fault-tolerant state that is scoped to the window and key of the current
trigger invocation.
- getPartitionedState(StateDescriptor<S, ?>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
-
- getPartitionedState(StateDescriptor<S, ?>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.PerWindowStateStore
-
- getPartitioner() - Method in class org.apache.flink.api.java.operators.CoGroupOperator.CoGroupOperatorSets.CoGroupOperatorSetsPredicate.CoGroupOperatorWithoutFunction
-
Gets the custom partitioner used by this join, or null
, if none is set.
- getPartitioner() - Method in class org.apache.flink.api.java.operators.CoGroupOperator
-
Gets the custom partitioner used by this join, or null
, if none is set.
- getPartitioner() - Method in class org.apache.flink.api.java.operators.JoinOperator
-
Gets the custom partitioner used by this join, or null
, if none is set.
- getPartitioner() - Method in class org.apache.flink.optimizer.plan.Channel
-
- getPartitioner() - Method in class org.apache.flink.streaming.api.graph.StreamEdge
-
- getPartitioner() - Method in class org.apache.flink.streaming.api.transformations.PartitionTransformation
-
Returns the StreamPartitioner
that must be used for partitioning the elements
of the input StreamTransformation
.
- getPartitionerTypes(Partitioner<T>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
- getPartitionerTypes(Partitioner<T>, String, boolean) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
- getPartitionId() - Method in class org.apache.flink.runtime.deployment.ResultPartitionDeploymentDescriptor
-
- getPartitionId() - Method in class org.apache.flink.runtime.executiongraph.IntermediateResultPartition
-
- getPartitionId() - Method in interface org.apache.flink.runtime.io.network.api.writer.ResultPartitionWriter
-
- getPartitionId() - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputChannel
-
- getPartitionId() - Method in exception org.apache.flink.runtime.io.network.partition.PartitionNotFoundException
-
- getPartitionId() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
-
- getPartitionId() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartitionID
-
- getPartitioning() - Method in class org.apache.flink.optimizer.dataproperties.GlobalProperties
-
- getPartitioning() - Method in class org.apache.flink.optimizer.dataproperties.RequestedGlobalProperties
-
Gets the partitioning property.
- getPartitioningFanOutNoEstimates(int) - Static method in class org.apache.flink.runtime.operators.hash.MutableHashTable
-
Gets the number of partitions to be used for an initial hash-table, when no estimates are
available.
- getPartitioningFields() - Method in class org.apache.flink.optimizer.dataproperties.GlobalProperties
-
- getPartitioningOrdering() - Method in class org.apache.flink.optimizer.dataproperties.GlobalProperties
-
- getPartitionLeadersForTopics(List<String>) - Method in class org.apache.flink.streaming.connectors.kafka.internals.Kafka08PartitionDiscoverer
-
Send request to Kafka to get partitions for topics.
- getPartitionMethod() - Method in class org.apache.flink.api.common.operators.base.PartitionOperatorBase
-
- getPartitionNumber() - Method in class org.apache.flink.runtime.executiongraph.IntermediateResultPartition
-
- getPartitionNumber() - Method in class org.apache.flink.runtime.operators.hash.HashPartition
-
Gets the partition number of this partition.
- getPartitionNumber() - Method in class org.apache.flink.runtime.operators.hash.InMemoryPartition
-
Gets the partition number of this partition.
- getPartitionOrdering() - Method in class org.apache.flink.api.common.operators.base.SortPartitionOperatorBase
-
- getPartitionRequestInitialBackoff() - Method in class org.apache.flink.runtime.io.network.NetworkEnvironment
-
- getPartitionRequestMaxBackoff() - Method in class org.apache.flink.runtime.io.network.NetworkEnvironment
-
- getPartitions() - Method in class org.apache.flink.runtime.executiongraph.IntermediateResult
-
- getPartitionsByTopic(String, KafkaProducer<byte[], byte[]>) - Static method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducerBase
-
- getPartitionStateChecker() - Method in class org.apache.flink.runtime.taskexecutor.JobManagerConnection
-
- getPartitionStateSerializer() - Method in class org.apache.flink.runtime.state.RegisteredOperatorBackendStateMetaInfo
-
- getPartitionStateSerializer() - Method in class org.apache.flink.runtime.state.RegisteredOperatorBackendStateMetaInfo.Snapshot
-
- getPartitionStateSerializerConfigSnapshot() - Method in class org.apache.flink.runtime.state.RegisteredOperatorBackendStateMetaInfo.Snapshot
-
- getPartitionType() - Method in class org.apache.flink.runtime.deployment.ResultPartitionDeploymentDescriptor
-
- getPartitionType() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
-
Returns the type of this result partition.
- getPassword() - Method in class org.apache.flink.streaming.connectors.rabbitmq.common.RMQConnectionConfig
-
Retrieve the password.
- getPassword(String) - Method in class org.apache.hadoop.conf.Configuration
-
Get the value for a known password configuration element.
- getPasswordFromConfig(String) - Method in class org.apache.hadoop.conf.Configuration
-
Fallback to clear text passwords in configuration.
- getPasswordFromCredentialProviders(String) - Method in class org.apache.hadoop.conf.Configuration
-
Try and resolve the provided element name as a credential provider
alias.
- getPath() - Method in class org.apache.flink.core.fs.FileInputSplit
-
Returns the path of the file containing this split's data.
- getPath() - Method in interface org.apache.flink.core.fs.FileStatus
-
Returns the corresponding Path to the FileStatus.
- getPath() - Method in class org.apache.flink.core.fs.local.LocalFileStatus
-
- getPath() - Method in class org.apache.flink.core.fs.Path
-
Return full path.
- getPath() - Method in class org.apache.flink.examples.java.distcp.FileCopyTask
-
- getPath() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileStatus
-
- getPath() - Method in class org.apache.flink.runtime.io.disk.iomanager.FileIOChannel.ID
-
Returns the path to the underlying temporary file.
- getPath() - Method in class org.apache.flink.runtime.webmonitor.history.ArchivedJson
-
- getPathFile() - Method in class org.apache.flink.runtime.io.disk.iomanager.FileIOChannel.ID
-
Returns the path to the underlying temporary file as a File.
- getPathForJob(JobID) - Static method in class org.apache.flink.runtime.jobmanager.ZooKeeperSubmittedJobGraphStore
-
Returns the JobID as a String (with leading slash).
- getPathParameter(Class<PP>) - Method in class org.apache.flink.runtime.rest.handler.HandlerRequest
-
- getPathParameters() - Method in class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingStatusMessageParameters
-
- getPathParameters() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointMessageParameters
-
- getPathParameters() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointMessageParameters
-
- getPathParameters() - Method in class org.apache.flink.runtime.rest.messages.EmptyMessageParameters
-
- getPathParameters() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedJobMetricsParameters
-
- getPathParameters() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedSubtaskMetricsParameters
-
- getPathParameters() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AggregateTaskManagerMetricsParameters
-
- getPathParameters() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.JobManagerMetricsMessageParameters
-
- getPathParameters() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.SubtaskMetricsMessageParameters
-
- getPathParameters() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalStatusMessageParameters
-
- getPathParameters() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointStatusMessageParameters
-
- getPathParameters() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointTriggerMessageParameters
-
- getPathParameters() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskAttemptMessageParameters
-
- getPathParameters() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskMessageParameters
-
- getPathParameters() - Method in class org.apache.flink.runtime.rest.messages.JobMessageParameters
-
- getPathParameters() - Method in class org.apache.flink.runtime.rest.messages.JobTerminationMessageParameters
-
- getPathParameters() - Method in class org.apache.flink.runtime.rest.messages.JobVertexMessageParameters
-
- getPathParameters() - Method in class org.apache.flink.runtime.rest.messages.MessageParameters
-
- getPathParameters() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMessageParameters
-
- getPathParameters() - Method in class org.apache.flink.runtime.webmonitor.handlers.JarDeleteMessageParameters
-
- getPathParameters() - Method in class org.apache.flink.runtime.webmonitor.handlers.JarPlanMessageParameters
-
- getPathParameters() - Method in class org.apache.flink.runtime.webmonitor.handlers.JarRunMessageParameters
-
- getPaths() - Method in class org.apache.flink.runtime.rest.handler.legacy.checkpoints.CheckpointConfigHandler
-
- getPaths() - Method in class org.apache.flink.runtime.rest.handler.legacy.checkpoints.CheckpointStatsDetailsHandler
-
- getPaths() - Method in class org.apache.flink.runtime.rest.handler.legacy.checkpoints.CheckpointStatsDetailsSubtasksHandler
-
- getPaths() - Method in class org.apache.flink.runtime.rest.handler.legacy.checkpoints.CheckpointStatsHandler
-
- getPaths() - Method in class org.apache.flink.runtime.rest.handler.legacy.ClusterConfigHandler
-
- getPaths() - Method in class org.apache.flink.runtime.rest.handler.legacy.ClusterOverviewHandler
-
- getPaths() - Method in class org.apache.flink.runtime.rest.handler.legacy.CurrentJobIdsHandler
-
- getPaths() - Method in class org.apache.flink.runtime.rest.handler.legacy.DashboardConfigHandler
-
- getPaths() - Method in class org.apache.flink.runtime.rest.handler.legacy.JobAccumulatorsHandler
-
- getPaths() - Method in class org.apache.flink.runtime.rest.handler.legacy.JobCancellationHandler
-
- getPaths() - Method in class org.apache.flink.runtime.rest.handler.legacy.JobConfigHandler
-
- getPaths() - Method in class org.apache.flink.runtime.rest.handler.legacy.JobDetailsHandler
-
- getPaths() - Method in class org.apache.flink.runtime.rest.handler.legacy.JobExceptionsHandler
-
- getPaths() - Method in class org.apache.flink.runtime.rest.handler.legacy.JobPlanHandler
-
- getPaths() - Method in class org.apache.flink.runtime.rest.handler.legacy.JobsOverviewHandler
-
- getPaths() - Method in class org.apache.flink.runtime.rest.handler.legacy.JobStoppingHandler
-
- getPaths() - Method in class org.apache.flink.runtime.rest.handler.legacy.JobVertexAccumulatorsHandler
-
- getPaths() - Method in class org.apache.flink.runtime.rest.handler.legacy.JobVertexBackPressureHandler
-
- getPaths() - Method in class org.apache.flink.runtime.rest.handler.legacy.JobVertexDetailsHandler
-
- getPaths() - Method in class org.apache.flink.runtime.rest.handler.legacy.JobVertexTaskManagersHandler
-
- getPaths() - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.AggregatingJobsMetricsHandler
-
- getPaths() - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.AggregatingSubtasksMetricsHandler
-
- getPaths() - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.AggregatingTaskManagersMetricsHandler
-
- getPaths() - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.JobManagerMetricsHandler
-
- getPaths() - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.JobMetricsHandler
-
- getPaths() - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.JobVertexMetricsHandler
-
Deprecated.
- getPaths() - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.SubtaskMetricsHandler
-
- getPaths() - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.TaskManagerMetricsHandler
-
- getPaths() - Method in interface org.apache.flink.runtime.rest.handler.legacy.RequestHandler
-
Returns an array of REST URL's under which this handler can be registered.
- getPaths() - Method in class org.apache.flink.runtime.rest.handler.legacy.SubtaskCurrentAttemptDetailsHandler
-
- getPaths() - Method in class org.apache.flink.runtime.rest.handler.legacy.SubtaskExecutionAttemptAccumulatorsHandler
-
- getPaths() - Method in class org.apache.flink.runtime.rest.handler.legacy.SubtaskExecutionAttemptDetailsHandler
-
- getPaths() - Method in class org.apache.flink.runtime.rest.handler.legacy.SubtasksAllAccumulatorsHandler
-
- getPaths() - Method in class org.apache.flink.runtime.rest.handler.legacy.SubtasksTimesHandler
-
- getPaths() - Method in class org.apache.flink.runtime.rest.handler.legacy.TaskManagerLogHandler
-
- getPaths() - Method in class org.apache.flink.runtime.rest.handler.legacy.TaskManagersHandler
-
- getPaths() - Method in interface org.apache.flink.runtime.rest.handler.WebHandler
-
Returns an array of REST URL's under which this handler can be registered.
- getPaths() - Method in class org.apache.flink.runtime.webmonitor.handlers.legacy.JarAccessDeniedHandler
-
- getPaths() - Method in class org.apache.flink.runtime.webmonitor.handlers.legacy.JarDeleteHandler
-
- getPaths() - Method in class org.apache.flink.runtime.webmonitor.handlers.legacy.JarListHandler
-
- getPaths() - Method in class org.apache.flink.runtime.webmonitor.handlers.legacy.JarPlanHandler
-
- getPaths() - Method in class org.apache.flink.runtime.webmonitor.handlers.legacy.JarRunHandler
-
- getPaths() - Method in class org.apache.flink.runtime.webmonitor.handlers.legacy.JarUploadHandler
-
- getPaths() - Method in class org.apache.flink.runtime.webmonitor.RuntimeMonitorHandler
-
- getPattern() - Method in class org.apache.flink.cep.PatternStream
-
- getPattern(String, Pattern) - Method in class org.apache.hadoop.conf.Configuration
-
Get the value of the name
property as a Pattern
.
- getPatternName() - Method in class org.apache.flink.cep.nfa.AfterMatchSkipStrategy
-
Get the referenced pattern name of this strategy.
- getPayload() - Method in class org.apache.flink.runtime.instance.SharedSlot
-
- getPayload() - Method in class org.apache.flink.runtime.instance.SimpleSlot
-
- getPayload() - Method in interface org.apache.flink.runtime.jobmaster.LogicalSlot
-
Returns the set payload or null if none.
- getPayload() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SingleLogicalSlot
-
- getPayload() - Method in interface org.apache.flink.runtime.rpc.messages.FencedMessage
-
- getPayload() - Method in class org.apache.flink.runtime.rpc.messages.LocalFencedMessage
-
- getPayload() - Method in class org.apache.flink.runtime.rpc.messages.RemoteFencedMessage
-
- getPayload() - Method in class org.apache.flink.runtime.rpc.messages.UnfencedMessage
-
- getPayload() - Method in class org.apache.flink.streaming.tests.Event
-
- getPayload() - Method in class org.apache.flink.table.client.gateway.TypedResult
-
- getPendingCheckpoint() - Method in class org.apache.flink.runtime.checkpoint.CheckpointTriggerResult
-
- getPendingCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
- getPendingCommitTransactions() - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.State
-
- getPendingTransaction() - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.State
-
- getPermanentBlobService() - Method in class org.apache.flink.runtime.blob.BlobCacheService
-
- getPermanentBlobService() - Method in class org.apache.flink.runtime.blob.BlobServer
-
- getPermanentBlobService() - Method in interface org.apache.flink.runtime.blob.BlobService
-
Returns a BLOB service for accessing permanent BLOBs.
- getPhysicalSlotNumber() - Method in class org.apache.flink.runtime.instance.SharedSlot
-
- getPhysicalSlotNumber() - Method in class org.apache.flink.runtime.instance.SimpleSlot
-
- getPhysicalSlotNumber() - Method in class org.apache.flink.runtime.instance.SimpleSlotContext
-
- getPhysicalSlotNumber() - Method in interface org.apache.flink.runtime.jobmaster.LogicalSlot
-
Gets the slot number on the TaskManager.
- getPhysicalSlotNumber() - Method in interface org.apache.flink.runtime.jobmaster.SlotContext
-
Gets the number of the slot.
- getPhysicalSlotNumber() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SingleLogicalSlot
-
- getPipelineBreakingExchange(ExecutionMode) - Static method in enum org.apache.flink.runtime.io.network.DataExchangeMode
-
- getPlan(String...) - Method in interface org.apache.flink.api.common.Program
-
The method which is invoked by the compiler to get the job that is then compiled into an
executable schedule.
- getPlan() - Method in class org.apache.flink.client.program.JobWithJars
-
Returns the plan.
- getPlan() - Method in class org.apache.flink.client.program.PreviewPlanEnvironment
-
- getPlanAsJSON(Plan) - Static method in class org.apache.flink.client.LocalExecutor
-
Creates a JSON representation of the given dataflow plan.
- getPlanNode() - Method in class org.apache.flink.optimizer.dag.OptimizerNode
-
- getPlanNode() - Method in class org.apache.flink.optimizer.plan.PlanNode
-
- getPlanNode() - Method in interface org.apache.flink.optimizer.plandump.DumpableNode
-
- getPlanWithJars() - Method in class org.apache.flink.client.program.PackagedProgram
-
Returns the plan with all required jars.
- getPlanWithoutJars() - Method in class org.apache.flink.client.program.PackagedProgram
-
Returns the plan without the required jars when the files are already provided by the cluster.
- getPoints() - Method in class org.apache.flink.metrics.datadog.DMetric
-
- getPojoFieldAt(int) - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo
-
- getPort() - Method in class org.apache.flink.metrics.jmx.JMXReporter
-
- getPort() - Method in class org.apache.flink.runtime.blob.AbstractBlobCache
-
Returns the port the BLOB server is listening on.
- getPort() - Method in class org.apache.flink.runtime.blob.BlobCacheService
-
- getPort() - Method in class org.apache.flink.runtime.blob.BlobServer
-
Returns the port on which the server is listening.
- getPort() - Method in interface org.apache.flink.runtime.blob.BlobService
-
Returns the port of the BLOB server that this BLOB service is working with.
- getPort() - Method in class org.apache.flink.runtime.minicluster.StandaloneMiniCluster
-
- getPort() - Method in class org.apache.flink.runtime.rpc.akka.AkkaRpcService
-
- getPort() - Method in interface org.apache.flink.runtime.rpc.RpcService
-
Return the port under which the rpc service is reachable.
- getPort() - Method in class org.apache.flink.runtime.util.LeaderConnectionInfo
-
- getPort() - Method in class org.apache.flink.streaming.api.environment.RemoteStreamEnvironment
-
Gets the port of the master (JobManager), where the
program will be executed.
- getPort() - Method in class org.apache.flink.streaming.connectors.rabbitmq.common.RMQConnectionConfig
-
- getPort() - Method in class org.apache.flink.streaming.experimental.SocketStreamIterator
-
Returns the port on which the iterator is getting the data.
- getPortRangeFromString(String) - Static method in class org.apache.flink.util.NetUtils
-
Returns an iterator over available ports defined by the range definition.
- getPos() - Method in class org.apache.flink.api.common.io.InputStreamFSInputWrapper
-
- getPos() - Method in class org.apache.flink.core.fs.AbstractMultiFSDataInputStream
-
- getPos() - Method in class org.apache.flink.core.fs.FSDataInputStream
-
Gets the current position in the input stream.
- getPos() - Method in class org.apache.flink.core.fs.FSDataInputStreamWrapper
-
- getPos() - Method in class 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() - Method in class org.apache.flink.core.fs.FSDataOutputStreamWrapper
-
- getPos() - Method in class org.apache.flink.core.fs.local.LocalDataInputStream
-
- getPos() - Method in class org.apache.flink.core.fs.local.LocalDataOutputStream
-
- getPos() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopDataInputStream
-
- getPos() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopDataOutputStream
-
- getPos() - Method in class org.apache.flink.runtime.state.DuplicatingCheckpointOutputStream
-
- getPos() - Method in class org.apache.flink.runtime.state.filesystem.FileBasedStateOutputStream
-
- getPos() - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointMetadataOutputStream
-
- getPos() - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStreamFactory.FsCheckpointStateOutputStream
-
- getPos() - Method in class org.apache.flink.runtime.state.memory.MemCheckpointStreamFactory.MemoryCheckpointOutputStream
-
- getPos() - Method in class org.apache.flink.streaming.connectors.fs.StreamWriterBase
-
- getPos() - Method in interface org.apache.flink.streaming.connectors.fs.Writer
-
Retrieves the current position, and thus size, of the output file.
- getPosition() - Method in class org.apache.flink.api.common.typeutils.CompositeType.FlatFieldDescriptor
-
- getPosition() - Method in class org.apache.flink.core.memory.ByteArrayInputStreamWithPos
-
- getPosition() - Method in class org.apache.flink.core.memory.ByteArrayOutputStreamWithPos
-
- getPosition() - Method in class org.apache.flink.runtime.io.disk.iomanager.FileSegment
-
- getPossibleGlobalProperties() - Method in class org.apache.flink.optimizer.operators.OperatorDescriptorDual
-
- getPossibleGlobalProperties() - Method in class org.apache.flink.optimizer.operators.OperatorDescriptorSingle
-
- getPossibleLocalProperties() - Method in class org.apache.flink.optimizer.operators.OperatorDescriptorDual
-
- getPossibleLocalProperties() - Method in class org.apache.flink.optimizer.operators.OperatorDescriptorSingle
-
- getPossibleProperties() - Method in class org.apache.flink.optimizer.dag.BinaryUnionNode
-
- getPossibleProperties() - Method in class org.apache.flink.optimizer.dag.BulkIterationNode
-
- getPossibleProperties() - Method in class org.apache.flink.optimizer.dag.CoGroupNode
-
- getPossibleProperties() - Method in class org.apache.flink.optimizer.dag.CoGroupRawNode
-
- getPossibleProperties() - Method in class org.apache.flink.optimizer.dag.CrossNode
-
- getPossibleProperties() - Method in class org.apache.flink.optimizer.dag.FilterNode
-
- getPossibleProperties() - Method in class org.apache.flink.optimizer.dag.FlatMapNode
-
- getPossibleProperties() - Method in class org.apache.flink.optimizer.dag.GroupCombineNode
-
- getPossibleProperties() - Method in class org.apache.flink.optimizer.dag.GroupReduceNode
-
- getPossibleProperties() - Method in class org.apache.flink.optimizer.dag.JoinNode
-
- getPossibleProperties() - Method in class org.apache.flink.optimizer.dag.MapNode
-
- getPossibleProperties() - Method in class org.apache.flink.optimizer.dag.MapPartitionNode
-
- getPossibleProperties() - Method in class org.apache.flink.optimizer.dag.OuterJoinNode
-
- getPossibleProperties() - Method in class org.apache.flink.optimizer.dag.PartitionNode
-
- getPossibleProperties() - Method in class org.apache.flink.optimizer.dag.ReduceNode
-
- getPossibleProperties() - Method in class org.apache.flink.optimizer.dag.SingleInputNode
-
- getPossibleProperties() - Method in class org.apache.flink.optimizer.dag.SinkJoiner
-
- getPossibleProperties() - Method in class org.apache.flink.optimizer.dag.SortPartitionNode
-
- getPossibleProperties() - Method in class org.apache.flink.optimizer.dag.TwoInputNode
-
- getPossibleProperties() - Method in class org.apache.flink.optimizer.dag.UnaryOperatorNode
-
- getPossibleProperties() - Method in class org.apache.flink.optimizer.dag.WorksetIterationNode
-
- getPossibleProperties() - Method in class org.apache.flink.optimizer.dag.WorksetIterationNode.SingleRootJoiner
-
- getPostPassClassName() - Method in class org.apache.flink.api.common.Plan
-
Gets the optimizer post-pass class for this job.
- getPQSize(KEY) - Method in class org.apache.flink.cep.operator.AbstractKeyedCEPPatternOperator
-
- getPrecision() - Method in class org.apache.calcite.avatica.util.DateTimeUtils.PrecisionTime
-
- getPredecessor() - Method in class org.apache.flink.optimizer.plan.SingleInputPlanNode
-
Gets the predecessor of this node, i.e.
- getPredecessorNode() - Method in class org.apache.flink.optimizer.dag.DataSinkNode
-
Gets the predecessor of this node.
- getPredecessorNode() - Method in class org.apache.flink.optimizer.dag.SingleInputNode
-
Gets the predecessor of this node.
- getPredecessors() - Method in class org.apache.flink.optimizer.dag.OptimizerNode
-
- getPredecessors() - Method in class org.apache.flink.optimizer.plan.BulkPartialSolutionPlanNode
-
- getPredecessors() - Method in class org.apache.flink.optimizer.plan.DualInputPlanNode
-
- getPredecessors() - Method in class org.apache.flink.optimizer.plan.NAryUnionPlanNode
-
- getPredecessors() - Method in class org.apache.flink.optimizer.plan.PlanNode
-
- getPredecessors() - Method in class org.apache.flink.optimizer.plan.SingleInputPlanNode
-
- getPredecessors() - Method in class org.apache.flink.optimizer.plan.SolutionSetPlanNode
-
- getPredecessors() - Method in class org.apache.flink.optimizer.plan.SourcePlanNode
-
- getPredecessors() - Method in class org.apache.flink.optimizer.plan.WorksetPlanNode
-
- getPredecessors() - Method in interface org.apache.flink.optimizer.plandump.DumpableNode
-
Gets an iterator over the predecessors.
- getPredecessors() - Method in class org.apache.flink.table.explain.Node
-
- getPredefinedOptions() - Method in class org.apache.flink.contrib.streaming.state.RocksDBStateBackend
-
Gets the currently set predefined options for RocksDB.
- getPreferredLocations() - Method in class org.apache.flink.runtime.clusterframework.types.SlotProfile
-
Returns the preferred locations for the slot.
- getPreferredLocations() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
Gets the overall preferred execution location for this vertex's current execution.
- getPreferredLocationsBasedOnInputs() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
Gets the location preferences of the vertex's current task execution, as determined by the locations
of the predecessors from which it receives input data.
- getPreferredLocationsBasedOnState() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
Gets the preferred location to execute the current task execution attempt, based on the state
that the execution attempt will resume.
- getPreferredResources() - Method in class org.apache.flink.api.common.operators.Operator
-
Gets the preferred resources for this contract instance.
- getPreferredResources() - Method in class org.apache.flink.api.java.operators.DataSink
-
Returns the preferred resources of this data sink.
- getPreferredResources() - Method in class org.apache.flink.api.java.operators.DeltaIteration
-
Gets the preferred resources from this iteration.
- getPreferredResources() - Method in class org.apache.flink.api.java.operators.Operator
-
Returns the preferred resource of this operator.
- getPreferredResources() - Method in class org.apache.flink.optimizer.plan.PlanNode
-
- getPreferredResources() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
Gets the preferred resource for the task.
- getPreferredResources() - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Gets the preferred resources for this operator.
- getPreferredResources() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getPreferredResources() - Method in class org.apache.flink.streaming.api.transformations.StreamTransformation
-
Gets the preferred resource of this stream transformation.
- getPreProcessingOperationName() - Method in class org.apache.flink.runtime.jobgraph.JobEdge
-
Gets the name of the pro-processing operation for this input.
- getPreviewPlan() - Method in class org.apache.flink.client.program.PackagedProgram
-
Returns the analyzed plan without any optimizations.
- getPrevious() - Method in class org.apache.flink.cep.pattern.Pattern
-
- getPreviousGlobalAggregate(String) - Method in class org.apache.flink.runtime.iterative.task.RuntimeAggregatorRegistry
-
- getPreviousIterationAggregate(String) - Method in interface org.apache.flink.api.common.functions.IterationRuntimeContext
-
- getPreviousIterationAggregate(String) - Method in class org.apache.flink.graph.gsa.ApplyFunction
-
Get the aggregated value that an aggregator computed in the previous iteration.
- getPreviousIterationAggregate(String) - Method in class org.apache.flink.graph.gsa.GatherFunction
-
Get the aggregated value that an aggregator computed in the previous iteration.
- getPreviousIterationAggregate(String) - Method in class org.apache.flink.graph.gsa.SumFunction
-
Get the aggregated value that an aggregator computed in the previous iteration.
- getPreviousIterationAggregate(String) - Method in class org.apache.flink.graph.pregel.ComputeFunction
-
Get the aggregated value that an aggregator computed in the previous iteration.
- getPreviousIterationAggregate(String) - Method in class org.apache.flink.graph.spargel.GatherFunction
-
Get the aggregated value that an aggregator computed in the previous iteration.
- getPreviousIterationAggregate(String) - Method in class org.apache.flink.graph.spargel.ScatterFunction
-
Get the aggregated value that an aggregator computed in the previous iteration.
- getPreviousState() - Method in class org.apache.flink.cep.nfa.ComputationState
-
- getPreviousType() - Method in exception org.apache.flink.optimizer.postpass.ConflictingFieldTypeInfoException
-
- getPrincipal() - Method in class org.apache.flink.runtime.security.SecurityConfiguration
-
- getPrintStatusDuringExecution() - Method in class org.apache.flink.client.program.ClusterClient
-
- getPriorAllocations() - Method in class org.apache.flink.runtime.clusterframework.types.SlotProfile
-
Returns the desired allocation ids for the slot.
- getPriorExecutionAttempt(int) - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionVertex
-
Returns the execution for the given attempt number.
- getPriorExecutionAttempt(int) - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionVertex
-
- getPriorExecutionAttempt(int) - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- getPrioritizedManagedKeyedState() - Method in class org.apache.flink.runtime.checkpoint.PrioritizedOperatorSubtaskState
-
Returns an immutable list with all alternative snapshots to restore the managed keyed state, in the order in
which we should attempt to restore.
- getPrioritizedManagedOperatorState() - Method in class org.apache.flink.runtime.checkpoint.PrioritizedOperatorSubtaskState
-
Returns an immutable list with all alternative snapshots to restore the managed operator state, in the order in
which we should attempt to restore.
- getPrioritizedRawKeyedState() - Method in class org.apache.flink.runtime.checkpoint.PrioritizedOperatorSubtaskState
-
Returns an immutable list with all alternative snapshots to restore the raw keyed state, in the order in which we
should attempt to restore.
- getPrioritizedRawOperatorState() - Method in class org.apache.flink.runtime.checkpoint.PrioritizedOperatorSubtaskState
-
Returns an immutable list with all alternative snapshots to restore the raw operator state, in the order in
which we should attempt to restore.
- getPrivateState() - Method in class org.apache.flink.runtime.state.IncrementalKeyedStateHandle
-
- getProber(TypeComparator<PT>, TypePairComparator<PT, T>) - Method in class org.apache.flink.runtime.operators.hash.AbstractMutableHashTable
-
- getProber(TypeComparator<PT>, TypePairComparator<PT, T>) - Method in class org.apache.flink.runtime.operators.hash.CompactingHashTable
-
- getProber(TypeComparator<PT>, TypePairComparator<PT, T>) - Method in class org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable
-
- getProbeSideBlockCount() - Method in class org.apache.flink.runtime.operators.hash.HashPartition
-
- getProbeSideChannel() - Method in class org.apache.flink.runtime.operators.hash.HashPartition
-
- getProbeSideComparator() - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
-
- getProbeSideRecordCount() - Method in class org.apache.flink.runtime.operators.hash.HashPartition
-
- getProcessingTimeService() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
Returns the
ProcessingTimeService
responsible for getting the current
processing time and registering timers.
- getProcessingTimeService() - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
-
- getProcessingTimeService() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
Returns the
ProcessingTimeService
responsible for telling the current
processing time and registering timers.
- getProcessingTimeTimers() - Method in class org.apache.flink.streaming.api.operators.InternalTimersSnapshot
-
- getProcessingTimeTimersPerKeyGroup() - Method in class org.apache.flink.streaming.api.operators.HeapInternalTimerService
-
- getProctimeAttribute() - Method in class org.apache.flink.streaming.connectors.kafka.KafkaTableSource
-
- getProducedDataSets() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
- getProducedDataSets() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
- getProducedPartitions() - Method in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
-
- getProducedPartitions() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- getProducedPartitions() - Method in class org.apache.flink.runtime.taskmanager.Task
-
- getProducedType() - Method in class org.apache.flink.addons.hbase.HBaseRowInputFormat
-
- getProducedType() - Method in class org.apache.flink.api.common.serialization.AbstractDeserializationSchema
-
Gets the type produced by this deserializer.
- getProducedType() - Method in class org.apache.flink.api.common.serialization.SimpleStringSchema
-
- getProducedType() - Method in class org.apache.flink.api.common.serialization.TypeInformationSerializationSchema
-
- getProducedType() - Method in class org.apache.flink.api.java.hadoop.mapred.HadoopInputFormat
-
- getProducedType() - Method in class org.apache.flink.api.java.hadoop.mapreduce.HadoopInputFormat
-
- getProducedType() - Method in class org.apache.flink.api.java.io.jdbc.JDBCInputFormat
-
- getProducedType() - Method in class org.apache.flink.api.java.io.RowCsvInputFormat
-
- getProducedType() - Method in class org.apache.flink.api.java.io.TypeSerializerInputFormat
-
- getProducedType() - Method in interface org.apache.flink.api.java.typeutils.ResultTypeQueryable
-
Gets the data type (as a
TypeInformation
) produced by this function or input format.
- getProducedType() - Method in class org.apache.flink.formats.avro.AvroInputFormat
-
- getProducedType() - Method in class org.apache.flink.formats.json.JsonRowDeserializationSchema
-
- getProducedType() - Method in class org.apache.flink.graph.library.ConnectedComponents.CCMessenger
-
- getProducedType() - Method in class org.apache.flink.graph.library.LabelPropagation.SendNewLabelToNeighbors
-
- getProducedType() - Method in class org.apache.flink.graph.utils.GraphUtils.MapTo
-
- getProducedType() - Method in class org.apache.flink.hadoopcompatibility.mapred.HadoopMapFunction
-
- getProducedType() - Method in class org.apache.flink.hadoopcompatibility.mapred.HadoopReduceCombineFunction
-
- getProducedType() - Method in class org.apache.flink.hadoopcompatibility.mapred.HadoopReduceFunction
-
- getProducedType() - Method in class org.apache.flink.hcatalog.HCatInputFormatBase
-
- getProducedType() - Method in class org.apache.flink.orc.OrcRowInputFormat
-
- getProducedType() - Method in class org.apache.flink.python.api.functions.PythonCoGroup
-
- getProducedType() - Method in class org.apache.flink.python.api.functions.PythonMapPartition
-
- getProducedType() - Method in class org.apache.flink.sql.tests.StreamSQLTestProgram.Generator
-
- getProducedType() - Method in class org.apache.flink.sql.tests.StreamSQLTestProgram.KillMapper
-
- getProducedType() - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumerBase
-
- getProducedType() - Method in class org.apache.flink.streaming.connectors.rabbitmq.RMQSource
-
- getProducedType() - Method in class org.apache.flink.streaming.examples.kafka.KafkaEventSchema
-
- getProducedType() - Method in class org.apache.flink.streaming.examples.statemachine.kafka.EventDeSerializer
-
- getProducedType() - Method in class org.apache.flink.streaming.util.keys.KeySelectorUtil.ArrayKeySelector
-
- getProducedType() - Method in class org.apache.flink.streaming.util.keys.KeySelectorUtil.ComparableKeySelector
-
- getProducedType() - Method in class org.apache.flink.streaming.util.serialization.JSONKeyValueDeserializationSchema
-
- getProducedType() - Method in class org.apache.flink.streaming.util.serialization.KeyedDeserializationSchemaWrapper
-
- getProducedType() - Method in class org.apache.flink.streaming.util.serialization.TypeInformationKeyValueSerializationSchema
-
- getProducer() - Method in class org.apache.flink.runtime.executiongraph.IntermediateResult
-
- getProducer() - Method in class org.apache.flink.runtime.executiongraph.IntermediateResultPartition
-
- getProducer() - Method in class org.apache.flink.runtime.jobgraph.IntermediateDataSet
-
- getProducerId() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartitionID
-
- getProducerId() - Method in class org.apache.flink.streaming.connectors.kafka.internal.FlinkKafkaProducer
-
- getProgramArgs() - Method in class org.apache.flink.client.cli.ProgramOptions
-
- getProgramArguments() - Method in class org.apache.flink.runtime.webmonitor.handlers.JarRunRequestBody
-
- getProgramOperator() - Method in class org.apache.flink.optimizer.plan.PlanNode
-
Gets the program operator that this node represents in the plan.
- getProgress() - Method in class org.apache.flink.api.java.hadoop.mapred.wrapper.HadoopDummyReporter
-
- getProgress() - Method in class org.apache.flink.yarn.YarnResourceManager
-
- getProgress() - Method in class org.apache.flink.yarn.YarnResourceManagerCallbackHandler
-
- getProperties() - Method in class org.apache.flink.api.java.utils.ParameterTool
-
- getProperties() - Method in class org.apache.flink.runtime.checkpoint.AbstractCheckpointStats
-
Returns the properties of this checkpoint.
- getProperties() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
-
- getProperties() - Method in class org.apache.flink.runtime.checkpoint.RestoredCheckpointStats
-
Returns the properties of the restored checkpoint.
- getProperties() - Method in class org.apache.flink.table.client.config.Source
-
- getProperties1() - Method in class org.apache.flink.optimizer.operators.OperatorDescriptorDual.GlobalPropertiesPair
-
- getProperties1() - Method in class org.apache.flink.optimizer.operators.OperatorDescriptorDual.LocalPropertiesPair
-
- getProperties2() - Method in class org.apache.flink.optimizer.operators.OperatorDescriptorDual.GlobalPropertiesPair
-
- getProperties2() - Method in class org.apache.flink.optimizer.operators.OperatorDescriptorDual.LocalPropertiesPair
-
- getPropertiesFromBrokerList(String) - Static method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducerBase
-
- getPropertySources(String) - Method in class org.apache.hadoop.conf.Configuration
-
Gets information about why a property was set.
- getProps() - Method in class org.apache.hadoop.conf.Configuration
-
- getPropsWithPrefix(String) - Method in class org.apache.hadoop.conf.Configuration
-
Constructs a mapping of configuration and includes all properties that
start with the specified configuration prefix.
- getProxyPortRange() - Method in class org.apache.flink.runtime.taskexecutor.QueryableStateConfiguration
-
Returns the port range where the queryable state client proxy can listen.
- getPushChainDriverClass() - Method in enum org.apache.flink.runtime.operators.DriverStrategy
-
- getQuantifier() - Method in class org.apache.flink.cep.pattern.Pattern
-
- getQuantile(double) - Method in class org.apache.flink.metrics.HistogramStatistics
-
Returns the value for the given quantile based on the represented histogram statistics.
- getQuantile(double) - Method in class org.apache.flink.runtime.metrics.DescriptiveStatisticsHistogramStatistics
-
- getQueryableStateConfig() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
-
- getQueryableStateName() - Method in class org.apache.flink.api.common.state.StateDescriptor
-
Returns the queryable state name.
- getQueryableStateName() - Method in class org.apache.flink.streaming.api.datastream.QueryableStateStream
-
Returns the name under which the state can be queried.
- getQueryConfig() - Method in class org.apache.flink.table.client.gateway.local.ExecutionContext.EnvironmentInstance
-
- getQueryExecutor() - Method in class org.apache.flink.queryablestate.network.AbstractServerBase
-
Returns the thread-pool responsible for processing incoming requests.
- getQueryParameter(Class<QP>) - Method in class org.apache.flink.runtime.rest.handler.HandlerRequest
-
- getQueryParameter(HandlerRequest<R, M>, Class<P>) - Static method in class org.apache.flink.runtime.rest.handler.util.HandlerRequestUtils
-
Returns the value of a query parameter, or null
if the query parameter is not set.
- getQueryParameter(HandlerRequest<R, M>, Class<P>, X) - Static method in class org.apache.flink.runtime.rest.handler.util.HandlerRequestUtils
-
- getQueryParameters() - Method in class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingTriggerMessageParameters
-
- getQueryParameters() - Method in class org.apache.flink.runtime.rest.messages.EmptyMessageParameters
-
- getQueryParameters() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AbstractAggregatedMetricsParameters
-
- getQueryParameters() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.JobManagerMetricsMessageParameters
-
- getQueryParameters() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.JobMetricsMessageParameters
-
- getQueryParameters() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.JobVertexMetricsMessageParameters
-
- getQueryParameters() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.SubtaskMetricsMessageParameters
-
- getQueryParameters() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.TaskManagerMetricsMessageParameters
-
- getQueryParameters() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalStatusMessageParameters
-
- getQueryParameters() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointStatusMessageParameters
-
- getQueryParameters() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointTriggerMessageParameters
-
- getQueryParameters() - Method in class org.apache.flink.runtime.rest.messages.JobAccumulatorsMessageParameters
-
- getQueryParameters() - Method in class org.apache.flink.runtime.rest.messages.JobMessageParameters
-
- getQueryParameters() - Method in class org.apache.flink.runtime.rest.messages.JobTerminationMessageParameters
-
- getQueryParameters() - Method in class org.apache.flink.runtime.rest.messages.JobVertexMessageParameters
-
- getQueryParameters() - Method in class org.apache.flink.runtime.rest.messages.MessageParameters
-
- getQueryParameters() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMessageParameters
-
- getQueryParameters() - Method in class org.apache.flink.runtime.webmonitor.handlers.JarDeleteMessageParameters
-
- getQueryParameters() - Method in class org.apache.flink.runtime.webmonitor.handlers.JarPlanMessageParameters
-
- getQueryParameters() - Method in class org.apache.flink.runtime.webmonitor.handlers.JarRunMessageParameters
-
- getQueryService() - Method in class org.apache.flink.runtime.metrics.MetricRegistryImpl
-
- getQueryServiceMessageSizeLimit() - Method in class org.apache.flink.runtime.metrics.MetricRegistryConfiguration
-
- getQueryServiceMetricInfo(CharacterFilter) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
-
Returns the metric query service scope for this group.
- getRandomFilename(String) - Static method in class org.apache.flink.util.FileUtils
-
Constructs a random filename with the given prefix and
a random part generated from hex characters.
- getRandomGenerable() - Method in class org.apache.flink.graph.generator.random.BlockInfo
-
- getRandomGenerables(long, int) - Method in class org.apache.flink.graph.generator.random.GeneratorFactoryBase
-
- getRandomGenerables(long, int) - Method in interface org.apache.flink.graph.generator.random.RandomGenerableFactory
-
The amount of work (elementCount * cyclesPerElement
) is used to
generate a list of blocks of work of near-equal size.
- getRandomOddEvenEdges(int, int, long) - Static method in class org.apache.flink.test.testdata.ConnectedComponentsData
-
Creates random edges such that even numbered vertices are connected with even numbered vertices
and odd numbered vertices only with other odd numbered ones.
- getRandomString(Random, int, int) - Static method in class org.apache.flink.util.StringUtils
-
Creates a random string with a length within the given interval.
- getRandomString(Random, int, int, char, char) - Static method in class org.apache.flink.util.StringUtils
-
Creates a random string with a length within the given interval.
- getRange(String, String) - Method in class org.apache.hadoop.conf.Configuration
-
Parse the given attribute as a set of integer ranges
- getRangeIndex(T) - Method in class org.apache.flink.api.common.distributions.CommonRangeBoundaries
-
- getRangeIndex(T) - Method in interface org.apache.flink.api.common.distributions.RangeBoundaries
-
Get the range index of record.
- getRankDataSet(ExecutionEnvironment) - Static method in class org.apache.flink.examples.java.relational.util.WebLogData
-
- getRate() - Method in class org.apache.flink.dropwizard.metrics.DropwizardMeterWrapper
-
- getRate() - Method in interface org.apache.flink.metrics.jmx.JMXReporter.JmxMeterMBean
-
- getRate() - Method in interface org.apache.flink.metrics.Meter
-
Returns the current rate of events per second.
- getRate() - Method in class org.apache.flink.metrics.MeterView
-
- getRatio() - Method in class org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo.SubtaskBackPressureInfo
-
- getRaw(String) - Method in class org.apache.hadoop.conf.Configuration
-
Get the value of the
name
property, without doing
variable expansion.If the key is
deprecated, it returns the value of the first key which replaces
the deprecated key and is not null.
- getRawClass(Type) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractionUtils
-
Returns the raw class of both parameterized types and generic arrays.
- getRawKeyedOperatorStateOutput() - Method in interface org.apache.flink.runtime.state.StateSnapshotContext
-
Returns an output stream for keyed state
- getRawKeyedOperatorStateOutput() - Method in class org.apache.flink.runtime.state.StateSnapshotContextSynchronousImpl
-
- getRawKeyedState() - Method in class org.apache.flink.runtime.checkpoint.OperatorSubtaskState
-
Returns a handle to the raw keyed state.
- getRawKeyedState() - Method in class org.apache.flink.runtime.checkpoint.SubtaskState
-
- getRawKeyedStateHandles(OperatorState, KeyGroupRange) - Static method in class org.apache.flink.runtime.checkpoint.StateAssignmentOperation
-
- getRawKeyedStateInputs() - Method in interface org.apache.flink.runtime.state.StateInitializationContext
-
Returns an iterable to obtain input streams for previously stored keyed state partitions that are assigned to
this operator.
- getRawKeyedStateInputs() - Method in class org.apache.flink.runtime.state.StateInitializationContextImpl
-
- getRawOperatorState() - Method in class org.apache.flink.runtime.checkpoint.OperatorSubtaskState
-
Returns a handle to the raw operator state.
- getRawOperatorState() - Method in class org.apache.flink.runtime.checkpoint.SubtaskState
-
- getRawOperatorStateInputs() - Method in interface org.apache.flink.runtime.state.StateInitializationContext
-
Returns an iterable to obtain input streams for previously stored operator state partitions that are assigned to
this operator.
- getRawOperatorStateInputs() - Method in class org.apache.flink.runtime.state.StateInitializationContextImpl
-
- getRawOperatorStateOutput() - Method in interface org.apache.flink.runtime.state.StateSnapshotContext
-
Returns an output stream for operator state
- getRawOperatorStateOutput() - Method in class org.apache.flink.runtime.state.StateSnapshotContextSynchronousImpl
-
- getRawPattern() - Method in class org.apache.flink.cep.pattern.GroupPattern
-
- getReadEndAfterSuperstepEnded() - Method in class org.apache.flink.runtime.iterative.concurrent.BlockingBackChannel
-
Called by iteration head after it has sent all input for the current superstep through the data channel
(blocks iteration head).
- getReaderForVersion(int, ClassLoader) - Static method in class org.apache.flink.runtime.state.KeyedBackendStateMetaInfoSnapshotReaderWriters
-
- getReaderForVersion(int, ClassLoader) - Static method in class org.apache.flink.streaming.api.operators.InternalTimersSnapshotReaderWriters
-
- getReaderIndex() - Method in interface org.apache.flink.runtime.io.network.buffer.Buffer
-
Returns the reader index of this buffer.
- getReaderIndex() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
-
- getReaderIndex() - Method in class org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
-
- getReadFields(int) - Method in class org.apache.flink.api.common.operators.DualInputSemanticProperties
-
- getReadFields(int) - Method in class org.apache.flink.api.common.operators.SemanticProperties.EmptySemanticProperties
-
- getReadFields(int) - Method in interface org.apache.flink.api.common.operators.SemanticProperties
-
Returns the position indexes of all fields of an input that are accessed by a function.
- getReadFields(int) - Method in class org.apache.flink.api.common.operators.SingleInputSemanticProperties
-
- getReadFields(int) - Method in class org.apache.flink.optimizer.dag.BinaryUnionNode.UnionSemanticProperties
-
- getReadingThread(ExceptionHandler<IOException>, MutableObjectIterator<E>, UnilateralSortMerger.CircularQueues<E>, LargeRecordHandler<E>, AbstractInvokable, TypeSerializer<E>, long) - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger
-
Creates the reading thread.
- getReadPosition() - Method in class org.apache.flink.runtime.io.disk.RandomAccessInputView
-
- getReadVersion() - Method in class org.apache.flink.core.io.VersionedIOReadableWritable
-
Returns the found serialization version.
- getReason() - Method in class org.apache.flink.runtime.messages.checkpoint.DeclineCheckpoint
-
Gets the reason why the checkpoint was declined.
- getReason() - Method in class org.apache.flink.runtime.registration.RegistrationResponse.Decline
-
Gets the reason for the rejection.
- getReceiverId() - Method in interface org.apache.flink.runtime.io.network.NetworkSequenceViewReader
-
- getRecord() - Method in class org.apache.flink.python.api.streaming.plan.PythonPlanReceiver
-
- getRecord(boolean) - Method in class org.apache.flink.python.api.streaming.plan.PythonPlanReceiver
-
- getRecord() - Method in class org.apache.flink.python.api.streaming.plan.PythonPlanStreamer
-
- getRecord(boolean) - Method in class org.apache.flink.python.api.streaming.plan.PythonPlanStreamer
-
- getRecord(int) - Method in class org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
-
- getRecord(T, int) - Method in class org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
-
- getRecord(int) - Method in interface org.apache.flink.runtime.operators.sort.InMemorySorter
-
Gets the record at the given logical position.
- getRecord(T, int) - Method in interface org.apache.flink.runtime.operators.sort.InMemorySorter
-
Gets the record at the given logical position.
- getRecord(int) - Method in class org.apache.flink.runtime.operators.sort.NormalizedKeySorter
-
- getRecord(T, int) - Method in class org.apache.flink.runtime.operators.sort.NormalizedKeySorter
-
- getRecordCount() - Method in class org.apache.flink.api.common.io.BlockInfo
-
Returns the recordCount.
- getRecordCount() - Method in class org.apache.flink.runtime.operators.hash.InMemoryPartition
-
number of records in partition including garbage
- getRecordsRead() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.IOMetricsInfo
-
- getRecordsReadFromBlock() - Method in class org.apache.flink.formats.avro.AvroInputFormat
-
- getRecordsWritten() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.IOMetricsInfo
-
- getRecordType() - Method in class org.apache.flink.table.client.gateway.local.CollectStreamTableSink
-
- getRecoveryMode(Configuration) - Static method in class org.apache.flink.runtime.util.LeaderRetrievalUtils
-
- getRecursionLevel() - Method in class org.apache.flink.runtime.operators.hash.HashPartition
-
Gets this partition's recursion level.
- getRecycler() - Method in interface org.apache.flink.runtime.io.network.buffer.Buffer
-
Gets the buffer's recycler.
- getRecycler() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
-
- getRecycler() - Method in class org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
-
- getRedirectAddress(String, RestfulGateway, Time) - Static method in class org.apache.flink.runtime.rest.handler.util.HandlerRedirectUtils
-
- getRedirectResponse(String, String) - Static method in class org.apache.flink.runtime.rest.handler.util.HandlerRedirectUtils
-
- getRedirectResponse(String, String, HttpResponseStatus) - Static method in class org.apache.flink.runtime.rest.handler.util.HandlerRedirectUtils
-
- getReduceFunction() - Method in class org.apache.flink.api.common.state.ReducingStateDescriptor
-
Returns the reduce function to be used for the reducing state.
- getReducingState(ReducingStateDescriptor<T>) - Method in interface org.apache.flink.api.common.functions.RuntimeContext
-
Gets a handle to the system's key/value reducing state.
- getReducingState(ReducingStateDescriptor<T>) - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
-
- getReducingState(ReducingStateDescriptor<T>) - Method in interface org.apache.flink.api.common.state.KeyedStateStore
-
Gets a handle to the system's key/value reducing state.
- getReducingState(ReducingStateDescriptor<T>) - Method in class org.apache.flink.runtime.state.DefaultKeyedStateStore
-
- getReducingState(ReducingStateDescriptor<T>) - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
-
- getReducingState(ReducingStateDescriptor<T>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.MergingWindowStateStore
-
- getReference() - Method in class org.apache.flink.runtime.state.SharedStateRegistry.Result
-
- getReferenceBytes() - Method in class org.apache.flink.runtime.state.CheckpointStorageLocationReference
-
Gets the reference bytes.
- getReferenceCount() - Method in class org.apache.flink.runtime.state.SharedStateRegistry.Result
-
- getRefreshInterval() - Method in class org.apache.flink.runtime.rest.handler.RestHandlerConfiguration
-
- getRefreshInterval() - Method in class org.apache.flink.runtime.rest.messages.DashboardConfiguration
-
- getRefreshInterval() - Method in class org.apache.flink.runtime.webmonitor.WebMonitorConfig
-
- getRefusedRegistrationPause() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
-
- getRegisteredBroadcastStateNames() - Method in interface org.apache.flink.api.common.state.OperatorStateStore
-
Returns a set with the names of all currently registered broadcast states.
- getRegisteredBroadcastStateNames() - Method in class org.apache.flink.runtime.state.DefaultOperatorStateBackend
-
- getRegisteredClass() - Method in class org.apache.flink.api.java.typeutils.runtime.KryoRegistration
-
- getRegisteredExecutions() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- getRegisteredInstance(ResourceID) - Method in class org.apache.flink.runtime.instance.InstanceManager
-
- getRegisteredInstanceById(InstanceID) - Method in class org.apache.flink.runtime.instance.InstanceManager
-
- getRegisteredKryoTypes() - Method in class org.apache.flink.api.common.ExecutionConfig
-
Returns the registered Kryo types.
- getRegisteredPojoTypes() - Method in class org.apache.flink.api.common.ExecutionConfig
-
Returns the registered POJO types.
- getRegisteredStateNames() - Method in interface org.apache.flink.api.common.state.OperatorStateStore
-
Returns a set with the names of all currently registered states.
- getRegisteredStateNames() - Method in class org.apache.flink.runtime.state.DefaultOperatorStateBackend
-
- getRegisteredSubclassesToSerializerConfigSnapshots() - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer.PojoSerializerConfigSnapshot
-
- getRegisteredTypesWithKryoSerializerClasses() - Method in class org.apache.flink.api.common.ExecutionConfig
-
Returns the registered types with their Kryo Serializer classes.
- getRegisteredTypesWithKryoSerializers() - Method in class org.apache.flink.api.common.ExecutionConfig
-
Returns the registered types with Kryo Serializers.
- getRegistrationId() - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorRegistrationSuccess
-
Gets the ID that the ResourceManager assigned the registration.
- getRegistrationName() - Method in class org.apache.flink.runtime.query.KvStateLocation
-
Returns the name under which the KvState instances have been registered.
- getRegistrationName() - Method in class org.apache.flink.runtime.query.KvStateMessage.LookupKvStateLocation
-
Returns the name under which the KvState has been registered.
- getRegistrationName() - Method in class org.apache.flink.runtime.query.KvStateMessage.NotifyKvStateRegistered
-
Returns the name under which the KvState has been registered.
- getRegistrationName() - Method in class org.apache.flink.runtime.query.KvStateMessage.NotifyKvStateUnregistered
-
Returns the name under which the KvState has been registered.
- getRehashThreshold() - Method in class org.apache.flink.streaming.runtime.operators.windowing.KeyMap
-
- getRelativeBackChannelMemory() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getRelativeInputMaterializationMemory(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getRelativeMemoryDriver() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getRelativeMemoryInput(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getRelativeMemoryLocalStrategy() - Method in class org.apache.flink.optimizer.plan.Channel
-
- getRelativeMemoryPerSubTask() - Method in class org.apache.flink.optimizer.plan.PlanNode
-
Gets the memory dedicated to each sub-task for this node.
- getRelativePath() - Method in class org.apache.flink.examples.java.distcp.FileCopyTask
-
- getRelativeSolutionSetMemory() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getRelativeTempMemory() - Method in class org.apache.flink.optimizer.plan.Channel
-
Gets the memory for materializing the channel's result from this Channel.
- getReleaseFuture() - Method in class org.apache.flink.runtime.executiongraph.Execution
-
Gets the release future which is completed once the execution reaches a terminal
state and the assigned resource has been released.
- getRemaining() - Method in class org.apache.flink.mesos.util.MesosResourceAllocation
-
Gets the remaining resources.
- getReplicatedInputFormat() - Method in class org.apache.flink.api.common.io.ReplicatingInputFormat
-
- getReplication() - Method in interface org.apache.flink.core.fs.FileStatus
-
Get the replication factor of a file.
- getReplication() - Method in class org.apache.flink.core.fs.local.LocalFileStatus
-
- getReplication() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileStatus
-
- getReplicationFactor() - Method in class org.apache.flink.optimizer.plan.Channel
-
Returns the replication factor of the connection.
- getReporter(MetricConfig) - Method in class org.apache.flink.dropwizard.ScheduledDropwizardReporter
-
- getReporter(MetricConfig) - Method in class org.apache.flink.metrics.graphite.GraphiteReporter
-
- getReporterConfigurations() - Method in class org.apache.flink.runtime.metrics.MetricRegistryConfiguration
-
- getReporters() - Method in class org.apache.flink.runtime.metrics.MetricRegistryImpl
-
- getRequestBody() - Method in class org.apache.flink.runtime.rest.handler.HandlerRequest
-
Returns the request body.
- getRequestClass() - Method in class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingStatusHeaders
-
- getRequestClass() - Method in class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingTriggerHeaders
-
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigHeaders
-
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatisticsHeaders
-
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatisticDetailsHeaders
-
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsHeaders
-
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.cluster.ShutdownHeaders
-
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.ClusterConfigurationInfoHeaders
-
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.ClusterOverviewHeaders
-
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.DashboardConfigurationHeaders
-
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsHeaders
-
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.job.JobExecutionResultHeaders
-
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.job.JobSubmitHeaders
-
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AbstractAggregatedMetricsHeaders
-
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AbstractMetricsHeaders
-
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalStatusHeaders
-
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalTriggerHeaders
-
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointStatusHeaders
-
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointTriggerHeaders
-
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskCurrentAttemptDetailsHeaders
-
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptAccumulatorsHeaders
-
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsHeaders
-
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.JobAccumulatorsHeaders
-
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.JobConfigHeaders
-
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.JobExceptionsHeaders
-
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.JobIdsWithStatusesOverviewHeaders
-
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.JobPlanHeaders
-
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.JobsOverviewHeaders
-
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.JobTerminationHeaders
-
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.JobVertexAccumulatorsHeaders
-
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.JobVertexBackPressureHeaders
-
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.JobVertexDetailsHeaders
-
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.JobVertexTaskManagersHeaders
-
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.SubtasksAllAccumulatorsHeaders
-
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.SubtasksTimesHeaders
-
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerDetailsHeaders
-
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerLogFileHeaders
-
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagersHeaders
-
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerStdoutFileHeaders
-
- getRequestClass() - Method in interface org.apache.flink.runtime.rest.messages.UntypedResponseMessageHeaders
-
Returns the class of the request message.
- getRequestClass() - Method in class org.apache.flink.runtime.webmonitor.handlers.JarDeleteHeaders
-
- getRequestClass() - Method in class org.apache.flink.runtime.webmonitor.handlers.JarListHeaders
-
- getRequestClass() - Method in class org.apache.flink.runtime.webmonitor.handlers.JarPlanHeaders
-
- getRequestClass() - Method in class org.apache.flink.runtime.webmonitor.handlers.JarRunHeaders
-
- getRequestClass() - Method in class org.apache.flink.runtime.webmonitor.handlers.JarUploadHeaders
-
- getRequestedChannelMax() - Method in class org.apache.flink.streaming.connectors.rabbitmq.common.RMQConnectionConfig
-
Retrieve the requested maximum channel number.
- getRequestedFrameMax() - Method in class org.apache.flink.streaming.connectors.rabbitmq.common.RMQConnectionConfig
-
Retrieve the requested maximum frame size.
- getRequestedHeartbeat() - Method in class org.apache.flink.streaming.connectors.rabbitmq.common.RMQConnectionConfig
-
Retrieve the requested heartbeat interval.
- getRequestFuture() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.PendingSlotRequest
-
- getRequestId(ByteBuf) - Static method in class org.apache.flink.queryablestate.network.messages.MessageSerializer
-
- getRequestId() - Method in class org.apache.flink.queryablestate.network.messages.RequestFailure
-
Returns the request ID responding to.
- getRequired(String) - Method in class org.apache.flink.api.java.utils.ParameterTool
-
Returns the String value for the given key.
- getRequiredClasspaths() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
Returns a list of classpaths referring to the directories/JAR files required to run this job.
- getRequiredClasspaths() - Method in class org.apache.flink.runtime.jobmaster.message.ClassloadingProps
-
- getRequiredClasspathURLs() - Method in class org.apache.flink.runtime.executiongraph.JobInformation
-
- getRequiredGlobalProps() - Method in class org.apache.flink.optimizer.plan.Channel
-
- getRequiredJarFileBlobKeys() - Method in class org.apache.flink.runtime.executiongraph.JobInformation
-
- getRequiredJarFiles() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
Returns a list of BLOB keys referring to the JAR files required to run this job.
- getRequiredJarFiles() - Method in class org.apache.flink.runtime.jobmaster.message.ClassloadingProps
-
- getRequiredLocalProps() - Method in class org.apache.flink.optimizer.plan.Channel
-
- getResolvedRootSlots() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotSharingManager
-
Returns a collection of all resolved root slots.
- getResource(String) - Method in class org.apache.hadoop.conf.Configuration
-
Get the
URL
for the named resource.
- getResourceAggregateType() - Method in class org.apache.flink.api.common.resources.Resource
-
- getResourceID() - Method in class org.apache.flink.mesos.runtime.clusterframework.RegisteredMesosWorkerNode
-
- getResourceID() - Method in class org.apache.flink.runtime.clusterframework.messages.NotifyResourceStarted
-
- getResourceID() - Method in class org.apache.flink.runtime.clusterframework.types.ResourceID
-
A ResourceID can always retrieve a ResourceID.
- getResourceID() - Method in interface org.apache.flink.runtime.clusterframework.types.ResourceIDRetrievable
-
Gets the ResourceID of the object.
- getResourceID() - Method in class org.apache.flink.runtime.clusterframework.types.SlotID
-
- getResourceID() - Method in class org.apache.flink.runtime.jobmaster.JMTMRegistrationSuccess
-
- getResourceID() - Method in class org.apache.flink.runtime.resourcemanager.registration.TaskExecutorConnection
-
- getResourceId() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerInfo
-
- getResourceID() - Method in class org.apache.flink.runtime.taskexecutor.JobManagerConnection
-
- getResourceID() - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutor
-
- getResourceID() - Method in class org.apache.flink.runtime.taskmanager.TaskManagerLocation
-
Gets the ID of the resource in which the TaskManager is started.
- getResourceID() - Method in class org.apache.flink.yarn.RegisteredYarnWorkerNode
-
- getResourceID() - Method in class org.apache.flink.yarn.YarnContainerInLaunch
-
- getResourceID() - Method in class org.apache.flink.yarn.YarnWorkerNode
-
- getResourceIdString() - Method in class org.apache.flink.runtime.clusterframework.types.ResourceID
-
Gets the Resource Id as string
- getResourceManageGateway() - Method in class org.apache.flink.runtime.resourcemanager.ResourceManagerRunner
-
- getResourceManagerBindAddress() - Method in class org.apache.flink.runtime.minicluster.MiniClusterConfiguration
-
- getResourceManagerClass() - Method in class org.apache.flink.mesos.runtime.clusterframework.MesosApplicationMasterRunner
-
- getResourceManagerClass() - Method in class org.apache.flink.yarn.YarnApplicationMasterRunner
-
- getResourceManagerId() - Method in class org.apache.flink.runtime.jobmaster.JobMasterRegistrationSuccess
-
- getResourceManagerId() - Method in class org.apache.flink.runtime.jobmaster.ResourceManagerAddress
-
- getResourceManagerId() - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorRegistrationSuccess
-
Gets the unique ID that identifies the ResourceManager.
- getResourceManagerLeaderElectionService() - Method in interface org.apache.flink.runtime.highavailability.HighAvailabilityServices
-
Gets the leader election service for the cluster's resource manager.
- getResourceManagerLeaderElectionService() - Method in class org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedHaServices
-
- getResourceManagerLeaderElectionService() - Method in class org.apache.flink.runtime.highavailability.nonha.standalone.StandaloneHaServices
-
- getResourceManagerLeaderElectionService() - Method in class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperHaServices
-
- getResourceManagerLeaderElectionService() - Method in class org.apache.flink.yarn.highavailability.YarnIntraNonHaMasterServices
-
- getResourceManagerLeaderElectionService() - Method in class org.apache.flink.yarn.highavailability.YarnPreConfiguredMasterNonHaServices
-
- getResourceManagerLeaderRetriever() - Method in interface org.apache.flink.runtime.highavailability.HighAvailabilityServices
-
Gets the leader retriever for the cluster's resource manager.
- getResourceManagerLeaderRetriever() - Method in class org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedHaServices
-
- getResourceManagerLeaderRetriever() - Method in class org.apache.flink.runtime.highavailability.nonha.standalone.StandaloneHaServices
-
- getResourceManagerLeaderRetriever() - Method in class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperHaServices
-
- getResourceManagerLeaderRetriever() - Method in class org.apache.flink.yarn.highavailability.YarnIntraNonHaMasterServices
-
- getResourceManagerLeaderRetriever() - Method in class org.apache.flink.yarn.highavailability.YarnPreConfiguredMasterNonHaServices
-
- getResourceManagerProps(Class<? extends FlinkResourceManager>, Configuration, LeaderRetrievalService) - Static method in class org.apache.flink.runtime.clusterframework.FlinkResourceManager
-
- getResourceManagerResourceId() - Method in class org.apache.flink.runtime.jobmaster.JobMasterRegistrationSuccess
-
- getResourceProfile() - Method in class org.apache.flink.runtime.clusterframework.types.SlotProfile
-
Returns the desired resource profile for the slot.
- getResourceProfile() - Method in class org.apache.flink.runtime.clusterframework.types.TaskManagerSlot
-
- getResourceProfile() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.PendingSlotRequest
-
- getResourceProfile() - Method in class org.apache.flink.runtime.resourcemanager.SlotRequest
-
Get the resource profile of the desired slot
- getResourceProfile() - Method in class org.apache.flink.runtime.taskexecutor.slot.SlotOffer
-
- getResourceProfile() - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlot
-
- getResourceProfile() - Method in class org.apache.flink.runtime.taskexecutor.SlotStatus
-
Get the resource profile of this slot
- getResources() - Method in class org.apache.flink.mesos.scheduler.Offer
-
- getResources() - Method in class org.apache.flink.runtime.instance.Instance
-
- getResponse(HttpResponseStatus, String) - Static method in class org.apache.flink.runtime.rest.handler.util.HandlerRedirectUtils
-
- getResponseClass() - Method in class org.apache.flink.runtime.rest.handler.async.AsynchronousOperationStatusMessageHeaders
-
- getResponseClass() - Method in class org.apache.flink.runtime.rest.handler.async.AsynchronousOperationTriggerMessageHeaders
-
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigHeaders
-
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatisticsHeaders
-
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatisticDetailsHeaders
-
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsHeaders
-
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.cluster.ShutdownHeaders
-
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.ClusterConfigurationInfoHeaders
-
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.ClusterOverviewHeaders
-
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.DashboardConfigurationHeaders
-
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsHeaders
-
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.job.JobExecutionResultHeaders
-
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.job.JobSubmitHeaders
-
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AbstractAggregatedMetricsHeaders
-
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AbstractMetricsHeaders
-
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskCurrentAttemptDetailsHeaders
-
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptAccumulatorsHeaders
-
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsHeaders
-
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.JobAccumulatorsHeaders
-
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.JobConfigHeaders
-
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.JobExceptionsHeaders
-
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.JobIdsWithStatusesOverviewHeaders
-
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.JobPlanHeaders
-
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.JobsOverviewHeaders
-
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.JobTerminationHeaders
-
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.JobVertexAccumulatorsHeaders
-
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.JobVertexBackPressureHeaders
-
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.JobVertexDetailsHeaders
-
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.JobVertexTaskManagersHeaders
-
- getResponseClass() - Method in interface org.apache.flink.runtime.rest.messages.MessageHeaders
-
Returns the class of the response message.
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.SubtasksAllAccumulatorsHeaders
-
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.SubtasksTimesHeaders
-
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerDetailsHeaders
-
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagersHeaders
-
- getResponseClass() - Method in class org.apache.flink.runtime.webmonitor.handlers.JarDeleteHeaders
-
- getResponseClass() - Method in class org.apache.flink.runtime.webmonitor.handlers.JarListHeaders
-
- getResponseClass() - Method in class org.apache.flink.runtime.webmonitor.handlers.JarPlanHeaders
-
- getResponseClass() - Method in class org.apache.flink.runtime.webmonitor.handlers.JarRunHeaders
-
- getResponseClass() - Method in class org.apache.flink.runtime.webmonitor.handlers.JarUploadHeaders
-
- getResponseHeaders() - Method in class org.apache.flink.runtime.rest.RestServerEndpointConfiguration
-
Response headers that should be added to every HTTP response.
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingStatusHeaders
-
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingTriggerHeaders
-
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigHeaders
-
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatisticsHeaders
-
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatisticDetailsHeaders
-
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsHeaders
-
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.cluster.ShutdownHeaders
-
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.ClusterConfigurationInfoHeaders
-
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.ClusterOverviewHeaders
-
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.DashboardConfigurationHeaders
-
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsHeaders
-
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.job.JobExecutionResultHeaders
-
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.job.JobSubmitHeaders
-
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AbstractAggregatedMetricsHeaders
-
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AbstractMetricsHeaders
-
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalStatusHeaders
-
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalTriggerHeaders
-
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointStatusHeaders
-
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointTriggerHeaders
-
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskCurrentAttemptDetailsHeaders
-
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptAccumulatorsHeaders
-
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsHeaders
-
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.JobAccumulatorsHeaders
-
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.JobConfigHeaders
-
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.JobExceptionsHeaders
-
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.JobIdsWithStatusesOverviewHeaders
-
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.JobPlanHeaders
-
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.JobsOverviewHeaders
-
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.JobTerminationHeaders
-
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.JobVertexAccumulatorsHeaders
-
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.JobVertexBackPressureHeaders
-
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.JobVertexDetailsHeaders
-
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.JobVertexTaskManagersHeaders
-
- getResponseStatusCode() - Method in interface org.apache.flink.runtime.rest.messages.MessageHeaders
-
Returns the http status code for the response.
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.SubtasksAllAccumulatorsHeaders
-
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.SubtasksTimesHeaders
-
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerDetailsHeaders
-
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagersHeaders
-
- getResponseStatusCode() - Method in class org.apache.flink.runtime.webmonitor.handlers.JarDeleteHeaders
-
- getResponseStatusCode() - Method in class org.apache.flink.runtime.webmonitor.handlers.JarListHeaders
-
- getResponseStatusCode() - Method in class org.apache.flink.runtime.webmonitor.handlers.JarPlanHeaders
-
- getResponseStatusCode() - Method in class org.apache.flink.runtime.webmonitor.handlers.JarRunHeaders
-
- getResponseStatusCode() - Method in class org.apache.flink.runtime.webmonitor.handlers.JarUploadHeaders
-
- getResponseTimeout() - Method in class org.apache.flink.table.client.config.Deployment
-
- getResponseTypeParameters() - Method in class org.apache.flink.runtime.rest.handler.async.AsynchronousOperationStatusMessageHeaders
-
- getResponseTypeParameters() - Method in interface org.apache.flink.runtime.rest.messages.MessageHeaders
-
Returns the collection of type parameters for the response type.
- getRestAddress() - Method in class org.apache.flink.runtime.minicluster.MiniCluster
-
- getRestAddress() - Method in class org.apache.flink.runtime.rest.RestServerEndpointConfiguration
-
- getRestAddress() - Method in class org.apache.flink.runtime.webmonitor.utils.WebFrontendBootstrap
-
- getRestAddress() - Method in interface org.apache.flink.runtime.webmonitor.WebMonitor
-
Returns the REST address of this WebMonitor.
- getRestAddress() - Method in class org.apache.flink.runtime.webmonitor.WebRuntimeMonitor
-
- getRestartAttempts() - Method in class org.apache.flink.api.common.restartstrategy.RestartStrategies.FixedDelayRestartStrategyConfiguration
-
- getRestartStrategy() - Method in class org.apache.flink.api.common.ExecutionConfig
-
Returns the restart strategy which has been set for the current job.
- getRestartStrategy() - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
Returns the specified restart strategy configuration.
- getRestartStrategy() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- getRestartStrategy() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Returns the specified restart strategy configuration.
- getRestartStrategyDescription() - Method in class org.apache.flink.api.common.ArchivedExecutionConfig
-
- getRestartStrategyFactory() - Method in class org.apache.flink.runtime.jobmaster.JobManagerSharedServices
-
- getRestBaseUrl() - Method in class org.apache.flink.runtime.rest.RestServerEndpoint
-
Returns the base URL of the REST server endpoint.
- getRestBindAddress() - Method in class org.apache.flink.runtime.rest.RestServerEndpointConfiguration
-
Returns the address that the REST server endpoint should bind itself to.
- getRestBindPort() - Method in class org.apache.flink.runtime.rest.RestServerEndpointConfiguration
-
Returns the port that the REST server endpoint should listen on.
- getRestClientConfiguration() - Method in class org.apache.flink.client.program.rest.RestClusterClientConfiguration
-
- getRestoreCheckpointId() - Method in class org.apache.flink.runtime.checkpoint.JobManagerTaskRestore
-
- getRestoredCheckpointStatistics() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.LatestCheckpoints
-
- getRestorePath() - Method in class org.apache.flink.runtime.jobgraph.SavepointRestoreSettings
-
Returns the path to the savepoint to restore from.
- getRestoreTimestamp() - Method in class org.apache.flink.runtime.checkpoint.RestoredCheckpointStats
-
Returns the timestamp when the checkpoint was restored.
- getRestoreTimestamp() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.RestoredCheckpointStatistics
-
- getRestPort() - Method in class org.apache.flink.runtime.entrypoint.ClusterConfiguration
-
- getResult(ACC) - Method in interface org.apache.flink.api.common.functions.AggregateFunction
-
Gets the result of the aggregation from the accumulator.
- getResult(ACC) - Method in class org.apache.flink.api.common.functions.RichAggregateFunction
-
- getResult() - Method in class org.apache.flink.graph.asm.dataset.ChecksumHashCode
-
- getResult() - Method in class org.apache.flink.graph.asm.dataset.Collect
-
- getResult() - Method in class org.apache.flink.graph.asm.dataset.Count
-
- getResult() - Method in interface org.apache.flink.graph.asm.dataset.DataSetAnalytic
-
This method must be called after the program has executed.
- getResult() - Method in interface org.apache.flink.graph.GraphAnalytic
-
This method must be called after the program has executed.
- getResult() - Method in class org.apache.flink.graph.library.clustering.directed.AverageClusteringCoefficient
-
- getResult() - Method in class org.apache.flink.graph.library.clustering.directed.GlobalClusteringCoefficient
-
- getResult() - Method in class org.apache.flink.graph.library.clustering.directed.TriadicCensus
-
- getResult() - Method in class org.apache.flink.graph.library.clustering.undirected.AverageClusteringCoefficient
-
- getResult() - Method in class org.apache.flink.graph.library.clustering.undirected.GlobalClusteringCoefficient
-
- getResult() - Method in class org.apache.flink.graph.library.clustering.undirected.TriadicCensus
-
- getResult() - Method in class org.apache.flink.graph.library.metric.ChecksumHashCode
-
- getResult() - Method in class org.apache.flink.graph.library.metric.directed.EdgeMetrics
-
- getResult() - Method in class org.apache.flink.graph.library.metric.directed.VertexMetrics
-
- getResult() - Method in class org.apache.flink.graph.library.metric.undirected.EdgeMetrics
-
- getResult() - Method in class org.apache.flink.graph.library.metric.undirected.VertexMetrics
-
- getResult() - Method in class org.apache.flink.graph.Runner
-
Get the result DataSet.
- getResult() - Method in class org.apache.flink.table.client.cli.CliView
-
- getResult(String) - Method in class org.apache.flink.table.client.gateway.local.ResultStore
-
- getResultFuture() - Method in class org.apache.flink.runtime.jobmaster.JobManagerRunner
-
- getResultId() - Method in class org.apache.flink.runtime.deployment.PartialInputChannelDeploymentDescriptor
-
- getResultId() - Method in class org.apache.flink.runtime.deployment.ResultPartitionDeploymentDescriptor
-
- getResultId() - Method in class org.apache.flink.table.client.gateway.ResultDescriptor
-
- getResultInputStream(String) - Static method in class org.apache.flink.test.util.TestBaseUtils
-
- getResultInputStream(String, String[]) - Static method in class org.apache.flink.test.util.TestBaseUtils
-
- getResultOptimizerProperties() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
- getResultPartitionConsumableNotifier() - Method in class org.apache.flink.runtime.taskexecutor.JobManagerConnection
-
- getResultPartitionManager() - Method in class org.apache.flink.runtime.io.network.NetworkEnvironment
-
- getResultReader(String) - Static method in class org.apache.flink.test.util.TestBaseUtils
-
- getResultReader(String, String[], boolean) - Static method in class org.apache.flink.test.util.TestBaseUtils
-
- getResults() - Method in class org.apache.flink.table.client.gateway.local.ResultStore
-
- getResultSchema() - Method in class org.apache.flink.table.client.gateway.ResultDescriptor
-
- getResultsFormatted(Map<String, Object>) - Static method in class org.apache.flink.api.common.accumulators.AccumulatorHelper
-
- getResultType() - Method in class org.apache.flink.api.java.operators.Operator
-
Returns the type of the result of this operator.
- getResultType() - Method in class org.apache.flink.runtime.executiongraph.IntermediateResult
-
- getResultType() - Method in class org.apache.flink.runtime.jobgraph.IntermediateDataSet
-
- getRetryDelay() - Method in class org.apache.flink.client.program.rest.RestClusterClientConfiguration
-
- getRetryMaxAttempts() - Method in class org.apache.flink.client.program.rest.RestClusterClientConfiguration
-
- getReturnQueue() - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBlockReader
-
Gets the queue in which the full memory segments are queued after the asynchronous read
is complete.
- getReturnQueue() - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBlockWriter
-
Gets the queue in which the memory segments are queued after the asynchronous write is completed.
- getReturnQueue() - Method in interface org.apache.flink.runtime.io.disk.iomanager.BlockChannelReader
-
Gets the queue in which the full memory segments are queued after the read is complete.
- getReturnQueue() - Method in interface org.apache.flink.runtime.io.disk.iomanager.BlockChannelWriter
-
Gets the queue in which the memory segments are queued after the asynchronous write
is completed
- getReturnType() - Method in class org.apache.flink.addons.hbase.HBaseTableSource
-
- getReturnType() - Method in class org.apache.flink.api.java.typeutils.TypeExtractionUtils.LambdaExecutable
-
- getReturnType() - Method in class org.apache.flink.orc.OrcTableSource
-
- getReturnType() - Method in class org.apache.flink.sql.tests.StreamSQLTestProgram.GeneratorTableSource
-
- getReturnType() - Method in class org.apache.flink.streaming.connectors.kafka.KafkaTableSource
-
- getReusingOuterJoinIterator(DriverStrategy, MutableObjectIterator<IT1>, MutableObjectIterator<IT2>, TypeSerializer<IT1>, TypeComparator<IT1>, TypeSerializer<IT2>, TypeComparator<IT2>, TypePairComparatorFactory<IT1, IT2>, MemoryManager, IOManager, double) - Method in class org.apache.flink.runtime.operators.AbstractOuterJoinDriver
-
- getReusingOuterJoinIterator(DriverStrategy, MutableObjectIterator<IT1>, MutableObjectIterator<IT2>, TypeSerializer<IT1>, TypeComparator<IT1>, TypeSerializer<IT2>, TypeComparator<IT2>, TypePairComparatorFactory<IT1, IT2>, MemoryManager, IOManager, double) - Method in class org.apache.flink.runtime.operators.FullOuterJoinDriver
-
- getReusingOuterJoinIterator(DriverStrategy, MutableObjectIterator<IT1>, MutableObjectIterator<IT2>, TypeSerializer<IT1>, TypeComparator<IT1>, TypeSerializer<IT2>, TypeComparator<IT2>, TypePairComparatorFactory<IT1, IT2>, MemoryManager, IOManager, double) - Method in class org.apache.flink.runtime.operators.LeftOuterJoinDriver
-
- getReusingOuterJoinIterator(DriverStrategy, MutableObjectIterator<IT1>, MutableObjectIterator<IT2>, TypeSerializer<IT1>, TypeComparator<IT1>, TypeSerializer<IT2>, TypeComparator<IT2>, TypePairComparatorFactory<IT1, IT2>, MemoryManager, IOManager, double) - Method in class org.apache.flink.runtime.operators.RightOuterJoinDriver
-
- getRevisionInformation() - Static method in class org.apache.flink.runtime.util.EnvironmentInformation
-
Returns the code revision (commit and commit date) of Flink, as generated by the Maven builds.
- getRight() - Method in class org.apache.flink.cep.pattern.conditions.AndCondition
-
- getRight() - Method in class org.apache.flink.cep.pattern.conditions.OrCondition
-
- getRightType() - Method in class org.apache.flink.api.java.typeutils.EitherTypeInfo
-
- getRocksIterator(RocksDB) - Static method in class org.apache.flink.contrib.streaming.state.RocksDBKeyedStateBackend
-
- getRocksIterator(RocksDB, ColumnFamilyHandle) - Static method in class org.apache.flink.contrib.streaming.state.RocksDBKeyedStateBackend
-
- getRocksIterator(RocksDB, ColumnFamilyHandle, ReadOptions) - Static method in class org.apache.flink.contrib.streaming.state.RocksDBKeyedStateBackend
-
- getRoot() - Method in class org.apache.flink.runtime.instance.Slot
-
Gets the root slot of the tree containing this slot.
- getRootOfStepFunction() - Method in class org.apache.flink.optimizer.plan.BulkIterationPlanNode
-
- getRootOfTerminationCriterion() - Method in class org.apache.flink.optimizer.plan.BulkIterationPlanNode
-
- getRootSlotNumber() - Method in class org.apache.flink.runtime.instance.Slot
-
Gets the number of the root slot.
- getRow(String[]) - Method in class org.apache.flink.table.client.cli.CliChangelogResultView
-
- getRow(String[]) - Method in class org.apache.flink.table.client.cli.CliResultView
-
- getRow(String[]) - Method in class org.apache.flink.table.client.cli.CliTableResultView
-
- getRowtimeAttributeDescriptors() - Method in class org.apache.flink.sql.tests.StreamSQLTestProgram.GeneratorTableSource
-
- getRowtimeAttributeDescriptors() - Method in class org.apache.flink.streaming.connectors.kafka.KafkaTableSource
-
- getRpcGateway() - Method in class org.apache.flink.runtime.rpc.messages.RemoteHandshakeMessage
-
- getRPCPortRange(Configuration) - Method in class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
-
- getRPCPortRange(Configuration) - Method in class org.apache.flink.yarn.entrypoint.YarnJobClusterEntrypoint
-
- getRPCPortRange(Configuration) - Method in class org.apache.flink.yarn.entrypoint.YarnSessionClusterEntrypoint
-
- getRpcService() - Method in class org.apache.flink.runtime.rpc.RpcEndpoint
-
Gets the endpoint's RPC service.
- getRpcServiceSharing() - Method in class org.apache.flink.runtime.minicluster.MiniClusterConfiguration
-
- getRpcTimeout() - Method in class org.apache.flink.runtime.jobmaster.JobMasterConfiguration
-
- getRpcTimeout() - Method in class org.apache.flink.runtime.minicluster.MiniClusterConfiguration
-
- getRpcUrl(String, int, String, HighAvailabilityServicesUtils.AddressResolution, Configuration) - Static method in class org.apache.flink.runtime.rpc.akka.AkkaRpcServiceUtils
-
- getRpcUrl(String, int, String, HighAvailabilityServicesUtils.AddressResolution, AkkaRpcServiceUtils.AkkaProtocol) - Static method in class org.apache.flink.runtime.rpc.akka.AkkaRpcServiceUtils
-
- getRunCommandOptions() - Static method in class org.apache.flink.client.cli.CliFrontendParser
-
- getRunnable() - Method in class org.apache.flink.runtime.rpc.messages.RunAsync
-
- getRunning() - Method in class org.apache.flink.client.cli.ListOptions
-
- getRunningJobsRegistry() - Method in interface org.apache.flink.runtime.highavailability.HighAvailabilityServices
-
Gets the registry that holds information about whether jobs are currently running.
- getRunningJobsRegistry() - Method in class org.apache.flink.runtime.highavailability.nonha.AbstractNonHaServices
-
- getRunningJobsRegistry() - Method in class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperHaServices
-
- getRunningJobsRegistry() - Method in class org.apache.flink.yarn.highavailability.AbstractYarnNonHaServices
-
- getRuntimeContext() - Method in class org.apache.flink.api.common.functions.AbstractRichFunction
-
- getRuntimeContext() - Method in interface org.apache.flink.api.common.functions.RichFunction
-
Gets the context that contains information about the UDF's runtime, such as the
parallelism of the function, the subtask index of the function, or the name of
the of the task that executes the function.
- getRuntimeContext() - Method in class org.apache.flink.api.common.io.ReplicatingInputFormat
-
- getRuntimeContext() - Method in class org.apache.flink.api.common.io.RichInputFormat
-
- getRuntimeContext() - Method in class org.apache.flink.api.common.io.RichOutputFormat
-
- getRuntimeContext() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
Returns a context that allows the operator to query information about the execution and also
to interact with systems such as broadcast variables and managed state.
- getRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalAggregateProcessAllWindowFunction
-
- getRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalAggregateProcessWindowFunction
-
- getRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableAllWindowFunction
-
- getRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableProcessAllWindowFunction
-
- getRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableProcessWindowFunction
-
- getRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableWindowFunction
-
- getRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueAllWindowFunction
-
- getRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueProcessAllWindowFunction
-
- getRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueProcessWindowFunction
-
- getRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueWindowFunction
-
- getSafetyNetCloseableRegistryForThread() - Static method in class org.apache.flink.core.fs.FileSystemSafetyNet
-
- getSampleId() - Method in class org.apache.flink.runtime.messages.StackTraceSampleResponse
-
- getSampleId() - Method in class org.apache.flink.runtime.rest.handler.legacy.backpressure.OperatorBackPressureStats
-
Returns the ID of the sample.
- getSampleId() - Method in class org.apache.flink.runtime.rest.handler.legacy.backpressure.StackTraceSample
-
Returns the ID of the sample.
- getSamples() - Method in class org.apache.flink.runtime.messages.StackTraceSampleResponse
-
- getSavepointPath() - Method in class org.apache.flink.client.cli.SavepointOptions
-
- getSavepointPath() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalRequest
-
- getSavepointPath() - Method in class org.apache.flink.runtime.state.filesystem.AbstractFileStateBackend
-
Gets the directory where savepoints are stored by default (when no custom path is given
to the savepoint trigger command).
- getSavepointPath() - Method in class org.apache.flink.runtime.webmonitor.handlers.JarRunRequestBody
-
- getSavepointRestoreSettings() - Method in class org.apache.flink.client.cli.ProgramOptions
-
- getSavepointRestoreSettings() - Method in class org.apache.flink.client.program.ContextEnvironment
-
- getSavepointRestoreSettings() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
Returns the configured savepoint restore setting.
- getSavepointSettings() - Method in class org.apache.flink.client.program.PackagedProgram
-
- getSavepointStatistics() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.LatestCheckpoints
-
- getSavepointTargetDirectory() - Method in class org.apache.flink.client.cli.CancelOptions
-
- getScalarValue(String) - Method in class org.apache.flink.mesos.scheduler.Offer
-
- getScalarValues() - Method in class org.apache.flink.mesos.scheduler.Offer
-
- getScanner() - Method in class org.apache.flink.addons.hbase.AbstractTableInputFormat
-
Returns an instance of Scan that retrieves the required subset of records from the HBase table.
- getScanner() - Method in class org.apache.flink.addons.hbase.HBaseRowInputFormat
-
- getScanner() - Method in class org.apache.flink.addons.hbase.TableInputFormat
-
Returns an instance of Scan that retrieves the required subset of records from the HBase table.
- getScatterBcastVars() - Method in class org.apache.flink.graph.spargel.ScatterGatherConfiguration
-
Get the broadcast variables of the ScatterFunction.
- getScheduled() - Method in class org.apache.flink.client.cli.ListOptions
-
- getScheduledExecutor() - Method in class org.apache.flink.runtime.rpc.akka.AkkaRpcService
-
- getScheduledExecutor() - Method in interface org.apache.flink.runtime.rpc.RpcService
-
Gets a scheduled executor from the RPC service.
- getScheduledExecutorService() - Method in class org.apache.flink.runtime.jobmaster.JobManagerSharedServices
-
- getScheduleMode() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- getScheduleMode() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
- getSchema(Schema, Schema) - Static method in class org.apache.flink.streaming.connectors.fs.AvroKeyValueSinkWriter.AvroKeyValue
-
Creates a KeyValuePair generic record schema.
- getSchemaString() - Method in class org.apache.flink.formats.avro.typeutils.AvroSerializer.AvroSchemaSerializerConfigSnapshot
-
- getScheme() - Method in class org.apache.flink.core.fs.ConnectionLimitingFactory
-
- getScheme() - Method in interface org.apache.flink.core.fs.FileSystemFactory
-
Gets the scheme of the file system created by this factory.
- getScheme() - Method in class org.apache.flink.core.fs.local.LocalFileSystemFactory
-
- getScheme() - Method in class org.apache.flink.fs.openstackhadoop.SwiftFileSystemFactory
-
- getScheme() - Method in class org.apache.flink.fs.s3hadoop.S3FileSystemFactory
-
- getScheme() - Method in class org.apache.flink.fs.s3presto.S3FileSystemFactory
-
- getScheme() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFsFactory
-
- getScheme() - Method in class org.apache.flink.runtime.fs.maprfs.MapRFsFactory
-
- getScopeComponents() - Method in class org.apache.flink.metrics.groups.UnregisteredMetricsGroup
-
- getScopeComponents() - Method in interface org.apache.flink.metrics.MetricGroup
-
Gets the scope as an array of the scope components, for example
["host-7", "taskmanager-2", "window_word_count", "my-mapper"]
.
- getScopeComponents() - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
-
Gets the scope as an array of the scope components, for example
["host-7", "taskmanager-2", "window_word_count", "my-mapper"]
.
- getScopeComponents() - Method in class org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
-
- getScopeFormats() - Method in interface org.apache.flink.runtime.metrics.MetricRegistry
-
Returns the scope formats.
- getScopeFormats() - Method in class org.apache.flink.runtime.metrics.MetricRegistryConfiguration
-
- getScopeFormats() - Method in class org.apache.flink.runtime.metrics.MetricRegistryImpl
-
- getScopeFormats() - Method in class org.apache.flink.runtime.metrics.NoOpMetricRegistry
-
- getScriptName(ExecutionConfig.GlobalJobParameters) - Static method in class org.apache.flink.streaming.python.api.environment.PythonStreamExecutionEnvironment.PythonJobParameters
-
- getSecondaryStreamException() - Method in class org.apache.flink.runtime.state.DuplicatingCheckpointOutputStream
-
- getSecondDegree() - Method in class org.apache.flink.examples.java.graph.util.EnumTrianglesDataTypes.EdgeWithDegrees
-
- getSecondDegree() - Method in class org.apache.flink.graph.library.TriangleEnumerator.EdgeWithDegrees
-
- getSecondIncomingConnection() - Method in class org.apache.flink.optimizer.dag.TwoInputNode
-
Gets the DagConnection through which this node receives its second input.
- getSecondInput() - Method in class org.apache.flink.api.common.operators.DualInputOperator
-
Returns the second input, or null, if none is set.
- getSecondInput() - Method in class org.apache.flink.streaming.api.datastream.BroadcastConnectedStream
-
- getSecondInput() - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
-
- getSecondInputType() - Method in class org.apache.flink.api.common.operators.BinaryOperatorInformation
-
- getSecondPredecessorNode() - Method in class org.apache.flink.optimizer.dag.TwoInputNode
-
- getSecondVertex() - Method in class org.apache.flink.examples.java.graph.util.EnumTrianglesDataTypes.Edge
-
- getSecondVertex() - Method in class org.apache.flink.examples.java.graph.util.EnumTrianglesDataTypes.EdgeWithDegrees
-
- getSecondVertex() - Method in class org.apache.flink.graph.library.TriangleEnumerator.EdgeWithDegrees
-
- getSecondVertex() - Method in class org.apache.flink.graph.library.TriangleEnumerator.Triad
-
- getSecurityConfig() - Method in class org.apache.flink.runtime.security.modules.HadoopModule
-
- getSecurityModuleFactories() - Method in class org.apache.flink.runtime.security.SecurityConfiguration
-
- getSeekedStreamForOffset(long) - Method in class org.apache.flink.core.fs.AbstractMultiFSDataInputStream
-
Delivers a the right stream for the given global stream offset.
- getSegmentsForReaders(List<List<MemorySegment>>, List<MemorySegment>, int) - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SpillingThread
-
Divides the given collection of memory buffers among numChannels
sublists.
- getSegmentSize() - Method in class org.apache.flink.runtime.memory.AbstractPagedOutputView
-
Gets the size of the segments used by this view.
- getSelectedNames() - Method in class org.apache.flink.streaming.api.graph.StreamEdge
-
- getSelectedNames() - Method in class org.apache.flink.streaming.api.transformations.SelectTransformation
-
Returns the names of the split streams that this SelectTransformation
selects.
- getSelectorForArray(int[], TypeInformation<X>) - Static method in class org.apache.flink.streaming.util.keys.KeySelectorUtil
-
- getSelectorForKeys(Keys<X>, TypeInformation<X>, ExecutionConfig) - Static method in class org.apache.flink.streaming.util.keys.KeySelectorUtil
-
- getSelectorForOneKey(Keys<X>, Partitioner<K>, TypeInformation<X>, ExecutionConfig) - Static method in class org.apache.flink.streaming.util.keys.KeySelectorUtil
-
- getSelfGateway(Class<C>) - Method in class org.apache.flink.runtime.rpc.RpcEndpoint
-
Returns a self gateway of the specified type which can be used to issue asynchronous
calls against the RpcEndpoint.
- getSemanticProperties() - Method in class org.apache.flink.api.common.operators.base.PartitionOperatorBase
-
- getSemanticProperties() - Method in class org.apache.flink.api.common.operators.base.SortPartitionOperatorBase
-
- getSemanticProperties() - Method in class org.apache.flink.api.common.operators.DualInputOperator
-
- getSemanticProperties() - Method in class org.apache.flink.api.common.operators.SingleInputOperator
-
- getSemanticProperties() - Method in class org.apache.flink.api.java.operators.CoGroupOperator
-
- getSemanticProperties() - Method in class org.apache.flink.api.java.operators.GroupCombineOperator
-
- getSemanticProperties() - Method in class org.apache.flink.api.java.operators.GroupReduceOperator
-
- getSemanticProperties() - Method in class org.apache.flink.api.java.operators.JoinOperator.EquiJoin
-
- getSemanticProperties() - Method in class org.apache.flink.api.java.operators.ReduceOperator
-
- getSemanticProperties() - Method in class org.apache.flink.api.java.operators.SingleInputUdfOperator
-
- getSemanticProperties() - Method in class org.apache.flink.api.java.operators.TwoInputUdfOperator
-
- getSemanticProperties() - Method in interface org.apache.flink.api.java.operators.UdfOperator
-
Gets the semantic properties that have been set for the user-defined functions (UDF).
- getSemanticProperties() - Method in class org.apache.flink.api.java.sca.UdfAnalyzer
-
- getSemanticProperties() - Method in class org.apache.flink.optimizer.dag.AbstractPartialSolutionNode
-
- getSemanticProperties() - Method in class org.apache.flink.optimizer.dag.BinaryUnionNode
-
- getSemanticProperties() - Method in class org.apache.flink.optimizer.dag.BulkIterationNode
-
- getSemanticProperties() - Method in class org.apache.flink.optimizer.dag.DataSinkNode
-
- getSemanticProperties() - Method in class org.apache.flink.optimizer.dag.DataSourceNode
-
- getSemanticProperties() - Method in class org.apache.flink.optimizer.dag.FilterNode
-
- getSemanticProperties() - Method in class org.apache.flink.optimizer.dag.OptimizerNode
-
- getSemanticProperties() - Method in class org.apache.flink.optimizer.dag.PartitionNode
-
- getSemanticProperties() - Method in class org.apache.flink.optimizer.dag.SingleInputNode
-
- getSemanticProperties() - Method in class org.apache.flink.optimizer.dag.SortPartitionNode
-
- getSemanticProperties() - Method in class org.apache.flink.optimizer.dag.TwoInputNode
-
- getSemanticProperties() - Method in class org.apache.flink.optimizer.dag.UnaryOperatorNode
-
- getSemanticProperties() - Method in class org.apache.flink.optimizer.dag.WorksetIterationNode
-
- getSemanticPropertiesForGlobalPropertyFiltering() - Method in class org.apache.flink.optimizer.dag.SingleInputNode
-
- getSemanticPropertiesForGlobalPropertyFiltering() - Method in class org.apache.flink.optimizer.dag.TwoInputNode
-
- getSemanticPropertiesForLocalPropertyFiltering() - Method in class org.apache.flink.optimizer.dag.CoGroupNode
-
- getSemanticPropertiesForLocalPropertyFiltering() - Method in class org.apache.flink.optimizer.dag.GroupCombineNode
-
- getSemanticPropertiesForLocalPropertyFiltering() - Method in class org.apache.flink.optimizer.dag.GroupReduceNode
-
- getSemanticPropertiesForLocalPropertyFiltering() - Method in class org.apache.flink.optimizer.dag.MapPartitionNode
-
- getSemanticPropertiesForLocalPropertyFiltering() - Method in class org.apache.flink.optimizer.dag.SingleInputNode
-
- getSemanticPropertiesForLocalPropertyFiltering() - Method in class org.apache.flink.optimizer.dag.TwoInputNode
-
- getSemanticPropsDual(Set<Annotation>, TypeInformation<?>, TypeInformation<?>, TypeInformation<?>) - Static method in class org.apache.flink.api.java.functions.SemanticPropUtil
-
- getSemanticPropsDualFromString(DualInputSemanticProperties, String[], String[], String[], String[], String[], String[], TypeInformation<?>, TypeInformation<?>, TypeInformation<?>) - Static method in class org.apache.flink.api.java.functions.SemanticPropUtil
-
- getSemanticPropsDualFromString(DualInputSemanticProperties, String[], String[], String[], String[], String[], String[], TypeInformation<?>, TypeInformation<?>, TypeInformation<?>, boolean) - Static method in class org.apache.flink.api.java.functions.SemanticPropUtil
-
- getSemanticPropsSingle(Set<Annotation>, TypeInformation<?>, TypeInformation<?>) - Static method in class org.apache.flink.api.java.functions.SemanticPropUtil
-
- getSemanticPropsSingleFromString(SingleInputSemanticProperties, String[], String[], String[], TypeInformation<?>, TypeInformation<?>) - Static method in class org.apache.flink.api.java.functions.SemanticPropUtil
-
- getSemanticPropsSingleFromString(SingleInputSemanticProperties, String[], String[], String[], TypeInformation<?>, TypeInformation<?>, boolean) - Static method in class org.apache.flink.api.java.functions.SemanticPropUtil
-
- getSendAndReceiveBufferSize() - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
-
- getSenderBacklog() - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
-
- getSentence() - Method in class org.apache.flink.storm.wordcount.operators.WordCountDataPojos.Sentence
-
- getSequenceNumber() - Method in interface org.apache.flink.runtime.io.network.NetworkSequenceViewReader
-
- getSequenceNumber() - Method in class org.apache.flink.streaming.tests.artificialstate.ComplexPayload.InnerPayLoad
-
- getSequenceNumber() - Method in class org.apache.flink.streaming.tests.Event
-
- getSerializableListState(String) - Method in interface org.apache.flink.api.common.state.OperatorStateStore
-
- getSerializableListState(String) - Method in class org.apache.flink.runtime.state.DefaultOperatorStateBackend
-
- getSerializableSerializerInstance() - Method in class org.apache.flink.api.java.typeutils.runtime.KryoRegistration
-
- getSerializationFormatIdentifier() - Method in class org.apache.flink.api.common.typeutils.ParameterlessTypeSerializerConfig
-
- getSerializedAccumulatorResults() - Method in class org.apache.flink.runtime.client.SerializedJobExecutionResult
-
- getSerializedException() - Method in exception org.apache.flink.util.SerializedThrowable
-
- getSerializedExecutionConfig() - Method in class org.apache.flink.runtime.executiongraph.JobInformation
-
- getSerializedExecutionConfig() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
- getSerializedJobInformation() - Method in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
-
Return the sub task's serialized job information.
- getSerializedKeyAndNamespace() - Method in class org.apache.flink.queryablestate.messages.KvStateInternalRequest
-
- getSerializedKeyAndNamespace() - Method in class org.apache.flink.queryablestate.messages.KvStateRequest
-
- getSerializedStateBackend() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getSerializedTaskInformation() - Method in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
-
Return the sub task's serialized task information.
- getSerializedThrowable() - Method in class org.apache.flink.runtime.jobmaster.JobResult
-
Returns an empty Optional
if the job finished successfully, otherwise the
Optional
will carry the failure cause.
- getSerializedUserAccumulators() - Method in class org.apache.flink.runtime.rest.messages.JobAccumulatorsInfo
-
- getSerializedValue(byte[], TypeSerializer<K>, TypeSerializer<N>, TypeSerializer<V>) - Method in class org.apache.flink.contrib.streaming.state.AbstractRocksDBState
-
- getSerializedValue(byte[], TypeSerializer<K>, TypeSerializer<N>, TypeSerializer<Map<UK, UV>>) - Method in class org.apache.flink.contrib.streaming.state.RocksDBMapState
-
- getSerializedValue(byte[], TypeSerializer<K>, TypeSerializer<N>, TypeSerializer<SV>) - Method in class org.apache.flink.runtime.state.heap.AbstractHeapState
-
- getSerializedValue(byte[], TypeSerializer<K>, TypeSerializer<N>, TypeSerializer<List<V>>) - Method in class org.apache.flink.runtime.state.heap.HeapListState
-
- getSerializedValue(byte[], TypeSerializer<K>, TypeSerializer<N>, TypeSerializer<Map<UK, UV>>) - Method in class org.apache.flink.runtime.state.heap.HeapMapState
-
- getSerializedValue(byte[], TypeSerializer<K>, TypeSerializer<N>, TypeSerializer<V>) - Method in interface org.apache.flink.runtime.state.internal.InternalKvState
-
Returns the serialized value for the given key and namespace.
- getSerializer() - Method in class org.apache.flink.api.common.ExecutionConfig.SerializableSerializer
-
- getSerializer() - Method in class org.apache.flink.api.common.state.StateDescriptor
-
Returns the
TypeSerializer
that can be used to serialize the value in the state.
- getSerializer() - Method in interface org.apache.flink.api.common.typeutils.TypeSerializerFactory
-
- getSerializer(Kryo) - Method in class org.apache.flink.api.java.typeutils.runtime.KryoRegistration
-
- getSerializer() - Method in class org.apache.flink.api.java.typeutils.runtime.RuntimeSerializerFactory
-
- getSerializer() - Method in class org.apache.flink.optimizer.plan.Channel
-
Gets the serializer from this Channel.
- getSerializer() - Method in class org.apache.flink.optimizer.plan.SourcePlanNode
-
Gets the serializer from this PlanNode.
- getSerializer(IN) - Method in class org.apache.flink.python.api.streaming.data.PythonSender
-
- getSerializer(IN) - Static method in class org.apache.flink.python.api.streaming.util.SerializationUtils
-
- getSerializer() - Method in class org.apache.flink.queryablestate.server.KvStateServerImpl
-
- getSerializer(T) - Static method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointSerializers
-
- getSerializer(int) - Static method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointSerializers
-
- getSerializerBytes() - Method in exception org.apache.flink.api.common.typeutils.UnloadableTypeSerializerException
-
- getSerializerClass() - Method in class org.apache.flink.api.java.typeutils.runtime.KryoRegistration
-
- getSerializerDefinitionType() - Method in class org.apache.flink.api.java.typeutils.runtime.KryoRegistration
-
- getSerializerForIterationChannel() - Method in class org.apache.flink.optimizer.plan.BulkIterationPlanNode
-
- getSerializerForIterationChannel() - Method in class org.apache.flink.optimizer.plan.WorksetIterationPlanNode
-
- getSerializerTree(TypeInformation<T>) - Static method in class org.apache.flink.api.java.Utils
-
Debugging utility to understand the hierarchy of serializers created by the Java API.
- getSeries() - Method in class org.apache.flink.metrics.datadog.DSeries
-
- getServerAddress() - Method in class org.apache.flink.queryablestate.client.proxy.KvStateClientProxyImpl
-
- getServerAddress() - Method in class org.apache.flink.queryablestate.network.AbstractServerBase
-
Returns the address of this server.
- getServerAddress() - Method in class org.apache.flink.queryablestate.server.KvStateServerImpl
-
- getServerAddress() - Method in interface org.apache.flink.runtime.query.KvStateServer
-
Returns the
address
the server is listening to.
- getServerAddress() - Method in class org.apache.flink.runtime.rest.RestServerEndpoint
-
Returns the address on which this endpoint is accepting requests.
- getServerChannelHandlers() - Method in class org.apache.flink.runtime.io.network.netty.NettyProtocol
-
Returns the server channel handlers.
- getServerConnectBacklog() - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
-
- getServerName() - Method in class org.apache.flink.queryablestate.network.AbstractServerBase
-
Gets the name of the server.
- getServerName() - Method in class org.apache.flink.queryablestate.network.AbstractServerHandler
-
- getServerNumThreads() - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
-
- getServerPort() - Method in class org.apache.flink.mesos.util.MesosArtifactServer
-
Get the server port on which the artifact server is listening.
- getServerPort() - Method in class org.apache.flink.runtime.webmonitor.utils.WebFrontendBootstrap
-
- getServerPort() - Method in interface org.apache.flink.runtime.webmonitor.WebMonitor
-
Gets the port that the web server actually binds to.
- getServerPort() - Method in class org.apache.flink.runtime.webmonitor.WebRuntimeMonitor
-
- getSessionContext() - Method in class org.apache.flink.table.client.gateway.local.ExecutionContext
-
- getSessionId() - Method in class org.apache.flink.table.client.cli.CliOptions
-
- getSessionProperties(SessionContext) - Method in interface org.apache.flink.table.client.gateway.Executor
-
Lists all session properties that are defined by the executor and the session.
- getSessionProperties(SessionContext) - Method in class org.apache.flink.table.client.gateway.local.LocalExecutor
-
- getSessionTimeout() - Method in class org.apache.flink.api.common.Plan
-
- getSessionTimeout() - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
Gets the session timeout for this environment.
- getSessionTimeout() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
Gets the timeout after which the corresponding ExecutionGraph is removed at the
job manager after it has been executed.
- getSharedBuffer() - Method in class org.apache.flink.core.memory.DataOutputSerializer
-
Gets a reference to the internal byte buffer.
- getSharedInstance() - Static method in class org.apache.flink.core.fs.local.LocalFileSystem
-
Gets the shared instance of this file system.
- getSharedNeighborCount() - Method in class org.apache.flink.graph.library.similarity.JaccardIndex.Result
-
Get the shared neighbor count.
- getSharedSlot() - Method in class org.apache.flink.runtime.jobmanager.scheduler.CoLocationConstraint
-
Gets the shared slot into which this constraint's tasks are places.
- getSharedSlotForTask(AbstractID, Iterable<TaskManagerLocation>, boolean) - Method in class org.apache.flink.runtime.instance.SlotSharingGroupAssignment
-
- getSharedState() - Method in class org.apache.flink.runtime.state.IncrementalKeyedStateHandle
-
- getSharedStateDirectory() - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStorageLocation
-
- getSharedStateHandleIDs() - Method in class org.apache.flink.runtime.state.IncrementalLocalKeyedStateHandle
-
- getSharedStateRegistry() - Method in class org.apache.flink.runtime.state.IncrementalKeyedStateHandle
-
- getShift() - Method in class org.apache.flink.streaming.runtime.operators.windowing.KeyMap
-
- getShipComparator(Channel, ExecutionConfig) - Static method in class org.apache.flink.optimizer.util.Utils
-
- getShipdate() - Method in class org.apache.flink.examples.java.relational.TPCHQuery3.Lineitem
-
- getShippriority() - Method in class org.apache.flink.examples.java.relational.TPCHQuery3.Order
-
- getShipStrategy() - Method in class org.apache.flink.optimizer.dag.DagConnection
-
Gets the shipping strategy for this connection.
- getShipStrategy() - Method in class org.apache.flink.optimizer.plan.Channel
-
- getShipStrategy() - Method in interface org.apache.flink.optimizer.plandump.DumpableConnection
-
- getShipStrategyComparator() - Method in class org.apache.flink.optimizer.plan.Channel
-
Gets the ship strategy comparator from this Channel.
- getShipStrategyKeys() - Method in class org.apache.flink.optimizer.plan.Channel
-
- getShipStrategyName() - Method in class org.apache.flink.runtime.jobgraph.JobEdge
-
Gets the name of the ship strategy for the represented input, like "forward", "partition hash",
"rebalance", "broadcast", ...
- getShipStrategySortOrder() - Method in class org.apache.flink.optimizer.plan.Channel
-
- getShipStrategyString(ShipStrategyType) - Static method in class org.apache.flink.optimizer.plantranslate.JsonMapper
-
- getShort(String) - Method in class org.apache.flink.api.java.utils.ParameterTool
-
Returns the Short value for the given key.
- getShort(String, short) - Method in class org.apache.flink.api.java.utils.ParameterTool
-
Returns the Short value for the given key.
- getShort(int) - Method in class 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.
- getShort(int) - Method in class org.apache.flink.storm.wrappers.StormTuple
-
- getShortBigEndian(int) - Method in class org.apache.flink.core.memory.MemorySegment
-
Reads a short integer value (16 bit, 2 bytes) from the given position, in big-endian byte order.
- getShortByField(String) - Method in class org.apache.flink.storm.wrappers.StormTuple
-
- getShortDescription() - Method in class org.apache.flink.graph.drivers.AdamicAdar
-
- getShortDescription() - Method in class org.apache.flink.graph.drivers.ClusteringCoefficient
-
- getShortDescription() - Method in class org.apache.flink.graph.drivers.ConnectedComponents
-
- getShortDescription() - Method in interface org.apache.flink.graph.drivers.Driver
-
A one-line description, presented in the algorithm listing.
- getShortDescription() - Method in class org.apache.flink.graph.drivers.EdgeList
-
- getShortDescription() - Method in class org.apache.flink.graph.drivers.GraphMetrics
-
- getShortDescription() - Method in class org.apache.flink.graph.drivers.HITS
-
- getShortDescription() - Method in class org.apache.flink.graph.drivers.JaccardIndex
-
- getShortDescription() - Method in class org.apache.flink.graph.drivers.PageRank
-
- getShortDescription() - Method in class org.apache.flink.graph.drivers.TriangleListing
-
- getShortLittleEndian(int) - Method in class 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() - Method in enum org.apache.flink.api.common.operators.Order
-
- getShortString() - Method in class org.apache.flink.graph.drivers.parameter.Simplify
-
- getShutdownTimeout() - Method in class org.apache.flink.test.util.MiniClusterResource.MiniClusterResourceConfiguration
-
- getSideOutput(OutputTag<X>) - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
-
Gets the
DataStream
that contains the elements that are emitted from an operation
into the side output with the given
OutputTag
.
- getSimpleEdgeDataSet(ExecutionEnvironment) - Static method in class org.apache.flink.graph.examples.data.CommunityDetectionData
-
- getSimplifyShortString() - Method in class org.apache.flink.graph.drivers.input.GeneratedMultiGraph
-
Get the short string representation of the simplify transformation.
- getSingleAbstractMethod(Class<?>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractionUtils
-
Extracts a Single Abstract Method (SAM) as defined in Java Specification (4.3.2.
- getSingleInputNode() - Method in class org.apache.flink.optimizer.plan.SingleInputPlanNode
-
- getSingleNestedSerializerAndConfig() - Method in class org.apache.flink.api.common.typeutils.CompositeTypeSerializerConfigSnapshot
-
- getSingleRootOfStepFunction() - Method in class org.apache.flink.optimizer.dag.BulkIterationNode
-
- getSingleRootOfStepFunction() - Method in class org.apache.flink.optimizer.dag.WorksetIterationNode
-
- getSinkIDs() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- getSinkNode() - Method in class org.apache.flink.optimizer.plan.SinkPlanNode
-
- getSinks() - Method in class org.apache.flink.optimizer.traversals.GraphCreatingVisitor
-
- getSize() - Method in class org.apache.flink.api.common.time.Time
-
Gets the length of this policy's time interval.
- getSize() - Method in class org.apache.flink.runtime.io.disk.iomanager.AbstractFileIOChannel
-
- getSize() - Method in interface org.apache.flink.runtime.io.disk.iomanager.FileIOChannel
-
Gets the size (in bytes) of the file underlying the channel.
- getSize() - Method in interface org.apache.flink.runtime.io.network.buffer.Buffer
-
Returns the size of the written data, i.e.
- getSize() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
-
- getSize() - Method in class org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
-
- getSize() - Method in class org.apache.flink.runtime.rpc.messages.RemoteRpcInvocation
-
Size (#bytes of the serialized data) of the rpc invocation message.
- getSize() - Method in class org.apache.flink.streaming.api.windowing.assigners.BaseAlignedWindowAssigner
-
- getSize() - Method in class org.apache.flink.streaming.api.windowing.assigners.SlidingEventTimeWindows
-
- getSize() - Method in class org.apache.flink.streaming.api.windowing.assigners.SlidingProcessingTimeWindows
-
- getSize() - Method in class org.apache.flink.streaming.api.windowing.assigners.TumblingProcessingTimeWindows
-
- getSize() - Method in class org.apache.flink.streaming.api.windowing.time.Time
-
Gets the length of this policy's time interval.
- getSizeLimit() - Method in class org.apache.flink.runtime.util.EvictingBoundedList
-
- getSizeOfFreeHeapMemory() - Static method in class org.apache.flink.runtime.util.EnvironmentInformation
-
Gets an estimate of the size of the free heap memory.
- getSizeOfFreeHeapMemoryWithDefrag() - Static method in class org.apache.flink.runtime.util.EnvironmentInformation
-
Gets an estimate of the size of the free heap memory.
- getSizeOfJvmHeap() - Method in class org.apache.flink.runtime.instance.HardwareDescription
-
Returns the size of the JVM heap memory
- getSizeOfManagedMemory() - Method in class org.apache.flink.runtime.instance.HardwareDescription
-
Returns the size of the memory managed by the system for caching, hashing, sorting, ...
- getSizeOfPhysicalMemory() - Method in class org.apache.flink.runtime.instance.HardwareDescription
-
Returns the size of physical memory in bytes available on the compute node.
- getSizeOfPhysicalMemory() - Static method in class org.apache.flink.runtime.util.Hardware
-
Returns the size of the physical memory in bytes.
- getSizeUnsafe() - Method in interface org.apache.flink.runtime.io.network.buffer.Buffer
-
Returns the size of the written data, i.e.
- getSizeUnsafe() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
-
- getSizeUnsafe() - Method in class org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
-
- getSlide() - Method in class org.apache.flink.streaming.api.windowing.assigners.SlidingAlignedProcessingTimeWindows
-
- getSlide() - Method in class org.apache.flink.streaming.api.windowing.assigners.SlidingEventTimeWindows
-
- getSlide() - Method in class org.apache.flink.streaming.api.windowing.assigners.SlidingProcessingTimeWindows
-
- getSlot() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotAndLocality
-
- getSlotContext() - Method in class org.apache.flink.runtime.instance.Slot
-
Gets the allocated slot that this slot refers to.
- getSlotForTask(JobVertexID, Iterable<TaskManagerLocation>) - Method in class org.apache.flink.runtime.instance.SlotSharingGroupAssignment
-
Gets a slot suitable for the given task vertex.
- getSlotForTask(CoLocationConstraint, Iterable<TaskManagerLocation>) - Method in class org.apache.flink.runtime.instance.SlotSharingGroupAssignment
-
Gets a slot for a task that has a co-location constraint.
- getSlotId() - Method in class org.apache.flink.runtime.clusterframework.types.TaskManagerSlot
-
- getSlotID() - Method in class org.apache.flink.runtime.taskexecutor.SlotStatus
-
Get the unique identification of this slot
- getSlotIndex() - Method in class org.apache.flink.runtime.taskexecutor.slot.SlotOffer
-
- getSlotManager() - Method in class org.apache.flink.runtime.resourcemanager.ResourceManagerRuntimeServices
-
- getSlotManagerConfiguration() - Method in class org.apache.flink.runtime.resourcemanager.ResourceManagerRuntimeServicesConfiguration
-
- getSlotNumber() - Method in class org.apache.flink.runtime.clusterframework.types.SlotID
-
- getSlotNumber() - Method in class org.apache.flink.runtime.instance.Slot
-
Gets the number of the slot.
- getSlotOwner() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotPool
-
Gets the slot owner implementation for this pool.
- getSlotProvider() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- getSlotProvider() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotPool
-
Gets the slot provider implementation for this pool.
- getSlotRequestId() - Method in class org.apache.flink.runtime.instance.SharedSlot
-
- getSlotRequestId() - Method in class org.apache.flink.runtime.instance.SimpleSlot
-
- getSlotRequestId() - Method in class org.apache.flink.runtime.jobmanager.scheduler.CoLocationConstraint
-
Returns the currently assigned slot request id identifying the slot to which tasks
belonging to this co-location constraint will be deployed to.
- getSlotRequestId() - Method in interface org.apache.flink.runtime.jobmaster.LogicalSlot
-
Gets the slot request id uniquely identifying the request with which this
slot has been allocated.
- getSlotRequestId() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SingleLogicalSlot
-
- getSlotRequestId() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotSharingManager.TaskSlot
-
- getSlotRequestTimeout() - Method in class org.apache.flink.runtime.jobmaster.JobMasterConfiguration
-
- getSlotRequestTimeout() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerConfiguration
-
- getSlots() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerRegistration
-
- getSlotSharingGroup() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
- getSlotSharingGroup() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
Gets the slot sharing group that this vertex is associated with.
- getSlotSharingGroup(Integer) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
Determines the slot sharing group of an operation across virtual nodes.
- getSlotSharingGroup() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getSlotSharingGroup() - Method in class org.apache.flink.streaming.api.transformations.StreamTransformation
-
Returns the slot sharing group of this transformation.
- getSlotSharingGroupId() - Method in class org.apache.flink.runtime.instance.SharedSlot
-
- getSlotSharingGroupId() - Method in class org.apache.flink.runtime.instance.SimpleSlot
-
- getSlotSharingGroupId() - Method in class org.apache.flink.runtime.jobmanager.scheduler.ScheduledUnit
-
- getSlotSharingGroupId() - Method in class org.apache.flink.runtime.jobmanager.scheduler.SlotSharingGroup
-
- getSlotSharingGroupId() - Method in interface org.apache.flink.runtime.jobmaster.LogicalSlot
-
Gets the slot sharing group id to which this slot belongs.
- getSlotSharingGroupId() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SingleLogicalSlot
-
- getSlotsPerTaskManager() - Method in class org.apache.flink.client.deployment.ClusterSpecification
-
- getSnapshot() - Method in class org.apache.flink.dropwizard.metrics.FlinkHistogramWrapper
-
- getSnapshot() - Method in class org.apache.flink.runtime.accumulators.AccumulatorRegistry
-
Creates a snapshot of this accumulator registry.
- getSocketAddr(String, String, String, int) - Method in class org.apache.hadoop.conf.Configuration
-
Get the socket address for hostProperty
as a
InetSocketAddress
.
- getSocketAddr(String, String, int) - Method in class org.apache.hadoop.conf.Configuration
-
Get the socket address for name
property as a
InetSocketAddress
.
- getSolutionSet() - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase
-
Gets the contract that represents the solution set for the step function.
- getSolutionSet() - Method in class org.apache.flink.api.java.operators.DeltaIteration
-
Gets the solution set of the delta iteration.
- getSolutionSetComparator() - Method in class org.apache.flink.optimizer.plan.WorksetIterationPlanNode
-
- getSolutionSetComparator(ClassLoader) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getSolutionSetDelta() - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase
-
Gets the contract that has been set as the solution set delta.
- getSolutionSetDelta() - Method in class org.apache.flink.optimizer.dag.WorksetIterationNode
-
- getSolutionSetDeltaPlanNode() - Method in class org.apache.flink.optimizer.plan.WorksetIterationPlanNode
-
- getSolutionSetKeyFields() - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase
-
- getSolutionSetKeyFields() - Method in class org.apache.flink.optimizer.dag.WorksetIterationNode
-
- getSolutionSetKeyFields() - Method in class org.apache.flink.optimizer.plan.WorksetIterationPlanNode
-
- getSolutionSetNode() - Method in class org.apache.flink.optimizer.dag.WorksetIterationNode
-
- getSolutionSetNode() - Method in class org.apache.flink.optimizer.plan.SolutionSetPlanNode
-
- getSolutionSetPlanNode() - Method in class org.apache.flink.optimizer.plan.WorksetIterationPlanNode
-
- getSolutionSetSerializer() - Method in class org.apache.flink.optimizer.plan.WorksetIterationPlanNode
-
- getSolutionSetSerializer(ClassLoader) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getSortedGrouping(int) - Method in class org.apache.flink.python.api.util.SetCache
-
- getSortingThread(ExceptionHandler<IOException>, UnilateralSortMerger.CircularQueues<E>, AbstractInvokable) - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger
-
- getSortOrders() - Method in class org.apache.flink.optimizer.plan.DualInputPlanNode
-
- getSortOrders(int) - Method in class org.apache.flink.optimizer.plan.SingleInputPlanNode
-
Gets the sort order for the specified driver comparator.
- getSortSelectionFunctionKey() - Method in class org.apache.flink.api.java.operators.SortedGrouping
-
- getSource() - Method in class org.apache.flink.graph.Edge
-
- getSource() - Method in class org.apache.flink.optimizer.dag.DagConnection
-
Gets the source of the connection.
- getSource() - Method in class org.apache.flink.optimizer.plan.Channel
-
Gets the source of this Channel.
- getSource() - Method in interface org.apache.flink.optimizer.plandump.DumpableConnection
-
- getSource() - Method in class org.apache.flink.runtime.executiongraph.ExecutionEdge
-
- getSource() - Method in class org.apache.flink.runtime.jobgraph.JobEdge
-
Returns the data set at the source of the edge.
- getSource(StreamExecutionEnvironment, long) - Static method in class org.apache.flink.streaming.examples.join.WindowJoinSampleData.GradeSource
-
- getSource(StreamExecutionEnvironment, long) - Static method in class org.apache.flink.streaming.examples.join.WindowJoinSampleData.SalarySource
-
- getSourceComponent() - Method in class org.apache.flink.storm.wrappers.StormTuple
-
- getSourceContext(TimeCharacteristic, ProcessingTimeService, Object, StreamStatusMaintainer, Output<StreamRecord<OUT>>, long, long) - Static method in class org.apache.flink.streaming.api.operators.StreamSourceContexts
-
- getSourceEdgeValue() - Method in class org.apache.flink.graph.bipartite.Projection
-
- getSourceGlobalStreamid() - Method in class org.apache.flink.storm.wrappers.StormTuple
-
- getSourceGlobalStreamId() - Method in class org.apache.flink.storm.wrappers.StormTuple
-
- getSourceId() - Method in class org.apache.flink.runtime.jobgraph.JobEdge
-
Gets the ID of the consumed data set.
- getSourceId() - Method in class org.apache.flink.streaming.api.graph.StreamEdge
-
- getSourceIDs() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- getSourceState() - Method in class org.apache.flink.cep.nfa.StateTransition
-
- getSourceStreamId() - Method in class org.apache.flink.storm.wrappers.StormTuple
-
- getSourceTask() - Method in class org.apache.flink.storm.wrappers.StormTuple
-
- getSourceVertex() - Method in class org.apache.flink.streaming.api.graph.StreamEdge
-
- getSpillingDirectories() - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManager
-
Gets the directories that the I/O manager spills to.
- getSpillingDirectoriesPaths() - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManager
-
Gets the directories that the I/O manager spills to, as path strings.
- getSpillingThread(ExceptionHandler<IOException>, UnilateralSortMerger.CircularQueues<E>, AbstractInvokable, MemoryManager, IOManager, TypeSerializerFactory<E>, TypeComparator<E>, List<MemorySegment>, List<MemorySegment>, int) - Method in class org.apache.flink.runtime.operators.sort.CombiningUnilateralSortMerger
-
- getSpillingThread(ExceptionHandler<IOException>, UnilateralSortMerger.CircularQueues<E>, AbstractInvokable, MemoryManager, IOManager, TypeSerializerFactory<E>, TypeComparator<E>, List<MemorySegment>, List<MemorySegment>, int) - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger
-
- getSpillingThresholdDriver() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getSpillingThresholdInput(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getSplit(int, int) - Method in class org.apache.flink.util.SplittableIterator
-
Splits this iterator into n partitions and returns the i-th partition
out of those.
- getSplitAssigner() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
- getSplitDataProperties() - Method in class org.apache.flink.api.common.operators.GenericDataSourceBase
-
Returns the data properties of this data source's splits.
- getSplitDataProperties() - Method in class org.apache.flink.api.java.operators.DataSource
-
- getSplitGroupKeys() - Method in interface org.apache.flink.api.common.operators.GenericDataSourceBase.SplitDataProperties
-
- getSplitGroupKeys() - Method in class org.apache.flink.api.java.io.SplitDataProperties
-
- getSplitLength() - Method in class org.apache.flink.api.common.io.FileInputFormat
-
Gets the length or remaining length of the current split.
- getSplitNumber() - Method in class org.apache.flink.core.io.GenericInputSplit
-
- getSplitNumber() - Method in interface org.apache.flink.core.io.InputSplit
-
Returns the number of this input split.
- getSplitNumber() - Method in class org.apache.flink.core.io.LocatableInputSplit
-
- getSplitNumber() - Method in class org.apache.flink.examples.java.distcp.FileCopyTaskInputSplit
-
- getSplitOrder() - Method in interface org.apache.flink.api.common.operators.GenericDataSourceBase.SplitDataProperties
-
- getSplitOrder() - Method in class org.apache.flink.api.java.io.SplitDataProperties
-
- getSplitPartitioner() - Method in interface org.apache.flink.api.common.operators.GenericDataSourceBase.SplitDataProperties
-
- getSplitPartitioner() - Method in class org.apache.flink.api.java.io.SplitDataProperties
-
- getSplitPartitionKeys() - Method in interface org.apache.flink.api.common.operators.GenericDataSourceBase.SplitDataProperties
-
- getSplitPartitionKeys() - Method in class org.apache.flink.api.java.io.SplitDataProperties
-
- getSplitStart() - Method in class org.apache.flink.api.common.io.FileInputFormat
-
Gets the start of the current split.
- getSplitState() - Method in class org.apache.flink.streaming.api.functions.source.TimestampedFileInputSplit
-
- getSqlExecutionPlan(String, Boolean) - Static method in class org.apache.flink.table.explain.PlanJsonParser
-
- getSrcVertex() - Method in class org.apache.flink.graph.Triplet
-
- getSslContext() - Method in class org.apache.flink.runtime.net.SSLUtils.SSLContext
-
- getSSLEnabled() - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
-
- getSSLEnabled(Configuration) - Static method in class org.apache.flink.runtime.net.SSLUtils
-
Retrieves the global ssl flag from configuration.
- getSslEngineFactory() - Method in class org.apache.flink.runtime.rest.RestClientConfiguration
-
Returns the
SSLEngine
that the REST client endpoint should use.
- getSslEngineFactory() - Method in class org.apache.flink.runtime.rest.RestServerEndpointConfiguration
-
Returns the
SSLEngine
that the REST server endpoint should use.
- getsSourceVertexValue() - Method in class org.apache.flink.graph.bipartite.Projection
-
- getStackTrace() - Method in class org.apache.flink.runtime.messages.StackTrace
-
- getStackTraces() - Method in class org.apache.flink.runtime.rest.handler.legacy.backpressure.StackTraceSample
-
Returns the a map of stack traces by execution ID.
- getStandardDeviation() - Method in class org.apache.flink.api.java.summarize.NumericColumnSummary
-
Standard Deviation is a measure of variation in a set of numbers.
- getStart() - Method in class org.apache.flink.core.fs.FileInputSplit
-
Returns the position of the first byte in the file to process.
- getStart() - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow
-
Gets the starting timestamp of the window.
- getStartCommand(String, Map<String, String>) - Static method in class org.apache.flink.runtime.clusterframework.BootstrapTools
-
Replaces placeholders in the template start command with values from startCommandValues.
- getStartedTaskManagers() - Method in class org.apache.flink.runtime.clusterframework.FlinkResourceManager
-
Gets the currently registered resources.
- getStartKeyGroup() - Method in class org.apache.flink.runtime.state.KeyGroupRange
-
- getStartRow() - Method in class org.apache.flink.addons.hbase.TableInputSplit
-
Returns the start row.
- getStartTime() - Method in class org.apache.flink.runtime.client.JobStatusMessage
-
- getStartTime() - Method in class org.apache.flink.runtime.messages.webmonitor.JobDetails
-
- getStartTime() - Method in class org.apache.flink.runtime.rest.handler.legacy.backpressure.StackTraceSample
-
Returns the time stamp, when the sample was triggered.
- getStartTime() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
-
- getStartTime() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
-
- getStartTime() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsInfo
-
- getStartTimestamp() - Method in class org.apache.flink.cep.nfa.ComputationState
-
- getState(ValueStateDescriptor<T>) - Method in interface org.apache.flink.api.common.functions.RuntimeContext
-
Gets a handle to the system's key/value state.
- getState(ValueStateDescriptor<T>) - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
-
- getState(ValueStateDescriptor<T>) - Method in interface org.apache.flink.api.common.state.KeyedStateStore
-
Gets a handle to the system's key/value state.
- getState() - Method in class org.apache.flink.api.java.sca.UdfAnalyzer
-
- getState() - Method in class org.apache.flink.cep.nfa.ComputationState
-
- getState() - Method in class org.apache.flink.graph.utils.proxy.OptionalBoolean
-
Get the actual state.
- getState(int) - Method in class org.apache.flink.runtime.checkpoint.OperatorState
-
- getState(int) - Method in class org.apache.flink.runtime.checkpoint.TaskState
-
Deprecated.
- getState() - Method in class org.apache.flink.runtime.clusterframework.types.TaskManagerSlot
-
- getState() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecution
-
- getState() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionGraph
-
Returns the current
JobStatus
for this execution graph.
- getState() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecution
-
- getState() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
-
- getState() - Method in class org.apache.flink.runtime.executiongraph.Execution
-
- getState() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- getState() - Method in class org.apache.flink.runtime.executiongraph.failover.FailoverRegion
-
- getState() - Method in class org.apache.flink.runtime.query.KvStateEntry
-
- getState(ValueStateDescriptor<T>) - Method in class org.apache.flink.runtime.state.DefaultKeyedStateStore
-
- getState() - Method in class org.apache.flink.runtime.state.heap.NestedMapsStateTable
-
Returns the internal data structure.
- getState() - Method in interface org.apache.flink.runtime.state.heap.StateEntry
-
Returns the state of this entry.
- getState() - Method in class org.apache.flink.storm.api.FlinkLocalCluster
-
- getState(ValueStateDescriptor<T>) - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
-
- getState() - Method in class org.apache.flink.streaming.connectors.fs.bucketing.BucketingSink
-
- getState(ValueStateDescriptor<T>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.MergingWindowStateStore
-
- getStateBackend() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Gets the state backend that defines how to store and checkpoint state.
- getStateBackend(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getStateBackend() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- getStateDescriptor() - Method in class org.apache.flink.streaming.api.datastream.QueryableStateStream
-
Returns the state descriptor for the queryable state instance.
- getStateDescriptor() - Method in class org.apache.flink.streaming.runtime.operators.windowing.EvictingWindowOperator
-
- getStateDescriptor() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
- getStateKeySelector() - Method in class org.apache.flink.streaming.api.transformations.OneInputTransformation
-
Returns the KeySelector
that must be used for partitioning keyed state in this
Operation.
- getStateKeySelector() - Method in class org.apache.flink.streaming.api.transformations.SinkTransformation
-
Returns the KeySelector
that must be used for partitioning keyed state in this
Sink.
- getStateKeySelector1() - Method in class org.apache.flink.streaming.api.transformations.TwoInputTransformation
-
Returns the KeySelector
that must be used for partitioning keyed state in this
Operation for the first input.
- getStateKeySelector2() - Method in class org.apache.flink.streaming.api.transformations.TwoInputTransformation
-
Returns the KeySelector
that must be used for partitioning keyed state in this
Operation for the second input.
- getStateKeySerializer(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getStateKeySerializer() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getStateKeyType() - Method in class org.apache.flink.streaming.api.transformations.OneInputTransformation
-
- getStateKeyType() - Method in class org.apache.flink.streaming.api.transformations.SinkTransformation
-
- getStateKeyType() - Method in class org.apache.flink.streaming.api.transformations.TwoInputTransformation
-
- getStateMetaInfo() - Method in interface org.apache.flink.runtime.state.BackendWritableBroadcastState
-
- getStateMetaInfo() - Method in class org.apache.flink.runtime.state.HeapBroadcastState
-
- getStateMetaInfoSnapshots() - Method in class org.apache.flink.runtime.state.KeyedBackendSerializationProxy
-
- getStateName() - Method in class org.apache.flink.queryablestate.messages.KvStateRequest
-
- getStateName() - Method in class org.apache.flink.streaming.tests.artificialstate.builder.ArtificialStateBuilder
-
- getStateNameToPartitionOffsets() - Method in interface org.apache.flink.runtime.state.OperatorStateHandle
-
Returns a map of meta data for all contained states by their name.
- getStateNameToPartitionOffsets() - Method in class org.apache.flink.runtime.state.OperatorStreamStateHandle
-
- getStatePartitioner(int, ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getStatePartitioner1() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getStatePartitioner2() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getStates() - Method in class org.apache.flink.cep.nfa.NFA
-
- getStates() - Method in class org.apache.flink.runtime.checkpoint.OperatorState
-
- getStates() - Method in class org.apache.flink.runtime.checkpoint.TaskState
-
Deprecated.
- getStateSentinel() - Method in enum org.apache.flink.streaming.connectors.kafka.config.StartupMode
-
- getStateSerializer() - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateTable
-
- getStateSerializer() - Method in class org.apache.flink.runtime.state.heap.StateTable
-
- getStateSerializer() - Method in class org.apache.flink.runtime.state.RegisteredKeyedBackendStateMetaInfo
-
- getStateSerializer() - Method in class org.apache.flink.runtime.state.RegisteredKeyedBackendStateMetaInfo.Snapshot
-
- getStateSerializerConfigSnapshot() - Method in class org.apache.flink.runtime.state.RegisteredKeyedBackendStateMetaInfo.Snapshot
-
- getStateServerPortRange() - Method in class org.apache.flink.runtime.taskexecutor.QueryableStateConfiguration
-
Returns the port range where the queryable state client proxy can listen.
- getStateSize() - Method in class org.apache.flink.api.common.operators.ResourceSpec
-
- getStateSize() - Method in class org.apache.flink.runtime.checkpoint.AbstractCheckpointStats
-
Returns the total checkpoint state size over all subtasks.
- getStateSize() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
-
- getStateSize() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpointStats
-
- getStateSize() - Method in class org.apache.flink.runtime.checkpoint.FailedCheckpointStats
-
- getStateSize() - Method in class org.apache.flink.runtime.checkpoint.OperatorState
-
- getStateSize() - Method in class org.apache.flink.runtime.checkpoint.OperatorSubtaskState
-
- getStateSize() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpointStats
-
- getStateSize() - Method in class org.apache.flink.runtime.checkpoint.StateObjectCollection
-
- getStateSize() - Method in class org.apache.flink.runtime.checkpoint.SubtaskState
-
- getStateSize() - Method in class org.apache.flink.runtime.checkpoint.SubtaskStateStats
-
Returns the size of the checkpointed state at this subtask.
- getStateSize() - Method in class org.apache.flink.runtime.checkpoint.TaskState
-
Deprecated.
- getStateSize() - Method in class org.apache.flink.runtime.checkpoint.TaskStateSnapshot
-
- getStateSize() - Method in class org.apache.flink.runtime.checkpoint.TaskStateStats
-
Returns the total checkpoint state size over all subtasks.
- getStateSize() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.Summary
-
- getStateSize() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
-
- getStateSize() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics
-
- getStateSize() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatistics
-
- getStateSize() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.Summary
-
- getStateSize() - Method in class org.apache.flink.runtime.state.ChainedStateHandle
-
- getStateSize() - Method in class org.apache.flink.runtime.state.DirectoryKeyedStateHandle
-
- getStateSize() - Method in class org.apache.flink.runtime.state.DirectoryStateHandle
-
- getStateSize() - Method in class org.apache.flink.runtime.state.filesystem.FileStateHandle
-
Returns the file size in bytes.
- getStateSize() - Method in class org.apache.flink.runtime.state.IncrementalKeyedStateHandle
-
- getStateSize() - Method in class org.apache.flink.runtime.state.IncrementalLocalKeyedStateHandle
-
- getStateSize() - Method in class org.apache.flink.runtime.state.KeyGroupsStateHandle
-
- getStateSize() - Method in class org.apache.flink.runtime.state.memory.ByteStreamStateHandle
-
- getStateSize() - Method in class org.apache.flink.runtime.state.OperatorStreamStateHandle
-
- getStateSize() - Method in class org.apache.flink.runtime.state.PlaceholderStreamStateHandle
-
- getStateSize() - Method in class org.apache.flink.runtime.state.RetrievableStreamStateHandle
-
- getStateSize() - Method in class org.apache.flink.runtime.state.SnapshotResult
-
- getStateSize() - Method in interface org.apache.flink.runtime.state.StateObject
-
Returns the size of the state in bytes.
- getStateSize(StateObject) - Static method in class org.apache.flink.runtime.state.StateUtil
-
Returns the size of a state object
- getStateSizeStats() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpointStatsSummary
-
Returns the summary stats for the state size of completed checkpoints.
- getStateSizeStats() - Method in class org.apache.flink.runtime.checkpoint.TaskStateStats.TaskStateStatsSummary
-
Returns the summary stats for the state size.
- getStateTable() - Method in class org.apache.flink.runtime.state.heap.AbstractHeapState
-
This should only be used for testing.
- getStateTimestamp(ExecutionState) - Method in interface org.apache.flink.runtime.executiongraph.AccessExecution
-
- getStateTimestamp(ExecutionState) - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionVertex
-
- getStateTimestamp(ExecutionState) - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecution
-
- getStateTimestamp(ExecutionState) - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionVertex
-
- getStateTimestamp(ExecutionState) - Method in class org.apache.flink.runtime.executiongraph.Execution
-
- getStateTimestamp(ExecutionState) - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- getStateTimestamps() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecution
-
- getStateTimestamps() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecution
-
- getStateTimestamps() - Method in class org.apache.flink.runtime.executiongraph.Execution
-
- getStateTransitions() - Method in class org.apache.flink.cep.nfa.State
-
- getStateType() - Method in class org.apache.flink.cep.nfa.State
-
- getStateType() - Method in class org.apache.flink.runtime.state.RegisteredKeyedBackendStateMetaInfo
-
- getStateType() - Method in class org.apache.flink.runtime.state.RegisteredKeyedBackendStateMetaInfo.Snapshot
-
- getStateValueSerializer() - Method in class org.apache.flink.runtime.query.KvStateInfo
-
- getStateWindow(W) - Method in class org.apache.flink.streaming.runtime.operators.windowing.MergingWindowSet
-
Returns the state window for the given in-flight Window
.
- getStatistics(BaseStatistics) - Method in class org.apache.flink.addons.hbase.AbstractTableInputFormat
-
- getStatistics(BaseStatistics) - Method in class org.apache.flink.api.common.io.BinaryInputFormat
-
- getStatistics(BaseStatistics) - Method in class org.apache.flink.api.common.io.DelimitedInputFormat
-
- getStatistics(BaseStatistics) - Method in class org.apache.flink.api.common.io.FileInputFormat
-
Obtains basic file statistics containing only file size.
- getStatistics(BaseStatistics) - Method in class org.apache.flink.api.common.io.GenericInputFormat
-
- getStatistics(BaseStatistics) - Method in interface org.apache.flink.api.common.io.InputFormat
-
Gets the basic statistics from the input described by this format.
- getStatistics(BaseStatistics) - Method in class org.apache.flink.api.common.io.ReplicatingInputFormat
-
- getStatistics(BaseStatistics) - Method in class org.apache.flink.api.java.hadoop.mapred.HadoopInputFormatBase
-
- getStatistics(BaseStatistics) - Method in class org.apache.flink.api.java.hadoop.mapreduce.HadoopInputFormatBase
-
- getStatistics(BaseStatistics) - Method in class org.apache.flink.api.java.io.jdbc.JDBCInputFormat
-
- getStatistics(BaseStatistics) - Method in class org.apache.flink.batch.connectors.cassandra.CassandraInputFormat
-
- getStatistics(BaseStatistics) - Method in class org.apache.flink.batch.tests.DataSetAllroundTestProgram.Generator
-
- getStatistics() - Method in class org.apache.flink.dropwizard.metrics.DropwizardHistogramWrapper
-
- getStatistics(BaseStatistics) - Method in class org.apache.flink.examples.java.distcp.FileCopyTaskInputFormat
-
- getStatistics(BaseStatistics) - Method in class org.apache.flink.hcatalog.HCatInputFormatBase
-
- getStatistics() - Method in interface org.apache.flink.metrics.Histogram
-
Create statistics for the currently recorded elements.
- getStatistics() - Method in class org.apache.flink.runtime.metrics.DescriptiveStatisticsHistogram
-
- getStatisticsKey() - Method in class org.apache.flink.api.common.operators.GenericDataSourceBase
-
Gets the key under which statistics about this data source may be obtained from the
statistics cache.
- getStatus() - Method in class org.apache.flink.runtime.checkpoint.AbstractCheckpointStats
-
Returns the status of this checkpoint.
- getStatus() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpointStats
-
- getStatus() - Method in class org.apache.flink.runtime.checkpoint.FailedCheckpointStats
-
- getStatus() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpointStats
-
- getStatus() - Method in class org.apache.flink.runtime.messages.webmonitor.JobDetails
-
- getStatus() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
-
- getStatus() - Method in class org.apache.flink.runtime.rest.messages.job.JobExecutionResultResponseBody
-
- getStatus() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsInfo
-
- getStatus() - Method in class org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo
-
- getStatus() - Method in class org.apache.flink.runtime.webmonitor.handlers.JarUploadResponseBody
-
- getStatus() - Method in class org.apache.flink.streaming.runtime.streamstatus.StreamStatus
-
- getStatusTimestamp(JobStatus) - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionGraph
-
Returns the timestamp for the given
JobStatus
.
- getStatusTimestamp(JobStatus) - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
-
- getStatusTimestamp(JobStatus) - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- getStdDev() - Method in class org.apache.flink.metrics.HistogramStatistics
-
Returns the standard deviation of the distribution reflected by the histogram statistics.
- getStdDev() - Method in interface org.apache.flink.metrics.jmx.JMXReporter.JmxHistogramMBean
-
- getStdDev() - Method in class org.apache.flink.runtime.metrics.DescriptiveStatisticsHistogramStatistics
-
- getStdoutLogging() - Method in class org.apache.flink.client.cli.ProgramOptions
-
- getStopException() - Method in class org.apache.flink.runtime.io.async.AbstractAsyncCallableWithResources
-
Returns a potential exception that might have been observed while stopping the operation.
- getStopException() - Method in interface org.apache.flink.runtime.io.async.AsyncStoppable
-
- getStorageLocation(JobID, BlobKey) - Method in class org.apache.flink.runtime.blob.BlobServer
-
Returns a file handle to the file associated with the given blob key on the blob
server.
- getStorageLocation(JobID, BlobKey) - Method in class org.apache.flink.runtime.blob.PermanentBlobCache
-
Returns a file handle to the file associated with the given blob key on the blob
server.
- getStorageLocation(JobID, BlobKey) - Method in class org.apache.flink.runtime.blob.TransientBlobCache
-
Returns a file handle to the file associated with the given blob key on the blob
server.
- getStoredJobsOverview() - Method in interface org.apache.flink.runtime.dispatcher.ArchivedExecutionGraphStore
-
- getStoredJobsOverview() - Method in class org.apache.flink.runtime.dispatcher.FileArchivedExecutionGraphStore
-
- getStoredJobsOverview() - Method in class org.apache.flink.runtime.dispatcher.MemoryArchivedExecutionGraphStore
-
- getStores(MetricStore, Map<String, String>, Map<String, String>) - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.AggregatingJobsMetricsHandler
-
- getStores(MetricStore, Map<String, String>, Map<String, String>) - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.AggregatingSubtasksMetricsHandler
-
- getStores(MetricStore, Map<String, String>, Map<String, String>) - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.AggregatingTaskManagersMetricsHandler
-
- getStormTopology() - Method in class org.apache.flink.storm.api.FlinkTopology
-
- getStrategy() - Method in class org.apache.flink.cep.nfa.AfterMatchSkipStrategy
-
- getStrategy() - Method in class org.apache.flink.optimizer.dag.PartitionNode.PartitionDescriptor
-
- getStrategy() - Method in class org.apache.flink.optimizer.dag.SortPartitionNode.SortPartitionDescriptor
-
- getStrategy() - Method in interface org.apache.flink.optimizer.operators.AbstractOperatorDescriptor
-
Gets the runtime strategy to be executed by this operator.
- getStrategy() - Method in class org.apache.flink.optimizer.operators.AllGroupCombineProperties
-
- getStrategy() - Method in class org.apache.flink.optimizer.operators.AllGroupReduceProperties
-
- getStrategy() - Method in class org.apache.flink.optimizer.operators.AllGroupWithPartialPreGroupProperties
-
- getStrategy() - Method in class org.apache.flink.optimizer.operators.AllReduceProperties
-
- getStrategy() - Method in class org.apache.flink.optimizer.operators.BinaryUnionOpDescriptor
-
- getStrategy() - Method in class org.apache.flink.optimizer.operators.CoGroupDescriptor
-
- getStrategy() - Method in class org.apache.flink.optimizer.operators.CoGroupRawDescriptor
-
- getStrategy() - Method in class org.apache.flink.optimizer.operators.CrossBlockOuterFirstDescriptor
-
- getStrategy() - Method in class org.apache.flink.optimizer.operators.CrossBlockOuterSecondDescriptor
-
- getStrategy() - Method in class org.apache.flink.optimizer.operators.CrossStreamOuterFirstDescriptor
-
- getStrategy() - Method in class org.apache.flink.optimizer.operators.CrossStreamOuterSecondDescriptor
-
- getStrategy() - Method in class org.apache.flink.optimizer.operators.FilterDescriptor
-
- getStrategy() - Method in class org.apache.flink.optimizer.operators.FlatMapDescriptor
-
- getStrategy() - Method in class org.apache.flink.optimizer.operators.GroupCombineProperties
-
- getStrategy() - Method in class org.apache.flink.optimizer.operators.GroupReduceProperties
-
- getStrategy() - Method in class org.apache.flink.optimizer.operators.GroupReduceWithCombineProperties
-
- getStrategy() - Method in class org.apache.flink.optimizer.operators.HashFullOuterJoinBuildFirstDescriptor
-
- getStrategy() - Method in class org.apache.flink.optimizer.operators.HashFullOuterJoinBuildSecondDescriptor
-
- getStrategy() - Method in class org.apache.flink.optimizer.operators.HashJoinBuildFirstProperties
-
- getStrategy() - Method in class org.apache.flink.optimizer.operators.HashJoinBuildSecondProperties
-
- getStrategy() - Method in class org.apache.flink.optimizer.operators.HashLeftOuterJoinBuildFirstDescriptor
-
- getStrategy() - Method in class org.apache.flink.optimizer.operators.HashLeftOuterJoinBuildSecondDescriptor
-
- getStrategy() - Method in class org.apache.flink.optimizer.operators.HashRightOuterJoinBuildFirstDescriptor
-
- getStrategy() - Method in class org.apache.flink.optimizer.operators.HashRightOuterJoinBuildSecondDescriptor
-
- getStrategy() - Method in class org.apache.flink.optimizer.operators.MapDescriptor
-
- getStrategy() - Method in class org.apache.flink.optimizer.operators.MapPartitionDescriptor
-
- getStrategy() - Method in class org.apache.flink.optimizer.operators.NoOpDescriptor
-
- getStrategy() - Method in class org.apache.flink.optimizer.operators.PartialGroupProperties
-
- getStrategy() - Method in class org.apache.flink.optimizer.operators.ReduceProperties
-
- getStrategy() - Method in class org.apache.flink.optimizer.operators.SolutionSetDeltaOperator
-
- getStrategy() - Method in class org.apache.flink.optimizer.operators.SortMergeFullOuterJoinDescriptor
-
- getStrategy() - Method in class org.apache.flink.optimizer.operators.SortMergeInnerJoinDescriptor
-
- getStrategy() - Method in class org.apache.flink.optimizer.operators.SortMergeLeftOuterJoinDescriptor
-
- getStrategy() - Method in class org.apache.flink.optimizer.operators.SortMergeRightOuterJoinDescriptor
-
- getStrategy() - Method in class org.apache.flink.optimizer.operators.UtilSinkJoinOpDescriptor
-
- getStrategyName() - Method in class org.apache.flink.runtime.executiongraph.failover.FailoverStrategy
-
Gets the name of the failover strategy, for logging purposes.
- getStrategyName() - Method in class org.apache.flink.runtime.executiongraph.failover.RestartAllStrategy
-
- getStrategyName() - Method in class org.apache.flink.runtime.executiongraph.failover.RestartIndividualStrategy
-
- getStrategyName() - Method in class org.apache.flink.runtime.executiongraph.failover.RestartPipelinedRegionStrategy
-
- getStream() - Method in class org.apache.flink.runtime.state.StatePartitionStreamProvider
-
Returns a stream with the data of one state partition.
- getStream() - Method in class org.apache.flink.streaming.connectors.fs.StreamWriterBase
-
Returns the current output stream, if the stream is open.
- getStreamEdges(int, int) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- getStreamElement() - Method in class org.apache.flink.streaming.api.operators.async.queue.StreamElementQueueEntry
-
- getStreamExecutionEnvironment() - Method in class org.apache.flink.table.client.gateway.local.ExecutionContext.EnvironmentInstance
-
- getStreamGraph() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- getStreamInactivityTimeout() - Method in class org.apache.flink.core.fs.LimitedConnectionsFileSystem
-
Gets the milliseconds that a stream may spend not writing any bytes before it is closed as inactive.
- getStreamingPlanAsJSON() - Method in class org.apache.flink.optimizer.plan.StreamingPlan
-
- getStreamingPlanAsJSON() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- getStreamNode(Integer) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- getStreamNodes() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- getStreamOpenTimeout() - Method in class org.apache.flink.core.fs.LimitedConnectionsFileSystem
-
Gets the number of milliseconds that a opening a stream may wait for availability in the
connection pool.
- getStreamOperator(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getStreamOutputs() - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
-
- getStreamRecord() - Method in class org.apache.flink.streaming.runtime.operators.windowing.TimestampedValue
-
- getStreamStatus() - Method in interface org.apache.flink.streaming.runtime.streamstatus.StreamStatusProvider
-
Returns the current stream status.
- getStreamStatus() - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
-
- getStreamStatusMaintainer() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- getStreamTimeCharacteristic() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Gets the time characteristic.
- getStrictObjectMapper() - Static method in class org.apache.flink.runtime.rest.util.RestMapperUtils
-
Returns a preconfigured ObjectMapper
.
- getString(String, String) - Method in class org.apache.flink.configuration.Configuration
-
Returns the value associated with the given key as a string.
- getString(ConfigOption<String>) - Method in class org.apache.flink.configuration.Configuration
-
Returns the value associated with the given config option as a string.
- getString(ConfigOption<String>, String) - Method in class org.apache.flink.configuration.Configuration
-
Returns the value associated with the given config option as a string.
- getString(String, String) - Method in class org.apache.flink.configuration.DelegatingConfiguration
-
- getString(ConfigOption<String>) - Method in class org.apache.flink.configuration.DelegatingConfiguration
-
- getString(ConfigOption<String>, String) - Method in class org.apache.flink.configuration.DelegatingConfiguration
-
- getString(String, String) - Method in class org.apache.flink.metrics.MetricConfig
-
- getString(int) - Method in class org.apache.flink.storm.wrappers.StormTuple
-
- getStringByField(String) - Method in class org.apache.flink.storm.wrappers.StormTuple
-
- getStringCollection(String) - Method in class org.apache.hadoop.conf.Configuration
-
Get the comma delimited values of the name
property as
a collection of String
s.
- getStringList() - Method in class org.apache.flink.streaming.tests.artificialstate.ComplexPayload
-
- getStrings(String) - Method in class org.apache.hadoop.conf.Configuration
-
Get the comma delimited values of the name
property as
an array of String
s.
- getStrings(String, String...) - Method in class org.apache.hadoop.conf.Configuration
-
Get the comma delimited values of the name
property as
an array of String
s.
- getStrPayload() - Method in class org.apache.flink.streaming.tests.artificialstate.ComplexPayload
-
- getStub() - Method in class org.apache.flink.runtime.operators.BatchTask
-
- getStub() - Method in class org.apache.flink.runtime.operators.chaining.ChainedAllReduceDriver
-
- getStub() - Method in class org.apache.flink.runtime.operators.chaining.ChainedDriver
-
- getStub() - Method in class org.apache.flink.runtime.operators.chaining.ChainedFlatMapDriver
-
- getStub() - Method in class org.apache.flink.runtime.operators.chaining.ChainedMapDriver
-
- getStub() - Method in class org.apache.flink.runtime.operators.chaining.ChainedReduceCombineDriver
-
- getStub() - Method in class org.apache.flink.runtime.operators.chaining.ChainedTerminationCriterionDriver
-
- getStub() - Method in class org.apache.flink.runtime.operators.chaining.GroupCombineChainedDriver
-
- getStub() - Method in class org.apache.flink.runtime.operators.chaining.SynchronousChainedCombineDriver
-
- getStub() - Method in class org.apache.flink.runtime.operators.NoOpChainedDriver
-
- getStub() - Method in interface org.apache.flink.runtime.operators.TaskContext
-
- getStubParameter(String, String) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getStubParameters() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getStubType() - Method in class org.apache.flink.runtime.operators.AbstractOuterJoinDriver
-
- getStubType() - Method in class org.apache.flink.runtime.operators.AllGroupCombineDriver
-
- getStubType() - Method in class org.apache.flink.runtime.operators.AllGroupReduceDriver
-
- getStubType() - Method in class org.apache.flink.runtime.operators.AllReduceDriver
-
- getStubType() - Method in class org.apache.flink.runtime.operators.CoGroupDriver
-
- getStubType() - Method in class org.apache.flink.runtime.operators.CoGroupRawDriver
-
- getStubType() - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetFirstDriver
-
- getStubType() - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetSecondDriver
-
- getStubType() - Method in class org.apache.flink.runtime.operators.CrossDriver
-
- getStubType() - Method in interface org.apache.flink.runtime.operators.Driver
-
Gets the class of the stub type that is run by this task.
- getStubType() - Method in class org.apache.flink.runtime.operators.FlatMapDriver
-
- getStubType() - Method in class org.apache.flink.runtime.operators.GroupReduceCombineDriver
-
- getStubType() - Method in class org.apache.flink.runtime.operators.GroupReduceDriver
-
- getStubType() - Method in class org.apache.flink.runtime.operators.JoinDriver
-
- getStubType() - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetFirstDriver
-
- getStubType() - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetSecondDriver
-
- getStubType() - Method in class org.apache.flink.runtime.operators.MapDriver
-
- getStubType() - Method in class org.apache.flink.runtime.operators.MapPartitionDriver
-
- getStubType() - Method in class org.apache.flink.runtime.operators.NoOpDriver
-
- getStubType() - Method in class org.apache.flink.runtime.operators.ReduceCombineDriver
-
- getStubType() - Method in class org.apache.flink.runtime.operators.ReduceDriver
-
- getStubType() - Method in class org.apache.flink.runtime.operators.UnionWithTempOperator
-
- getStubWrapper(ClassLoader) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getSubmittedJobGraphStore() - Method in interface org.apache.flink.runtime.highavailability.HighAvailabilityServices
-
Gets the submitted job graph store for the job manager
- getSubmittedJobGraphStore() - Method in class org.apache.flink.runtime.highavailability.nonha.AbstractNonHaServices
-
- getSubmittedJobGraphStore() - Method in class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperHaServices
-
- getSubmittedJobGraphStore() - Method in class org.apache.flink.yarn.highavailability.AbstractYarnNonHaServices
-
- getSubtask() - Method in class org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo.SubtaskBackPressureInfo
-
- getSubtaskCheckpointStatistics() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails
-
- getSubtaskId() - Method in class org.apache.flink.runtime.jobgraph.OperatorInstanceID
-
- getSubtaskIndex() - Method in class org.apache.flink.runtime.checkpoint.SubtaskStateStats
-
Returns the subtask index.
- getSubtaskIndex() - Method in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
-
Returns the task's index in the subtask group.
- getSubtaskIndex() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsInfo
-
- getSubtaskIndex() - Method in class org.apache.flink.streaming.runtime.streamrecord.LatencyMarker
-
- getSubtaskMetricStore(String, String, int) - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.MetricStore
-
- getSubtaskMetricStore(int) - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.MetricStore.TaskMetricStore
-
- getSubtasks() - Method in class org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo
-
- getSubtaskState() - Method in class org.apache.flink.runtime.messages.checkpoint.AcknowledgeCheckpoint
-
- getSubtaskStateByOperatorID(OperatorID) - Method in class org.apache.flink.runtime.checkpoint.TaskStateSnapshot
-
Returns the subtask state for the given operator id (or null if not contained).
- getSubtaskStateMappings() - Method in class org.apache.flink.runtime.checkpoint.TaskStateSnapshot
-
Returns the set of all mappings from operator id to the corresponding subtask state.
- getSubtaskStates() - Method in class org.apache.flink.runtime.checkpoint.OperatorState
-
- getSubtaskStates() - Method in class org.apache.flink.runtime.checkpoint.TaskState
-
Deprecated.
- getSubtaskStats() - Method in class org.apache.flink.runtime.checkpoint.TaskStateStats
-
Returns the stats for all subtasks.
- getSuccessfulCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
- getSum() - Method in class org.apache.flink.api.java.summarize.NumericColumnSummary
-
- getSum() - Method in class org.apache.flink.runtime.checkpoint.MinMaxAvgStats
-
Returns the sum of all seen values.
- getSum() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedMetric
-
- getSumBcastVars() - Method in class org.apache.flink.graph.gsa.GSAConfiguration
-
Get the broadcast variables of the SumFunction.
- getSummary() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics
-
- getSummary() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails
-
- getSummary() - Method in class org.apache.flink.streaming.connectors.wikiedits.WikipediaEditEvent
-
- getSummaryStats() - Method in class org.apache.flink.runtime.checkpoint.CheckpointStatsSnapshot
-
Returns the snapshotted completed checkpoint summary stats.
- getSummaryStats() - Method in class org.apache.flink.runtime.checkpoint.TaskStateStats
-
Returns the summary of the subtask stats.
- getSuperstep() - Method in class org.apache.flink.runtime.broadcast.BroadcastVariableKey
-
- getSuperstepNumber() - Method in interface org.apache.flink.api.common.functions.IterationRuntimeContext
-
Gets the number of the current superstep.
- getSuperstepNumber() - Method in class org.apache.flink.graph.gsa.ApplyFunction
-
Gets the number of the superstep, starting at 1.
- getSuperstepNumber() - Method in class org.apache.flink.graph.gsa.GatherFunction
-
Gets the number of the superstep, starting at 1.
- getSuperstepNumber() - Method in class org.apache.flink.graph.gsa.SumFunction
-
Gets the number of the superstep, starting at 1.
- getSuperstepNumber() - Method in class org.apache.flink.graph.pregel.ComputeFunction
-
Gets the number of the superstep, starting at 1.
- getSuperstepNumber() - Method in class org.apache.flink.graph.spargel.GatherFunction
-
Gets the number of the superstep, starting at 1.
- getSuperstepNumber() - Method in class org.apache.flink.graph.spargel.ScatterFunction
-
Gets the number of the superstep, starting at 1.
- getSuperTemplateTypes(Class<?>) - Static method in class org.apache.flink.util.ReflectionUtil
-
- getSuperTemplateTypes(Class<?>, Class<?>) - Static method in class org.apache.flink.util.ReflectionUtil
-
- getSyncCheckpointDuration() - Method in class org.apache.flink.runtime.checkpoint.SubtaskStateStats
-
Returns the duration of the synchronous part of the checkpoint.
- getSyncCheckpointDurationStats() - Method in class org.apache.flink.runtime.checkpoint.TaskStateStats.TaskStateStatsSummary
-
Returns the summary stats for the sync checkpoint duration.
- getSyncDuration() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics.CheckpointDuration
-
- getSyncDurationMillis() - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetrics
-
- getSynchronizationLock() - Method in class org.apache.flink.util.AbstractCloseableRegistry
-
Returns the lock on which manipulations to members closeableToRef and closeable must be synchronized.
- getSynchronousDuration() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.CheckpointDuration
-
- getSystemProperties() - Method in class org.apache.flink.runtime.clusterframework.ContainerSpecification
-
Get the system properties.
- getTableEnvironment() - Method in class org.apache.flink.table.client.gateway.local.ExecutionContext.EnvironmentInstance
-
- getTableName() - Method in class org.apache.flink.addons.hbase.AbstractTableInputFormat
-
What table is to be read.
- getTableName() - Method in class org.apache.flink.addons.hbase.HBaseRowInputFormat
-
- getTableName() - Method in class org.apache.flink.addons.hbase.TableInputFormat
-
What table is to be read.
- getTableName() - Method in class org.apache.flink.addons.hbase.TableInputSplit
-
Returns the table name.
- getTables() - Method in class org.apache.flink.table.client.config.Environment
-
- getTableSchema() - Method in class org.apache.flink.addons.hbase.HBaseTableSource
-
- getTableSchema() - Method in class org.apache.flink.orc.OrcTableSource
-
- getTableSchema() - Method in class org.apache.flink.sql.tests.StreamSQLTestProgram.GeneratorTableSource
-
- getTableSchema() - Method in class org.apache.flink.streaming.connectors.kafka.KafkaTableSource.Builder
-
Returns the configured table schema.
- getTableSchema() - Method in class org.apache.flink.streaming.connectors.kafka.KafkaTableSource
-
- getTableSchema(SessionContext, String) - Method in interface org.apache.flink.table.client.gateway.Executor
-
Returns the schema of a table.
- getTableSchema(SessionContext, String) - Method in class org.apache.flink.table.client.gateway.local.LocalExecutor
-
- getTableSink() - Method in class org.apache.flink.table.client.gateway.local.CollectStreamResult
-
- getTableSink() - Method in interface org.apache.flink.table.client.gateway.local.DynamicResult
-
Returns the table sink required by this result type.
- getTag() - Method in class org.apache.flink.api.java.sca.TaggedValue
-
- getTags() - Method in class org.apache.flink.metrics.datadog.DMetric
-
- getTarget() - Method in class org.apache.flink.graph.Edge
-
- getTarget() - Method in class org.apache.flink.optimizer.dag.DagConnection
-
Gets the target of the connection.
- getTarget() - Method in class org.apache.flink.optimizer.plan.Channel
-
Gets the target of this Channel.
- getTarget() - Method in class org.apache.flink.runtime.executiongraph.ExecutionEdge
-
- getTarget() - Method in class org.apache.flink.runtime.jobgraph.JobEdge
-
Returns the vertex connected to this edge.
- getTargetAddress() - Method in class org.apache.flink.runtime.registration.RegisteredRpcConnection
-
- getTargetAddress() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.PendingSlotRequest
-
- getTargetAddress() - Method in class org.apache.flink.runtime.resourcemanager.SlotRequest
-
- getTargetDirectory() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointTriggerRequestBody
-
- getTargetEdgeValue() - Method in class org.apache.flink.graph.bipartite.Projection
-
- getTargetGateway() - Method in class org.apache.flink.runtime.registration.RegisteredRpcConnection
-
Gets the RegisteredGateway.
- getTargetId() - Method in class org.apache.flink.streaming.api.graph.StreamEdge
-
- getTargetLeaderId() - Method in class org.apache.flink.runtime.registration.RegisteredRpcConnection
-
- getTargetLocation() - Method in class org.apache.flink.runtime.checkpoint.CheckpointOptions
-
Returns the target location for the checkpoint.
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingStatusHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingTriggerHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.handler.legacy.files.LogFileHandlerSpecification
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.handler.legacy.files.StdoutFileHandlerSpecification
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.handler.legacy.files.WebContentHandlerSpecification
-
- getTargetRestEndpointURL() - Method in interface org.apache.flink.runtime.rest.handler.RestHandlerSpecification
-
Returns the generalized endpoint url that this request should be sent to, for example /job/:jobid
.
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatisticsHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatisticDetailsHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.cluster.ShutdownHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.ClusterConfigurationInfoHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.ClusterOverviewHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.DashboardConfigurationHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.job.JobExecutionResultHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.job.JobSubmitHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AbstractMetricsHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedJobMetricsHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedSubtaskMetricsHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedTaskManagerMetricsHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.JobManagerMetricsHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.JobMetricsHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.JobVertexMetricsHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.SubtaskMetricsHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.TaskManagerMetricsHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalStatusHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalTriggerHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointStatusHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointTriggerHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskCurrentAttemptDetailsHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptAccumulatorsHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.JobAccumulatorsHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.JobConfigHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.JobExceptionsHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.JobIdsWithStatusesOverviewHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.JobPlanHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.JobsOverviewHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.JobTerminationHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.JobVertexAccumulatorsHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.JobVertexBackPressureHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.JobVertexDetailsHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.JobVertexTaskManagersHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.SubtasksAllAccumulatorsHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.SubtasksTimesHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerDetailsHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerLogFileHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagersHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerStdoutFileHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.YarnCancelJobTerminationHeaders
-
Deprecated.
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.YarnStopJobTerminationHeaders
-
Deprecated.
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.webmonitor.handlers.JarDeleteHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.webmonitor.handlers.JarListHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.webmonitor.handlers.JarPlanHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.webmonitor.handlers.JarRunHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.webmonitor.handlers.JarUploadHeaders
-
- getTargetSlotNumber() - Method in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
-
Gets the number of the slot into which the task is to be deployed.
- getTargetState() - Method in class org.apache.flink.cep.nfa.StateTransition
-
- getTargetTopic(T) - Method in interface org.apache.flink.streaming.util.serialization.KeyedSerializationSchema
-
Optional method to determine the target topic for the element.
- getTargetTopic(T) - Method in class org.apache.flink.streaming.util.serialization.KeyedSerializationSchemaWrapper
-
- getTargetTopic(Tuple2<K, V>) - Method in class org.apache.flink.streaming.util.serialization.TypeInformationKeyValueSerializationSchema
-
- getTargetVertex() - Method in class org.apache.flink.streaming.api.graph.StreamEdge
-
- getTargetVertexValue() - Method in class org.apache.flink.graph.bipartite.Projection
-
- getTask() - Method in class org.apache.flink.examples.java.distcp.FileCopyTaskInputSplit
-
- getTask(ExecutionAttemptID) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
-
Get the task for the given execution attempt id.
- getTaskAssignment() - Method in class org.apache.flink.runtime.jobmanager.scheduler.SlotSharingGroup
-
- getTaskCancellationInterval() - Method in class org.apache.flink.api.common.ExecutionConfig
-
Gets the interval (in milliseconds) between consecutive attempts to cancel a running task.
- getTaskCancellationTimeout() - Method in class org.apache.flink.api.common.ExecutionConfig
-
Returns the timeout (in milliseconds) after which an ongoing task
cancellation leads to a fatal TaskManager error.
- getTaskConfig() - Method in class org.apache.flink.runtime.operators.BatchTask
-
- getTaskConfig() - Method in class org.apache.flink.runtime.operators.chaining.ChainedDriver
-
- getTaskConfig() - Method in interface org.apache.flink.runtime.operators.TaskContext
-
- getTaskConfiguration() - Method in interface org.apache.flink.runtime.execution.Environment
-
Returns the task-wide configuration object, originally attached to the job vertex.
- getTaskConfiguration() - Method in class org.apache.flink.runtime.executiongraph.TaskInformation
-
- getTaskConfiguration() - Method in class org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
-
Returns the task configuration object which was attached to the original
JobVertex
.
- getTaskConfiguration() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
-
- getTaskConfiguration() - Method in class org.apache.flink.runtime.taskmanager.Task
-
- getTaskEventDispatcher() - Method in interface org.apache.flink.runtime.execution.Environment
-
- getTaskEventDispatcher() - Method in class org.apache.flink.runtime.io.network.NetworkEnvironment
-
- getTaskEventDispatcher() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
-
- getTaskExecutionId() - Method in class org.apache.flink.runtime.messages.checkpoint.AbstractCheckpointMessage
-
- getTaskExecutorGateway() - Method in class org.apache.flink.runtime.resourcemanager.registration.TaskExecutorConnection
-
- getTaskFormat() - Method in class org.apache.flink.runtime.metrics.scope.ScopeFormats
-
- getTaskInfo() - Method in interface org.apache.flink.runtime.execution.Environment
-
Returns the
TaskInfo
object associated with this subtask
- getTaskInfo() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
-
- getTaskInfo() - Method in class org.apache.flink.runtime.taskmanager.Task
-
- getTaskInformationOrBlobKey() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
- getTaskKvStateRegistry() - Method in interface org.apache.flink.runtime.execution.Environment
-
- getTaskKvStateRegistry() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
-
- getTaskLocalSnapshot() - Method in class org.apache.flink.runtime.state.SnapshotResult
-
- getTaskLocalState() - Method in class org.apache.flink.streaming.api.operators.OperatorSnapshotFinalizer
-
- getTaskManagerActions() - Method in class org.apache.flink.runtime.taskexecutor.JobManagerConnection
-
- getTaskManagerAddress() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
-
- getTaskManagerBindAddress() - Method in class org.apache.flink.runtime.minicluster.MiniClusterConfiguration
-
- getTaskManagerClass() - Method in class org.apache.flink.yarn.YarnApplicationMasterRunner
-
- getTaskManagerConnection() - Method in class org.apache.flink.runtime.clusterframework.types.TaskManagerSlot
-
- getTaskManagerConnection() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerRegistration
-
- getTaskManagerFormat() - Method in class org.apache.flink.runtime.metrics.scope.ScopeFormats
-
- getTaskManagerGateway() - Method in class org.apache.flink.runtime.instance.Instance
-
Returns the InstanceGateway of this Instance.
- getTaskManagerGateway() - Method in class org.apache.flink.runtime.instance.SimpleSlotContext
-
- getTaskManagerGateway() - Method in class org.apache.flink.runtime.instance.Slot
-
Gets the actor gateway that can be used to send messages to the TaskManager.
- getTaskManagerGateway() - Method in interface org.apache.flink.runtime.jobmaster.LogicalSlot
-
Return the TaskManager gateway to talk to the TaskManager.
- getTaskManagerGateway() - Method in interface org.apache.flink.runtime.jobmaster.SlotContext
-
Gets the actor gateway that can be used to send messages to the TaskManager.
- getTaskManagerGateway() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SingleLogicalSlot
-
- getTaskManagerHostname() - Method in class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManagerParameters
-
Get the taskManager hostname.
- getTaskManagerID() - Method in class org.apache.flink.runtime.instance.Instance
-
- getTaskManagerID() - Method in class org.apache.flink.runtime.instance.Slot
-
Gets the ID of the TaskManager that offers this slot.
- getTaskManagerInfo() - Method in interface org.apache.flink.runtime.execution.Environment
-
Gets the task manager info, with configuration and hostname.
- getTaskManagerInfo() - Method in class org.apache.flink.runtime.operators.BatchTask
-
- getTaskManagerInfo() - Method in interface org.apache.flink.runtime.operators.TaskContext
-
- getTaskManagerInfo() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
-
- getTaskManagerInfos() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagersInfo
-
- getTaskManagerJobFormat() - Method in class org.apache.flink.runtime.metrics.scope.ScopeFormats
-
- getTaskManagerLocation() - Method in class org.apache.flink.runtime.instance.Instance
-
- getTaskManagerLocation() - Method in class org.apache.flink.runtime.instance.SimpleSlotContext
-
- getTaskManagerLocation() - Method in class org.apache.flink.runtime.instance.Slot
-
Gets the location info of the TaskManager that offers this slot.
- getTaskManagerLocation() - Method in interface org.apache.flink.runtime.jobmaster.LogicalSlot
-
Return the TaskManager location of this slot.
- getTaskManagerLocation() - Method in interface org.apache.flink.runtime.jobmaster.SlotContext
-
Gets the location info of the TaskManager that offers this slot.
- getTaskManagerLocation() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SingleLogicalSlot
-
- getTaskManagerLocation() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServices
-
- getTaskManagerLocationFuture() - Method in class org.apache.flink.runtime.executiongraph.Execution
-
- getTaskManagerLogPath() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
-
- getTaskManagerMemoryMB() - Method in class org.apache.flink.client.deployment.ClusterSpecification
-
- getTaskManagerMetricStore(String) - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.MetricStore
-
- getTaskManagerNumSlots() - Method in class org.apache.flink.client.LocalExecutor
-
- getTaskManagerRequestTimeout() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerConfiguration
-
- getTaskManagers() - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.MetricStore
-
- getTaskManagerShellCommand(Configuration, ContaineredTaskManagerParameters, String, String, boolean, boolean, boolean, Class<?>) - Static method in class org.apache.flink.runtime.clusterframework.BootstrapTools
-
Generates the shell command to start a task manager.
- getTaskManagerStateStore() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServices
-
- getTaskManagerStdoutPath() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
-
- getTaskManagerTimeout() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerConfiguration
-
- getTaskMetricStore(String, String) - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.MetricStore
-
- getTaskName() - Method in interface org.apache.flink.api.common.functions.RuntimeContext
-
Returns the name of the task in which the UDF runs, as assigned during plan construction.
- getTaskName() - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
-
- getTaskName() - Method in class org.apache.flink.api.common.TaskInfo
-
Returns the name of the task
- getTaskName() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- getTaskName() - Method in class org.apache.flink.runtime.executiongraph.TaskInformation
-
- getTaskName() - Method in class org.apache.flink.runtime.operators.chaining.ChainedAllReduceDriver
-
- getTaskName() - Method in class org.apache.flink.runtime.operators.chaining.ChainedDriver
-
- getTaskName() - Method in class org.apache.flink.runtime.operators.chaining.ChainedFlatMapDriver
-
- getTaskName() - Method in class org.apache.flink.runtime.operators.chaining.ChainedMapDriver
-
- getTaskName() - Method in class org.apache.flink.runtime.operators.chaining.ChainedReduceCombineDriver
-
- getTaskName() - Method in class org.apache.flink.runtime.operators.chaining.ChainedTerminationCriterionDriver
-
- getTaskName() - Method in exception org.apache.flink.runtime.operators.chaining.ExceptionInChainedStubException
-
- getTaskName() - Method in class org.apache.flink.runtime.operators.chaining.GroupCombineChainedDriver
-
- getTaskName() - Method in class org.apache.flink.runtime.operators.chaining.SynchronousChainedCombineDriver
-
- getTaskName() - Method in class org.apache.flink.runtime.operators.NoOpChainedDriver
-
- getTaskName() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getTaskNameWithSubtaskIndex() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionVertex
-
Returns the name of this execution vertex in the format "myTask (2/7)".
- getTaskNameWithSubtaskIndex() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionVertex
-
- getTaskNameWithSubtaskIndex() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- getTaskNameWithSubtasks() - Method in interface org.apache.flink.api.common.functions.RuntimeContext
-
- getTaskNameWithSubtasks() - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
-
- getTaskNameWithSubtasks() - Method in class org.apache.flink.api.common.TaskInfo
-
- getTaskOwnedStateDirectory() - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStorageLocation
-
- getTaskRestore() - Method in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
-
- getTaskRestore() - Method in class org.apache.flink.runtime.executiongraph.Execution
-
- getTasks() - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlot
-
Get all tasks running in this task slot.
- getTasks(JobID) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
-
Return an iterator over all tasks for a given job.
- getTaskSlotTable() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServices
-
- getTasksPerState() - Method in class org.apache.flink.runtime.messages.webmonitor.JobDetails
-
- getTasksPerState() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
-
- getTaskStateManager() - Method in interface org.apache.flink.runtime.execution.Environment
-
- getTaskStateManager() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
-
- getTaskStates() - Method in interface org.apache.flink.runtime.checkpoint.savepoint.Savepoint
-
- getTaskStates() - Method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV1
-
- getTaskStates() - Method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV2
-
- getTaskStateSnapshot() - Method in class org.apache.flink.runtime.checkpoint.JobManagerTaskRestore
-
- getTaskStateStats(JobVertexID) - Method in class org.apache.flink.runtime.checkpoint.AbstractCheckpointStats
-
Returns the task state stats for the given job vertex ID or
null
if no task with such an ID is available.
- getTaskToExecute() - Method in class org.apache.flink.runtime.jobmanager.scheduler.ScheduledUnit
-
- getTaskVertices() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionJobVertex
-
Returns all execution vertices for this job vertex.
- getTaskVertices() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionJobVertex
-
- getTaskVertices() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
- getTebiBytes() - Method in class org.apache.flink.configuration.MemorySize
-
Gets the memory size in Tebibytes (= 1024 Gibibytes).
- getTempDir() - Static method in class org.apache.flink.core.testutils.CommonTestUtils
-
Reads the path to the directory for temporary files from the configuration and returns it.
- getTempDirPath(String) - Method in class org.apache.flink.test.util.AbstractTestBase
-
- getTempFilePath(String) - Method in class org.apache.flink.test.util.AbstractTestBase
-
- getTemplateType(Class<?>, int) - Static method in class org.apache.flink.util.ReflectionUtil
-
- getTemplateType(Class<?>, Class<?>, int) - Static method in class org.apache.flink.util.ReflectionUtil
-
- getTemplateType1(Class<?>) - Static method in class org.apache.flink.util.ReflectionUtil
-
- getTemplateType1(Type) - Static method in class org.apache.flink.util.ReflectionUtil
-
- getTemplateType2(Class<?>) - Static method in class org.apache.flink.util.ReflectionUtil
-
- getTemplateType3(Class<?>) - Static method in class org.apache.flink.util.ReflectionUtil
-
- getTemplateType4(Class<?>) - Static method in class org.apache.flink.util.ReflectionUtil
-
- getTemplateType5(Class<?>) - Static method in class org.apache.flink.util.ReflectionUtil
-
- getTemplateType6(Class<?>) - Static method in class org.apache.flink.util.ReflectionUtil
-
- getTemplateType7(Class<?>) - Static method in class org.apache.flink.util.ReflectionUtil
-
- getTemplateType8(Class<?>) - Static method in class org.apache.flink.util.ReflectionUtil
-
- getTemplateTypeInfos() - Method in class org.apache.flink.util.ReflectionUtil.FullTypeInfo
-
- getTemplateTypes(ParameterizedType) - Static method in class org.apache.flink.util.ReflectionUtil
-
- getTemplateTypes(Class<?>) - Static method in class org.apache.flink.util.ReflectionUtil
-
- getTempMode() - Method in class org.apache.flink.optimizer.plan.Channel
-
- getTemporaryFileDirectory() - Static method in class org.apache.flink.runtime.util.EnvironmentInformation
-
Gets the directory for temporary files, as returned by the JVM system property "java.io.tmpdir".
- getTerminal() - Method in class org.apache.flink.table.client.cli.CliClient
-
- getTerminalStateFuture() - Method in class org.apache.flink.runtime.executiongraph.Execution
-
Gets a future that completes once the task execution reaches a terminal state.
- getTerminalStateFuture() - Method in interface org.apache.flink.runtime.jobmaster.LogicalSlot.Payload
-
Gets the terminal state future which is completed once the payload
has reached a terminal state.
- getTerminationCriterion() - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase
-
- getTerminationCriterion() - Method in class org.apache.flink.api.java.operators.BulkIterationResultSet
-
- getTerminationFuture() - Method in class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
-
- getTerminationFuture() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- getTerminationFuture() - Method in class org.apache.flink.runtime.rpc.akka.AkkaRpcService
-
- getTerminationFuture() - Method in class org.apache.flink.runtime.rpc.RpcEndpoint
-
Return a future which is completed with true when the rpc endpoint has been terminated.
- getTerminationFuture() - Method in interface org.apache.flink.runtime.rpc.RpcServer
-
Return a future which is completed when the rpc endpoint has been terminated.
- getTerminationFuture() - Method in interface org.apache.flink.runtime.rpc.RpcService
-
Returns a future indicating when the RPC service has been shut down.
- getTerminationFuture() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerRunner
-
- getTestEnvironment() - Method in class org.apache.flink.test.util.MiniClusterResource
-
- getTestKeytab() - Static method in class org.apache.flink.test.util.SecureTestEnvironment
-
- getTheta0() - Method in class org.apache.flink.examples.java.ml.LinearRegression.Params
-
- getTheta1() - Method in class org.apache.flink.examples.java.ml.LinearRegression.Params
-
- getThirdVertex() - Method in class org.apache.flink.graph.library.TriangleEnumerator.Triad
-
- getTieEdgeDataSet(ExecutionEnvironment) - Static method in class org.apache.flink.graph.examples.data.CommunityDetectionData
-
- getTieEdgeDataSet(ExecutionEnvironment) - Static method in class org.apache.flink.graph.examples.data.LabelPropagationData
-
- getTieVertexSet(ExecutionEnvironment) - Static method in class org.apache.flink.graph.examples.data.LabelPropagationData
-
- getTimeCharacteristic() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getTimeCharacteristic() - Method in class org.apache.flink.table.client.config.Execution
-
- getTimeDuration(String, long, TimeUnit) - Method in class org.apache.hadoop.conf.Configuration
-
Return time duration in the given time unit.
- getTimeDurations(String, TimeUnit) - Method in class org.apache.hadoop.conf.Configuration
-
- getTimeNanos() - Method in class org.apache.flink.runtime.rpc.messages.RunAsync
-
- getTimeout() - Method in class org.apache.flink.runtime.client.JobListeningContext
-
- getTimeout() - Method in class org.apache.flink.runtime.resourcemanager.ResourceManagerConfiguration
-
- getTimeout() - Method in class org.apache.flink.runtime.rest.handler.RestHandlerConfiguration
-
- getTimeout() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
-
- getTimerServiceShutdownTimeout() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
-
- getTimes() - Method in class org.apache.flink.cep.pattern.Pattern
-
- getTimestamp() - Method in class org.apache.flink.cep.nfa.ComputationState
-
- getTimestamp() - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetaData
-
- getTimestamp() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
-
- getTimestamp() - Method in class org.apache.flink.runtime.executiongraph.ErrorInfo
-
Returns the timestamp for the contained exception.
- getTimestamp() - Method in class org.apache.flink.runtime.io.network.api.CheckpointBarrier
-
- getTimestamp() - Method in class org.apache.flink.runtime.messages.checkpoint.NotifyCheckpointComplete
-
- getTimestamp() - Method in class org.apache.flink.runtime.messages.checkpoint.TriggerCheckpoint
-
- getTimestamp() - Method in interface org.apache.flink.streaming.api.operators.async.queue.AsyncCollectionResult
-
- getTimestamp() - Method in class org.apache.flink.streaming.api.operators.async.queue.StreamRecordQueueEntry
-
- getTimestamp() - Method in class org.apache.flink.streaming.api.operators.InternalTimer
-
- getTimestamp() - Method in class org.apache.flink.streaming.api.watermark.Watermark
-
Returns the timestamp associated with this
Watermark
in milliseconds.
- getTimestamp() - Method in class org.apache.flink.streaming.connectors.wikiedits.WikipediaEditEvent
-
Returns the timestamp when this event arrived at the source.
- getTimestamp() - Method in class org.apache.flink.streaming.examples.kafka.KafkaEvent
-
- getTimestamp() - Method in class org.apache.flink.streaming.runtime.operators.windowing.TimestampedValue
-
- getTimestamp() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecord
-
Returns the timestamp associated with this stream value in milliseconds.
- getTimestampForRecord(T, long) - Method in class org.apache.flink.streaming.connectors.kafka.internals.KafkaTopicPartitionStateWithPeriodicWatermarks
-
- getTimestampForRecord(T, long) - Method in class org.apache.flink.streaming.connectors.kafka.internals.KafkaTopicPartitionStateWithPunctuatedWatermarks
-
- getTimestamps() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
-
- getTimeZone(Calendar) - Static method in class org.apache.calcite.avatica.util.DateTimeUtils
-
Gets the active time zone based on a Calendar argument
- getTimeZoneName() - Method in class org.apache.flink.runtime.rest.messages.DashboardConfiguration
-
- getTimeZoneOffset() - Method in class org.apache.flink.runtime.rest.messages.DashboardConfiguration
-
- getTitle() - Method in class org.apache.flink.streaming.connectors.wikiedits.WikipediaEditEvent
-
- getTitle() - Method in class org.apache.flink.table.client.cli.CliChangelogResultView
-
- getTitle() - Method in class org.apache.flink.table.client.cli.CliInputView
-
- getTitle() - Method in class org.apache.flink.table.client.cli.CliRowView
-
- getTitle() - Method in class org.apache.flink.table.client.cli.CliTableResultView
-
- getTitle() - Method in class org.apache.flink.table.client.cli.CliView
-
- getTitleLine() - Method in class org.apache.flink.table.client.cli.CliView
-
- getTmpDirectories() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
-
- getTmpDirectories() - Method in interface org.apache.flink.runtime.taskmanager.TaskManagerRuntimeInfo
-
Gets the list of temporary file directories.
- getTmpDirectory() - Method in class org.apache.flink.runtime.jobmaster.JobMasterConfiguration
-
- getTmpDirPaths() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
-
- getTo() - Method in class org.apache.flink.cep.pattern.Quantifier.Times
-
- getTo() - Method in class org.apache.flink.util.LongValueSequenceIterator
-
- getTo() - Method in class org.apache.flink.util.NumberSequenceIterator
-
- getTopic() - Method in class org.apache.flink.streaming.connectors.kafka.internals.KafkaTopicPartition
-
- getTopic() - Method in class org.apache.flink.streaming.connectors.kafka.internals.KafkaTopicPartitionState
-
- getTopic() - Method in class org.apache.flink.streaming.connectors.kafka.KafkaTableSource.Builder
-
Returns the configured topic.
- getTopicPartition() - Method in class org.apache.flink.streaming.connectors.kafka.internals.KafkaTopicPartitionLeader
-
- getTopicPattern() - Method in class org.apache.flink.streaming.connectors.kafka.internals.KafkaTopicsDescriptor
-
- getTopId() - Method in class org.apache.flink.graph.bipartite.BipartiteEdge
-
- getTopology(String) - Method in class org.apache.flink.storm.api.FlinkLocalCluster
-
- getTopologyConf(String) - Method in class org.apache.flink.storm.api.FlinkLocalCluster
-
- getTopologyInfo(String) - Method in class org.apache.flink.storm.api.FlinkLocalCluster
-
- getTopVertices() - Method in class org.apache.flink.graph.bipartite.BipartiteGraph
-
Get dataset with top vertices.
- getTotalCount() - Method in class org.apache.flink.api.java.summarize.ColumnSummary
-
The number of all rows in this column including both nulls and non-nulls.
- getTotalFields() - Method in class org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
-
- getTotalFields() - Method in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
-
- getTotalFields() - Method in class org.apache.flink.api.common.typeinfo.NothingTypeInfo
-
- getTotalFields() - Method in class org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
-
- getTotalFields() - Method in class org.apache.flink.api.common.typeinfo.SqlTimeTypeInfo
-
- getTotalFields() - Method in class org.apache.flink.api.common.typeinfo.TypeInformation
-
Gets the number of logical fields in this type.
- getTotalFields() - Method in class org.apache.flink.api.java.typeutils.EitherTypeInfo
-
- getTotalFields() - Method in class org.apache.flink.api.java.typeutils.EnumTypeInfo
-
- getTotalFields() - Method in class org.apache.flink.api.java.typeutils.GenericTypeInfo
-
- getTotalFields() - Method in class org.apache.flink.api.java.typeutils.ListTypeInfo
-
- getTotalFields() - Method in class org.apache.flink.api.java.typeutils.MapTypeInfo
-
- getTotalFields() - Method in class org.apache.flink.api.java.typeutils.MissingTypeInfo
-
- getTotalFields() - Method in class org.apache.flink.api.java.typeutils.ObjectArrayTypeInfo
-
- getTotalFields() - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo
-
- getTotalFields() - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfoBase
-
- getTotalFields() - Method in class org.apache.flink.api.java.typeutils.ValueTypeInfo
-
- getTotalFields() - Method in class org.apache.flink.api.java.typeutils.WritableTypeInfo
-
- getTotalFields() - Method in class org.apache.flink.graph.drivers.transform.LongValueWithProperHashCode.LongValueWithProperHashCodeTypeInfo
-
- getTotalFields() - Method in class org.apache.flink.graph.types.valuearray.ValueArrayTypeInfo
-
- getTotalFields() - Method in class org.apache.flink.queryablestate.client.VoidNamespaceTypeInfo
-
- getTotalFields() - Method in class org.apache.flink.runtime.state.VoidNamespaceTypeInfo
-
- getTotalInputSize() - Method in class org.apache.flink.api.common.io.FileInputFormat.FileBaseStatistics
-
Gets the file size.
- getTotalInputSize() - Method in interface org.apache.flink.api.common.io.statistics.BaseStatistics
-
Gets the total size of the input.
- getTotalMainWidth() - Method in class org.apache.flink.table.client.cli.CliView
-
- getTotalNumberCheckpoints() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.Counts
-
- getTotalNumberOfBuffers() - Method in class org.apache.flink.runtime.io.network.partition.ResultSubpartition
-
- getTotalNumberOfBytes() - Method in class org.apache.flink.runtime.io.network.partition.ResultSubpartition
-
- getTotalNumberOfCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.CheckpointStatsCounts
-
Returns the total number of checkpoints (in progress, completed, failed).
- getTotalNumberOfMemorySegments() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
-
- getTotalNumberOfOpenStreams() - Method in class org.apache.flink.core.fs.LimitedConnectionsFileSystem
-
Gets the total number of open streams (input plus output).
- getTotalNumberOfParallelSubtasks() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- getTotalNumberOfSlots() - Method in class org.apache.flink.runtime.instance.Instance
-
- getTotalNumberOfSlots() - Method in class org.apache.flink.runtime.instance.InstanceManager
-
- getTotalNumberOfSlots() - Method in class org.apache.flink.runtime.jobmanager.scheduler.Scheduler
-
- getTotalNumberOfSplits() - Method in class org.apache.flink.core.io.GenericInputSplit
-
- getTotalNumberOfVertices() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- getTotalNumPages() - Method in class org.apache.flink.runtime.memory.MemoryManager
-
Gets the total number of memory pages managed by this memory manager.
- getTransactionalId() - Method in class org.apache.flink.streaming.connectors.kafka.internal.FlinkKafkaProducer
-
- getTransactionCoordinatorId() - Method in class org.apache.flink.streaming.connectors.kafka.internal.FlinkKafkaProducer
-
- getTransformation() - Method in class org.apache.flink.streaming.api.datastream.BroadcastStream
-
- getTransformation() - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
- getTransformation() - Method in class org.apache.flink.streaming.api.datastream.DataStreamSink
-
Returns the transformation that contains the actual sink operator of this sink.
- getTransformation() - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer010.FlinkKafkaProducer010Configuration
-
Deprecated.
- getTransformationUID() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getTransformers() - Method in class org.apache.flink.graph.drivers.input.GeneratedGraph
-
- getTransformers() - Method in interface org.apache.flink.graph.drivers.transform.Transformable
-
Get the list of transforms.
- getTransientBlobService() - Method in class org.apache.flink.runtime.blob.BlobCacheService
-
- getTransientBlobService() - Method in class org.apache.flink.runtime.blob.BlobServer
-
- getTransientBlobService() - Method in interface org.apache.flink.runtime.blob.BlobService
-
Returns a BLOB service for accessing transient BLOBs.
- getTransitiveChainedTaskConfigs(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getTransitiveChainedTaskConfigsWithSelf(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getTransitivePredecessors() - Method in class org.apache.flink.streaming.api.transformations.CoFeedbackTransformation
-
- getTransitivePredecessors() - Method in class org.apache.flink.streaming.api.transformations.FeedbackTransformation
-
- getTransitivePredecessors() - Method in class org.apache.flink.streaming.api.transformations.OneInputTransformation
-
- getTransitivePredecessors() - Method in class org.apache.flink.streaming.api.transformations.PartitionTransformation
-
- getTransitivePredecessors() - Method in class org.apache.flink.streaming.api.transformations.SelectTransformation
-
- getTransitivePredecessors() - Method in class org.apache.flink.streaming.api.transformations.SideOutputTransformation
-
- getTransitivePredecessors() - Method in class org.apache.flink.streaming.api.transformations.SinkTransformation
-
- getTransitivePredecessors() - Method in class org.apache.flink.streaming.api.transformations.SourceTransformation
-
- getTransitivePredecessors() - Method in class org.apache.flink.streaming.api.transformations.SplitTransformation
-
- getTransitivePredecessors() - Method in class org.apache.flink.streaming.api.transformations.StreamTransformation
-
Returns all transitive predecessor StreamTransformation
s of this StreamTransformation
.
- getTransitivePredecessors() - Method in class org.apache.flink.streaming.api.transformations.TwoInputTransformation
-
- getTransitivePredecessors() - Method in class org.apache.flink.streaming.api.transformations.UnionTransformation
-
- getTransportType() - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
-
- getTrgVertex() - Method in class org.apache.flink.graph.Triplet
-
- getTriangleCount() - Method in class org.apache.flink.graph.library.clustering.directed.LocalClusteringCoefficient.Result
-
Get the number of triangles containing this vertex; equivalently,
this is the number of edges between neighbors of this vertex.
- getTriangleCount() - Method in class org.apache.flink.graph.library.clustering.undirected.LocalClusteringCoefficient.Result
-
Get the number of triangles containing this vertex; equivalently,
this is the number of edges between neighbors of this vertex.
- getTrigger() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
- getTriggerHandler() - Method in class org.apache.flink.runtime.rest.handler.legacy.JobCancellationWithSavepointHandlers
-
- getTriggerId() - Method in class org.apache.flink.runtime.rest.handler.async.OperationKey
-
Get the trigger id for the given operation key.
- getTriggerId() - Method in class org.apache.flink.runtime.rest.handler.async.TriggerResponse
-
- getTriggerTimestamp() - Method in class org.apache.flink.runtime.checkpoint.AbstractCheckpointStats
-
Returns the timestamp when the checkpoint was triggered.
- getTriggerTimestamp() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
-
- getTrimmed(String) - Method in class org.apache.hadoop.conf.Configuration
-
Get the value of the name
property as a trimmed String
,
null
if no such property exists.
- getTrimmed(String, String) - Method in class org.apache.hadoop.conf.Configuration
-
Get the value of the name
property as a trimmed String
,
defaultValue
if no such property exists.
- getTrimmedStringCollection(String) - Method in class org.apache.hadoop.conf.Configuration
-
Get the comma delimited values of the name
property as
a collection of String
s, trimmed of the leading and trailing whitespace.
- getTrimmedStrings(String) - Method in class org.apache.hadoop.conf.Configuration
-
Get the comma delimited values of the name
property as
an array of String
s, trimmed of the leading and trailing whitespace.
- getTrimmedStrings(String, String...) - Method in class org.apache.hadoop.conf.Configuration
-
Get the comma delimited values of the name
property as
an array of String
s, trimmed of the leading and trailing whitespace.
- getTriplets() - Method in class org.apache.flink.graph.Graph
-
This method allows access to the graph's edge values along with its source and target vertex values.
- getTrueArray(int) - Static method in class org.apache.flink.optimizer.plan.SingleInputPlanNode
-
- getTrueCount() - Method in class org.apache.flink.api.java.summarize.BooleanColumnSummary
-
- getTupleClass(int) - Static method in class org.apache.flink.api.java.tuple.Tuple
-
Gets the class corresponding to the tuple of the given arity (dimensions).
- getTupleClass() - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializerBase
-
- getTupleClass() - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializerConfigSnapshot
-
- getTwo() - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.TaggedUnion
-
- getTwoInputNode() - Method in class org.apache.flink.optimizer.plan.DualInputPlanNode
-
- getType(int) - Method in class org.apache.flink.api.common.operators.Ordering
-
- getType() - Method in class org.apache.flink.api.common.state.AggregatingStateDescriptor
-
- getType() - Method in class org.apache.flink.api.common.state.FoldingStateDescriptor
-
Deprecated.
- getType() - Method in class org.apache.flink.api.common.state.ListStateDescriptor
-
- getType() - Method in class org.apache.flink.api.common.state.MapStateDescriptor
-
- getType() - Method in class org.apache.flink.api.common.state.ReducingStateDescriptor
-
- getType() - Method in class org.apache.flink.api.common.state.StateDescriptor
-
- getType() - Method in class org.apache.flink.api.common.state.ValueStateDescriptor
-
- getType() - Method in class org.apache.flink.api.common.typeutils.CompositeType.FlatFieldDescriptor
-
- getType() - Method in class org.apache.flink.api.java.DataSet
-
- getType() - Method in class org.apache.flink.api.java.operators.DataSink
-
- getType() - Method in class org.apache.flink.api.java.utils.Option
-
- getType() - Method in class org.apache.flink.formats.avro.typeutils.AvroSerializer
-
- getType() - Method in class org.apache.flink.metrics.datadog.DMetric
-
- getType() - Method in class org.apache.flink.python.api.types.CustomTypeWrapper
-
- getType() - Method in class org.apache.flink.runtime.accumulators.StringifiedAccumulatorResult
-
- getType() - Method in exception org.apache.flink.runtime.broadcast.InitializationTypeConflictException
-
- getType() - Method in class org.apache.flink.runtime.rest.messages.JobAccumulatorsInfo.UserTaskAccumulator
-
- getType() - Method in class org.apache.flink.streaming.api.datastream.BroadcastStream
-
- getType() - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Gets the type of the stream.
- getType() - Method in class org.apache.flink.table.client.gateway.TypedResult
-
- getType() - Method in class org.apache.flink.table.explain.Node
-
- getType1() - Method in class org.apache.flink.streaming.api.datastream.BroadcastConnectedStream
-
Gets the type of the first input.
- getType1() - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
-
Gets the type of the first input.
- getType2() - Method in class org.apache.flink.streaming.api.datastream.BroadcastConnectedStream
-
Gets the type of the second input.
- getType2() - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
-
Gets the type of the second input.
- getTypeAt(String) - Method in class org.apache.flink.api.common.typeutils.CompositeType
-
Returns the type of the (nested) field at the given field expression position.
- getTypeAt(int) - Method in class org.apache.flink.api.common.typeutils.CompositeType
-
Returns the type of the (unnested) field at the given field position.
- getTypeAt(String) - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo
-
- getTypeAt(int) - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo
-
- getTypeAt(String) - Method in class org.apache.flink.api.java.typeutils.RowTypeInfo
-
- getTypeAt(String) - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfoBase
-
- getTypeAt(int) - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfoBase
-
- getTypeClass() - Method in class org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
-
- getTypeClass() - Method in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
-
- getTypeClass() - Method in class org.apache.flink.api.common.typeinfo.NothingTypeInfo
-
- getTypeClass() - Method in class org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
-
- getTypeClass() - Method in class org.apache.flink.api.common.typeinfo.SqlTimeTypeInfo
-
- getTypeClass() - Method in class org.apache.flink.api.common.typeinfo.TypeInformation
-
Gets the class of the type represented by this type information.
- getTypeClass() - Method in class org.apache.flink.api.common.typeutils.CompositeType
-
Returns the type class of the composite type
- getTypeClass() - Method in class org.apache.flink.api.common.typeutils.GenericTypeSerializerConfigSnapshot
-
- getTypeClass() - Method in class org.apache.flink.api.java.typeutils.EitherTypeInfo
-
- getTypeClass() - Method in class org.apache.flink.api.java.typeutils.EnumTypeInfo
-
- getTypeClass() - Method in class org.apache.flink.api.java.typeutils.GenericTypeInfo
-
- getTypeClass() - Method in class org.apache.flink.api.java.typeutils.ListTypeInfo
-
- getTypeClass() - Method in class org.apache.flink.api.java.typeutils.MapTypeInfo
-
- getTypeClass() - Method in class org.apache.flink.api.java.typeutils.MissingTypeInfo
-
- getTypeClass() - Method in class org.apache.flink.api.java.typeutils.ObjectArrayTypeInfo
-
- getTypeClass() - Method in class org.apache.flink.api.java.typeutils.ValueTypeInfo
-
- getTypeClass() - Method in class org.apache.flink.api.java.typeutils.WritableTypeInfo
-
- getTypeClass() - Method in class org.apache.flink.graph.drivers.transform.LongValueWithProperHashCode.LongValueWithProperHashCodeTypeInfo
-
- getTypeClass() - Method in class org.apache.flink.graph.types.valuearray.ValueArrayTypeInfo
-
- getTypeClass() - Method in class org.apache.flink.queryablestate.client.VoidNamespaceTypeInfo
-
- getTypeClass() - Method in class org.apache.flink.runtime.state.VoidNamespaceTypeInfo
-
- getTypeException() - Method in class org.apache.flink.api.java.typeutils.MissingTypeInfo
-
- getTypeHierarchy(List<Type>, Type, Class<?>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractionUtils
-
Traverses the type hierarchy of a type up until a certain stop class is found.
- getTypeInfo() - Method in class org.apache.flink.api.common.typeinfo.TypeHint
-
Gets the type information described by this TypeHint.
- getTypeInfo() - Method in class org.apache.flink.util.OutputTag
-
- getTypeInfoFactory(Type) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
Returns the type information factory for a type using the factory registry or annotations.
- getTypeInformation() - Method in class org.apache.flink.api.java.typeutils.PojoField
-
- getTypeInfoSize() - Method in class org.apache.flink.python.api.streaming.util.SerializationUtils.Serializer
-
- getTypeInfoSize() - Method in class org.apache.flink.python.api.streaming.util.SerializationUtils.TupleSerializer
-
- getTypeNumber() - Method in class org.apache.flink.streaming.api.graph.StreamEdge
-
- getTypes() - Method in class org.apache.flink.api.common.operators.Ordering
-
- getTypeSerializer() - Method in class org.apache.flink.api.common.typeutils.TypeSerializerSerializationUtil.TypeSerializerSerializationProxy
-
- getTypeSerializerIn1(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getTypeSerializerIn1() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getTypeSerializerIn2(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getTypeSerializerIn2() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getTypeSerializerOut(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getTypeSerializerOut() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getTypeSerializerSideOut(OutputTag<?>, ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getTypeToInstantiate() - Method in class org.apache.flink.api.java.typeutils.runtime.AvroSerializer.AvroSerializerConfigSnapshot
-
Deprecated.
- getTypeToInstantiate() - Method in class org.apache.flink.formats.avro.typeutils.AvroSerializer.AvroSerializerConfigSnapshot
-
Deprecated.
- getUdfRuntimeContext() - Method in class org.apache.flink.runtime.operators.chaining.ChainedDriver
-
- getUid() - Method in class org.apache.flink.streaming.api.transformations.StreamTransformation
-
Returns the user-specified ID of this transformation.
- getUnannouncedCredit() - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
-
Gets the currently unannounced credit.
- getUnaryOperatorReturnType(Function, Class<?>, int, int, int[], int[], TypeInformation<IN>, String, boolean) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
Returns the unary operator's return type.
- getUnavailableResponse() - Static method in class org.apache.flink.runtime.rest.handler.util.HandlerRedirectUtils
-
- getUnchecked() - Method in class org.apache.flink.util.OptionalFailure
-
- getUndirected() - Method in class org.apache.flink.graph.Graph
-
This operation adds all inverse-direction edges to the graph.
- getUnfencedMainThreadExecutor() - Method in class org.apache.flink.runtime.rpc.FencedRpcEndpoint
-
Returns a main thread executor which is not bound to the fencing token.
- getUnguardedFileSystem(URI) - Static method in class org.apache.flink.core.fs.FileSystem
-
- getUnionListState(ListStateDescriptor<S>) - Method in interface org.apache.flink.api.common.state.OperatorStateStore
-
Creates (or restores) a list state.
- getUnionListState(ListStateDescriptor<S>) - Method in class org.apache.flink.runtime.state.DefaultOperatorStateBackend
-
- getUniqueFieldCombination() - Method in class org.apache.flink.optimizer.dataproperties.GlobalProperties
-
- getUniqueFields() - Method in class org.apache.flink.api.common.operators.CompilerHints
-
Gets the FieldSets that are unique
- getUniqueFields() - Method in class org.apache.flink.optimizer.dag.OptimizerNode
-
Gets the FieldSets which are unique in the output of the node.
- getUniqueFields() - Method in class org.apache.flink.optimizer.dataproperties.LocalProperties
-
Gets the fields whose combination is unique within the data set.
- getUniqueInternalName(String) - Method in class org.apache.flink.cep.nfa.compiler.NFAStateNameHandler
-
Used to give a unique name to
NFA
states
created during the translation process.
- getUnit() - Method in class org.apache.flink.api.common.time.Time
-
Gets the time unit for this policy's time interval.
- getUnit() - Method in class org.apache.flink.streaming.api.windowing.time.Time
-
Gets the time unit for this policy's time interval.
- getUnixEpochTimestamp() - Static method in class org.apache.flink.metrics.datadog.DMetric
-
- getUnrequestedParameters() - Method in class org.apache.flink.api.java.utils.ParameterTool
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingStatusHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingTriggerHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatisticsHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatisticDetailsHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.cluster.ShutdownHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.ClusterConfigurationInfoHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.ClusterOverviewHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.DashboardConfigurationHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.job.JobExecutionResultHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.job.JobSubmitHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AbstractMetricsHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedJobMetricsHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedSubtaskMetricsHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedTaskManagerMetricsHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.JobManagerMetricsHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.JobMetricsHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.JobVertexMetricsHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.SubtaskMetricsHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.TaskManagerMetricsHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalStatusHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalTriggerHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointStatusHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointTriggerHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskCurrentAttemptDetailsHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptAccumulatorsHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.JobAccumulatorsHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.JobConfigHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.JobExceptionsHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.JobIdsWithStatusesOverviewHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.JobPlanHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.JobsOverviewHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.JobTerminationHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.JobVertexAccumulatorsHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.JobVertexBackPressureHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.JobVertexDetailsHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.JobVertexTaskManagersHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.SubtasksAllAccumulatorsHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.SubtasksTimesHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerDetailsHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerLogFileHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagersHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerStdoutFileHeaders
-
- getUnresolvedMessageParameters() - Method in interface org.apache.flink.runtime.rest.messages.UntypedResponseMessageHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.webmonitor.handlers.JarDeleteHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.webmonitor.handlers.JarListHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.webmonitor.handlers.JarPlanHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.webmonitor.handlers.JarRunHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.webmonitor.handlers.JarUploadHeaders
-
- getUnsortedGrouping(int) - Method in class org.apache.flink.python.api.util.SetCache
-
- getUntilCondition() - Method in class org.apache.flink.cep.pattern.Pattern
-
- getUploadDir() - Method in class org.apache.flink.runtime.rest.RestServerEndpointConfiguration
-
Returns the directory used to temporarily store multipart/form-data uploads.
- getUploadedFiles() - Method in class org.apache.flink.runtime.rest.handler.FileUploads
-
- getUploadedFiles() - Method in class org.apache.flink.runtime.rest.handler.HandlerRequest
-
- getUpperPart() - Method in class org.apache.flink.util.AbstractID
-
Gets the upper 64 bits of the ID.
- getUri() - Method in class org.apache.flink.core.fs.FileSystem
-
Returns a URI whose scheme and authority identify this file system.
- getUri() - Method in class org.apache.flink.core.fs.LimitedConnectionsFileSystem
-
- getUri() - Method in class org.apache.flink.core.fs.local.LocalFileSystem
-
- getUri() - Method in class org.apache.flink.core.fs.SafetyNetWrapperFileSystem
-
- getUri() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileSystem
-
- getUri() - Method in class org.apache.flink.streaming.connectors.rabbitmq.common.RMQConnectionConfig
-
Retrieve the URI.
- getUsage() - Method in class org.apache.flink.graph.drivers.input.CirculantGraph
-
- getUsage() - Method in class org.apache.flink.graph.drivers.input.GridGraph
-
- getUsage() - Method in class org.apache.flink.graph.drivers.parameter.BooleanParameter
-
- getUsage() - Method in class org.apache.flink.graph.drivers.parameter.ChoiceParameter
-
- getUsage() - Method in class org.apache.flink.graph.drivers.parameter.IterationConvergence
-
- getUsage() - Method in interface org.apache.flink.graph.drivers.parameter.Parameter
-
An informal usage string.
- getUsage() - Method in interface org.apache.flink.graph.drivers.parameter.Parameterized
-
Human-readable format for the command-line usage string.
- getUsage() - Method in class org.apache.flink.graph.drivers.parameter.ParameterizedBase
-
- getUsage() - Method in class org.apache.flink.graph.drivers.parameter.SimpleParameter
-
- getUsage() - Method in class org.apache.flink.graph.drivers.parameter.Simplify
-
- getUseLargeRecordHandler() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getUser() - Method in class org.apache.flink.streaming.connectors.wikiedits.WikipediaEditEvent
-
- getUserAccumulators() - Method in class org.apache.flink.runtime.executiongraph.Execution
-
- getUserAccumulators() - Method in class org.apache.flink.runtime.rest.messages.JobAccumulatorsInfo
-
- getUserAccumulatorsStringified() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecution
-
Returns the user-defined accumulators as strings.
- getUserAccumulatorsStringified() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecution
-
- getUserAccumulatorsStringified() - Method in class org.apache.flink.runtime.executiongraph.Execution
-
- getUserClassLoader() - Method in interface org.apache.flink.runtime.execution.Environment
-
Returns the user code class loader
- getUserClassLoader() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- getUserClassLoader() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
-
- getUserCodeAnnotation(Class<A>) - Method in class org.apache.flink.api.common.operators.util.UserCodeClassWrapper
-
- getUserCodeAnnotation(Class<A>) - Method in class org.apache.flink.api.common.operators.util.UserCodeObjectWrapper
-
- getUserCodeAnnotation(Class<A>) - Method in interface org.apache.flink.api.common.operators.util.UserCodeWrapper
-
Gets an annotation that pertains to the user code class.
- getUserCodeClass() - Method in class org.apache.flink.api.common.operators.util.UserCodeClassWrapper
-
- getUserCodeClass() - Method in class org.apache.flink.api.common.operators.util.UserCodeObjectWrapper
-
- getUserCodeClass() - Method in interface org.apache.flink.api.common.operators.util.UserCodeWrapper
-
Gets the class of the user code.
- getUserCodeClassLoader() - Method in interface org.apache.flink.api.common.functions.RuntimeContext
-
Gets the ClassLoader to load classes that were are not in system's classpath, but are part of the
jar file of a user job.
- getUserCodeClassLoader() - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
-
- getUserCodeClassLoader() - Method in class org.apache.flink.api.common.typeutils.TypeSerializerConfigSnapshot
-
Returns the user code class loader.
- getUserCodeClassLoader() - Method in class org.apache.flink.client.program.ContextEnvironment
-
- getUserCodeClassLoader() - Method in class org.apache.flink.client.program.JobWithJars
-
Gets the
ClassLoader
that must be used to load user code classes.
- getUserCodeClassLoader() - Method in class org.apache.flink.client.program.PackagedProgram
-
Gets the
ClassLoader
that must be used to load user code classes.
- getUserCodeClassLoader() - Method in class org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
-
Returns the user code class loader of this invokable.
- getUserCodeClassLoader() - Method in interface org.apache.flink.runtime.operators.TaskContext
-
- getUserCodeClassloader() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- getUserCodeClassLoaderInfo(ClassLoader) - Static method in class org.apache.flink.runtime.util.ClassLoaderUtil
-
Gets information about URL class loaders.
- getUserCodeObject(Class<? super T>, ClassLoader) - Method in class org.apache.flink.api.common.operators.util.UserCodeClassWrapper
-
- getUserCodeObject() - Method in class org.apache.flink.api.common.operators.util.UserCodeClassWrapper
-
- getUserCodeObject(Class<? super T>, ClassLoader) - Method in class org.apache.flink.api.common.operators.util.UserCodeObjectWrapper
-
- getUserCodeObject() - Method in class org.apache.flink.api.common.operators.util.UserCodeObjectWrapper
-
- getUserCodeObject(Class<? super T>, ClassLoader) - Method in interface org.apache.flink.api.common.operators.util.UserCodeWrapper
-
Gets the user code object, which may be either a function or an input or output format.
- getUserCodeObject() - Method in interface org.apache.flink.api.common.operators.util.UserCodeWrapper
-
Gets the user code object.
- getUserCodeWrapper() - Method in class org.apache.flink.api.common.operators.AbstractUdfOperator
-
Gets the function that is held by this operator.
- getUserCodeWrapper() - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase.PartialSolutionPlaceHolder
-
- getUserCodeWrapper() - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase.SolutionSetPlaceHolder
-
- getUserCodeWrapper() - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase.WorksetPlaceHolder
-
- getUserCodeWrapper() - Method in class org.apache.flink.api.common.operators.GenericDataSinkBase
-
Gets the class describing the output format.
- getUserCodeWrapper() - Method in class org.apache.flink.api.common.operators.GenericDataSourceBase
-
Gets the class describing the input format.
- getUserCodeWrapper() - Method in class org.apache.flink.api.common.operators.Operator
-
Gets the user code wrapper.
- getUserContext() - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
-
- getUserDefinedOperatorIDs() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
Returns a list containing the alternative IDs of all operators contained in this execution job vertex.
- getUserDefinedOperatorIDs() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
- getUserFunction() - Method in class org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
-
Gets the user function executed in this operator.
- getUserFunctionParameters() - Method in class org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
-
Since the streaming API does not implement any parametrization of functions via a
configuration, the config returned here is actually empty.
- getUserHash() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- getUserJarBlobKeys() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
Returns a set of BLOB keys referring to the JAR files required to run this job.
- getUserJars() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
Gets the list of assigned user jar paths.
- getUserMap() - Method in class org.apache.flink.runtime.accumulators.AccumulatorRegistry
-
Gets the map for user-defined accumulators.
- getUsername() - Method in class org.apache.flink.streaming.connectors.rabbitmq.common.RMQConnectionConfig
-
Retrieve the user name.
- getUserProvidedNodeHash() - Method in class org.apache.flink.streaming.api.transformations.StreamTransformation
-
Gets the user provided hash.
- getUserSongTriplets(ExecutionEnvironment) - Static method in class org.apache.flink.graph.examples.data.MusicProfilesData
-
- getValByRegex(String) - Method in class org.apache.hadoop.conf.Configuration
-
get keys matching the the regex
- getValue() - Method in class org.apache.flink.api.common.resources.Resource
-
- getValue(BooleanValue) - Method in class org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator.BooleanValueSummaryAggregator
-
- getValue(DoubleValue) - Method in class org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator.DoubleValueSummaryAggregator
-
- getValue(FloatValue) - Method in class org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator.FloatValueSummaryAggregator
-
- getValue(VT) - Method in class org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator
-
Get the value out of a value type.
- getValue(IntValue) - Method in class org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator.IntegerValueSummaryAggregator
-
- getValue(LongValue) - Method in class org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator.LongValueSummaryAggregator
-
- getValue(ShortValue) - Method in class org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator.ShortValueSummaryAggregator
-
- getValue(StringValue) - Method in class org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator.StringValueSummaryAggregator
-
- getValue(ConfigOption<?>) - Method in class org.apache.flink.configuration.Configuration
-
Returns the value associated with the given config option as a string.
- getValue(ConfigOption<?>) - Method in class org.apache.flink.configuration.DelegatingConfiguration
-
- getValue() - Method in class org.apache.flink.dropwizard.metrics.FlinkGaugeWrapper
-
- getValue() - Method in class org.apache.flink.graph.bipartite.BipartiteEdge
-
- getValue() - Method in class org.apache.flink.graph.drivers.parameter.IterationConvergence
-
- getValue() - Method in interface org.apache.flink.graph.drivers.parameter.Parameter
-
Get the parameter value.
- getValue() - Method in class org.apache.flink.graph.drivers.parameter.SimpleParameter
-
- getValue() - Method in class org.apache.flink.graph.drivers.parameter.Simplify
-
- getValue() - Method in class org.apache.flink.graph.Edge
-
- getValue() - Method in class org.apache.flink.graph.Vertex
-
- getValue() - Method in interface org.apache.flink.metrics.Gauge
-
Calculates and returns the measured value.
- getValue() - Method in interface org.apache.flink.metrics.jmx.JMXReporter.JmxGaugeMBean
-
- getValue() - Method in class org.apache.flink.runtime.accumulators.StringifiedAccumulatorResult
-
- getValue() - Method in class org.apache.flink.runtime.executiongraph.metrics.DownTimeGauge
-
- getValue() - Method in class org.apache.flink.runtime.executiongraph.metrics.NumberOfFullRestartsGauge
-
- getValue() - Method in class org.apache.flink.runtime.executiongraph.metrics.RestartTimeGauge
-
- getValue() - Method in class org.apache.flink.runtime.executiongraph.metrics.UpTimeGauge
-
- getValue() - Method in class org.apache.flink.runtime.rest.messages.ClusterConfigurationInfoEntry
-
- getValue() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.Metric
-
- getValue() - Method in class org.apache.flink.runtime.rest.messages.JobAccumulatorsInfo.UserTaskAccumulator
-
- getValue() - Method in class org.apache.flink.runtime.rest.messages.MessageParameter
-
Returns the resolved value of this parameter, or null
if it isn't resolved yet.
- getValue() - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperSharedValue
-
- getValue() - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperVersionedValue
-
- getValue(int) - Method in class org.apache.flink.storm.wrappers.StormTuple
-
- getValue() - Method in class org.apache.flink.streaming.connectors.fs.AvroKeyValueSinkWriter.AvroKeyValue
-
- getValue() - Method in class org.apache.flink.streaming.connectors.kafka.internal.metrics.KafkaMetricMuttableWrapper
-
- getValue() - Method in class org.apache.flink.streaming.connectors.kafka.internals.metrics.KafkaMetricWrapper
-
- getValue() - Method in class org.apache.flink.streaming.runtime.metrics.MinWatermarkGauge
-
- getValue() - Method in class org.apache.flink.streaming.runtime.metrics.WatermarkGauge
-
- getValue() - Method in class org.apache.flink.streaming.runtime.operators.windowing.KeyMap.Entry
-
- getValue() - Method in class org.apache.flink.streaming.runtime.operators.windowing.TimestampedValue
-
- getValue() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecord
-
Returns the value wrapped in this stream value.
- getValue() - Method in class org.apache.flink.types.BooleanValue
-
- getValue() - Method in class org.apache.flink.types.ByteValue
-
Returns the value of the encapsulated byte.
- getValue() - Method in class org.apache.flink.types.CharValue
-
Returns the value of the encapsulated char.
- getValue() - Method in class org.apache.flink.types.DoubleValue
-
Returns the value of the encapsulated primitive double.
- getValue() - Method in class org.apache.flink.types.FloatValue
-
Returns the value of the encapsulated primitive float.
- getValue() - Method in class org.apache.flink.types.IntValue
-
Returns the value of the encapsulated int.
- getValue() - Method in class org.apache.flink.types.LongValue
-
Returns the value of the encapsulated long.
- getValue() - Method in class org.apache.flink.types.ShortValue
-
Returns the value of the encapsulated short.
- getValue() - Method in class org.apache.flink.types.StringValue
-
Gets this StringValue as a String.
- getValueByField(String) - Method in class org.apache.flink.storm.wrappers.StormTuple
-
- getValueByName(String) - Method in class org.apache.flink.storm.wrappers.StormTuple
-
- getValueClass() - Method in class org.apache.flink.runtime.rest.handler.async.AsynchronousOperationStatusMessageHeaders
-
- getValueClass() - Method in class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingStatusHeaders
-
- getValueClass() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalStatusHeaders
-
- getValueClass() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointStatusHeaders
-
- getValues() - Method in class org.apache.flink.api.common.operators.util.ListKeyGroupedIterator
-
Returns an iterator over all values that belong to the current key.
- getValues() - Method in class org.apache.flink.metrics.HistogramStatistics
-
Returns the elements of the statistics' sample.
- getValues() - Method in class org.apache.flink.runtime.metrics.DescriptiveStatisticsHistogramStatistics
-
- getValues() - Method in interface org.apache.flink.runtime.util.KeyGroupedIterator
-
- getValues() - Method in class org.apache.flink.runtime.util.NonReusingKeyGroupedIterator
-
Returns an iterator over all values that belong to the current key.
- getValues() - Method in class org.apache.flink.runtime.util.ReusingKeyGroupedIterator
-
Returns an iterator over all values that belong to the current key.
- getValues() - Method in class org.apache.flink.storm.wrappers.StormTuple
-
- getValues1() - Method in class org.apache.flink.runtime.operators.sort.NonReusingSortMergeCoGroupIterator
-
- getValues1() - Method in class org.apache.flink.runtime.operators.sort.ReusingSortMergeCoGroupIterator
-
- getValues1() - Method in interface org.apache.flink.runtime.operators.util.CoGroupTaskIterator
-
Returns an iterable over the left input values for the current key.
- getValues2() - Method in class org.apache.flink.runtime.operators.sort.NonReusingSortMergeCoGroupIterator
-
- getValues2() - Method in class org.apache.flink.runtime.operators.sort.ReusingSortMergeCoGroupIterator
-
- getValues2() - Method in interface org.apache.flink.runtime.operators.util.CoGroupTaskIterator
-
Returns an iterable over the left input values for the current key.
- getValueSerializer() - Method in class org.apache.flink.api.common.state.MapStateDescriptor
-
Gets the serializer for the values in the state.
- getValueSerializer() - Method in class org.apache.flink.api.common.typeutils.base.MapSerializer
-
- getValueSerializer() - Method in class org.apache.flink.cep.nfa.SharedBuffer.SharedBufferSerializer
-
- getValueSerializer() - Method in class org.apache.flink.contrib.streaming.state.RocksDBAggregatingState
-
- getValueSerializer() - Method in class org.apache.flink.contrib.streaming.state.RocksDBFoldingState
-
Deprecated.
- getValueSerializer() - Method in class org.apache.flink.contrib.streaming.state.RocksDBListState
-
- getValueSerializer() - Method in class org.apache.flink.contrib.streaming.state.RocksDBMapState
-
- getValueSerializer() - Method in class org.apache.flink.contrib.streaming.state.RocksDBReducingState
-
- getValueSerializer() - Method in class org.apache.flink.contrib.streaming.state.RocksDBValueState
-
- getValueSerializer() - Method in class org.apache.flink.runtime.state.heap.HeapAggregatingState
-
- getValueSerializer() - Method in class org.apache.flink.runtime.state.heap.HeapFoldingState
-
Deprecated.
- getValueSerializer() - Method in class org.apache.flink.runtime.state.heap.HeapListState
-
- getValueSerializer() - Method in class org.apache.flink.runtime.state.heap.HeapMapState
-
- getValueSerializer() - Method in class org.apache.flink.runtime.state.heap.HeapReducingState
-
- getValueSerializer() - Method in class org.apache.flink.runtime.state.heap.HeapValueState
-
- getValueSerializer() - Method in interface org.apache.flink.runtime.state.internal.InternalKvState
-
- getValueSerializer() - Method in class org.apache.flink.runtime.state.RegisteredBroadcastBackendStateMetaInfo
-
- getValueSerializer() - Method in class org.apache.flink.runtime.state.RegisteredBroadcastBackendStateMetaInfo.Snapshot
-
- getValueSerializerConfigSnapshot() - Method in class org.apache.flink.runtime.state.RegisteredBroadcastBackendStateMetaInfo.Snapshot
-
- getValueTypeInfo() - Method in class org.apache.flink.api.java.typeutils.MapTypeInfo
-
Gets the type information for the values in the map
- getVariable() - Method in class org.apache.flink.runtime.broadcast.BroadcastVariableMaterialization
-
- getVariable(BroadcastVariableInitializer<T, C>) - Method in class org.apache.flink.runtime.broadcast.BroadcastVariableMaterialization
-
- getVariance() - Method in class org.apache.flink.api.java.summarize.NumericColumnSummary
-
Variance is a measure of how far a set of numbers are spread out.
- getVersion() - Method in class org.apache.flink.api.common.typeutils.base.CollectionSerializerConfigSnapshot
-
- getVersion() - Method in class org.apache.flink.api.common.typeutils.base.EnumSerializer.EnumSerializerConfigSnapshot
-
- getVersion() - Method in class org.apache.flink.api.common.typeutils.base.GenericArraySerializerConfigSnapshot
-
- getVersion() - Method in class org.apache.flink.api.common.typeutils.base.MapSerializerConfigSnapshot
-
- getVersion() - Method in class org.apache.flink.api.common.typeutils.ParameterlessTypeSerializerConfig
-
- getVersion() - Method in class org.apache.flink.api.common.typeutils.TypeSerializerSerializationUtil.TypeSerializerSerializationProxy
-
- getVersion() - Method in class org.apache.flink.api.java.typeutils.runtime.AvroSerializer.AvroSerializerConfigSnapshot
-
Deprecated.
- getVersion() - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer.CopyableValueSerializerConfigSnapshot
-
- getVersion() - Method in class org.apache.flink.api.java.typeutils.runtime.EitherSerializerConfigSnapshot
-
- getVersion() - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer.KryoSerializerConfigSnapshot
-
- getVersion() - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer.PojoSerializerConfigSnapshot
-
- getVersion() - Method in class org.apache.flink.api.java.typeutils.runtime.RowSerializer.RowSerializerConfigSnapshot
-
- getVersion() - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializerConfigSnapshot
-
- getVersion() - Method in class org.apache.flink.api.java.typeutils.runtime.ValueSerializer.ValueSerializerConfigSnapshot
-
- getVersion() - Method in class org.apache.flink.api.java.typeutils.runtime.WritableSerializer.WritableSerializerConfigSnapshot
-
- getVersion() - Method in class org.apache.flink.api.scala.typeutils.ScalaOptionSerializerConfigSnapshot
-
- getVersion() - Method in class org.apache.flink.api.scala.typeutils.ScalaTrySerializerConfigSnapshot
-
- getVersion() - Method in class org.apache.flink.api.scala.typeutils.TraversableSerializerConfigSnapshot
-
- getVersion() - Method in class org.apache.flink.cep.nfa.ComputationState
-
- getVersion() - Method in class org.apache.flink.cep.nfa.NFA.NFASerializerConfigSnapshot
-
- getVersion() - Method in class org.apache.flink.cep.nfa.SharedBuffer.SharedBufferSerializerConfigSnapshot
-
- getVersion() - Method in interface org.apache.flink.core.io.SimpleVersionedSerializer
-
Gets the version with which this serializer serializes.
- getVersion() - Method in interface org.apache.flink.core.io.Versioned
-
Returns the version number of the object.
- getVersion() - Method in class org.apache.flink.formats.avro.typeutils.AvroSerializer.AvroSchemaSerializerConfigSnapshot
-
- getVersion() - Method in class org.apache.flink.formats.avro.typeutils.AvroSerializer.AvroSerializerConfigSnapshot
-
Deprecated.
- getVersion() - Method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV1
-
- getVersion() - Method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV2
-
- getVersion() - Method in class org.apache.flink.runtime.rest.handler.legacy.messages.ClusterOverviewWithVersion
-
- getVersion() - Method in class org.apache.flink.runtime.rpc.akka.AkkaRpcService
-
- getVersion() - Method in class org.apache.flink.runtime.rpc.messages.RemoteHandshakeMessage
-
- getVersion() - Method in class org.apache.flink.runtime.state.KeyedBackendSerializationProxy
-
- getVersion() - Method in class org.apache.flink.runtime.state.OperatorBackendSerializationProxy
-
- getVersion() - Static method in class org.apache.flink.runtime.util.EnvironmentInformation
-
Returns the version of the code as String.
- getVersion() - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.UnionSerializerConfigSnapshot
-
- getVersion() - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.StateSerializerConfigSnapshot
-
- getVersion() - Method in class org.apache.flink.streaming.api.operators.InternalTimerServiceSerializationProxy
-
- getVersion() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer.StreamElementSerializerConfigSnapshot
-
- getVersionedValue() - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperSharedCount
-
- getVersionSerializer() - Method in class org.apache.flink.cep.nfa.SharedBuffer.SharedBufferSerializer
-
- getVertex() - Method in class org.apache.flink.runtime.executiongraph.Execution
-
- getVertexGroupCount() - Method in class org.apache.flink.graph.library.Summarization.VertexGroupItem
-
- getVertexGroupCount() - Method in class org.apache.flink.graph.library.Summarization.VertexValue
-
- getVertexGroupValue() - Method in class org.apache.flink.graph.library.Summarization.VertexGroupItem
-
- getVertexGroupValue() - Method in class org.apache.flink.graph.library.Summarization.VertexValue
-
- getVertexId() - Method in class org.apache.flink.graph.library.Summarization.VertexGroupItem
-
- getVertexId() - Method in class org.apache.flink.runtime.broadcast.BroadcastVariableKey
-
- getVertexID() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- getVertexId0() - Method in interface org.apache.flink.graph.asm.result.BinaryResult
-
Get the first vertex ID.
- getVertexId0() - Method in class org.apache.flink.graph.asm.result.BinaryResultBase
-
- getVertexId0() - Method in interface org.apache.flink.graph.asm.result.TertiaryResult
-
Get the first vertex ID.
- getVertexId0() - Method in class org.apache.flink.graph.asm.result.TertiaryResultBase
-
- getVertexId0() - Method in interface org.apache.flink.graph.asm.result.UnaryResult
-
Get the first vertex ID.
- getVertexId0() - Method in class org.apache.flink.graph.asm.result.UnaryResultBase
-
- getVertexId1() - Method in interface org.apache.flink.graph.asm.result.BinaryResult
-
Get the second vertex ID.
- getVertexId1() - Method in class org.apache.flink.graph.asm.result.BinaryResultBase
-
- getVertexId1() - Method in interface org.apache.flink.graph.asm.result.TertiaryResult
-
Get the second vertex ID.
- getVertexId1() - Method in class org.apache.flink.graph.asm.result.TertiaryResultBase
-
- getVertexId2() - Method in interface org.apache.flink.graph.asm.result.TertiaryResult
-
Get the third vertex ID.
- getVertexId2() - Method in class org.apache.flink.graph.asm.result.TertiaryResultBase
-
- getVertexIds() - Method in class org.apache.flink.graph.Graph
-
- getVertexIDs() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- getVertexWithAttempt() - Method in class org.apache.flink.runtime.executiongraph.Execution
-
- getVertices(ExecutionEnvironment) - Static method in class org.apache.flink.graph.examples.data.SummarizationData
-
Creates a set of vertices with attached
String
values.
- getVertices() - Method in class org.apache.flink.graph.Graph
-
- getVertices() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
Returns an Iterable to iterate all vertices registered with the job graph.
- getVerticesAsArray() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
Returns an array of all job vertices that are registered with the job graph.
- getVerticesAsTuple2() - Method in class org.apache.flink.graph.Graph
-
- getVerticesSortedTopologicallyFromSources() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
- getVerticesToAcknowledge() - Method in class org.apache.flink.runtime.jobgraph.tasks.JobCheckpointingSettings
-
- getVerticesToConfirm() - Method in class org.apache.flink.runtime.jobgraph.tasks.JobCheckpointingSettings
-
- getVerticesTopologically() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionGraph
-
Returns an iterable containing all job vertices for this execution graph in the order they were created.
- getVerticesTopologically() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
-
- getVerticesTopologically() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- getVerticesToTrigger() - Method in class org.apache.flink.runtime.jobgraph.tasks.JobCheckpointingSettings
-
- getVirtualHost() - Method in class org.apache.flink.streaming.connectors.rabbitmq.common.RMQConnectionConfig
-
Retrieve the virtual host.
- getVisibleMainHeight() - Method in class org.apache.flink.table.client.cli.CliView
-
- getVisitDataSet(ExecutionEnvironment) - Static method in class org.apache.flink.examples.java.relational.util.WebLogData
-
- getVMID() - Method in class org.apache.flink.mesos.scheduler.Offer
-
- getWaitForSolutionSetUpdate() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getWaitTime() - Method in class org.apache.flink.streaming.api.transformations.CoFeedbackTransformation
-
Returns the wait time.
- getWaitTime() - Method in class org.apache.flink.streaming.api.transformations.FeedbackTransformation
-
Returns the wait time.
- getWatermark() - Method in interface org.apache.flink.streaming.api.operators.async.queue.AsyncWatermarkResult
-
Get the resulting watermark.
- getWatermark() - Method in class org.apache.flink.streaming.api.operators.async.queue.WatermarkQueueEntry
-
- getWatermarkGauge() - Method in class org.apache.flink.streaming.api.collector.selector.DirectedOutput
-
- getWatermarkGauge() - Method in class org.apache.flink.streaming.runtime.io.RecordWriterOutput
-
- getWatermarkGauge() - Method in interface org.apache.flink.streaming.runtime.tasks.OperatorChain.WatermarkGaugeExposingOutput
-
- getWebFrontendAddress() - Method in class org.apache.flink.runtime.webmonitor.WebMonitorConfig
-
- getWebFrontendPort() - Method in class org.apache.flink.runtime.webmonitor.WebMonitorConfig
-
- getWebInterfaceURL() - Method in class org.apache.flink.client.program.ClusterClient
-
Returns an URL (as a string) to the JobManager web interface.
- getWebInterfaceURL() - Method in class org.apache.flink.client.program.MiniClusterClient
-
- getWebInterfaceURL() - Method in class org.apache.flink.client.program.rest.RestClusterClient
-
- getWebInterfaceURL() - Method in class org.apache.flink.client.program.StandaloneClusterClient
-
- getWebInterfaceURL() - Method in class org.apache.flink.yarn.YarnClusterClient
-
- getWebMonitorLeaderElectionService() - Method in interface org.apache.flink.runtime.highavailability.HighAvailabilityServices
-
- getWebMonitorLeaderElectionService() - Method in class org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedHaServices
-
- getWebMonitorLeaderElectionService() - Method in class org.apache.flink.runtime.highavailability.nonha.standalone.StandaloneHaServices
-
- getWebMonitorLeaderElectionService() - Method in class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperHaServices
-
- getWebMonitorLeaderElectionService() - Method in class org.apache.flink.yarn.highavailability.YarnIntraNonHaMasterServices
-
- getWebMonitorLeaderElectionService() - Method in class org.apache.flink.yarn.highavailability.YarnPreConfiguredMasterNonHaServices
-
- getWebMonitorLeaderRetriever() - Method in interface org.apache.flink.runtime.highavailability.HighAvailabilityServices
-
- getWebMonitorLeaderRetriever() - Method in class org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedHaServices
-
- getWebMonitorLeaderRetriever() - Method in class org.apache.flink.runtime.highavailability.nonha.standalone.StandaloneHaServices
-
- getWebMonitorLeaderRetriever() - Method in class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperHaServices
-
- getWebMonitorLeaderRetriever() - Method in class org.apache.flink.yarn.highavailability.YarnIntraNonHaMasterServices
-
- getWebMonitorLeaderRetriever() - Method in class org.apache.flink.yarn.highavailability.YarnPreConfiguredMasterNonHaServices
-
- getWebUiDir() - Method in class org.apache.flink.runtime.rest.handler.RestHandlerConfiguration
-
- getWebUIPort() - Method in class org.apache.flink.runtime.jobmanager.JobManagerCliOptions
-
- getWebUIPort() - Method in class org.apache.flink.test.util.MiniClusterResource
-
- getWeight() - Method in class org.apache.flink.api.java.sampling.IntermediateSampleData
-
- getWidth() - Method in class org.apache.flink.table.client.cli.CliClient
-
- getWidth() - Method in class org.apache.flink.table.client.cli.CliView
-
- getWildcardIPAddress() - Static method in class org.apache.flink.util.NetUtils
-
Returns the wildcard address to listen on all interfaces.
- getWindowAssigner() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
- getWindowSerializer(ExecutionConfig) - Method in class org.apache.flink.streaming.api.windowing.assigners.BaseAlignedWindowAssigner
-
- getWindowSerializer(ExecutionConfig) - Method in class org.apache.flink.streaming.api.windowing.assigners.DynamicEventTimeSessionWindows
-
- getWindowSerializer(ExecutionConfig) - Method in class org.apache.flink.streaming.api.windowing.assigners.DynamicProcessingTimeSessionWindows
-
- getWindowSerializer(ExecutionConfig) - Method in class org.apache.flink.streaming.api.windowing.assigners.EventTimeSessionWindows
-
- getWindowSerializer(ExecutionConfig) - Method in class org.apache.flink.streaming.api.windowing.assigners.GlobalWindows
-
- getWindowSerializer(ExecutionConfig) - Method in class org.apache.flink.streaming.api.windowing.assigners.ProcessingTimeSessionWindows
-
- getWindowSerializer(ExecutionConfig) - Method in class org.apache.flink.streaming.api.windowing.assigners.SlidingEventTimeWindows
-
- getWindowSerializer(ExecutionConfig) - Method in class org.apache.flink.streaming.api.windowing.assigners.SlidingProcessingTimeWindows
-
- getWindowSerializer(ExecutionConfig) - Method in class org.apache.flink.streaming.api.windowing.assigners.TumblingEventTimeWindows
-
- getWindowSerializer(ExecutionConfig) - Method in class org.apache.flink.streaming.api.windowing.assigners.TumblingProcessingTimeWindows
-
- getWindowSerializer(ExecutionConfig) - Method in class org.apache.flink.streaming.api.windowing.assigners.WindowAssigner
-
Returns a
TypeSerializer
for serializing windows that are assigned by
this
WindowAssigner
.
- getWindowSize() - Method in class org.apache.flink.streaming.api.windowing.evictors.TimeEvictor
-
- getWindowStartWithOffset(long, long, long) - Static method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow
-
Method to get the window start for a timestamp.
- getWindowTime() - Method in class org.apache.flink.cep.pattern.Pattern
-
- getWord() - Method in class org.apache.flink.examples.java.wordcount.WordCountPojo.Word
-
- getWord() - Method in class org.apache.flink.streaming.examples.kafka.KafkaEvent
-
- getWorker() - Method in class org.apache.flink.mesos.runtime.clusterframework.RegisteredMesosWorkerNode
-
- getWorker() - Method in class org.apache.flink.runtime.resourcemanager.registration.WorkerRegistration
-
- getWorkerIndex() - Method in class org.apache.flink.runtime.iterative.event.WorkerDoneEvent
-
- getWorkingDirectory() - Method in class org.apache.flink.core.fs.FileSystem
-
Returns the path of the file system's current working directory.
- getWorkingDirectory() - Method in class org.apache.flink.core.fs.LimitedConnectionsFileSystem
-
- getWorkingDirectory() - Method in class org.apache.flink.core.fs.local.LocalFileSystem
-
- getWorkingDirectory() - Method in class org.apache.flink.core.fs.SafetyNetWrapperFileSystem
-
- getWorkingDirectory() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileSystem
-
- getWorkset() - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase
-
Gets the contract that represents the workset for the step function.
- getWorkset() - Method in class org.apache.flink.api.java.operators.DeltaIteration
-
Gets the working set of the delta iteration.
- getWorksetNode() - Method in class org.apache.flink.optimizer.dag.WorksetIterationNode
-
- getWorksetNode() - Method in class org.apache.flink.optimizer.plan.WorksetPlanNode
-
- getWorksetPlanNode() - Method in class org.apache.flink.optimizer.plan.WorksetIterationPlanNode
-
- getWorksetSerializer() - Method in class org.apache.flink.optimizer.plan.WorksetIterationPlanNode
-
- getWorksetType() - Method in class org.apache.flink.api.java.operators.DeltaIterationResultSet
-
- getWrappedDelegate() - Method in class org.apache.flink.core.fs.FSDataInputStreamWrapper
-
- getWrappedDelegate() - Method in class org.apache.flink.core.fs.FSDataOutputStreamWrapper
-
- getWrappedDelegate() - Method in class org.apache.flink.core.fs.SafetyNetWrapperFileSystem
-
- getWrappedDelegate() - Method in interface org.apache.flink.util.WrappingProxy
-
- getWrappedException() - Method in exception org.apache.flink.runtime.operators.chaining.ExceptionInChainedStubException
-
- getWrappedFunction() - Method in class org.apache.flink.api.java.operators.translation.WrappingFunction
-
- getWriteEnd() - Method in class org.apache.flink.runtime.iterative.concurrent.BlockingBackChannel
-
Called by iteration tail to save the output of the current superstep.
- getWriteMode() - Method in class org.apache.flink.api.common.io.FileOutputFormat
-
- getWriteOffset() - Method in class org.apache.flink.runtime.io.disk.FileChannelOutputView
-
- getWriteOptions() - Method in class org.apache.flink.contrib.streaming.state.RocksDBKeyedStateBackend
-
- getWriter(int) - Method in interface org.apache.flink.runtime.execution.Environment
-
- getWriter(int) - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
-
- getWriterForVersion(int, RegisteredKeyedBackendStateMetaInfo.Snapshot<N, S>) - Static method in class org.apache.flink.runtime.state.KeyedBackendStateMetaInfoSnapshotReaderWriters
-
- getWriterForVersion(int, InternalTimersSnapshot<K, N>) - Static method in class org.apache.flink.streaming.api.operators.InternalTimersSnapshotReaderWriters
-
- getWriters() - Method in class org.apache.flink.runtime.operators.shipping.OutputCollector
-
List of writers that are associated with this output collector
- getWrittenBytes() - Method in class org.apache.flink.runtime.io.network.buffer.BufferConsumer
-
- getYarnClient() - Method in class org.apache.flink.yarn.AbstractYarnClusterDescriptor
-
- getYarnJobClusterEntrypoint() - Method in class org.apache.flink.yarn.AbstractYarnClusterDescriptor
-
The class to start the application master with.
- getYarnJobClusterEntrypoint() - Method in class org.apache.flink.yarn.LegacyYarnClusterDescriptor
-
- getYarnJobClusterEntrypoint() - Method in class org.apache.flink.yarn.YarnClusterDescriptor
-
- getYarnPropertiesLocation(String) - Static method in class org.apache.flink.yarn.cli.FlinkYarnSessionCli
-
- getYarnSessionClusterEntrypoint() - Method in class org.apache.flink.yarn.AbstractYarnClusterDescriptor
-
The class to start the application master with.
- getYarnSessionClusterEntrypoint() - Method in class org.apache.flink.yarn.LegacyYarnClusterDescriptor
-
- getYarnSessionClusterEntrypoint() - Method in class org.apache.flink.yarn.YarnClusterDescriptor
-
- getZooKeeperEnsemble(Configuration) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
-
Returns the configured ZooKeeper quorum (and removes whitespace, because ZooKeeper does not
tolerate it).
- getZooKeeperLoginContextName() - Method in class org.apache.flink.runtime.security.SecurityConfiguration
-
- getZookeeperNamespace() - Method in class org.apache.flink.yarn.AbstractYarnClusterDescriptor
-
- getZooKeeperServiceName() - Method in class org.apache.flink.runtime.security.SecurityConfiguration
-
- global() - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Sets the partitioning of the
DataStream
so that the output values
all go to the first instance of the next processing operator.
- globalClasspaths - Variable in class org.apache.flink.api.java.RemoteEnvironment
-
The classpaths that need to be attached to each job.
- GlobalClusteringCoefficient<K extends Comparable<K> & CopyableValue<K>,VV,EV> - Class in org.apache.flink.graph.library.clustering.directed
-
The global clustering coefficient measures the connectedness of a graph.
- GlobalClusteringCoefficient() - Constructor for class org.apache.flink.graph.library.clustering.directed.GlobalClusteringCoefficient
-
- GlobalClusteringCoefficient<K extends Comparable<K> & CopyableValue<K>,VV,EV> - Class in org.apache.flink.graph.library.clustering.undirected
-
The global clustering coefficient measures the connectedness of a graph.
- GlobalClusteringCoefficient() - Constructor for class org.apache.flink.graph.library.clustering.undirected.GlobalClusteringCoefficient
-
- GlobalClusteringCoefficient.Result - Class in org.apache.flink.graph.library.clustering.directed
-
Wraps global clustering coefficient metrics.
- GlobalClusteringCoefficient.Result - Class in org.apache.flink.graph.library.clustering.undirected
-
Wraps global clustering coefficient metrics.
- GlobalConfiguration - Class in org.apache.flink.configuration
-
Global configuration object for Flink.
- GlobalJobParameters() - Constructor for class org.apache.flink.api.common.ExecutionConfig.GlobalJobParameters
-
- GlobalModVersionMismatch - Exception in org.apache.flink.runtime.executiongraph
-
An exception that indicates a mismatch between the expected global modification version
of the execution graph, and the actual modification version.
- GlobalModVersionMismatch(long, long) - Constructor for exception org.apache.flink.runtime.executiongraph.GlobalModVersionMismatch
-
- GlobalPartitioner<T> - Class in org.apache.flink.streaming.runtime.partitioner
-
Partitioner that sends all elements to the downstream operator with subtask ID=0.
- GlobalPartitioner() - Constructor for class org.apache.flink.streaming.runtime.partitioner.GlobalPartitioner
-
- GlobalProperties - Class in org.apache.flink.optimizer.dataproperties
-
This class represents global properties of the data at a certain point in the plan.
- GlobalProperties() - Constructor for class org.apache.flink.optimizer.dataproperties.GlobalProperties
-
Initializes the global properties with no partitioning.
- GlobalPropertiesPair(RequestedGlobalProperties, RequestedGlobalProperties) - Constructor for class org.apache.flink.optimizer.operators.OperatorDescriptorDual.GlobalPropertiesPair
-
- globalProps - Variable in class org.apache.flink.optimizer.plan.PlanNode
-
- globalState() - Method in class org.apache.flink.streaming.api.functions.windowing.InternalProcessApplyAllWindowContext
-
- globalState() - Method in class org.apache.flink.streaming.api.functions.windowing.InternalProcessApplyWindowContext
-
- globalState() - Method in class org.apache.flink.streaming.api.functions.windowing.ProcessAllWindowFunction.Context
-
State accessor for per-key global state.
- globalState() - Method in class org.apache.flink.streaming.api.functions.windowing.ProcessWindowFunction.Context
-
State accessor for per-key global state.
- globalState() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalProcessAllWindowContext
-
- globalState() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalProcessWindowContext
-
- globalState() - Method in interface org.apache.flink.streaming.runtime.operators.windowing.functions.InternalWindowFunction.InternalWindowContext
-
- globalState() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.WindowContext
-
- GlobalWindow - Class in org.apache.flink.streaming.api.windowing.windows
-
The default window into which all data is placed (via
GlobalWindows
).
- GlobalWindow.Serializer - Class in org.apache.flink.streaming.api.windowing.windows
-
- GlobalWindows - Class in org.apache.flink.streaming.api.windowing.assigners
-
- GlobalWindows.NeverTrigger - Class in org.apache.flink.streaming.api.windowing.assigners
-
A trigger that never fires, as default Trigger for GlobalWindows.
- GlobFilePathFilter - Class in 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() - Constructor for class org.apache.flink.api.common.io.GlobFilePathFilter
-
Constructor for GlobFilePathFilter that will match all files
- GlobFilePathFilter(List<String>, List<String>) - Constructor for class org.apache.flink.api.common.io.GlobFilePathFilter
-
Constructor for GlobFilePathFilter
- GMT_ZONE - Static variable in class org.apache.calcite.avatica.util.DateTimeUtils
-
- go() - Method in class org.apache.flink.core.testutils.CheckedThread
-
This method needs to be overwritten to contain the main work logic.
- go() - Method in class org.apache.flink.runtime.operators.sort.CombiningUnilateralSortMerger.CombiningSpillingThread
-
Entry point of the thread.
- go() - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.ReadingThread
-
The entry point for the thread.
- go() - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SortingThread
-
Entry point of the thread.
- go() - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SpillingThread
-
Entry point of the thread.
- go() - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.ThreadBase
-
Equivalent to the run() method.
- GPU_NAME - Static variable in class org.apache.flink.api.common.operators.ResourceSpec
-
- GPUResource - Class in org.apache.flink.api.common.resources
-
The GPU resource.
- GPUResource(double) - Constructor for class org.apache.flink.api.common.resources.GPUResource
-
- gpus() - Method in class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManagerParameters
-
Get the GPU units to use for the TaskManager Process.
- gpus() - Method in class org.apache.flink.mesos.scheduler.Offer
-
- gpus(double) - Static method in class org.apache.flink.mesos.Utils
-
Construct a gpu resource.
- gpus(String, double) - Static method in class org.apache.flink.mesos.Utils
-
Construct a gpu resource.
- gracefulShutdown(long, TimeUnit, ExecutorService...) - Static method in class org.apache.flink.util.ExecutorUtils
-
- GradeSource() - Constructor for class org.apache.flink.streaming.examples.join.WindowJoinSampleData.GradeSource
-
- grantLeadership(UUID) - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
-
Callback method when current resourceManager is granted leadership.
- grantLeadership(UUID) - Method in class org.apache.flink.runtime.jobmaster.JobManagerRunner
-
- grantLeadership(UUID) - Method in interface org.apache.flink.runtime.leaderelection.LeaderContender
-
Callback method which is called by the
LeaderElectionService
upon selecting this
instance as the new leader.
- grantLeadership(UUID) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
-
Callback method when current resourceManager is granted leadership.
- grantLeadership(UUID) - Method in class org.apache.flink.runtime.webmonitor.WebMonitorEndpoint
-
- Graph<K,VV,EV> - Class in org.apache.flink.graph
-
- Graph(DataSet<Vertex<K, VV>>, DataSet<Edge<K, EV>>, ExecutionEnvironment) - Constructor for class org.apache.flink.graph.Graph
-
Creates a graph from two DataSets: vertices and edges.
- GraphAlgorithm<K,VV,EV,T> - Interface in org.apache.flink.graph
-
- GraphAlgorithmWrappingBase<K,VV,EV,R> - Class in org.apache.flink.graph.utils.proxy
-
- GraphAlgorithmWrappingBase() - Constructor for class org.apache.flink.graph.utils.proxy.GraphAlgorithmWrappingBase
-
- GraphAlgorithmWrappingDataSet<K,VV,EV,T> - Class in org.apache.flink.graph.utils.proxy
-
- GraphAlgorithmWrappingDataSet() - Constructor for class org.apache.flink.graph.utils.proxy.GraphAlgorithmWrappingDataSet
-
- GraphAlgorithmWrappingGraph<IN_K,IN_VV,IN_EV,OUT_K,OUT_VV,OUT_EV> - Class in org.apache.flink.graph.utils.proxy
-
- GraphAlgorithmWrappingGraph() - Constructor for class org.apache.flink.graph.utils.proxy.GraphAlgorithmWrappingGraph
-
- GraphAnalytic<K,VV,EV,T> - Interface in org.apache.flink.graph
-
A
GraphAnalytic
is similar to a
GraphAlgorithm
but is terminal
and results are retrieved via accumulators.
- GraphAnalyticBase<K,VV,EV,T> - Class in org.apache.flink.graph
-
- GraphAnalyticBase() - Constructor for class org.apache.flink.graph.GraphAnalyticBase
-
- GraphCreatingVisitor - Class in org.apache.flink.optimizer.traversals
-
This traversal creates the optimizer DAG from a program.
- GraphCreatingVisitor(int, ExecutionMode) - Constructor for class org.apache.flink.optimizer.traversals.GraphCreatingVisitor
-
- GraphCsvReader - Class in org.apache.flink.graph
-
A class to build a Graph using path(s) provided to CSV file(s) with optional vertex and edge data.
- GraphCsvReader(Path, Path, ExecutionEnvironment) - Constructor for class org.apache.flink.graph.GraphCsvReader
-
- GraphCsvReader(Path, ExecutionEnvironment) - Constructor for class org.apache.flink.graph.GraphCsvReader
-
- GraphCsvReader(Path, MapFunction<K, VV>, ExecutionEnvironment) - Constructor for class org.apache.flink.graph.GraphCsvReader
-
- GraphCsvReader(String, ExecutionEnvironment) - Constructor for class org.apache.flink.graph.GraphCsvReader
-
- GraphCsvReader(String, String, ExecutionEnvironment) - Constructor for class org.apache.flink.graph.GraphCsvReader
-
- GraphCsvReader(String, MapFunction<K, VV>, ExecutionEnvironment) - Constructor for class org.apache.flink.graph.GraphCsvReader
-
- GraphGenerator<K,VV,EV> - Interface in org.apache.flink.graph.generator
-
Graph generators shall be
- parallelizable, in order to create large datasets
- scale-free, generating the same graph regardless of parallelism
- thrifty, using as few operators as possible
- GraphGeneratorBase<K,VV,EV> - Class in org.apache.flink.graph.generator
-
Base class for graph generators.
- GraphGeneratorBase() - Constructor for class org.apache.flink.graph.generator.GraphGeneratorBase
-
- GraphGeneratorUtils - Class in org.apache.flink.graph.generator
-
Utilities for graph generators.
- GraphiteReporter - Class in org.apache.flink.metrics.graphite
-
This class acts as a factory for the GraphiteReporter
and allows using it as a
Flink reporter.
- GraphiteReporter() - Constructor for class org.apache.flink.metrics.graphite.GraphiteReporter
-
- GraphKeyTypeTransform<VV,EV> - Class in org.apache.flink.graph.drivers.transform
-
Transform the ID type of graphs from
LongValue
to byte, short,
char, integer, float, double, or string.
- GraphKeyTypeTransform(long) - Constructor for class org.apache.flink.graph.drivers.transform.GraphKeyTypeTransform
-
Create a key type transform.
- GraphMetrics<K extends Comparable<K>,VV,EV> - Class in org.apache.flink.graph.drivers
-
Driver for directed and undirected graph metrics analytics.
- GraphMetrics() - Constructor for class org.apache.flink.graph.drivers.GraphMetrics
-
- GraphUtils - Class in org.apache.flink.graph.utils
-
Graph
utilities.
- GraphUtils.AddLongValue - Class in org.apache.flink.graph.utils
-
- GraphUtils.IdentityMapper<T> - Class in org.apache.flink.graph.utils
-
The identity mapper returns the input as output.
- GraphUtils.MapTo<I,O> - Class in org.apache.flink.graph.utils
-
Map each element to a value.
- GraphUtils.NonForwardingIdentityMapper<T> - Class in org.apache.flink.graph.utils
-
The identity mapper returns the input as output.
- GraphValidator<K,VV,EV> - Class in org.apache.flink.graph.validation
-
A utility for defining validation criteria for different types of Graphs.
- GraphValidator() - Constructor for class org.apache.flink.graph.validation.GraphValidator
-
- greedy() - Method in class org.apache.flink.cep.pattern.Pattern
-
Specifies that this pattern is greedy.
- greedy() - Method in class org.apache.flink.cep.pattern.Quantifier
-
- GridGraph - Class in org.apache.flink.graph.drivers.input
-
- GridGraph() - Constructor for class org.apache.flink.graph.drivers.input.GridGraph
-
- GridGraph - Class in org.apache.flink.graph.generator
-
- GridGraph(ExecutionEnvironment) - Constructor for class org.apache.flink.graph.generator.GridGraph
-
An undirected Graph
connecting vertices in a regular tiling in
one or more dimensions and where the endpoints are optionally connected.
- GROUP_OFFSET - Static variable in class org.apache.flink.streaming.connectors.kafka.internals.KafkaTopicPartitionStateSentinel
-
Magic number that defines the partition should start from its committed group offset in Kafka.
- groupBy(KeySelector<T, K>) - Method in class org.apache.flink.api.java.DataSet
-
- groupBy(int...) - Method in class org.apache.flink.api.java.DataSet
-
- groupBy(String...) - Method in class org.apache.flink.api.java.DataSet
-
Groups a
DataSet
using field expressions.
- GroupCombineChainedDriver<IN,OUT> - Class in org.apache.flink.runtime.operators.chaining
-
Chained variant of the GroupReduceCombineDriver
Acts like a combiner with a custom output type OUT.
- GroupCombineChainedDriver() - Constructor for class org.apache.flink.runtime.operators.chaining.GroupCombineChainedDriver
-
- GroupCombineFunction<IN,OUT> - Interface in org.apache.flink.api.common.functions
-
Generic interface used for combine functions ("combiners").
- GroupCombineNode - Class in org.apache.flink.optimizer.dag
-
The optimizer representation of a GroupCombineNode operation.
- GroupCombineNode(GroupCombineOperatorBase<?, ?, ?>) - Constructor for class org.apache.flink.optimizer.dag.GroupCombineNode
-
Creates a new optimizer node for the given operator.
- GroupCombineOperator<IN,OUT> - Class in org.apache.flink.api.java.operators
-
This operator behaves like the GroupReduceOperator with Combine but only runs the Combine part which reduces all data
locally in their partitions.
- GroupCombineOperator(DataSet<IN>, TypeInformation<OUT>, GroupCombineFunction<IN, OUT>, String) - Constructor for class org.apache.flink.api.java.operators.GroupCombineOperator
-
Constructor for a non-grouped reduce (all reduce).
- GroupCombineOperator(Grouping<IN>, TypeInformation<OUT>, GroupCombineFunction<IN, OUT>, String) - Constructor for class org.apache.flink.api.java.operators.GroupCombineOperator
-
Constructor for a grouped reduce.
- GroupCombineOperatorBase<IN,OUT,FT extends GroupCombineFunction<IN,OUT>> - Class in org.apache.flink.api.common.operators.base
-
Base operator for the combineGroup transformation.
- GroupCombineOperatorBase(FT, UnaryOperatorInformation<IN, OUT>, int[], String) - Constructor for class org.apache.flink.api.common.operators.base.GroupCombineOperatorBase
-
- GroupCombineProperties - Class in org.apache.flink.optimizer.operators
-
The properties file belonging to the GroupCombineNode.
- GroupCombineProperties(FieldSet, Ordering) - Constructor for class org.apache.flink.optimizer.operators.GroupCombineProperties
-
- GroupedProcessingTimeWindowExample - Class in org.apache.flink.streaming.examples.windowing
-
An example of grouped stream windowing into sliding time windows.
- GroupedProcessingTimeWindowExample() - Constructor for class org.apache.flink.streaming.examples.windowing.GroupedProcessingTimeWindowExample
-
- Grouping<T> - Class in org.apache.flink.api.java.operators
-
Grouping is an intermediate step for a transformation on a grouped DataSet.
- Grouping(DataSet<T>, Keys<T>) - Constructor for class org.apache.flink.api.java.operators.Grouping
-
- GroupPattern<T,F extends T> - Class in org.apache.flink.cep.pattern
-
Base class for a group pattern definition.
- GroupReduceCombineDriver<IN,OUT> - Class in org.apache.flink.runtime.operators
-
Non-chained combine driver which is used for a CombineGroup transformation or a GroupReduce transformation where
the user supplied a RichGroupReduceFunction with a combine method.
- GroupReduceCombineDriver() - Constructor for class org.apache.flink.runtime.operators.GroupReduceCombineDriver
-
- GroupReduceDriver<IT,OT> - Class in org.apache.flink.runtime.operators
-
GroupReduce task which is executed by a Task Manager.
- GroupReduceDriver() - Constructor for class org.apache.flink.runtime.operators.GroupReduceDriver
-
- GroupReduceFunction<T,O> - Interface in org.apache.flink.api.common.functions
-
The interface for group reduce functions.
- GroupReduceIterator<IN,OUT> - Class in org.apache.flink.api.java.functions
-
Base class that simplifies reducing all values provided as
Iterable
.
- GroupReduceIterator() - Constructor for class org.apache.flink.api.java.functions.GroupReduceIterator
-
- GroupReduceNode - Class in org.apache.flink.optimizer.dag
-
The optimizer representation of a GroupReduce operation.
- GroupReduceNode(GroupReduceOperatorBase<?, ?, ?>) - Constructor for class org.apache.flink.optimizer.dag.GroupReduceNode
-
Creates a new optimizer node for the given operator.
- groupReduceOnEdges(EdgesFunctionWithVertexValue<K, VV, EV, T>, EdgeDirection) - Method in class org.apache.flink.graph.Graph
-
Groups by vertex and computes a GroupReduce transformation over the edge values of each vertex.
- groupReduceOnEdges(EdgesFunctionWithVertexValue<K, VV, EV, T>, EdgeDirection, TypeInformation<T>) - Method in class org.apache.flink.graph.Graph
-
Groups by vertex and computes a GroupReduce transformation over the edge values of each vertex.
- groupReduceOnEdges(EdgesFunction<K, EV, T>, EdgeDirection) - Method in class org.apache.flink.graph.Graph
-
Groups by vertex and computes a GroupReduce transformation over the edge values of each vertex.
- groupReduceOnEdges(EdgesFunction<K, EV, T>, EdgeDirection, TypeInformation<T>) - Method in class org.apache.flink.graph.Graph
-
Groups by vertex and computes a GroupReduce transformation over the edge values of each vertex.
- groupReduceOnNeighbors(NeighborsFunctionWithVertexValue<K, VV, EV, T>, EdgeDirection) - Method in class org.apache.flink.graph.Graph
-
Groups by vertex and computes a GroupReduce transformation over the neighbors (both edges and vertices)
of each vertex.
- groupReduceOnNeighbors(NeighborsFunctionWithVertexValue<K, VV, EV, T>, EdgeDirection, TypeInformation<T>) - Method in class org.apache.flink.graph.Graph
-
Groups by vertex and computes a GroupReduce transformation over the neighbors (both edges and vertices)
of each vertex.
- groupReduceOnNeighbors(NeighborsFunction<K, VV, EV, T>, EdgeDirection) - Method in class org.apache.flink.graph.Graph
-
Groups by vertex and computes a GroupReduce transformation over the neighbors (both edges and vertices)
of each vertex.
- groupReduceOnNeighbors(NeighborsFunction<K, VV, EV, T>, EdgeDirection, TypeInformation<T>) - Method in class org.apache.flink.graph.Graph
-
Groups by vertex and computes a GroupReduce transformation over the neighbors (both edges and vertices)
of each vertex.
- GroupReduceOperator<IN,OUT> - Class in org.apache.flink.api.java.operators
-
This operator represents the application of a "reduceGroup" function on a data set, and the
result data set produced by the function.
- GroupReduceOperator(DataSet<IN>, TypeInformation<OUT>, GroupReduceFunction<IN, OUT>, String) - Constructor for class org.apache.flink.api.java.operators.GroupReduceOperator
-
Constructor for a non-grouped reduce (all reduce).
- GroupReduceOperator(Grouping<IN>, TypeInformation<OUT>, GroupReduceFunction<IN, OUT>, String) - Constructor for class org.apache.flink.api.java.operators.GroupReduceOperator
-
Constructor for a grouped reduce.
- GroupReduceOperatorBase<IN,OUT,FT extends GroupReduceFunction<IN,OUT>> - Class in org.apache.flink.api.common.operators.base
-
- GroupReduceOperatorBase(UserCodeWrapper<FT>, UnaryOperatorInformation<IN, OUT>, int[], String) - Constructor for class org.apache.flink.api.common.operators.base.GroupReduceOperatorBase
-
- GroupReduceOperatorBase(FT, UnaryOperatorInformation<IN, OUT>, int[], String) - Constructor for class org.apache.flink.api.common.operators.base.GroupReduceOperatorBase
-
- GroupReduceOperatorBase(Class<? extends FT>, UnaryOperatorInformation<IN, OUT>, int[], String) - Constructor for class org.apache.flink.api.common.operators.base.GroupReduceOperatorBase
-
- GroupReduceOperatorBase(UserCodeWrapper<FT>, UnaryOperatorInformation<IN, OUT>, String) - Constructor for class org.apache.flink.api.common.operators.base.GroupReduceOperatorBase
-
- GroupReduceOperatorBase(FT, UnaryOperatorInformation<IN, OUT>, String) - Constructor for class org.apache.flink.api.common.operators.base.GroupReduceOperatorBase
-
- GroupReduceOperatorBase(Class<? extends FT>, UnaryOperatorInformation<IN, OUT>, String) - Constructor for class org.apache.flink.api.common.operators.base.GroupReduceOperatorBase
-
- GroupReduceProperties - Class in org.apache.flink.optimizer.operators
-
- GroupReduceProperties(FieldSet) - Constructor for class org.apache.flink.optimizer.operators.GroupReduceProperties
-
- GroupReduceProperties(FieldSet, Ordering) - Constructor for class org.apache.flink.optimizer.operators.GroupReduceProperties
-
- GroupReduceProperties(FieldSet, Partitioner<?>) - Constructor for class org.apache.flink.optimizer.operators.GroupReduceProperties
-
- GroupReduceProperties(FieldSet, Ordering, Partitioner<?>) - Constructor for class org.apache.flink.optimizer.operators.GroupReduceProperties
-
- GroupReduceWithCombineProperties - Class in org.apache.flink.optimizer.operators
-
- GroupReduceWithCombineProperties(FieldSet) - Constructor for class org.apache.flink.optimizer.operators.GroupReduceWithCombineProperties
-
- GroupReduceWithCombineProperties(FieldSet, Ordering) - Constructor for class org.apache.flink.optimizer.operators.GroupReduceWithCombineProperties
-
- GroupReduceWithCombineProperties(FieldSet, Partitioner<?>) - Constructor for class org.apache.flink.optimizer.operators.GroupReduceWithCombineProperties
-
- GroupReduceWithCombineProperties(FieldSet, Ordering, Partitioner<?>) - Constructor for class org.apache.flink.optimizer.operators.GroupReduceWithCombineProperties
-
- groupsFields(FieldSet) - Method in class org.apache.flink.api.common.operators.Ordering
-
- GSAConfiguration - Class in org.apache.flink.graph.gsa
-
A GSAConfiguration object can be used to set the iteration name and
degree of parallelism, to register aggregators and use broadcast sets in
the
GatherFunction
,
SumFunction
as well as
ApplyFunction
.
- GSAConfiguration() - Constructor for class org.apache.flink.graph.gsa.GSAConfiguration
-
- GSAConnectedComponents<K,VV extends Comparable<VV>,EV> - Class in org.apache.flink.graph.library
-
A gather-sum-apply implementation of the Weakly Connected Components algorithm.
- GSAConnectedComponents(Integer) - Constructor for class org.apache.flink.graph.library.GSAConnectedComponents
-
Creates an instance of the GSA Connected Components algorithm.
- GSAPageRank<K> - Class in org.apache.flink.graph.examples
-
This is an implementation of a simple PageRank algorithm, using a gather-sum-apply iteration.
- GSAPageRank(double, int) - Constructor for class org.apache.flink.graph.examples.GSAPageRank
-
Creates an instance of the GSA PageRank algorithm.
- GSASingleSourceShortestPaths - Class in org.apache.flink.graph.examples
-
This example shows how to use Gelly's Gather-Sum-Apply iterations.
- GSASingleSourceShortestPaths() - Constructor for class org.apache.flink.graph.examples.GSASingleSourceShortestPaths
-
- GSASingleSourceShortestPaths<K,VV> - Class in org.apache.flink.graph.library
-
This is an implementation of the Single Source Shortest Paths algorithm, using a gather-sum-apply iteration.
- GSASingleSourceShortestPaths(K, Integer) - Constructor for class org.apache.flink.graph.library.GSASingleSourceShortestPaths
-
Creates an instance of the GSA SingleSourceShortestPaths algorithm.
- GzipInflaterInputStreamFactory - Class in org.apache.flink.api.common.io.compression
-
Factory for input streams that decompress the GZIP compression format.
- GzipInflaterInputStreamFactory() - Constructor for class org.apache.flink.api.common.io.compression.GzipInflaterInputStreamFactory
-
- id - Variable in class org.apache.flink.examples.java.clustering.KMeans.Centroid
-
- id - Variable in class org.apache.flink.optimizer.dag.OptimizerNode
-
- id - Variable in class org.apache.flink.runtime.io.disk.iomanager.AbstractFileIOChannel
-
The ID of the underlying channel.
- ID(File, int) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.FileIOChannel.ID
-
- ID(File, int, Random) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.FileIOChannel.ID
-
- id - Variable in class org.apache.flink.runtime.webmonitor.handlers.JarListInfo.JarFileInfo
-
- ID - Static variable in class org.apache.flink.streaming.api.graph.JSONGenerator
-
- id - Variable in class org.apache.flink.streaming.api.transformations.StreamTransformation
-
- IdAndEstimatesVisitor - Class in org.apache.flink.optimizer.traversals
-
This traversal of the optimizer DAG assigns IDs to each node (in a pre-order fashion),
and calls each node to compute its estimates.
- IdAndEstimatesVisitor(DataStatistics) - Constructor for class org.apache.flink.optimizer.traversals.IdAndEstimatesVisitor
-
- idCounter - Static variable in class org.apache.flink.streaming.api.transformations.StreamTransformation
-
- identifier - Variable in class org.apache.flink.python.api.PythonOperationInfo
-
- identifyDynamicPath(int) - Method in class org.apache.flink.optimizer.dag.AbstractPartialSolutionNode
-
- identifyDynamicPath(int) - Method in class org.apache.flink.optimizer.dag.OptimizerNode
-
- IdentityGroupReduce<IN> - Class in org.apache.flink.python.api.functions.util
-
Utility function to group and sort data.
- IdentityGroupReduce() - Constructor for class org.apache.flink.python.api.functions.util.IdentityGroupReduce
-
- IdentityMapper() - Constructor for class org.apache.flink.graph.utils.GraphUtils.IdentityMapper
-
- IDLE - Static variable in class org.apache.flink.streaming.runtime.streamstatus.StreamStatus
-
- IDLE_STATUS - Static variable in class org.apache.flink.streaming.runtime.streamstatus.StreamStatus
-
- IDLENESS_TIMEOUT - Static variable in class org.apache.flink.configuration.RestOptions
-
The maximum time in ms for a connection to stay idle before failing.
- IdPartitioner - Class in org.apache.flink.api.java.functions
-
Partitioner that partitions by id.
- IdPartitioner() - Constructor for class org.apache.flink.api.java.functions.IdPartitioner
-
- ifNotPresent(Runnable) - Method in class org.apache.flink.util.OptionalConsumer
-
- ifPresent(Consumer<T>) - Method in class org.apache.flink.util.OptionalConsumer
-
- ignoreComments(String) - Method in class org.apache.flink.api.java.io.CsvReader
-
Configures the string that starts comments.
- ignoreCommentsEdges(String) - Method in class org.apache.flink.graph.GraphCsvReader
-
Configures the string that starts comments for the Edge Csv Reader.
- ignoreCommentsVertices(String) - Method in class org.apache.flink.graph.GraphCsvReader
-
Configures the string that starts comments for the Vertex Csv Reader.
- ignoreFailuresAfterTransactionTimeout() - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
-
- ignoreFailuresAfterTransactionTimeout() - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer011
-
Disables the propagation of exceptions thrown when committing presumably timed out Kafka
transactions during recovery of the job.
- ignoreFirstLine() - Method in class org.apache.flink.api.java.io.CsvReader
-
Sets the CSV reader to ignore the first line.
- ignoreFirstLineEdges() - Method in class org.apache.flink.graph.GraphCsvReader
-
Sets the CSV reader for the Edges file to ignore the first line.
- ignoreFirstLineVertices() - Method in class org.apache.flink.graph.GraphCsvReader
-
Sets the CSV reader for the Vertices file to ignore the first line.
- ignoreFn() - Static method in class org.apache.flink.util.function.FunctionUtils
-
Consumer which ignores the input.
- ignoreInvalidLines - Variable in class org.apache.flink.api.java.io.CsvReader
-
- ignoreInvalidLines() - Method in class org.apache.flink.api.java.io.CsvReader
-
Sets the CSV reader to ignore any invalid lines.
- ignoreInvalidLinesEdges() - Method in class org.apache.flink.graph.GraphCsvReader
-
Sets the CSV reader for the Edges file to ignore any invalid lines.
- ignoreInvalidLinesVertices() - Method in class org.apache.flink.graph.GraphCsvReader
-
Sets the CSV reader Vertices file to ignore any invalid lines.
- IgnoringHandler() - Constructor for class org.apache.flink.streaming.api.functions.timestamps.AscendingTimestampExtractor.IgnoringHandler
-
- IllegalConfigurationException - Exception in org.apache.flink.configuration
-
An
IllegalConfigurationException
is thrown when
the values in a given
Configuration
are not valid.
- IllegalConfigurationException(String) - Constructor for exception org.apache.flink.configuration.IllegalConfigurationException
-
Constructs an new IllegalConfigurationException with the given error message.
- IllegalConfigurationException(String, Object...) - Constructor for exception org.apache.flink.configuration.IllegalConfigurationException
-
Constructs an new IllegalConfigurationException with the given error message
format and arguments.
- IllegalConfigurationException(String, Throwable) - Constructor for exception org.apache.flink.configuration.IllegalConfigurationException
-
Constructs an new IllegalConfigurationException with the given error message
and a given cause.
- IllegalExecutionStateException - Exception in org.apache.flink.runtime.executiongraph
-
- IllegalExecutionStateException(ExecutionState, ExecutionState) - Constructor for exception org.apache.flink.runtime.executiongraph.IllegalExecutionStateException
-
Creates a new IllegalExecutionStateException with the error message indicating
the expected and actual state.
- IllegalExecutionStateException(Execution, ExecutionState, ExecutionState) - Constructor for exception org.apache.flink.runtime.executiongraph.IllegalExecutionStateException
-
Creates a new IllegalExecutionStateException with the error message indicating
the expected and actual state.
- ImmutableAggregatingState<IN,OUT> - Class in org.apache.flink.queryablestate.client.state
-
- immutableEntries() - Method in interface org.apache.flink.api.common.state.ReadOnlyBroadcastState
-
Returns an immutable
Iterable
over the entries in the state.
- immutableEntries() - Method in class org.apache.flink.runtime.state.HeapBroadcastState
-
- ImmutableFoldingState<IN,ACC> - Class in org.apache.flink.queryablestate.client.state
-
Deprecated.
- ImmutableListState<V> - Class in org.apache.flink.queryablestate.client.state
-
A read-only
ListState
that does not allow for modifications.
- ImmutableMapState<K,V> - Class in org.apache.flink.queryablestate.client.state
-
A read-only
MapState
that does not allow for modifications.
- ImmutableReducingState<V> - Class in org.apache.flink.queryablestate.client.state
-
- ImmutableStateBinder - Class in org.apache.flink.queryablestate.client.state
-
- ImmutableStateBinder(byte[]) - Constructor for class org.apache.flink.queryablestate.client.state.ImmutableStateBinder
-
- ImmutableValueState<V> - Class in org.apache.flink.queryablestate.client.state
-
A read-only
ValueState
that does not allow for modifications.
- Impl(SqlFunction) - Constructor for class org.apache.calcite.sql2rel.AuxiliaryConverter.Impl
-
- In(String, PredicateLeaf.Type, Serializable...) - Constructor for class org.apache.flink.orc.OrcRowInputFormat.In
-
Creates an IN predicate.
- in - Variable in class org.apache.flink.python.api.streaming.data.PythonStreamer
-
- inc() - Method in interface org.apache.flink.metrics.Counter
-
Increment the current count by 1.
- inc(long) - Method in interface org.apache.flink.metrics.Counter
-
Increment the current count by the given value.
- inc() - Method in class org.apache.flink.metrics.SimpleCounter
-
Increment the current count by 1.
- inc(long) - Method in class org.apache.flink.metrics.SimpleCounter
-
Increment the current count by the given value.
- includeAlternativeOperatorIDs(Map<OperatorID, ExecutionJobVertex>) - Static method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
- includedMask - Variable in class org.apache.flink.api.java.io.CsvReader
-
- includeFields(boolean...) - Method in class org.apache.flink.api.java.io.CsvReader
-
Configures which fields of the CSV file should be included and which should be skipped.
- includeFields(String) - Method in class org.apache.flink.api.java.io.CsvReader
-
Configures which fields of the CSV file should be included and which should be skipped.
- includeFields(long) - Method in class org.apache.flink.api.java.io.CsvReader
-
Configures which fields of the CSV file should be included and which should be skipped.
- includeFieldsEdges(boolean...) - Method in class org.apache.flink.graph.GraphCsvReader
-
Configures which fields of the CSV file containing edges data should be included and which should be skipped.
- includeFieldsEdges(String) - Method in class org.apache.flink.graph.GraphCsvReader
-
Configures which fields of the CSV file containing edges data should be included and which should be skipped.
- includeFieldsEdges(long) - Method in class org.apache.flink.graph.GraphCsvReader
-
Configures which fields of the CSV file containing edges data should be included and which should be skipped.
- includeFieldsVertices(boolean...) - Method in class org.apache.flink.graph.GraphCsvReader
-
Configures which fields of the CSV file containing vertices data should be included and which should be skipped.
- includeFieldsVertices(String) - Method in class org.apache.flink.graph.GraphCsvReader
-
Configures which fields of the CSV file containing vertices data should be included and which should be skipped.
- includeFieldsVertices(long) - Method in class org.apache.flink.graph.GraphCsvReader
-
Configures which fields of the CSV file containing vertices data should be included and which should be skipped.
- includeLegacyJobVertexIDs(Map<JobVertexID, ExecutionJobVertex>) - Static method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
- includeRegionInScan(byte[], byte[]) - Method in class org.apache.flink.addons.hbase.AbstractTableInputFormat
-
Test if the given region is to be included in the scan while splitting the regions of a table.
- includeSerializedAccumulatorsParameter - Variable in class org.apache.flink.runtime.rest.messages.JobAccumulatorsMessageParameters
-
- IncompatibleKeysException(String) - Constructor for exception org.apache.flink.api.common.operators.Keys.IncompatibleKeysException
-
- IncompatibleKeysException(TypeInformation<?>, TypeInformation<?>) - Constructor for exception org.apache.flink.api.common.operators.Keys.IncompatibleKeysException
-
- inConn - Variable in class org.apache.flink.optimizer.dag.SingleInputNode
-
- incrCounter(Enum<?>, long) - Method in class org.apache.flink.api.java.hadoop.mapred.wrapper.HadoopDummyReporter
-
- incrCounter(String, String, long) - Method in class org.apache.flink.api.java.hadoop.mapred.wrapper.HadoopDummyReporter
-
- increase() - Method in class org.apache.flink.cep.nfa.DeweyNumber
-
Creates a new dewey number from this such that its last digit is increased by
one.
- increase(int) - Method in class org.apache.flink.cep.nfa.DeweyNumber
-
Creates a new dewey number from this such that its last digit is increased by the supplied
number.
- increaseBackoff() - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputChannel
-
Increases the current backoff and returns whether the operation was successful.
- increaseBuffersInBacklog(BufferConsumer) - Method in class org.apache.flink.runtime.io.network.partition.ResultSubpartition
-
Increases the number of non-event buffers by one after adding a non-event
buffer into this subpartition.
- increaseRefreshInterval() - Method in class org.apache.flink.table.client.cli.CliResultView
-
- increment() - Method in class org.apache.flink.runtime.util.AtomicDisposableReferenceCounter
-
Increments the reference count and returns whether it was successful.
- INCREMENTAL_CHECKPOINTS - Static variable in class org.apache.flink.configuration.CheckpointingOptions
-
Option whether the state backend should create incremental checkpoints,
if possible.
- IncrementalKeyedStateHandle - Class in org.apache.flink.runtime.state
-
The handle to states of an incremental snapshot.
- IncrementalKeyedStateHandle(UUID, KeyGroupRange, long, Map<StateHandleID, StreamStateHandle>, Map<StateHandleID, StreamStateHandle>, StreamStateHandle) - Constructor for class org.apache.flink.runtime.state.IncrementalKeyedStateHandle
-
- IncrementalLearningSkeleton - Class in org.apache.flink.streaming.examples.ml
-
Skeleton for incremental machine learning algorithm consisting of a
pre-computed model, which gets updated for the new inputs and new input data
for which the job provides predictions.
- IncrementalLearningSkeleton() - Constructor for class org.apache.flink.streaming.examples.ml.IncrementalLearningSkeleton
-
- IncrementalLearningSkeleton.FiniteNewDataSource - Class in org.apache.flink.streaming.examples.ml
-
Feeds new data for newData.
- IncrementalLearningSkeleton.FiniteTrainingDataSource - Class in org.apache.flink.streaming.examples.ml
-
Feeds new training data for the partial model builder.
- IncrementalLearningSkeleton.PartialModelBuilder - Class in org.apache.flink.streaming.examples.ml
-
Builds up-to-date partial models on new training data.
- IncrementalLearningSkeleton.Predictor - Class in org.apache.flink.streaming.examples.ml
-
Creates newData using the model produced in batch-processing and the
up-to-date partial model.
- IncrementalLearningSkeletonData - Class in org.apache.flink.streaming.examples.ml.util
-
Data for IncrementalLearningSkeletonITCase.
- IncrementalLocalKeyedStateHandle - Class in org.apache.flink.runtime.state
-
- IncrementalLocalKeyedStateHandle(UUID, long, DirectoryStateHandle, KeyGroupRange, StreamStateHandle, Set<StateHandleID>) - Constructor for class org.apache.flink.runtime.state.IncrementalLocalKeyedStateHandle
-
- IncrementalSSSP - Class in org.apache.flink.graph.examples
-
This example illustrates how to
create a Graph directly from CSV files
use the scatter-gather iteration's messaging direction configuration option
- IncrementalSSSP() - Constructor for class org.apache.flink.graph.examples.IncrementalSSSP
-
- IncrementalSSSP.InvalidateMessenger - Class in org.apache.flink.graph.examples
-
Initiate or propagate INVALIDATE messages.
- IncrementalSSSP.VertexDistanceUpdater - Class in org.apache.flink.graph.examples
-
When an INVALIDATE message indicates that the only shortest path
containing this vertex has been removed then set the vertex distance to
infinity.
- IncrementalSSSPData - Class in org.apache.flink.graph.examples.data
-
Provides the default data sets used for the IncrementalSSSP example program.
- incrementIterationCounter() - Method in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
-
- incrNewOperationCounters(boolean) - Method in class org.apache.flink.api.java.sca.UdfAnalyzer
-
- inDegrees() - Method in class org.apache.flink.graph.Graph
-
Return the in-degree of all vertices in the graph.
- index - Variable in class org.apache.flink.runtime.io.network.partition.ResultSubpartition
-
The index of the subpartition at the parent partition.
- IndexedSortable - Interface in org.apache.flink.runtime.operators.sort
-
- IndexedSorter - Interface in org.apache.flink.runtime.operators.sort
-
- indexes - Variable in class org.apache.flink.api.common.operators.Ordering
-
- indexOf(Object) - Method in class org.apache.flink.types.ListValue
-
- IndexRequestBuilder<T> - Interface in org.apache.flink.streaming.connectors.elasticsearch
-
- INDIVIDUAL_RESTART_STRATEGY_NAME - Static variable in class org.apache.flink.runtime.executiongraph.failover.FailoverStrategyLoader
-
- INF_TIMEOUT - Static variable in class org.apache.flink.runtime.rpc.RpcUtils
-
HACK: Set to 21474835 seconds, Akka's maximum delay (Akka 2.4.20).
- inFirstIteration() - Method in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
-
- INFLATER_INPUT_STREAM_FACTORIES - Static variable in class org.apache.flink.api.common.io.FileInputFormat
-
A mapping of file extensions to decompression algorithms based on DEFLATE.
- InflaterInputStreamFactory<T extends InputStream> - Interface in org.apache.flink.api.common.io.compression
-
- info(String[]) - Method in class org.apache.flink.client.cli.CliFrontend
-
Executes the info action.
- INFO_CATEGORY_JM - Static variable in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo
-
- INFO_CATEGORY_JOB - Static variable in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo
-
- INFO_CATEGORY_OPERATOR - Static variable in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo
-
- INFO_CATEGORY_TASK - Static variable in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo
-
- INFO_CATEGORY_TM - Static variable in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo
-
- InfoMessage - Class in org.apache.flink.runtime.clusterframework.messages
-
A simple informational message sent by the resource master to the client.
- InfoMessage(String) - Constructor for class org.apache.flink.runtime.clusterframework.messages.InfoMessage
-
- InfoMessage(String, Date) - Constructor for class org.apache.flink.runtime.clusterframework.messages.InfoMessage
-
- InfoMessage - Interface in org.apache.flink.runtime.messages.webmonitor
-
Abstract base interface of all info messages exchanged between the
JobManager an for example the runtime monitor.
- InfoMessageListenerRpcGateway - Interface in org.apache.flink.runtime.resourcemanager
-
- InfoOptions - Class in org.apache.flink.client.cli
-
Command line options for the INFO command.
- InfoOptions(CommandLine) - Constructor for class org.apache.flink.client.cli.InfoOptions
-
- IngestionTimeExtractor<T> - Class in org.apache.flink.streaming.api.functions
-
A timestamp assigner that assigns timestamps based on the machine's wall clock.
- IngestionTimeExtractor() - Constructor for class org.apache.flink.streaming.api.functions.IngestionTimeExtractor
-
- init(Frame) - Method in class org.apache.flink.api.java.sca.ModifiedASMFrame
-
- init(IterationRuntimeContext) - Method in class org.apache.flink.graph.gsa.ApplyFunction
-
- init(IterationRuntimeContext) - Method in class org.apache.flink.graph.gsa.GatherFunction
-
- init(IterationRuntimeContext) - Method in class org.apache.flink.graph.gsa.SumFunction
-
- init() - Method in class org.apache.flink.streaming.runtime.tasks.OneInputStreamTask
-
- init() - Method in class org.apache.flink.streaming.runtime.tasks.SourceStreamTask
-
- init() - Method in class org.apache.flink.streaming.runtime.tasks.StreamIterationHead
-
- init() - Method in class org.apache.flink.streaming.runtime.tasks.StreamIterationTail
-
- init() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- init() - Method in class org.apache.flink.streaming.runtime.tasks.TwoInputStreamTask
-
- init() - Method in class org.apache.flink.table.client.cli.CliInputView
-
- init() - Method in class org.apache.flink.table.client.cli.CliResultView
-
- init() - Method in class org.apache.flink.table.client.cli.CliRowView
-
- init() - Method in class org.apache.flink.table.client.cli.CliView
-
Starts threads if necessary.
- initAndExecPythonScript(PythonEnvironmentFactory, Path, String, String[]) - Static method in class org.apache.flink.streaming.python.util.InterpreterUtils
-
Initializes the Jython interpreter and executes a python script.
- initBroadcastInputReaders() - Method in class org.apache.flink.runtime.operators.BatchTask
-
- initBroadcastInputsSerializers(int) - Method in class org.apache.flink.runtime.operators.BatchTask
-
Creates all the serializers and iterators for the broadcast inputs.
- initDefaultsFromConfiguration(Configuration) - Static method in class org.apache.flink.api.common.io.FileOutputFormat
-
Initialize defaults for output format.
- INITIAL_CENTERS - Static variable in class org.apache.flink.test.testdata.KMeansData
-
- INITIAL_CENTERS_2D - Static variable in class org.apache.flink.test.testdata.KMeansData
-
- INITIAL_REGISTRATION_BACKOFF - Static variable in class org.apache.flink.configuration.TaskManagerOptions
-
The initial registration backoff between two consecutive registration attempts.
- INITIAL_TASKS - Static variable in class org.apache.flink.mesos.configuration.MesosOptions
-
The initial number of Mesos tasks to allocate.
- InitializationTypeConflictException - Exception in org.apache.flink.runtime.broadcast
-
- InitializationTypeConflictException(Class<?>) - Constructor for exception org.apache.flink.runtime.broadcast.InitializationTypeConflictException
-
- initialize(Configuration) - Static method in class org.apache.flink.core.fs.FileSystem
-
Initializes the shared file system settings.
- initialize() - Method in class org.apache.flink.mesos.runtime.clusterframework.MesosFlinkResourceManager
-
- initialize() - Method in class org.apache.flink.mesos.runtime.clusterframework.MesosResourceManager
-
- initialize() - Method in class org.apache.flink.runtime.clusterframework.FlinkResourceManager
-
Initializes the framework specific components.
- initialize() - Method in class org.apache.flink.runtime.clusterframework.standalone.StandaloneResourceManager
-
- initialize() - Method in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
-
- initialize() - Method in class org.apache.flink.runtime.iterative.task.IterationIntermediateTask
-
- initialize() - Method in class org.apache.flink.runtime.iterative.task.IterationTailTask
-
- initialize() - Method in class org.apache.flink.runtime.operators.AbstractCachedBuildSideJoinDriver
-
- initialize() - Method in class org.apache.flink.runtime.operators.BatchTask
-
- initialize() - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetFirstDriver
-
- initialize() - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetSecondDriver
-
- initialize() - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetFirstDriver
-
- initialize() - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetSecondDriver
-
- initialize() - Method in interface org.apache.flink.runtime.operators.ResettableDriver
-
- initialize() - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
-
Initializes the framework specific components.
- initialize() - Method in class org.apache.flink.runtime.resourcemanager.StandaloneResourceManager
-
- initialize(FlinkLocalCluster.LocalClusterFactory) - Static method in class org.apache.flink.storm.api.FlinkLocalCluster
-
Sets a different factory for FlinkLocalClusters to be used for execution.
- initialize(FunctionInitializationContext) - Method in class org.apache.flink.streaming.tests.artificialstate.builder.ArtificialListStateBuilder
-
- initialize(FunctionInitializationContext) - Method in class org.apache.flink.streaming.tests.artificialstate.builder.ArtificialMapStateBuilder
-
- initialize(FunctionInitializationContext) - Method in class org.apache.flink.streaming.tests.artificialstate.builder.ArtificialStateBuilder
-
Registers the state.
- initialize(FunctionInitializationContext) - Method in class org.apache.flink.streaming.tests.artificialstate.builder.ArtificialValueStateBuilder
-
- initialize() - Method in class org.apache.flink.yarn.YarnFlinkResourceManager
-
- initialize() - Method in class org.apache.flink.yarn.YarnResourceManager
-
- initialize(ActorRef) - Method in class org.apache.flink.yarn.YarnResourceManagerCallbackHandler
-
- initializeAggregate() - Method in class org.apache.flink.api.java.aggregation.AggregationFunction
-
- initializeBroadcastVariable(Iterable<T>) - Method in interface org.apache.flink.api.common.functions.BroadcastVariableInitializer
-
The method that reads the data elements from the broadcast variable and
creates the transformed data structure.
- initializeBroadcastVariable(Iterable<T>) - Method in class org.apache.flink.runtime.broadcast.DefaultBroadcastVariableInitializer
-
- initializeBufferMetrics(Task) - Method in class org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
-
Initialize Buffer Metrics for a task.
- initializeConnections() - Method in class org.apache.flink.streaming.connectors.kafka.internal.Kafka09PartitionDiscoverer
-
- initializeConnections() - Method in class org.apache.flink.streaming.connectors.kafka.internals.AbstractPartitionDiscoverer
-
Establish the required connections in order to fetch topics and partitions metadata.
- initializeConnections() - Method in class org.apache.flink.streaming.connectors.kafka.internals.Kafka08PartitionDiscoverer
-
- initializeContextEnvironment(ExecutionEnvironmentFactory) - Static method in class org.apache.flink.api.java.ExecutionEnvironment
-
Sets a context environment factory, that creates the context environment for running programs
with pre-configured environments.
- initializeContextEnvironment(StreamExecutionEnvironmentFactory) - Static method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- initializeFields(T) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer
-
- initializeGlobal(int) - Method in class org.apache.flink.api.common.io.FileOutputFormat
-
Initialization of the distributed file system if it is used.
- initializeGlobal(int) - Method in interface org.apache.flink.api.common.io.InitializeOnMaster
-
The method is invoked on the master (JobManager) before the distributed program execution starts.
- initializeHandler() - Method in class org.apache.flink.queryablestate.client.proxy.KvStateClientProxyImpl
-
- initializeHandler() - Method in class org.apache.flink.queryablestate.network.AbstractServerBase
-
Returns the
handler
to be used for
serving the incoming requests.
- initializeHandler() - Method in class org.apache.flink.queryablestate.server.KvStateServerImpl
-
- initializeHandlers(CompletableFuture<String>) - Method in class org.apache.flink.runtime.dispatcher.DispatcherRestEndpoint
-
- initializeHandlers(CompletableFuture<String>) - Method in class org.apache.flink.runtime.rest.RestServerEndpoint
-
This method is called at the beginning of
RestServerEndpoint.start()
to setup all handlers that the REST server endpoint
implementation requires.
- initializeHandlers(CompletableFuture<String>) - Method in class org.apache.flink.runtime.webmonitor.WebMonitorEndpoint
-
- initializeLocationForCheckpoint(long) - Method in interface org.apache.flink.runtime.state.CheckpointStorage
-
Initializes a storage location for new checkpoint with the given ID.
- initializeLocationForCheckpoint(long) - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStorage
-
- initializeLocationForCheckpoint(long) - Method in class org.apache.flink.runtime.state.memory.MemoryBackendCheckpointStorage
-
- initializeLocationForSavepoint(long, String) - Method in interface org.apache.flink.runtime.state.CheckpointStorage
-
Initializes a storage location for new savepoint with the given ID.
- initializeLocationForSavepoint(long, String) - Method in class org.apache.flink.runtime.state.filesystem.AbstractFsCheckpointStorage
-
Creates a file system based storage location for a savepoint.
- InitializeOnMaster - Interface in org.apache.flink.api.common.io
-
This interface may be implemented by
OutputFormat
s to have the master initialize them globally.
- initializeOnMaster(ClassLoader) - Method in class org.apache.flink.runtime.jobgraph.InputFormatVertex
-
- initializeOnMaster(ClassLoader) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
A hook that can be overwritten by sub classes to implement logic that is called by the
master when the job starts.
- initializeOnMaster(ClassLoader) - Method in class org.apache.flink.runtime.jobgraph.OutputFormatVertex
-
- initializeSafetyNetForThread() - Static method in class org.apache.flink.core.fs.FileSystemSafetyNet
-
Activates the safety net for a thread.
- initializeSerializerUnlessSet(ExecutionConfig) - Method in class org.apache.flink.api.common.state.StateDescriptor
-
Initializes the serializer, unless it has been initialized before.
- initializeServices(Configuration) - Method in class org.apache.flink.mesos.entrypoint.MesosJobClusterEntrypoint
-
- initializeServices(Configuration) - Method in class org.apache.flink.mesos.entrypoint.MesosSessionClusterEntrypoint
-
- initializeServices(Configuration) - Method in class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
-
- initializeState(StateInitializationContext) - Method in class org.apache.flink.cep.operator.AbstractKeyedCEPPatternOperator
-
- initializeState(FunctionInitializationContext) - Method in interface org.apache.flink.streaming.api.checkpoint.CheckpointedFunction
-
This method is called when the parallel function instance is created during distributed
execution.
- initializeState(FunctionInitializationContext) - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
-
- initializeState(FunctionInitializationContext) - Method in class org.apache.flink.streaming.api.functions.source.ContinuousFileMonitoringFunction
-
- initializeState(StateInitializationContext) - Method in class org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperator
-
- initializeState(FunctionInitializationContext) - Method in class org.apache.flink.streaming.api.functions.source.FromElementsFunction
-
- initializeState(FunctionInitializationContext) - Method in class org.apache.flink.streaming.api.functions.source.MessageAcknowledgingSourceBase
-
- initializeState(FunctionInitializationContext) - Method in class org.apache.flink.streaming.api.functions.source.StatefulSequenceSource
-
- initializeState() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- initializeState(StateInitializationContext) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
Stream operators with state which can be restored need to override this hook method.
- initializeState(StateInitializationContext) - Method in class org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
-
- initializeState(StateInitializationContext) - Method in class org.apache.flink.streaming.api.operators.async.AsyncWaitOperator
-
- initializeState() - Method in interface org.apache.flink.streaming.api.operators.StreamOperator
-
Provides a context to initialize all state in the operator.
- initializeState(FunctionInitializationContext) - Method in class org.apache.flink.streaming.connectors.cassandra.CassandraSinkBase
-
- initializeState(FunctionInitializationContext) - Method in class org.apache.flink.streaming.connectors.elasticsearch.ElasticsearchSinkBase
-
- initializeState(FunctionInitializationContext) - Method in class org.apache.flink.streaming.connectors.fs.bucketing.BucketingSink
-
- initializeState(FunctionInitializationContext) - Method in class org.apache.flink.streaming.connectors.fs.RollingSink
-
Deprecated.
- initializeState(FunctionInitializationContext) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumerBase
-
- initializeState(FunctionInitializationContext) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer011
-
- initializeState(FunctionInitializationContext) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducerBase
-
- initializeState(StateInitializationContext) - Method in class org.apache.flink.streaming.runtime.operators.GenericWriteAheadSink
-
- initializeState(FunctionInitializationContext) - Method in class org.apache.flink.streaming.tests.artificialstate.ArtificalOperatorStateMapper
-
- initializeState(FunctionInitializationContext) - Method in class org.apache.flink.streaming.tests.artificialstate.ArtificialKeyedStateMapper
-
- initializeState(FunctionInitializationContext) - Method in class org.apache.flink.streaming.tests.SequenceGeneratorSource
-
- initializeTypeComparatorBuilder(int) - Method in interface org.apache.flink.api.common.typeutils.CompositeType.TypeComparatorBuilder
-
- initializeUserContext() - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
-
- initializeUserContext() - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer011
-
- initialPartitionBuffersCount - Variable in class org.apache.flink.runtime.operators.hash.ReOpenableHashPartition
-
- initId(int) - Method in class org.apache.flink.optimizer.dag.OptimizerNode
-
Sets the ID of this node.
- initInputReaders() - Method in class org.apache.flink.runtime.operators.BatchTask
-
- initInputsSerializersAndComparators(int, int) - Method in class org.apache.flink.runtime.operators.BatchTask
-
Creates all the serializers and comparators.
- initLocalStrategies(int) - Method in class org.apache.flink.runtime.operators.BatchTask
-
NOTE: This method must be invoked after the invocation of #initInputReaders()
and
#initInputSerializersAndComparators(int)
!
- initMax() - Method in class org.apache.flink.api.java.summarize.aggregation.DoubleSummaryAggregator
-
- initMax() - Method in class org.apache.flink.api.java.summarize.aggregation.FloatSummaryAggregator
-
- initMax() - Method in class org.apache.flink.api.java.summarize.aggregation.IntegerSummaryAggregator
-
- initMax() - Method in class org.apache.flink.api.java.summarize.aggregation.LongSummaryAggregator
-
- initMax() - Method in class org.apache.flink.api.java.summarize.aggregation.NumericSummaryAggregator
-
- initMax() - Method in class org.apache.flink.api.java.summarize.aggregation.ShortSummaryAggregator
-
- initMaxDepth() - Method in class org.apache.flink.optimizer.dag.DagConnection
-
- initMin() - Method in class org.apache.flink.api.java.summarize.aggregation.DoubleSummaryAggregator
-
- initMin() - Method in class org.apache.flink.api.java.summarize.aggregation.FloatSummaryAggregator
-
- initMin() - Method in class org.apache.flink.api.java.summarize.aggregation.IntegerSummaryAggregator
-
- initMin() - Method in class org.apache.flink.api.java.summarize.aggregation.LongSummaryAggregator
-
- initMin() - Method in class org.apache.flink.api.java.summarize.aggregation.NumericSummaryAggregator
-
- initMin() - Method in class org.apache.flink.api.java.summarize.aggregation.ShortSummaryAggregator
-
- initOutPathDistFS(Path, FileSystem.WriteMode, boolean) - Method in class org.apache.flink.core.fs.FileSystem
-
Initializes output directories on distributed file systems according to the given write mode.
- initOutPathDistFS(Path, FileSystem.WriteMode, boolean) - Method in class org.apache.flink.core.fs.SafetyNetWrapperFileSystem
-
- initOutPathLocalFS(Path, FileSystem.WriteMode, boolean) - Method in class org.apache.flink.core.fs.FileSystem
-
Initializes output directories on local file systems according to the given write mode.
- initOutPathLocalFS(Path, FileSystem.WriteMode, boolean) - Method in class org.apache.flink.core.fs.SafetyNetWrapperFileSystem
-
- initOutputs() - Method in class org.apache.flink.runtime.iterative.task.IterationHeadTask
-
- initOutputs() - Method in class org.apache.flink.runtime.operators.BatchTask
-
Creates a writer for each output.
- initOutputs(AbstractInvokable, ClassLoader, TaskConfig, List<ChainedDriver<?, ?>>, List<RecordWriter<?>>, ExecutionConfig, Map<String, Accumulator<?, ?>>) - Static method in class org.apache.flink.runtime.operators.BatchTask
-
Creates a writer for each output.
- initPrimitiveAggregator() - Method in class org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator.BooleanValueSummaryAggregator
-
- initPrimitiveAggregator() - Method in class org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator.DoubleValueSummaryAggregator
-
- initPrimitiveAggregator() - Method in class org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator.FloatValueSummaryAggregator
-
- initPrimitiveAggregator() - Method in class org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator
-
Initialize an aggregator that can be used for the underlying primitive in the Value type.
- initPrimitiveAggregator() - Method in class org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator.IntegerValueSummaryAggregator
-
- initPrimitiveAggregator() - Method in class org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator.LongValueSummaryAggregator
-
- initPrimitiveAggregator() - Method in class org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator.ShortValueSummaryAggregator
-
- initPrimitiveAggregator() - Method in class org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator.StringValueSummaryAggregator
-
- initProperties(GlobalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.plan.PlanNode
-
- initStub(Class<? super S>) - Method in class org.apache.flink.runtime.operators.BatchTask
-
- initSum() - Method in class org.apache.flink.api.java.summarize.aggregation.DoubleSummaryAggregator
-
- initSum() - Method in class org.apache.flink.api.java.summarize.aggregation.FloatSummaryAggregator
-
- initSum() - Method in class org.apache.flink.api.java.summarize.aggregation.IntegerSummaryAggregator
-
- initSum() - Method in class org.apache.flink.api.java.summarize.aggregation.LongSummaryAggregator
-
- initSum() - Method in class org.apache.flink.api.java.summarize.aggregation.NumericSummaryAggregator
-
- initSum() - Method in class org.apache.flink.api.java.summarize.aggregation.ShortSummaryAggregator
-
- initTable(int, byte) - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
-
- initTransactions() - Method in class org.apache.flink.streaming.connectors.kafka.internal.FlinkKafkaProducer
-
- InMemoryPartition<T> - Class in org.apache.flink.runtime.operators.hash
-
- InMemoryPartition(TypeSerializer<T>, int, ListMemorySegmentSource, int, int) - Constructor for class org.apache.flink.runtime.operators.hash.InMemoryPartition
-
Creates a new partition, in memory, with one buffer.
- InMemorySorter<T> - Interface in org.apache.flink.runtime.operators.sort
-
- InMemorySorterFactory<T> - Interface in org.apache.flink.runtime.operators.sort
-
- InMemorySpout<T> - Class in org.apache.flink.storm.util
-
Implements a Spout that reads data stored in memory.
- InMemorySpout(T[]) - Constructor for class org.apache.flink.storm.util.InMemorySpout
-
- InnerJoinOperatorBase<IN1,IN2,OUT,FT extends FlatJoinFunction<IN1,IN2,OUT>> - Class in org.apache.flink.api.common.operators.base
-
- InnerJoinOperatorBase(UserCodeWrapper<FT>, BinaryOperatorInformation<IN1, IN2, OUT>, int[], int[], String) - Constructor for class org.apache.flink.api.common.operators.base.InnerJoinOperatorBase
-
- InnerJoinOperatorBase(FT, BinaryOperatorInformation<IN1, IN2, OUT>, int[], int[], String) - Constructor for class org.apache.flink.api.common.operators.base.InnerJoinOperatorBase
-
- InnerJoinOperatorBase(Class<? extends FT>, BinaryOperatorInformation<IN1, IN2, OUT>, int[], int[], String) - Constructor for class org.apache.flink.api.common.operators.base.InnerJoinOperatorBase
-
- InnerPayLoad(long) - Constructor for class org.apache.flink.streaming.tests.artificialstate.ComplexPayload.InnerPayLoad
-
- InPlaceMutableHashTable<T> - Class in org.apache.flink.runtime.operators.hash
-
This hash table supports updating elements.
- InPlaceMutableHashTable(TypeSerializer<T>, TypeComparator<T>, List<MemorySegment>) - Constructor for class org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable
-
- InPlaceMutableHashTable.EntryIterator - Class in org.apache.flink.runtime.operators.hash
-
WARNING: Doing any other operation on the table invalidates the iterator! (Even
using getMatchFor of a prober!)
- InPlaceMutableHashTable.HashTableProber<PT> - Class in org.apache.flink.runtime.operators.hash
-
A prober for accessing the table.
- InPlaceMutableHashTable.ReduceFacade - Class in org.apache.flink.runtime.operators.hash
-
A facade for doing such operations on the hash table that are needed for a reduce operator driver.
- inProgress() - Static method in class org.apache.flink.runtime.rest.handler.async.AsynchronousOperationResult
-
- inProgress() - Static method in class org.apache.flink.runtime.rest.messages.job.JobExecutionResultResponseBody
-
- inProgress() - Static method in class org.apache.flink.runtime.rest.messages.queue.QueueStatus
-
- input - Variable in class org.apache.flink.api.common.operators.GenericDataSinkBase
-
- input - Variable in class org.apache.flink.api.common.operators.SingleInputOperator
-
The input which produces the data consumed by this operator.
- Input<K,VV,EV> - Interface in org.apache.flink.graph.drivers.input
-
- input - Variable in class org.apache.flink.optimizer.dag.DataSinkNode
-
- input - Variable in class org.apache.flink.optimizer.plan.SingleInputPlanNode
-
- input - Variable in class org.apache.flink.runtime.operators.resettable.NonReusingBlockResettableIterator
-
- input - Variable in class org.apache.flink.runtime.operators.resettable.SpillingResettableIterator
-
- input - Variable in class org.apache.flink.runtime.operators.resettable.SpillingResettableMutableObjectIterator
-
- input - Variable in class org.apache.flink.streaming.connectors.cassandra.CassandraSink.CassandraSinkBuilder
-
- input1 - Variable in class org.apache.flink.api.common.operators.DualInputOperator
-
The operator producing the first input.
- input1 - Variable in class org.apache.flink.api.java.operators.join.JoinOperatorSetsBase
-
- input1 - Variable in class org.apache.flink.optimizer.dag.TwoInputNode
-
- input1 - Variable in class org.apache.flink.optimizer.plan.DualInputPlanNode
-
- input2 - Variable in class org.apache.flink.api.common.operators.DualInputOperator
-
The operator producing the second input.
- input2 - Variable in class org.apache.flink.api.java.operators.join.JoinOperatorSetsBase
-
- input2 - Variable in class org.apache.flink.optimizer.dag.TwoInputNode
-
- input2 - Variable in class org.apache.flink.optimizer.plan.DualInputPlanNode
-
- INPUT_ENTER_PAGE - Static variable in class org.apache.flink.table.client.cli.CliStrings
-
- INPUT_ERROR - Static variable in class org.apache.flink.table.client.cli.CliStrings
-
- INPUT_FILE_PATH - Static variable in class org.apache.flink.storm.util.FileSpout
-
- INPUT_HELP - Static variable in class org.apache.flink.table.client.cli.CliStrings
-
- INPUT_PAIRS - Static variable in class org.apache.flink.streaming.examples.iteration.util.IterateExampleData
-
- INPUT_TITLE - Static variable in class org.apache.flink.table.client.cli.CliStrings
-
- InputBase<K,VV,EV> - Class in org.apache.flink.graph.drivers.input
-
Base class for inputs.
- InputBase() - Constructor for class org.apache.flink.graph.drivers.input.InputBase
-
- InputChannel - Class in org.apache.flink.runtime.io.network.partition.consumer
-
- InputChannel(SingleInputGate, int, ResultPartitionID, int, int, Counter, Counter) - Constructor for class org.apache.flink.runtime.io.network.partition.consumer.InputChannel
-
- InputChannel.BufferAndAvailability - Class in org.apache.flink.runtime.io.network.partition.consumer
-
A combination of a
Buffer
and a flag indicating availability of further buffers,
and the backlog length indicating how many non-event buffers are available in the
subpartition.
- InputChannelDeploymentDescriptor - Class in org.apache.flink.runtime.deployment
-
Deployment descriptor for a single input channel instance.
- InputChannelDeploymentDescriptor(ResultPartitionID, ResultPartitionLocation) - Constructor for class org.apache.flink.runtime.deployment.InputChannelDeploymentDescriptor
-
- InputChannelID - Class in org.apache.flink.runtime.io.network.partition.consumer
-
Identifier for input channels.
- InputChannelID() - Constructor for class org.apache.flink.runtime.io.network.partition.consumer.InputChannelID
-
- InputChannelID(long, long) - Constructor for class org.apache.flink.runtime.io.network.partition.consumer.InputChannelID
-
- InputChannelID(AbstractID) - Constructor for class org.apache.flink.runtime.io.network.partition.consumer.InputChannelID
-
- InputChannelStatus() - Constructor for class org.apache.flink.streaming.runtime.streamstatus.StatusWatermarkValve.InputChannelStatus
-
- inputComparators - Variable in class org.apache.flink.runtime.operators.BatchTask
-
The comparators for the central driver.
- inputDataSet - Variable in class org.apache.flink.api.java.operators.Grouping
-
- InputEndOfStreamException - Exception in org.apache.flink.runtime.checkpoint.decline
-
Exception indicating that a checkpoint was declined because one of the input
stream reached its end before the alignment was complete.
- InputEndOfStreamException() - Constructor for exception org.apache.flink.runtime.checkpoint.decline.InputEndOfStreamException
-
- InputFormat<OT,T extends InputSplit> - Interface in org.apache.flink.api.common.io
-
The base interface for data sources that produces records.
- InputFormatSourceFunction<OUT> - Class in org.apache.flink.streaming.api.functions.source
-
- InputFormatSourceFunction(InputFormat<OUT, ?>, TypeInformation<OUT>) - Constructor for class org.apache.flink.streaming.api.functions.source.InputFormatSourceFunction
-
- InputFormatVertex - Class in org.apache.flink.runtime.jobgraph
-
- InputFormatVertex(String) - Constructor for class org.apache.flink.runtime.jobgraph.InputFormatVertex
-
- InputFormatVertex(String, JobVertexID) - Constructor for class org.apache.flink.runtime.jobgraph.InputFormatVertex
-
- InputFormatVertex(String, JobVertexID, List<JobVertexID>, List<OperatorID>, List<OperatorID>) - Constructor for class org.apache.flink.runtime.jobgraph.InputFormatVertex
-
- inputGate - Variable in class org.apache.flink.runtime.io.network.api.reader.AbstractReader
-
The input gate to read from.
- inputGate - Variable in class org.apache.flink.runtime.io.network.partition.consumer.InputChannel
-
- InputGate - Interface in org.apache.flink.runtime.io.network.partition.consumer
-
An input gate consumes one or more partitions of a single produced intermediate result.
- InputGateDeploymentDescriptor - Class in org.apache.flink.runtime.deployment
-
Deployment descriptor for a single input gate instance.
- InputGateDeploymentDescriptor(IntermediateDataSetID, ResultPartitionType, int, InputChannelDeploymentDescriptor[]) - Constructor for class org.apache.flink.runtime.deployment.InputGateDeploymentDescriptor
-
- InputGateListener - Interface in org.apache.flink.runtime.io.network.partition.consumer
-
Listener interface implemented by consumers of
InputGate
instances
that want to be notified of availability of buffer or event instances.
- InputGateMetrics - Class in org.apache.flink.runtime.io.network.partition.consumer
-
Collects metrics of an input gate.
- InputGateUtil - Class in org.apache.flink.streaming.runtime.io
-
Utility for dealing with input gates.
- inputIterators - Variable in class org.apache.flink.runtime.operators.BatchTask
-
The inputs reader, wrapped in an iterator.
- InputMap() - Constructor for class org.apache.flink.streaming.examples.iteration.IterateExample.InputMap
-
- InputProcessorUtil - Class in org.apache.flink.streaming.runtime.io
-
- InputProcessorUtil() - Constructor for class org.apache.flink.streaming.runtime.io.InputProcessorUtil
-
- inputReaders - Variable in class org.apache.flink.runtime.operators.BatchTask
-
The input readers of this task.
- inputs - Variable in class org.apache.flink.runtime.operators.BatchTask
-
The inputs to the operator.
- inputSerializers - Variable in class org.apache.flink.runtime.operators.BatchTask
-
The serializers for the input data type.
- InputSplit - Interface in org.apache.flink.core.io
-
This interface must be implemented by all kind of input splits that can be assigned to input formats.
- InputSplitAssigner - Interface in org.apache.flink.core.io
-
An input split assigner distributes the
InputSplit
s among the instances on which a
data source exists.
- InputSplitOpenThread(FileInputSplit, long) - Constructor for class org.apache.flink.api.common.io.FileInputFormat.InputSplitOpenThread
-
- InputSplitProvider - Interface in org.apache.flink.runtime.jobgraph.tasks
-
An input split provider can be successively queried to provide a series of
InputSplit
objects a
task is supposed to consume in the course of its execution.
- InputSplitProviderException - Exception in org.apache.flink.runtime.jobgraph.tasks
-
- InputSplitProviderException(String) - Constructor for exception org.apache.flink.runtime.jobgraph.tasks.InputSplitProviderException
-
- InputSplitProviderException(String, Throwable) - Constructor for exception org.apache.flink.runtime.jobgraph.tasks.InputSplitProviderException
-
- InputSplitProviderException(Throwable) - Constructor for exception org.apache.flink.runtime.jobgraph.tasks.InputSplitProviderException
-
- InputSplitSource<T extends InputSplit> - Interface in org.apache.flink.core.io
-
- inputStream - Variable in class org.apache.flink.core.fs.FSDataInputStreamWrapper
-
- inputStream1 - Variable in class org.apache.flink.streaming.api.datastream.ConnectedStreams
-
- inputStream2 - Variable in class org.apache.flink.streaming.api.datastream.ConnectedStreams
-
- InputStreamFSInputWrapper - Class in org.apache.flink.api.common.io
-
- InputStreamFSInputWrapper(InputStream) - Constructor for class org.apache.flink.api.common.io.InputStreamFSInputWrapper
-
- inputStreamStatus(StreamStatus, int) - Method in class org.apache.flink.streaming.runtime.streamstatus.StatusWatermarkValve
-
- inputType - Variable in class org.apache.flink.api.common.operators.UnaryOperatorInformation
-
Input Type of the operator
- inputType1 - Variable in class org.apache.flink.api.common.operators.BinaryOperatorInformation
-
Input type of the first input
- inputType2 - Variable in class org.apache.flink.api.common.operators.BinaryOperatorInformation
-
Input type of the second input
- InputTypeConfigurable - Interface in org.apache.flink.api.java.typeutils
-
OutputFormat
s can implement this interface to be configured
with the data type they will operate on.
- inputView - Variable in class org.apache.flink.api.java.typeutils.runtime.DataInputViewStream
-
- InputViewIterator<E> - Class in org.apache.flink.runtime.io.disk
-
- InputViewIterator(DataInputView, TypeSerializer<E>) - Constructor for class org.apache.flink.runtime.io.disk.InputViewIterator
-
- inputWatermark(Watermark, int) - Method in class org.apache.flink.streaming.runtime.streamstatus.StatusWatermarkValve
-
- insert(T) - Method in class org.apache.flink.runtime.operators.hash.AbstractMutableHashTable
-
- insert(T) - Method in class org.apache.flink.runtime.operators.hash.CompactingHashTable
-
- insert(T) - Method in class org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable
-
Inserts the given record into the hash table.
- insertAfterNoMatch(T) - Method in class org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable.HashTableProber
-
This method can be called after getMatchFor returned null.
- insertIntoBuildBuffer(BT) - Method in class org.apache.flink.runtime.operators.hash.HashPartition
-
Inserts the given object into the current buffer.
- insertIntoProbeBuffer(PT) - Method in class org.apache.flink.runtime.operators.hash.HashPartition
-
Inserts the given record into the probe side buffers.
- insertIntoTable(BT, int) - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
-
- insertOrReplace(BT) - Method in class org.apache.flink.api.common.operators.util.JoinHashMap
-
- insertOrReplaceRecord(T) - Method in class org.apache.flink.runtime.operators.hash.AbstractMutableHashTable
-
- insertOrReplaceRecord(T) - Method in class org.apache.flink.runtime.operators.hash.CompactingHashTable
-
Replaces record in hash table if record already present or append record if not.
- insertOrReplaceRecord(T) - Method in class org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable
-
Searches the hash table for a record with the given key.
- install() - Method in class org.apache.flink.runtime.security.modules.HadoopModule
-
- install() - Method in class org.apache.flink.runtime.security.modules.JaasModule
-
- install() - Method in interface org.apache.flink.runtime.security.modules.SecurityModule
-
Install the security module.
- install() - Method in class org.apache.flink.runtime.security.modules.ZooKeeperModule
-
- install(SecurityConfiguration) - Static method in class org.apache.flink.runtime.security.SecurityUtils
-
Installs a process-wide security configuration.
- install(SecurityConfiguration, Map<String, TestingSecurityContext.ClientSecurityConfiguration>) - Static method in class org.apache.flink.test.util.TestingSecurityContext
-
- installAsShutdownHook(Logger) - Static method in class org.apache.flink.runtime.util.JvmShutdownSafeguard
-
Installs the safeguard shutdown hook.
- installAsShutdownHook(Logger, long) - Static method in class org.apache.flink.runtime.util.JvmShutdownSafeguard
-
Installs the safeguard shutdown hook.
- installSecurityContext(Configuration) - Method in class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
-
- installSecurityContext(Configuration, String) - Static method in class org.apache.flink.yarn.entrypoint.YarnEntrypointUtils
-
- installSecurityContext(Configuration) - Method in class org.apache.flink.yarn.entrypoint.YarnJobClusterEntrypoint
-
- installSecurityContext(Configuration) - Method in class org.apache.flink.yarn.entrypoint.YarnSessionClusterEntrypoint
-
- INSTANCE - Static variable in class org.apache.calcite.rel.rules.AggregateReduceFunctionsRule
-
The singleton.
- INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.array.BooleanPrimitiveArraySerializer
-
- INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.array.BytePrimitiveArraySerializer
-
- INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.array.CharPrimitiveArraySerializer
-
- INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.array.DoublePrimitiveArraySerializer
-
- INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.array.FloatPrimitiveArraySerializer
-
- INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.array.IntPrimitiveArraySerializer
-
- INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.array.LongPrimitiveArraySerializer
-
- INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.array.ShortPrimitiveArraySerializer
-
- INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.array.StringArraySerializer
-
- INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.BigDecSerializer
-
- INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.BigIntSerializer
-
- INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.BooleanSerializer
-
- INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.BooleanValueSerializer
-
- INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.ByteSerializer
-
- INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.ByteValueSerializer
-
- INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.CharSerializer
-
- INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.CharValueSerializer
-
- INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.DateSerializer
-
- INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.DoubleSerializer
-
- INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.DoubleValueSerializer
-
- INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.FloatSerializer
-
- INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.FloatValueSerializer
-
- INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.IntSerializer
-
- INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.IntValueSerializer
-
- INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.LongSerializer
-
- INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.LongValueSerializer
-
- INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.NullValueSerializer
-
- INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.ShortSerializer
-
- INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.ShortValueSerializer
-
- INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.SqlDateSerializer
-
- INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.SqlTimeSerializer
-
- INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.SqlTimestampSerializer
-
- INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.StringSerializer
-
- INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.StringValueSerializer
-
- INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.VoidSerializer
-
- INSTANCE - Static variable in class org.apache.flink.api.java.tuple.Tuple0
-
- INSTANCE - Static variable in class org.apache.flink.api.java.typeutils.runtime.Tuple0Serializer
-
- INSTANCE - Static variable in class org.apache.flink.client.program.DetachedEnvironment.DetachedJobExecutionResult
-
- INSTANCE - Static variable in class org.apache.flink.optimizer.util.NoOpUnaryUdfOp
-
- INSTANCE - Static variable in class org.apache.flink.queryablestate.client.VoidNamespace
-
The singleton instance.
- INSTANCE - Static variable in class org.apache.flink.queryablestate.client.VoidNamespaceSerializer
-
- INSTANCE - Static variable in class org.apache.flink.queryablestate.client.VoidNamespaceTypeInfo
-
- instance() - Static method in class org.apache.flink.runtime.broadcast.DefaultBroadcastVariableInitializer
-
- INSTANCE - Static variable in class org.apache.flink.runtime.checkpoint.RoundRobinOperatorStateRepartitioner
-
- INSTANCE - Static variable in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV1Serializer
-
- Instance - Class in org.apache.flink.runtime.instance
-
An instance represents a
TaskManager
registered at a JobManager and ready to receive work.
- Instance(TaskManagerGateway, TaskManagerLocation, InstanceID, HardwareDescription, int) - Constructor for class org.apache.flink.runtime.instance.Instance
-
Constructs an instance reflecting a registered TaskManager.
- INSTANCE - Static variable in class org.apache.flink.runtime.io.network.api.EndOfPartitionEvent
-
The singleton instance of this event.
- INSTANCE - Static variable in class org.apache.flink.runtime.io.network.api.EndOfSuperstepEvent
-
The singleton instance of this event.
- INSTANCE - Static variable in class org.apache.flink.runtime.io.network.buffer.FreeingBufferRecycler
-
- instance() - Static method in class org.apache.flink.runtime.iterative.concurrent.BlockingBackChannelBroker
-
Retrieve singleton instance.
- instance() - Static method in class org.apache.flink.runtime.iterative.concurrent.IterationAggregatorBroker
-
Retrieve singleton instance.
- instance() - Static method in class org.apache.flink.runtime.iterative.concurrent.SolutionSetBroker
-
Retrieve the singleton instance.
- instance() - Static method in class org.apache.flink.runtime.iterative.concurrent.SolutionSetUpdateBarrierBroker
-
- instance() - Static method in class org.apache.flink.runtime.iterative.concurrent.SuperstepKickoffLatchBroker
-
Retrieve the singleton instance.
- INSTANCE - Static variable in class org.apache.flink.runtime.iterative.event.TerminationEvent
-
- INSTANCE - Static variable in class org.apache.flink.runtime.metrics.NoOpMetricRegistry
-
- INSTANCE - Static variable in class org.apache.flink.runtime.state.SnappyStreamCompressionDecorator
-
- INSTANCE - Static variable in class org.apache.flink.runtime.state.UncompressedStreamCompressionDecorator
-
- INSTANCE - Static variable in class org.apache.flink.runtime.state.VoidNamespace
-
The singleton instance
- INSTANCE - Static variable in class org.apache.flink.runtime.state.VoidNamespaceSerializer
-
- INSTANCE - Static variable in class org.apache.flink.runtime.state.VoidNamespaceTypeInfo
-
- INSTANCE - Static variable in class org.apache.flink.runtime.util.FatalExitExceptionHandler
-
- INSTANCE - Static variable in class org.apache.flink.streaming.runtime.io.BlockingQueueBroker
-
Singleton instance.
- instanceDied(Instance) - Method in interface org.apache.flink.runtime.instance.InstanceListener
-
Called when an instance died.
- instanceDied(Instance) - Method in class org.apache.flink.runtime.jobmanager.scheduler.Scheduler
-
- InstanceDiedException - Exception in org.apache.flink.runtime.instance
-
A special instance signaling that an attempted operation on an instance is not possible,
because the instance has died.
- InstanceDiedException(Instance) - Constructor for exception org.apache.flink.runtime.instance.InstanceDiedException
-
- InstanceID - Class in org.apache.flink.runtime.instance
-
Class for statistically unique instance IDs.
- InstanceID() - Constructor for class org.apache.flink.runtime.instance.InstanceID
-
- InstanceID(byte[]) - Constructor for class org.apache.flink.runtime.instance.InstanceID
-
- InstanceListener - Interface in org.apache.flink.runtime.instance
-
Classes implementing the InstanceListener interface can be notified about
the availability disappearance of instances.
- InstanceManager - Class in org.apache.flink.runtime.instance
-
Simple manager that keeps track of which TaskManager are available and alive.
- InstanceManager() - Constructor for class org.apache.flink.runtime.instance.InstanceManager
-
Creates an new instance manager.
- instanceSize() - Method in class org.openjdk.jol.info.ClassLayout
-
- instantiate(Channel, SingleInputNode) - Method in class org.apache.flink.optimizer.dag.PartitionNode.PartitionDescriptor
-
- instantiate(Channel, SingleInputNode) - Method in class org.apache.flink.optimizer.dag.SortPartitionNode.SortPartitionDescriptor
-
- instantiate(OperatorDescriptorDual, Channel, Channel, List<Set<? extends NamedChannel>>, List<PlanNode>, CostEstimator, RequestedGlobalProperties, RequestedGlobalProperties, RequestedLocalProperties, RequestedLocalProperties) - Method in class org.apache.flink.optimizer.dag.TwoInputNode
-
- instantiate(OperatorDescriptorDual, Channel, Channel, List<Set<? extends NamedChannel>>, List<PlanNode>, CostEstimator, RequestedGlobalProperties, RequestedGlobalProperties, RequestedLocalProperties, RequestedLocalProperties) - Method in class org.apache.flink.optimizer.dag.WorksetIterationNode
-
- instantiate(Channel, Channel, TwoInputNode) - Method in class org.apache.flink.optimizer.operators.AbstractSortMergeJoinDescriptor
-
- instantiate(Channel, SingleInputNode) - Method in class org.apache.flink.optimizer.operators.AllGroupCombineProperties
-
- instantiate(Channel, SingleInputNode) - Method in class org.apache.flink.optimizer.operators.AllGroupReduceProperties
-
- instantiate(Channel, SingleInputNode) - Method in class org.apache.flink.optimizer.operators.AllGroupWithPartialPreGroupProperties
-
- instantiate(Channel, SingleInputNode) - Method in class org.apache.flink.optimizer.operators.AllReduceProperties
-
- instantiate(Channel, Channel, TwoInputNode) - Method in class org.apache.flink.optimizer.operators.BinaryUnionOpDescriptor
-
- instantiate(Channel, Channel, TwoInputNode) - Method in class org.apache.flink.optimizer.operators.CartesianProductDescriptor
-
- instantiate(Channel, Channel, TwoInputNode) - Method in class org.apache.flink.optimizer.operators.CoGroupDescriptor
-
- instantiate(Channel, Channel, TwoInputNode) - Method in class org.apache.flink.optimizer.operators.CoGroupRawDescriptor
-
- instantiate(Channel, Channel, TwoInputNode) - Method in class org.apache.flink.optimizer.operators.CoGroupWithSolutionSetFirstDescriptor
-
- instantiate(Channel, SingleInputNode) - Method in class org.apache.flink.optimizer.operators.FilterDescriptor
-
- instantiate(Channel, SingleInputNode) - Method in class org.apache.flink.optimizer.operators.FlatMapDescriptor
-
- instantiate(Channel, SingleInputNode) - Method in class org.apache.flink.optimizer.operators.GroupCombineProperties
-
- instantiate(Channel, SingleInputNode) - Method in class org.apache.flink.optimizer.operators.GroupReduceProperties
-
- instantiate(Channel, SingleInputNode) - Method in class org.apache.flink.optimizer.operators.GroupReduceWithCombineProperties
-
- instantiate(Channel, Channel, TwoInputNode) - Method in class org.apache.flink.optimizer.operators.HashFullOuterJoinBuildFirstDescriptor
-
- instantiate(Channel, Channel, TwoInputNode) - Method in class org.apache.flink.optimizer.operators.HashFullOuterJoinBuildSecondDescriptor
-
- instantiate(Channel, Channel, TwoInputNode) - Method in class org.apache.flink.optimizer.operators.HashJoinBuildFirstProperties
-
- instantiate(Channel, Channel, TwoInputNode) - Method in class org.apache.flink.optimizer.operators.HashJoinBuildSecondProperties
-
- instantiate(Channel, Channel, TwoInputNode) - Method in class org.apache.flink.optimizer.operators.HashLeftOuterJoinBuildFirstDescriptor
-
- instantiate(Channel, Channel, TwoInputNode) - Method in class org.apache.flink.optimizer.operators.HashLeftOuterJoinBuildSecondDescriptor
-
- instantiate(Channel, Channel, TwoInputNode) - Method in class org.apache.flink.optimizer.operators.HashRightOuterJoinBuildFirstDescriptor
-
- instantiate(Channel, Channel, TwoInputNode) - Method in class org.apache.flink.optimizer.operators.HashRightOuterJoinBuildSecondDescriptor
-
- instantiate(Channel, SingleInputNode) - Method in class org.apache.flink.optimizer.operators.MapDescriptor
-
- instantiate(Channel, SingleInputNode) - Method in class org.apache.flink.optimizer.operators.MapPartitionDescriptor
-
- instantiate(Channel, SingleInputNode) - Method in class org.apache.flink.optimizer.operators.NoOpDescriptor
-
- instantiate(Channel, Channel, TwoInputNode) - Method in class org.apache.flink.optimizer.operators.OperatorDescriptorDual
-
- instantiate(Channel, SingleInputNode) - Method in class org.apache.flink.optimizer.operators.OperatorDescriptorSingle
-
- instantiate(Channel, SingleInputNode) - Method in class org.apache.flink.optimizer.operators.PartialGroupProperties
-
- instantiate(Channel, SingleInputNode) - Method in class org.apache.flink.optimizer.operators.ReduceProperties
-
- instantiate(Channel, SingleInputNode) - Method in class org.apache.flink.optimizer.operators.SolutionSetDeltaOperator
-
- instantiate(Channel, Channel, TwoInputNode) - Method in class org.apache.flink.optimizer.operators.UtilSinkJoinOpDescriptor
-
- instantiate(Class<T>, Class<? super T>) - Static method in class org.apache.flink.util.InstantiationUtil
-
Creates a new instance of the given class.
- instantiate(Class<T>) - Static method in class org.apache.flink.util.InstantiationUtil
-
Creates a new instance of the given class.
- instantiateCandidate(OperatorDescriptorSingle, Channel, List<Set<? extends NamedChannel>>, List<PlanNode>, CostEstimator, RequestedGlobalProperties, RequestedLocalProperties) - Method in class org.apache.flink.optimizer.dag.BulkIterationNode
-
- instantiateCandidate(OperatorDescriptorSingle, Channel, List<Set<? extends NamedChannel>>, List<PlanNode>, CostEstimator, RequestedGlobalProperties, RequestedLocalProperties) - Method in class org.apache.flink.optimizer.dag.SingleInputNode
-
- instantiateDeserializationUtils() - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
-
- instantiateJobManagerMetricGroup(MetricRegistry, String) - Static method in class org.apache.flink.runtime.metrics.util.MetricUtils
-
- instantiateStatusMetrics(MetricGroup) - Static method in class org.apache.flink.runtime.metrics.util.MetricUtils
-
- instantiateTaskManagerMetricGroup(MetricRegistry, TaskManagerLocation, NetworkEnvironment) - Static method in class org.apache.flink.runtime.metrics.util.MetricUtils
-
- instantiateUserCode(TaskConfig, ClassLoader, Class<? super T>) - Static method in class org.apache.flink.runtime.operators.BatchTask
-
Instantiates a user code class from is definition in the task configuration.
- InstantiationUtil - Class in org.apache.flink.util
-
Utility class to create instances from class objects and checking failure reasons.
- InstantiationUtil.ClassLoaderObjectInputStream - Class in org.apache.flink.util
-
A custom ObjectInputStream that can load classes using a specific ClassLoader.
- InstantiationUtil.FailureTolerantObjectInputStream - Class in 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.
- INT - Static variable in class org.apache.flink.api.common.typeinfo.Types
-
Returns type information for both a primitive
int
and
Integer
.
- INT_ARRAY_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
-
- INT_PRIMITIVE_ARRAY_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
-
- INT_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
-
- INT_VALUE_ARRAY_TYPE_INFO - Static variable in class org.apache.flink.graph.types.valuearray.ValueArrayTypeInfo
-
- INT_VALUE_TYPE_INFO - Static variable in class org.apache.flink.api.java.typeutils.ValueTypeInfo
-
- IntArrayList - Class in org.apache.flink.runtime.util
-
Minimal implementation of an array-backed list of ints
- IntArrayList(int) - Constructor for class org.apache.flink.runtime.util.IntArrayList
-
- IntComparator - Class in org.apache.flink.api.common.typeutils.base
-
- IntComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.IntComparator
-
- IntCounter - Class in org.apache.flink.api.common.accumulators
-
An accumulator that sums up Integer
values.
- IntCounter() - Constructor for class org.apache.flink.api.common.accumulators.IntCounter
-
- IntCounter(int) - Constructor for class org.apache.flink.api.common.accumulators.IntCounter
-
- IntegerRanges() - Constructor for class org.apache.hadoop.conf.Configuration.IntegerRanges
-
- IntegerRanges(String) - Constructor for class org.apache.hadoop.conf.Configuration.IntegerRanges
-
- IntegerSummaryAggregator - Class in org.apache.flink.api.java.summarize.aggregation
-
Aggregator that can handle Integer types.
- IntegerSummaryAggregator() - Constructor for class org.apache.flink.api.java.summarize.aggregation.IntegerSummaryAggregator
-
- IntegerSummaryAggregator.MaxIntegerAggregator - Class in org.apache.flink.api.java.summarize.aggregation
-
Aggregator for max operation.
- IntegerSummaryAggregator.MinIntegerAggregator - Class in org.apache.flink.api.java.summarize.aggregation
-
Aggregator for min operation.
- IntegerSummaryAggregator.SumIntegerAggregator - Class in org.apache.flink.api.java.summarize.aggregation
-
Aggregator for sum operation.
- IntegerTypeInfo<T> - Class in org.apache.flink.api.common.typeinfo
-
Type information for numeric integer primitive types: int, long, byte, short, character.
- IntegerTypeInfo(Class<T>, Class<?>[], TypeSerializer<T>, Class<? extends TypeComparator<T>>) - Constructor for class org.apache.flink.api.common.typeinfo.IntegerTypeInfo
-
- IntegerValueSummaryAggregator() - Constructor for class org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator.IntegerValueSummaryAggregator
-
- InterestingProperties - Class in org.apache.flink.optimizer.dataproperties
-
Interesting properties are propagated from parent operators to child operators.
- InterestingProperties() - Constructor for class org.apache.flink.optimizer.dataproperties.InterestingProperties
-
- InterestingPropertyVisitor - Class in org.apache.flink.optimizer.traversals
-
Visitor that computes the interesting properties for each node in the optimizer DAG.
- InterestingPropertyVisitor(CostEstimator) - Constructor for class org.apache.flink.optimizer.traversals.InterestingPropertyVisitor
-
Creates a new visitor that computes the interesting properties for all nodes in the plan.
- IntermediateDataSet - Class in org.apache.flink.runtime.jobgraph
-
An intermediate data set is the data set produced by an operator - either a
source or any intermediate operation.
- IntermediateDataSet(IntermediateDataSetID, ResultPartitionType, JobVertex) - Constructor for class org.apache.flink.runtime.jobgraph.IntermediateDataSet
-
- IntermediateDataSetID - Class in org.apache.flink.runtime.jobgraph
-
- IntermediateDataSetID() - Constructor for class org.apache.flink.runtime.jobgraph.IntermediateDataSetID
-
Creates an new random intermediate data set ID.
- IntermediateDataSetID(AbstractID) - Constructor for class org.apache.flink.runtime.jobgraph.IntermediateDataSetID
-
Creates a new intermediate data set ID with the bytes of the given ID.
- IntermediateDataSetID(UUID) - Constructor for class org.apache.flink.runtime.jobgraph.IntermediateDataSetID
-
Creates a new intermediate data set ID with the bytes of the given UUID.
- IntermediateResult - Class in org.apache.flink.runtime.executiongraph
-
- IntermediateResult(IntermediateDataSetID, ExecutionJobVertex, int, ResultPartitionType) - Constructor for class org.apache.flink.runtime.executiongraph.IntermediateResult
-
- IntermediateResultPartition - Class in org.apache.flink.runtime.executiongraph
-
- IntermediateResultPartition(IntermediateResult, ExecutionVertex, int) - Constructor for class org.apache.flink.runtime.executiongraph.IntermediateResultPartition
-
- IntermediateResultPartitionID - Class in org.apache.flink.runtime.jobgraph
-
- IntermediateResultPartitionID() - Constructor for class org.apache.flink.runtime.jobgraph.IntermediateResultPartitionID
-
Creates an new random intermediate result partition ID.
- IntermediateResultPartitionID(long, long) - Constructor for class org.apache.flink.runtime.jobgraph.IntermediateResultPartitionID
-
- IntermediateSampleData<T> - Class in org.apache.flink.api.java.sampling
-
The data structure which is transferred between partitions and the coordinator for distributed
random sampling.
- IntermediateSampleData(double, T) - Constructor for class org.apache.flink.api.java.sampling.IntermediateSampleData
-
- Internal - Annotation Type in org.apache.flink.annotation
-
Interface to mark methods within stable, public APIs as an internal developer API.
- InternalAggregateProcessAllWindowFunction<T,ACC,V,R,W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing.functions
-
- InternalAggregateProcessAllWindowFunction(AggregateFunction<T, ACC, V>, ProcessAllWindowFunction<V, R, W>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalAggregateProcessAllWindowFunction
-
- InternalAggregateProcessWindowFunction<T,ACC,V,R,K,W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing.functions
-
- InternalAggregateProcessWindowFunction(AggregateFunction<T, ACC, V>, ProcessWindowFunction<V, R, K, W>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalAggregateProcessWindowFunction
-
- InternalAggregatingState<K,N,IN,SV,OUT> - Interface in org.apache.flink.runtime.state.internal
-
- InternalAppendingState<K,N,IN,SV,OUT> - Interface in org.apache.flink.runtime.state.internal
-
- internalDeregisterApplication(ApplicationStatus, String) - Method in class org.apache.flink.mesos.runtime.clusterframework.MesosResourceManager
-
- internalDeregisterApplication(ApplicationStatus, String) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
-
The framework specific code to deregister the application.
- internalDeregisterApplication(ApplicationStatus, String) - Method in class org.apache.flink.runtime.resourcemanager.StandaloneResourceManager
-
- internalDeregisterApplication(ApplicationStatus, String) - Method in class org.apache.flink.yarn.YarnResourceManager
-
- InternalFoldingState<K,N,T,ACC> - Interface in org.apache.flink.runtime.state.internal
-
- internalHandleException(IOException) - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.ThreadBase
-
Internally handles an exception and makes sure that this method returns without a problem.
- InternalIterableAllWindowFunction<IN,OUT,W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing.functions
-
Internal window function for wrapping an
AllWindowFunction
that takes an
Iterable
when the window state also is an
Iterable
.
- InternalIterableAllWindowFunction(AllWindowFunction<IN, OUT, W>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableAllWindowFunction
-
- InternalIterableProcessAllWindowFunction<IN,OUT,W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing.functions
-
Internal window function for wrapping a
ProcessAllWindowFunction
that takes an
Iterable
when the window state also is an
Iterable
.
- InternalIterableProcessAllWindowFunction(ProcessAllWindowFunction<IN, OUT, W>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableProcessAllWindowFunction
-
- InternalIterableProcessWindowFunction<IN,OUT,KEY,W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing.functions
-
Internal window function for wrapping a
ProcessWindowFunction
that takes an
Iterable
when the window state also is an
Iterable
.
- InternalIterableProcessWindowFunction(ProcessWindowFunction<IN, OUT, KEY, W>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableProcessWindowFunction
-
- InternalIterableWindowFunction<IN,OUT,KEY,W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing.functions
-
Internal window function for wrapping a
WindowFunction
that takes an
Iterable
when the window state also is an
Iterable
.
- InternalIterableWindowFunction(WindowFunction<IN, OUT, KEY, W>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableWindowFunction
-
- InternalKeyContext<K> - Interface in org.apache.flink.runtime.state.heap
-
This interface is the current context of a keyed state.
- InternalKvState<K,N,V> - Interface in org.apache.flink.runtime.state.internal
-
The
InternalKvState
is the root of the internal state type hierarchy, similar to the
State
being the root of the public API state hierarchy.
- InternalListState<K,N,T> - Interface in org.apache.flink.runtime.state.internal
-
The peer to the
ListState
in the internal state type hierarchy.
- InternalMapState<K,N,UK,UV> - Interface in org.apache.flink.runtime.state.internal
-
The peer to the
MapState
in the internal state type hierarchy.
- InternalMergingState<K,N,IN,SV,OUT> - Interface in org.apache.flink.runtime.state.internal
-
The peer to the
MergingState
in the internal state type hierarchy.
- internalNioBuffer(int, int) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
-
- InternalProcessAllWindowContext<IN,OUT,W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing.functions
-
Internal reusable context wrapper.
- InternalProcessApplyAllWindowContext<IN,OUT,W extends Window> - Class in org.apache.flink.streaming.api.functions.windowing
-
Internal reusable context wrapper.
- InternalProcessApplyWindowContext<IN,OUT,KEY,W extends Window> - Class in org.apache.flink.streaming.api.functions.windowing
-
Internal reusable context wrapper.
- InternalProcessWindowContext<IN,OUT,KEY,W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing.functions
-
Internal reusable context wrapper.
- InternalReducingState<K,N,T> - Interface in org.apache.flink.runtime.state.internal
-
The peer to the
ReducingState
in the internal state type hierarchy.
- InternalSingleValueAllWindowFunction<IN,OUT,W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing.functions
-
Internal window function for wrapping an
AllWindowFunction
that takes an
Iterable
when the window state is a single value.
- InternalSingleValueAllWindowFunction(AllWindowFunction<IN, OUT, W>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueAllWindowFunction
-
- InternalSingleValueProcessAllWindowFunction<IN,OUT,W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing.functions
-
Internal window function for wrapping a
ProcessAllWindowFunction
that takes an
Iterable
when the window state is a single value.
- InternalSingleValueProcessAllWindowFunction(ProcessAllWindowFunction<IN, OUT, W>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueProcessAllWindowFunction
-
- InternalSingleValueProcessWindowFunction<IN,OUT,KEY,W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing.functions
-
Internal window function for wrapping a
ProcessWindowFunction
that takes an
Iterable
when the window state is a single value.
- InternalSingleValueProcessWindowFunction(ProcessWindowFunction<IN, OUT, KEY, W>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueProcessWindowFunction
-
- InternalSingleValueWindowFunction<IN,OUT,KEY,W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing.functions
-
Internal window function for wrapping a
WindowFunction
that takes an
Iterable
when the window state is a single value.
- InternalSingleValueWindowFunction(WindowFunction<IN, OUT, KEY, W>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueWindowFunction
-
- InternalTimer<K,N> - Class in org.apache.flink.streaming.api.operators
-
Internal class for keeping track of in-flight timers.
- InternalTimer(long, K, N) - Constructor for class org.apache.flink.streaming.api.operators.InternalTimer
-
- InternalTimer.TimerSerializer<K,N> - Class in org.apache.flink.streaming.api.operators
-
- InternalTimerService<N> - Interface in org.apache.flink.streaming.api.operators
-
Interface for working with time and timers.
- internalTimerService - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
- internalTimerServiceManager() - Method in interface org.apache.flink.streaming.api.operators.StreamOperatorStateContext
-
Returns the internal timer service manager for the stream operator.
- InternalTimerServiceSerializationProxy<K,N> - Class in org.apache.flink.streaming.api.operators
-
Serialization proxy for the timer services for a given key-group.
- InternalTimerServiceSerializationProxy(Map<String, HeapInternalTimerService<K, N>>, ClassLoader, int, KeyGroupsList, KeyContext, ProcessingTimeService, int) - Constructor for class org.apache.flink.streaming.api.operators.InternalTimerServiceSerializationProxy
-
Constructor to use when restoring timer services.
- InternalTimerServiceSerializationProxy(Map<String, HeapInternalTimerService<K, N>>, int) - Constructor for class org.apache.flink.streaming.api.operators.InternalTimerServiceSerializationProxy
-
Constructor to use when writing timer services.
- InternalTimersSnapshot<K,N> - Class in org.apache.flink.streaming.api.operators
-
A snapshot of internal timers, containing event and processing timers and
the serializers to use to write / read them.
- InternalTimersSnapshot() - Constructor for class org.apache.flink.streaming.api.operators.InternalTimersSnapshot
-
Empty constructor used when restoring the timers.
- InternalTimersSnapshot(TypeSerializer<K>, TypeSerializerConfigSnapshot, TypeSerializer<N>, TypeSerializerConfigSnapshot, Set<InternalTimer<K, N>>, Set<InternalTimer<K, N>>) - Constructor for class org.apache.flink.streaming.api.operators.InternalTimersSnapshot
-
Constructor to use when snapshotting the timers.
- InternalTimersSnapshotReaderWriters - Class in org.apache.flink.streaming.api.operators
-
- InternalTimersSnapshotReaderWriters() - Constructor for class org.apache.flink.streaming.api.operators.InternalTimersSnapshotReaderWriters
-
- InternalTimersSnapshotReaderWriters.InternalTimersSnapshotReader<K,N> - Interface in org.apache.flink.streaming.api.operators
-
- InternalTimersSnapshotReaderWriters.InternalTimersSnapshotWriter - Interface in org.apache.flink.streaming.api.operators
-
- InternalTimeServiceManager<K,N> - Class in org.apache.flink.streaming.api.operators
-
An entity keeping all the time-related services available to all operators extending the
AbstractStreamOperator
.
- internalTimeServiceManager(AbstractKeyedStateBackend<K>, KeyContext, Iterable<KeyGroupStatePartitionStreamProvider>) - Method in class org.apache.flink.streaming.api.operators.StreamTaskStateInitializerImpl
-
- InternalValueState<K,N,T> - Interface in org.apache.flink.runtime.state.internal
-
The peer to the
ValueState
in the internal state type hierarchy.
- InternalWindowFunction<IN,OUT,KEY,W extends Window> - Interface in org.apache.flink.streaming.runtime.operators.windowing.functions
-
Internal interface for functions that are evaluated over keyed (grouped) windows.
- InternalWindowFunction.InternalWindowContext - Interface in org.apache.flink.streaming.runtime.operators.windowing.functions
-
- InterpreterUtils - Class in org.apache.flink.streaming.python.util
-
A collection of utility methods for interacting with jython.
- intersect(Graph<K, VV, EV>, boolean) - Method in class org.apache.flink.graph.Graph
-
Performs intersect on the edge sets of the input graphs.
- intersects(TimeWindow) - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow
-
Returns true
if this window intersects the given window.
- intervalDayTimeToString(long, TimeUnitRange, int) - Static method in class org.apache.calcite.avatica.util.DateTimeUtils
-
- intervalYearMonthToString(int, TimeUnitRange) - Static method in class org.apache.calcite.avatica.util.DateTimeUtils
-
- IntMaximum - Class in org.apache.flink.api.common.accumulators
-
An accumulator that finds the maximum integer
value.
- IntMaximum() - Constructor for class org.apache.flink.api.common.accumulators.IntMaximum
-
- IntMaximum(int) - Constructor for class org.apache.flink.api.common.accumulators.IntMaximum
-
- IntMinimum - Class in org.apache.flink.api.common.accumulators
-
An accumulator that finds the minimum integer
value.
- IntMinimum() - Constructor for class org.apache.flink.api.common.accumulators.IntMinimum
-
- IntMinimum(int) - Constructor for class org.apache.flink.api.common.accumulators.IntMinimum
-
- IntParser - Class in org.apache.flink.types.parser
-
Parses a decimal text field into a IntValue.
- IntParser() - Constructor for class org.apache.flink.types.parser.IntParser
-
- IntPrimitiveArrayComparator - Class in org.apache.flink.api.common.typeutils.base.array
-
- IntPrimitiveArrayComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.array.IntPrimitiveArrayComparator
-
- IntPrimitiveArraySerializer - Class in org.apache.flink.api.common.typeutils.base.array
-
A serializer for int arrays.
- IntPrimitiveArraySerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.array.IntPrimitiveArraySerializer
-
- IntSerializer - Class in org.apache.flink.api.common.typeutils.base
-
- IntSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.IntSerializer
-
- IntSerializer() - Constructor for class org.apache.flink.python.api.streaming.util.SerializationUtils.IntSerializer
-
- IntValue - Class in org.apache.flink.types
-
Boxed serializable and comparable integer type, representing the primitive
type int
.
- IntValue() - Constructor for class org.apache.flink.types.IntValue
-
Initializes the encapsulated int with 0.
- IntValue(int) - Constructor for class org.apache.flink.types.IntValue
-
Initializes the encapsulated int with the provided value.
- IntValueArray - Class in org.apache.flink.graph.types.valuearray
-
- IntValueArray() - Constructor for class org.apache.flink.graph.types.valuearray.IntValueArray
-
Initializes an expandable array with default capacity.
- IntValueArray(int) - Constructor for class org.apache.flink.graph.types.valuearray.IntValueArray
-
Initializes a fixed-size array with the provided number of bytes.
- IntValueArrayComparator - Class in org.apache.flink.graph.types.valuearray
-
Specialized comparator for IntValueArray based on CopyableValueComparator.
- IntValueArrayComparator(boolean) - Constructor for class org.apache.flink.graph.types.valuearray.IntValueArrayComparator
-
- IntValueArraySerializer - Class in org.apache.flink.graph.types.valuearray
-
Specialized serializer for IntValueArray
.
- IntValueArraySerializer() - Constructor for class org.apache.flink.graph.types.valuearray.IntValueArraySerializer
-
- IntValueComparator - Class in org.apache.flink.api.common.typeutils.base
-
Specialized comparator for IntValue based on CopyableValueComparator.
- IntValueComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.IntValueComparator
-
- IntValueParser - Class in org.apache.flink.types.parser
-
Parses a decimal text field into a IntValue.
- IntValueParser() - Constructor for class org.apache.flink.types.parser.IntValueParser
-
- IntValueSerializer - Class in org.apache.flink.api.common.typeutils.base
-
- IntValueSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.IntValueSerializer
-
- InvalidateMessenger(Edge<Long, Double>) - Constructor for class org.apache.flink.graph.examples.IncrementalSSSP.InvalidateMessenger
-
- InvalidFieldReferenceException(String) - Constructor for exception org.apache.flink.api.common.typeutils.CompositeType.InvalidFieldReferenceException
-
- invalidLineCount - Variable in class org.apache.flink.api.common.io.GenericCsvInputFormat
-
- InvalidProgramException - Exception in org.apache.flink.api.common
-
An exception thrown to indicate that the composed program is invalid.
- InvalidProgramException() - Constructor for exception org.apache.flink.api.common.InvalidProgramException
-
Creates a new exception with no message.
- InvalidProgramException(String) - Constructor for exception org.apache.flink.api.common.InvalidProgramException
-
Creates a new exception with the given message.
- InvalidProgramException(String, Throwable) - Constructor for exception org.apache.flink.api.common.InvalidProgramException
-
Creates a new exception with the given message and cause.
- InvalidSemanticAnnotationException(String) - Constructor for exception org.apache.flink.api.common.operators.SemanticProperties.InvalidSemanticAnnotationException
-
- InvalidSemanticAnnotationException(String, Throwable) - Constructor for exception org.apache.flink.api.common.operators.SemanticProperties.InvalidSemanticAnnotationException
-
- InvalidTypesException - Exception in org.apache.flink.api.common.functions
-
A special case of the
InvalidProgramException
, indicating that the types used in
an operation are invalid or inconsistent.
- InvalidTypesException() - Constructor for exception org.apache.flink.api.common.functions.InvalidTypesException
-
Creates a new exception with no message.
- InvalidTypesException(String) - Constructor for exception org.apache.flink.api.common.functions.InvalidTypesException
-
Creates a new exception with the given message.
- InvalidTypesException(String, Throwable) - Constructor for exception org.apache.flink.api.common.functions.InvalidTypesException
-
- InvalidVertexIdsValidator<K,VV,EV> - Class in org.apache.flink.graph.validation
-
Validate that the edge set vertex IDs exist in the vertex set.
- InvalidVertexIdsValidator() - Constructor for class org.apache.flink.graph.validation.InvalidVertexIdsValidator
-
- invertNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.array.PrimitiveArrayComparator
-
- invertNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.BasicTypeComparator
-
- invertNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueComparator
-
- invertNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.ByteValueComparator
-
- invertNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.CharValueComparator
-
- invertNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueComparator
-
- invertNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.FloatValueComparator
-
- invertNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.IntValueComparator
-
- invertNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.LongValueComparator
-
- invertNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.NullValueComparator
-
- invertNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.ShortValueComparator
-
- invertNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.StringValueComparator
-
- invertNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.TypeComparator
-
Flag whether normalized key comparisons should be inverted key should be interpreted
inverted, i.e.
- invertNormalizedKey() - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueComparator
-
- invertNormalizedKey() - Method in class org.apache.flink.api.java.typeutils.runtime.GenericTypeComparator
-
- invertNormalizedKey() - Method in class org.apache.flink.api.java.typeutils.runtime.NullAwareComparator
-
- invertNormalizedKey() - Method in class org.apache.flink.api.java.typeutils.runtime.PojoComparator
-
- invertNormalizedKey() - Method in class org.apache.flink.api.java.typeutils.runtime.RowComparator
-
- invertNormalizedKey() - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
-
- invertNormalizedKey() - Method in class org.apache.flink.api.java.typeutils.runtime.ValueComparator
-
- invertNormalizedKey() - Method in class org.apache.flink.api.java.typeutils.runtime.WritableComparator
-
- invertNormalizedKey() - Method in class org.apache.flink.graph.types.valuearray.ByteValueArrayComparator
-
- invertNormalizedKey() - Method in class org.apache.flink.graph.types.valuearray.CharValueArrayComparator
-
- invertNormalizedKey() - Method in class org.apache.flink.graph.types.valuearray.DoubleValueArrayComparator
-
- invertNormalizedKey() - Method in class org.apache.flink.graph.types.valuearray.FloatValueArrayComparator
-
- invertNormalizedKey() - Method in class org.apache.flink.graph.types.valuearray.IntValueArrayComparator
-
- invertNormalizedKey() - Method in class org.apache.flink.graph.types.valuearray.LongValueArrayComparator
-
- invertNormalizedKey() - Method in class org.apache.flink.graph.types.valuearray.NullValueArrayComparator
-
- invertNormalizedKey() - Method in class org.apache.flink.graph.types.valuearray.ShortValueArrayComparator
-
- invertNormalizedKey() - Method in class org.apache.flink.graph.types.valuearray.StringValueArrayComparator
-
- invertNormKey - Variable in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
-
- inView - Variable in class org.apache.flink.runtime.operators.resettable.SpillingResettableIterator
-
- inView - Variable in class org.apache.flink.runtime.operators.resettable.SpillingResettableMutableObjectIterator
-
- invoke() - Method in class org.apache.flink.runtime.iterative.task.IterationSynchronizationSinkTask
-
- invoke() - Method in class org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
-
Starts the execution.
- invoke() - Method in class org.apache.flink.runtime.operators.BatchTask
-
The main work method.
- invoke() - Method in class org.apache.flink.runtime.operators.DataSinkTask
-
- invoke() - Method in class org.apache.flink.runtime.operators.DataSourceTask
-
- invoke(Object, Method, Object[]) - Method in class org.apache.flink.runtime.rpc.akka.FencedAkkaInvocationHandler
-
- invoke(T) - Method in class org.apache.flink.streaming.api.functions.sink.DiscardingSink
-
- invoke(IN) - Method in class org.apache.flink.streaming.api.functions.sink.OutputFormatSinkFunction
-
Deprecated.
- invoke(IN) - Method in class org.apache.flink.streaming.api.functions.sink.PrintSinkFunction
-
- invoke(IN) - Method in interface org.apache.flink.streaming.api.functions.sink.SinkFunction
-
- invoke(IN, SinkFunction.Context) - Method in interface org.apache.flink.streaming.api.functions.sink.SinkFunction
-
Writes the given value to the sink.
- invoke(IN) - Method in class org.apache.flink.streaming.api.functions.sink.SocketClientSink
-
Called when new data arrives to the sink, and forwards it to Socket.
- invoke(TXN, IN, SinkFunction.Context) - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
-
Write value within a transaction.
- invoke(IN) - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
-
This should not be implemented by subclasses.
- invoke(IN, SinkFunction.Context) - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
-
- invoke(IN) - Method in class org.apache.flink.streaming.api.functions.sink.WriteSinkFunction
-
Deprecated.
Implementation of the invoke method of the SinkFunction class.
- invoke(IN) - Method in class org.apache.flink.streaming.connectors.cassandra.CassandraSinkBase
-
- invoke(T) - Method in class org.apache.flink.streaming.connectors.elasticsearch.ElasticsearchSinkBase
-
- invoke(T) - Method in class org.apache.flink.streaming.connectors.fs.bucketing.BucketingSink
-
- invoke(T) - Method in class org.apache.flink.streaming.connectors.fs.RollingSink
-
Deprecated.
- invoke(T, SinkFunction.Context) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer010
-
- invoke(FlinkKafkaProducer011.KafkaTransactionState, IN, SinkFunction.Context) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer011
-
- invoke(IN, SinkFunction.Context) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducerBase
-
Called when new data arrives to the sink, and forwards it to Kafka.
- invoke(T) - Method in class org.apache.flink.streaming.connectors.nifi.NiFiSink
-
- invoke(IN) - Method in class org.apache.flink.streaming.connectors.rabbitmq.RMQSink
-
Called when new data arrives to the sink, and forwards it to RMQ.
- invoke(IN, SinkFunction.Context) - Method in class org.apache.flink.streaming.experimental.CollectSink
-
- invoke(PyObject, SinkFunction.Context) - Method in class org.apache.flink.streaming.python.api.functions.PythonSinkFunction
-
- invoke() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- invokeInteractiveModeForExecution() - Method in class org.apache.flink.client.program.PackagedProgram
-
This method assumes that the context environment is prepared, or the execution
will be a local execution by default.
- invokeRegistration(G, F, long) - Method in class org.apache.flink.runtime.registration.RetryingRegistration
-
- IO_CURRENT_INPUT_1_WATERMARK - Static variable in class org.apache.flink.runtime.metrics.MetricNames
-
- IO_CURRENT_INPUT_2_WATERMARK - Static variable in class org.apache.flink.runtime.metrics.MetricNames
-
- IO_CURRENT_INPUT_WATERMARK - Static variable in class org.apache.flink.runtime.metrics.MetricNames
-
- IO_CURRENT_OUTPUT_WATERMARK - Static variable in class org.apache.flink.runtime.metrics.MetricNames
-
- IO_NUM_BUFFERS_IN - Static variable in class org.apache.flink.runtime.metrics.MetricNames
-
- IO_NUM_BUFFERS_IN_LOCAL - Static variable in class org.apache.flink.runtime.metrics.MetricNames
-
- IO_NUM_BUFFERS_IN_LOCAL_RATE - Static variable in class org.apache.flink.runtime.metrics.MetricNames
-
- IO_NUM_BUFFERS_IN_REMOTE - Static variable in class org.apache.flink.runtime.metrics.MetricNames
-
- IO_NUM_BUFFERS_IN_REMOTE_RATE - Static variable in class org.apache.flink.runtime.metrics.MetricNames
-
- IO_NUM_BUFFERS_OUT - Static variable in class org.apache.flink.runtime.metrics.MetricNames
-
- IO_NUM_BUFFERS_OUT_RATE - Static variable in class org.apache.flink.runtime.metrics.MetricNames
-
- IO_NUM_BYTES_IN - Static variable in class org.apache.flink.runtime.metrics.MetricNames
-
- IO_NUM_BYTES_IN_LOCAL - Static variable in class org.apache.flink.runtime.metrics.MetricNames
-
- IO_NUM_BYTES_IN_LOCAL_RATE - Static variable in class org.apache.flink.runtime.metrics.MetricNames
-
- IO_NUM_BYTES_IN_REMOTE - Static variable in class org.apache.flink.runtime.metrics.MetricNames
-
- IO_NUM_BYTES_IN_REMOTE_RATE - Static variable in class org.apache.flink.runtime.metrics.MetricNames
-
- IO_NUM_BYTES_OUT - Static variable in class org.apache.flink.runtime.metrics.MetricNames
-
- IO_NUM_BYTES_OUT_RATE - Static variable in class org.apache.flink.runtime.metrics.MetricNames
-
- IO_NUM_RECORDS_IN - Static variable in class org.apache.flink.runtime.metrics.MetricNames
-
- IO_NUM_RECORDS_IN_RATE - Static variable in class org.apache.flink.runtime.metrics.MetricNames
-
- IO_NUM_RECORDS_OUT - Static variable in class org.apache.flink.runtime.metrics.MetricNames
-
- IO_NUM_RECORDS_OUT_RATE - Static variable in class org.apache.flink.runtime.metrics.MetricNames
-
- ioBuffer() - Method in class org.apache.flink.queryablestate.network.NettyBufferPool
-
- ioBuffer(int) - Method in class org.apache.flink.queryablestate.network.NettyBufferPool
-
- ioBuffer(int, int) - Method in class org.apache.flink.queryablestate.network.NettyBufferPool
-
- IOManager - Class in org.apache.flink.runtime.io.disk.iomanager
-
The facade for the provided I/O manager services.
- IOManager(String[]) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.IOManager
-
Constructs a new IOManager.
- ioManager - Variable in class org.apache.flink.runtime.operators.hash.MutableHashTable
-
The I/O manager used to instantiate writers for the spilled partitions.
- ioManager - Variable in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SpillingThread
-
- IOManager.IOMode - Enum in org.apache.flink.runtime.io.disk.iomanager
-
- IOManagerAsync - Class in org.apache.flink.runtime.io.disk.iomanager
-
A version of the
IOManager
that uses asynchronous I/O.
- IOManagerAsync() - Constructor for class org.apache.flink.runtime.io.disk.iomanager.IOManagerAsync
-
Constructs a new asynchronous I/O manger, writing files to the system 's temp directory.
- IOManagerAsync(String) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.IOManagerAsync
-
Constructs a new asynchronous I/O manger, writing file to the given directory.
- IOManagerAsync(String[]) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.IOManagerAsync
-
Constructs a new asynchronous I/O manger, writing file round robin across the given directories.
- IOMetrics - Class in org.apache.flink.runtime.executiongraph
-
An instance of this class represents a snapshot of the io-related metrics of a single task.
- IOMetrics(Meter, Meter, Meter, Meter, Meter) - Constructor for class org.apache.flink.runtime.executiongraph.IOMetrics
-
- IOMetrics(long, long, long, long, long, double, double, double, double, double) - Constructor for class org.apache.flink.runtime.executiongraph.IOMetrics
-
- IOMetricsInfo - Class in org.apache.flink.runtime.rest.messages.job.metrics
-
IO metrics information.
- IOMetricsInfo(long, boolean, long, boolean, long, boolean, long, boolean) - Constructor for class org.apache.flink.runtime.rest.messages.job.metrics.IOMetricsInfo
-
- ioMode() - Method in class org.apache.flink.runtime.taskmanager.NetworkEnvironmentConfiguration
-
- IOReadableWritable - Interface in org.apache.flink.core.io
-
This interface must be implemented by every class whose objects have to be serialized to their binary representation
and vice-versa.
- IOUtils - Class in org.apache.flink.util
-
An utility class for I/O related functionality.
- ipAddressAndPortToUrlString(InetAddress, int) - Static method in class org.apache.flink.util.NetUtils
-
Encodes an IP address and port to be included in URL.
- ipAddressToUrlString(InetAddress) - Static method in class org.apache.flink.util.NetUtils
-
Encodes an IP address properly as a URL string.
- IPC_PORT - Static variable in class org.apache.flink.configuration.ResourceManagerOptions
-
- isAbsolute() - Method in class org.apache.flink.core.fs.Path
-
Checks if the directory of this path is absolute.
- isAcknowledgedBy(ExecutionAttemptID) - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
-
- isActive(CommandLine) - Method in interface org.apache.flink.client.cli.CustomCommandLine
-
Signals whether the custom command-line wants to execute or not.
- isActive(CommandLine) - Method in class org.apache.flink.client.cli.DefaultCLI
-
- isActive(CommandLine) - Method in class org.apache.flink.client.cli.LegacyCLI
-
- isActive(JobID, AllocationID) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlot
-
- isActive() - Method in class org.apache.flink.streaming.runtime.streamstatus.StreamStatus
-
- isActive(CommandLine) - Method in class org.apache.flink.yarn.cli.FlinkYarnSessionCli
-
- isAlive() - Method in class org.apache.flink.runtime.instance.Instance
-
- isAlive() - Method in class org.apache.flink.runtime.instance.Slot
-
Checks of the slot is still alive, i.e.
- isAlive() - Method in interface org.apache.flink.runtime.jobmaster.LogicalSlot
-
True if the slot is alive and has not been released.
- isAlive() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SingleLogicalSlot
-
- isAllocated(JobID, AllocationID) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlot
-
- isAllocated(int, JobID, AllocationID) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
-
Check whether the slot for the given index is allocated for the given job and allocation id.
- isAmbiguousKeyPossible(TypeSerializer, TypeSerializer) - Static method in class org.apache.flink.contrib.streaming.state.RocksDBKeySerializationUtils
-
- isArchived() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionGraph
-
Returns whether this execution graph was archived.
- isArchived() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
-
- isArchived() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- isAssigned() - Method in class org.apache.flink.runtime.jobmanager.scheduler.CoLocationConstraint
-
Checks whether the location of this constraint has been assigned.
- isAssigned() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.PendingSlotRequest
-
- isAssignedAndAlive() - Method in class org.apache.flink.runtime.jobmanager.scheduler.CoLocationConstraint
-
- isAutomaticRecovery() - Method in class org.apache.flink.streaming.connectors.rabbitmq.common.RMQConnectionConfig
-
Returns true if automatic connection recovery is enabled, false otherwise.
- isAutoTypeRegistrationDisabled() - Method in class org.apache.flink.api.common.ExecutionConfig
-
- isAvailable() - Method in interface org.apache.flink.runtime.io.network.NetworkSequenceViewReader
-
Checks whether this reader is available or not.
- isAvailable() - Method in interface org.apache.flink.runtime.io.network.partition.ResultSubpartitionView
-
- isBasicType() - Method in class org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
-
- isBasicType() - Method in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
-
- isBasicType() - Method in class org.apache.flink.api.common.typeinfo.NothingTypeInfo
-
- isBasicType() - Method in class org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
-
- isBasicType() - Method in class org.apache.flink.api.common.typeinfo.SqlTimeTypeInfo
-
- isBasicType() - Method in class org.apache.flink.api.common.typeinfo.TypeInformation
-
Checks if this type information represents a basic type.
- isBasicType() - Method in class org.apache.flink.api.java.typeutils.EitherTypeInfo
-
- isBasicType() - Method in class org.apache.flink.api.java.typeutils.EnumTypeInfo
-
- isBasicType() - Method in class org.apache.flink.api.java.typeutils.GenericTypeInfo
-
- isBasicType() - Method in class org.apache.flink.api.java.typeutils.ListTypeInfo
-
- isBasicType() - Method in class org.apache.flink.api.java.typeutils.MapTypeInfo
-
- isBasicType() - Method in class org.apache.flink.api.java.typeutils.MissingTypeInfo
-
- isBasicType() - Method in class org.apache.flink.api.java.typeutils.ObjectArrayTypeInfo
-
- isBasicType() - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo
-
- isBasicType() - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfoBase
-
- isBasicType() - Method in class org.apache.flink.api.java.typeutils.ValueTypeInfo
-
- isBasicType() - Method in class org.apache.flink.api.java.typeutils.WritableTypeInfo
-
- isBasicType() - Method in class org.apache.flink.graph.drivers.transform.LongValueWithProperHashCode.LongValueWithProperHashCodeTypeInfo
-
- isBasicType() - Method in class org.apache.flink.graph.types.valuearray.ValueArrayTypeInfo
-
- isBasicType() - Method in class org.apache.flink.queryablestate.client.VoidNamespaceTypeInfo
-
- isBasicType() - Method in class org.apache.flink.runtime.state.VoidNamespaceTypeInfo
-
- isBasicValueType() - Method in class org.apache.flink.api.java.typeutils.ValueTypeInfo
-
- isBatchExecution() - Method in class org.apache.flink.table.client.config.Execution
-
- isBlocking() - Method in enum org.apache.flink.runtime.io.network.partition.ResultPartitionType
-
- isBotEdit() - Method in class org.apache.flink.streaming.connectors.wikiedits.WikipediaEditEvent
-
- isBounded() - Method in enum org.apache.flink.runtime.io.network.partition.ResultPartitionType
-
Whether this partition uses a limited number of (network) buffers or not.
- isBranching() - Method in class org.apache.flink.optimizer.dag.OptimizerNode
-
Checks whether this node has branching output.
- isBreakingPipeline() - Method in class org.apache.flink.optimizer.dag.DagConnection
-
Checks whether this connection is marked to break the pipeline.
- isBuffer() - Method in class org.apache.flink.runtime.io.disk.iomanager.FileSegment
-
- isBuffer() - Method in interface org.apache.flink.runtime.io.network.buffer.Buffer
-
Returns whether this buffer represents a buffer or an event.
- isBuffer() - Method in class org.apache.flink.runtime.io.network.buffer.BufferConsumer
-
- isBuffer() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
-
- isBuffer() - Method in class org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
-
- isBuffer() - Method in class org.apache.flink.runtime.io.network.partition.consumer.BufferOrEvent
-
- isBufferConsumed() - Method in enum org.apache.flink.runtime.io.network.api.serialization.RecordDeserializer.DeserializationResult
-
- isBytesReadComplete() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.IOMetricsInfo
-
- isBytesWrittenComplete() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.IOMetricsInfo
-
- isCached() - Method in enum org.apache.flink.optimizer.dag.TempMode
-
- isCallByValue() - Method in class org.apache.flink.api.java.sca.TaggedValue
-
- isCalled() - Method in class org.apache.flink.runtime.io.async.AbstractAsyncCallableWithResources
-
True once the async method was called.
- isCanceled() - Method in class org.apache.flink.runtime.instance.Slot
-
Checks of the slot has been cancelled.
- isCanceled() - Method in class org.apache.flink.runtime.registration.RetryingRegistration
-
Checks if the registration was canceled.
- isCanceled() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- isCanceledOrFailed() - Method in class org.apache.flink.runtime.taskmanager.Task
-
Checks whether the task has failed, is canceled, or is being canceled at the moment.
- isCanceledOrStopped() - Method in class org.apache.flink.streaming.api.operators.StreamSource
-
Checks whether the source has been canceled or stopped.
- isCancelJob() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointTriggerRequestBody
-
- isCancelled() - Method in class org.apache.flink.runtime.state.DoneFuture
-
- isCaseClass() - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfoBase
-
- isCastableToDefinedType(String) - Method in class org.apache.flink.api.java.utils.Option
-
- isChainable(StreamEdge, StreamGraph) - Static method in class org.apache.flink.streaming.api.graph.StreamingJobGraphGenerator
-
- isChainEnd() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- isChainingEnabled - Variable in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- isChainingEnabled() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Returns whether operator chaining is enabled.
- isChainingEnabled() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- isChainStart() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- isChangelogMode() - Method in class org.apache.flink.table.client.config.Execution
-
- isCheckpointCommitted(int, long) - Method in class org.apache.flink.streaming.connectors.cassandra.CassandraCommitter
-
- isCheckpointCommitted(int, long) - Method in class org.apache.flink.streaming.runtime.operators.CheckpointCommitter
-
Checked the resource whether the given checkpoint was committed completely.
- isCheckpointingEnabled() - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Checks whether checkpointing is enabled.
- isCheckpointingEnabled() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- isCheckpointingEnabled() - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
-
Returns true if checkpointing is enabled for the running job.
- isClassType(Type) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractionUtils
-
Checks if a type can be converted to a Class.
- isCleanupTime(W, long) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
Returns true
if the given time is the cleanup time for the given window.
- isClientConnected() - Method in class org.apache.flink.runtime.client.JobClientActor
-
- isCloseableRegistered(Closeable) - Method in class org.apache.flink.util.AbstractCloseableRegistry
-
- isClosed() - Method in class org.apache.flink.core.fs.ClosingFSDataInputStream
-
- isClosed() - Method in class org.apache.flink.core.fs.ClosingFSDataOutputStream
-
- isClosed() - Method in class org.apache.flink.runtime.blob.BlobClient
-
- isClosed() - Method in class org.apache.flink.runtime.io.disk.iomanager.AbstractFileIOChannel
-
- isClosed() - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousFileIOChannel
-
- isClosed() - Method in class org.apache.flink.runtime.io.disk.iomanager.ChannelReaderInputView
-
- isClosed() - Method in interface org.apache.flink.runtime.io.disk.iomanager.FileIOChannel
-
Checks whether the channel has been closed.
- isClosed() - Method in class org.apache.flink.runtime.io.disk.iomanager.RequestQueue
-
Checks whether this request queue is closed.
- isClosed() - Method in class org.apache.flink.runtime.io.disk.iomanager.SynchronousFileIOChannel
-
- isClosed() - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
-
- isClosed() - Method in class org.apache.flink.runtime.registration.RegisteredRpcConnection
-
- isClosed() - Method in class org.apache.flink.runtime.state.filesystem.FileBasedStateOutputStream
-
- isClosed() - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointMetadataOutputStream
-
- isClosed() - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStreamFactory.FsCheckpointStateOutputStream
-
Checks whether the stream is closed.
- isClosed() - Method in class org.apache.flink.runtime.state.memory.MemCheckpointStreamFactory.MemoryCheckpointOutputStream
-
- isClosed() - Method in class org.apache.flink.util.AbstractCloseableRegistry
-
- isClosed() - Method in class org.apache.flink.util.ResourceGuard
-
Returns true if the resource guard is closed, i.e.
- isClosed() - Method in class org.apache.flink.yarn.highavailability.YarnHighAvailabilityServices
-
Checks whether these services have been shut down.
- isClosureCleanerEnabled() - Method in class org.apache.flink.api.common.ExecutionConfig
-
Returns whether the ClosureCleaner is enabled.
- isCollectionExecution() - Method in class org.apache.flink.test.util.JavaProgramTestBase
-
- isCollector() - Method in class org.apache.flink.api.java.sca.TaggedValue
-
- isCombinable() - Method in class org.apache.flink.api.common.operators.base.GroupReduceOperatorBase
-
Checks whether the operation is combinable.
- isCombinable() - Method in class org.apache.flink.api.java.operators.GroupReduceOperator
-
- isCombinableFirst() - Method in class org.apache.flink.api.common.operators.base.CoGroupOperatorBase
-
- isCombinableFirst() - Method in class org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase
-
- isCombinableSecond() - Method in class org.apache.flink.api.common.operators.base.CoGroupOperatorBase
-
- isCombinableSecond() - Method in class org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase
-
- isCombineable() - Method in class org.apache.flink.optimizer.dag.GroupReduceNode
-
Checks, whether a combiner function has been given for the function encapsulated
by this reduce contract.
- isCompacted() - Method in class org.apache.flink.runtime.operators.hash.InMemoryPartition
-
- isCompatibleSerializationFormatIdentifier(String) - Method in class org.apache.flink.api.common.typeutils.base.BooleanSerializer
-
- isCompatibleSerializationFormatIdentifier(String) - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueSerializer
-
- isCompatibleSerializationFormatIdentifier(String) - Method in class org.apache.flink.api.common.typeutils.base.ByteSerializer
-
- isCompatibleSerializationFormatIdentifier(String) - Method in class org.apache.flink.api.common.typeutils.base.ByteValueSerializer
-
- isCompatibleSerializationFormatIdentifier(String) - Method in class org.apache.flink.api.common.typeutils.base.CharSerializer
-
- isCompatibleSerializationFormatIdentifier(String) - Method in class org.apache.flink.api.common.typeutils.base.CharValueSerializer
-
- isCompatibleSerializationFormatIdentifier(String) - Method in class org.apache.flink.api.common.typeutils.base.DateSerializer
-
- isCompatibleSerializationFormatIdentifier(String) - Method in class org.apache.flink.api.common.typeutils.base.DoubleSerializer
-
- isCompatibleSerializationFormatIdentifier(String) - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueSerializer
-
- isCompatibleSerializationFormatIdentifier(String) - Method in class org.apache.flink.api.common.typeutils.base.FloatSerializer
-
- isCompatibleSerializationFormatIdentifier(String) - Method in class org.apache.flink.api.common.typeutils.base.FloatValueSerializer
-
- isCompatibleSerializationFormatIdentifier(String) - Method in class org.apache.flink.api.common.typeutils.base.IntSerializer
-
- isCompatibleSerializationFormatIdentifier(String) - Method in class org.apache.flink.api.common.typeutils.base.IntValueSerializer
-
- isCompatibleSerializationFormatIdentifier(String) - Method in class org.apache.flink.api.common.typeutils.base.LongSerializer
-
- isCompatibleSerializationFormatIdentifier(String) - Method in class org.apache.flink.api.common.typeutils.base.LongValueSerializer
-
- isCompatibleSerializationFormatIdentifier(String) - Method in class org.apache.flink.api.common.typeutils.base.ShortSerializer
-
- isCompatibleSerializationFormatIdentifier(String) - Method in class org.apache.flink.api.common.typeutils.base.ShortValueSerializer
-
- isCompatibleSerializationFormatIdentifier(String) - Method in class org.apache.flink.api.common.typeutils.base.SqlDateSerializer
-
- isCompatibleSerializationFormatIdentifier(String) - Method in class org.apache.flink.api.common.typeutils.base.SqlTimeSerializer
-
- isCompatibleSerializationFormatIdentifier(String) - Method in class org.apache.flink.api.common.typeutils.base.StringSerializer
-
- isCompatibleSerializationFormatIdentifier(String) - Method in class org.apache.flink.api.common.typeutils.base.StringValueSerializer
-
- isCompatibleSerializationFormatIdentifier(String) - Method in class org.apache.flink.api.common.typeutils.base.TypeSerializerSingleton
-
Subclasses can override this if they know that they are also compatible with identifiers of other formats.
- isCompatibleSerializationFormatIdentifier(String) - Method in class org.apache.flink.graph.drivers.transform.LongValueWithProperHashCode.LongValueWithProperHashCodeSerializer
-
- isCompatibleSerializationFormatIdentifier(String) - Method in class org.apache.flink.graph.types.valuearray.ByteValueArraySerializer
-
- isCompatibleSerializationFormatIdentifier(String) - Method in class org.apache.flink.graph.types.valuearray.CharValueArraySerializer
-
- isCompatibleSerializationFormatIdentifier(String) - Method in class org.apache.flink.graph.types.valuearray.DoubleValueArraySerializer
-
- isCompatibleSerializationFormatIdentifier(String) - Method in class org.apache.flink.graph.types.valuearray.FloatValueArraySerializer
-
- isCompatibleSerializationFormatIdentifier(String) - Method in class org.apache.flink.graph.types.valuearray.IntValueArraySerializer
-
- isCompatibleSerializationFormatIdentifier(String) - Method in class org.apache.flink.graph.types.valuearray.LongValueArraySerializer
-
- isCompatibleSerializationFormatIdentifier(String) - Method in class org.apache.flink.graph.types.valuearray.ShortValueArraySerializer
-
- isCompatibleSerializationFormatIdentifier(String) - Method in class org.apache.flink.graph.types.valuearray.StringValueArraySerializer
-
- isCompatibleWith(DeweyNumber) - Method in class org.apache.flink.cep.nfa.DeweyNumber
-
Checks whether this dewey number is compatible to the other dewey number.
- isCompleted() - Method in enum org.apache.flink.runtime.checkpoint.CheckpointStatsStatus
-
Returns whether the checkpoint has completed successfully.
- isComputablyPartitioned() - Method in enum org.apache.flink.optimizer.dataproperties.PartitioningProperty
-
Checks, if this property represents a partitioning that is computable.
- isConnected() - Method in class org.apache.flink.runtime.registration.RegisteredRpcConnection
-
- isConsumable() - Method in class org.apache.flink.runtime.executiongraph.IntermediateResultPartition
-
- isContainer() - Method in class org.apache.flink.api.java.sca.TaggedValue
-
- isConverged(int, T) - Method in interface org.apache.flink.api.common.aggregators.ConvergenceCriterion
-
Decide whether the iterative algorithm has converged
- isConverged(int, DoubleValue) - Method in class org.apache.flink.api.common.aggregators.DoubleZeroConvergence
-
Returns true, if the aggregator value is zero, false otherwise.
- isConverged(int, LongValue) - Method in class org.apache.flink.api.common.aggregators.LongZeroConvergence
-
Returns true, if the aggregator value is zero, false otherwise.
- isConverged(int, LongValue) - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase.TerminationCriterionAggregationConvergence
-
- isConverged(int, LongValue) - Method in class org.apache.flink.runtime.iterative.convergence.WorksetEmptyConvergenceCriterion
-
- isCreditBased() - Method in class org.apache.flink.runtime.io.network.NetworkEnvironment
-
- isCreditBasedEnabled() - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
-
- isDataSet(int) - Method in class org.apache.flink.python.api.util.SetCache
-
Checks whether the cached set for the given ID is a
DataSet
.
- isDefaultOverwriteFiles() - Method in class org.apache.flink.client.LocalExecutor
-
- isDefaultReference() - Method in class org.apache.flink.runtime.state.CheckpointStorageLocationReference
-
Returns true, if this object is the default reference.
- isDeprecated(String) - Static method in class org.apache.hadoop.conf.Configuration
-
checks whether the given key
is deprecated.
- isDestroyed() - Method in interface org.apache.flink.runtime.io.network.buffer.BufferPool
-
Checks whether this buffer pool has been destroyed.
- isDestroyed() - Method in interface org.apache.flink.runtime.io.network.buffer.BufferProvider
-
Returns whether the buffer provider has been destroyed.
- isDestroyed() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
-
- isDetached() - Method in class org.apache.flink.client.program.ClusterClient
-
A flag to indicate whether this clients submits jobs detached.
- isDetached() - Method in class org.apache.flink.yarn.YarnClusterClient
-
- isDetachedMode() - Method in class org.apache.flink.yarn.AbstractYarnClusterDescriptor
-
- isDir() - Method in interface org.apache.flink.core.fs.FileStatus
-
Checks if this object represents a directory.
- isDir() - Method in class org.apache.flink.core.fs.local.LocalFileStatus
-
- isDir() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileStatus
-
- isDirect() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
-
- isDirectBufferPooled() - Method in class org.apache.flink.queryablestate.network.NettyBufferPool
-
- isDiscarded() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpointStats
-
Returns whether the checkpoint has been discarded.
- isDiscarded() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
-
- isDiscarded() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics.CompletedCheckpointStatistics
-
- isDispose() - Method in class org.apache.flink.client.cli.SavepointOptions
-
- isDisposed() - Method in class org.apache.flink.runtime.util.AtomicDisposableReferenceCounter
-
Returns whether the reference count has reached the disposed state.
- isDistributedFS() - Method in class org.apache.flink.core.fs.FileSystem
-
Returns true if this is a distributed file system.
- isDistributedFS() - Method in class org.apache.flink.core.fs.LimitedConnectionsFileSystem
-
- isDistributedFS() - Method in class org.apache.flink.core.fs.local.LocalFileSystem
-
- isDistributedFS() - Method in class org.apache.flink.core.fs.SafetyNetWrapperFileSystem
-
- isDistributedFS() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileSystem
-
- isDone() - Method in class org.apache.flink.runtime.state.DoneFuture
-
- isDone() - Method in class org.apache.flink.streaming.api.operators.async.queue.StreamElementQueueEntry
-
True if the stream element queue entry has been completed; otherwise false.
- isDummy() - Method in class org.apache.flink.api.java.typeutils.runtime.KryoRegistration
-
- isElementLate(StreamRecord<IN>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
Decide if a record is currently late, based on current watermark and allowed lateness.
- isEmpty() - Method in class org.apache.flink.api.common.operators.Keys
-
- isEmpty() - Method in class org.apache.flink.cep.nfa.NFA
-
Check if the NFA has finished processing all incoming data so far.
- isEmpty() - Method in class org.apache.flink.cep.nfa.SharedBuffer
-
- isEmpty() - Method in class org.apache.flink.runtime.checkpoint.StateObjectCollection
-
- isEmpty() - Method in class org.apache.flink.runtime.jobmaster.SerializedInputSplit
-
- isEmpty() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotSharingManager
-
- isEmpty() - Method in class org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
-
Checks whether the buffer is empty.
- isEmpty() - Method in interface org.apache.flink.runtime.operators.sort.InMemorySorter
-
Checks whether the buffer is empty.
- isEmpty() - Method in class org.apache.flink.runtime.operators.sort.NormalizedKeySorter
-
Checks whether the buffer is empty.
- isEmpty() - Method in class org.apache.flink.runtime.state.ChainedStateHandle
-
Check if there are any states handles present.
- isEmpty() - Method in class org.apache.flink.runtime.state.heap.StateTable
-
- isEmpty() - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlot
-
- isEmpty() - Method in class org.apache.flink.runtime.util.EvictingBoundedList
-
- isEmpty() - Method in class org.apache.flink.runtime.util.IntArrayList
-
- isEmpty() - Method in class org.apache.flink.runtime.util.LongArrayList
-
- isEmpty() - Method in class org.apache.flink.storm.util.StormConfig
-
- isEmpty() - Method in class org.apache.flink.streaming.api.operators.async.queue.OrderedStreamElementQueue
-
- isEmpty() - Method in interface org.apache.flink.streaming.api.operators.async.queue.StreamElementQueue
-
True if the queue is empty; otherwise false.
- isEmpty() - Method in class org.apache.flink.streaming.api.operators.async.queue.UnorderedStreamElementQueue
-
- isEmpty() - Method in class org.apache.flink.streaming.connectors.kafka.internals.ClosableBlockingQueue
-
Checks whether the queue is empty (has no elements).
- isEmpty() - Method in class org.apache.flink.streaming.runtime.io.BarrierBuffer
-
- isEmpty() - Method in class org.apache.flink.streaming.runtime.io.BarrierTracker
-
- isEmpty() - Method in interface org.apache.flink.streaming.runtime.io.CheckpointBarrierHandler
-
Checks if the barrier handler has buffered any data internally.
- isEmpty() - Method in class org.apache.flink.streaming.runtime.operators.windowing.KeyMap
-
Checks whether the map is empty.
- isEmpty() - Method in class org.apache.flink.types.ListValue
-
- isEmpty() - Method in class org.apache.flink.types.MapValue
-
- isEmpty() - Method in class org.apache.hadoop.conf.Configuration.IntegerRanges
-
- isEncodeForHTML() - Method in class org.apache.flink.optimizer.plandump.PlanJSONDumpGenerator
-
- isEndOfInput() - Method in class org.apache.flink.queryablestate.network.ChunkedByteBuf
-
- isEndOfStream(T) - Method in class org.apache.flink.api.common.serialization.AbstractDeserializationSchema
-
Method to decide whether the element signals the end of the stream.
- isEndOfStream(T) - Method in interface org.apache.flink.api.common.serialization.DeserializationSchema
-
Method to decide whether the element signals the end of the stream.
- isEndOfStream(String) - Method in class org.apache.flink.api.common.serialization.SimpleStringSchema
-
- isEndOfStream(T) - Method in class org.apache.flink.api.common.serialization.TypeInformationSerializationSchema
-
This schema never considers an element to signal end-of-stream, so this method returns always false.
- isEndOfStream(Row) - Method in class org.apache.flink.formats.json.JsonRowDeserializationSchema
-
- isEndOfStream(KafkaEvent) - Method in class org.apache.flink.streaming.examples.kafka.KafkaEventSchema
-
- isEndOfStream(Event) - Method in class org.apache.flink.streaming.examples.statemachine.kafka.EventDeSerializer
-
- isEndOfStream(T) - Method in interface org.apache.flink.streaming.util.serialization.DeserializationSchema
-
Deprecated.
Method to decide whether the element signals the end of the stream.
- isEndOfStream(ObjectNode) - Method in class org.apache.flink.streaming.util.serialization.JSONKeyValueDeserializationSchema
-
- isEndOfStream(T) - Method in interface org.apache.flink.streaming.util.serialization.KeyedDeserializationSchema
-
Method to decide whether the element signals the end of the stream.
- isEndOfStream(T) - Method in class org.apache.flink.streaming.util.serialization.KeyedDeserializationSchemaWrapper
-
- isEndOfStream(Tuple2<K, V>) - Method in class org.apache.flink.streaming.util.serialization.TypeInformationKeyValueSerializationSchema
-
This schema never considers an element to signal end-of-stream, so this method returns always false.
- isEndOfSuperstep() - Method in class org.apache.flink.runtime.iterative.task.SyncEventHandler
-
- isEvent(Buffer, Class<?>) - Static method in class org.apache.flink.runtime.io.network.api.serialization.EventSerializer
-
Identifies whether the given buffer encodes the given event.
- isEvent() - Method in class org.apache.flink.runtime.io.network.partition.consumer.BufferOrEvent
-
- isEventGroupShutdown() - Method in class org.apache.flink.queryablestate.network.AbstractServerBase
-
- isEventGroupShutdown() - Method in class org.apache.flink.queryablestate.network.Client
-
- isEventTime() - Method in class org.apache.flink.streaming.api.windowing.assigners.BaseAlignedWindowAssigner
-
- isEventTime() - Method in class org.apache.flink.streaming.api.windowing.assigners.DynamicEventTimeSessionWindows
-
- isEventTime() - Method in class org.apache.flink.streaming.api.windowing.assigners.DynamicProcessingTimeSessionWindows
-
- isEventTime() - Method in class org.apache.flink.streaming.api.windowing.assigners.EventTimeSessionWindows
-
- isEventTime() - Method in class org.apache.flink.streaming.api.windowing.assigners.GlobalWindows
-
- isEventTime() - Method in class org.apache.flink.streaming.api.windowing.assigners.ProcessingTimeSessionWindows
-
- isEventTime() - Method in class org.apache.flink.streaming.api.windowing.assigners.SlidingEventTimeWindows
-
- isEventTime() - Method in class org.apache.flink.streaming.api.windowing.assigners.SlidingProcessingTimeWindows
-
- isEventTime() - Method in class org.apache.flink.streaming.api.windowing.assigners.TumblingEventTimeWindows
-
- isEventTime() - Method in class org.apache.flink.streaming.api.windowing.assigners.TumblingProcessingTimeWindows
-
- isEventTime() - Method in class org.apache.flink.streaming.api.windowing.assigners.WindowAssigner
-
Returns true
if elements are assigned to windows based on event time,
false
otherwise.
- isExactlyOnce() - Method in class org.apache.flink.runtime.jobgraph.tasks.CheckpointCoordinatorConfiguration
-
- isExactlyPartitionedOnFields(FieldList) - Method in class org.apache.flink.optimizer.dataproperties.GlobalProperties
-
- isExactMatch(FieldList) - Method in class org.apache.flink.api.common.operators.util.FieldList
-
- isExecutable - Variable in class org.apache.flink.api.common.cache.DistributedCache.DistributedCacheEntry
-
- isExternalizedCheckpointsEnabled() - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Returns whether checkpoints should be persisted externally.
- isExtremal(Comparable<R>, R) - Method in class org.apache.flink.streaming.api.functions.aggregation.Comparator
-
- isFailed() - Method in enum org.apache.flink.runtime.checkpoint.CheckpointStatsStatus
-
Returns whether the checkpoint has failed.
- isFailOnCheckpointingErrors() - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
This determines the behaviour of tasks if there is an error in their local checkpointing.
- isFailTaskOnCheckpointError() - Method in class org.apache.flink.api.common.ExecutionConfig
-
This method is visible because of the way the configuration is currently forwarded from the checkpoint config to
the task.
- isFailure() - Method in class org.apache.flink.runtime.checkpoint.CheckpointTriggerResult
-
- isFailure() - Method in class org.apache.flink.util.OptionalFailure
-
- isFilterPushedDown() - Method in class org.apache.flink.orc.OrcTableSource
-
- isFinal() - Method in class org.apache.flink.cep.nfa.State
-
- isFinalState() - Method in class org.apache.flink.cep.nfa.ComputationState
-
- isFinished() - Method in class org.apache.flink.runtime.executiongraph.Execution
-
- isFinished() - Method in class org.apache.flink.runtime.io.network.api.reader.AbstractReader
-
- isFinished() - Method in interface org.apache.flink.runtime.io.network.api.reader.ReaderBase
-
Returns whether the reader has consumed the input.
- isFinished() - Method in class org.apache.flink.runtime.io.network.buffer.BufferBuilder
-
- isFinished() - Method in class org.apache.flink.runtime.io.network.buffer.BufferConsumer
-
- isFinished() - Method in interface org.apache.flink.runtime.io.network.partition.consumer.InputGate
-
- isFinished() - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
-
- isFinished() - Method in class org.apache.flink.runtime.io.network.partition.consumer.UnionInputGate
-
- isFire() - Method in enum org.apache.flink.streaming.api.windowing.triggers.TriggerResult
-
- isFixedTopics() - Method in class org.apache.flink.streaming.connectors.kafka.internals.KafkaTopicsDescriptor
-
- isFlushAlwaysEnabled() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- isForceAvroEnabled() - Method in class org.apache.flink.api.common.ExecutionConfig
-
Returns whether the Apache Avro is the default serializer for POJOs.
- isForceCheckpointing() - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
- isForceCheckpointing() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- isForceKryoEnabled() - Method in class org.apache.flink.api.common.ExecutionConfig
-
- isFree() - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlot
-
- isFreeBSD() - Static method in enum org.apache.flink.util.OperatingSystem
-
Checks whether the operating system this JVM runs on is FreeBSD.
- isFreed() - Method in class org.apache.flink.core.memory.MemorySegment
-
Checks whether the memory segment was freed.
- isFull() - Method in class org.apache.flink.graph.types.valuearray.ByteValueArray
-
- isFull() - Method in class org.apache.flink.graph.types.valuearray.CharValueArray
-
- isFull() - Method in class org.apache.flink.graph.types.valuearray.DoubleValueArray
-
- isFull() - Method in class org.apache.flink.graph.types.valuearray.FloatValueArray
-
- isFull() - Method in class org.apache.flink.graph.types.valuearray.IntValueArray
-
- isFull() - Method in class org.apache.flink.graph.types.valuearray.LongValueArray
-
- isFull() - Method in class org.apache.flink.graph.types.valuearray.NullValueArray
-
- isFull() - Method in class org.apache.flink.graph.types.valuearray.ShortValueArray
-
- isFull() - Method in class org.apache.flink.graph.types.valuearray.StringValueArray
-
- isFull() - Method in interface org.apache.flink.graph.types.valuearray.ValueArray
-
An bounded array fills when the allocated capacity has been fully used.
- isFull() - Method in class org.apache.flink.runtime.io.network.buffer.BufferBuilder
-
- isFullBuffer() - Method in enum org.apache.flink.runtime.io.network.api.serialization.RecordSerializer.SerializationResult
-
Whether the target buffer is full after the serialization process.
- isFullRecord() - Method in enum org.apache.flink.runtime.io.network.api.serialization.RecordDeserializer.DeserializationResult
-
- isFullRecord() - Method in enum org.apache.flink.runtime.io.network.api.serialization.RecordSerializer.SerializationResult
-
Whether the full record was serialized and completely written to
a target buffer.
- isFullyAcknowledged() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
-
- isFullyReplicated() - Method in class org.apache.flink.optimizer.dataproperties.GlobalProperties
-
- isGloballyTerminalState() - Method in enum org.apache.flink.runtime.jobgraph.JobStatus
-
Checks whether this state is globally terminal.
- isGrouped() - Method in class org.apache.flink.api.java.sca.TaggedValue
-
- isHidden() - Method in class org.apache.flink.graph.drivers.parameter.IterationConvergence
-
- isHidden() - Method in interface org.apache.flink.graph.drivers.parameter.Parameter
-
A hidden parameter is parsed from the command-line configuration but is
not printed in the usage string.
- isHidden() - Method in class org.apache.flink.graph.drivers.parameter.SimpleParameter
-
- isHidden() - Method in class org.apache.flink.graph.drivers.parameter.Simplify
-
- isHighAvailabilityModeActivated(Configuration) - Static method in enum org.apache.flink.runtime.jobmanager.HighAvailabilityMode
-
Returns true if the defined recovery mode supports high availability.
- isIdle() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerRegistration
-
- isIdle() - Method in class org.apache.flink.streaming.runtime.streamstatus.StreamStatus
-
- isIdReference() - Method in class org.apache.flink.runtime.jobgraph.JobEdge
-
- isImmediateSolutionSetUpdate() - Method in class org.apache.flink.optimizer.plan.WorksetIterationPlanNode
-
- isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.array.BooleanPrimitiveArraySerializer
-
- isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.array.BytePrimitiveArraySerializer
-
- isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.array.CharPrimitiveArraySerializer
-
- isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.array.DoublePrimitiveArraySerializer
-
- isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.array.FloatPrimitiveArraySerializer
-
- isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.array.IntPrimitiveArraySerializer
-
- isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.array.LongPrimitiveArraySerializer
-
- isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.array.ShortPrimitiveArraySerializer
-
- isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.array.StringArraySerializer
-
- isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.BigDecSerializer
-
- isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.BigIntSerializer
-
- isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.BooleanSerializer
-
- isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueSerializer
-
- isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.ByteSerializer
-
- isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.ByteValueSerializer
-
- isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.CharSerializer
-
- isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.CharValueSerializer
-
- isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.DateSerializer
-
- isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.DoubleSerializer
-
- isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueSerializer
-
- isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.EnumSerializer
-
- isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.FloatSerializer
-
- isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.FloatValueSerializer
-
- isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.GenericArraySerializer
-
- isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.IntSerializer
-
- isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.IntValueSerializer
-
- isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.ListSerializer
-
- isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.LongSerializer
-
- isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.LongValueSerializer
-
- isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.MapSerializer
-
- isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.NullValueSerializer
-
- isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.ShortSerializer
-
- isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.ShortValueSerializer
-
- isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.SqlDateSerializer
-
- isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.SqlTimeSerializer
-
- isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.SqlTimestampSerializer
-
- isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.StringSerializer
-
- isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.StringValueSerializer
-
- isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.VoidSerializer
-
- isImmutableType() - Method in class org.apache.flink.api.common.typeutils.TypeDeserializerAdapter
-
- isImmutableType() - Method in class org.apache.flink.api.common.typeutils.TypeSerializer
-
Gets whether the type is an immutable type.
- isImmutableType() - Method in class org.apache.flink.api.common.typeutils.UnloadableDummyTypeSerializer
-
- isImmutableType() - Method in class org.apache.flink.api.java.typeutils.runtime.AvroSerializer
-
Deprecated.
- isImmutableType() - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer
-
- isImmutableType() - Method in class org.apache.flink.api.java.typeutils.runtime.EitherSerializer
-
- isImmutableType() - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer
-
- isImmutableType() - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer
-
- isImmutableType() - Method in class org.apache.flink.api.java.typeutils.runtime.RowSerializer
-
- isImmutableType() - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializerBase
-
- isImmutableType() - Method in class org.apache.flink.api.java.typeutils.runtime.ValueSerializer
-
- isImmutableType() - Method in class org.apache.flink.api.java.typeutils.runtime.WritableSerializer
-
- isImmutableType() - Method in class org.apache.flink.cep.nfa.DeweyNumber.DeweyNumberSerializer
-
- isImmutableType() - Method in class org.apache.flink.cep.nfa.NFA.NFASerializer
-
- isImmutableType() - Method in class org.apache.flink.cep.nfa.SharedBuffer.SharedBufferSerializer
-
- isImmutableType() - Method in class org.apache.flink.formats.avro.typeutils.AvroSerializer
-
- isImmutableType() - Method in class org.apache.flink.formats.avro.typeutils.BackwardsCompatibleAvroSerializer
-
- isImmutableType() - Method in class org.apache.flink.graph.drivers.transform.LongValueWithProperHashCode.LongValueWithProperHashCodeSerializer
-
- isImmutableType() - Method in class org.apache.flink.graph.types.valuearray.ByteValueArraySerializer
-
- isImmutableType() - Method in class org.apache.flink.graph.types.valuearray.CharValueArraySerializer
-
- isImmutableType() - Method in class org.apache.flink.graph.types.valuearray.DoubleValueArraySerializer
-
- isImmutableType() - Method in class org.apache.flink.graph.types.valuearray.FloatValueArraySerializer
-
- isImmutableType() - Method in class org.apache.flink.graph.types.valuearray.IntValueArraySerializer
-
- isImmutableType() - Method in class org.apache.flink.graph.types.valuearray.LongValueArraySerializer
-
- isImmutableType() - Method in class org.apache.flink.graph.types.valuearray.NullValueArraySerializer
-
- isImmutableType() - Method in class org.apache.flink.graph.types.valuearray.ShortValueArraySerializer
-
- isImmutableType() - Method in class org.apache.flink.graph.types.valuearray.StringValueArraySerializer
-
- isImmutableType() - Method in class org.apache.flink.queryablestate.client.VoidNamespaceSerializer
-
- isImmutableType() - Method in class org.apache.flink.runtime.state.ArrayListSerializer
-
- isImmutableType() - Method in class org.apache.flink.runtime.state.VoidNamespaceSerializer
-
- isImmutableType() - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.StateSerializer
-
- isImmutableType() - Method in class org.apache.flink.streaming.api.operators.InternalTimer.TimerSerializer
-
- isImmutableType() - Method in class org.apache.flink.streaming.api.windowing.windows.GlobalWindow.Serializer
-
- isImmutableType() - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow.Serializer
-
- isImmutableType() - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer011.ContextStateSerializer
-
- isImmutableType() - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer011.TransactionStateSerializer
-
- isImmutableType() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
-
- isIncluded(int) - Method in class org.apache.hadoop.conf.Configuration.IntegerRanges
-
Is the given value in the set of ranges
- isIncrementalCheckpointsEnabled() - Method in class org.apache.flink.contrib.streaming.state.RocksDBStateBackend
-
Gets whether incremental checkpoints are enabled for this state backend.
- isInfinite(Double) - Method in class org.apache.flink.api.java.summarize.aggregation.DoubleSummaryAggregator
-
- isInfinite(Float) - Method in class org.apache.flink.api.java.summarize.aggregation.FloatSummaryAggregator
-
- isInfinite(Integer) - Method in class org.apache.flink.api.java.summarize.aggregation.IntegerSummaryAggregator
-
- isInfinite(Long) - Method in class org.apache.flink.api.java.summarize.aggregation.LongSummaryAggregator
-
- isInfinite(T) - Method in class org.apache.flink.api.java.summarize.aggregation.NumericSummaryAggregator
-
- isInfinite(Short) - Method in class org.apache.flink.api.java.summarize.aggregation.ShortSummaryAggregator
-
- isInMemory() - Method in class org.apache.flink.runtime.operators.hash.HashPartition
-
Checks whether this partition is in memory or spilled.
- isInProgress() - Method in enum org.apache.flink.runtime.checkpoint.CheckpointStatsStatus
-
Returns whether the checkpoint is in progress.
- isInput() - Method in class org.apache.flink.api.java.sca.TaggedValue
-
- isInput1Iterable() - Method in class org.apache.flink.api.java.sca.TaggedValue
-
- isInput1Iterator() - Method in class org.apache.flink.api.java.sca.TaggedValue
-
- isInputAsynchronouslyMaterialized(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- isInputCached(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- isInputIterable() - Method in class org.apache.flink.api.java.sca.TaggedValue
-
- isInputIterator() - Method in class org.apache.flink.api.java.sca.TaggedValue
-
- isInputResettable(int) - Method in class org.apache.flink.runtime.operators.AbstractCachedBuildSideJoinDriver
-
- isInputResettable(int) - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetFirstDriver
-
- isInputResettable(int) - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetSecondDriver
-
- isInputResettable(int) - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetFirstDriver
-
- isInputResettable(int) - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetSecondDriver
-
- isInputResettable(int) - Method in interface org.apache.flink.runtime.operators.ResettableDriver
-
- isInputVertex() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
- isInSSSP(Edge<Long, Double>, DataSet<Edge<Long, Double>>) - Static method in class org.apache.flink.graph.examples.IncrementalSSSP
-
Function that verifies whether the edge to be removed is part of the SSSP or not.
- isIntConstant() - Method in class org.apache.flink.api.java.sca.TaggedValue
-
- isIterative() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- isIterativeInputGate(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- isIteratorTrueAssumption() - Method in class org.apache.flink.api.java.sca.TaggedValue
-
- isIteratorTrueAssumptionApplied() - Method in class org.apache.flink.api.java.sca.UdfAnalyzer
-
- isJobExecutionResult() - Method in class org.apache.flink.api.common.JobSubmissionResult
-
Checks if this JobSubmissionResult is also a JobExecutionResult.
- isJvmFatalError(Throwable) - Static method in class 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) - Static method in class 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.
- isKeyGroupAlreadyFinished(int) - Method in class org.apache.flink.runtime.state.KeyedStateCheckpointOutputStream
-
Returns true if the key group is already completely written and immutable.
- isKeyGroupAlreadyStarted(int) - Method in class org.apache.flink.runtime.state.KeyedStateCheckpointOutputStream
-
Returns true, if the key group with the given id was already started.
- isKeyType() - Method in class org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
-
- isKeyType() - Method in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
-
- isKeyType() - Method in class org.apache.flink.api.common.typeinfo.NothingTypeInfo
-
- isKeyType() - Method in class org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
-
- isKeyType() - Method in class org.apache.flink.api.common.typeinfo.SqlTimeTypeInfo
-
- isKeyType() - Method in class org.apache.flink.api.common.typeinfo.TypeInformation
-
Checks whether this type can be used as a key.
- isKeyType() - Method in class org.apache.flink.api.common.typeutils.CompositeType
-
- isKeyType() - Method in class org.apache.flink.api.java.typeutils.EitherTypeInfo
-
- isKeyType() - Method in class org.apache.flink.api.java.typeutils.EnumTypeInfo
-
- isKeyType() - Method in class org.apache.flink.api.java.typeutils.GenericTypeInfo
-
- isKeyType() - Method in class org.apache.flink.api.java.typeutils.ListTypeInfo
-
- isKeyType() - Method in class org.apache.flink.api.java.typeutils.MapTypeInfo
-
- isKeyType() - Method in class org.apache.flink.api.java.typeutils.MissingTypeInfo
-
- isKeyType() - Method in class org.apache.flink.api.java.typeutils.ObjectArrayTypeInfo
-
- isKeyType() - Method in class org.apache.flink.api.java.typeutils.ValueTypeInfo
-
- isKeyType() - Method in class org.apache.flink.api.java.typeutils.WritableTypeInfo
-
- isKeyType() - Method in class org.apache.flink.graph.drivers.transform.LongValueWithProperHashCode.LongValueWithProperHashCodeTypeInfo
-
- isKeyType() - Method in class org.apache.flink.graph.types.valuearray.ValueArrayTypeInfo
-
- isKeyType() - Method in class org.apache.flink.queryablestate.client.VoidNamespaceTypeInfo
-
- isKeyType() - Method in class org.apache.flink.runtime.state.VoidNamespaceTypeInfo
-
- isLatencyMarker() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElement
-
Checks whether this element is a record.
- isLatencyTrackingConfigured() - Method in class org.apache.flink.api.common.ExecutionConfig
-
- isLatencyTrackingEnabled() - Method in class org.apache.flink.api.common.ExecutionConfig
-
- isLeader() - Method in class org.apache.flink.runtime.leaderelection.ZooKeeperLeaderElectionService
-
- isLeft() - Method in class org.apache.flink.types.Either
-
- isLenient() - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
-
- isLinux() - Static method in enum org.apache.flink.util.OperatingSystem
-
Checks whether the operating system this JVM runs on is Linux.
- isLoaded() - Method in class org.apache.flink.client.program.ClusterClient.LazyActorSystemLoader
-
Indicates whether the ActorSystem has already been instantiated.
- isLocal() - Method in class org.apache.flink.runtime.deployment.ResultPartitionLocation
-
- isLocalRecoveryEnabled() - Method in class org.apache.flink.runtime.state.LocalRecoveryConfig
-
- isLocalRecoveryEnabled() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
-
- isMac() - Static method in enum org.apache.flink.util.OperatingSystem
-
Checks whether the operating system this JVM runs on is Windows.
- isMandatory() - Method in class org.apache.flink.runtime.rest.messages.MessageParameter
-
Returns whether this parameter must be resolved for the request.
- isMatching(ResourceProfile) - Method in class org.apache.flink.runtime.clusterframework.types.ResourceProfile
-
Check whether required resource profile can be matched.
- isMatchingRequirement(ResourceProfile) - Method in class org.apache.flink.runtime.clusterframework.types.TaskManagerSlot
-
Check whether required resource profile can be matched by this slot.
- isMaterialized() - Method in class org.apache.flink.table.client.gateway.local.ChangelogCollectStreamResult
-
- isMaterialized() - Method in interface org.apache.flink.table.client.gateway.local.DynamicResult
-
Returns whether this result is materialized such that snapshots can be taken or results
must be retrieved record-wise.
- isMaterialized() - Method in class org.apache.flink.table.client.gateway.local.MaterializedCollectStreamResult
-
- isMaterialized() - Method in class org.apache.flink.table.client.gateway.ResultDescriptor
-
- isMaterializing() - Method in enum org.apache.flink.runtime.operators.DamBehavior
-
Checks whether this enumeration represents some form of materialization,
either with a full dam or without.
- isMaterializing() - Method in enum org.apache.flink.runtime.operators.DriverStrategy
-
- isMaxParallelismConfigured() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
- isMetBy(Ordering) - Method in class org.apache.flink.api.common.operators.Ordering
-
- isMetBy(GlobalProperties) - Method in class org.apache.flink.optimizer.dataproperties.RequestedGlobalProperties
-
Checks, if this set of interesting properties, is met by the given
produced properties.
- isMetBy(LocalProperties) - Method in class org.apache.flink.optimizer.dataproperties.RequestedLocalProperties
-
Checks, if this set of properties, as interesting properties, is met by the given
properties.
- isMinor() - Method in class org.apache.flink.streaming.connectors.wikiedits.WikipediaEditEvent
-
- isMoreAvailable() - Method in class org.apache.flink.runtime.io.network.partition.ResultSubpartition.BufferAndBacklog
-
- isNan(Double) - Method in class org.apache.flink.api.java.summarize.aggregation.DoubleSummaryAggregator
-
- isNan(Float) - Method in class org.apache.flink.api.java.summarize.aggregation.FloatSummaryAggregator
-
- isNan(Integer) - Method in class org.apache.flink.api.java.summarize.aggregation.IntegerSummaryAggregator
-
- isNan(Long) - Method in class org.apache.flink.api.java.summarize.aggregation.LongSummaryAggregator
-
- isNan(T) - Method in class org.apache.flink.api.java.summarize.aggregation.NumericSummaryAggregator
-
- isNan(Short) - Method in class org.apache.flink.api.java.summarize.aggregation.ShortSummaryAggregator
-
- isNativeCodeLoaded() - Static method in class org.apache.hadoop.util.NativeCodeLoader
-
Check if native-hadoop code is loaded for this platform.
- isNetworkStrategy() - Method in enum org.apache.flink.runtime.operators.shipping.ShipStrategyType
-
- isNew() - Method in class org.apache.flink.streaming.connectors.wikiedits.WikipediaEditEvent
-
- isNFAChanged() - Method in class org.apache.flink.cep.nfa.NFA
-
Check if the matching status of the NFA has changed so far.
- isNonStaticInnerClass(Class<?>) - Static method in class org.apache.flink.util.InstantiationUtil
-
Checks, whether the class is an inner class that is not statically accessible.
- isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.array.PrimitiveArrayComparator
-
- isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.BigDecComparator
-
- isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.BigIntComparator
-
- isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.BooleanComparator
-
- isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueComparator
-
- isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.ByteComparator
-
- isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.ByteValueComparator
-
- isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.CharComparator
-
- isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.CharValueComparator
-
- isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.DateComparator
-
- isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.DoubleComparator
-
- isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueComparator
-
- isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.EnumComparator
-
- isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.FloatComparator
-
- isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.FloatValueComparator
-
- isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.IntComparator
-
- isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.IntValueComparator
-
- isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.LongComparator
-
- isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.LongValueComparator
-
- isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.NullValueComparator
-
- isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.ShortComparator
-
- isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.ShortValueComparator
-
- isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.SqlTimestampComparator
-
- isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.StringComparator
-
- isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.StringValueComparator
-
- isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.TypeComparator
-
Checks, whether the given number of bytes for a normalized is only a prefix to determine the order of elements
of the data type for which this comparator provides the comparison methods.
- isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueComparator
-
- isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.java.typeutils.runtime.GenericTypeComparator
-
- isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.java.typeutils.runtime.NullAwareComparator
-
- isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoComparator
-
- isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.java.typeutils.runtime.RowComparator
-
- isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
-
- isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.java.typeutils.runtime.ValueComparator
-
- isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.java.typeutils.runtime.WritableComparator
-
- isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.graph.types.valuearray.ByteValueArrayComparator
-
- isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.graph.types.valuearray.CharValueArrayComparator
-
- isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.graph.types.valuearray.DoubleValueArrayComparator
-
- isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.graph.types.valuearray.FloatValueArrayComparator
-
- isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.graph.types.valuearray.IntValueArrayComparator
-
- isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.graph.types.valuearray.LongValueArrayComparator
-
- isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.graph.types.valuearray.NullValueArrayComparator
-
- isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.graph.types.valuearray.ShortValueArrayComparator
-
- isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.graph.types.valuearray.StringValueArrayComparator
-
- isNull() - Method in class org.apache.flink.api.java.sca.TaggedValue
-
- IsNull(String, PredicateLeaf.Type) - Constructor for class org.apache.flink.orc.OrcRowInputFormat.IsNull
-
Creates an IS_NULL predicate.
- isNull(int) - Method in class org.apache.flink.types.Record
-
- isNullOrEmpty(ChainedStateHandle<?>) - Static method in class org.apache.flink.runtime.state.ChainedStateHandle
-
- isNullOrEmpty(Collection<?>) - Static method in class org.apache.flink.util.CollectionUtil
-
- isNullOrEmpty(Map<?, ?>) - Static method in class org.apache.flink.util.CollectionUtil
-
- isNullOrWhitespaceOnly(String) - Static method in class org.apache.flink.util.StringUtils
-
Checks if the string is null, empty, or contains only whitespace characters.
- isNumBytesInLocalComplete() - Method in class org.apache.flink.runtime.rest.handler.util.MutableIOMetrics
-
- isNumBytesInRemoteComplete() - Method in class org.apache.flink.runtime.rest.handler.util.MutableIOMetrics
-
- isNumBytesOutComplete() - Method in class org.apache.flink.runtime.rest.handler.util.MutableIOMetrics
-
- isNumRecordsInComplete() - Method in class org.apache.flink.runtime.rest.handler.util.MutableIOMetrics
-
- isNumRecordsOutComplete() - Method in class org.apache.flink.runtime.rest.handler.util.MutableIOMetrics
-
- isObjectReuseEnabled() - Method in class org.apache.flink.api.common.ExecutionConfig
-
Returns whether object reuse has been enabled or disabled.
- isOffHeap() - Method in class org.apache.flink.core.memory.MemorySegment
-
Checks whether this memory segment is backed by off-heap memory.
- isOffsetDefined() - Method in class org.apache.flink.streaming.connectors.kafka.internals.KafkaTopicPartitionState
-
- isOnDynamicPath() - Method in class org.apache.flink.optimizer.dag.AbstractPartialSolutionNode
-
- isOnDynamicPath() - Method in class org.apache.flink.optimizer.dag.DagConnection
-
- isOnDynamicPath() - Method in class org.apache.flink.optimizer.dag.OptimizerNode
-
- isOnDynamicPath() - Method in class org.apache.flink.optimizer.plan.Channel
-
- isOnDynamicPath() - Method in class org.apache.flink.optimizer.plan.PlanNode
-
- isOne() - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.TaggedUnion
-
- isOpen() - Method in class org.apache.flink.streaming.connectors.kafka.internals.ClosableBlockingQueue
-
Checks whether the queue is currently open, meaning elements can be added and polled.
- isOptDegrees() - Method in class org.apache.flink.graph.spargel.ScatterGatherConfiguration
-
Gets whether the degrees option is set.
- isOptNumVertices() - Method in class org.apache.flink.graph.IterationConfiguration
-
Gets whether the number of vertices option is set.
- isOrdered() - Method in enum org.apache.flink.api.common.operators.Order
-
Checks, if this enum constant represents in fact an order.
- isOrderEqualOnFirstNFields(Ordering, int) - Method in class org.apache.flink.api.common.operators.Ordering
-
- isOuter() - Method in enum org.apache.flink.api.java.operators.join.JoinType
-
- isOutputVertex() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
- isOverdue() - Method in class org.apache.flink.api.common.time.Deadline
-
Determines whether the deadline is in the past, i.e.
- isPartitioned() - Method in enum org.apache.flink.optimizer.dataproperties.PartitioningProperty
-
Checks, if this property represents in fact a partitioning.
- isPartitionedOnFields(FieldSet) - Method in class org.apache.flink.optimizer.dataproperties.GlobalProperties
-
- isPartitionedOnKey() - Method in enum org.apache.flink.optimizer.dataproperties.PartitioningProperty
-
Checks if this property presents a partitioning that is not random, but on a partitioning key.
- isPeriodicCheckpointingConfigured() - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
Returns whether periodic checkpointing has been configured.
- isPipelined() - Method in enum org.apache.flink.runtime.io.network.partition.ResultPartitionType
-
- isPlainTerminal() - Method in class org.apache.flink.table.client.cli.CliClient
-
- isPowerOf2(long) - Static method in class org.apache.flink.util.MathUtils
-
Checks whether the given value is a power of two.
- isPreAllocated() - Method in class org.apache.flink.runtime.memory.MemoryManager
-
Checks whether this memory manager pre-allocates the memory.
- isPreAllocateMemory() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
-
- isPrintHelp() - Method in class org.apache.flink.client.cli.CommandLineOptions
-
- isPrintHelp() - Method in class org.apache.flink.table.client.cli.CliOptions
-
- isPrintingStatusDuringExecution() - Method in class org.apache.flink.api.common.PlanExecutor
-
Gets whether the executor prints progress results to "standard out" (
System.out
).
- isProgramSubmitEnabled() - Method in class org.apache.flink.runtime.webmonitor.WebMonitorConfig
-
- isProperClass(Class<?>) - Static method in class org.apache.flink.util.InstantiationUtil
-
Checks, whether the class is a proper class, i.e.
- isProperlyShutDown() - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManager
-
Utility method to check whether the IO manager has been properly shut down.
- isProperlyShutDown() - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManagerAsync
-
Utility method to check whether the IO manager has been properly shut down.
- isPruneMarkerSet() - Method in class org.apache.flink.optimizer.plan.PlanNode
-
Checks whether the pruning marker was set.
- isPublic(Class<?>) - Static method in class org.apache.flink.util.InstantiationUtil
-
Checks, whether the given class is public.
- isPurge() - Method in enum org.apache.flink.streaming.api.windowing.triggers.TriggerResult
-
- isQueryable() - Method in class org.apache.flink.api.common.state.StateDescriptor
-
Returns whether the state created from this descriptor is queryable.
- isQueuedSchedulingAllowed() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- isRecord() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElement
-
Checks whether this element is a record.
- isRecordsReadComplete() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.IOMetricsInfo
-
- isRecordsWrittenComplete() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.IOMetricsInfo
-
- isRecycled() - Method in interface org.apache.flink.runtime.io.network.buffer.Buffer
-
Returns whether this buffer has been recycled or not.
- isRecycled() - Method in class org.apache.flink.runtime.io.network.buffer.BufferConsumer
-
- isRecycled() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
-
- isRecycled() - Method in class org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
-
- isRegistered(InstanceID) - Method in class org.apache.flink.runtime.instance.InstanceManager
-
- isRegistered(ResourceID) - Method in class org.apache.flink.runtime.instance.InstanceManager
-
- isRegisteredAsAvailable() - Method in interface org.apache.flink.runtime.io.network.NetworkSequenceViewReader
-
- isRegular() - Method in class org.apache.flink.api.java.sca.TaggedValue
-
- isReleased() - Method in class org.apache.flink.runtime.instance.Slot
-
Checks of the slot has been released.
- isReleased() - Method in interface org.apache.flink.runtime.io.network.NetworkSequenceViewReader
-
- isReleased() - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
-
- isReleased() - Method in class org.apache.flink.runtime.io.network.partition.ResultSubpartition
-
- isReleased() - Method in interface org.apache.flink.runtime.io.network.partition.ResultSubpartitionView
-
- isReleasing() - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlot
-
- isRemote() - Method in class org.apache.flink.runtime.deployment.ResultPartitionLocation
-
- isReplication() - Method in enum org.apache.flink.optimizer.dataproperties.PartitioningProperty
-
Checks, if this property represents a full replication.
- isRequiresMigration() - Method in class org.apache.flink.api.common.typeutils.CompatibilityResult
-
- isResolved() - Method in class org.apache.flink.runtime.rest.messages.MessageParameter
-
Returns whether this parameter has been resolved.
- isResolved() - Method in class org.apache.flink.runtime.rest.messages.MessageParameters
-
Returns whether all mandatory parameters have been resolved.
- isRestored() - Method in class org.apache.flink.runtime.checkpoint.PrioritizedOperatorSubtaskState
-
Returns true if this was created for a restored operator, false otherwise.
- isRestored() - Method in interface org.apache.flink.runtime.state.ManagedInitializationContext
-
Returns true, if state was restored from the snapshot of a previous execution.
- isRestored() - Method in class org.apache.flink.runtime.state.StateInitializationContextImpl
-
- isRestored() - Method in interface org.apache.flink.streaming.api.operators.StreamOperatorStateContext
-
Returns true, the states provided by this context are restored from a checkpoint/savepoint.
- isResultCollection() - Method in interface org.apache.flink.streaming.api.operators.async.queue.AsyncResult
-
True fi the async result is a collection of output elements; otherwise false.
- isResultCollection() - Method in class org.apache.flink.streaming.api.operators.async.queue.StreamElementQueueEntry
-
- isRetrieving() - Method in class org.apache.flink.table.client.cli.CliResultView
-
- isRetrieving() - Method in class org.apache.flink.table.client.gateway.local.CollectStreamResult
-
- isRight() - Method in class org.apache.flink.types.Either
-
- isRootAndEmpty() - Method in class org.apache.flink.runtime.instance.SharedSlot
-
Checks whether this slot is a root slot that has not yet added any child slots.
- isRunning() - Method in class org.apache.flink.api.common.PlanExecutor
-
Checks if this executor is currently running.
- isRunning() - Method in class org.apache.flink.client.LocalExecutor
-
- isRunning() - Method in class org.apache.flink.client.RemoteExecutor
-
- isRunning() - Method in class org.apache.flink.runtime.minicluster.MiniCluster
-
Checks if the mini cluster was started and is running.
- isRunning() - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.ThreadBase
-
Checks whether this thread is still alive.
- isRunning() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- isRunning() - Method in class org.apache.flink.table.client.cli.CliView
-
- isSameSlotSharingGroup(StreamNode) - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- isSavepoint() - Method in class org.apache.flink.runtime.checkpoint.CheckpointProperties
-
Returns whether the checkpoint properties describe a standard savepoint.
- isSavepoint() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.RestoredCheckpointStatistics
-
- isSavepoint() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
-
- isSensitive(String) - Static method in class org.apache.flink.configuration.GlobalConfiguration
-
Check whether the key is a hidden key.
- isSentinel(long) - Static method in class org.apache.flink.streaming.connectors.kafka.internals.KafkaTopicPartitionStateSentinel
-
- isSerializable(Object) - Static method in class org.apache.flink.util.InstantiationUtil
-
- isSerializerInitialized() - Method in class org.apache.flink.api.common.state.StateDescriptor
-
Checks whether the serializer has been initialized.
- isShutdown() - Method in class org.apache.flink.runtime.blob.BlobServer
-
Tests whether the BLOB server has been requested to shut down.
- isShutdown() - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
- isShutDown() - Method in class org.apache.flink.runtime.highavailability.nonha.AbstractNonHaServices
-
- isShutdown() - Method in class org.apache.flink.runtime.highavailability.nonha.leaderelection.SingleLeaderElectionService
-
- isShutdown() - Method in class org.apache.flink.runtime.io.network.NetworkEnvironment
-
- isShutdown() - Method in class org.apache.flink.runtime.memory.MemoryManager
-
Checks whether the MemoryManager has been shut down.
- isShutdown() - Method in class org.apache.flink.runtime.metrics.MetricRegistryImpl
-
Returns whether this registry has been shutdown.
- isShutdownOnAttachedExit() - Method in class org.apache.flink.client.cli.ProgramOptions
-
- isSkipInvalidLines() - Method in class org.apache.flink.api.java.io.TextValueInputFormat
-
- isSkippingFirstLineAsHeader() - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
-
- isSlotFree(int) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
-
Check whether the task slot with the given index is free.
- isSnapshotCompleted() - Method in class org.apache.flink.runtime.state.SnapshotDirectory
-
Returns true
if the snapshot is marked as completed.
- isSolaris() - Static method in enum org.apache.flink.util.OperatingSystem
-
Checks whether the operating system this JVM runs on is Solaris.
- isSolutionSetUnManaged() - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase
-
gets whether the solution set is in managed or unmanaged memory.
- isSolutionSetUnManaged() - Method in class org.apache.flink.api.java.operators.DeltaIteration
-
gets whether the solution set is in managed or unmanaged memory.
- isSolutionSetUnmanaged() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- isSolutionSetUnmanagedMemory() - Method in class org.apache.flink.graph.IterationConfiguration
-
Gets whether the solution set is kept in managed memory (Flink's internal way of keeping object
in serialized form) or as a simple object map.
- isSolutionSetUpdate - Variable in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
-
- isSortedGrouping(int) - Method in class org.apache.flink.python.api.util.SetCache
-
- isSortKey(int, TypeInformation<?>) - Static method in class org.apache.flink.api.common.operators.Keys.ExpressionKeys
-
- isSortKey(String, TypeInformation<?>) - Static method in class org.apache.flink.api.common.operators.Keys.ExpressionKeys
-
- isSortKeyType() - Method in class org.apache.flink.api.common.typeinfo.TypeInformation
-
Checks whether this type can be used as a key for sorting.
- isSortKeyType() - Method in class org.apache.flink.api.common.typeutils.CompositeType
-
- isSortKeyType() - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo
-
- isSpecial() - Method in class org.apache.flink.streaming.connectors.wikiedits.WikipediaEditEvent
-
- isStandaloneDeployment() - Method in class org.apache.flink.table.client.config.Deployment
-
- isStart() - Method in class org.apache.flink.cep.nfa.State
-
- isStarted(ResourceID) - Method in class org.apache.flink.runtime.clusterframework.FlinkResourceManager
-
Gets the started worker for a given resource ID, if one is available.
- isStarted() - Method in class org.apache.flink.runtime.resourcemanager.JobLeaderIdService
-
Checks whether the service has been started.
- isStartState() - Method in class org.apache.flink.cep.nfa.ComputationState
-
- isStillAlive(long, long) - Method in class org.apache.flink.runtime.instance.Instance
-
Checks whether the last heartbeat occurred within the last n
milliseconds
before the given timestamp now
.
- isStop() - Method in class org.apache.flink.cep.nfa.State
-
- isStoppable() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionGraph
-
Returns whether the job for this execution graph is stoppable.
- isStoppable() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
-
- isStoppable() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- isStoppable() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
- isStoppable() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
-
- isStopped() - Method in class org.apache.flink.runtime.io.async.AbstractAsyncCallableWithResources
-
Check if the IO operation is stopped
- isStopped() - Method in interface org.apache.flink.runtime.io.async.AsyncStoppable
-
Check whether the operation is stopped
- isStopState() - Method in class org.apache.flink.cep.nfa.ComputationState
-
- isStreamingExecution() - Method in class org.apache.flink.table.client.config.Execution
-
- isStreamStatus() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElement
-
Checks whether this element is a stream status.
- isSuccess() - Method in class org.apache.flink.runtime.checkpoint.CheckpointTriggerResult
-
- isSuccess() - Method in class org.apache.flink.runtime.jobmaster.JobResult
-
Returns true
if the job finished successfully.
- isSynchronous() - Method in enum org.apache.flink.runtime.io.disk.iomanager.IOManager.IOMode
-
- isSysoutLoggingEnabled() - Method in class org.apache.flink.api.common.ExecutionConfig
-
Gets whether progress update messages should be printed to System.out
- isTagged(Value) - Static method in class org.apache.flink.api.java.sca.UdfAnalyzerUtils
-
- isTalk() - Method in class org.apache.flink.streaming.connectors.wikiedits.WikipediaEditEvent
-
- isTerminal() - Method in enum org.apache.flink.runtime.execution.ExecutionState
-
- isTerminal() - Method in enum org.apache.flink.streaming.examples.statemachine.dfa.State
-
Checks if this state is a terminal state.
- isTerminalState() - Method in enum org.apache.flink.runtime.jobgraph.JobStatus
-
Checks whether this state is locally terminal.
- isTerminated() - Method in class org.apache.flink.streaming.runtime.tasks.ProcessingTimeService
-
Returns true if the service has been shut down, false otherwise.
- isTerminated() - Method in class org.apache.flink.streaming.runtime.tasks.SystemProcessingTimeService
-
- isTerminated() - Method in class org.apache.flink.streaming.runtime.tasks.TestProcessingTimeService
-
- isThis() - Method in class org.apache.flink.api.java.sca.TaggedValue
-
- isTopicPattern() - Method in class org.apache.flink.streaming.connectors.kafka.internals.KafkaTopicsDescriptor
-
- isTopologyRecovery() - Method in class org.apache.flink.streaming.connectors.rabbitmq.common.RMQConnectionConfig
-
Returns true if topology recovery is enabled, false otherwise.
- isTriggered() - Method in class org.apache.flink.core.testutils.MultiShotLatch
-
Checks if the latch was triggered.
- isTriggered() - Method in class org.apache.flink.core.testutils.OneShotLatch
-
Checks if the latch was triggered.
- isTrivial() - Method in class org.apache.flink.optimizer.dataproperties.GlobalProperties
-
Checks, if the properties in this object are trivial, i.e.
- isTrivial() - Method in class org.apache.flink.optimizer.dataproperties.LocalProperties
-
Checks, if the properties in this object are trivial, i.e.
- isTrivial() - Method in class org.apache.flink.optimizer.dataproperties.RequestedGlobalProperties
-
Checks, if the properties in this object are trivial, i.e.
- isTrivial() - Method in class org.apache.flink.optimizer.dataproperties.RequestedLocalProperties
-
Checks, if the properties in this object are trivial, i.e.
- isTupleType() - Method in class org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
-
- isTupleType() - Method in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
-
- isTupleType() - Method in class org.apache.flink.api.common.typeinfo.NothingTypeInfo
-
- isTupleType() - Method in class org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
-
- isTupleType() - Method in class org.apache.flink.api.common.typeinfo.SqlTimeTypeInfo
-
- isTupleType() - Method in class org.apache.flink.api.common.typeinfo.TypeInformation
-
Checks if this type information represents a Tuple type.
- isTupleType() - Method in class org.apache.flink.api.java.typeutils.EitherTypeInfo
-
- isTupleType() - Method in class org.apache.flink.api.java.typeutils.EnumTypeInfo
-
- isTupleType() - Method in class org.apache.flink.api.java.typeutils.GenericTypeInfo
-
- isTupleType() - Method in class org.apache.flink.api.java.typeutils.ListTypeInfo
-
- isTupleType() - Method in class org.apache.flink.api.java.typeutils.MapTypeInfo
-
- isTupleType() - Method in class org.apache.flink.api.java.typeutils.MissingTypeInfo
-
- isTupleType() - Method in class org.apache.flink.api.java.typeutils.ObjectArrayTypeInfo
-
- isTupleType() - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo
-
- isTupleType() - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfoBase
-
- isTupleType() - Method in class org.apache.flink.api.java.typeutils.ValueTypeInfo
-
- isTupleType() - Method in class org.apache.flink.api.java.typeutils.WritableTypeInfo
-
- isTupleType() - Method in class org.apache.flink.graph.drivers.transform.LongValueWithProperHashCode.LongValueWithProperHashCodeTypeInfo
-
- isTupleType() - Method in class org.apache.flink.graph.types.valuearray.ValueArrayTypeInfo
-
- isTupleType() - Method in class org.apache.flink.queryablestate.client.VoidNamespaceTypeInfo
-
- isTupleType() - Method in class org.apache.flink.runtime.state.VoidNamespaceTypeInfo
-
- isTwo() - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.TaggedUnion
-
- isUdfBinary() - Method in class org.apache.flink.api.java.sca.UdfAnalyzer
-
- isUdfReduceFunction() - Method in class org.apache.flink.api.java.sca.UdfAnalyzer
-
- isUnknown() - Method in class org.apache.flink.runtime.deployment.ResultPartitionLocation
-
- isUnpatrolled() - Method in class org.apache.flink.streaming.connectors.wikiedits.WikipediaEditEvent
-
- isUnsortedGrouping(int) - Method in class org.apache.flink.python.api.util.SetCache
-
- isUseSnapshotCompression() - Method in class org.apache.flink.api.common.ExecutionConfig
-
- isUsingAsynchronousSnapshots() - Method in class org.apache.flink.runtime.state.filesystem.FsStateBackend
-
Gets whether the key/value data structures are asynchronously snapshotted.
- isUsingAsynchronousSnapshots() - Method in class org.apache.flink.runtime.state.memory.MemoryStateBackend
-
Gets whether the key/value data structures are asynchronously snapshotted.
- isUsingInteractiveMode() - Method in class org.apache.flink.client.program.PackagedProgram
-
- isUsingKeyGroupCompression() - Method in class org.apache.flink.runtime.state.KeyedBackendSerializationProxy
-
- isUsingProgramEntryPoint() - Method in class org.apache.flink.client.program.PackagedProgram
-
- isValid() - Method in class org.apache.flink.api.common.operators.ResourceSpec
-
Check whether all the field values are valid.
- isValid() - Method in class org.apache.flink.contrib.streaming.state.RocksIteratorWrapper
-
- isValid(K, UUID) - Method in class org.apache.flink.runtime.taskexecutor.slot.TimerService
-
Check whether the timeout for the given key and ticket is still valid (not yet unregistered
and not yet overwritten).
- isValidSubset(FieldSet) - Method in class org.apache.flink.api.common.operators.util.FieldList
-
- isValidSubset(FieldList) - Method in class org.apache.flink.api.common.operators.util.FieldList
-
- isValidSubset(FieldSet) - Method in class org.apache.flink.api.common.operators.util.FieldSet
-
Checks if the given set of fields is a valid subset of this set of fields.
- isValidTimeout(JobID, UUID) - Method in class org.apache.flink.runtime.resourcemanager.JobLeaderIdService
-
- isValidTimeout(AllocationID, UUID) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
-
Check whether the timeout with ticket is valid for the given allocation id.
- isValidUnorderedPrefix(FieldSet) - Method in class org.apache.flink.api.common.operators.util.FieldList
-
- isWatermark() - Method in interface org.apache.flink.streaming.api.operators.async.queue.AsyncResult
-
True if the async result is a
Watermark
; otherwise false.
- isWatermark() - Method in class org.apache.flink.streaming.api.operators.async.queue.StreamElementQueueEntry
-
- isWatermark() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElement
-
Checks whether this element is a watermark.
- isWatermarkAligned - Variable in class org.apache.flink.streaming.runtime.streamstatus.StatusWatermarkValve.InputChannelStatus
-
- isWindowLate(W) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
Returns true
if the watermark is after the end timestamp plus the allowed lateness
of the given window.
- isWindows() - Static method in enum org.apache.flink.util.OperatingSystem
-
Checks whether the operating system this JVM runs on is Windows.
- isWithSavepoint() - Method in class org.apache.flink.client.cli.CancelOptions
-
- isWorksetIteration - Variable in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
-
- isWorksetUpdate - Variable in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
-
- isWritable() - Method in class org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
-
- isWritable(int) - Method in class org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
-
- isWriteAheadLogEnabled - Variable in class org.apache.flink.streaming.connectors.cassandra.CassandraSink.CassandraSinkBuilder
-
- isZkSaslDisable() - Method in class org.apache.flink.runtime.security.SecurityConfiguration
-
- isZooKeeperRecoveryMode(Configuration) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
-
- IterableIterator<E> - Interface in org.apache.flink.util
-
- iterate(int) - Method in class org.apache.flink.api.java.DataSet
-
Initiates an iterative part of the program that executes multiple times and feeds back data sets.
- iterate() - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Initiates an iterative part of the program that feeds back data streams.
- iterate(long) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Initiates an iterative part of the program that feeds back data streams.
- iterate() - Method in class org.apache.flink.streaming.python.api.datastream.PythonDataStream
-
- iterate(Long) - Method in class org.apache.flink.streaming.python.api.datastream.PythonDataStream
-
- iterateDelta(DataSet<R>, int, int...) - Method in class org.apache.flink.api.java.DataSet
-
Initiates a delta iteration.
- iterateEdges(Iterable<Tuple2<K, Edge<K, EV>>>, Collector<O>) - Method in interface org.apache.flink.graph.EdgesFunction
-
This method is called per vertex and can iterate over all of its neighboring edges
with the specified direction.
- iterateEdges(Vertex<K, VV>, Iterable<Edge<K, EV>>, Collector<O>) - Method in interface org.apache.flink.graph.EdgesFunctionWithVertexValue
-
This method is called per vertex and can iterate over all of its neighboring edges
with the specified direction.
- IterateExample - Class in org.apache.flink.streaming.examples.iteration
-
Example illustrating iterations in Flink streaming.
- IterateExample() - Constructor for class org.apache.flink.streaming.examples.iteration.IterateExample
-
- IterateExample.InputMap - Class in org.apache.flink.streaming.examples.iteration
-
Map the inputs so that the next Fibonacci numbers can be calculated while preserving the original input tuple.
- IterateExample.MySelector - Class in org.apache.flink.streaming.examples.iteration
-
OutputSelector testing which tuple needs to be iterated again.
- IterateExample.OutputMap - Class in org.apache.flink.streaming.examples.iteration
-
Giving back the input pair and the counter.
- IterateExample.Step - Class in org.apache.flink.streaming.examples.iteration
-
Iteration step function that calculates the next Fibonacci number.
- IterateExampleData - Class in org.apache.flink.streaming.examples.iteration.util
-
Data for IterateExampleITCase.
- iterateNeighbors(Iterable<Tuple3<K, Edge<K, EV>, Vertex<K, VV>>>, Collector<O>) - Method in interface org.apache.flink.graph.NeighborsFunction
-
This method is called per vertex and can iterate over all of its neighbors
with the specified direction.
- iterateNeighbors(Vertex<K, VV>, Iterable<Tuple2<Edge<K, EV>, Vertex<K, VV>>>, Collector<O>) - Method in interface org.apache.flink.graph.NeighborsFunctionWithVertexValue
-
This method is called per vertex and can iterate over all of its neighbors
with the specified direction.
- IterationAggregatorBroker - Class in org.apache.flink.runtime.iterative.concurrent
-
- IterationAggregatorBroker() - Constructor for class org.apache.flink.runtime.iterative.concurrent.IterationAggregatorBroker
-
- IterationConfiguration - Class in org.apache.flink.graph
-
This is used as a base class for vertex-centric iteration or gather-sum-apply iteration configuration.
- IterationConfiguration() - Constructor for class org.apache.flink.graph.IterationConfiguration
-
- IterationConvergence - Class in org.apache.flink.graph.drivers.parameter
-
Iterative algorithms which converge can be terminated with a maximum number
of iterations or a convergence threshold which stops computation when the
total change in scores is below a given delta.
- IterationConvergence(ParameterizedBase, int) - Constructor for class org.apache.flink.graph.drivers.parameter.IterationConvergence
-
Add this parameter to the list of parameters stored by owner.
- IterationConvergence.Value - Class in org.apache.flink.graph.drivers.parameter
-
Encapsulate the number of iterations and the convergence threshold.
- IterationEventWithAggregators - Class in org.apache.flink.runtime.iterative.event
-
Base class for iteration
TaskEvent
transmitting operator aggregators.
- IterationEventWithAggregators() - Constructor for class org.apache.flink.runtime.iterative.event.IterationEventWithAggregators
-
- IterationEventWithAggregators(String, Value) - Constructor for class org.apache.flink.runtime.iterative.event.IterationEventWithAggregators
-
- IterationEventWithAggregators(Map<String, Aggregator<?>>) - Constructor for class org.apache.flink.runtime.iterative.event.IterationEventWithAggregators
-
- IterationHeadTask<X,Y,S extends Function,OT> - Class in org.apache.flink.runtime.iterative.task
-
The head is responsible for coordinating an iteration and can run a
Driver
inside.
- IterationHeadTask(Environment) - Constructor for class org.apache.flink.runtime.iterative.task.IterationHeadTask
-
Create an Invokable task and set its environment.
- iterationIdCounter - Static variable in class org.apache.flink.streaming.api.graph.StreamGraphGenerator
-
- IterationIntermediateTask<S extends Function,OT> - Class in org.apache.flink.runtime.iterative.task
-
An intermediate iteration task, which runs a
Driver
inside.
- IterationIntermediateTask(Environment) - Constructor for class org.apache.flink.runtime.iterative.task.IterationIntermediateTask
-
Create an Invokable task and set its environment.
- IterationNode - Interface in org.apache.flink.optimizer.dag
-
- IterationOperator - Interface in org.apache.flink.api.common.operators
-
- IterationPlanNode - Interface in org.apache.flink.optimizer.plan
-
- IterationRuntimeContext - Interface in org.apache.flink.api.common.functions
-
- iterations - Variable in class org.apache.flink.graph.drivers.parameter.IterationConvergence.Value
-
- IterationSynchronizationSinkTask - Class in org.apache.flink.runtime.iterative.task
-
The task responsible for synchronizing all iteration heads, implemented as an output task.
- IterationSynchronizationSinkTask(Environment) - Constructor for class org.apache.flink.runtime.iterative.task.IterationSynchronizationSinkTask
-
Create an Invokable task and set its environment.
- IterationTailTask<S extends Function,OT> - Class in org.apache.flink.runtime.iterative.task
-
An iteration tail, which runs a driver inside.
- IterationTailTask(Environment) - Constructor for class org.apache.flink.runtime.iterative.task.IterationTailTask
-
Create an Invokable task and set its environment.
- iterativeBroadcastInputs - Variable in class org.apache.flink.runtime.operators.BatchTask
-
The indices of the iterative broadcast inputs.
- IterativeCondition<T> - Class in org.apache.flink.cep.pattern.conditions
-
A user-defined condition that decides if an element should be accepted in the pattern or not.
- IterativeCondition() - Constructor for class org.apache.flink.cep.pattern.conditions.IterativeCondition
-
- IterativeCondition.Context<T> - Interface in org.apache.flink.cep.pattern.conditions
-
The context used when evaluating the
condition
.
- IterativeDataSet<T> - Class in org.apache.flink.api.java.operators
-
The IterativeDataSet represents the start of an iteration.
- IterativeDataSet(ExecutionEnvironment, TypeInformation<T>, DataSet<T>, int) - Constructor for class org.apache.flink.api.java.operators.IterativeDataSet
-
- iterativeInputs - Variable in class org.apache.flink.runtime.operators.BatchTask
-
The indices of the iterative inputs.
- IterativeStream<T> - Class in org.apache.flink.streaming.api.datastream
-
The iterative data stream represents the start of an iteration in a
DataStream
.
- IterativeStream(DataStream<T>, long) - Constructor for class org.apache.flink.streaming.api.datastream.IterativeStream
-
- IterativeStream.ConnectedIterativeStreams<I,F> - Class in org.apache.flink.streaming.api.datastream
-
- iterator() - Method in class org.apache.flink.api.common.functions.util.CopyingIterator
-
- iterator() - Method in class org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase.SimpleListIterable
-
- iterator() - Method in class org.apache.flink.api.common.operators.util.FieldSet
-
- iterator() - Method in class org.apache.flink.api.common.operators.util.ListKeyGroupedIterator.ValuesIterator
-
- iterator() - Method in interface org.apache.flink.api.common.state.BroadcastState
-
Iterates over all the mappings in the state.
- iterator() - Method in interface org.apache.flink.api.common.state.MapState
-
Iterates over all the mappings in the state.
- iterator() - Method in class org.apache.flink.api.java.operators.translation.Tuple3UnwrappingIterator
-
- iterator() - Method in class org.apache.flink.api.java.operators.translation.TupleUnwrappingIterator
-
- iterator() - Method in class org.apache.flink.contrib.streaming.state.RocksDBMapState
-
- iterator() - Method in class org.apache.flink.graph.pregel.MessageIterator
-
- iterator() - Method in class org.apache.flink.graph.spargel.MessageIterator
-
- iterator() - Method in class org.apache.flink.graph.types.valuearray.ByteValueArray
-
- iterator() - Method in class org.apache.flink.graph.types.valuearray.CharValueArray
-
- iterator() - Method in class org.apache.flink.graph.types.valuearray.DoubleValueArray
-
- iterator() - Method in class org.apache.flink.graph.types.valuearray.FloatValueArray
-
- iterator() - Method in class org.apache.flink.graph.types.valuearray.IntValueArray
-
- iterator() - Method in class org.apache.flink.graph.types.valuearray.LongValueArray
-
- iterator() - Method in class org.apache.flink.graph.types.valuearray.NullValueArray
-
- iterator() - Method in class org.apache.flink.graph.types.valuearray.ShortValueArray
-
- iterator() - Method in class org.apache.flink.graph.types.valuearray.StringValueArray
-
- iterator() - Method in class org.apache.flink.queryablestate.client.state.ImmutableMapState
-
Iterates over all the mappings in the state.
- iterator() - Method in class org.apache.flink.runtime.checkpoint.StateObjectCollection
-
- iterator() - Method in class org.apache.flink.runtime.jobmanager.scheduler.LifoSetQueue
-
- iterator() - Method in class org.apache.flink.runtime.jobmanager.scheduler.SetQueue
-
- iterator() - Method in class org.apache.flink.runtime.operators.CoGroupRawDriver.SimpleIterable
-
- iterator() - Method in class org.apache.flink.runtime.operators.sort.PartialOrderPriorityQueue
-
- iterator - Variable in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger
-
The iterator to be returned by the sort-merger.
- iterator() - Method in class org.apache.flink.runtime.operators.util.metrics.CountingIterable
-
- iterator() - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateTable
-
- iterator() - Method in class org.apache.flink.runtime.state.heap.HeapMapState
-
- iterator() - Method in class org.apache.flink.runtime.state.HeapBroadcastState
-
- iterator() - Method in class org.apache.flink.runtime.state.KeyGroupRange
-
- iterator() - Method in class org.apache.flink.runtime.state.KeyGroupRangeOffsets
-
- iterator() - Method in class org.apache.flink.runtime.taskexecutor.SlotReport
-
- iterator() - Method in class org.apache.flink.runtime.util.EmptyIterator
-
- iterator() - Method in class org.apache.flink.runtime.util.EvictingBoundedList
-
- iterator() - Method in class org.apache.flink.runtime.util.NonReusingKeyGroupedIterator.ValuesIterator
-
- iterator() - Method in class org.apache.flink.runtime.util.NonReusingMutableToRegularIteratorWrapper
-
- iterator() - Method in class org.apache.flink.runtime.util.ReusingKeyGroupedIterator.ValuesIterator
-
- iterator() - Method in class org.apache.flink.runtime.util.ReusingMutableToRegularIteratorWrapper
-
- iterator() - Method in class org.apache.flink.runtime.util.SingleElementIterator
-
- iterator() - Method in class org.apache.flink.streaming.runtime.operators.windowing.KeyMap
-
Creates an iterator over the entries of this map.
- iterator() - Method in class org.apache.flink.types.ListValue
-
- iterator() - Method in class org.apache.flink.util.CloseableIterable.Empty
-
- iterator() - Method in class org.apache.flink.util.UnionIterator
-
- iterator() - Method in class org.apache.hadoop.conf.Configuration.IntegerRanges
-
- iterator() - Method in class org.apache.hadoop.conf.Configuration
-
Get an
Iterator
to go through the list of
String
key-value pairs in the configuration.
- iterator1 - Variable in class org.apache.flink.runtime.operators.sort.AbstractMergeIterator
-
- iterator2 - Variable in class org.apache.flink.runtime.operators.sort.AbstractMergeIterator
-
- iteratorException - Variable in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger
-
The exception that is set, if the iterator cannot be created.
- IteratorInputFormat<T> - Class in org.apache.flink.api.java.io
-
An input format that returns objects from an iterator.
- IteratorInputFormat(Iterator<T>) - Constructor for class org.apache.flink.api.java.io.IteratorInputFormat
-
- iteratorLock - Variable in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger
-
The monitor which guards the iterator field.
- p75 - Variable in class org.apache.flink.runtime.metrics.dump.MetricDump.HistogramDump
-
- p90 - Variable in class org.apache.flink.runtime.metrics.dump.MetricDump.HistogramDump
-
- p95 - Variable in class org.apache.flink.runtime.metrics.dump.MetricDump.HistogramDump
-
- p98 - Variable in class org.apache.flink.runtime.metrics.dump.MetricDump.HistogramDump
-
- p99 - Variable in class org.apache.flink.runtime.metrics.dump.MetricDump.HistogramDump
-
- p999 - Variable in class org.apache.flink.runtime.metrics.dump.MetricDump.HistogramDump
-
- PackagedProgram - Class in org.apache.flink.client.program
-
This class encapsulates represents a program, packaged in a jar file.
- PackagedProgram(File, String...) - Constructor for class org.apache.flink.client.program.PackagedProgram
-
Creates an instance that wraps the plan defined in the jar file using the given
argument.
- PackagedProgram(File, List<URL>, String...) - Constructor for class org.apache.flink.client.program.PackagedProgram
-
Creates an instance that wraps the plan defined in the jar file using the given
argument.
- PackagedProgram(File, String, String...) - Constructor for class org.apache.flink.client.program.PackagedProgram
-
Creates an instance that wraps the plan defined in the jar file using the given
arguments.
- PackagedProgram(File, List<URL>, String, String...) - Constructor for class org.apache.flink.client.program.PackagedProgram
-
Creates an instance that wraps the plan defined in the jar file using the given
arguments.
- PackagedProgramUtils - Class in org.apache.flink.client.program
-
- PACT - Static variable in class org.apache.flink.streaming.api.graph.JSONGenerator
-
- PageRank - Class in org.apache.flink.examples.java.graph
-
A basic implementation of the Page Rank algorithm using a bulk iteration.
- PageRank() - Constructor for class org.apache.flink.examples.java.graph.PageRank
-
- PageRank<K,VV,EV> - Class in org.apache.flink.graph.drivers
-
- PageRank() - Constructor for class org.apache.flink.graph.drivers.PageRank
-
- PageRank<K> - Class in org.apache.flink.graph.examples
-
This is an implementation of a simple PageRank algorithm, using a scatter-gather iteration.
- PageRank(double, int) - Constructor for class org.apache.flink.graph.examples.PageRank
-
Creates an instance of the PageRank algorithm.
- PageRank<K,VV,EV> - Class in org.apache.flink.graph.library.linkanalysis
-
PageRank computes a per-vertex score which is the sum of PageRank scores
transmitted over in-edges.
- PageRank(double, int) - Constructor for class org.apache.flink.graph.library.linkanalysis.PageRank
-
PageRank with a fixed number of iterations.
- PageRank(double, double) - Constructor for class org.apache.flink.graph.library.linkanalysis.PageRank
-
PageRank with a convergence threshold.
- PageRank(double, int, double) - Constructor for class org.apache.flink.graph.library.linkanalysis.PageRank
-
PageRank with a convergence threshold and a maximum iteration count.
- PageRank.BuildOutgoingEdgeList - Class in org.apache.flink.examples.java.graph
-
A reduce function that takes a sequence of edges and builds the adjacency list for the vertex where the edges
originate.
- PageRank.Dampener - Class in org.apache.flink.examples.java.graph
-
The function that applies the page rank dampening formula.
- PageRank.EpsilonFilter - Class in org.apache.flink.examples.java.graph
-
Filter that filters vertices where the rank difference is below a threshold.
- PageRank.JoinVertexWithEdgesMatch - Class in org.apache.flink.examples.java.graph
-
Join function that distributes a fraction of a vertex's rank to all neighbors.
- PageRank.RankAssigner - Class in org.apache.flink.examples.java.graph
-
A map function that assigns an initial rank to all pages.
- PageRank.RankMessenger<K> - Class in org.apache.flink.graph.examples
-
Distributes the rank of a vertex among all target vertices according to
the transition probability, which is associated with an edge as the edge
value.
- PageRank.Result<T> - Class in org.apache.flink.graph.library.linkanalysis
-
A result for the PageRank algorithm.
- PageRank.VertexRankUpdater<K> - Class in org.apache.flink.graph.examples
-
Function that updates the rank of a vertex by summing up the partial
ranks from all incoming messages and then applying the dampening formula.
- PageRankData - Class in org.apache.flink.examples.java.graph.util
-
Provides the default data sets used for the PageRank example program.
- PageRankData() - Constructor for class org.apache.flink.examples.java.graph.util.PageRankData
-
- PageRankData - Class in org.apache.flink.graph.examples.data
-
Provides the default data set used for the PageRank test program.
- PageRankData - Class in org.apache.flink.test.testdata
-
Test data for PageRank programs.
- pairComparator - Variable in class org.apache.flink.runtime.operators.hash.AbstractHashTableProber
-
- pairComparator - Variable in class org.apache.flink.runtime.operators.sort.AbstractMergeIterator
-
- parallelism(int) - Method in class org.apache.flink.api.java.operators.DeltaIteration
-
Sets the parallelism for the iteration.
- parallelism - Variable in class org.apache.flink.api.java.operators.Operator
-
- parallelism - Variable in class org.apache.flink.graph.drivers.DriverBase
-
- parallelism - Variable in class org.apache.flink.graph.drivers.input.InputBase
-
- parallelism - Variable in class org.apache.flink.graph.generator.GraphGeneratorBase
-
- parallelism - Variable in class org.apache.flink.graph.GraphAnalyticBase
-
- parallelism - Variable in class org.apache.flink.graph.utils.proxy.GraphAlgorithmWrappingBase
-
- parallelism - Variable in class org.apache.flink.python.api.PythonOperationInfo
-
- PARALLELISM - Static variable in class org.apache.flink.streaming.api.graph.JSONGenerator
-
- PARALLELISM_AUTO_MAX - Static variable in class org.apache.flink.api.common.ExecutionConfig
-
Deprecated.
- PARALLELISM_AUTO_MAX_ERROR_MESSAGE - Static variable in class org.apache.flink.runtime.executiongraph.ExecutionGraphBuilder
-
- PARALLELISM_DEFAULT - Static variable in class org.apache.flink.api.common.ExecutionConfig
-
The flag value indicating use of the default parallelism.
- PARALLELISM_OPTION - Static variable in class org.apache.flink.client.cli.CliFrontendParser
-
- PARALLELISM_UNKNOWN - Static variable in class org.apache.flink.api.common.ExecutionConfig
-
The flag value indicating an unknown or unset parallelism.
- parallelismQueryParameter - Variable in class org.apache.flink.runtime.webmonitor.handlers.JarRunMessageParameters
-
- ParallelismQueryParameter - Class in org.apache.flink.runtime.webmonitor.handlers
-
Query parameter specifying the parallelism of the job.
- ParallelismQueryParameter() - Constructor for class org.apache.flink.runtime.webmonitor.handlers.ParallelismQueryParameter
-
- ParallelIteratorInputFormat<T> - Class in org.apache.flink.api.java.io
-
- ParallelIteratorInputFormat(SplittableIterator<T>) - Constructor for class org.apache.flink.api.java.io.ParallelIteratorInputFormat
-
- ParallelSourceFunction<OUT> - Interface in org.apache.flink.streaming.api.functions.source
-
A stream data source that is executed in parallel.
- Parameter<T> - Interface in org.apache.flink.graph.drivers.parameter
-
Encapsulates the usage and configuration of a command-line parameter.
- PARAMETER_JOB_ID - Static variable in class org.apache.flink.runtime.rest.handler.legacy.metrics.JobMetricsHandler
-
- PARAMETER_METRICS - Static variable in class org.apache.flink.runtime.rest.handler.legacy.metrics.AbstractMetricsHandler
-
- PARAMETER_SUBTASK_INDEX - Static variable in class org.apache.flink.runtime.rest.handler.legacy.SubtaskExecutionAttemptDetailsHandler
-
- PARAMETER_VERTEX_ID - Static variable in class org.apache.flink.runtime.rest.handler.legacy.metrics.JobVertexMetricsHandler
-
Deprecated.
- parameterizeChannel(Channel, boolean, ExecutionMode, boolean) - Method in class org.apache.flink.optimizer.dataproperties.GlobalProperties
-
- parameterizeChannel(Channel, boolean, ExecutionMode, boolean) - Method in class org.apache.flink.optimizer.dataproperties.RequestedGlobalProperties
-
Parametrizes the ship strategy fields of a channel such that the channel produces
the desired global properties.
- parameterizeChannel(Channel) - Method in class org.apache.flink.optimizer.dataproperties.RequestedLocalProperties
-
Parametrizes the local strategy fields of a channel such that the channel produces the desired local properties.
- Parameterized - Interface in org.apache.flink.graph.drivers.parameter
-
A configurable command-line choice, such as an input or algorithm.
- ParameterizedBase - Class in org.apache.flink.graph.drivers.parameter
-
Base class for a
Parameterized
which maintains a list of parameters
used to print the command-line usage string and configure parameters.
- ParameterizedBase() - Constructor for class org.apache.flink.graph.drivers.parameter.ParameterizedBase
-
- ParameterlessTypeSerializerConfig - Class in org.apache.flink.api.common.typeutils
-
- ParameterlessTypeSerializerConfig() - Constructor for class org.apache.flink.api.common.typeutils.ParameterlessTypeSerializerConfig
-
This empty nullary constructor is required for deserializing the configuration.
- ParameterlessTypeSerializerConfig(String) - Constructor for class org.apache.flink.api.common.typeutils.ParameterlessTypeSerializerConfig
-
- parameters - Variable in class org.apache.flink.api.common.operators.Operator
-
- ParameterTool - Class in org.apache.flink.api.java.utils
-
This class provides simple utility methods for reading and parsing program arguments from different sources.
- ParameterValuesProvider - Interface in org.apache.flink.api.java.io.jdbc.split
-
This interface is used by the
JDBCInputFormat
to compute the list of parallel query to run (i.e.
- Params() - Constructor for class org.apache.flink.examples.java.ml.LinearRegression.Params
-
- Params(double, double) - Constructor for class org.apache.flink.examples.java.ml.LinearRegression.Params
-
- PARAMS - Static variable in class org.apache.flink.examples.java.ml.util.LinearRegressionData
-
- paramsFromGenericOptionsParser(String[]) - Static method in class org.apache.flink.hadoopcompatibility.HadoopUtils
-
Returns
ParameterTool
for the arguments parsed by
GenericOptionsParser
.
- parent - Variable in class org.apache.flink.runtime.io.network.partition.ResultSubpartition
-
The parent partition this subpartition belongs to.
- parent - Variable in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
-
The parent group containing this group.
- parent() - Method in class org.apache.flink.runtime.metrics.groups.JobManagerJobMetricGroup
-
- parent() - Method in class org.apache.flink.runtime.metrics.groups.OperatorMetricGroup
-
- parent() - Method in class org.apache.flink.runtime.metrics.groups.TaskManagerJobMetricGroup
-
- parent() - Method in class org.apache.flink.runtime.metrics.groups.TaskMetricGroup
-
- parentFirst(URL[], ClassLoader) - Static method in class org.apache.flink.runtime.execution.librarycache.FlinkUserCodeClassLoaders
-
- parentID - Variable in class org.apache.flink.python.api.PythonOperationInfo
-
- parentMetricGroup - Variable in class org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
-
- parse(String) - Static method in class org.apache.flink.api.java.typeutils.TypeInfoParser
-
Deprecated.
Generates an instance of TypeInformation
by parsing a type
information string.
- parse(Options, String[], boolean) - Static method in class org.apache.flink.client.cli.CliFrontendParser
-
- parse(String) - Static method in class org.apache.flink.configuration.MemorySize
-
Parses the given string as as MemorySize.
- parse(String) - Static method in class org.apache.flink.table.client.cli.SqlCommandParser
-
- parse(URL) - Static method in class org.apache.flink.table.client.config.Environment
-
Parses an environment file from an URL.
- parse(String) - Static method in class org.apache.flink.table.client.config.Environment
-
Parses an environment file from an String.
- parseArguments(String[]) - Static method in class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
-
- parseBytes(String) - Static method in class org.apache.flink.configuration.MemorySize
-
Parses the given string as bytes.
- parseClass(Class<?>) - Static method in class org.openjdk.jol.info.ClassLayout
-
- parseCommandLineOptions(String[], boolean) - Method in interface org.apache.flink.client.cli.CustomCommandLine
-
- parseDateFormat(String, String, TimeZone) - Static method in class org.apache.calcite.avatica.util.DateTimeUtils
-
Deprecated.
- parseDateFormat(String, DateFormat, TimeZone) - Static method in class org.apache.calcite.avatica.util.DateTimeUtils
-
- parsedValues - Variable in class org.apache.flink.api.java.io.CsvInputFormat
-
- parseDynamicProperties(CommandLine) - Static method in class org.apache.flink.runtime.clusterframework.BootstrapTools
-
Parse the dynamic properties (passed on the command line).
- parseEmbeddedModeClient(String[]) - Static method in class org.apache.flink.table.client.cli.CliOptionsParser
-
- ParseException - Exception in org.apache.flink.api.common.io
-
Exception indicating that the parsing of input contents has failed because the data
does not match the configured parser.
- ParseException() - Constructor for exception org.apache.flink.api.common.io.ParseException
-
- ParseException(String) - Constructor for exception org.apache.flink.api.common.io.ParseException
-
- ParseException(Throwable) - Constructor for exception org.apache.flink.api.common.io.ParseException
-
- ParseException(String, Throwable) - Constructor for exception org.apache.flink.api.common.io.ParseException
-
- parseField(byte[], int, int, byte[], BigDecimal) - Method in class org.apache.flink.types.parser.BigDecParser
-
- parseField(byte[], int, int) - Static method in class 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) - Static method in class 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) - Method in class org.apache.flink.types.parser.BigIntParser
-
- parseField(byte[], int, int) - Static method in class 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) - Static method in class 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) - Method in class org.apache.flink.types.parser.BooleanParser
-
- parseField(byte[], int, int, byte[], BooleanValue) - Method in class org.apache.flink.types.parser.BooleanValueParser
-
- parseField(byte[], int, int, byte[], Byte) - Method in class org.apache.flink.types.parser.ByteParser
-
- parseField(byte[], int, int) - Static method in class org.apache.flink.types.parser.ByteParser
-
Static utility to parse a field of type byte from a byte sequence that represents text
characters
(such as when read from a file stream).
- parseField(byte[], int, int, char) - Static method in class org.apache.flink.types.parser.ByteParser
-
Static utility to parse a field of type byte from a byte sequence that represents text
characters
(such as when read from a file stream).
- parseField(byte[], int, int, byte[], ByteValue) - Method in class org.apache.flink.types.parser.ByteValueParser
-
- parseField(byte[], int, int, byte[], Double) - Method in class org.apache.flink.types.parser.DoubleParser
-
- parseField(byte[], int, int) - Static method in class org.apache.flink.types.parser.DoubleParser
-
Static utility to parse a field of type double from a byte sequence that represents text
characters
(such as when read from a file stream).
- parseField(byte[], int, int, char) - Static method in class org.apache.flink.types.parser.DoubleParser
-
Static utility to parse a field of type double from a byte sequence that represents text
characters
(such as when read from a file stream).
- parseField(byte[], int, int, byte[], DoubleValue) - Method in class org.apache.flink.types.parser.DoubleValueParser
-
- parseField(byte[], int, int, byte[], T) - Method in class org.apache.flink.types.parser.FieldParser
-
Each parser's logic should be implemented inside this method
- parseField(byte[], int, int, byte[], Float) - Method in class org.apache.flink.types.parser.FloatParser
-
- parseField(byte[], int, int) - Static method in class org.apache.flink.types.parser.FloatParser
-
Static utility to parse a field of type float from a byte sequence that represents text
characters
(such as when read from a file stream).
- parseField(byte[], int, int, char) - Static method in class org.apache.flink.types.parser.FloatParser
-
Static utility to parse a field of type float from a byte sequence that represents text
characters
(such as when read from a file stream).
- parseField(byte[], int, int, byte[], FloatValue) - Method in class org.apache.flink.types.parser.FloatValueParser
-
- parseField(byte[], int, int, byte[], Integer) - Method in class org.apache.flink.types.parser.IntParser
-
- parseField(byte[], int, int) - Static method in class org.apache.flink.types.parser.IntParser
-
Static utility to parse a field of type int from a byte sequence that represents text
characters
(such as when read from a file stream).
- parseField(byte[], int, int, char) - Static method in class org.apache.flink.types.parser.IntParser
-
Static utility to parse a field of type int from a byte sequence that represents text
characters
(such as when read from a file stream).
- parseField(byte[], int, int, byte[], IntValue) - Method in class org.apache.flink.types.parser.IntValueParser
-
- parseField(byte[], int, int, byte[], Long) - Method in class org.apache.flink.types.parser.LongParser
-
- parseField(byte[], int, int) - Static method in class org.apache.flink.types.parser.LongParser
-
Static utility to parse a field of type long from a byte sequence that represents text characters
(such as when read from a file stream).
- parseField(byte[], int, int, char) - Static method in class org.apache.flink.types.parser.LongParser
-
Static utility to parse a field of type long from a byte sequence that represents text characters
(such as when read from a file stream).
- parseField(byte[], int, int, byte[], LongValue) - Method in class org.apache.flink.types.parser.LongValueParser
-
- parseField(byte[], int, int, byte[], Short) - Method in class org.apache.flink.types.parser.ShortParser
-
- parseField(byte[], int, int) - Static method in class org.apache.flink.types.parser.ShortParser
-
Static utility to parse a field of type short from a byte sequence that represents text characters
(such as when read from a file stream).
- parseField(byte[], int, int, char) - Static method in class org.apache.flink.types.parser.ShortParser
-
Static utility to parse a field of type short from a byte sequence that represents text characters
(such as when read from a file stream).
- parseField(byte[], int, int, byte[], ShortValue) - Method in class org.apache.flink.types.parser.ShortValueParser
-
- parseField(byte[], int, int, byte[], Date) - Method in class org.apache.flink.types.parser.SqlDateParser
-
- parseField(byte[], int, int) - Static method in class 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) - Static method in class 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) - Method in class org.apache.flink.types.parser.SqlTimeParser
-
- parseField(byte[], int, int) - Static method in class 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) - Static method in class 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) - Method in class org.apache.flink.types.parser.SqlTimestampParser
-
- parseField(byte[], int, int) - Static method in class 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) - Static method in class 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) - Method in class org.apache.flink.types.parser.StringParser
-
- parseField(byte[], int, int, byte[], StringValue) - Method in class org.apache.flink.types.parser.StringValueParser
-
- parseGatewayModeClient(String[]) - Static method in class org.apache.flink.table.client.cli.CliOptionsParser
-
- parseGatewayModeGateway(String[]) - Static method in class org.apache.flink.table.client.cli.CliOptionsParser
-
- parseHostPortAddress(String) - Static method in class org.apache.flink.client.ClientUtils
-
Utility method that converts a string of the form "host:port" into an
InetSocketAddress
.
- parseJobVertexId(Map<String, String>) - Static method in class org.apache.flink.runtime.rest.handler.legacy.AbstractJobVertexRequestHandler
-
Returns the job vertex ID parsed from the provided parameters.
- parseLocalStateDirectories(Configuration) - Static method in class org.apache.flink.configuration.ConfigurationUtils
-
- parseParameters(String[]) - Method in class org.apache.flink.client.cli.CliFrontend
-
Parses the command line arguments and starts the requested action.
- parsePrecisionDateTimeLiteral(String, String, TimeZone) - Static method in class org.apache.calcite.avatica.util.DateTimeUtils
-
Deprecated.
- parsePrecisionDateTimeLiteral(String, DateFormat, TimeZone, int) - Static method in class org.apache.calcite.avatica.util.DateTimeUtils
-
Parses a string using
SimpleDateFormat
and a given pattern, and
if present, parses a fractional seconds component.
- parseQuotedStrings - Variable in class org.apache.flink.api.java.io.CsvReader
-
- parseQuotedStrings(char) - Method in class org.apache.flink.api.java.io.CsvReader
-
Enables quoted String parsing.
- parseQuotedStringsEdges(char) - Method in class org.apache.flink.graph.GraphCsvReader
-
Enables quoted String parsing for Edge Csv Reader.
- parseQuotedStringsVertices(char) - Method in class org.apache.flink.graph.GraphCsvReader
-
Enables quoted String parsing for Vertex Csv Reader.
- parseRecord(Object[], byte[], int, int) - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
-
- parseRecord(Object[], byte[], int, int) - Method in class org.apache.flink.api.java.io.RowCsvInputFormat
-
- parseRunCommand(String[]) - Static method in class org.apache.flink.client.cli.CliFrontendParser
-
- parseTempDirectories(Configuration) - Static method in class org.apache.flink.configuration.ConfigurationUtils
-
- PartialGroupProperties - Class in org.apache.flink.optimizer.operators
-
- PartialGroupProperties(FieldSet) - Constructor for class org.apache.flink.optimizer.operators.PartialGroupProperties
-
- PartialInputChannelDeploymentDescriptor - Class in org.apache.flink.runtime.deployment
-
Partial deployment descriptor for a single input channel instance.
- PartialInputChannelDeploymentDescriptor(IntermediateDataSetID, ResultPartitionID, TaskManagerLocation, int) - Constructor for class org.apache.flink.runtime.deployment.PartialInputChannelDeploymentDescriptor
-
- PartialModelBuilder() - Constructor for class org.apache.flink.streaming.examples.ml.IncrementalLearningSkeleton.PartialModelBuilder
-
- PartialOrderPriorityQueue<T> - Class in org.apache.flink.runtime.operators.sort
-
This class implements a priority-queue, which maintains a partial
ordering of its elements such that the least element can always be found
in constant time.
- PartialOrderPriorityQueue(Comparator<T>, int) - Constructor for class org.apache.flink.runtime.operators.sort.PartialOrderPriorityQueue
-
- PartialSolutionPlaceHolder(BulkIterationBase<OT>, OperatorInformation<OT>) - Constructor for class org.apache.flink.api.common.operators.base.BulkIterationBase.PartialSolutionPlaceHolder
-
- partition(K, int) - Method in interface org.apache.flink.api.common.functions.Partitioner
-
Computes the partition for the given key.
- partition(Integer, int) - Method in class org.apache.flink.api.java.functions.IdPartitioner
-
- partition(T, int) - Method in class org.apache.flink.api.java.io.SplitDataProperties.SourcePartitionerMarker
-
- partition(T, byte[], byte[], String, int[]) - Method in class org.apache.flink.streaming.connectors.kafka.partitioner.FlinkFixedPartitioner
-
- partition(T, byte[], byte[], String, int[]) - Method in class org.apache.flink.streaming.connectors.kafka.partitioner.FlinkKafkaDelegatePartitioner
-
Deprecated.
- partition(T, byte[], byte[], String, int[]) - Method in class org.apache.flink.streaming.connectors.kafka.partitioner.FlinkKafkaPartitioner
-
Determine the id of the partition that the record should be written to.
- partition(T, byte[], byte[], int) - Method in class org.apache.flink.streaming.connectors.kafka.partitioner.KafkaPartitioner
-
Deprecated.
- PARTITION_DISCOVERY_DISABLED - Static variable in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumerBase
-
The default interval to execute partition discovery,
in milliseconds (Long.MIN_VALUE
, i.e.
- partitionBuffers - Variable in class org.apache.flink.runtime.operators.hash.HashPartition
-
- partitionByHash(int...) - Method in class org.apache.flink.api.java.DataSet
-
Hash-partitions a DataSet on the specified key fields.
- partitionByHash(String...) - Method in class org.apache.flink.api.java.DataSet
-
Hash-partitions a DataSet on the specified key fields.
- partitionByHash(KeySelector<T, K>) - Method in class org.apache.flink.api.java.DataSet
-
Partitions a DataSet using the specified KeySelector.
- partitionByRange(int...) - Method in class org.apache.flink.api.java.DataSet
-
Range-partitions a DataSet on the specified key fields.
- partitionByRange(String...) - Method in class org.apache.flink.api.java.DataSet
-
Range-partitions a DataSet on the specified key fields.
- partitionByRange(KeySelector<T, K>) - Method in class org.apache.flink.api.java.DataSet
-
Range-partitions a DataSet using the specified KeySelector.
- partitionByRange(DataSet<T>, DataDistribution, int...) - Static method in class org.apache.flink.api.java.utils.DataSetUtils
-
Range-partitions a DataSet on the specified tuple field positions.
- partitionByRange(DataSet<T>, DataDistribution, String...) - Static method in class org.apache.flink.api.java.utils.DataSetUtils
-
Range-partitions a DataSet on the specified fields.
- partitionByRange(DataSet<T>, DataDistribution, KeySelector<T, K>) - Static method in class org.apache.flink.api.java.utils.DataSetUtils
-
Range-partitions a DataSet using the specified key selector function.
- partitionCustom(Partitioner<K>, int) - Method in class org.apache.flink.api.java.DataSet
-
Partitions a tuple DataSet on the specified key fields using a custom partitioner.
- partitionCustom(Partitioner<K>, String) - Method in class org.apache.flink.api.java.DataSet
-
Partitions a POJO DataSet on the specified key fields using a custom partitioner.
- partitionCustom(Partitioner<K>, KeySelector<T, K>) - Method in class org.apache.flink.api.java.DataSet
-
Partitions a DataSet on the key returned by the selector, using a custom partitioner.
- partitionCustom(Partitioner<K>, int) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Partitions a tuple DataStream on the specified key fields using a custom partitioner.
- partitionCustom(Partitioner<K>, String) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Partitions a POJO DataStream on the specified key fields using a custom partitioner.
- partitionCustom(Partitioner<K>, KeySelector<T, K>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Partitions a DataStream on the key returned by the selector, using a custom partitioner.
- PartitionDescriptor(PartitionOperatorBase.PartitionMethod, FieldSet, Ordering, Partitioner<?>, DataDistribution) - Constructor for class org.apache.flink.optimizer.dag.PartitionNode.PartitionDescriptor
-
- Partitioner<K> - Interface in org.apache.flink.api.common.functions
-
Function to implement a custom partition assignment for keys.
- partitioner - Variable in class org.apache.flink.streaming.connectors.kafka.KafkaTableSink
-
- PartitionException - Exception in org.apache.flink.runtime.taskexecutor.exceptions
-
Exception indicating a problem with the result partitions on the
TaskExecutor
side.
- PartitionException(String) - Constructor for exception org.apache.flink.runtime.taskexecutor.exceptions.PartitionException
-
- PartitionException(String, Throwable) - Constructor for exception org.apache.flink.runtime.taskexecutor.exceptions.PartitionException
-
- PartitionException(Throwable) - Constructor for exception org.apache.flink.runtime.taskexecutor.exceptions.PartitionException
-
- partitionId - Variable in class org.apache.flink.runtime.io.network.partition.consumer.InputChannel
-
- PartitionInfo - Class in org.apache.flink.runtime.executiongraph
-
Contains information where to find a partition.
- PartitionInfo(IntermediateDataSetID, InputChannelDeploymentDescriptor) - Constructor for class org.apache.flink.runtime.executiongraph.PartitionInfo
-
- PartitioningProperty - Enum in org.apache.flink.optimizer.dataproperties
-
An enumeration of the different types of distributing data across partitions or
parallel workers.
- PartitionNode - Class in org.apache.flink.optimizer.dag
-
The optimizer's internal representation of a Partition operator node.
- PartitionNode(PartitionOperatorBase<?>) - Constructor for class org.apache.flink.optimizer.dag.PartitionNode
-
- PartitionNode.PartitionDescriptor - Class in org.apache.flink.optimizer.dag
-
- PartitionNotFoundException - Exception in org.apache.flink.runtime.io.network.partition
-
Exception for failed partition requests due to non-existing partitions.
- PartitionNotFoundException(ResultPartitionID) - Constructor for exception org.apache.flink.runtime.io.network.partition.PartitionNotFoundException
-
- partitionNumber - Variable in class org.apache.flink.api.common.io.GenericInputFormat
-
The partition of this split.
- PartitionOperator<T> - Class in org.apache.flink.api.java.operators
-
This operator represents a partitioning.
- PartitionOperator(DataSet<T>, PartitionOperatorBase.PartitionMethod, Keys<T>, String) - Constructor for class org.apache.flink.api.java.operators.PartitionOperator
-
- PartitionOperator(DataSet<T>, PartitionOperatorBase.PartitionMethod, Keys<T>, DataDistribution, String) - Constructor for class org.apache.flink.api.java.operators.PartitionOperator
-
- PartitionOperator(DataSet<T>, PartitionOperatorBase.PartitionMethod, String) - Constructor for class org.apache.flink.api.java.operators.PartitionOperator
-
- PartitionOperator(DataSet<T>, Keys<T>, Partitioner<?>, String) - Constructor for class org.apache.flink.api.java.operators.PartitionOperator
-
- PartitionOperator(DataSet<T>, Keys<T>, Partitioner<P>, TypeInformation<P>, String) - Constructor for class org.apache.flink.api.java.operators.PartitionOperator
-
- PartitionOperatorBase<IN> - Class in org.apache.flink.api.common.operators.base
-
- PartitionOperatorBase(UnaryOperatorInformation<IN, IN>, PartitionOperatorBase.PartitionMethod, int[], String) - Constructor for class org.apache.flink.api.common.operators.base.PartitionOperatorBase
-
- PartitionOperatorBase(UnaryOperatorInformation<IN, IN>, PartitionOperatorBase.PartitionMethod, String) - Constructor for class org.apache.flink.api.common.operators.base.PartitionOperatorBase
-
- PartitionOperatorBase.PartitionMethod - Enum in org.apache.flink.api.common.operators.base
-
- PartitionProducerDisposedException - Exception in org.apache.flink.runtime.jobmanager
-
Exception returned to a TaskManager on JobManagerMessages.RequestPartitionProducerState
if the producer of a partition has been disposed.
- PartitionProducerDisposedException(ResultPartitionID) - Constructor for exception org.apache.flink.runtime.jobmanager.PartitionProducerDisposedException
-
- PartitionProducerStateChecker - Interface in org.apache.flink.runtime.io.network.netty
-
Intermediate partition state checker to query the JobManager about the state
of the producer of a result partition.
- PartitionRequestClient - Class in org.apache.flink.runtime.io.network.netty
-
Partition request client for remote partition requests.
- partitionRequestInitialBackoff() - Method in class org.apache.flink.runtime.taskmanager.NetworkEnvironmentConfiguration
-
- partitionRequestMaxBackoff() - Method in class org.apache.flink.runtime.taskmanager.NetworkEnvironmentConfiguration
-
- partitionsBeingBuilt - Variable in class org.apache.flink.runtime.operators.hash.MutableHashTable
-
The partitions that are built by processing the current partition.
- partitionsFor(String) - Method in class org.apache.flink.streaming.connectors.kafka.internal.FlinkKafkaProducer
-
- PartitionTransformation<T> - Class in org.apache.flink.streaming.api.transformations
-
This transformation represents a change of partitioning of the input elements.
- PartitionTransformation(StreamTransformation<T>, StreamPartitioner<T>) - Constructor for class org.apache.flink.streaming.api.transformations.PartitionTransformation
-
- PassThroughAllWindowFunction<W extends Window,T> - Class in org.apache.flink.streaming.api.functions.windowing
-
- PassThroughAllWindowFunction() - Constructor for class org.apache.flink.streaming.api.functions.windowing.PassThroughAllWindowFunction
-
- PassThroughWindowFunction<K,W extends Window,T> - Class in org.apache.flink.streaming.api.functions.windowing
-
- PassThroughWindowFunction() - Constructor for class org.apache.flink.streaming.api.functions.windowing.PassThroughWindowFunction
-
- Path - Class in org.apache.flink.core.fs
-
- Path() - Constructor for class org.apache.flink.core.fs.Path
-
Constructs a new (empty) path object (used to reconstruct path object after RPC call).
- Path(URI) - Constructor for class org.apache.flink.core.fs.Path
-
Constructs a path object from a given URI.
- Path(String, String) - Constructor for class org.apache.flink.core.fs.Path
-
Resolve a child path against a parent path.
- Path(Path, String) - Constructor for class org.apache.flink.core.fs.Path
-
Resolve a child path against a parent path.
- Path(String, Path) - Constructor for class org.apache.flink.core.fs.Path
-
Resolve a child path against a parent path.
- Path(Path, Path) - Constructor for class org.apache.flink.core.fs.Path
-
Resolve a child path against a parent path.
- Path(String) - Constructor for class org.apache.flink.core.fs.Path
-
Construct a path from a String.
- Path(String, String, String) - Constructor for class org.apache.flink.core.fs.Path
-
Construct a Path from a scheme, an authority and a path string.
- path(String) - Method in class org.apache.flink.orc.OrcTableSource.Builder
-
Sets the path of the ORC file(s).
- path(String, boolean) - Method in class org.apache.flink.orc.OrcTableSource.Builder
-
Sets the path of the ORC file(s).
- path - Variable in class org.apache.flink.python.api.PythonOperationInfo
-
- path() - Method in interface org.apache.flink.runtime.instance.ActorGateway
-
Returns the path of the remote instance.
- path() - Method in class org.apache.flink.runtime.instance.AkkaActorGateway
-
Returns the ActorPath of the remote instance.
- path - Variable in class org.apache.flink.storm.util.FileSpout
-
- path - Variable in class org.apache.flink.streaming.api.functions.sink.WriteSinkFunction
-
Deprecated.
- PATH_HADOOP_CONFIG - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- PathGraph - Class in org.apache.flink.graph.drivers.input
-
- PathGraph() - Constructor for class org.apache.flink.graph.drivers.input.PathGraph
-
- PathGraph - Class in org.apache.flink.graph.generator
-
- PathGraph(ExecutionEnvironment, long) - Constructor for class org.apache.flink.graph.generator.PathGraph
-
An undirected
Graph
with
n
vertices where each vertex
v
i connects to adjacent vertices v
i+1 when
i < n-1
and v
i-1 when
i > 0
.
- pathToCheckpointId(String) - Static method in class org.apache.flink.runtime.checkpoint.ZooKeeperCompletedCheckpointStore
-
Converts a path to the checkpoint id.
- pattern(DataStream<T>, Pattern<T, ?>) - Static method in class org.apache.flink.cep.CEP
-
- pattern(DataStream<T>, Pattern<T, ?>, EventComparator<T>) - Static method in class org.apache.flink.cep.CEP
-
- Pattern<T,F extends T> - Class in org.apache.flink.cep.pattern
-
Base class for a pattern definition.
- Pattern(String, Pattern<T, ? extends T>, Quantifier.ConsumingStrategy, AfterMatchSkipStrategy) - Constructor for class org.apache.flink.cep.pattern.Pattern
-
- PatternFlatSelectFunction<IN,OUT> - Interface in org.apache.flink.cep
-
Base interface for a pattern select function which can produce multiple resulting elements.
- PatternFlatTimeoutFunction<IN,OUT> - Interface in org.apache.flink.cep
-
Base interface for a pattern timeout function which can produce multiple resulting elements.
- PatternSelectFunction<IN,OUT> - Interface in org.apache.flink.cep
-
Base interface for a pattern select function.
- PatternStream<T> - Class in org.apache.flink.cep
-
Stream abstraction for CEP pattern detection.
- PatternStream.CoMapTimeout<R,L> - Class in org.apache.flink.cep
-
Used for joining results from timeout side-output for API backward compatibility.
- PatternTimeoutFunction<IN,OUT> - Interface in org.apache.flink.cep
-
Base interface for a pattern timeout function.
- payload(T) - Static method in class org.apache.flink.table.client.gateway.TypedResult
-
- peek() - Method in class org.apache.flink.runtime.jobmanager.scheduler.LifoSetQueue
-
- peek() - Method in class org.apache.flink.runtime.jobmanager.scheduler.SetQueue
-
- peek() - Method in class org.apache.flink.runtime.operators.sort.PartialOrderPriorityQueue
-
Returns the least element of the PriorityQueue in constant time, but
does not remove it from the priority queue.
- peek() - Method in class org.apache.flink.streaming.connectors.kafka.internals.ClosableBlockingQueue
-
Returns the queue's next element without removing it, if the queue is non-empty.
- peekBlockingly() - Method in class org.apache.flink.streaming.api.operators.async.queue.OrderedStreamElementQueue
-
- peekBlockingly() - Method in interface org.apache.flink.streaming.api.operators.async.queue.StreamElementQueue
-
Peek at the head of the queue and return the first completed
AsyncResult
.
- peekBlockingly() - Method in class org.apache.flink.streaming.api.operators.async.queue.UnorderedStreamElementQueue
-
- PendingCheckpoint - Class in org.apache.flink.runtime.checkpoint
-
A pending checkpoint is a checkpoint that has been started, but has not been
acknowledged by all tasks that need to acknowledge it.
- PendingCheckpoint(JobID, long, long, Map<ExecutionAttemptID, ExecutionVertex>, CheckpointProperties, CheckpointStorageLocation, Executor) - Constructor for class org.apache.flink.runtime.checkpoint.PendingCheckpoint
-
- PendingCheckpoint.TaskAcknowledgeResult - Enum in org.apache.flink.runtime.checkpoint
-
- pendingCheckpoints - Variable in class org.apache.flink.streaming.api.functions.source.MessageAcknowledgingSourceBase
-
The list with IDs from checkpoints that were triggered, but not yet completed or notified of
completion.
- PendingCheckpointStatistics(long, CheckpointStatsStatus, boolean, long, long, long, long, long, int, int, Map<JobVertexID, TaskCheckpointStatistics>) - Constructor for class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics.PendingCheckpointStatistics
-
- PendingCheckpointStats - Class in org.apache.flink.runtime.checkpoint
-
Statistics for a pending checkpoint that is still in progress.
- pendingCommitTransactions - Variable in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
-
- pendingCommitTransactions - Variable in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.State
-
- pendingFiles - Variable in class org.apache.flink.streaming.connectors.fs.RollingSink.BucketState
-
Deprecated.
Pending files that accumulated since the last checkpoint.
- pendingFilesPerCheckpoint - Variable in class org.apache.flink.streaming.connectors.fs.RollingSink.BucketState
-
Deprecated.
When doing a checkpoint we move the pending files since the last checkpoint to this map
with the id of the checkpoint.
- pendingRecords - Variable in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducerBase
-
Number of unacknowledged records.
- pendingRecordsLock - Variable in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducerBase
-
Lock for accessing the pending records.
- PendingSlotRequest - Class in org.apache.flink.runtime.resourcemanager.slotmanager
-
- PendingSlotRequest(SlotRequest) - Constructor for class org.apache.flink.runtime.resourcemanager.slotmanager.PendingSlotRequest
-
- PendingSubtaskCheckpointStatistics(int) - Constructor for class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.PendingSubtaskCheckpointStatistics
-
- pendingTransaction - Variable in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.State
-
- pendingTransactions() - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
-
- performOperation() - Method in class org.apache.flink.runtime.io.async.AbstractAsyncCallableWithResources
-
Implements the actual operation.
- performSnapshot(long, long, CheckpointStreamFactory, CheckpointOptions) - Method in interface org.apache.flink.runtime.state.SnapshotStrategy
-
- PeriodicOffsetCommitter - Class in org.apache.flink.streaming.connectors.kafka.internals
-
A thread that periodically writes the current Kafka partition offsets to Zookeeper.
- permanent(Path) - Static method in class org.apache.flink.runtime.state.SnapshotDirectory
-
- PermanentBlobCache - Class in org.apache.flink.runtime.blob
-
Provides a cache for permanent BLOB files including a per-job ref-counting and a staged cleanup.
- PermanentBlobCache(Configuration, BlobView, InetSocketAddress) - Constructor for class org.apache.flink.runtime.blob.PermanentBlobCache
-
Instantiates a new cache for permanent BLOBs which are also available in an HA store.
- PermanentBlobKey - Class in org.apache.flink.runtime.blob
-
BLOB key referencing permanent BLOB files.
- PermanentBlobKey() - Constructor for class org.apache.flink.runtime.blob.PermanentBlobKey
-
Constructs a new BLOB key.
- PermanentBlobService - Interface in org.apache.flink.runtime.blob
-
A service to retrieve permanent binary large objects (BLOBs).
- permuteResults - Variable in class org.apache.flink.graph.library.clustering.TriangleListingBase
-
- persist() - Method in class org.apache.flink.streaming.runtime.operators.windowing.MergingWindowSet
-
Persist the updated mapping to the given state if the mapping changed since
initialization.
- PersistentMetadataCheckpointStorageLocation - Class in org.apache.flink.runtime.state.memory
-
A checkpoint storage location for the
MemoryStateBackend
when it durably
persists the metadata in a file system.
- PersistentMetadataCheckpointStorageLocation(FileSystem, Path, int) - Constructor for class org.apache.flink.runtime.state.memory.PersistentMetadataCheckpointStorageLocation
-
Creates a checkpoint storage persists metadata to a file system and stores state
in line in state handles with the metadata.
- PerWindowStateStore(KeyedStateBackend<?>, ExecutionConfig) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.PerWindowStateStore
-
- PiEstimation - Class in org.apache.flink.examples.java.misc
-
Estimates the value of Pi using the Monte Carlo method.
- PiEstimation() - Constructor for class org.apache.flink.examples.java.misc.PiEstimation
-
- PiEstimation.Sampler - Class in org.apache.flink.examples.java.misc
-
Sampler randomly emits points that fall within a square of edge x * y.
- PiEstimation.SumReducer - Class in org.apache.flink.examples.java.misc
-
Simply sums up all long values.
- PIPELINED_REGION_RESTART_STRATEGY_NAME - Static variable in class org.apache.flink.runtime.executiongraph.failover.FailoverStrategyLoader
-
- PipelineErrorHandler - Class in org.apache.flink.runtime.rest.handler
-
This is the last handler in the pipeline.
- PipelineErrorHandler(Logger, Map<String, String>) - Constructor for class org.apache.flink.runtime.rest.handler.PipelineErrorHandler
-
- PipelineErrorHandler - Class in org.apache.flink.runtime.webmonitor
-
This is the last handler in the pipeline.
- PipelineErrorHandler(Logger) - Constructor for class org.apache.flink.runtime.webmonitor.PipelineErrorHandler
-
- PlaceholderStreamStateHandle - Class in org.apache.flink.runtime.state
-
A placeholder state handle for shared state that will replaced by an original that was
created in a previous checkpoint.
- PlaceholderStreamStateHandle() - Constructor for class org.apache.flink.runtime.state.PlaceholderStreamStateHandle
-
- placePipelineBreakersIfNecessary(DriverStrategy, Channel, Channel) - Method in class org.apache.flink.optimizer.dag.TwoInputNode
-
- Plan - Class in org.apache.flink.api.common
-
This class represents Flink programs, in the form of dataflow plans.
- Plan(Collection<? extends GenericDataSinkBase<?>>, String) - Constructor for class org.apache.flink.api.common.Plan
-
Creates a new dataflow plan with the given name, describing the data flow that ends at the
given data sinks.
- Plan(Collection<? extends GenericDataSinkBase<?>>, String, int) - Constructor for class org.apache.flink.api.common.Plan
-
Creates a new program plan with the given name and default parallelism, describing the data flow that ends
at the given data sinks.
- Plan(GenericDataSinkBase<?>, String) - Constructor for class org.apache.flink.api.common.Plan
-
Creates a new program plan with the given name, containing initially a single data sink.
- Plan(GenericDataSinkBase<?>, String, int) - Constructor for class org.apache.flink.api.common.Plan
-
Creates a new program plan with the given name and default parallelism, containing initially a single data
sink.
- Plan(Collection<? extends GenericDataSinkBase<?>>) - Constructor for class org.apache.flink.api.common.Plan
-
Creates a new program plan, describing the data flow that ends at the
given data sinks.
- Plan(Collection<? extends GenericDataSinkBase<?>>, int) - Constructor for class org.apache.flink.api.common.Plan
-
Creates a new program plan with the given default parallelism, describing the data flow that ends at the
given data sinks.
- Plan(GenericDataSinkBase<?>) - Constructor for class org.apache.flink.api.common.Plan
-
Creates a new program plan with single data sink.
- Plan(GenericDataSinkBase<?>, int) - Constructor for class org.apache.flink.api.common.Plan
-
Creates a new program plan with single data sink and the given default parallelism.
- plan(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.drivers.AdamicAdar
-
- plan(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.drivers.ClusteringCoefficient
-
- plan(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.drivers.ConnectedComponents
-
- plan(Graph<K, VV, EV>) - Method in interface org.apache.flink.graph.drivers.Driver
-
"Run" algorithms and analytics on the input graph.
- plan(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.drivers.EdgeList
-
- plan(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.drivers.GraphMetrics
-
- plan(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.drivers.HITS
-
- plan(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.drivers.JaccardIndex
-
- plan(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.drivers.PageRank
-
- plan(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.drivers.TriangleListing
-
- PLAN_ARGUMENTS_KEY - Static variable in class org.apache.flink.python.api.PythonPlanBinder
-
- PLAN_TMP_DIR - Static variable in class org.apache.flink.python.api.PythonOptions
-
The config parameter defining where temporary plan-related files are stored on the client.
- PLAN_TMP_DIR - Static variable in class org.apache.flink.streaming.python.PythonOptions
-
The config parameter defining where temporary plan-related files are stored on the client.
- PLANBINDER_CONFIG_BCVAR_COUNT - Static variable in class org.apache.flink.python.api.PythonPlanBinder
-
- PLANBINDER_CONFIG_BCVAR_NAME_PREFIX - Static variable in class org.apache.flink.python.api.PythonPlanBinder
-
- PlanBothUnwrappingCoGroupOperator<I1,I2,OUT,K> - Class in org.apache.flink.api.java.operators.translation
-
A co group operator that applies the operation only on the unwrapped values.
- PlanBothUnwrappingCoGroupOperator(CoGroupFunction<I1, I2, OUT>, Keys.SelectorFunctionKeys<I1, K>, Keys.SelectorFunctionKeys<I2, K>, String, TypeInformation<OUT>, TypeInformation<Tuple2<K, I1>>, TypeInformation<Tuple2<K, I2>>) - Constructor for class org.apache.flink.api.java.operators.translation.PlanBothUnwrappingCoGroupOperator
-
- PlanExecutor - Class in org.apache.flink.api.common
-
A PlanExecutor executes a Flink program's dataflow plan.
- PlanExecutor() - Constructor for class org.apache.flink.api.common.PlanExecutor
-
- PlanFilterOperator<T> - Class in org.apache.flink.api.java.operators.translation
-
- PlanFilterOperator(FilterFunction<T>, String, TypeInformation<T>) - Constructor for class org.apache.flink.api.java.operators.translation.PlanFilterOperator
-
- PlanFilterOperator.FlatMapFilter<T> - Class in org.apache.flink.api.java.operators.translation
-
- PlanFinalizer - Class in org.apache.flink.optimizer.traversals
-
This visitor traverses the selected execution plan and finalizes it:
The graph of nodes is double-linked (links from child to parent are inserted).
If unions join static and dynamic paths, the cache is marked as a memory consumer.
Relative memory fractions are assigned to all nodes.
All nodes are collected into a set.
- PlanFinalizer() - Constructor for class org.apache.flink.optimizer.traversals.PlanFinalizer
-
Creates a new plan finalizer.
- PlanJSONDumpGenerator - Class in org.apache.flink.optimizer.plandump
-
- PlanJSONDumpGenerator() - Constructor for class org.apache.flink.optimizer.plandump.PlanJSONDumpGenerator
-
- PlanJsonParser - Class in org.apache.flink.table.explain
-
Utility for converting an execution plan from JSON to a human-readable string.
- PlanJsonParser() - Constructor for class org.apache.flink.table.explain.PlanJsonParser
-
- PlanLeftUnwrappingCoGroupOperator<I1,I2,OUT,K> - Class in org.apache.flink.api.java.operators.translation
-
A co group operator that applies the operation only on the unwrapped values on the left.
- PlanLeftUnwrappingCoGroupOperator(CoGroupFunction<I1, I2, OUT>, Keys.SelectorFunctionKeys<I1, K>, int[], String, TypeInformation<OUT>, TypeInformation<Tuple2<K, I1>>, TypeInformation<I2>) - Constructor for class org.apache.flink.api.java.operators.translation.PlanLeftUnwrappingCoGroupOperator
-
- PlanNode - Class in org.apache.flink.optimizer.plan
-
The representation of a data exchange between to operators.
- PlanNode(OptimizerNode, String, DriverStrategy) - Constructor for class org.apache.flink.optimizer.plan.PlanNode
-
- PlanNode.FeedbackPropertiesMeetRequirementsReport - Enum in org.apache.flink.optimizer.plan
-
- PlanNode.SourceAndDamReport - Enum in org.apache.flink.optimizer.plan
-
- PlanProjectOperator<T,R extends Tuple> - Class in org.apache.flink.api.java.operators.translation
-
A map operator that retains a subset of fields from incoming tuples.
- PlanProjectOperator(int[], String, TypeInformation<T>, TypeInformation<R>, ExecutionConfig) - Constructor for class org.apache.flink.api.java.operators.translation.PlanProjectOperator
-
- PlanRightUnwrappingCoGroupOperator<I1,I2,OUT,K> - Class in org.apache.flink.api.java.operators.translation
-
A co group operator that applies the operation only on the unwrapped values on the right.
- PlanRightUnwrappingCoGroupOperator(CoGroupFunction<I1, I2, OUT>, int[], Keys.SelectorFunctionKeys<I2, K>, String, TypeInformation<OUT>, TypeInformation<I1>, TypeInformation<Tuple2<K, I2>>) - Constructor for class org.apache.flink.api.java.operators.translation.PlanRightUnwrappingCoGroupOperator
-
- PlanUnwrappingGroupCombineOperator<IN,OUT,K> - Class in org.apache.flink.api.java.operators.translation
-
A group combine operator that takes 2-tuples (key-value pairs), and applies the group combine operation only
on the unwrapped values.
- PlanUnwrappingGroupCombineOperator(GroupCombineFunction<IN, OUT>, Keys.SelectorFunctionKeys<IN, K>, String, TypeInformation<OUT>, TypeInformation<Tuple2<K, IN>>) - Constructor for class org.apache.flink.api.java.operators.translation.PlanUnwrappingGroupCombineOperator
-
- PlanUnwrappingReduceGroupOperator<IN,OUT,K> - Class in org.apache.flink.api.java.operators.translation
-
A reduce operator that takes 2-tuples (key-value pairs), and applies the group reduce operation only
on the unwrapped values.
- PlanUnwrappingReduceGroupOperator(GroupReduceFunction<IN, OUT>, Keys.SelectorFunctionKeys<IN, K>, String, TypeInformation<OUT>, TypeInformation<Tuple2<K, IN>>, boolean) - Constructor for class org.apache.flink.api.java.operators.translation.PlanUnwrappingReduceGroupOperator
-
- PlanUnwrappingReduceOperator<T,K> - Class in org.apache.flink.api.java.operators.translation
-
A reduce operator that takes 2-tuples (key-value pairs), and applies the reduce operation only
on the unwrapped values.
- PlanUnwrappingReduceOperator(ReduceFunction<T>, Keys.SelectorFunctionKeys<T, K>, String, TypeInformation<T>, TypeInformation<Tuple2<K, T>>) - Constructor for class org.apache.flink.api.java.operators.translation.PlanUnwrappingReduceOperator
-
- PlanUnwrappingSortedGroupCombineOperator<IN,OUT,K1,K2> - Class in org.apache.flink.api.java.operators.translation
-
A reduce operator that takes 3-tuples (groupKey, sortKey, value), and applies the sorted partial group reduce
operation only on the unwrapped values.
- PlanUnwrappingSortedGroupCombineOperator(GroupCombineFunction<IN, OUT>, Keys.SelectorFunctionKeys<IN, K1>, Keys.SelectorFunctionKeys<IN, K2>, String, TypeInformation<OUT>, TypeInformation<Tuple3<K1, K2, IN>>) - Constructor for class org.apache.flink.api.java.operators.translation.PlanUnwrappingSortedGroupCombineOperator
-
- PlanUnwrappingSortedReduceGroupOperator<IN,OUT,K1,K2> - Class in org.apache.flink.api.java.operators.translation
-
A reduce operator that takes 3-tuples (groupKey, sortKey, value), and applies the sorted group reduce
operation only on the unwrapped values.
- PlanUnwrappingSortedReduceGroupOperator(GroupReduceFunction<IN, OUT>, Keys.SelectorFunctionKeys<IN, K1>, Keys.SelectorFunctionKeys<IN, K2>, String, TypeInformation<OUT>, TypeInformation<Tuple3<K1, K2, IN>>, boolean) - Constructor for class org.apache.flink.api.java.operators.translation.PlanUnwrappingSortedReduceGroupOperator
-
- plus(Duration) - Method in class org.apache.flink.api.common.time.Deadline
-
- Point() - Constructor for class org.apache.flink.examples.java.clustering.KMeans.Point
-
- Point(double, double) - Constructor for class org.apache.flink.examples.java.clustering.KMeans.Point
-
- Point() - Constructor for class org.apache.flink.graph.examples.EuclideanGraphWeighing.Point
-
- Point(double, double) - Constructor for class org.apache.flink.graph.examples.EuclideanGraphWeighing.Point
-
- POINTS - Static variable in class org.apache.flink.examples.java.clustering.util.KMeansData
-
- PoissonSampler<T> - Class in org.apache.flink.api.java.sampling
-
A sampler implementation based on the Poisson Distribution.
- PoissonSampler(double, long) - Constructor for class org.apache.flink.api.java.sampling.PoissonSampler
-
Create a poisson sampler which can sample elements with replacement.
- PoissonSampler(double) - Constructor for class org.apache.flink.api.java.sampling.PoissonSampler
-
Create a poisson sampler which can sample elements with replacement.
- POJO(Class<T>) - Static method in class org.apache.flink.api.common.typeinfo.Types
-
Returns type information for a POJO (Plain Old Java Object).
- POJO(Class<T>, Map<String, TypeInformation<?>>) - Static method in class org.apache.flink.api.common.typeinfo.Types
-
Returns type information for a POJO (Plain Old Java Object) and allows to specify all fields manually.
- PojoComparator<T> - Class in org.apache.flink.api.java.typeutils.runtime
-
- PojoComparator(Field[], TypeComparator<?>[], TypeSerializer<T>, Class<T>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.PojoComparator
-
- PojoCsvInputFormat<OUT> - Class in org.apache.flink.api.java.io
-
Input format that reads csv into POJOs.
- PojoCsvInputFormat(Path, PojoTypeInfo<OUT>) - Constructor for class org.apache.flink.api.java.io.PojoCsvInputFormat
-
- PojoCsvInputFormat(Path, PojoTypeInfo<OUT>, String[]) - Constructor for class org.apache.flink.api.java.io.PojoCsvInputFormat
-
- PojoCsvInputFormat(Path, String, String, PojoTypeInfo<OUT>) - Constructor for class org.apache.flink.api.java.io.PojoCsvInputFormat
-
- PojoCsvInputFormat(Path, String, String, PojoTypeInfo<OUT>, String[]) - Constructor for class org.apache.flink.api.java.io.PojoCsvInputFormat
-
- PojoCsvInputFormat(Path, PojoTypeInfo<OUT>, int[]) - Constructor for class org.apache.flink.api.java.io.PojoCsvInputFormat
-
- PojoCsvInputFormat(Path, PojoTypeInfo<OUT>, String[], int[]) - Constructor for class org.apache.flink.api.java.io.PojoCsvInputFormat
-
- PojoCsvInputFormat(Path, String, String, PojoTypeInfo<OUT>, int[]) - Constructor for class org.apache.flink.api.java.io.PojoCsvInputFormat
-
- PojoCsvInputFormat(Path, String, String, PojoTypeInfo<OUT>, String[], int[]) - Constructor for class org.apache.flink.api.java.io.PojoCsvInputFormat
-
- PojoCsvInputFormat(Path, PojoTypeInfo<OUT>, boolean[]) - Constructor for class org.apache.flink.api.java.io.PojoCsvInputFormat
-
- PojoCsvInputFormat(Path, PojoTypeInfo<OUT>, String[], boolean[]) - Constructor for class org.apache.flink.api.java.io.PojoCsvInputFormat
-
- PojoCsvInputFormat(Path, String, String, PojoTypeInfo<OUT>, boolean[]) - Constructor for class org.apache.flink.api.java.io.PojoCsvInputFormat
-
- PojoCsvInputFormat(Path, String, String, PojoTypeInfo<OUT>, String[], boolean[]) - Constructor for class org.apache.flink.api.java.io.PojoCsvInputFormat
-
- PojoField - Class in org.apache.flink.api.java.typeutils
-
Represent a field definition for
PojoTypeInfo
type of objects.
- PojoField(Field, TypeInformation<?>) - Constructor for class org.apache.flink.api.java.typeutils.PojoField
-
- PojoSerializer<T> - Class in org.apache.flink.api.java.typeutils.runtime
-
- PojoSerializer(Class<T>, TypeSerializer<?>[], Field[], ExecutionConfig) - Constructor for class org.apache.flink.api.java.typeutils.runtime.PojoSerializer
-
- PojoSerializer(Class<T>, Field[], TypeSerializer<Object>[], LinkedHashMap<Class<?>, Integer>, TypeSerializer<?>[], HashMap<Class<?>, TypeSerializer<?>>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.PojoSerializer
-
- PojoSerializer.PojoSerializerConfigSnapshot<T> - Class in org.apache.flink.api.java.typeutils.runtime
-
- PojoSerializerConfigSnapshot() - Constructor for class 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<?>, TypeSerializerConfigSnapshot>>, LinkedHashMap<Class<?>, Tuple2<TypeSerializer<?>, TypeSerializerConfigSnapshot>>, HashMap<Class<?>, Tuple2<TypeSerializer<?>, TypeSerializerConfigSnapshot>>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.PojoSerializer.PojoSerializerConfigSnapshot
-
- PojoSerializerConfigSnapshot(Class<T>, LinkedHashMap<String, Tuple2<TypeSerializer<?>, TypeSerializerConfigSnapshot>>, LinkedHashMap<Class<?>, Tuple2<TypeSerializer<?>, TypeSerializerConfigSnapshot>>, HashMap<Class<?>, Tuple2<TypeSerializer<?>, TypeSerializerConfigSnapshot>>, boolean) - Constructor for class org.apache.flink.api.java.typeutils.runtime.PojoSerializer.PojoSerializerConfigSnapshot
-
- pojoType(Class<T>, String...) - Method in class org.apache.flink.api.java.io.CsvReader
-
Configures the reader to read the CSV data and parse it to the given type.
- PojoTypeInfo<T> - Class in org.apache.flink.api.java.typeutils
-
TypeInformation for "Java Beans"-style types.
- PojoTypeInfo(Class<T>, List<PojoField>) - Constructor for class org.apache.flink.api.java.typeutils.PojoTypeInfo
-
- PojoTypeInfo.NamedFlatFieldDescriptor - Class in org.apache.flink.api.java.typeutils
-
- poll() - Method in class org.apache.flink.runtime.jobmanager.scheduler.LifoSetQueue
-
- poll() - Method in class org.apache.flink.runtime.jobmanager.scheduler.SetQueue
-
- poll() - Method in class org.apache.flink.runtime.operators.sort.PartialOrderPriorityQueue
-
Removes and returns the least element of the PriorityQueue in
log(size) time.
- poll() - Method in class org.apache.flink.streaming.api.operators.async.queue.OrderedStreamElementQueue
-
- poll() - Method in interface org.apache.flink.streaming.api.operators.async.queue.StreamElementQueue
-
Poll the first completed
AsyncResult
from the head of this queue.
- poll() - Method in class org.apache.flink.streaming.api.operators.async.queue.UnorderedStreamElementQueue
-
- poll() - Method in class org.apache.flink.streaming.connectors.kafka.internals.ClosableBlockingQueue
-
Returns the queue's next element and removes it, the queue is non-empty.
- pollBatch() - Method in class org.apache.flink.streaming.connectors.kafka.internals.ClosableBlockingQueue
-
Returns all of the queue's current elements in a list, if the queue is non-empty.
- pollNext() - Method in class org.apache.flink.streaming.connectors.kafka.internal.Handover
-
Polls the next element from the Handover, possibly blocking until the next element is
available.
- pollNextBufferOrEvent() - Method in interface org.apache.flink.runtime.io.network.partition.consumer.InputGate
-
- pollNextBufferOrEvent() - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
-
- pollNextBufferOrEvent() - Method in class org.apache.flink.runtime.io.network.partition.consumer.UnionInputGate
-
- pollTimeout - Variable in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer09
-
From Kafka's Javadoc: The time, in milliseconds, spent waiting in poll if data is not
available.
- populateFlinkSecureConfigurations(Configuration) - Static method in class org.apache.flink.test.util.SecureTestEnvironment
-
- port - Variable in class org.apache.flink.api.java.RemoteEnvironment
-
The port of the JobManager main actor system.
- PORT - Static variable in class org.apache.flink.configuration.BlobServerOptions
-
The config parameter defining the server port of the blob service.
- PORT - Static variable in class org.apache.flink.configuration.JobManagerOptions
-
The config parameter defining the network port to connect to
for communication with the job manager.
- PORT - Static variable in class org.apache.flink.configuration.RestOptions
-
The port that the server listens on / the client connects to.
- PORT - Static variable in class org.apache.flink.configuration.WebOptions
-
- port - Variable in class org.apache.flink.python.api.streaming.data.PythonStreamer
-
- portRanges() - Method in class org.apache.flink.mesos.scheduler.Offer
-
- ports(Protos.Value.Range...) - Static method in class org.apache.flink.mesos.Utils
-
Construct a port resource.
- ports(String, Protos.Value.Range...) - Static method in class org.apache.flink.mesos.Utils
-
Construct a port resource.
- position - Variable in class org.apache.flink.core.memory.ByteArrayInputStreamWithPos
-
- postPass(OptimizedPlan) - Method in class org.apache.flink.optimizer.postpass.JavaApiPostPass
-
- postPass(OptimizedPlan) - Method in interface org.apache.flink.optimizer.postpass.OptimizerPostPass
-
Central post processing function.
- postPassHelper - Variable in class org.apache.flink.optimizer.plan.BulkPartialSolutionPlanNode
-
- postPassHelper - Variable in class org.apache.flink.optimizer.plan.SingleInputPlanNode
-
- postPassHelper - Variable in class org.apache.flink.optimizer.plan.SolutionSetPlanNode
-
- postPassHelper - Variable in class org.apache.flink.optimizer.plan.WorksetIterationPlanNode
-
- postPassHelper - Variable in class org.apache.flink.optimizer.plan.WorksetPlanNode
-
- postPassHelper1 - Variable in class org.apache.flink.optimizer.plan.DualInputPlanNode
-
- postPassHelper2 - Variable in class org.apache.flink.optimizer.plan.DualInputPlanNode
-
- postStop() - Method in class org.apache.flink.mesos.runtime.clusterframework.MesosFlinkResourceManager
-
- postStop() - Method in class org.apache.flink.mesos.runtime.clusterframework.MesosResourceManager
-
- postStop() - Method in class org.apache.flink.runtime.client.JobClientActor
-
- postStop() - Method in class org.apache.flink.runtime.clusterframework.FlinkResourceManager
-
- postStop() - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
-
- postStop() - Method in class org.apache.flink.runtime.jobmaster.JobMaster
-
Suspend the job and shutdown all other services including rpc.
- postStop() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotPool
-
- postStop() - Method in class org.apache.flink.runtime.metrics.dump.MetricQueryService
-
- postStop() - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
-
- postStop() - Method in class org.apache.flink.runtime.rpc.RpcEndpoint
-
User overridable callback.
- postStop() - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutor
-
Called to shut down the TaskManager.
- postStop() - Method in class org.apache.flink.yarn.YarnResourceManager
-
- postSubmit() - Method in class org.apache.flink.streaming.util.StreamingProgramTestBase
-
- postSubmit() - Method in class org.apache.flink.test.util.JavaProgramTestBase
-
- postSuperstep() - Method in class org.apache.flink.graph.gsa.ApplyFunction
-
This method is executed once per superstep after the vertex update function has been invoked for each vertex.
- postSuperstep() - Method in class org.apache.flink.graph.gsa.GatherFunction
-
This method is executed once per superstep after the vertex update function has been invoked for each vertex.
- postSuperstep() - Method in class org.apache.flink.graph.gsa.SumFunction
-
This method is executed once per superstep after the vertex update function has been invoked for each vertex.
- postSuperstep() - Method in class org.apache.flink.graph.pregel.ComputeFunction
-
This method is executed once per superstep after the vertex update function has been invoked for each vertex.
- postSuperstep() - Method in class org.apache.flink.graph.spargel.GatherFunction
-
This method is executed once per superstep after the gather function has been invoked for each vertex.
- postSuperstep() - Method in class org.apache.flink.graph.spargel.ScatterFunction
-
This method is executed once per superstep after the scatter function has been invoked for each vertex.
- PostVersionedIOReadableWritable - Class in org.apache.flink.core.io
-
- PostVersionedIOReadableWritable() - Constructor for class org.apache.flink.core.io.PostVersionedIOReadableWritable
-
- postVisit(PlanNode) - Method in class org.apache.flink.optimizer.plantranslate.JobGraphGenerator
-
This method implements the post-visit during the depth-first traversal.
- postVisit(PlanNode) - Method in class org.apache.flink.optimizer.traversals.BinaryUnionReplacer
-
- postVisit(OptimizerNode) - Method in class org.apache.flink.optimizer.traversals.BranchesVisitor
-
- postVisit(Operator<?>) - Method in class org.apache.flink.optimizer.traversals.GraphCreatingVisitor
-
- postVisit(OptimizerNode) - Method in class org.apache.flink.optimizer.traversals.IdAndEstimatesVisitor
-
- postVisit(OptimizerNode) - Method in class org.apache.flink.optimizer.traversals.InterestingPropertyVisitor
-
- postVisit(PlanNode) - Method in class org.apache.flink.optimizer.traversals.PlanFinalizer
-
- postVisit(PlanNode) - Method in class org.apache.flink.optimizer.traversals.RangePartitionRewriter
-
- postVisit(OptimizerNode) - Method in class org.apache.flink.optimizer.traversals.StaticDynamicPathIdentifier
-
- postVisit(Operator<?>) - Method in class org.apache.flink.optimizer.traversals.StepFunctionValidator
-
- postVisit(OptimizerNode) - Method in class org.apache.flink.optimizer.traversals.UnionParallelismAndForwardEnforcer
-
- postVisit(T) - Method in interface org.apache.flink.util.Visitor
-
Method that is invoked after all child nodes or descendant nodes were visited.
- powerX(long, long) - Static method in class org.apache.calcite.avatica.util.DateTimeUtils
-
Cheap, unsafe, long power.
- PrecisionTime(Calendar, String, int) - Constructor for class org.apache.calcite.avatica.util.DateTimeUtils.PrecisionTime
-
- preCommit(TXN) - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
-
Pre commit previously created transaction.
- preCommit(FlinkKafkaProducer011.KafkaTransactionState) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer011
-
- Preconditions - Class in org.apache.flink.util
-
A collection of static utility methods to validate input.
- PREDECESSORS - Static variable in class org.apache.flink.streaming.api.graph.JSONGenerator
-
- PredefinedOptions - Enum in org.apache.flink.contrib.streaming.state
-
- Predicate() - Constructor for class org.apache.flink.orc.OrcRowInputFormat.Predicate
-
- predict(Integer) - Method in class org.apache.flink.streaming.examples.ml.IncrementalLearningSkeleton.Predictor
-
- Predictor() - Constructor for class org.apache.flink.streaming.examples.ml.IncrementalLearningSkeleton.Predictor
-
- preferredLocality(ResourceProfile, Collection<TaskManagerLocation>) - Static method in class org.apache.flink.runtime.clusterframework.types.SlotProfile
-
Returns a slot profile for the given resource profile and the preferred locations.
- preferredResources - Variable in class org.apache.flink.api.java.operators.Operator
-
- PregelSSSP - Class in org.apache.flink.graph.examples
-
This example shows how to use Gelly's Vertex-Centric iterations.
- PregelSSSP() - Constructor for class org.apache.flink.graph.examples.PregelSSSP
-
- PregelSSSP.SSSPCombiner - Class in org.apache.flink.graph.examples
-
The messages combiner.
- PregelSSSP.SSSPComputeFunction - Class in org.apache.flink.graph.examples
-
The compute function for SSSP.
- prepare() - Method in class org.apache.flink.runtime.operators.AbstractCachedBuildSideJoinDriver
-
- prepare() - Method in class org.apache.flink.runtime.operators.AbstractOuterJoinDriver
-
- prepare() - Method in class org.apache.flink.runtime.operators.AllGroupCombineDriver
-
- prepare() - Method in class org.apache.flink.runtime.operators.AllGroupReduceDriver
-
- prepare() - Method in class org.apache.flink.runtime.operators.AllReduceDriver
-
- prepare() - Method in class org.apache.flink.runtime.operators.CoGroupDriver
-
- prepare() - Method in class org.apache.flink.runtime.operators.CoGroupRawDriver
-
- prepare() - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetFirstDriver
-
- prepare() - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetSecondDriver
-
- prepare() - Method in class org.apache.flink.runtime.operators.CrossDriver
-
- prepare() - Method in interface org.apache.flink.runtime.operators.Driver
-
This method is called before the user code is opened.
- prepare() - Method in class org.apache.flink.runtime.operators.FlatMapDriver
-
- prepare() - Method in class org.apache.flink.runtime.operators.GroupReduceCombineDriver
-
- prepare() - Method in class org.apache.flink.runtime.operators.GroupReduceDriver
-
- prepare() - Method in class org.apache.flink.runtime.operators.JoinDriver
-
- prepare() - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetFirstDriver
-
- prepare() - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetSecondDriver
-
- prepare() - Method in class org.apache.flink.runtime.operators.MapDriver
-
- prepare() - Method in class org.apache.flink.runtime.operators.MapPartitionDriver
-
- prepare() - Method in class org.apache.flink.runtime.operators.NoOpDriver
-
- prepare() - Method in class org.apache.flink.runtime.operators.ReduceCombineDriver
-
- prepare() - Method in class org.apache.flink.runtime.operators.ReduceDriver
-
- prepare() - Method in class org.apache.flink.runtime.operators.UnionWithTempOperator
-
- prepare(Map, TopologyContext, OutputCollector) - Method in class org.apache.flink.storm.exclamation.operators.ExclamationBolt
-
- prepare(Map, TopologyContext, OutputCollector) - Method in class org.apache.flink.storm.split.operators.VerifyAndEnrichBolt
-
- prepare(Map, TopologyContext, OutputCollector) - Method in class org.apache.flink.storm.util.AbstractBoltSink
-
- prepare(Map, TopologyContext, OutputCollector) - Method in class org.apache.flink.storm.wordcount.operators.BoltCounter
-
- prepare(Map, TopologyContext, OutputCollector) - Method in class org.apache.flink.storm.wordcount.operators.BoltCounterByName
-
- prepare(Map, TopologyContext, OutputCollector) - Method in class org.apache.flink.storm.wordcount.operators.BoltTokenizer
-
- prepare(Map, TopologyContext, OutputCollector) - Method in class org.apache.flink.storm.wordcount.operators.BoltTokenizerByName
-
- prepare(TemporaryFolder) - Static method in class org.apache.flink.test.util.SecureTestEnvironment
-
- prepareAndCommitOffsets(Map<KafkaTopicPartition, Long>) - Method in class org.apache.flink.streaming.connectors.kafka.internals.ZookeeperOffsetHandler
-
Commits offsets for Kafka partitions to ZooKeeper.
- prepareLeadershipAsync() - Method in class org.apache.flink.mesos.runtime.clusterframework.MesosResourceManager
-
- prepareLeadershipAsync() - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
-
This method can be overridden to add a (non-blocking) initialization routine to the
ResourceManager that will be called when leadership is granted but before leadership is
confirmed.
- prepareNextPartition() - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
-
- prepareNextPartition() - Method in class org.apache.flink.runtime.operators.hash.ReOpenableMutableHashTable
-
- preparePlanMode() - Method in class org.apache.flink.python.api.streaming.plan.PythonPlanStreamer
-
- prepareProbePhase(IOManager, FileIOChannel.Enumerator, LinkedBlockingQueue<MemorySegment>) - Method in class org.apache.flink.runtime.operators.hash.HashPartition
-
- prepareSimple(Map<?, ?>, TopologyContext) - Method in class org.apache.flink.storm.util.AbstractBoltSink
-
- prepareSimple(Map, TopologyContext) - Method in class org.apache.flink.storm.util.BoltFileSink
-
- prepareSimple(Map, TopologyContext) - Method in class org.apache.flink.storm.util.BoltPrintSink
-
- preStart() - Method in class org.apache.flink.runtime.akka.QuarantineMonitor
-
- preStart() - Method in class org.apache.flink.runtime.client.JobClientActor
-
- preStart() - Method in class org.apache.flink.runtime.clusterframework.FlinkResourceManager
-
- preSubmit() - Method in class org.apache.flink.streaming.util.StreamingProgramTestBase
-
- preSubmit() - Method in class org.apache.flink.test.util.JavaProgramTestBase
-
- preSuperstep() - Method in class org.apache.flink.graph.gsa.ApplyFunction
-
This method is executed once per superstep before the vertex update function is invoked for each vertex.
- preSuperstep() - Method in class org.apache.flink.graph.gsa.GatherFunction
-
This method is executed once per superstep before the vertex update function is invoked for each vertex.
- preSuperstep() - Method in class org.apache.flink.graph.gsa.SumFunction
-
This method is executed once per superstep before the vertex update function is invoked for each vertex.
- preSuperstep() - Method in class org.apache.flink.graph.pregel.ComputeFunction
-
This method is executed once per superstep before the vertex update function is invoked for each vertex.
- preSuperstep() - Method in class org.apache.flink.graph.spargel.GatherFunction
-
This method is executed once per superstep before the gather function is invoked for each vertex.
- preSuperstep() - Method in class org.apache.flink.graph.spargel.ScatterFunction
-
This method is executed once per superstep before the scatter function is invoked for each vertex.
- prev() - Method in class org.apache.flink.contrib.streaming.state.RocksIteratorWrapper
-
- PreviewPlanEnvironment - Class in org.apache.flink.client.program
-
Environment to extract the pre-optimized plan.
- PreviewPlanEnvironment() - Constructor for class org.apache.flink.client.program.PreviewPlanEnvironment
-
- PreviousAllocationSchedulingStrategy - Class in org.apache.flink.runtime.jobmaster.slotpool
-
- previousResults - Variable in class org.apache.flink.table.client.cli.CliResultView
-
- preVisit(PlanNode) - Method in class org.apache.flink.optimizer.plantranslate.JobGraphGenerator
-
This methods implements the pre-visiting during a depth-first traversal.
- preVisit(PlanNode) - Method in class org.apache.flink.optimizer.traversals.BinaryUnionReplacer
-
- preVisit(OptimizerNode) - Method in class org.apache.flink.optimizer.traversals.BranchesVisitor
-
- preVisit(Operator<?>) - Method in class org.apache.flink.optimizer.traversals.GraphCreatingVisitor
-
- preVisit(OptimizerNode) - Method in class org.apache.flink.optimizer.traversals.IdAndEstimatesVisitor
-
- preVisit(OptimizerNode) - Method in class org.apache.flink.optimizer.traversals.InterestingPropertyVisitor
-
- preVisit(PlanNode) - Method in class org.apache.flink.optimizer.traversals.PlanFinalizer
-
- preVisit(PlanNode) - Method in class org.apache.flink.optimizer.traversals.RangePartitionRewriter
-
- preVisit(OptimizerNode) - Method in class org.apache.flink.optimizer.traversals.StaticDynamicPathIdentifier
-
- preVisit(Operator<?>) - Method in class org.apache.flink.optimizer.traversals.StepFunctionValidator
-
- preVisit(OptimizerNode) - Method in class org.apache.flink.optimizer.traversals.UnionParallelismAndForwardEnforcer
-
- preVisit(T) - Method in interface org.apache.flink.util.Visitor
-
Method that is invoked on the visit before visiting and child nodes or descendant nodes.
- PrimaryAndSecondaryStream(CheckpointStreamFactory.CheckpointStateOutputStream, CheckpointStreamFactory.CheckpointStateOutputStream) - Constructor for class org.apache.flink.runtime.state.CheckpointStreamWithResultProvider.PrimaryAndSecondaryStream
-
- PrimaryStreamOnly(CheckpointStreamFactory.CheckpointStateOutputStream) - Constructor for class org.apache.flink.runtime.state.CheckpointStreamWithResultProvider.PrimaryStreamOnly
-
- PRIMITIVE_ARRAY(TypeInformation<?>) - Static method in class org.apache.flink.api.common.typeinfo.Types
-
Returns type information for Java arrays of primitive type (such as byte[]
).
- PrimitiveArrayComparator<T,C extends BasicTypeComparator> - Class in org.apache.flink.api.common.typeutils.base.array
-
- PrimitiveArrayComparator(boolean, C) - Constructor for class org.apache.flink.api.common.typeutils.base.array.PrimitiveArrayComparator
-
- PrimitiveArrayTypeInfo<T> - Class in org.apache.flink.api.common.typeinfo
-
- PrimitiveInputFormat<OT> - Class in org.apache.flink.api.java.io
-
An input format that reads single field primitive data from a given file.
- PrimitiveInputFormat(Path, Class<OT>) - Constructor for class org.apache.flink.api.java.io.PrimitiveInputFormat
-
- PrimitiveInputFormat(Path, String, Class<OT>) - Constructor for class org.apache.flink.api.java.io.PrimitiveInputFormat
-
- print() - Method in class org.apache.flink.api.java.DataSet
-
Prints the elements in a DataSet to the standard output stream
System.out
of the JVM that calls
the print() method.
- print(String) - Method in class org.apache.flink.api.java.DataSet
-
- Print<T> - Class in org.apache.flink.graph.drivers.output
-
Print algorithm output.
- Print() - Constructor for class org.apache.flink.graph.drivers.output.Print
-
- print() - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Writes a DataStream to the standard output stream (stdout).
- PrintableResult - Interface in org.apache.flink.graph.asm.result
-
- printAnalytics(PrintStream) - Method in class org.apache.flink.graph.drivers.ClusteringCoefficient
-
- printAnalytics(PrintStream) - Method in interface org.apache.flink.graph.drivers.Driver
-
Analytic results are summaries so are always printed to the console
irrespective of the chosen Output
.
- printAnalytics(PrintStream) - Method in class org.apache.flink.graph.drivers.DriverBase
-
- printAnalytics(PrintStream) - Method in class org.apache.flink.graph.drivers.GraphMetrics
-
- printAnalytics(PrintStream) - Method in class org.apache.flink.graph.drivers.TriangleListing
-
- printHelp(Collection<CustomCommandLine<?>>) - Static method in class org.apache.flink.client.cli.CliFrontendParser
-
Prints the help for the client.
- printHelpClient() - Static method in class org.apache.flink.table.client.cli.CliOptionsParser
-
Prints the help for the client.
- printHelpEmbeddedModeClient() - Static method in class org.apache.flink.table.client.cli.CliOptionsParser
-
- printHelpForCancel(Collection<CustomCommandLine<?>>) - Static method in class org.apache.flink.client.cli.CliFrontendParser
-
- printHelpForInfo() - Static method in class org.apache.flink.client.cli.CliFrontendParser
-
- printHelpForList(Collection<CustomCommandLine<?>>) - Static method in class org.apache.flink.client.cli.CliFrontendParser
-
- printHelpForModify(Collection<CustomCommandLine<?>>) - Static method in class org.apache.flink.client.cli.CliFrontendParser
-
- printHelpForRun(Collection<CustomCommandLine<?>>) - Static method in class org.apache.flink.client.cli.CliFrontendParser
-
- printHelpForSavepoint(Collection<CustomCommandLine<?>>) - Static method in class org.apache.flink.client.cli.CliFrontendParser
-
- printHelpForStop(Collection<CustomCommandLine<?>>) - Static method in class org.apache.flink.client.cli.CliFrontendParser
-
- printHelpGateway() - Static method in class org.apache.flink.table.client.cli.CliOptionsParser
-
Prints the help for the gateway.
- printHelpGatewayModeClient() - Static method in class org.apache.flink.table.client.cli.CliOptionsParser
-
- printHelpGatewayModeGateway() - Static method in class org.apache.flink.table.client.cli.CliOptionsParser
-
- PrintingOutputFormat<T> - Class in org.apache.flink.api.java.io
-
Output format that prints results into either stdout or stderr.
- PrintingOutputFormat() - Constructor for class org.apache.flink.api.java.io.PrintingOutputFormat
-
Instantiates a printing output format that prints to standard out.
- PrintingOutputFormat(boolean) - Constructor for class org.apache.flink.api.java.io.PrintingOutputFormat
-
Instantiates a printing output format that prints to standard out.
- PrintingOutputFormat(String, boolean) - Constructor for class org.apache.flink.api.java.io.PrintingOutputFormat
-
Instantiates a printing output format that prints to standard out with a prefixed message.
- printOnTaskManager(String) - Method in class org.apache.flink.api.java.DataSet
-
Writes a DataSet to the standard output streams (stdout) of the TaskManagers that execute
the program (or more specifically, the data sink operators).
- PrintSampleStream - Class in org.apache.flink.storm.print
-
Prints incoming tweets.
- PrintSampleStream() - Constructor for class org.apache.flink.storm.print.PrintSampleStream
-
- PrintSinkFunction<IN> - Class in org.apache.flink.streaming.api.functions.sink
-
Implementation of the SinkFunction writing every tuple to the standard
output or standard error stream.
- PrintSinkFunction() - Constructor for class org.apache.flink.streaming.api.functions.sink.PrintSinkFunction
-
Instantiates a print sink function that prints to standard out.
- PrintSinkFunction(boolean) - Constructor for class org.apache.flink.streaming.api.functions.sink.PrintSinkFunction
-
Instantiates a print sink function that prints to standard out.
- printStackTrace(PrintStream) - Method in exception org.apache.flink.util.SerializedThrowable
-
- printStackTrace(PrintWriter) - Method in exception org.apache.flink.util.SerializedThrowable
-
- printToErr() - Method in class org.apache.flink.api.java.DataSet
-
Prints the elements in a DataSet to the standard error stream
System.err
of the JVM that calls
the print() method.
- printToErr(String) - Method in class org.apache.flink.api.java.DataSet
-
- printToErr() - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Writes a DataStream to the standard output stream (stderr).
- printToLogger(Logger) - Method in class org.apache.flink.api.java.sca.UdfAnalyzer
-
- priorAllocation(ResourceProfile, Collection<AllocationID>) - Static method in class org.apache.flink.runtime.clusterframework.types.SlotProfile
-
Returns a slot profile for the given resource profile and the prior allocations.
- prioritizedOperatorState(OperatorID) - Method in interface org.apache.flink.runtime.state.TaskStateManager
-
Returns means to restore previously reported state of an operator running in the owning task.
- prioritizedOperatorState(OperatorID) - Method in class org.apache.flink.runtime.state.TaskStateManagerImpl
-
- PrioritizedOperatorSubtaskState - Class in org.apache.flink.runtime.checkpoint
-
This class is a wrapper over multiple alternative
OperatorSubtaskState
that are (partial) substitutes for
each other and imposes a priority ordering over all alternatives for the different states which define an order in
which the operator should attempt to restore the state from them.
- PrioritizedOperatorSubtaskState.Builder - Class in org.apache.flink.runtime.checkpoint
-
- privateDuplicate(TupleComparatorBase<T>) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
-
- prob() - Method in class org.apache.flink.streaming.examples.statemachine.dfa.Transition
-
- probeIterator - Variable in class org.apache.flink.runtime.operators.hash.MutableHashTable
-
Iterator over the elements from the probe side.
- Prober(TypeComparator<PT>, TypePairComparator<PT, BT>) - Constructor for class org.apache.flink.api.common.operators.util.JoinHashMap.Prober
-
- probeSideBuffer - Variable in class org.apache.flink.runtime.operators.hash.HashPartition
-
- probeSideChannel - Variable in class org.apache.flink.runtime.operators.hash.HashPartition
-
- probeSideRecordCounter - Variable in class org.apache.flink.runtime.operators.hash.HashPartition
-
- probeSideSerializer - Variable in class org.apache.flink.runtime.operators.hash.MutableHashTable
-
The utilities to serialize the probe side data types.
- probeSideSerializer - Variable in class org.apache.flink.runtime.operators.hash.NonReusingBuildFirstHashJoinIterator
-
- probeSideSerializer - Variable in class org.apache.flink.runtime.operators.hash.NonReusingBuildSecondHashJoinIterator
-
- probeSideSerializer - Variable in class org.apache.flink.runtime.operators.hash.ReusingBuildFirstHashJoinIterator
-
- probeSideSerializer - Variable in class org.apache.flink.runtime.operators.hash.ReusingBuildSecondHashJoinIterator
-
- probeTypeComparator - Variable in class org.apache.flink.runtime.operators.hash.AbstractHashTableProber
-
- process(T, long) - Method in class org.apache.flink.cep.nfa.NFA
-
Processes the next input event.
- process(T, long, AfterMatchSkipStrategy) - Method in class org.apache.flink.cep.nfa.NFA
-
Processes the next input event.
- process(K, S) - Method in class org.apache.flink.runtime.state.KeyedStateFunction
-
The actual method to be applied on each of the states.
- process(ProcessAllWindowFunction<T, R, W>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies the given window function to each window.
- process(ProcessAllWindowFunction<T, R, W>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies the given window function to each window.
- process(KeyedBroadcastProcessFunction<KS, IN1, IN2, OUT>) - Method in class org.apache.flink.streaming.api.datastream.BroadcastConnectedStream
-
- process(KeyedBroadcastProcessFunction<KS, IN1, IN2, OUT>, TypeInformation<OUT>) - Method in class org.apache.flink.streaming.api.datastream.BroadcastConnectedStream
-
- process(BroadcastProcessFunction<IN1, IN2, OUT>) - Method in class org.apache.flink.streaming.api.datastream.BroadcastConnectedStream
-
- process(BroadcastProcessFunction<IN1, IN2, OUT>, TypeInformation<OUT>) - Method in class org.apache.flink.streaming.api.datastream.BroadcastConnectedStream
-
- process(CoProcessFunction<IN1, IN2, R>) - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
-
Applies the given
CoProcessFunction
on the connected input streams,
thereby creating a transformed output stream.
- process(CoProcessFunction<IN1, IN2, R>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
-
Applies the given
CoProcessFunction
on the connected input streams,
thereby creating a transformed output stream.
- process(ProcessFunction<T, R>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Applies the given
ProcessFunction
on the input stream, thereby
creating a transformed output stream.
- process(ProcessFunction<T, R>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Applies the given
ProcessFunction
on the input stream, thereby
creating a transformed output stream.
- process(ProcessFunction<T, R>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
- process(ProcessFunction<T, R>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
- process(KeyedProcessFunction<KEY, T, R>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Applies the given
KeyedProcessFunction
on the input stream, thereby creating a transformed output stream.
- process(KeyedProcessFunction<KEY, T, R>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Applies the given
KeyedProcessFunction
on the input stream, thereby creating a transformed output stream.
- process(ProcessWindowFunction<T, R, K, W>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies the given window function to each window.
- process(ProcessWindowFunction<T, R, K, W>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies the given window function to each window.
- process(ProcessAllWindowFunction<T, R, W>.Context, Iterable<T>, Collector<R>) - Method in class org.apache.flink.streaming.api.functions.windowing.FoldApplyProcessAllWindowFunction
-
Deprecated.
- process(K, ProcessWindowFunction<T, R, K, W>.Context, Iterable<T>, Collector<R>) - Method in class org.apache.flink.streaming.api.functions.windowing.FoldApplyProcessWindowFunction
-
Deprecated.
- process(ProcessAllWindowFunction<IN, OUT, W>.Context, Iterable<IN>, Collector<OUT>) - Method in class org.apache.flink.streaming.api.functions.windowing.ProcessAllWindowFunction
-
Evaluates the window and outputs none or several elements.
- process(KEY, ProcessWindowFunction<IN, OUT, KEY, W>.Context, Iterable<IN>, Collector<OUT>) - Method in class org.apache.flink.streaming.api.functions.windowing.ProcessWindowFunction
-
Evaluates the window and outputs none or several elements.
- process(ProcessAllWindowFunction<T, R, W>.Context, Iterable<T>, Collector<R>) - Method in class org.apache.flink.streaming.api.functions.windowing.ReduceApplyProcessAllWindowFunction
-
- process(K, ProcessWindowFunction<T, R, K, W>.Context, Iterable<T>, Collector<R>) - Method in class org.apache.flink.streaming.api.functions.windowing.ReduceApplyProcessWindowFunction
-
- process(T, RuntimeContext, RequestIndexer) - Method in interface org.apache.flink.streaming.connectors.elasticsearch.ElasticsearchSinkFunction
-
Process the incoming element to produce multiple ActionsRequests
.
- process(T, RuntimeContext, RequestIndexer) - Method in interface org.apache.flink.streaming.connectors.elasticsearch2.ElasticsearchSinkFunction
-
Deprecated.
- process(Byte, W, InternalWindowFunction.InternalWindowContext, Iterable<T>, Collector<R>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalAggregateProcessAllWindowFunction
-
- process(K, W, InternalWindowFunction.InternalWindowContext, Iterable<T>, Collector<R>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalAggregateProcessWindowFunction
-
- process(Byte, W, InternalWindowFunction.InternalWindowContext, Iterable<IN>, Collector<OUT>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableAllWindowFunction
-
- process(Byte, W, InternalWindowFunction.InternalWindowContext, Iterable<IN>, Collector<OUT>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableProcessAllWindowFunction
-
- process(KEY, W, InternalWindowFunction.InternalWindowContext, Iterable<IN>, Collector<OUT>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableProcessWindowFunction
-
- process(KEY, W, InternalWindowFunction.InternalWindowContext, Iterable<IN>, Collector<OUT>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableWindowFunction
-
- process(Byte, W, InternalWindowFunction.InternalWindowContext, IN, Collector<OUT>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueAllWindowFunction
-
- process(Byte, W, InternalWindowFunction.InternalWindowContext, IN, Collector<OUT>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueProcessAllWindowFunction
-
- process(KEY, W, InternalWindowFunction.InternalWindowContext, IN, Collector<OUT>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueProcessWindowFunction
-
- process(KEY, W, InternalWindowFunction.InternalWindowContext, IN, Collector<OUT>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueWindowFunction
-
- process(KEY, W, InternalWindowFunction.InternalWindowContext, IN, Collector<OUT>) - Method in interface org.apache.flink.streaming.runtime.operators.windowing.functions.InternalWindowFunction
-
Evaluates the window and outputs none or several elements.
- ProcessAllWindowFunction<IN,OUT,W extends Window> - Class in org.apache.flink.streaming.api.functions.windowing
-
Base abstract class for functions that are evaluated over non-keyed windows using a context
for retrieving extra information.
- ProcessAllWindowFunction() - Constructor for class org.apache.flink.streaming.api.functions.windowing.ProcessAllWindowFunction
-
- ProcessAllWindowFunction.Context - Class in org.apache.flink.streaming.api.functions.windowing
-
The context holding window metadata.
- processBroadcastElement(IN2, BroadcastProcessFunction<IN1, IN2, OUT>.Context, Collector<OUT>) - Method in class org.apache.flink.streaming.api.functions.co.BroadcastProcessFunction
-
- processBroadcastElement(IN2, KeyedBroadcastProcessFunction<KS, IN1, IN2, OUT>.Context, Collector<OUT>) - Method in class org.apache.flink.streaming.api.functions.co.KeyedBroadcastProcessFunction
-
- processContext - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
- processElement(StreamRecord<IN>) - Method in class org.apache.flink.cep.operator.AbstractKeyedCEPPatternOperator
-
- processElement(StreamRecord<IN>) - Method in class org.apache.flink.storm.wrappers.BoltWrapper
-
- processElement(StreamRecord<StormTuple<IN>>) - Method in class org.apache.flink.storm.wrappers.MergedInputsBoltWrapper
-
- processElement(IN1, BroadcastProcessFunction<IN1, IN2, OUT>.ReadOnlyContext, Collector<OUT>) - Method in class org.apache.flink.streaming.api.functions.co.BroadcastProcessFunction
-
This method is called for each element in the (non-broadcast)
data stream
.
- processElement(IN1, KeyedBroadcastProcessFunction<KS, IN1, IN2, OUT>.ReadOnlyContext, Collector<OUT>) - Method in class org.apache.flink.streaming.api.functions.co.KeyedBroadcastProcessFunction
-
This method is called for each element in the (non-broadcast)
keyed stream
.
- processElement(I, KeyedProcessFunction<K, I, O>.Context, Collector<O>) - Method in class org.apache.flink.streaming.api.functions.KeyedProcessFunction
-
Process one element from the input stream.
- processElement(I, ProcessFunction<I, O>.Context, Collector<O>) - Method in class org.apache.flink.streaming.api.functions.ProcessFunction
-
Process one element from the input stream.
- processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.api.functions.query.QueryableAppendingStateOperator
-
- processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.api.functions.query.QueryableValueStateOperator
-
- processElement(StreamRecord<TimestampedFileInputSplit>) - Method in class org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperator
-
- processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.api.operators.async.AsyncWaitOperator
-
- processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.api.operators.KeyedProcessOperator
-
- processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.api.operators.LegacyKeyedProcessOperator
-
Deprecated.
- processElement(StreamRecord<IN>) - Method in interface org.apache.flink.streaming.api.operators.OneInputStreamOperator
-
Processes one element that arrived at this operator.
- processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.api.operators.ProcessOperator
-
- processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.api.operators.StreamFilter
-
- processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.api.operators.StreamFlatMap
-
- processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.api.operators.StreamGroupedFold
-
Deprecated.
- processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.api.operators.StreamGroupedReduce
-
- processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.api.operators.StreamMap
-
- processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.api.operators.StreamProject
-
- processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.api.operators.StreamSink
-
- processElement(String, ProcessFunction<String, Tuple2<String, Integer>>.Context, Collector<Tuple2<String, Integer>>) - Method in class org.apache.flink.streaming.examples.sideoutput.SideOutputExample.Tokenizer
-
- processElement(StreamRecord<T>) - Method in class org.apache.flink.streaming.runtime.operators.ExtractTimestampsOperator
-
Deprecated.
- processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.runtime.operators.GenericWriteAheadSink
-
- processElement(StreamRecord<T>) - Method in class org.apache.flink.streaming.runtime.operators.TimestampsAndPeriodicWatermarksOperator
-
- processElement(StreamRecord<T>) - Method in class org.apache.flink.streaming.runtime.operators.TimestampsAndPunctuatedWatermarksOperator
-
- processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.EvictingWindowOperator
-
- processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
- processElement1(IN1, CoProcessFunction<IN1, IN2, OUT>.Context, Collector<OUT>) - Method in class org.apache.flink.streaming.api.functions.co.CoProcessFunction
-
This method is called for each element in the first of the connected streams.
- processElement1(StreamRecord<IN1>) - Method in class org.apache.flink.streaming.api.operators.co.CoBroadcastWithKeyedOperator
-
- processElement1(StreamRecord<IN1>) - Method in class org.apache.flink.streaming.api.operators.co.CoBroadcastWithNonKeyedOperator
-
- processElement1(StreamRecord<IN1>) - Method in class org.apache.flink.streaming.api.operators.co.CoProcessOperator
-
- processElement1(StreamRecord<IN1>) - Method in class org.apache.flink.streaming.api.operators.co.CoStreamFlatMap
-
- processElement1(StreamRecord<IN1>) - Method in class org.apache.flink.streaming.api.operators.co.CoStreamMap
-
- processElement1(StreamRecord<IN1>) - Method in class org.apache.flink.streaming.api.operators.co.KeyedCoProcessOperator
-
- processElement1(StreamRecord<IN1>) - Method in interface org.apache.flink.streaming.api.operators.TwoInputStreamOperator
-
Processes one element that arrived on the first input of this two-input operator.
- processElement2(IN2, CoProcessFunction<IN1, IN2, OUT>.Context, Collector<OUT>) - Method in class org.apache.flink.streaming.api.functions.co.CoProcessFunction
-
This method is called for each element in the second of the connected streams.
- processElement2(StreamRecord<IN2>) - Method in class org.apache.flink.streaming.api.operators.co.CoBroadcastWithKeyedOperator
-
- processElement2(StreamRecord<IN2>) - Method in class org.apache.flink.streaming.api.operators.co.CoBroadcastWithNonKeyedOperator
-
- processElement2(StreamRecord<IN2>) - Method in class org.apache.flink.streaming.api.operators.co.CoProcessOperator
-
- processElement2(StreamRecord<IN2>) - Method in class org.apache.flink.streaming.api.operators.co.CoStreamFlatMap
-
- processElement2(StreamRecord<IN2>) - Method in class org.apache.flink.streaming.api.operators.co.CoStreamMap
-
- processElement2(StreamRecord<IN2>) - Method in class org.apache.flink.streaming.api.operators.co.KeyedCoProcessOperator
-
- processElement2(StreamRecord<IN2>) - Method in interface org.apache.flink.streaming.api.operators.TwoInputStreamOperator
-
Processes one element that arrived on the second input of this two-input operator.
- processExitCode() - Method in enum org.apache.flink.runtime.clusterframework.ApplicationStatus
-
Gets the process exit code associated with this status
- ProcessFunction<I,O> - Class in org.apache.flink.streaming.api.functions
-
A function that processes elements of a stream.
- ProcessFunction() - Constructor for class org.apache.flink.streaming.api.functions.ProcessFunction
-
- ProcessFunction.Context - Class in org.apache.flink.streaming.api.functions
-
- ProcessFunction.OnTimerContext - Class in org.apache.flink.streaming.api.functions
-
- Processing - Enum in org.apache.flink.runtime.rpc.akka.messages
-
Controls the processing behaviour of the AkkaRpcActor
- ProcessingModeDeserializer() - Constructor for class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigInfo.ProcessingModeDeserializer
-
- ProcessingModeSerializer() - Constructor for class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigInfo.ProcessingModeSerializer
-
- ProcessingTimeCallback - Interface in org.apache.flink.streaming.runtime.tasks
-
- ProcessingTimeService - Class in org.apache.flink.streaming.runtime.tasks
-
Defines the current processing time and handles all related actions,
such as register timers for tasks to be executed in the future.
- ProcessingTimeService() - Constructor for class org.apache.flink.streaming.runtime.tasks.ProcessingTimeService
-
- ProcessingTimeSessionWindows - Class in org.apache.flink.streaming.api.windowing.assigners
-
A
WindowAssigner
that windows elements into sessions based on the current processing
time.
- ProcessingTimeSessionWindows(long) - Constructor for class org.apache.flink.streaming.api.windowing.assigners.ProcessingTimeSessionWindows
-
- ProcessingTimeTrigger - Class in org.apache.flink.streaming.api.windowing.triggers
-
A
Trigger
that fires once the current system time passes the end of the window
to which a pane belongs.
- processInput() - Method in class org.apache.flink.streaming.runtime.io.StreamInputProcessor
-
- processInput() - Method in class org.apache.flink.streaming.runtime.io.StreamTwoInputProcessor
-
- processLatencyMarker(LatencyMarker) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- processLatencyMarker(LatencyMarker) - Method in interface org.apache.flink.streaming.api.operators.OneInputStreamOperator
-
- processLatencyMarker1(LatencyMarker) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- processLatencyMarker1(LatencyMarker) - Method in interface org.apache.flink.streaming.api.operators.TwoInputStreamOperator
-
Processes a
LatencyMarker
that arrived on the first input of this two-input operator.
- processLatencyMarker2(LatencyMarker) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- processLatencyMarker2(LatencyMarker) - Method in interface org.apache.flink.streaming.api.operators.TwoInputStreamOperator
-
Processes a
LatencyMarker
that arrived on the second input of this two-input operator.
- processMatchedSequences(Iterable<Map<String, List<IN>>>, long) - Method in class org.apache.flink.cep.operator.AbstractKeyedCEPPatternOperator
-
- processMatchedSequences(Iterable<Map<String, List<IN>>>, long) - Method in class org.apache.flink.cep.operator.FlatSelectCepOperator
-
- processMatchedSequences(Iterable<Map<String, List<IN>>>, long) - Method in class org.apache.flink.cep.operator.FlatSelectTimeoutCepOperator
-
- processMatchedSequences(Iterable<Map<String, List<IN>>>, long) - Method in class org.apache.flink.cep.operator.SelectCepOperator
-
- processMatchedSequences(Iterable<Map<String, List<IN>>>, long) - Method in class org.apache.flink.cep.operator.SelectTimeoutCepOperator
-
- ProcessOperator<IN,OUT> - Class in org.apache.flink.streaming.api.operators
-
- ProcessOperator(ProcessFunction<IN, OUT>) - Constructor for class org.apache.flink.streaming.api.operators.ProcessOperator
-
- processProbeIter() - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
-
- ProcessReaper - Class in org.apache.flink.runtime.process
-
Utility actors that monitors other actors and kills the JVM upon
actor termination.
- ProcessReaper(ActorRef, Logger, int) - Constructor for class org.apache.flink.runtime.process.ProcessReaper
-
- processRecord(Tuple2<Boolean, Row>) - Method in class org.apache.flink.table.client.gateway.local.ChangelogCollectStreamResult
-
- processRecord(Tuple2<Boolean, Row>) - Method in class org.apache.flink.table.client.gateway.local.CollectStreamResult
-
- processRecord(Tuple2<Boolean, Row>) - Method in class org.apache.flink.table.client.gateway.local.MaterializedCollectStreamResult
-
- ProcessShutDownThread - Class in org.apache.flink.runtime.util
-
JVM shut down thread awaiting actor system shut down for a certain amount
of time before exiting the JVM.
- ProcessShutDownThread(Logger, ActorSystem, Duration) - Constructor for class org.apache.flink.runtime.util.ProcessShutDownThread
-
Creates a shut down thread.
- processTimedOutSequences(Iterable<Tuple2<Map<String, List<IN>>, Long>>, long) - Method in class org.apache.flink.cep.operator.AbstractKeyedCEPPatternOperator
-
- processTimedOutSequences(Iterable<Tuple2<Map<String, List<IN>>, Long>>, long) - Method in class org.apache.flink.cep.operator.FlatSelectTimeoutCepOperator
-
- processTimedOutSequences(Iterable<Tuple2<Map<String, List<IN>>, Long>>, long) - Method in class org.apache.flink.cep.operator.SelectTimeoutCepOperator
-
- processUnmatchedBuildIter() - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
-
- processWatermark(Watermark) - Method in class org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperator
-
- processWatermark(Watermark) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- processWatermark(Watermark) - Method in class org.apache.flink.streaming.api.operators.async.AsyncWaitOperator
-
- processWatermark(Watermark) - Method in class org.apache.flink.streaming.api.operators.co.CoBroadcastWithNonKeyedOperator
-
- processWatermark(Watermark) - Method in class org.apache.flink.streaming.api.operators.co.CoProcessOperator
-
- processWatermark(Watermark) - Method in interface org.apache.flink.streaming.api.operators.OneInputStreamOperator
-
- processWatermark(Watermark) - Method in class org.apache.flink.streaming.api.operators.ProcessOperator
-
- processWatermark(Watermark) - Method in class org.apache.flink.streaming.api.operators.StreamSink
-
- processWatermark(Watermark) - Method in class org.apache.flink.streaming.runtime.operators.ExtractTimestampsOperator
-
Deprecated.
- processWatermark(Watermark) - Method in class org.apache.flink.streaming.runtime.operators.TimestampsAndPeriodicWatermarksOperator
-
Override the base implementation to completely ignore watermarks propagated from
upstream (we rely only on the
AssignerWithPeriodicWatermarks
to emit
watermarks from here).
- processWatermark(Watermark) - Method in class org.apache.flink.streaming.runtime.operators.TimestampsAndPunctuatedWatermarksOperator
-
Override the base implementation to completely ignore watermarks propagated from
upstream (we rely only on the
AssignerWithPunctuatedWatermarks
to emit
watermarks from here).
- processWatermark1(Watermark) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- processWatermark1(Watermark) - Method in interface org.apache.flink.streaming.api.operators.TwoInputStreamOperator
-
Processes a
Watermark
that arrived on the first input of this two-input operator.
- processWatermark2(Watermark) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- processWatermark2(Watermark) - Method in interface org.apache.flink.streaming.api.operators.TwoInputStreamOperator
-
Processes a
Watermark
that arrived on the second input of this two-input operator.
- ProcessWindowFunction<IN,OUT,KEY,W extends Window> - Class in org.apache.flink.streaming.api.functions.windowing
-
Base abstract class for functions that are evaluated over keyed (grouped) windows using a context
for retrieving extra information.
- ProcessWindowFunction() - Constructor for class org.apache.flink.streaming.api.functions.windowing.ProcessWindowFunction
-
- ProcessWindowFunction.Context - Class in org.apache.flink.streaming.api.functions.windowing
-
The context holding window metadata.
- produce(ConsumerRecords<byte[], byte[]>) - Method in class org.apache.flink.streaming.connectors.kafka.internal.Handover
-
Hands over an element from the producer.
- producer - Variable in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducerBase
-
KafkaProducer instance.
- producerConfig - Variable in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducerBase
-
User defined properties for the Producer.
- ProducerFailedException - Exception in org.apache.flink.runtime.io.network.partition
-
Network-stack level Exception to notify remote receiver about a failed
partition producer.
- ProducerFailedException(Throwable) - Constructor for exception org.apache.flink.runtime.io.network.partition.ProducerFailedException
-
The cause of the producer failure.
- product - Variable in class org.apache.flink.table.examples.java.StreamSQLExample.Order
-
- profile() - Method in class org.apache.flink.mesos.runtime.clusterframework.store.MesosWorkerStore.Worker
-
Get the resource profile associated with the worker.
- Program - Interface in org.apache.flink.api.common
-
A Program represents and end-to-end Flink program.
- ProgramAbortException() - Constructor for error org.apache.flink.client.program.OptimizerPlanEnvironment.ProgramAbortException
-
- programArgsQueryParameter - Variable in class org.apache.flink.runtime.webmonitor.handlers.JarRunMessageParameters
-
- ProgramArgsQueryParameter - Class in org.apache.flink.runtime.webmonitor.handlers
-
Query parameter specifying the arguments for the program.
- ProgramArgsQueryParameter() - Constructor for class org.apache.flink.runtime.webmonitor.handlers.ProgramArgsQueryParameter
-
- ProgramDescription - Interface in org.apache.flink.api.common
-
Implementing this interface allows a Program to have a description
of the plan which can be shown to the user.
- ProgramInvocationException - Exception in org.apache.flink.client.program
-
Exception used to indicate that there is an error during the invocation of a Flink program.
- ProgramInvocationException(String) - Constructor for exception org.apache.flink.client.program.ProgramInvocationException
-
Creates a ProgramInvocationException with the given message.
- ProgramInvocationException(Throwable) - Constructor for exception org.apache.flink.client.program.ProgramInvocationException
-
Creates a ProgramInvocationException for the given exception.
- ProgramInvocationException(String, Throwable) - Constructor for exception org.apache.flink.client.program.ProgramInvocationException
-
Creates a ProgramInvocationException for the given exception with an
additional message.
- ProgramMissingJobException - Exception in org.apache.flink.client.program
-
Exception used to indicate that no job was executed during the invocation of a Flink program.
- ProgramMissingJobException(String) - Constructor for exception org.apache.flink.client.program.ProgramMissingJobException
-
- ProgramOptions - Class in org.apache.flink.client.cli
-
Base class for command line options that refer to a JAR file program.
- ProgramOptions(CommandLine) - Constructor for class org.apache.flink.client.cli.ProgramOptions
-
- ProgramParametrizationException - Exception in org.apache.flink.client.program
-
Exception used to indicate that there is an error in the parametrization of a Flink program.
- ProgramParametrizationException(String) - Constructor for exception org.apache.flink.client.program.ProgramParametrizationException
-
Creates a ProgramParametrizationException with the given message.
- progress() - Method in class org.apache.flink.api.java.hadoop.mapred.wrapper.HadoopDummyProgressable
-
- progress() - Method in class org.apache.flink.api.java.hadoop.mapred.wrapper.HadoopDummyReporter
-
- project(int...) - Method in class org.apache.flink.api.java.DataSet
-
- project(int...) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Initiates a Project transformation on a
Tuple
DataStream
.
Note: Only Tuple DataStreams can be projected.
- project(Row, int[]) - Static method in class org.apache.flink.types.Row
-
Creates a new Row with projected fields from another row.
- ProjectCross(DataSet<I1>, DataSet<I2>, int[], boolean[], TupleTypeInfo<OUT>, CrossOperatorBase.CrossHint) - Constructor for class org.apache.flink.api.java.operators.CrossOperator.ProjectCross
-
- ProjectCross(DataSet<I1>, DataSet<I2>, int[], boolean[], TupleTypeInfo<OUT>, CrossOperator.CrossProjection<I1, I2>, CrossOperatorBase.CrossHint) - Constructor for class org.apache.flink.api.java.operators.CrossOperator.ProjectCross
-
- projectFields(int[]) - Method in class org.apache.flink.addons.hbase.HBaseTableSource
-
- projectFields(RowTypeInfo, int[]) - Static method in class org.apache.flink.api.java.typeutils.RowTypeInfo
-
- projectFields(int[]) - Method in class org.apache.flink.orc.OrcTableSource
-
- projectFirst(int...) - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
-
Continues a ProjectCross transformation and adds fields of the first cross input.
- projectFirst(int...) - Method in class org.apache.flink.api.java.operators.CrossOperator.DefaultCross
-
Initiates a ProjectCross transformation and projects the first cross input.
- projectFirst(int...) - Method in class org.apache.flink.api.java.operators.CrossOperator.ProjectCross
-
Continues a ProjectCross transformation and adds fields of the first cross input to the projection.
- projectFirst(int...) - Method in class org.apache.flink.api.java.operators.JoinOperator.DefaultJoin
-
Applies a ProjectJoin transformation and projects the first join input
- projectFirst(int...) - Method in class org.apache.flink.api.java.operators.JoinOperator.ProjectJoin
-
Continues a ProjectJoin transformation and adds fields of the first join input to the projection.
- Projection(DataSet<T>, int[]) - Constructor for class org.apache.flink.api.java.operators.ProjectOperator.Projection
-
- Projection<KC,VVC,VV,EV> - Class in org.apache.flink.graph.bipartite
-
The edge value of a full bipartite projection.
- Projection() - Constructor for class org.apache.flink.graph.bipartite.Projection
-
- Projection(Vertex<KC, VVC>, VV, VV, EV, EV) - Constructor for class org.apache.flink.graph.bipartite.Projection
-
- projectionBottomFull() - Method in class org.apache.flink.graph.bipartite.BipartiteGraph
-
Convert a bipartite graph into a graph that contains only bottom vertices.
- projectionBottomSimple() - Method in class org.apache.flink.graph.bipartite.BipartiteGraph
-
Convert a bipartite graph into an undirected graph that contains only bottom vertices.
- projectionTopFull() - Method in class org.apache.flink.graph.bipartite.BipartiteGraph
-
Convert a bipartite graph into a graph that contains only top vertices.
- projectionTopSimple() - Method in class org.apache.flink.graph.bipartite.BipartiteGraph
-
Convert a bipartite graph into an undirected graph that contains only top vertices.
- ProjectJoin(DataSet<I1>, DataSet<I2>, Keys<I1>, Keys<I2>, JoinOperatorBase.JoinHint, int[], boolean[], TupleTypeInfo<OUT>) - Constructor for class org.apache.flink.api.java.operators.JoinOperator.ProjectJoin
-
- ProjectJoin(DataSet<I1>, DataSet<I2>, Keys<I1>, Keys<I2>, JoinOperatorBase.JoinHint, int[], boolean[], TupleTypeInfo<OUT>, JoinOperator.JoinProjection<I1, I2>) - Constructor for class org.apache.flink.api.java.operators.JoinOperator.ProjectJoin
-
- ProjectOperator<IN,OUT extends Tuple> - Class in org.apache.flink.api.java.operators
-
This operator represents the application of a projection operation on a data set, and the
result data set produced by the function.
- ProjectOperator(DataSet<IN>, int[], TupleTypeInfo<OUT>) - Constructor for class org.apache.flink.api.java.operators.ProjectOperator
-
- ProjectOperator.Projection<T> - Class in org.apache.flink.api.java.operators
-
- projectSecond(int...) - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
-
Continues a ProjectCross transformation and adds fields of the second cross input.
- projectSecond(int...) - Method in class org.apache.flink.api.java.operators.CrossOperator.DefaultCross
-
Initiates a ProjectCross transformation and projects the second cross input.
- projectSecond(int...) - Method in class org.apache.flink.api.java.operators.CrossOperator.ProjectCross
-
Continues a ProjectCross transformation and adds fields of the second cross input to the projection.
- projectSecond(int...) - Method in class org.apache.flink.api.java.operators.JoinOperator.DefaultJoin
-
Applies a ProjectJoin transformation and projects the second join input
- projectSecond(int...) - Method in class org.apache.flink.api.java.operators.JoinOperator.ProjectJoin
-
Continues a ProjectJoin transformation and adds fields of the second join input to the projection.
- projectTuple1() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
-
Projects a pair of crossed elements to a
Tuple
with the previously selected fields.
- projectTuple1() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
-
- projectTuple1() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
- projectTuple10() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
-
Projects a pair of crossed elements to a
Tuple
with the previously selected fields.
- projectTuple10() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
-
- projectTuple10() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
- projectTuple11() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
-
Projects a pair of crossed elements to a
Tuple
with the previously selected fields.
- projectTuple11() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
-
- projectTuple11() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
- projectTuple12() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
-
Projects a pair of crossed elements to a
Tuple
with the previously selected fields.
- projectTuple12() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
-
- projectTuple12() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
- projectTuple13() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
-
Projects a pair of crossed elements to a
Tuple
with the previously selected fields.
- projectTuple13() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
-
- projectTuple13() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
- projectTuple14() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
-
Projects a pair of crossed elements to a
Tuple
with the previously selected fields.
- projectTuple14() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
-
- projectTuple14() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
- projectTuple15() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
-
Projects a pair of crossed elements to a
Tuple
with the previously selected fields.
- projectTuple15() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
-
- projectTuple15() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
- projectTuple16() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
-
Projects a pair of crossed elements to a
Tuple
with the previously selected fields.
- projectTuple16() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
-
- projectTuple16() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
- projectTuple17() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
-
Projects a pair of crossed elements to a
Tuple
with the previously selected fields.
- projectTuple17() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
-
- projectTuple17() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
- projectTuple18() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
-
Projects a pair of crossed elements to a
Tuple
with the previously selected fields.
- projectTuple18() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
-
- projectTuple18() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
- projectTuple19() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
-
Projects a pair of crossed elements to a
Tuple
with the previously selected fields.
- projectTuple19() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
-
- projectTuple19() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
- projectTuple2() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
-
Projects a pair of crossed elements to a
Tuple
with the previously selected fields.
- projectTuple2() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
-
- projectTuple2() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
- projectTuple20() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
-
Projects a pair of crossed elements to a
Tuple
with the previously selected fields.
- projectTuple20() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
-
- projectTuple20() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
- projectTuple21() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
-
Projects a pair of crossed elements to a
Tuple
with the previously selected fields.
- projectTuple21() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
-
- projectTuple21() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
- projectTuple22() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
-
Projects a pair of crossed elements to a
Tuple
with the previously selected fields.
- projectTuple22() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
-
- projectTuple22() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
- projectTuple23() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
-
Projects a pair of crossed elements to a
Tuple
with the previously selected fields.
- projectTuple23() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
-
- projectTuple23() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
- projectTuple24() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
-
Projects a pair of crossed elements to a
Tuple
with the previously selected fields.
- projectTuple24() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
-
- projectTuple24() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
- projectTuple25() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
-
Projects a pair of crossed elements to a
Tuple
with the previously selected fields.
- projectTuple25() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
-
- projectTuple25() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
- projectTuple3() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
-
Projects a pair of crossed elements to a
Tuple
with the previously selected fields.
- projectTuple3() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
-
- projectTuple3() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
- projectTuple4() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
-
Projects a pair of crossed elements to a
Tuple
with the previously selected fields.
- projectTuple4() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
-
- projectTuple4() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
- projectTuple5() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
-
Projects a pair of crossed elements to a
Tuple
with the previously selected fields.
- projectTuple5() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
-
- projectTuple5() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
- projectTuple6() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
-
Projects a pair of crossed elements to a
Tuple
with the previously selected fields.
- projectTuple6() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
-
- projectTuple6() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
- projectTuple7() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
-
Projects a pair of crossed elements to a
Tuple
with the previously selected fields.
- projectTuple7() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
-
- projectTuple7() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
- projectTuple8() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
-
Projects a pair of crossed elements to a
Tuple
with the previously selected fields.
- projectTuple8() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
-
- projectTuple8() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
- projectTuple9() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
-
Projects a pair of crossed elements to a
Tuple
with the previously selected fields.
- projectTuple9() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
-
- projectTuple9() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
- projectTupleX() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
-
- projectTupleX() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
-
- projectTupleX() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
- PrometheusReporter - Class in org.apache.flink.metrics.prometheus
-
- PrometheusReporter() - Constructor for class org.apache.flink.metrics.prometheus.PrometheusReporter
-
- properties - Variable in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer09
-
User-supplied properties for Kafka.
- properties - Variable in class org.apache.flink.streaming.connectors.kafka.KafkaTableSink
-
- properties(Properties) - Method in class org.apache.flink.table.descriptors.Kafka
-
Sets the configuration properties for the Kafka consumer.
- PROPERTIES_FILE_LOCATION - Static variable in class org.apache.flink.yarn.configuration.YarnConfigOptions
-
When a Flink job is submitted to YARN, the JobManager's host and the number of available
processing slots is written into a properties file, so that the Flink client is able
to pick those details up.
- PropertiesUtil - Class in org.apache.flink.util
-
Simple utilities for getting typed values from Properties.
- property(String, String) - Method in class org.apache.flink.table.descriptors.Kafka
-
Adds a configuration properties for the Kafka consumer.
- PropertyStrings - Class in org.apache.flink.table.client.config
-
Strings used for key and values in an environment file.
- PROXY_ASYNC_QUERY_THREADS - Static variable in class org.apache.flink.configuration.QueryableStateOptions
-
Number of async query threads for the client proxy (0 => #slots).
- PROXY_NETWORK_THREADS - Static variable in class org.apache.flink.configuration.QueryableStateOptions
-
Number of network (event loop) threads for the client proxy (0 => #slots).
- PROXY_PORT_RANGE - Static variable in class org.apache.flink.configuration.QueryableStateOptions
-
The config parameter defining the server port range of the queryable state proxy.
- ProxyMetricGroup<P extends MetricGroup> - Class in org.apache.flink.runtime.metrics.groups
-
Metric group which forwards all registration calls to its parent metric group.
- ProxyMetricGroup(P) - Constructor for class org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
-
- prune(long) - Method in class org.apache.flink.cep.nfa.SharedBuffer
-
Deletes all entries in each page which have expired with respect to given pruning timestamp.
- pruneBuffer() - Method in class org.apache.flink.core.memory.DataOutputSerializer
-
- pruneMatchingCheckpoints(LongPredicate) - Method in class org.apache.flink.runtime.state.NoOpTaskLocalStateStoreImpl
-
- pruneMatchingCheckpoints(LongPredicate) - Method in interface org.apache.flink.runtime.state.TaskLocalStateStore
-
Remove all checkpoints from the store that match the given predicate.
- pruneMatchingCheckpoints(LongPredicate) - Method in class org.apache.flink.runtime.state.TaskLocalStateStoreImpl
-
- prunePlanAlternatives(List<PlanNode>) - Method in class org.apache.flink.optimizer.dag.OptimizerNode
-
- prunePlanAlternativesWithCommonBranching(List<PlanNode>) - Method in class org.apache.flink.optimizer.dag.OptimizerNode
-
- Public - Annotation Type in org.apache.flink.annotation
-
Annotation for marking classes as public, stable interfaces.
- PublicEvolving - Annotation Type in org.apache.flink.annotation
-
Annotation to mark classes and methods for public use, but with evolving interfaces.
- publish(TaskEvent) - Method in class org.apache.flink.runtime.io.network.api.reader.AbstractReader
-
- publish(TaskEvent) - Method in class org.apache.flink.runtime.io.network.api.TaskEventHandler
-
Publishes the task event to all subscribed event listeners.
- publish(ResultPartitionID, TaskEvent) - Method in class org.apache.flink.runtime.io.network.TaskEventDispatcher
-
- PurgingTrigger<T,W extends Window> - Class in org.apache.flink.streaming.api.windowing.triggers
-
A trigger that can turn any
Trigger
into a purging
Trigger
.
- pushDownPages() - Method in class org.apache.flink.runtime.operators.hash.InMemoryPartition
-
- put(K, V) - Method in interface org.apache.flink.api.common.state.BroadcastState
-
Associates a new value with the given key.
- put(UK, UV) - Method in interface org.apache.flink.api.common.state.MapState
-
Associates a new value with the given key.
- put(K, V, long, K, V, long, int, DeweyNumber) - Method in class org.apache.flink.cep.nfa.SharedBuffer
-
Stores given value (value + timestamp) under the given key.
- put(K, V, long, DeweyNumber) - Method in class org.apache.flink.cep.nfa.SharedBuffer
-
Stores given value (value + timestamp) under the given key.
- put(UK, UV) - Method in class org.apache.flink.contrib.streaming.state.RocksDBMapState
-
- put(ColumnFamilyHandle, byte[], byte[]) - Method in class org.apache.flink.contrib.streaming.state.RocksDBWriteBatchWrapper
-
- put(int, byte) - Method in class org.apache.flink.core.memory.HeapMemorySegment
-
- put(int, byte[]) - Method in class org.apache.flink.core.memory.HeapMemorySegment
-
- put(int, byte[], int, int) - Method in class org.apache.flink.core.memory.HeapMemorySegment
-
- put(DataInput, int, int) - Method in class org.apache.flink.core.memory.HeapMemorySegment
-
- put(int, ByteBuffer, int) - Method in class org.apache.flink.core.memory.HeapMemorySegment
-
- put(int, byte) - Method in class org.apache.flink.core.memory.HybridMemorySegment
-
- put(int, byte[]) - Method in class org.apache.flink.core.memory.HybridMemorySegment
-
- put(int, byte[], int, int) - Method in class org.apache.flink.core.memory.HybridMemorySegment
-
- put(DataInput, int, int) - Method in class org.apache.flink.core.memory.HybridMemorySegment
-
- put(int, ByteBuffer, int) - Method in class org.apache.flink.core.memory.HybridMemorySegment
-
- put(int, byte) - Method in class org.apache.flink.core.memory.MemorySegment
-
Writes the given byte into this buffer at the given position.
- put(int, byte[]) - Method in class org.apache.flink.core.memory.MemorySegment
-
Bulk put method.
- put(int, byte[], int, int) - Method in class org.apache.flink.core.memory.MemorySegment
-
Bulk put method.
- put(DataInput, int, int) - Method in class org.apache.flink.core.memory.MemorySegment
-
Bulk put method.
- put(int, ByteBuffer, int) - Method in class org.apache.flink.core.memory.MemorySegment
-
Bulk put method.
- put(K, V) - Method in class org.apache.flink.queryablestate.client.state.ImmutableMapState
-
- put(File, JobID, BlobKey) - Method in interface org.apache.flink.runtime.blob.BlobStore
-
Copies the local file to the blob store.
- put(File, JobID, BlobKey) - Method in class org.apache.flink.runtime.blob.FileSystemBlobStore
-
- put(File, JobID, BlobKey) - Method in class org.apache.flink.runtime.blob.VoidBlobStore
-
- put(ArchivedExecutionGraph) - Method in interface org.apache.flink.runtime.dispatcher.ArchivedExecutionGraphStore
-
- put(ArchivedExecutionGraph) - Method in class org.apache.flink.runtime.dispatcher.FileArchivedExecutionGraphStore
-
- put(ArchivedExecutionGraph) - Method in class org.apache.flink.runtime.dispatcher.MemoryArchivedExecutionGraphStore
-
- put(A, B, V) - Method in class org.apache.flink.runtime.jobmaster.slotpool.DualKeyMap
-
- put(T) - Method in class org.apache.flink.runtime.operators.sort.PartialOrderPriorityQueue
-
Adds a buffer to a PriorityQueue in log(size) time.
- put(K, int, N, S) - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateTable
-
- put(N, S) - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateTable
-
- put(UK, UV) - Method in class org.apache.flink.runtime.state.heap.HeapMapState
-
- put(N, S) - Method in class org.apache.flink.runtime.state.heap.NestedMapsStateTable
-
- put(K, int, N, S) - Method in class org.apache.flink.runtime.state.heap.NestedMapsStateTable
-
- put(N, S) - Method in class org.apache.flink.runtime.state.heap.StateTable
-
Maps the composite of active key and given namespace to the specified state.
- put(K, int, N, S) - Method in class org.apache.flink.runtime.state.heap.StateTable
-
- put(K, V) - Method in class org.apache.flink.runtime.state.HeapBroadcastState
-
- put(JobID, JobManagerConnection) - Method in class org.apache.flink.runtime.taskexecutor.JobManagerTable
-
- put(Object, Object) - Method in class org.apache.flink.storm.util.StormConfig
-
- put(StreamElementQueueEntry<T>) - Method in class org.apache.flink.streaming.api.operators.async.queue.OrderedStreamElementQueue
-
- put(StreamElementQueueEntry<T>) - Method in interface org.apache.flink.streaming.api.operators.async.queue.StreamElementQueue
-
Put the given element in the queue if capacity is left.
- put(StreamElementQueueEntry<T>) - Method in class org.apache.flink.streaming.api.operators.async.queue.UnorderedStreamElementQueue
-
- put(K, V) - Method in class org.apache.flink.streaming.runtime.operators.windowing.KeyMap
-
Inserts the given value, mapped under the given key.
- put(K, V) - Method in class org.apache.flink.types.MapValue
-
- putAll(Map<K, V>) - Method in interface org.apache.flink.api.common.state.BroadcastState
-
Copies all of the mappings from the given map into the state.
- putAll(Map<UK, UV>) - Method in interface org.apache.flink.api.common.state.MapState
-
Copies all of the mappings from the given map into the state.
- putAll(Map<UK, UV>) - Method in class org.apache.flink.contrib.streaming.state.RocksDBMapState
-
- putAll(Map<K, V>) - Method in class org.apache.flink.queryablestate.client.state.ImmutableMapState
-
- putAll(Map<UK, UV>) - Method in class org.apache.flink.runtime.state.heap.HeapMapState
-
- putAll(Map<K, V>) - Method in class org.apache.flink.runtime.state.HeapBroadcastState
-
- putAll(Map) - Method in class org.apache.flink.storm.util.StormConfig
-
- putAll(Map<? extends K, ? extends V>) - Method in class org.apache.flink.types.MapValue
-
- putAndGetOld(N, S) - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateTable
-
- putAndGetOld(N, S) - Method in class org.apache.flink.runtime.state.heap.NestedMapsStateTable
-
- putAndGetOld(N, S) - Method in class org.apache.flink.runtime.state.heap.StateTable
-
Maps the composite of active key and given namespace to the specified state.
- putBoolean(int, boolean) - Method in class org.apache.flink.core.memory.HeapMemorySegment
-
- putBoolean(int, boolean) - Method in class org.apache.flink.core.memory.HybridMemorySegment
-
- putBoolean(int, boolean) - Method in class org.apache.flink.core.memory.MemorySegment
-
Writes one byte containing the byte value into this buffer at the given
position.
- putChar(int, char) - Method in class org.apache.flink.core.memory.MemorySegment
-
Writes a char value to the given position, in the system's native byte order.
- putCharBigEndian(int, char) - Method in class org.apache.flink.core.memory.MemorySegment
-
Writes the given character (16 bit, 2 bytes) to the given position in big-endian
byte order.
- putCharLittleEndian(int, char) - Method in class org.apache.flink.core.memory.MemorySegment
-
Writes the given character (16 bit, 2 bytes) to the given position in little-endian
byte order.
- putDouble(int, double) - Method in class org.apache.flink.core.memory.MemorySegment
-
Writes the given double-precision floating-point value (64bit, 8 bytes) to the given position in the
system's native byte order.
- putDoubleBigEndian(int, double) - Method in class org.apache.flink.core.memory.MemorySegment
-
Writes the given double-precision floating-point value (64bit, 8 bytes) to the given position in big endian
byte order.
- putDoubleLittleEndian(int, double) - Method in class org.apache.flink.core.memory.MemorySegment
-
Writes the given double-precision floating-point value (64bit, 8 bytes) to the given position in little endian
byte order.
- putFloat(int, float) - Method in class org.apache.flink.core.memory.MemorySegment
-
Writes the given single-precision float value (32bit, 4 bytes) to the given position in the system's native
byte order.
- putFloatBigEndian(int, float) - Method in class org.apache.flink.core.memory.MemorySegment
-
Writes the given single-precision float value (32bit, 4 bytes) to the given position in big endian
byte order.
- putFloatLittleEndian(int, float) - Method in class org.apache.flink.core.memory.MemorySegment
-
Writes the given single-precision float value (32bit, 4 bytes) to the given position in little endian
byte order.
- putIfAbsent(K, KeyMap.LazyFactory<V>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.KeyMap
-
Inserts a value for the given key, if no value is yet contained for that key.
- putInt(int, int) - Method in class org.apache.flink.core.memory.MemorySegment
-
Writes the given int value (32bit, 4 bytes) to the given position in the system's native
byte order.
- putIntBigEndian(int, int) - Method in class org.apache.flink.core.memory.MemorySegment
-
Writes the given int value (32bit, 4 bytes) to the given position in big endian
byte order.
- putIntLittleEndian(int, int) - Method in class org.apache.flink.core.memory.MemorySegment
-
Writes the given int value (32bit, 4 bytes) to the given position in little endian
byte order.
- putJobGraph(SubmittedJobGraph) - Method in class org.apache.flink.runtime.dispatcher.SingleJobSubmittedJobGraphStore
-
- putJobGraph(SubmittedJobGraph) - Method in class org.apache.flink.runtime.jobmanager.StandaloneSubmittedJobGraphStore
-
- putJobGraph(SubmittedJobGraph) - Method in interface org.apache.flink.runtime.jobmanager.SubmittedJobGraphStore
-
- putJobGraph(SubmittedJobGraph) - Method in class org.apache.flink.runtime.jobmanager.ZooKeeperSubmittedJobGraphStore
-
- putLong(int, long) - Method in class org.apache.flink.core.memory.MemorySegment
-
Writes the given long value (64bit, 8 bytes) to the given position in the system's native
byte order.
- putLongBigEndian(int, long) - Method in class org.apache.flink.core.memory.MemorySegment
-
Writes the given long value (64bit, 8 bytes) to the given position in big endian
byte order.
- putLongLittleEndian(int, long) - Method in class org.apache.flink.core.memory.MemorySegment
-
Writes the given long value (64bit, 8 bytes) to the given position in little endian
byte order.
- putNormalizedKey(T, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.array.PrimitiveArrayComparator
-
- putNormalizedKey(BigDecimal, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.BigDecComparator
-
Adds a normalized key containing a normalized order of magnitude of the given record.
- putNormalizedKey(BigInteger, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.BigIntComparator
-
Adds a normalized key containing the normalized number of bits and MSBs of the given record.
- putNormalizedKey(Boolean, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.BooleanComparator
-
- putNormalizedKey(BooleanValue, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueComparator
-
- putNormalizedKey(Byte, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.ByteComparator
-
- putNormalizedKey(ByteValue, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.ByteValueComparator
-
- putNormalizedKey(Character, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.CharComparator
-
- putNormalizedKey(CharValue, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.CharValueComparator
-
- putNormalizedKey(Date, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.DateComparator
-
- putNormalizedKey(Double, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.DoubleComparator
-
- putNormalizedKey(DoubleValue, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueComparator
-
- putNormalizedKey(T, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.EnumComparator
-
- putNormalizedKey(Float, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.FloatComparator
-
- putNormalizedKey(FloatValue, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.FloatValueComparator
-
- putNormalizedKey(Integer, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.IntComparator
-
- putNormalizedKey(IntValue, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.IntValueComparator
-
- putNormalizedKey(Long, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.LongComparator
-
- putNormalizedKey(LongValue, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.LongValueComparator
-
- putNormalizedKey(NullValue, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.NullValueComparator
-
- putNormalizedKey(Short, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.ShortComparator
-
- putNormalizedKey(ShortValue, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.ShortValueComparator
-
- putNormalizedKey(Date, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.SqlTimestampComparator
-
- putNormalizedKey(String, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.StringComparator
-
- putNormalizedKey(StringValue, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.StringValueComparator
-
- putNormalizedKey(T, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.TypeComparator
-
Writes a normalized key for the given record into the target byte array, starting at the specified position
and writing exactly the given number of bytes.
- putNormalizedKey(T, MemorySegment, int, int) - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueComparator
-
- putNormalizedKey(T, MemorySegment, int, int) - Method in class org.apache.flink.api.java.typeutils.runtime.GenericTypeComparator
-
- putNormalizedKey(T, MemorySegment, int, int) - Method in class org.apache.flink.api.java.typeutils.runtime.NullAwareComparator
-
- putNormalizedKey(T, MemorySegment, int, int) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoComparator
-
- putNormalizedKey(Row, MemorySegment, int, int) - Method in class org.apache.flink.api.java.typeutils.runtime.RowComparator
-
- putNormalizedKey(T, MemorySegment, int, int) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparator
-
- putNormalizedKey(T, MemorySegment, int, int) - Method in class org.apache.flink.api.java.typeutils.runtime.ValueComparator
-
- putNormalizedKey(T, MemorySegment, int, int) - Method in class org.apache.flink.api.java.typeutils.runtime.WritableComparator
-
- putNormalizedKey(ByteValueArray, MemorySegment, int, int) - Method in class org.apache.flink.graph.types.valuearray.ByteValueArrayComparator
-
- putNormalizedKey(CharValueArray, MemorySegment, int, int) - Method in class org.apache.flink.graph.types.valuearray.CharValueArrayComparator
-
- putNormalizedKey(DoubleValueArray, MemorySegment, int, int) - Method in class org.apache.flink.graph.types.valuearray.DoubleValueArrayComparator
-
- putNormalizedKey(FloatValueArray, MemorySegment, int, int) - Method in class org.apache.flink.graph.types.valuearray.FloatValueArrayComparator
-
- putNormalizedKey(IntValueArray, MemorySegment, int, int) - Method in class org.apache.flink.graph.types.valuearray.IntValueArrayComparator
-
- putNormalizedKey(LongValueArray, MemorySegment, int, int) - Method in class org.apache.flink.graph.types.valuearray.LongValueArrayComparator
-
- putNormalizedKey(NullValueArray, MemorySegment, int, int) - Method in class org.apache.flink.graph.types.valuearray.NullValueArrayComparator
-
- putNormalizedKey(ShortValueArray, MemorySegment, int, int) - Method in class org.apache.flink.graph.types.valuearray.ShortValueArrayComparator
-
- putNormalizedKey(StringValueArray, MemorySegment, int, int) - Method in class org.apache.flink.graph.types.valuearray.StringValueArrayComparator
-
- putNormalizedKeyDate(Date, MemorySegment, int, int) - Static method in class org.apache.flink.api.common.typeutils.base.DateComparator
-
- putOrAggregate(K, V, ReduceFunction<V>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.KeyMap
-
Inserts or aggregates a value into the hash map.
- putPermanent(JobID, byte[]) - Method in class org.apache.flink.runtime.blob.BlobServer
-
- putPermanent(JobID, InputStream) - Method in class org.apache.flink.runtime.blob.BlobServer
-
- putPermanent(JobID, byte[]) - Method in interface org.apache.flink.runtime.blob.BlobWriter
-
Uploads the data of the given byte array for the given job to the BLOB server and makes it
a permanent BLOB.
- putPermanent(JobID, InputStream) - Method in interface org.apache.flink.runtime.blob.BlobWriter
-
Uploads the data from the given input stream for the given job to the BLOB server and makes it
a permanent BLOB.
- putPermanent(JobID, byte[]) - Method in class org.apache.flink.runtime.blob.VoidBlobWriter
-
- putPermanent(JobID, InputStream) - Method in class org.apache.flink.runtime.blob.VoidBlobWriter
-
- putShort(int, short) - Method in class org.apache.flink.core.memory.MemorySegment
-
Writes the given short value into this buffer at the given position, using
the native byte order of the system.
- putShortBigEndian(int, short) - Method in class org.apache.flink.core.memory.MemorySegment
-
Writes the given short integer value (16 bit, 2 bytes) to the given position in big-endian
byte order.
- putShortLittleEndian(int, short) - Method in class org.apache.flink.core.memory.MemorySegment
-
Writes the given short integer value (16 bit, 2 bytes) to the given position in little-endian
byte order.
- putState(int, OperatorSubtaskState) - Method in class org.apache.flink.runtime.checkpoint.OperatorState
-
- putState(int, SubtaskState) - Method in class org.apache.flink.runtime.checkpoint.TaskState
-
Deprecated.
- putSubtaskStateByOperatorID(OperatorID, OperatorSubtaskState) - Method in class org.apache.flink.runtime.checkpoint.TaskStateSnapshot
-
Maps the given operator id to the given subtask state.
- putTransient(byte[]) - Method in class org.apache.flink.runtime.blob.BlobServer
-
- putTransient(JobID, byte[]) - Method in class org.apache.flink.runtime.blob.BlobServer
-
- putTransient(InputStream) - Method in class org.apache.flink.runtime.blob.BlobServer
-
- putTransient(JobID, InputStream) - Method in class org.apache.flink.runtime.blob.BlobServer
-
- putTransient(byte[]) - Method in class org.apache.flink.runtime.blob.TransientBlobCache
-
- putTransient(JobID, byte[]) - Method in class org.apache.flink.runtime.blob.TransientBlobCache
-
- putTransient(InputStream) - Method in class org.apache.flink.runtime.blob.TransientBlobCache
-
- putTransient(JobID, InputStream) - Method in class org.apache.flink.runtime.blob.TransientBlobCache
-
- putTransient(byte[]) - Method in interface org.apache.flink.runtime.blob.TransientBlobService
-
Uploads the (job-unrelated) data of the given byte array to the BLOB server.
- putTransient(JobID, byte[]) - Method in interface org.apache.flink.runtime.blob.TransientBlobService
-
Uploads the data of the given byte array for the given job to the BLOB server.
- putTransient(InputStream) - Method in interface org.apache.flink.runtime.blob.TransientBlobService
-
Uploads the (job-unrelated) data from the given input stream to the BLOB server.
- putTransient(JobID, InputStream) - Method in interface org.apache.flink.runtime.blob.TransientBlobService
-
Uploads the data from the given input stream for the given job to the BLOB server.
- putTypeInfo(ByteBuffer) - Method in class org.apache.flink.python.api.streaming.util.SerializationUtils.BooleanSerializer
-
- putTypeInfo(ByteBuffer) - Method in class org.apache.flink.python.api.streaming.util.SerializationUtils.ByteSerializer
-
- putTypeInfo(ByteBuffer) - Method in class org.apache.flink.python.api.streaming.util.SerializationUtils.BytesSerializer
-
- putTypeInfo(ByteBuffer) - Method in class org.apache.flink.python.api.streaming.util.SerializationUtils.CustomTypeWrapperSerializer
-
- putTypeInfo(ByteBuffer) - Method in class org.apache.flink.python.api.streaming.util.SerializationUtils.DoubleSerializer
-
- putTypeInfo(ByteBuffer) - Method in class org.apache.flink.python.api.streaming.util.SerializationUtils.FloatSerializer
-
- putTypeInfo(ByteBuffer) - Method in class org.apache.flink.python.api.streaming.util.SerializationUtils.IntSerializer
-
- putTypeInfo(ByteBuffer) - Method in class org.apache.flink.python.api.streaming.util.SerializationUtils.LongSerializer
-
- putTypeInfo(ByteBuffer) - Method in class org.apache.flink.python.api.streaming.util.SerializationUtils.NullSerializer
-
- putTypeInfo(ByteBuffer) - Method in class org.apache.flink.python.api.streaming.util.SerializationUtils.Serializer
-
- putTypeInfo(ByteBuffer) - Method in class org.apache.flink.python.api.streaming.util.SerializationUtils.StringSerializer
-
- putTypeInfo(ByteBuffer) - Method in class org.apache.flink.python.api.streaming.util.SerializationUtils.TupleSerializer
-
- putVariables(Map<String, String>) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
-
Enters all variables specific to this
AbstractMetricGroup
and their associated values into the map.
- putVariables(Map<String, String>) - Method in class org.apache.flink.runtime.metrics.groups.GenericValueMetricGroup
-
- putVariables(Map<String, String>) - Method in class org.apache.flink.runtime.metrics.groups.JobManagerMetricGroup
-
- putVariables(Map<String, String>) - Method in class org.apache.flink.runtime.metrics.groups.JobMetricGroup
-
- putVariables(Map<String, String>) - Method in class org.apache.flink.runtime.metrics.groups.OperatorMetricGroup
-
- putVariables(Map<String, String>) - Method in class org.apache.flink.runtime.metrics.groups.TaskManagerMetricGroup
-
- putVariables(Map<String, String>) - Method in class org.apache.flink.runtime.metrics.groups.TaskMetricGroup
-
- putWorker(MesosWorkerStore.Worker) - Method in interface org.apache.flink.mesos.runtime.clusterframework.store.MesosWorkerStore
-
Put a worker into storage.
- putWorker(MesosWorkerStore.Worker) - Method in class org.apache.flink.mesos.runtime.clusterframework.store.StandaloneMesosWorkerStore
-
- putWorker(MesosWorkerStore.Worker) - Method in class org.apache.flink.mesos.runtime.clusterframework.store.ZooKeeperMesosWorkerStore
-
- PyBooleanSerializer - Class in org.apache.flink.streaming.python.util.serialization
-
A Serializer
implementation for PyBoolean
class type.
- PyBooleanSerializer() - Constructor for class org.apache.flink.streaming.python.util.serialization.PyBooleanSerializer
-
- PyFloatSerializer - Class in org.apache.flink.streaming.python.util.serialization
-
A Serializer
implementation for PyFloat
class type.
- PyFloatSerializer() - Constructor for class org.apache.flink.streaming.python.util.serialization.PyFloatSerializer
-
- PyIntegerSerializer - Class in org.apache.flink.streaming.python.util.serialization
-
A Serializer
implementation for PyInteger
class type.
- PyIntegerSerializer() - Constructor for class org.apache.flink.streaming.python.util.serialization.PyIntegerSerializer
-
- PyKey - Class in org.apache.flink.streaming.python.api.functions
-
A key type used by
PythonKeySelector
to
host a python object and provide the necessary interface to compare two python objects.
- PyKey(Object) - Constructor for class org.apache.flink.streaming.python.api.functions.PyKey
-
- PyLongSerializer - Class in org.apache.flink.streaming.python.util.serialization
-
A Serializer
implementation for PyLong
class type.
- PyLongSerializer() - Constructor for class org.apache.flink.streaming.python.util.serialization.PyLongSerializer
-
- PyObjectSerializer - Class in org.apache.flink.streaming.python.util.serialization
-
A Serializer
implementation for PyObject
class type.
- PyObjectSerializer() - Constructor for class org.apache.flink.streaming.python.util.serialization.PyObjectSerializer
-
- PyStringSerializer - Class in org.apache.flink.streaming.python.util.serialization
-
A Serializer
implementation for PyString
class type.
- PyStringSerializer() - Constructor for class org.apache.flink.streaming.python.util.serialization.PyStringSerializer
-
- PYTHON_BINARY_PATH - Static variable in class org.apache.flink.python.api.PythonOptions
-
The config parameter defining the path to the python binary to use.
- PythonApplyFunction<W extends Window> - Class in org.apache.flink.streaming.python.api.functions
-
The PythonApplyFunction
is a thin wrapper layer over a Python UDF WindowFunction
.
- PythonApplyFunction(WindowFunction<PyObject, Object, Object, W>) - Constructor for class org.apache.flink.streaming.python.api.functions.PythonApplyFunction
-
- PythonCoGroup<IN1,IN2,OUT> - Class in org.apache.flink.python.api.functions
-
CoGroupFunction that uses a python script.
- PythonCoGroup(Configuration, int, int, TypeInformation<OUT>) - Constructor for class org.apache.flink.python.api.functions.PythonCoGroup
-
- PythonCollector - Class in org.apache.flink.streaming.python.util
-
Collects a PyObject
record and forwards it.
- PythonCollector() - Constructor for class org.apache.flink.streaming.python.util.PythonCollector
-
- PythonConstants - Class in org.apache.flink.streaming.python.api.environment
-
Collection of constants for the Streaming Python API.
- PythonConstants() - Constructor for class org.apache.flink.streaming.python.api.environment.PythonConstants
-
- PythonDataStream<D extends DataStream<org.python.core.PyObject>> - Class in org.apache.flink.streaming.python.api.datastream
-
A
PythonDataStream
is a thin wrapper layer over
DataStream
, which represents a
stream of elements of the same type.
- PythonDataStream(D) - Constructor for class org.apache.flink.streaming.python.api.datastream.PythonDataStream
-
- PythonDualInputSender<IN1,IN2> - Class in org.apache.flink.python.api.streaming.data
-
This class is a
PythonSender
for operations with two input streams.
- PythonDualInputSender(Configuration) - Constructor for class org.apache.flink.python.api.streaming.data.PythonDualInputSender
-
- PythonDualInputStreamer<IN1,IN2,OUT> - Class in org.apache.flink.python.api.streaming.data
-
- PythonDualInputStreamer(AbstractRichFunction, Configuration, int, int, boolean) - Constructor for class org.apache.flink.python.api.streaming.data.PythonDualInputStreamer
-
- PythonEnvironmentFactory - Class in org.apache.flink.streaming.python.api.environment
-
- PythonEnvironmentFactory(String, Path, String) - Constructor for class org.apache.flink.streaming.python.api.environment.PythonEnvironmentFactory
-
- PythonFilterFunction - Class in org.apache.flink.streaming.python.api.functions
-
The PythonFilterFunction
is a thin wrapper layer over a Python UDF FilterFunction
.
- PythonFilterFunction(FilterFunction<PyObject>) - Constructor for class org.apache.flink.streaming.python.api.functions.PythonFilterFunction
-
- PythonFlatMapFunction - Class in org.apache.flink.streaming.python.api.functions
-
The PythonFlatMapFunction
is a thin wrapper layer over a Python UDF FlatMapFunction
.
- PythonFlatMapFunction(FlatMapFunction<PyObject, Object>) - Constructor for class org.apache.flink.streaming.python.api.functions.PythonFlatMapFunction
-
- PythonGeneratorFunction - Class in org.apache.flink.streaming.python.api.functions
-
The PythonGeneratorFunction
is a thin wrapper layer over a Python UDF SourceFunction
.
- PythonGeneratorFunction(SourceFunction<Object>) - Constructor for class org.apache.flink.streaming.python.api.functions.PythonGeneratorFunction
-
- PythonIterativeStream - Class in org.apache.flink.streaming.python.api.datastream
-
- PythonIterator - Interface in org.apache.flink.streaming.python.util
-
An interface definition for Python iterator.
- PythonIteratorFunction - Class in org.apache.flink.streaming.python.api.functions
-
The PythonIteratorFunction
is a thin wrapper layer over a Python UDF Iterator
.
- PythonIteratorFunction(Iterator<Object>) - Constructor for class org.apache.flink.streaming.python.api.functions.PythonIteratorFunction
-
- PythonKeyedStream - Class in org.apache.flink.streaming.python.api.datastream
-
- PythonKeySelector - Class in org.apache.flink.streaming.python.api.functions
-
The PythonKeySelector
is a thin wrapper layer over a Python UDF KeySelector
.
- PythonKeySelector(KeySelector<PyObject, PyKey>) - Constructor for class org.apache.flink.streaming.python.api.functions.PythonKeySelector
-
- PythonMapFunction - Class in org.apache.flink.streaming.python.api.functions
-
The PythonMapFunction
is a thin wrapper layer over a Python UDF MapFunction
.
- PythonMapFunction(MapFunction<PyObject, PyObject>) - Constructor for class org.apache.flink.streaming.python.api.functions.PythonMapFunction
-
- PythonMapPartition<IN,OUT> - Class in org.apache.flink.python.api.functions
-
Multi-purpose class, usable by all operations using a python script with one input source and possibly differing
in-/output types.
- PythonMapPartition(Configuration, int, int, TypeInformation<OUT>) - Constructor for class org.apache.flink.python.api.functions.PythonMapPartition
-
- PythonOperationInfo - Class in org.apache.flink.python.api
-
Generic container for all information required to an operation to the DataSet API.
- PythonOperationInfo(PythonPlanStreamer, int) - Constructor for class org.apache.flink.python.api.PythonOperationInfo
-
- PythonOptions - Class in org.apache.flink.python.api
-
Configuration options for the Python API.
- PythonOptions - Class in org.apache.flink.streaming.python
-
Configuration options for the Python API.
- PythonOutputSelector - Class in org.apache.flink.streaming.python.api.functions
-
The PythonOutputSelector
is a thin wrapper layer over a Python UDF OutputSelector
.
- PythonOutputSelector(OutputSelector<PyObject>) - Constructor for class org.apache.flink.streaming.python.api.functions.PythonOutputSelector
-
- PythonPlanBinder - Class in org.apache.flink.python.api
-
This class allows the execution of a Flink plan written in python.
- PythonPlanBinder(Configuration) - Constructor for class org.apache.flink.python.api.PythonPlanBinder
-
- PythonPlanBinder.Operation - Enum in org.apache.flink.python.api
-
This enum contains the identifiers for all supported DataSet operations.
- PythonPlanReceiver - Class in org.apache.flink.python.api.streaming.plan
-
Instances of this class can be used to receive data from the plan process.
- PythonPlanReceiver(InputStream) - Constructor for class org.apache.flink.python.api.streaming.plan.PythonPlanReceiver
-
- PythonPlanSender - Class in org.apache.flink.python.api.streaming.plan
-
Instances of this class can be used to send data to the plan process.
- PythonPlanSender(OutputStream) - Constructor for class org.apache.flink.python.api.streaming.plan.PythonPlanSender
-
- PythonPlanStreamer - Class in org.apache.flink.python.api.streaming.plan
-
Generic class to exchange data during the plan phase.
- PythonPlanStreamer(Configuration) - Constructor for class org.apache.flink.python.api.streaming.plan.PythonPlanStreamer
-
- PythonReceiver<OUT> - Class in org.apache.flink.python.api.streaming.data
-
This class is used to read data from memory-mapped files.
- PythonReceiver(Configuration, boolean) - Constructor for class org.apache.flink.python.api.streaming.data.PythonReceiver
-
- PythonReduceFunction - Class in org.apache.flink.streaming.python.api.functions
-
The PythonReduceFunction
is a thin wrapper layer over a Python UDF ReduceFunction
.
- PythonReduceFunction(ReduceFunction<PyObject>) - Constructor for class org.apache.flink.streaming.python.api.functions.PythonReduceFunction
-
- PythonSender - Class in org.apache.flink.python.api.streaming.data
-
General-purpose class to write data to memory-mapped files.
- PythonSender(Configuration) - Constructor for class org.apache.flink.python.api.streaming.data.PythonSender
-
- PythonSender.Serializer<T> - Class in org.apache.flink.python.api.streaming.data
-
Interface for all serializers used by
PythonSender
classes to write container objects.
- PythonSerializationSchema - Class in org.apache.flink.streaming.python.util.serialization
-
- PythonSerializationSchema(SerializationSchema<PyObject>) - Constructor for class org.apache.flink.streaming.python.util.serialization.PythonSerializationSchema
-
- PythonSingleInputSender<IN> - Class in org.apache.flink.python.api.streaming.data
-
This class is a
PythonSender
for operations with one input stream.
- PythonSingleInputSender(Configuration) - Constructor for class org.apache.flink.python.api.streaming.data.PythonSingleInputSender
-
- PythonSingleInputStreamer<IN,OUT> - Class in org.apache.flink.python.api.streaming.data
-
- PythonSingleInputStreamer(AbstractRichFunction, Configuration, int, int, boolean) - Constructor for class org.apache.flink.python.api.streaming.data.PythonSingleInputStreamer
-
- PythonSingleOutputStreamOperator - Class in org.apache.flink.streaming.python.api.datastream
-
- PythonSinkFunction - Class in org.apache.flink.streaming.python.api.functions
-
The PythonSinkFunction
is a thin wrapper layer over a Python UDF SinkFunction
.
- PythonSinkFunction(SinkFunction<PyObject>) - Constructor for class org.apache.flink.streaming.python.api.functions.PythonSinkFunction
-
- PythonSplitStream - Class in org.apache.flink.streaming.python.api.datastream
-
- PythonStreamBinder - Class in org.apache.flink.streaming.python.api
-
Allows the execution of Flink stream plan that is written in Python.
- PythonStreamer<S extends PythonSender,OUT> - Class in org.apache.flink.python.api.streaming.data
-
This streamer is used by functions to send/receive data to/from an external python process.
- PythonStreamer(AbstractRichFunction, Configuration, int, int, boolean, S) - Constructor for class org.apache.flink.python.api.streaming.data.PythonStreamer
-
- PythonStreamExecutionEnvironment - Class in org.apache.flink.streaming.python.api.environment
-
- PythonStreamExecutionEnvironment.PythonJobParameters - Class in org.apache.flink.streaming.python.api.environment
-
Utility class for storing/retrieving parameters in/from a ExecutionConfig.GlobalJobParameters
.
- PythonWindowedStream<W extends Window> - Class in org.apache.flink.streaming.python.api.datastream
-
- RandomAccessInputView - Class in org.apache.flink.runtime.io.disk
-
- RandomAccessInputView(ArrayList<MemorySegment>, int) - Constructor for class org.apache.flink.runtime.io.disk.RandomAccessInputView
-
- RandomAccessInputView(ArrayList<MemorySegment>, int, int) - Constructor for class org.apache.flink.runtime.io.disk.RandomAccessInputView
-
- RandomAccessOutputView - Class in org.apache.flink.runtime.io.disk
-
- RandomAccessOutputView(MemorySegment[], int) - Constructor for class org.apache.flink.runtime.io.disk.RandomAccessOutputView
-
- RandomAccessOutputView(MemorySegment[], int, int) - Constructor for class org.apache.flink.runtime.io.disk.RandomAccessOutputView
-
- randomEmit(T) - Method in class org.apache.flink.runtime.io.network.api.writer.RecordWriter
-
This is used to send LatencyMarks to a random target channel.
- randomEmit(T) - Method in class org.apache.flink.streaming.runtime.io.StreamRecordWriter
-
- RandomGenerable<T extends org.apache.commons.math3.random.RandomGenerator> - Interface in org.apache.flink.graph.generator.random
-
A RandomGenerable provides deferred instantiation and initialization of a
RandomGenerator.
- RandomGenerableFactory<T extends org.apache.commons.math3.random.RandomGenerator> - Interface in org.apache.flink.graph.generator.random
-
A RandomGenerableFactory
returns a scale-free collection of sources
of pseudorandomness which can be used to perform repeatable parallel
computation regardless of parallelism.
- randomInvalidTransition(Random) - Method in enum org.apache.flink.streaming.examples.statemachine.dfa.State
-
Returns an event type that, if applied as a transition on this state, will result
in an illegal state transition.
- RandomSampler<T> - Class in org.apache.flink.api.java.sampling
-
A data sample is a set of data selected from a statistical population by a defined procedure.
- RandomSampler() - Constructor for class org.apache.flink.api.java.sampling.RandomSampler
-
- RandomSpout - Class in org.apache.flink.storm.split.operators
-
A Spout implementation that emits random numbers, optionally splitting them into odd/even streams.
- RandomSpout(boolean, long) - Constructor for class org.apache.flink.storm.split.operators.RandomSpout
-
- randomTransition(Random) - Method in enum org.apache.flink.streaming.examples.statemachine.dfa.State
-
Picks a random transition, based on the probabilities of the outgoing transitions
of this state.
- range(long, long) - Static method in class org.apache.flink.mesos.Utils
-
Construct a range value.
- RangeBoundaries<T> - Interface in org.apache.flink.api.common.distributions
-
RangeBoundaries is used to split the records into multiple ranges.
- RangeBoundaryBuilder<T> - Class in org.apache.flink.runtime.operators.udf
-
Build RangeBoundaries with input records.
- RangeBoundaryBuilder(TypeComparatorFactory<T>, int) - Constructor for class org.apache.flink.runtime.operators.udf.RangeBoundaryBuilder
-
- RangePartitionRewriter - Class in org.apache.flink.optimizer.traversals
-
- RangePartitionRewriter(OptimizedPlan) - Constructor for class org.apache.flink.optimizer.traversals.RangePartitionRewriter
-
- ranges(String, String, Protos.Value.Range...) - Static method in class org.apache.flink.mesos.Utils
-
Construct a range resource.
- rangeValues(Collection<Protos.Resource>) - Static method in class org.apache.flink.mesos.Utils
-
Gets a stream of values from a collection of range resources.
- rangeValues(Protos.Value.Range) - Static method in class org.apache.flink.mesos.Utils
-
Gets a stream of values from a range.
- RankAssigner(double) - Constructor for class org.apache.flink.examples.java.graph.PageRank.RankAssigner
-
- RankMessenger() - Constructor for class org.apache.flink.graph.examples.PageRank.RankMessenger
-
- RANKS - Static variable in class org.apache.flink.examples.java.relational.util.WebLogData
-
- RANKS - Static variable in class org.apache.flink.test.testdata.WebLogAnalysisData
-
- RANKS_AFTER_3_ITERATIONS - Static variable in class org.apache.flink.graph.examples.data.PageRankData
-
- RANKS_AFTER_3_ITERATIONS - Static variable in class org.apache.flink.test.testdata.PageRankData
-
- RANKS_AFTER_EPSILON_0_0001_CONVERGENCE - Static variable in class org.apache.flink.test.testdata.PageRankData
-
- rate - Variable in class org.apache.flink.runtime.metrics.dump.MetricDump.MeterDump
-
- RawJsonDeserializer - Class in org.apache.flink.runtime.rest.messages.json
-
Json deserializer which deserializes raw json.
- RawJsonDeserializer() - Constructor for class org.apache.flink.runtime.rest.messages.json.RawJsonDeserializer
-
- rawKeyedStateInputs() - Method in interface org.apache.flink.streaming.api.operators.StreamOperatorStateContext
-
Returns an iterable to obtain input streams for previously stored keyed state partitions that are assigned to
this operator.
- rawKeyedStateInputs(Iterator<StateObjectCollection<KeyedStateHandle>>) - Method in class org.apache.flink.streaming.api.operators.StreamTaskStateInitializerImpl
-
- rawOperatorStateInputs() - Method in interface org.apache.flink.streaming.api.operators.StreamOperatorStateContext
-
Returns an iterable to obtain input streams for previously stored operator state partitions that are assigned to
this stream operator.
- rawOperatorStateInputs(Iterator<StateObjectCollection<OperatorStateHandle>>) - Method in class org.apache.flink.streaming.api.operators.StreamTaskStateInitializerImpl
-
- reacceptRegisteredWorkers(Collection<ResourceID>) - Method in class org.apache.flink.mesos.runtime.clusterframework.MesosFlinkResourceManager
-
Accept the given registered workers into the internal state.
- reacceptRegisteredWorkers(Collection<ResourceID>) - Method in class org.apache.flink.runtime.clusterframework.FlinkResourceManager
-
This method is called when the resource manager starts after a failure and reconnects to
the leader JobManager, who still has some workers registered.
- reacceptRegisteredWorkers(Collection<ResourceID>) - Method in class org.apache.flink.runtime.clusterframework.standalone.StandaloneResourceManager
-
- reacceptRegisteredWorkers(Collection<ResourceID>) - Method in class org.apache.flink.yarn.YarnFlinkResourceManager
-
- reachedEnd() - Method in class org.apache.flink.addons.hbase.AbstractTableInputFormat
-
- reachedEnd() - Method in class org.apache.flink.api.common.io.BinaryInputFormat
-
- reachedEnd() - Method in class org.apache.flink.api.common.io.DelimitedInputFormat
-
Checks whether the current split is at its end.
- reachedEnd() - Method in interface org.apache.flink.api.common.io.InputFormat
-
Method used to check if the end of the input is reached.
- reachedEnd() - Method in class org.apache.flink.api.common.io.ReplicatingInputFormat
-
- reachedEnd() - Method in class org.apache.flink.api.java.hadoop.mapred.HadoopInputFormatBase
-
- reachedEnd() - Method in class org.apache.flink.api.java.hadoop.mapreduce.HadoopInputFormatBase
-
- reachedEnd() - Method in class org.apache.flink.api.java.io.CollectionInputFormat
-
- reachedEnd() - Method in class org.apache.flink.api.java.io.IteratorInputFormat
-
- reachedEnd() - Method in class org.apache.flink.api.java.io.jdbc.JDBCInputFormat
-
Checks whether all data has been read.
- reachedEnd() - Method in class org.apache.flink.api.java.io.ParallelIteratorInputFormat
-
- reachedEnd() - Method in class org.apache.flink.batch.connectors.cassandra.CassandraInputFormat
-
- reachedEnd() - Method in class org.apache.flink.batch.tests.DataSetAllroundTestProgram.Generator
-
- reachedEnd() - Method in class org.apache.flink.examples.java.distcp.FileCopyTaskInputFormat
-
- reachedEnd() - Method in class org.apache.flink.formats.avro.AvroInputFormat
-
- reachedEnd() - Method in class org.apache.flink.hcatalog.HCatInputFormatBase
-
- reachedEnd() - Method in class org.apache.flink.orc.OrcRowInputFormat
-
- reachedEnd() - Method in class org.apache.flink.storm.util.FiniteFileSpout
-
Can be called before nextTuple() any times including 0.
- reachedEnd() - Method in class org.apache.flink.storm.util.FiniteInMemorySpout
-
- reachedEnd() - Method in interface org.apache.flink.storm.util.FiniteSpout
-
When returns true, the spout has reached the end of the stream.
- reachedEnd() - Method in class org.apache.flink.storm.util.NullTerminatingSpout
-
- read() - Method in class org.apache.flink.api.common.io.BinaryInputFormat.BlockBasedInput
-
- read(byte[]) - Method in class org.apache.flink.api.common.io.BinaryInputFormat.BlockBasedInput
-
- read(byte[], int, int) - Method in class org.apache.flink.api.common.io.BinaryInputFormat.BlockBasedInput
-
- read(DataInputView) - Method in class org.apache.flink.api.common.io.BlockInfo
-
- read() - Method in class org.apache.flink.api.common.io.InputStreamFSInputWrapper
-
- read(byte[], int, int) - Method in class org.apache.flink.api.common.io.InputStreamFSInputWrapper
-
- read(byte[]) - Method in class org.apache.flink.api.common.io.InputStreamFSInputWrapper
-
- read(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.EnumSerializer.EnumSerializerConfigSnapshot
-
- read(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.GenericArraySerializerConfigSnapshot
-
- read(DataInputView) - Method in class org.apache.flink.api.common.typeutils.CompositeTypeSerializerConfigSnapshot
-
- read(DataInputView) - Method in class org.apache.flink.api.common.typeutils.GenericTypeSerializerConfigSnapshot
-
- read(DataInputView) - Method in class org.apache.flink.api.common.typeutils.ParameterlessTypeSerializerConfig
-
- read(DataInputView) - Method in class org.apache.flink.api.common.typeutils.TypeSerializerSerializationUtil.TypeSerializerSerializationProxy
-
- read(ObjectInputStream) - Method in class org.apache.flink.api.java.hadoop.common.HadoopInputFormatCommonBase
-
- read(ObjectInputStream) - Method in class org.apache.flink.api.java.hadoop.common.HadoopOutputFormatCommonBase
-
- read(DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.AvroSerializer.AvroSerializerConfigSnapshot
-
Deprecated.
- read() - Method in class org.apache.flink.api.java.typeutils.runtime.DataInputViewStream
-
- read(byte[], int, int) - Method in class org.apache.flink.api.java.typeutils.runtime.DataInputViewStream
-
- read(Kryo, Input, Class) - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.JavaSerializer
-
- read(Kryo, Input, Class<T>) - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.Serializers.DummyAvroKryoSerializerClass
-
- read(Kryo, Input, Class) - Method in class org.apache.flink.api.java.typeutils.runtime.KryoRegistrationSerializerConfigSnapshot.DummyKryoSerializerClass
-
- read(DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.KryoRegistrationSerializerConfigSnapshot
-
- read() - Method in class org.apache.flink.api.java.typeutils.runtime.NoFetchingInput
-
- read(byte[], int, int) - Method in class org.apache.flink.api.java.typeutils.runtime.NoFetchingInput
-
- read(DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer.PojoSerializerConfigSnapshot
-
- read(DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializerConfigSnapshot
-
- read(DataInputView) - Method in class org.apache.flink.configuration.Configuration
-
- read(DataInputView) - Method in class org.apache.flink.configuration.DelegatingConfiguration
-
- read() - Method in class org.apache.flink.core.fs.AbstractMultiFSDataInputStream
-
- read() - Method in class org.apache.flink.core.fs.FSDataInputStreamWrapper
-
- read(byte[]) - Method in class org.apache.flink.core.fs.FSDataInputStreamWrapper
-
- read(byte[], int, int) - Method in class org.apache.flink.core.fs.FSDataInputStreamWrapper
-
- read() - Method in class org.apache.flink.core.fs.local.LocalDataInputStream
-
- read(byte[], int, int) - Method in class org.apache.flink.core.fs.local.LocalDataInputStream
-
- read(DataInputView) - Method in class org.apache.flink.core.fs.Path
-
- read(DataInputView) - Method in interface org.apache.flink.core.io.IOReadableWritable
-
Reads the object's internal data from the given data input view.
- read(DataInputView, boolean) - Method in class org.apache.flink.core.io.PostVersionedIOReadableWritable
-
Read from the provided
in
.
- read(InputStream) - Method in class org.apache.flink.core.io.PostVersionedIOReadableWritable
-
- read(DataInputView) - Method in class 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) - Method in class org.apache.flink.core.io.VersionedIOReadableWritable
-
- read() - Method in class org.apache.flink.core.memory.ByteArrayInputStreamWithPos
-
- read(byte[], int, int) - Method in class org.apache.flink.core.memory.ByteArrayInputStreamWithPos
-
- read(byte[], int, int) - Method in class org.apache.flink.core.memory.DataInputDeserializer
-
- read(byte[]) - Method in class org.apache.flink.core.memory.DataInputDeserializer
-
- read(byte[], int, int) - Method in interface org.apache.flink.core.memory.DataInputView
-
Reads up to len
bytes of memory and stores it into b
starting at offset off
.
- read(byte[]) - Method in interface org.apache.flink.core.memory.DataInputView
-
Tries to fill the given byte array b
.
- read(DataInputView) - Method in class org.apache.flink.formats.avro.typeutils.AvroSerializer.AvroSchemaSerializerConfigSnapshot
-
- read(DataInputView) - Method in class org.apache.flink.formats.avro.typeutils.AvroSerializer.AvroSerializerConfigSnapshot
-
Deprecated.
- read(Kryo, Input, Class<Schema>) - Method in class org.apache.flink.formats.avro.utils.AvroKryoSerializerUtils.AvroSchemaSerializer
-
- read(byte[], int, int) - Method in class org.apache.flink.formats.avro.utils.FSDataInputStreamWrapper
-
- read(DataInputView) - Method in class org.apache.flink.graph.types.valuearray.ByteValueArray
-
- read(DataInputView) - Method in class org.apache.flink.graph.types.valuearray.CharValueArray
-
- read(DataInputView) - Method in class org.apache.flink.graph.types.valuearray.DoubleValueArray
-
- read(DataInputView) - Method in class org.apache.flink.graph.types.valuearray.FloatValueArray
-
- read(DataInputView) - Method in class org.apache.flink.graph.types.valuearray.IntValueArray
-
- read(DataInputView) - Method in class org.apache.flink.graph.types.valuearray.LongValueArray
-
- read(DataInputView) - Method in class org.apache.flink.graph.types.valuearray.NullValueArray
-
- read(DataInputView) - Method in class org.apache.flink.graph.types.valuearray.ShortValueArray
-
- read(DataInputView) - Method in class org.apache.flink.graph.types.valuearray.StringValueArray
-
- read() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopDataInputStream
-
- read(byte[], int, int) - Method in class org.apache.flink.runtime.fs.hdfs.HadoopDataInputStream
-
- read() - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBufferFileSegmentReader
-
- read() - Method in interface org.apache.flink.runtime.io.disk.iomanager.BufferFileSegmentReader
-
- read(DataInputView) - Method in class org.apache.flink.runtime.io.network.api.CancelCheckpointMarker
-
- read(DataInputView) - Method in class org.apache.flink.runtime.io.network.api.CheckpointBarrier
-
- read(DataInputView) - Method in class org.apache.flink.runtime.io.network.api.EndOfPartitionEvent
-
- read(DataInputView) - Method in class org.apache.flink.runtime.io.network.api.EndOfSuperstepEvent
-
- read(DataInputView) - Method in class org.apache.flink.runtime.iterative.event.IterationEventWithAggregators
-
- read(DataInputView) - Method in class org.apache.flink.runtime.iterative.event.TerminationEvent
-
- read(DataInputView) - Method in class org.apache.flink.runtime.iterative.event.WorkerDoneEvent
-
- read(byte[]) - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
-
- read(byte[], int, int) - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
-
- read(DataInputView) - Method in class org.apache.flink.runtime.plugable.NonReusingDeserializationDelegate
-
- read(DataInputView) - Method in class org.apache.flink.runtime.plugable.ReusingDeserializationDelegate
-
- read(DataInputView) - Method in class org.apache.flink.runtime.plugable.SerializationDelegate
-
- read() - Method in class org.apache.flink.runtime.state.BoundedInputStream
-
- read(byte[]) - Method in class org.apache.flink.runtime.state.BoundedInputStream
-
- read(byte[], int, int) - Method in class org.apache.flink.runtime.state.BoundedInputStream
-
- read(DataInputView) - Method in class org.apache.flink.runtime.state.KeyedBackendSerializationProxy
-
- read(DataInputView) - Method in class org.apache.flink.runtime.state.OperatorBackendSerializationProxy
-
- read() - Method in class org.apache.flink.runtime.util.ForwardingInputStream
-
- read(byte[]) - Method in class org.apache.flink.runtime.util.ForwardingInputStream
-
- read(byte[], int, int) - Method in class org.apache.flink.runtime.util.ForwardingInputStream
-
- read(DataInputView, boolean) - Method in class org.apache.flink.streaming.api.operators.InternalTimerServiceSerializationProxy
-
- read(Kryo, Input, Class<PyBoolean>) - Method in class org.apache.flink.streaming.python.util.serialization.PyBooleanSerializer
-
- read(Kryo, Input, Class<PyFloat>) - Method in class org.apache.flink.streaming.python.util.serialization.PyFloatSerializer
-
- read(Kryo, Input, Class<PyInteger>) - Method in class org.apache.flink.streaming.python.util.serialization.PyIntegerSerializer
-
- read(Kryo, Input, Class<PyLong>) - Method in class org.apache.flink.streaming.python.util.serialization.PyLongSerializer
-
- read(Kryo, Input, Class<PyObject>) - Method in class org.apache.flink.streaming.python.util.serialization.PyObjectSerializer
-
- read(Kryo, Input, Class<PyString>) - Method in class org.apache.flink.streaming.python.util.serialization.PyStringSerializer
-
- read(DataInputView) - Method in class org.apache.flink.types.BooleanValue
-
- read(DataInputView) - Method in class org.apache.flink.types.ByteValue
-
- read(DataInputView) - Method in class org.apache.flink.types.CharValue
-
- read(DataInputView) - Method in class org.apache.flink.types.DoubleValue
-
- read(DataInputView) - Method in class org.apache.flink.types.FloatValue
-
- read(DataInputView) - Method in class org.apache.flink.types.IntValue
-
- read(DataInputView) - Method in class org.apache.flink.types.ListValue
-
- read(DataInputView) - Method in class org.apache.flink.types.LongValue
-
- read(DataInputView) - Method in class org.apache.flink.types.MapValue
-
- read(DataInputView) - Method in class org.apache.flink.types.NullValue
-
- read(DataInputView) - Method in class org.apache.flink.types.Record
-
- read(DataInputView) - Method in class org.apache.flink.types.ShortValue
-
- read(DataInputView) - Method in class org.apache.flink.types.StringValue
-
- read_text_file(String) - Method in class org.apache.flink.streaming.python.api.environment.PythonStreamExecutionEnvironment
-
- READ_WHOLE_SPLIT_FLAG - Static variable in class org.apache.flink.api.common.io.FileInputFormat
-
The splitLength is set to -1L for reading the whole split.
- readableBytes() - Method in interface org.apache.flink.runtime.io.network.buffer.Buffer
-
- readAllResultLines(List<String>, String) - Static method in class org.apache.flink.test.util.TestBaseUtils
-
- readAllResultLines(List<String>, String, String[]) - Static method in class org.apache.flink.test.util.TestBaseUtils
-
- readAllResultLines(List<String>, String, String[], boolean) - Static method in class org.apache.flink.test.util.TestBaseUtils
-
- readAndSetBroadcastInput(int, String, DistributedRuntimeUDFContext, int) - Method in class org.apache.flink.runtime.operators.BatchTask
-
- readArrayStart() - Method in class org.apache.flink.formats.avro.utils.DataInputDecoder
-
- readBigDecimal(DataInputView) - Static method in class org.apache.flink.api.common.typeutils.base.BigDecSerializer
-
- readBigInteger(DataInputView) - Static method in class org.apache.flink.api.common.typeutils.base.BigIntSerializer
-
- readBlock(MemorySegment) - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBlockReader
-
Issues a read request, which will asynchronously fill the given segment with the next block in the
underlying file channel.
- readBlock(T) - Method in interface org.apache.flink.runtime.io.disk.iomanager.BlockChannelReader
-
Issues a read request, which will fill the given segment with the next block in the
underlying file channel.
- readBoolean() - Method in class org.apache.flink.core.memory.DataInputDeserializer
-
- readBoolean() - Method in class org.apache.flink.formats.avro.utils.DataInputDecoder
-
- readBoolean() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
-
- readBroadcastStateMetaInfo(DataInputView) - Method in interface org.apache.flink.runtime.state.OperatorBackendStateMetaInfoSnapshotReaderWriters.BroadcastStateMetaInfoReader
-
- readBroadcastStateMetaInfo(DataInputView) - Method in class org.apache.flink.runtime.state.OperatorBackendStateMetaInfoSnapshotReaderWriters.BroadcastStateMetaInfoReaderV3
-
- readBufferFromFileChannel(Buffer) - Method in class org.apache.flink.runtime.io.disk.iomanager.BufferFileChannelReader
-
Reads data from the object's file channel into the given buffer.
- readByte() - Method in class org.apache.flink.core.memory.DataInputDeserializer
-
- readByte() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
-
- readBytes(byte[], int, int) - Method in class org.apache.flink.api.java.typeutils.runtime.NoFetchingInput
-
- readBytes(ByteBuffer) - Method in class org.apache.flink.formats.avro.utils.DataInputDecoder
-
- readBytes(int) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
-
- readChar() - Method in class org.apache.flink.core.memory.DataInputDeserializer
-
- readChar() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
-
- readChunk(ChannelHandlerContext) - Method in class org.apache.flink.queryablestate.network.ChunkedByteBuf
-
- readClassDescriptor() - Method in class org.apache.flink.util.InstantiationUtil.FailureTolerantObjectInputStream
-
- readCsvFile(String) - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
Creates a CSV reader to read a comma separated value (CSV) file.
- readDouble() - Method in class org.apache.flink.core.memory.DataInputDeserializer
-
- readDouble() - Method in class org.apache.flink.formats.avro.utils.DataInputDecoder
-
- readDouble() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
-
- readDualForwardAnnotations(Class<?>) - Static method in class org.apache.flink.api.java.functions.FunctionAnnotation
-
Reads the annotations of a user defined function with two inputs and returns semantic properties according to the forwarded fields annotated.
- readEnum() - Method in class org.apache.flink.formats.avro.utils.DataInputDecoder
-
- reader - Variable in class org.apache.flink.runtime.io.disk.iomanager.ChannelReaderInputView
-
- Reader<T extends IOReadableWritable> - Interface in org.apache.flink.runtime.io.network.api.reader
-
A record-oriented reader for immutable record types.
- reader - Variable in class org.apache.flink.storm.util.FileSpout
-
- ReaderBase - Interface in org.apache.flink.runtime.io.network.api.reader
-
The basic API for every reader.
- ReaderIterator<T> - Class in org.apache.flink.runtime.operators.util
-
- ReaderIterator(MutableReader<DeserializationDelegate<T>>, TypeSerializer<T>) - Constructor for class org.apache.flink.runtime.operators.util.ReaderIterator
-
Creates a new iterator, wrapping the given reader.
- readFields(DataInput) - Method in class org.apache.hadoop.conf.Configuration
-
- readFile(FileInputFormat<X>, String) - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
- readFile(FileInputFormat<OUT>, String) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Reads the contents of the user-specified
filePath
based on the given
FileInputFormat
.
- readFile(FileInputFormat<OUT>, String, FileProcessingMode, long, FilePathFilter) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- readFile(FileInputFormat<OUT>, String, FileProcessingMode, long) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Reads the contents of the user-specified
filePath
based on the given
FileInputFormat
.
- readFile(FileInputFormat<OUT>, String, FileProcessingMode, long, TypeInformation<OUT>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Reads the contents of the user-specified
filePath
based on the given
FileInputFormat
.
- readFile(File, String) - Static method in class org.apache.flink.util.FileUtils
-
- readFileInfoFromConfig(Configuration) - Static method in class org.apache.flink.api.common.cache.DistributedCache
-
- readFileOfPrimitives(String, Class<X>) - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
Creates a
DataSet
that represents the primitive type produced by reading the given file line wise.
- readFileOfPrimitives(String, String, Class<X>) - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
Creates a
DataSet
that represents the primitive type produced by reading the given file in delimited way.
- readFileStream(String, long, FileMonitoringFunction.WatchType) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- readFileUtf8(File) - Static method in class org.apache.flink.util.FileUtils
-
- readFixed(byte[], int, int) - Method in class org.apache.flink.formats.avro.utils.DataInputDecoder
-
- readFloat() - Method in class org.apache.flink.core.memory.DataInputDeserializer
-
- readFloat() - Method in class org.apache.flink.formats.avro.utils.DataInputDecoder
-
- readFloat() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
-
- readFully(byte[]) - Method in class org.apache.flink.core.memory.DataInputDeserializer
-
- readFully(byte[], int, int) - Method in class org.apache.flink.core.memory.DataInputDeserializer
-
- readFully(byte[]) - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
-
- readFully(byte[], int, int) - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
-
- readFully(InputStream, byte[], int, int) - Static method in class org.apache.flink.util.IOUtils
-
Reads len bytes in a loop.
- readHadoopFile(FileInputFormat<K, V>, Class<K>, Class<V>, String, JobConf) - Static method in class org.apache.flink.hadoopcompatibility.HadoopInputs
-
Creates a Flink
InputFormat
that wraps the given Hadoop
FileInputFormat
.
- readHadoopFile(FileInputFormat<K, V>, Class<K>, Class<V>, String) - Static method in class org.apache.flink.hadoopcompatibility.HadoopInputs
-
Creates a Flink
InputFormat
that wraps the given Hadoop
FileInputFormat
.
- readHadoopFile(FileInputFormat<K, V>, Class<K>, Class<V>, String, Job) - Static method in class org.apache.flink.hadoopcompatibility.HadoopInputs
-
Creates a Flink
InputFormat
that wraps the given Hadoop
FileInputFormat
.
- readHadoopFile(FileInputFormat<K, V>, Class<K>, Class<V>, String) - Static method in class org.apache.flink.hadoopcompatibility.HadoopInputs
-
Creates a Flink
InputFormat
that wraps the given Hadoop
FileInputFormat
.
- readIndex() - Method in class org.apache.flink.formats.avro.utils.DataInputDecoder
-
- ReadingThread(ExceptionHandler<IOException>, MutableObjectIterator<E>, UnilateralSortMerger.CircularQueues<E>, LargeRecordHandler<E>, E, AbstractInvokable, long) - Constructor for class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.ReadingThread
-
Creates a new reading thread.
- readInt() - Method in class org.apache.flink.core.memory.DataInputDeserializer
-
- readInt() - Method in class org.apache.flink.formats.avro.utils.DataInputDecoder
-
- readInt() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
-
- readInto(Buffer) - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBufferFileReader
-
- readInto(Buffer) - Method in interface org.apache.flink.runtime.io.disk.iomanager.BufferFileReader
-
- readInto(Buffer) - Method in class org.apache.flink.runtime.io.disk.iomanager.SynchronousBufferFileReader
-
- readIntoAndCopyNullMask(int, DataInputView, DataOutputView, boolean[]) - Static method in class org.apache.flink.api.java.typeutils.runtime.NullMaskUtils
-
- readIntoNullMask(int, DataInputView, boolean[]) - Static method in class org.apache.flink.api.java.typeutils.runtime.NullMaskUtils
-
- readKey(TypeSerializer<K>, ByteArrayInputStreamWithPos, DataInputView, boolean) - Static method in class org.apache.flink.contrib.streaming.state.RocksDBKeySerializationUtils
-
- readKeyGroup(int, DataInputView) - Static method in class org.apache.flink.contrib.streaming.state.RocksDBKeySerializationUtils
-
- readLine() - Method in class org.apache.flink.api.common.io.DelimitedInputFormat
-
- readLine() - Method in class org.apache.flink.core.memory.DataInputDeserializer
-
- readLine() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
-
- readLong() - Method in class org.apache.flink.core.memory.DataInputDeserializer
-
- readLong() - Method in class org.apache.flink.formats.avro.utils.DataInputDecoder
-
- readLong() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
-
- readMapStart() - Method in class org.apache.flink.formats.avro.utils.DataInputDecoder
-
- readNamespace(TypeSerializer<N>, ByteArrayInputStreamWithPos, DataInputView, boolean) - Static method in class org.apache.flink.contrib.streaming.state.RocksDBKeySerializationUtils
-
- readNull() - Method in class org.apache.flink.formats.avro.utils.DataInputDecoder
-
- readNullableString(DataInputView) - Static method in class org.apache.flink.util.StringUtils
-
Reads a String from the given input.
- readObjectFromConfig(Configuration, String, ClassLoader) - Static method in class org.apache.flink.util.InstantiationUtil
-
- ReadOnlyBroadcastState<K,V> - Interface in org.apache.flink.api.common.state
-
- ReadOnlyContext() - Constructor for class org.apache.flink.streaming.api.functions.co.BaseBroadcastProcessFunction.ReadOnlyContext
-
- ReadOnlyContext() - Constructor for class org.apache.flink.streaming.api.functions.co.BroadcastProcessFunction.ReadOnlyContext
-
- ReadOnlyContext() - Constructor for class org.apache.flink.streaming.api.functions.co.KeyedBroadcastProcessFunction.ReadOnlyContext
-
- readOnlySlice() - Method in interface org.apache.flink.runtime.io.network.buffer.Buffer
-
Returns a read-only slice of this buffer's readable bytes, i.e.
- readOnlySlice(int, int) - Method in interface org.apache.flink.runtime.io.network.buffer.Buffer
-
Returns a read-only slice of this buffer.
- readOnlySlice() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
-
- readOnlySlice(int, int) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
-
- readOnlySlice() - Method in class org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
-
- readOnlySlice(int, int) - Method in class org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
-
- ReadOnlySlicedNetworkBuffer - Class in org.apache.flink.runtime.io.network.buffer
-
Minimal best-effort read-only sliced
Buffer
implementation wrapping a
NetworkBuffer
's sub-region based on
io.netty.buffer.SlicedByteBuf and
io.netty.buffer.ReadOnlyByteBuf.
- readOperatorStateMetaInfo(DataInputView) - Method in interface org.apache.flink.runtime.state.OperatorBackendStateMetaInfoSnapshotReaderWriters.OperatorBackendStateMetaInfoReader
-
- readOperatorStateMetaInfo(DataInputView) - Method in class org.apache.flink.runtime.state.OperatorBackendStateMetaInfoSnapshotReaderWriters.OperatorBackendStateMetaInfoReaderV1
-
- readOperatorStateMetaInfo(DataInputView) - Method in class org.apache.flink.runtime.state.OperatorBackendStateMetaInfoSnapshotReaderWriters.OperatorBackendStateMetaInfoReaderV2
-
- readParametersFromConfig(Configuration, ClassLoader) - Method in interface org.apache.flink.api.common.typeutils.TypeComparatorFactory
-
- readParametersFromConfig(Configuration, ClassLoader) - Method in interface org.apache.flink.api.common.typeutils.TypeSerializerFactory
-
- readParametersFromConfig(Configuration, ClassLoader) - Method in class org.apache.flink.api.java.typeutils.runtime.RuntimeComparatorFactory
-
- readParametersFromConfig(Configuration, ClassLoader) - Method in class org.apache.flink.api.java.typeutils.runtime.RuntimeSerializerFactory
-
- readPhase - Variable in class org.apache.flink.runtime.operators.resettable.NonReusingBlockResettableIterator
-
- readRecord(OT, byte[], int, int) - Method in class org.apache.flink.api.common.io.DelimitedInputFormat
-
This function parses the given byte array which represents a serialized record.
- readRecord(OUT, byte[], int, int) - Method in class org.apache.flink.api.java.io.CsvInputFormat
-
- readRecord(OT, byte[], int, int) - Method in class org.apache.flink.api.java.io.PrimitiveInputFormat
-
- readRecord(String, byte[], int, int) - Method in class org.apache.flink.api.java.io.TextInputFormat
-
- readRecord(StringValue, byte[], int, int) - Method in class org.apache.flink.api.java.io.TextValueInputFormat
-
- readRecordAt(long, T) - Method in class org.apache.flink.runtime.operators.hash.InMemoryPartition
-
- readRecordAt(long) - Method in class org.apache.flink.runtime.operators.hash.InMemoryPartition
-
- readResolve() - Method in class org.apache.flink.runtime.messages.Acknowledge
-
Read resolve to preserve the singleton object property.
- readResolve() - Method in class org.apache.flink.runtime.state.CheckpointStorageLocationReference
-
readResolve() preserves the singleton property of the default value.
- readSequenceFile(Class<K>, Class<V>, String) - Static method in class org.apache.flink.hadoopcompatibility.HadoopInputs
-
Creates a Flink
InputFormat
to read a Hadoop sequence file for the given key and value classes.
- readSerializerConfigSnapshot(DataInputView, ClassLoader) - Static method in class org.apache.flink.api.common.typeutils.TypeSerializerSerializationUtil
-
- readSerializerConfigSnapshots(DataInputView, ClassLoader) - Static method in class org.apache.flink.api.common.typeutils.TypeSerializerSerializationUtil
-
- readSerializersAndConfigsWithResilience(DataInputView, ClassLoader) - Static method in class org.apache.flink.api.common.typeutils.TypeSerializerSerializationUtil
-
- readShort() - Method in class org.apache.flink.core.memory.DataInputDeserializer
-
- readShort() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
-
- readSingleForwardAnnotations(Class<?>) - Static method in class org.apache.flink.api.java.functions.FunctionAnnotation
-
Reads the annotations of a user defined function with one input and returns semantic properties according to the forwarded fields annotated.
- readStateMetaInfo(DataInputView) - Method in interface org.apache.flink.runtime.state.KeyedBackendStateMetaInfoSnapshotReaderWriters.KeyedBackendStateMetaInfoReader
-
- readString(Utf8) - Method in class org.apache.flink.formats.avro.utils.DataInputDecoder
-
- readString() - Method in class org.apache.flink.formats.avro.utils.DataInputDecoder
-
- readString(DataInput) - Static method in class org.apache.flink.types.StringValue
-
- readString(DataInputView) - Static method in class org.apache.flink.util.StringUtils
-
Reads a non-null String from the given input.
- readStubAnnotations() - Method in class org.apache.flink.optimizer.dag.AbstractPartialSolutionNode
-
- readStubAnnotations() - Method in class org.apache.flink.optimizer.dag.BinaryUnionNode
-
- readStubAnnotations() - Method in class org.apache.flink.optimizer.dag.BulkIterationNode
-
- readStubAnnotations() - Method in class org.apache.flink.optimizer.dag.OptimizerNode
-
Reads all stub annotations, i.e.
- readStubAnnotations() - Method in class org.apache.flink.optimizer.dag.WorksetIterationNode
-
- readTextFile(String) - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
Creates a
DataSet
that represents the Strings produced by reading the given file line wise.
- readTextFile(String, String) - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
Creates a
DataSet
that represents the Strings produced by reading the given file line wise.
- readTextFile(String) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Reads the given file line-by-line and creates a data stream that contains a string with the
contents of each such line.
- readTextFile(String, String) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Reads the given file line-by-line and creates a data stream that contains a string with the
contents of each such line.
- readTextFileWithValue(String) - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
Creates a
DataSet
that represents the Strings produced by reading the given file line wise.
- readTextFileWithValue(String, String, boolean) - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
Creates a
DataSet
that represents the Strings produced by reading the given file line wise.
- readTimersSnapshot(DataInputView) - Method in interface org.apache.flink.streaming.api.operators.InternalTimersSnapshotReaderWriters.InternalTimersSnapshotReader
-
Reads a timers snapshot from the provided input view.
- readUniqueFieldsAnnotation() - Method in class org.apache.flink.optimizer.dag.OptimizerNode
-
- readUnsignedByte() - Method in class org.apache.flink.core.memory.DataInputDeserializer
-
- readUnsignedByte() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
-
- readUnsignedShort() - Method in class org.apache.flink.core.memory.DataInputDeserializer
-
- readUnsignedShort() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
-
- readUTF() - Method in class org.apache.flink.core.memory.DataInputDeserializer
-
- readUTF() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
-
- readVarLongCount(DataInput) - Static method in class org.apache.flink.formats.avro.utils.DataInputDecoder
-
- readWithKeyDenormalization(T, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.array.PrimitiveArrayComparator
-
- readWithKeyDenormalization(T, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.BasicTypeComparator
-
- readWithKeyDenormalization(BooleanValue, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueComparator
-
- readWithKeyDenormalization(ByteValue, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.ByteValueComparator
-
- readWithKeyDenormalization(CharValue, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.CharValueComparator
-
- readWithKeyDenormalization(DoubleValue, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueComparator
-
- readWithKeyDenormalization(FloatValue, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.FloatValueComparator
-
- readWithKeyDenormalization(IntValue, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.IntValueComparator
-
- readWithKeyDenormalization(LongValue, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.LongValueComparator
-
- readWithKeyDenormalization(NullValue, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.NullValueComparator
-
- readWithKeyDenormalization(ShortValue, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.ShortValueComparator
-
- readWithKeyDenormalization(StringValue, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.StringValueComparator
-
- readWithKeyDenormalization(T, DataInputView) - Method in class org.apache.flink.api.common.typeutils.TypeComparator
-
Reads the record back while de-normalizing the key fields.
- readWithKeyDenormalization(T, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueComparator
-
- readWithKeyDenormalization(T, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.GenericTypeComparator
-
- readWithKeyDenormalization(T, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.NullAwareComparator
-
- readWithKeyDenormalization(T, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoComparator
-
- readWithKeyDenormalization(Row, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.RowComparator
-
- readWithKeyDenormalization(T, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
-
- readWithKeyDenormalization(T, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.ValueComparator
-
- readWithKeyDenormalization(T, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.WritableComparator
-
- readWithKeyDenormalization(ByteValueArray, DataInputView) - Method in class org.apache.flink.graph.types.valuearray.ByteValueArrayComparator
-
- readWithKeyDenormalization(CharValueArray, DataInputView) - Method in class org.apache.flink.graph.types.valuearray.CharValueArrayComparator
-
- readWithKeyDenormalization(DoubleValueArray, DataInputView) - Method in class org.apache.flink.graph.types.valuearray.DoubleValueArrayComparator
-
- readWithKeyDenormalization(FloatValueArray, DataInputView) - Method in class org.apache.flink.graph.types.valuearray.FloatValueArrayComparator
-
- readWithKeyDenormalization(IntValueArray, DataInputView) - Method in class org.apache.flink.graph.types.valuearray.IntValueArrayComparator
-
- readWithKeyDenormalization(LongValueArray, DataInputView) - Method in class org.apache.flink.graph.types.valuearray.LongValueArrayComparator
-
- readWithKeyDenormalization(NullValueArray, DataInputView) - Method in class org.apache.flink.graph.types.valuearray.NullValueArrayComparator
-
- readWithKeyDenormalization(ShortValueArray, DataInputView) - Method in class org.apache.flink.graph.types.valuearray.ShortValueArrayComparator
-
- readWithKeyDenormalization(StringValueArray, DataInputView) - Method in class org.apache.flink.graph.types.valuearray.StringValueArrayComparator
-
- readWriteLock - Variable in class org.apache.flink.runtime.blob.AbstractBlobCache
-
Lock guarding concurrent file accesses.
- rebalance() - Method in class org.apache.flink.api.java.DataSet
-
Enforces a re-balancing of the DataSet, i.e., the DataSet is evenly distributed over all parallel instances of the
following task.
- rebalance(String, RebalanceOptions) - Method in class org.apache.flink.storm.api.FlinkLocalCluster
-
- rebalance() - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Sets the partitioning of the
DataStream
so that the output elements
are distributed evenly to instances of the next operation in a round-robin
fashion.
- RebalancePartitioner<T> - Class in org.apache.flink.streaming.runtime.partitioner
-
Partitioner that distributes the data equally by cycling through the output
channels.
- RebalancePartitioner() - Constructor for class org.apache.flink.streaming.runtime.partitioner.RebalancePartitioner
-
- receiveAcknowledgeMessage(AcknowledgeCheckpoint) - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
Receives an AcknowledgeCheckpoint message and returns whether the
message was associated with a pending checkpoint.
- receiveDeclineMessage(DeclineCheckpoint) - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
- receiveHeartbeat(ResourceID, I) - Method in class org.apache.flink.runtime.heartbeat.HeartbeatManagerImpl
-
- receiveHeartbeat(ResourceID, I) - Method in interface org.apache.flink.runtime.heartbeat.HeartbeatTarget
-
Sends a heartbeat response to the target.
- receiver - Variable in class org.apache.flink.python.api.streaming.data.PythonStreamer
-
- receiver - Variable in class org.apache.flink.python.api.streaming.plan.PythonPlanStreamer
-
- reconcile(ReconciliationCoordinator.Reconcile) - Method in class org.apache.flink.mesos.runtime.clusterframework.MesosResourceManager
-
Handles a reconciliation request from a task monitor.
- reconcile(ReconciliationCoordinator.Reconcile) - Method in interface org.apache.flink.mesos.runtime.clusterframework.MesosResourceManagerActions
-
Trigger reconciliation with the Mesos master.
- reconnect(JobID) - Method in class org.apache.flink.runtime.taskexecutor.JobLeaderService
-
Triggers reconnection to the last known leader of the given job.
- ReconnectResourceManager - Class in org.apache.flink.runtime.clusterframework.messages
-
This message signals that the ResourceManager should reconnect to the JobManager.
- ReconnectResourceManager(ActorRef, long) - Constructor for class org.apache.flink.runtime.clusterframework.messages.ReconnectResourceManager
-
- Record - Class in org.apache.flink.types
-
The Record represents a multi-valued data record.
- Record() - Constructor for class org.apache.flink.types.Record
-
Required nullary constructor for instantiation by serialization logic.
- Record(Value) - Constructor for class org.apache.flink.types.Record
-
Creates a new record containing only a single field, which is the given value.
- Record(Value, Value) - Constructor for class org.apache.flink.types.Record
-
Creates a new record containing exactly two fields, which are the given values.
- Record(int) - Constructor for class org.apache.flink.types.Record
-
Creates a new record, containing the given number of fields.
- RECORD_DELIMITER - Static variable in class org.apache.flink.api.common.io.DelimitedInputFormat
-
The configuration key to set the record delimiter.
- RecordDeserializer<T extends IOReadableWritable> - Interface in org.apache.flink.runtime.io.network.api.serialization
-
Interface for turning sequences of memory segments into records.
- RecordDeserializer.DeserializationResult - Enum in org.apache.flink.runtime.io.network.api.serialization
-
Status of the deserialization result.
- recordReader - Variable in class org.apache.flink.api.java.hadoop.mapreduce.HadoopInputFormatBase
-
- RecordReader<T extends IOReadableWritable> - Class in org.apache.flink.runtime.io.network.api.reader
-
Record oriented reader for immutable types.
- RecordReader(InputGate, Class<T>, String[]) - Constructor for class org.apache.flink.runtime.io.network.api.reader.RecordReader
-
Creates a new RecordReader that de-serializes records from the given input gate and
can spill partial records to disk, if they grow large.
- RecordSerializer<T extends IOReadableWritable> - Interface in org.apache.flink.runtime.io.network.api.serialization
-
Interface for turning records into sequences of memory segments.
- RecordSerializer.SerializationResult - Enum in org.apache.flink.runtime.io.network.api.serialization
-
Status of the serialization result.
- recordSize() - Method in class org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
-
- recordSize() - Method in interface org.apache.flink.runtime.operators.sort.IndexedSortable
-
Gets the size of each record, the number of bytes separating the head
of successive records.
- recordSize() - Method in class org.apache.flink.runtime.operators.sort.NormalizedKeySorter
-
- recordsPerSegment() - Method in class org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
-
- recordsPerSegment() - Method in interface org.apache.flink.runtime.operators.sort.IndexedSortable
-
Gets the number of elements in each memory segment.
- recordsPerSegment() - Method in class org.apache.flink.runtime.operators.sort.NormalizedKeySorter
-
- recordWriter - Variable in class org.apache.flink.api.java.hadoop.mapred.HadoopOutputFormatBase
-
- recordWriter - Variable in class org.apache.flink.api.java.hadoop.mapreduce.HadoopOutputFormatBase
-
- RecordWriter<T extends IOReadableWritable> - Class in org.apache.flink.runtime.io.network.api.writer
-
A record-oriented runtime result writer.
- RecordWriter(ResultPartitionWriter) - Constructor for class org.apache.flink.runtime.io.network.api.writer.RecordWriter
-
- RecordWriter(ResultPartitionWriter, ChannelSelector<T>) - Constructor for class org.apache.flink.runtime.io.network.api.writer.RecordWriter
-
- RecordWriter(ResultPartitionWriter, ChannelSelector<T>, boolean) - Constructor for class org.apache.flink.runtime.io.network.api.writer.RecordWriter
-
- RecordWriterOutput<OUT> - Class in org.apache.flink.streaming.runtime.io
-
- RecordWriterOutput(StreamRecordWriter<SerializationDelegate<StreamRecord<OUT>>>, TypeSerializer<OUT>, OutputTag, StreamStatusProvider) - Constructor for class org.apache.flink.streaming.runtime.io.RecordWriterOutput
-
- recover() - Method in interface org.apache.flink.runtime.checkpoint.CompletedCheckpointStore
-
- recover() - Method in class org.apache.flink.runtime.checkpoint.StandaloneCompletedCheckpointStore
-
- recover() - Method in class org.apache.flink.runtime.checkpoint.ZooKeeperCompletedCheckpointStore
-
Gets the latest checkpoint from ZooKeeper and removes all others.
- recoverAndAbort(TXN) - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
-
Abort a transaction that was rejected by a coordinator after a failure.
- recoverAndAbort(FlinkKafkaProducer011.KafkaTransactionState) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer011
-
- recoverAndCommit(TXN) - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
-
Invoked on recovered transactions after a failure.
- recoverAndCommit(FlinkKafkaProducer011.KafkaTransactionState) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer011
-
- recoverJobGraph(JobID) - Method in class org.apache.flink.runtime.dispatcher.SingleJobSubmittedJobGraphStore
-
- recoverJobGraph(JobID) - Method in class org.apache.flink.runtime.jobmanager.StandaloneSubmittedJobGraphStore
-
- recoverJobGraph(JobID) - Method in interface org.apache.flink.runtime.jobmanager.SubmittedJobGraphStore
-
- recoverJobGraph(JobID) - Method in class org.apache.flink.runtime.jobmanager.ZooKeeperSubmittedJobGraphStore
-
- recoverWorkers() - Method in interface org.apache.flink.mesos.runtime.clusterframework.store.MesosWorkerStore
-
Recover the stored workers.
- recoverWorkers() - Method in class org.apache.flink.mesos.runtime.clusterframework.store.StandaloneMesosWorkerStore
-
- recoverWorkers() - Method in class org.apache.flink.mesos.runtime.clusterframework.store.ZooKeeperMesosWorkerStore
-
- RECOVERY_JOB_DELAY - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- RECOVERY_JOB_MANAGER_PORT - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- RECOVERY_MODE - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- recursionLevel - Variable in class org.apache.flink.runtime.operators.hash.HashPartition
-
- recursivelyRegisterType(TypeInformation<?>, ExecutionConfig, Set<Class<?>>) - Static method in class org.apache.flink.api.java.typeutils.runtime.kryo.Serializers
-
- recursivelyRegisterType(Class<?>, ExecutionConfig, Set<Class<?>>) - Static method in class org.apache.flink.api.java.typeutils.runtime.kryo.Serializers
-
- recycle(MemorySegment) - Method in interface org.apache.flink.runtime.io.network.buffer.BufferRecycler
-
- recycle(MemorySegment) - Method in class org.apache.flink.runtime.io.network.buffer.FreeingBufferRecycler
-
Frees the given memory segment.
- recycle(MemorySegment) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
-
- recycle(MemorySegment) - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
-
Exclusive buffer is recycled to this input channel directly and it may trigger return extra
floating buffer and notify increased credit to the producer.
- recycleBuffer() - Method in interface org.apache.flink.runtime.io.network.buffer.Buffer
-
Releases this buffer once, i.e.
- recycleBuffer() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
-
- recycleBuffer() - Method in class org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
-
- recycleMemorySegments(List<MemorySegment>) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
-
- RedirectHandler<T extends RestfulGateway> - Class in org.apache.flink.runtime.rest.handler
-
SimpleChannelInboundHandler
which encapsulates the redirection logic for the
REST endpoints.
- RedirectHandler(CompletableFuture<String>, GatewayRetriever<? extends T>, Time, Map<String, String>) - Constructor for class org.apache.flink.runtime.rest.handler.RedirectHandler
-
- RedirectingSslHandler - Class in org.apache.flink.runtime.net
-
SSL handler which automatically redirects Non-SSL requests to SSL address.
- RedirectingSslHandler(String, CompletableFuture<String>, SSLEngineFactory) - Constructor for class org.apache.flink.runtime.net.RedirectingSslHandler
-
- reduce(Iterable<T>, Collector<O>) - Method in interface org.apache.flink.api.common.functions.GroupReduceFunction
-
The reduce method.
- reduce(T, T) - Method in interface 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>) - Method in class org.apache.flink.api.common.functions.RichGroupReduceFunction
-
- reduce(T, T) - Method in class org.apache.flink.api.common.functions.RichReduceFunction
-
- reduce(ReduceFunction<T>) - Method in class org.apache.flink.api.java.DataSet
-
Applies a Reduce transformation on a non-grouped
DataSet
.
- reduce(Iterable<T>, Collector<T>) - Method in class org.apache.flink.api.java.functions.FirstReducer
-
- reduce(Iterable<IN>, Collector<OUT>) - Method in class org.apache.flink.api.java.functions.GroupReduceIterator
-
- reduce(Iterable<IntermediateSampleData<T>>, Collector<T>) - Method in class org.apache.flink.api.java.functions.SampleInCoordinator
-
- reduce(T, T) - Method in class org.apache.flink.api.java.functions.SelectByMaxFunction
-
Reduce implementation, returns bigger tuple or value1 if both tuples are
equal.
- reduce(T, T) - Method in class org.apache.flink.api.java.functions.SelectByMinFunction
-
Reduce implementation, returns smaller tuple or value1 if both tuples are
equal.
- reduce(Iterable<IN>, Collector<OUT>) - Method in class org.apache.flink.api.java.operators.translation.CombineToGroupCombineWrapper
-
- reduce(Iterable<IN>, Collector<OUT>) - Method in class org.apache.flink.api.java.operators.translation.RichCombineToGroupCombineWrapper
-
- reduce(ReduceFunction<T>) - Method in class org.apache.flink.api.java.operators.UnsortedGrouping
-
Applies a Reduce transformation on a grouped
DataSet
.
- reduce(Tuple3<Integer, KMeans.Point, Long>, Tuple3<Integer, KMeans.Point, Long>) - Method in class org.apache.flink.examples.java.clustering.KMeans.CentroidAccumulator
-
- reduce(Iterable<Tuple2<Long, Long>>, Collector<Tuple2<Long, Long[]>>) - Method in class org.apache.flink.examples.java.graph.PageRank.BuildOutgoingEdgeList
-
- reduce(Long, Long) - Method in class org.apache.flink.examples.java.misc.PiEstimation.SumReducer
-
- reduce(Tuple2<LinearRegression.Params, Integer>, Tuple2<LinearRegression.Params, Integer>) - Method in class org.apache.flink.examples.java.ml.LinearRegression.UpdateAccumulator
-
- reduce(Vertex<K, LongValue>, Vertex<K, LongValue>) - Method in class org.apache.flink.graph.asm.degree.annotate.DegreeAnnotationFunctions.DegreeCount
-
- reduce(LongValue, LongValue) - Method in class org.apache.flink.graph.utils.GraphUtils.AddLongValue
-
- reduce(Iterable<Tuple2<KEYIN, VALUEIN>>, Collector<Tuple2<KEYOUT, VALUEOUT>>) - Method in class org.apache.flink.hadoopcompatibility.mapred.HadoopReduceCombineFunction
-
- reduce(Iterable<Tuple2<KEYIN, VALUEIN>>, Collector<Tuple2<KEYOUT, VALUEOUT>>) - Method in class org.apache.flink.hadoopcompatibility.mapred.HadoopReduceFunction
-
- reduce(Iterable<IN>, Collector<IN>) - Method in class org.apache.flink.python.api.functions.util.IdentityGroupReduce
-
- reduce(ReduceFunction<T>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies a reduce function to the window.
- reduce(ReduceFunction<T>, AllWindowFunction<T, R, W>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies the given window function to each window.
- reduce(ReduceFunction<T>, AllWindowFunction<T, R, W>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies the given window function to each window.
- reduce(ReduceFunction<T>, ProcessAllWindowFunction<T, R, W>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies the given window function to each window.
- reduce(ReduceFunction<T>, ProcessAllWindowFunction<T, R, W>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies the given window function to each window.
- reduce(ReduceFunction<T>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Applies a reduce transformation on the grouped data stream grouped on by
the given key position.
- reduce(ReduceFunction<T>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies a reduce function to the window.
- reduce(ReduceFunction<T>, WindowFunction<T, R, K, W>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies the given window function to each window.
- reduce(ReduceFunction<T>, WindowFunction<T, R, K, W>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies the given window function to each window.
- reduce(ReduceFunction<T>, ProcessWindowFunction<T, R, K, W>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies the given window function to each window.
- reduce(ReduceFunction<T>, ProcessWindowFunction<T, R, K, W>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies the given window function to each window.
- reduce(T, T) - Method in class org.apache.flink.streaming.api.functions.aggregation.ComparableAggregator
-
- reduce(T, T) - Method in class org.apache.flink.streaming.api.functions.aggregation.SumAggregator
-
- reduce(ReduceFunction<PyObject>) - Method in class org.apache.flink.streaming.python.api.datastream.PythonKeyedStream
-
- reduce(ReduceFunction<PyObject>) - Method in class org.apache.flink.streaming.python.api.datastream.PythonWindowedStream
-
- reduce(PyObject, PyObject) - Method in class org.apache.flink.streaming.python.api.functions.PythonReduceFunction
-
- ReduceApplyAllWindowFunction<W extends Window,T,R> - Class in org.apache.flink.streaming.api.functions.windowing
-
- ReduceApplyAllWindowFunction(ReduceFunction<T>, AllWindowFunction<T, R, W>) - Constructor for class org.apache.flink.streaming.api.functions.windowing.ReduceApplyAllWindowFunction
-
- ReduceApplyProcessAllWindowFunction<W extends Window,T,R> - Class in org.apache.flink.streaming.api.functions.windowing
-
- ReduceApplyProcessAllWindowFunction(ReduceFunction<T>, ProcessAllWindowFunction<T, R, W>) - Constructor for class org.apache.flink.streaming.api.functions.windowing.ReduceApplyProcessAllWindowFunction
-
- ReduceApplyProcessWindowFunction<K,W extends Window,T,R> - Class in org.apache.flink.streaming.api.functions.windowing
-
- ReduceApplyProcessWindowFunction(ReduceFunction<T>, ProcessWindowFunction<T, R, K, W>) - Constructor for class org.apache.flink.streaming.api.functions.windowing.ReduceApplyProcessWindowFunction
-
- ReduceApplyWindowFunction<K,W extends Window,T,R> - Class in org.apache.flink.streaming.api.functions.windowing
-
- ReduceApplyWindowFunction(ReduceFunction<T>, WindowFunction<T, R, K, W>) - Constructor for class org.apache.flink.streaming.api.functions.windowing.ReduceApplyWindowFunction
-
- ReduceCombineDriver<T> - Class in org.apache.flink.runtime.operators
-
Combine operator for Reduce functions, standalone (not chained).
- ReduceCombineDriver() - Constructor for class org.apache.flink.runtime.operators.ReduceCombineDriver
-
- ReduceDriver<T> - Class in org.apache.flink.runtime.operators
-
Reduce driver which is executed by a Task Manager.
- ReduceDriver() - Constructor for class org.apache.flink.runtime.operators.ReduceDriver
-
- reduceEdges(EV, EV) - Method in interface org.apache.flink.graph.ReduceEdgesFunction
-
It combines two neighboring edge values into one new value of the same type.
- ReduceEdgesFunction<EV> - Interface in org.apache.flink.graph
-
- ReduceFacade(ReduceFunction<T>, Collector<T>, boolean) - Constructor for class org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable.ReduceFacade
-
- ReduceFunction<T> - Interface in org.apache.flink.api.common.functions
-
Base interface for Reduce functions.
- reduceGroup(GroupReduceFunction<T, R>) - Method in class org.apache.flink.api.java.DataSet
-
Applies a GroupReduce transformation on a non-grouped
DataSet
.
- reduceGroup(Iterable<IN>) - Method in class org.apache.flink.api.java.functions.GroupReduceIterator
-
- reduceGroup(GroupReduceFunction<T, R>) - Method in class org.apache.flink.api.java.operators.SortedGrouping
-
Applies a GroupReduce transformation on a grouped and sorted
DataSet
.
- reduceGroup(GroupReduceFunction<T, R>) - Method in class org.apache.flink.api.java.operators.UnsortedGrouping
-
Applies a GroupReduce transformation on a grouped
DataSet
.
- reduceNeighbors(VV, VV) - Method in interface org.apache.flink.graph.ReduceNeighborsFunction
-
It combines two neighboring vertex values into one new value of the same type.
- ReduceNeighborsFunction<VV> - Interface in org.apache.flink.graph
-
- ReduceNode - Class in org.apache.flink.optimizer.dag
-
The Optimizer representation of a Reduce operator.
- ReduceNode(ReduceOperatorBase<?, ?>) - Constructor for class org.apache.flink.optimizer.dag.ReduceNode
-
- ReduceNode(ReduceNode) - Constructor for class org.apache.flink.optimizer.dag.ReduceNode
-
- reduceOnEdges(ReduceEdgesFunction<EV>, EdgeDirection) - Method in class org.apache.flink.graph.Graph
-
Compute a reduce transformation over the edge values of each vertex.
- reduceOnNeighbors(ReduceNeighborsFunction<VV>, EdgeDirection) - Method in class org.apache.flink.graph.Graph
-
Compute a reduce transformation over the neighbors' vertex values of each vertex.
- ReduceOperator<IN> - Class in org.apache.flink.api.java.operators
-
This operator represents the application of a "reduce" function on a data set, and the
result data set produced by the function.
- ReduceOperator(DataSet<IN>, ReduceFunction<IN>, String) - Constructor for class org.apache.flink.api.java.operators.ReduceOperator
-
This is the case for a reduce-all case (in contrast to the reduce-per-group case).
- ReduceOperator(Grouping<IN>, ReduceFunction<IN>, String) - Constructor for class org.apache.flink.api.java.operators.ReduceOperator
-
- ReduceOperatorBase<T,FT extends ReduceFunction<T>> - Class in org.apache.flink.api.common.operators.base
-
Base data flow operator for Reduce user-defined functions.
- ReduceOperatorBase(UserCodeWrapper<FT>, UnaryOperatorInformation<T, T>, int[], String) - Constructor for class org.apache.flink.api.common.operators.base.ReduceOperatorBase
-
Creates a grouped reduce data flow operator.
- ReduceOperatorBase(FT, UnaryOperatorInformation<T, T>, int[], String) - Constructor for class org.apache.flink.api.common.operators.base.ReduceOperatorBase
-
Creates a grouped reduce data flow operator.
- ReduceOperatorBase(Class<? extends FT>, UnaryOperatorInformation<T, T>, int[], String) - Constructor for class org.apache.flink.api.common.operators.base.ReduceOperatorBase
-
Creates a grouped reduce data flow operator.
- ReduceOperatorBase(UserCodeWrapper<FT>, UnaryOperatorInformation<T, T>, String) - Constructor for class org.apache.flink.api.common.operators.base.ReduceOperatorBase
-
Creates a non-grouped reduce data flow operator (all-reduce).
- ReduceOperatorBase(FT, UnaryOperatorInformation<T, T>, String) - Constructor for class 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) - Constructor for class org.apache.flink.api.common.operators.base.ReduceOperatorBase
-
Creates a non-grouped reduce data flow operator (all-reduce).
- ReduceOperatorBase.CombineHint - Enum in 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.
- ReduceProperties - Class in org.apache.flink.optimizer.operators
-
- ReduceProperties(FieldSet, DriverStrategy) - Constructor for class org.apache.flink.optimizer.operators.ReduceProperties
-
- ReduceProperties(FieldSet, Partitioner<?>, DriverStrategy) - Constructor for class org.apache.flink.optimizer.operators.ReduceProperties
-
- ReducingState<T> - Interface in org.apache.flink.api.common.state
-
State
interface for reducing state.
- ReducingStateDescriptor<T> - Class in org.apache.flink.api.common.state
-
- ReducingStateDescriptor(String, ReduceFunction<T>, Class<T>) - Constructor for class 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>) - Constructor for class org.apache.flink.api.common.state.ReducingStateDescriptor
-
Creates a new ReducingStateDescriptor
with the given name and default value.
- ReducingStateDescriptor(String, ReduceFunction<T>, TypeSerializer<T>) - Constructor for class org.apache.flink.api.common.state.ReducingStateDescriptor
-
Creates a new ValueStateDescriptor
with the given name and default value.
- reference - Variable in class org.apache.flink.api.common.typeutils.base.array.PrimitiveArrayComparator
-
- ReflectionUtil - Class in org.apache.flink.util
-
Utility for reflection operations on classes and generic type parametrization.
- ReflectionUtil.FullTypeInfo - Class in org.apache.flink.util
-
Container for the full type information of a type.
- refresh() - Method in class org.apache.flink.runtime.security.DynamicConfiguration
-
- refresh() - Method in class org.apache.flink.table.client.cli.CliChangelogResultView
-
- refresh() - Method in class org.apache.flink.table.client.cli.CliResultView
-
- refresh() - Method in class org.apache.flink.table.client.cli.CliTableResultView
-
- REFRESH_INTERVAL - Static variable in class org.apache.flink.configuration.WebOptions
-
The config parameter defining the refresh interval for the web-frontend.
- REFRESH_INTERVALS - Static variable in class org.apache.flink.table.client.cli.CliResultView
-
- refreshInterval - Variable in class org.apache.flink.table.client.cli.CliResultView
-
- REFUSED_REGISTRATION_BACKOFF - Static variable in class org.apache.flink.configuration.TaskManagerOptions
-
The backoff after a registration has been refused by the job manager before retrying to connect.
- register(Metric, String, AbstractMetricGroup) - Method in interface org.apache.flink.runtime.metrics.MetricRegistry
-
Registers a new
Metric
with this registry.
- register(Metric, String, AbstractMetricGroup) - Method in class org.apache.flink.runtime.metrics.MetricRegistryImpl
-
- register(Metric, String, AbstractMetricGroup) - Method in class org.apache.flink.runtime.metrics.NoOpMetricRegistry
-
- register(Logger) - Static method in class org.apache.flink.runtime.util.SignalHandler
-
Register some signal handlers.
- registerAggregationConvergenceCriterion(String, Aggregator<T>, ConvergenceCriterion<T>) - Method in class org.apache.flink.api.common.aggregators.AggregatorRegistry
-
- registerAggregationConvergenceCriterion(String, Aggregator<X>, ConvergenceCriterion<X>) - Method in class org.apache.flink.api.java.operators.DeltaIteration
-
- registerAggregationConvergenceCriterion(String, Aggregator<X>, ConvergenceCriterion<X>) - Method in class org.apache.flink.api.java.operators.IterativeDataSet
-
- registerAggregator(String, Aggregator<?>) - Method in class org.apache.flink.api.common.aggregators.AggregatorRegistry
-
- registerAggregator(String, Aggregator<?>) - Method in class org.apache.flink.api.java.operators.DeltaIteration
-
- registerAggregator(String, Aggregator<?>) - Method in class org.apache.flink.api.java.operators.IterativeDataSet
-
- registerAggregator(String, Aggregator<?>) - Method in class org.apache.flink.graph.IterationConfiguration
-
Registers a new aggregator.
- registerAll(Iterable<? extends CompositeStateHandle>) - Method in class org.apache.flink.runtime.state.SharedStateRegistry
-
Register given shared states in the registry.
- registerAllRequestsProcessedListener(NotificationListener) - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBufferFileWriter
-
- registerAllRequestsProcessedListener(NotificationListener) - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousFileIOChannel
-
Registers a listener to be notified when all outstanding requests have been processed.
- registerAllRequestsProcessedListener(NotificationListener) - Method in interface org.apache.flink.runtime.io.disk.iomanager.BufferFileWriter
-
Registers a listener, which is notified after all outstanding requests have been processed.
- registerBufferPool(BufferPool) - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
-
Registers a buffer pool with this result partition.
- registerCachedFile(String, DistributedCache.DistributedCacheEntry) - Method in class org.apache.flink.api.common.Plan
-
register cache files in program level
- registerCachedFile(String, String) - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
Registers a file at the distributed cache under the given name.
- registerCachedFile(String, String, boolean) - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
Registers a file at the distributed cache under the given name.
- registerCachedFile(String, String) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Registers a file at the distributed cache under the given name.
- registerCachedFile(String, String, boolean) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Registers a file at the distributed cache under the given name.
- registerCachedFilesWithPlan(Plan) - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
Registers all files that were registered at this execution environment's cache registry of the
given plan's cache registry.
- registerChannelToBeRemovedAtShudown(FileIOChannel.ID) - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SpillingThread
-
Adds a channel to the list of channels that are to be removed at shutdown.
- registerCheckpointEventHandler(AbstractInvokable) - Method in class org.apache.flink.streaming.runtime.io.BarrierBuffer
-
- registerCheckpointEventHandler(AbstractInvokable) - Method in class org.apache.flink.streaming.runtime.io.BarrierTracker
-
- registerCheckpointEventHandler(AbstractInvokable) - Method in interface org.apache.flink.streaming.runtime.io.CheckpointBarrierHandler
-
Registers the task be notified once all checkpoint barriers have been received for a checkpoint.
- registerCleanupTimer(W) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
Registers a timer to cleanup the content of the window.
- registerCloseable(C) - Method in class org.apache.flink.util.AbstractCloseableRegistry
-
- registerConsumer() - Method in class org.apache.flink.runtime.executiongraph.IntermediateResult
-
- registered(Registered) - Method in class org.apache.flink.mesos.runtime.clusterframework.MesosResourceManager
-
- Registered - Class in org.apache.flink.mesos.scheduler.messages
-
Message sent by the callback handler to the scheduler actor
when the scheduler successfully registers with a Mesos master.
- Registered(Protos.FrameworkID, Protos.MasterInfo) - Constructor for class org.apache.flink.mesos.scheduler.messages.Registered
-
- registered(SchedulerDriver, Protos.FrameworkID, Protos.MasterInfo) - Method in class org.apache.flink.mesos.scheduler.SchedulerProxy
-
- RegisteredBroadcastBackendStateMetaInfo<K,V> - Class in org.apache.flink.runtime.state
-
- RegisteredBroadcastBackendStateMetaInfo(String, OperatorStateHandle.Mode, TypeSerializer<K>, TypeSerializer<V>) - Constructor for class org.apache.flink.runtime.state.RegisteredBroadcastBackendStateMetaInfo
-
- RegisteredBroadcastBackendStateMetaInfo(RegisteredBroadcastBackendStateMetaInfo<K, V>) - Constructor for class org.apache.flink.runtime.state.RegisteredBroadcastBackendStateMetaInfo
-
- RegisteredBroadcastBackendStateMetaInfo.Snapshot<K,V> - Class in org.apache.flink.runtime.state
-
- RegisteredKeyedBackendStateMetaInfo<N,S> - Class in org.apache.flink.runtime.state
-
Compound meta information for a registered state in a keyed state backend.
- RegisteredKeyedBackendStateMetaInfo(StateDescriptor.Type, String, TypeSerializer<N>, TypeSerializer<S>) - Constructor for class org.apache.flink.runtime.state.RegisteredKeyedBackendStateMetaInfo
-
- RegisteredKeyedBackendStateMetaInfo.Snapshot<N,S> - Class in org.apache.flink.runtime.state
-
- RegisteredMesosWorkerNode - Class in org.apache.flink.mesos.runtime.clusterframework
-
- RegisteredMesosWorkerNode(MesosWorkerStore.Worker) - Constructor for class org.apache.flink.mesos.runtime.clusterframework.RegisteredMesosWorkerNode
-
- RegisteredOperatorBackendStateMetaInfo<S> - Class in org.apache.flink.runtime.state
-
Compound meta information for a registered state in an operator state backend.
- RegisteredOperatorBackendStateMetaInfo(String, TypeSerializer<S>, OperatorStateHandle.Mode) - Constructor for class org.apache.flink.runtime.state.RegisteredOperatorBackendStateMetaInfo
-
- RegisteredOperatorBackendStateMetaInfo.Snapshot<S> - Class in org.apache.flink.runtime.state
-
- registeredPartitions - Variable in class org.apache.flink.runtime.io.network.partition.ResultPartitionManager
-
- RegisteredRpcConnection<F extends Serializable,G extends RpcGateway,S extends RegistrationResponse.Success> - Class in org.apache.flink.runtime.registration
-
This utility class implements the basis of RPC connecting from one component to another component,
for example the RPC connection from TaskExecutor to ResourceManager.
- RegisteredRpcConnection(Logger, String, F, Executor) - Constructor for class org.apache.flink.runtime.registration.RegisteredRpcConnection
-
- RegisteredYarnWorkerNode - Class in org.apache.flink.yarn
-
- RegisteredYarnWorkerNode(Container) - Constructor for class org.apache.flink.yarn.RegisteredYarnWorkerNode
-
- registerEventTimeTimer(N, long) - Method in class org.apache.flink.streaming.api.operators.HeapInternalTimerService
-
- registerEventTimeTimer(N, long) - Method in interface org.apache.flink.streaming.api.operators.InternalTimerService
-
Registers a timer to be fired when event time watermark passes the given time.
- registerEventTimeTimer(long) - Method in class org.apache.flink.streaming.api.SimpleTimerService
-
- registerEventTimeTimer(long) - Method in interface org.apache.flink.streaming.api.TimerService
-
Registers a timer to be fired when the event time watermark passes the given time.
- registerEventTimeTimer(long) - Method in interface org.apache.flink.streaming.api.windowing.triggers.Trigger.TriggerContext
-
Register an event-time callback.
- registerEventTimeTimer(long) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
-
- registerExecutionListener(ExecutionStatusListener) - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- registerExecutionListener(TaskExecutionStateListener) - Method in class org.apache.flink.runtime.taskmanager.Task
-
- registerInflaterInputStreamFactory(String, InflaterInputStreamFactory<?>) - Static method in class org.apache.flink.api.common.io.FileInputFormat
-
- RegisterInfoMessageListener - Class in org.apache.flink.runtime.clusterframework.messages
-
This message signals to the resource master to register the sender as an
info message listener.
- registerInfoMessageListener(String) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
-
Registers an info message listener.
- registerInfoMessageListener(String) - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
-
Registers an infoMessage listener
- RegisterInfoMessageListenerSuccessful - Class in org.apache.flink.runtime.clusterframework.messages
-
This message signals to the application client that the registration was successful.
- registerJob(JobID) - Method in class org.apache.flink.runtime.blob.PermanentBlobCache
-
Registers use of job-related BLOBs.
- registerJob(JobID, Collection<PermanentBlobKey>, Collection<URL>) - Method in class org.apache.flink.runtime.execution.librarycache.BlobLibraryCacheManager
-
- registerJob(JobID, Collection<PermanentBlobKey>, Collection<URL>) - Method in interface org.apache.flink.runtime.execution.librarycache.LibraryCacheManager
-
Registers a job with its required jar files and classpaths.
- registerJobManager(JobMasterId, ResourceID, String, JobID, Time) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
-
- registerJobManager(JobMasterId, ResourceID, String, JobID, Time) - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
-
Register a
JobMaster
at the resource manager.
- registerJobStatusListener(JobStatusListener) - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- registerKryoType(Class<?>) - Method in class org.apache.flink.api.common.ExecutionConfig
-
Registers the given type with the serialization stack.
- registerKvState(KeyGroupRange, KvStateID, InetSocketAddress) - Method in class org.apache.flink.runtime.query.KvStateLocation
-
Registers a KvState instance for the given key group index.
- registerKvState(JobID, JobVertexID, KeyGroupRange, String, InternalKvState<?, ?, ?>) - Method in class org.apache.flink.runtime.query.KvStateRegistry
-
Registers the KvState instance and returns the assigned ID.
- registerKvState(KeyGroupRange, String, InternalKvState<?, ?, ?>) - Method in class org.apache.flink.runtime.query.TaskKvStateRegistry
-
Registers the KvState instance at the KvStateRegistry.
- registerListener(InputGateListener) - Method in interface org.apache.flink.runtime.io.network.partition.consumer.InputGate
-
- registerListener(InputGateListener) - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
-
- registerListener(InputGateListener) - Method in class org.apache.flink.runtime.io.network.partition.consumer.UnionInputGate
-
- registerListener(JobID, KvStateRegistryListener) - Method in class org.apache.flink.runtime.query.KvStateRegistry
-
Registers a listener with the registry.
- registerMetrics(MetricGroup) - Method in class org.apache.flink.runtime.executiongraph.failover.FailoverStrategy
-
Tells the FailoverStrategy to register its metrics.
- registerMetrics(MetricGroup) - Method in class org.apache.flink.runtime.executiongraph.failover.RestartIndividualStrategy
-
- registerOpenChannelToBeRemovedAtShudown(FileIOChannel) - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SpillingThread
-
Adds a channel reader/writer to the list of channels that are to be removed at shutdown.
- registerPartition(ResultPartitionID) - Method in class org.apache.flink.runtime.io.network.TaskEventDispatcher
-
- registerPojoType(Class<?>) - Method in class org.apache.flink.api.common.ExecutionConfig
-
Registers the given type with the serialization stack.
- registerProcessingTimeTimer(N, long) - Method in class org.apache.flink.streaming.api.operators.HeapInternalTimerService
-
- registerProcessingTimeTimer(N, long) - Method in interface org.apache.flink.streaming.api.operators.InternalTimerService
-
Registers a timer to be fired when processing time passes the given time.
- registerProcessingTimeTimer(long) - Method in class org.apache.flink.streaming.api.SimpleTimerService
-
- registerProcessingTimeTimer(long) - Method in interface org.apache.flink.streaming.api.TimerService
-
Registers a timer to be fired when processing time passes the given time.
- registerProcessingTimeTimer(long) - Method in interface org.apache.flink.streaming.api.windowing.triggers.Trigger.TriggerContext
-
Register a system time callback.
- registerProcessingTimeTimer(long) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
-
- registerQueueLengthMetrics(MetricGroup, SingleInputGate) - Static method in class org.apache.flink.runtime.io.network.partition.consumer.InputGateMetrics
-
- registerQueueLengthMetrics(MetricGroup, ResultPartition) - Static method in class org.apache.flink.runtime.io.network.partition.ResultPartitionMetrics
-
- registerReference(SharedStateRegistryKey, StreamStateHandle) - Method in class org.apache.flink.runtime.state.SharedStateRegistry
-
Register a reference to the given shared state in the registry.
- RegisterResourceManager - Class in org.apache.flink.runtime.clusterframework.messages
-
This message signals that the resource manager wants to register at the JobManager leader.
- RegisterResourceManager(ActorRef) - Constructor for class org.apache.flink.runtime.clusterframework.messages.RegisterResourceManager
-
- RegisterResourceManagerSuccessful - Class in org.apache.flink.runtime.clusterframework.messages
-
Message that informs the resource manager that the JobManager accepted its registration.
- RegisterResourceManagerSuccessful(ActorRef, Collection<ResourceID>) - Constructor for class org.apache.flink.runtime.clusterframework.messages.RegisterResourceManagerSuccessful
-
Creates a new message with a list of existing known TaskManagers.
- registerResultPartition(ResultPartition) - Method in class org.apache.flink.runtime.io.network.partition.ResultPartitionManager
-
- registerSharedStates(SharedStateRegistry) - Method in class org.apache.flink.runtime.checkpoint.OperatorState
-
- registerSharedStates(SharedStateRegistry) - Method in class org.apache.flink.runtime.checkpoint.OperatorSubtaskState
-
- registerSharedStates(SharedStateRegistry) - Method in class org.apache.flink.runtime.checkpoint.SubtaskState
-
- registerSharedStates(SharedStateRegistry) - Method in class org.apache.flink.runtime.checkpoint.TaskState
-
Deprecated.
- registerSharedStates(SharedStateRegistry) - Method in class org.apache.flink.runtime.checkpoint.TaskStateSnapshot
-
- registerSharedStates(SharedStateRegistry) - Method in interface org.apache.flink.runtime.state.CompositeStateHandle
-
Register both newly created and already referenced shared states in the given
SharedStateRegistry
.
- registerSharedStates(SharedStateRegistry) - Method in class org.apache.flink.runtime.state.DirectoryKeyedStateHandle
-
- registerSharedStates(SharedStateRegistry) - Method in class org.apache.flink.runtime.state.IncrementalKeyedStateHandle
-
- registerSharedStates(SharedStateRegistry) - Method in class org.apache.flink.runtime.state.KeyGroupsStateHandle
-
- registerSharedStatesAfterRestored(SharedStateRegistry) - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
-
Register all shared states in the given registry.
- registerShutdownActions(CompletableFuture<ApplicationStatus>) - Method in class org.apache.flink.mesos.entrypoint.MesosJobClusterEntrypoint
-
- registerShutdownActions(CompletableFuture<ApplicationStatus>) - Method in class org.apache.flink.runtime.entrypoint.JobClusterEntrypoint
-
- registerShutdownActions(CompletableFuture<ApplicationStatus>) - Method in class org.apache.flink.yarn.entrypoint.YarnJobClusterEntrypoint
-
- registerSlotRequest(SlotRequest) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
-
Requests a slot with the respective resource profile.
- registerTask(JobID, ExecutionAttemptID, Collection<PermanentBlobKey>, Collection<URL>) - Method in class org.apache.flink.runtime.execution.librarycache.BlobLibraryCacheManager
-
- registerTask(JobID, ExecutionAttemptID, Collection<PermanentBlobKey>, Collection<URL>) - Method in interface org.apache.flink.runtime.execution.librarycache.LibraryCacheManager
-
Registers a job task execution with its required jar files and classpaths.
- registerTask(Task) - Method in class org.apache.flink.runtime.io.network.NetworkEnvironment
-
- registerTaskEventListener(EventListener<TaskEvent>, Class<? extends TaskEvent>) - Method in class org.apache.flink.runtime.io.network.api.reader.AbstractReader
-
- registerTaskEventListener(EventListener<TaskEvent>, Class<? extends TaskEvent>) - Method in interface org.apache.flink.runtime.io.network.api.reader.ReaderBase
-
- registerTaskExecutor(String, ResourceID, int, HardwareDescription, Time) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
-
- registerTaskExecutor(String, ResourceID, int, HardwareDescription, Time) - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
-
- registerTaskManager(TaskManagerGateway, TaskManagerLocation, HardwareDescription, int) - Method in class org.apache.flink.runtime.instance.InstanceManager
-
Registers a task manager.
- registerTaskManager(String, TaskManagerLocation, Time) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
-
- registerTaskManager(String, TaskManagerLocation, Time) - Method in interface org.apache.flink.runtime.jobmaster.JobMasterGateway
-
Registers the task manager at the job manager.
- registerTaskManager(ResourceID) - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotPool
-
Register TaskManager to this pool, only those slots come from registered TaskManager will be considered valid.
- registerTaskManager(ResourceID) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.SlotPoolGateway
-
- registerTaskManager(TaskExecutorConnection, SlotReport) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
-
Registers a new task manager at the slot manager.
- registerTimeout(K, long, TimeUnit) - Method in class org.apache.flink.runtime.taskexecutor.slot.TimerService
-
Register a timeout for the given key which shall occur in the given delay.
- registerTimer(long, ProcessingTimeCallback) - Method in class org.apache.flink.streaming.runtime.tasks.ProcessingTimeService
-
Registers a task to be executed when (processing) time is timestamp
.
- registerTimer(long, ProcessingTimeCallback) - Method in class org.apache.flink.streaming.runtime.tasks.SystemProcessingTimeService
-
Registers a task to be executed no sooner than time timestamp
, but without strong
guarantees of order.
- registerTimer(long, ProcessingTimeCallback) - Method in class org.apache.flink.streaming.runtime.tasks.TestProcessingTimeService
-
- registerType(Class<?>) - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
Registers the given type with the serialization stack.
- registerType(Class<?>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Registers the given type with the serialization stack.
- registerTypeWithKryoSerializer(Class<?>, T) - Method in class org.apache.flink.api.common.ExecutionConfig
-
Registers the given type with a Kryo Serializer.
- registerTypeWithKryoSerializer(Class<?>, Class<? extends Serializer>) - Method in class org.apache.flink.api.common.ExecutionConfig
-
Registers the given Serializer via its class as a serializer for the given type at the KryoSerializer
- registerTypeWithKryoSerializer(Class<?>, T) - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
Registers the given type with a Kryo Serializer.
- registerTypeWithKryoSerializer(Class<?>, Class<? extends Serializer<?>>) - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
Registers the given Serializer via its class as a serializer for the given type at the KryoSerializer.
- registerTypeWithKryoSerializer(Class<?>, T) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Registers the given type with a Kryo Serializer.
- registerTypeWithKryoSerializer(Class<?>, Class<? extends Serializer>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Registers the given Serializer via its class as a serializer for the
given type at the KryoSerializer.
- REGISTRATION_MAX_BACKOFF - Static variable in class org.apache.flink.configuration.TaskManagerOptions
-
The maximum registration backoff between two consecutive registration attempts.
- REGISTRATION_TIMEOUT - Static variable in class org.apache.flink.configuration.TaskManagerOptions
-
Defines the timeout it can take for the TaskManager registration.
- RegistrationConnectionListener<T extends RegisteredRpcConnection<?,?,S>,S extends RegistrationResponse.Success> - Interface in org.apache.flink.runtime.registration
-
Classes which want to be notified about the registration result by the
RegisteredRpcConnection
have to implement this interface.
- RegistrationResponse - Class in org.apache.flink.runtime.registration
-
- RegistrationResponse() - Constructor for class org.apache.flink.runtime.registration.RegistrationResponse
-
- RegistrationResponse.Decline - Class in org.apache.flink.runtime.registration
-
A rejected (declined) registration.
- RegistrationResponse.Success - Class in org.apache.flink.runtime.registration
-
Base class for a successful registration.
- RegistrationTimeoutException - Exception in org.apache.flink.runtime.taskexecutor.exceptions
-
Exception which indicates that the
TaskExecutor
could not register at
the master in time.
- RegistrationTimeoutException(String) - Constructor for exception org.apache.flink.runtime.taskexecutor.exceptions.RegistrationTimeoutException
-
- RegistrationTimeoutException(String, Throwable) - Constructor for exception org.apache.flink.runtime.taskexecutor.exceptions.RegistrationTimeoutException
-
- RegistrationTimeoutException(Throwable) - Constructor for exception org.apache.flink.runtime.taskexecutor.exceptions.RegistrationTimeoutException
-
- registry - Variable in class org.apache.flink.dropwizard.ScheduledDropwizardReporter
-
- registry - Variable in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
-
The registry that this metrics group belongs to.
- RegularToMutableObjectIterator<T> - Class in org.apache.flink.runtime.util
-
- RegularToMutableObjectIterator(Iterator<T>, TypeSerializer<T>) - Constructor for class org.apache.flink.runtime.util.RegularToMutableObjectIterator
-
- reinterpretAsKeyedStream(DataStream<T>, KeySelector<T, K>) - Static method in class org.apache.flink.streaming.api.datastream.DataStreamUtils
-
- reinterpretAsKeyedStream(DataStream<T>, KeySelector<T, K>, TypeInformation<K>) - Static method in class org.apache.flink.streaming.api.datastream.DataStreamUtils
-
- relativeTimeMillis() - Method in class org.apache.flink.runtime.util.clock.Clock
-
- relativeTimeMillis() - Method in class org.apache.flink.runtime.util.clock.SystemClock
-
- relativeTimeNanos() - Method in class org.apache.flink.runtime.util.clock.Clock
-
- relativeTimeNanos() - Method in class org.apache.flink.runtime.util.clock.SystemClock
-
- release(K, V, long, int) - Method in class org.apache.flink.cep.nfa.SharedBuffer
-
Decreases the reference counter for the given value, key, timestamp entry so that it can be
removed once the reference counter reaches 0.
- release() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
-
- release(Throwable) - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
-
Releases the result partition.
- release() - Method in class org.apache.flink.runtime.io.network.partition.ResultSubpartition
-
- release(Throwable) - Method in class org.apache.flink.runtime.jobmaster.slotpool.SingleLogicalSlot
-
A release of the payload by the AllocatedSlot
triggers a release of the payload of
the logical slot.
- release(Throwable) - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotSharingManager.MultiTaskSlot
-
- release(Throwable) - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotSharingManager.SingleTaskSlot
-
- release(Throwable) - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotSharingManager.TaskSlot
-
Release the task slot.
- release(MemorySegment) - Method in class org.apache.flink.runtime.memory.MemoryManager
-
Tries to release the memory for the specified segment.
- release(Collection<MemorySegment>) - Method in class org.apache.flink.runtime.memory.MemoryManager
-
Tries to release many memory segments together.
- release() - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateTableSnapshot
-
- release(String) - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
-
Releases the lock from the node under the given ZooKeeper path.
- releaseAll(Object) - Method in class org.apache.flink.runtime.memory.MemoryManager
-
Releases all memory segments for the given owner.
- releaseAll() - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
-
Releases all lock nodes of this ZooKeeperStateHandleStore.
- releaseAllReferencesFromTask(BatchTask<?, ?>) - Method in class org.apache.flink.runtime.broadcast.BroadcastVariableManager
-
- releaseAllResources() - Method in interface org.apache.flink.runtime.io.network.NetworkSequenceViewReader
-
- releaseAllResources() - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
-
- releaseAllResources() - Method in interface org.apache.flink.runtime.io.network.partition.ResultSubpartitionView
-
- releaseAndTryRemove(String) - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
-
Releases the lock for the given state node and tries to remove the state node if it is no longer locked.
- releaseAndTryRemoveAll() - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
-
Releases all lock nodes of this ZooKeeperStateHandleStores and tries to remove all state nodes which
are not locked anymore.
- releaseArrays() - Method in class org.apache.flink.core.memory.DataInputDeserializer
-
- releaseBlocker() - Method in class org.apache.flink.core.testutils.BlockerSync
-
Lets the blocked thread continue.
- releaseBroadcastVariables(String, int, DistributedRuntimeUDFContext) - Method in class org.apache.flink.runtime.operators.BatchTask
-
- releaseJob(JobID) - Method in class org.apache.flink.runtime.blob.PermanentBlobCache
-
Unregisters use of job-related BLOBs and allow them to be released.
- releaseJobGraph(JobID) - Method in class org.apache.flink.runtime.dispatcher.SingleJobSubmittedJobGraphStore
-
- releaseJobGraph(JobID) - Method in class org.apache.flink.runtime.jobmanager.StandaloneSubmittedJobGraphStore
-
- releaseJobGraph(JobID) - Method in interface org.apache.flink.runtime.jobmanager.SubmittedJobGraphStore
-
Releases the locks on the specified
JobGraph
.
- releaseJobGraph(JobID) - Method in class org.apache.flink.runtime.jobmanager.ZooKeeperSubmittedJobGraphStore
-
- releaseLocalStateForAllocationId(AllocationID) - Method in class org.apache.flink.runtime.state.TaskExecutorLocalStateStoresManager
-
- releaseMemory(int) - Method in interface org.apache.flink.runtime.io.network.buffer.BufferPoolOwner
-
- releaseMemory(int) - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
-
Releases buffers held by this result partition.
- releaseOutputs() - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
-
This method releases all resources of the record writer output.
- releasePartitionsProducedBy(ExecutionAttemptID) - Method in class org.apache.flink.runtime.io.network.partition.ResultPartitionManager
-
- releasePartitionsProducedBy(ExecutionAttemptID, Throwable) - Method in class org.apache.flink.runtime.io.network.partition.ResultPartitionManager
-
- releasePendingWorker(ResourceID) - Method in class org.apache.flink.mesos.runtime.clusterframework.MesosFlinkResourceManager
-
Release the given pending worker.
- releasePendingWorker(ResourceID) - Method in class org.apache.flink.runtime.clusterframework.FlinkResourceManager
-
Trigger a release of a pending worker.
- releasePendingWorker(ResourceID) - Method in class org.apache.flink.runtime.clusterframework.standalone.StandaloneResourceManager
-
- releasePendingWorker(ResourceID) - Method in class org.apache.flink.yarn.YarnFlinkResourceManager
-
- releaseReference(String, int, BatchTask<?, ?>) - Method in class org.apache.flink.runtime.broadcast.BroadcastVariableManager
-
- releaseReference(BroadcastVariableKey, BatchTask<?, ?>) - Method in class org.apache.flink.runtime.broadcast.BroadcastVariableManager
-
- releaseResource(InstanceID, Exception) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
-
- releaseResource(InstanceID, Exception) - Method in interface org.apache.flink.runtime.resourcemanager.slotmanager.ResourceActions
-
Releases the resource with the given instance id.
- releaseResources() - Method in class org.apache.flink.runtime.io.async.AbstractAsyncCallableWithResources
-
Releases resources acquired by this object.
- releaseSlot(Throwable) - Method in class org.apache.flink.runtime.instance.SharedSlot
-
- releaseSlot(Throwable) - Method in class org.apache.flink.runtime.instance.SimpleSlot
-
- releaseSlot(Throwable) - Method in class org.apache.flink.runtime.instance.Slot
-
This method cancels and releases the slot and all its sub-slots.
- releaseSlot() - Method in interface org.apache.flink.runtime.jobmaster.LogicalSlot
-
- releaseSlot(Throwable) - Method in interface org.apache.flink.runtime.jobmaster.LogicalSlot
-
Releases this slot.
- releaseSlot(SlotRequestId, SlotSharingGroupId, Throwable) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.AllocatedSlotActions
-
- releaseSlot(Throwable) - Method in class org.apache.flink.runtime.jobmaster.slotpool.SingleLogicalSlot
-
- releaseSlot(SlotRequestId, SlotSharingGroupId, Throwable) - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotPool
-
- releaseStartedWorker(RegisteredMesosWorkerNode) - Method in class org.apache.flink.mesos.runtime.clusterframework.MesosFlinkResourceManager
-
Release the given started worker.
- releaseStartedWorker(WorkerType) - Method in class org.apache.flink.runtime.clusterframework.FlinkResourceManager
-
Trigger a release of a started worker.
- releaseStartedWorker(ResourceID) - Method in class org.apache.flink.runtime.clusterframework.standalone.StandaloneResourceManager
-
- releaseStartedWorker(RegisteredYarnWorkerNode) - Method in class org.apache.flink.yarn.YarnFlinkResourceManager
-
- releaseTable() - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
-
Releases the table (the array of buckets) and returns the occupied memory segments to the list of free segments.
- releaseTable() - Method in class org.apache.flink.runtime.operators.hash.ReOpenableMutableHashTable
-
- releaseTaskManager(ResourceID, Exception) - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotPool
-
Unregister TaskManager from this pool, all the related slots will be released and tasks be canceled.
- releaseTaskManager(ResourceID, Exception) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.SlotPoolGateway
-
- releaseWorker() - Method in class org.apache.flink.mesos.runtime.clusterframework.store.MesosWorkerStore.Worker
-
Transition the worker to a released state.
- reloadConfiguration() - Method in class org.apache.hadoop.conf.Configuration
-
Reload configuration from previously added resources.
- remainingCapacity() - Method in class org.apache.flink.runtime.operators.sort.PartialOrderPriorityQueue
-
Returns the remaining capacity of the backing array.
- RemoteEnvironment - Class in org.apache.flink.api.java
-
- RemoteEnvironment(String, int, String...) - Constructor for class org.apache.flink.api.java.RemoteEnvironment
-
Creates a new RemoteEnvironment that points to the master (JobManager) described by the
given host name and port.
- RemoteEnvironment(String, int, Configuration, String[]) - Constructor for class org.apache.flink.api.java.RemoteEnvironment
-
Creates a new RemoteEnvironment that points to the master (JobManager) described by the
given host name and port.
- RemoteEnvironment(String, int, Configuration, String[], URL[]) - Constructor for class org.apache.flink.api.java.RemoteEnvironment
-
Creates a new RemoteEnvironment that points to the master (JobManager) described by the
given host name and port.
- RemoteExecutor - Class in org.apache.flink.client
-
The RemoteExecutor is a
PlanExecutor
that takes the program
and ships it to a remote Flink cluster for execution.
- RemoteExecutor(String, int) - Constructor for class org.apache.flink.client.RemoteExecutor
-
- RemoteExecutor(String, int, URL) - Constructor for class org.apache.flink.client.RemoteExecutor
-
- RemoteExecutor(String, URL) - Constructor for class org.apache.flink.client.RemoteExecutor
-
- RemoteExecutor(String, int, List<URL>) - Constructor for class org.apache.flink.client.RemoteExecutor
-
- RemoteExecutor(String, int, Configuration) - Constructor for class org.apache.flink.client.RemoteExecutor
-
- RemoteExecutor(String, int, Configuration, URL) - Constructor for class org.apache.flink.client.RemoteExecutor
-
- RemoteExecutor(String, Configuration, URL) - Constructor for class org.apache.flink.client.RemoteExecutor
-
- RemoteExecutor(String, int, Configuration, List<URL>, List<URL>) - Constructor for class org.apache.flink.client.RemoteExecutor
-
- RemoteExecutor(InetSocketAddress, Configuration, List<URL>, List<URL>) - Constructor for class org.apache.flink.client.RemoteExecutor
-
- RemoteFencedMessage<F extends Serializable,P extends Serializable> - Class in org.apache.flink.runtime.rpc.messages
-
- RemoteFencedMessage(F, P) - Constructor for class org.apache.flink.runtime.rpc.messages.RemoteFencedMessage
-
- RemoteHandshakeMessage - Class in org.apache.flink.runtime.rpc.messages
-
Handshake message between rpc endpoints.
- RemoteHandshakeMessage(Class<?>, int) - Constructor for class org.apache.flink.runtime.rpc.messages.RemoteHandshakeMessage
-
- RemoteInputChannel - Class in org.apache.flink.runtime.io.network.partition.consumer
-
An input channel, which requests a remote partition queue.
- RemoteInputChannel(SingleInputGate, int, ResultPartitionID, ConnectionID, ConnectionManager, TaskIOMetricGroup) - Constructor for class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
-
- RemoteInputChannel(SingleInputGate, int, ResultPartitionID, ConnectionID, ConnectionManager, int, int, TaskIOMetricGroup) - Constructor for class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
-
- RemoteRpcInvocation - Class in org.apache.flink.runtime.rpc.messages
-
Remote rpc invocation message which is used when the actor communication is remote and, thus, the
message has to be serialized.
- RemoteRpcInvocation(String, Class<?>[], Object[]) - Constructor for class org.apache.flink.runtime.rpc.messages.RemoteRpcInvocation
-
- RemoteStreamEnvironment - Class in org.apache.flink.streaming.api.environment
-
- RemoteStreamEnvironment(String, int, String...) - Constructor for class org.apache.flink.streaming.api.environment.RemoteStreamEnvironment
-
Creates a new RemoteStreamEnvironment that points to the master
(JobManager) described by the given host name and port.
- RemoteStreamEnvironment(String, int, Configuration, String...) - Constructor for class org.apache.flink.streaming.api.environment.RemoteStreamEnvironment
-
Creates a new RemoteStreamEnvironment that points to the master
(JobManager) described by the given host name and port.
- RemoteStreamEnvironment(String, int, Configuration, String[], URL[]) - Constructor for class org.apache.flink.streaming.api.environment.RemoteStreamEnvironment
-
Creates a new RemoteStreamEnvironment that points to the master
(JobManager) described by the given host name and port.
- RemoteTransportException - Exception in org.apache.flink.runtime.io.network.netty.exception
-
- RemoteTransportException(String, SocketAddress) - Constructor for exception org.apache.flink.runtime.io.network.netty.exception.RemoteTransportException
-
- RemoteTransportException(String, SocketAddress, Throwable) - Constructor for exception org.apache.flink.runtime.io.network.netty.exception.RemoteTransportException
-
- remove() - Method in class org.apache.flink.api.common.functions.util.CopyingIterator
-
- remove() - Method in class org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase.SimpleListIterable.SimpleListIterator
-
- remove() - Method in class org.apache.flink.api.common.operators.util.ListKeyGroupedIterator.ValuesIterator
-
- remove(K) - Method in interface org.apache.flink.api.common.state.BroadcastState
-
Deletes the mapping of the given key.
- remove(UK) - Method in interface org.apache.flink.api.common.state.MapState
-
Deletes the mapping of the given key.
- remove() - Method in class org.apache.flink.api.java.operators.translation.Tuple3UnwrappingIterator
-
- remove() - Method in class org.apache.flink.api.java.operators.translation.TupleUnwrappingIterator
-
- remove(UK) - Method in class org.apache.flink.contrib.streaming.state.RocksDBMapState
-
- remove() - Method in class org.apache.flink.graph.pregel.MessageIterator
-
- remove() - Method in class org.apache.flink.graph.spargel.MessageIterator
-
- remove() - Method in class org.apache.flink.hadoopcompatibility.mapred.wrapper.HadoopTupleUnwrappingIterator
-
- remove(K) - Method in class org.apache.flink.queryablestate.client.state.ImmutableMapState
-
- remove(Object) - Method in class org.apache.flink.runtime.checkpoint.StateObjectCollection
-
- remove(String) - Method in class org.apache.flink.runtime.iterative.concurrent.Broker
-
Blocking retrieval and removal of the object to share.
- remove(Object) - Method in class org.apache.flink.runtime.jobmanager.scheduler.SetQueue
-
- remove() - Method in class org.apache.flink.runtime.operators.CoGroupRawDriver.SimpleIterable.SimpleIterator
-
- remove() - Method in class org.apache.flink.runtime.operators.resettable.NonReusingBlockResettableIterator
-
- remove() - Method in class org.apache.flink.runtime.operators.resettable.SpillingResettableIterator
-
- remove() - Method in class org.apache.flink.runtime.operators.util.metrics.CountingIterator
-
- remove(N) - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateTable
-
- remove(UK) - Method in class org.apache.flink.runtime.state.heap.HeapMapState
-
- remove(N) - Method in class org.apache.flink.runtime.state.heap.NestedMapsStateTable
-
- remove(N) - Method in class org.apache.flink.runtime.state.heap.StateTable
-
Removes the mapping for the composite of active key and given namespace.
- remove(K) - Method in class org.apache.flink.runtime.state.HeapBroadcastState
-
- remove(JobID) - Method in class org.apache.flink.runtime.taskexecutor.JobManagerTable
-
- remove(ExecutionAttemptID) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlot
-
Remove the task identified by the given execution attempt id.
- remove() - Method in class org.apache.flink.runtime.util.EmptyIterator
-
- remove() - Method in class org.apache.flink.runtime.util.NonReusingKeyGroupedIterator.ValuesIterator
-
- remove() - Method in class org.apache.flink.runtime.util.NonReusingMutableToRegularIteratorWrapper
-
- remove() - Method in class org.apache.flink.runtime.util.ReusingKeyGroupedIterator.ValuesIterator
-
- remove() - Method in class org.apache.flink.runtime.util.ReusingMutableToRegularIteratorWrapper
-
- remove() - Method in class org.apache.flink.runtime.util.SingleElementIterator
-
- remove(Object) - Method in class org.apache.flink.storm.util.StormConfig
-
- remove() - Method in class org.apache.flink.streaming.examples.join.WindowJoinSampleData.GradeSource
-
- remove() - Method in class org.apache.flink.streaming.examples.join.WindowJoinSampleData.SalarySource
-
- remove() - Method in class org.apache.flink.streaming.examples.utils.ThrottledIterator
-
- remove() - Method in class org.apache.flink.streaming.experimental.SocketStreamIterator
-
- remove(int) - Method in class org.apache.flink.types.ListValue
-
- remove(Object) - Method in class org.apache.flink.types.ListValue
-
- remove(Object) - Method in class org.apache.flink.types.MapValue
-
- remove() - Method in class org.apache.flink.util.LongValueSequenceIterator
-
- remove() - Method in class org.apache.flink.util.NumberSequenceIterator
-
- remove() - Method in class org.apache.flink.util.UnionIterator
-
- removeAll(Collection<?>) - Method in class org.apache.flink.runtime.checkpoint.StateObjectCollection
-
- removeAll(Collection<?>) - Method in class org.apache.flink.runtime.jobmanager.scheduler.SetQueue
-
- removeAll(Collection<?>) - Method in class org.apache.flink.types.ListValue
-
- removeAndGetOld(N) - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateTable
-
- removeAndGetOld(N) - Method in class org.apache.flink.runtime.state.heap.NestedMapsStateTable
-
- removeAndGetOld(N) - Method in class org.apache.flink.runtime.state.heap.StateTable
-
Removes the mapping for the composite of active key and given namespace, returning the state that was
found under the entry.
- removeCloseableInternal(Closeable) - Method in class org.apache.flink.util.AbstractCloseableRegistry
-
Removes a mapping from the registry map, respecting locking.
- removeClosedBranches(List<OptimizerNode.UnclosedBranchDescriptor>) - Method in class org.apache.flink.optimizer.dag.OptimizerNode
-
- removeConfig(ConfigOption<T>) - Method in class org.apache.flink.configuration.Configuration
-
Removes given config option from the configuration.
- removeConfig(ConfigOption<T>) - Method in class org.apache.flink.configuration.DelegatingConfiguration
-
- removeConfig(ConfigOption<T>) - Method in class org.apache.flink.configuration.UnmodifiableConfiguration
-
- removeEdge(Edge<K, EV>) - Method in class org.apache.flink.graph.Graph
-
Removes all edges that match the given edge from the graph.
- removeEdges(List<Edge<K, EV>>) - Method in class org.apache.flink.graph.Graph
-
Removes all the edges that match the edges in the given data set from the graph.
- removeField(int) - Method in class org.apache.flink.types.Record
-
Removes the field at the given position.
- removeIf(Predicate<? super T>) - Method in class org.apache.flink.runtime.checkpoint.StateObjectCollection
-
- removeInputChannel(RemoteInputChannel) - Method in interface org.apache.flink.runtime.io.network.NetworkClientHandler
-
- removeInstanceListener(InstanceListener) - Method in class org.apache.flink.runtime.instance.InstanceManager
-
- removeJob(JobID) - Method in class org.apache.flink.runtime.metrics.groups.JobManagerMetricGroup
-
- removeJob(JobID) - Method in class org.apache.flink.runtime.resourcemanager.JobLeaderIdService
-
Remove the given job from being monitored by the service.
- removeJob(JobID) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
-
- removeJob(JobID) - Method in class org.apache.flink.runtime.taskexecutor.JobLeaderService
-
Remove the given job from being monitored by the job leader service.
- removeJobGraph(JobID) - Method in class org.apache.flink.runtime.dispatcher.SingleJobSubmittedJobGraphStore
-
- removeJobGraph(JobID) - Method in class org.apache.flink.runtime.jobmanager.StandaloneSubmittedJobGraphStore
-
- removeJobGraph(JobID) - Method in interface org.apache.flink.runtime.jobmanager.SubmittedJobGraphStore
-
- removeJobGraph(JobID) - Method in class org.apache.flink.runtime.jobmanager.ZooKeeperSubmittedJobGraphStore
-
- removeJobMetricsGroup(JobID, TaskManagerJobMetricGroup) - Method in class org.apache.flink.runtime.metrics.groups.TaskManagerMetricGroup
-
- removeKeyA(A) - Method in class org.apache.flink.runtime.jobmaster.slotpool.DualKeyMap
-
- removeKeyB(B) - Method in class org.apache.flink.runtime.jobmaster.slotpool.DualKeyMap
-
- removeLast() - Method in class org.apache.flink.runtime.util.IntArrayList
-
- removeLong(int) - Method in class org.apache.flink.runtime.util.LongArrayList
-
- removePath(Path) - Method in class org.apache.flink.mesos.util.MesosArtifactServer
-
- RemoveRangeIndex<T> - Class in org.apache.flink.runtime.operators.udf
-
- RemoveRangeIndex() - Constructor for class org.apache.flink.runtime.operators.udf.RemoveRangeIndex
-
- RemoveResource - Class in org.apache.flink.runtime.clusterframework.messages
-
Message sent to the ResourceManager by the JobManager to instruct to remove a resource.
- RemoveResource(ResourceID) - Constructor for class org.apache.flink.runtime.clusterframework.messages.RemoveResource
-
Constructor for a shutdown of a registered resource.
- removeResult(String) - Method in class org.apache.flink.table.client.gateway.local.ResultStore
-
- removeShutdownHook(Thread, String, Logger) - Static method in class org.apache.flink.util.ShutdownHookUtil
-
Removes a shutdown hook from the JVM.
- removeSlotListener() - Method in class org.apache.flink.runtime.instance.Instance
-
Removes the listener that receives notifications for slot availability.
- removeTask(ExecutionAttemptID) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
-
Remove the task with the given execution attempt id from its task slot.
- removeTaskMetricGroup(AbstractID) - Method in class org.apache.flink.runtime.metrics.groups.TaskManagerJobMetricGroup
-
- removeUngroupedInputs(TaggedValue) - Static method in class org.apache.flink.api.java.sca.UdfAnalyzerUtils
-
- removeUngroupedInputsFromContainer(TaggedValue) - Static method in class org.apache.flink.api.java.sca.UdfAnalyzerUtils
-
- removeVertex(Vertex<K, VV>) - Method in class org.apache.flink.graph.Graph
-
Removes the given vertex and its edges from the graph.
- removeVertexFromGroup(JobVertexID) - Method in class org.apache.flink.runtime.jobmanager.scheduler.SlotSharingGroup
-
- removeVertices(List<Vertex<K, VV>>) - Method in class org.apache.flink.graph.Graph
-
Removes the given list of vertices and its edges from the graph.
- removeWorker(Protos.TaskID) - Method in interface org.apache.flink.mesos.runtime.clusterframework.store.MesosWorkerStore
-
Remove a worker from storage.
- removeWorker(Protos.TaskID) - Method in class org.apache.flink.mesos.runtime.clusterframework.store.StandaloneMesosWorkerStore
-
- removeWorker(Protos.TaskID) - Method in class org.apache.flink.mesos.runtime.clusterframework.store.ZooKeeperMesosWorkerStore
-
- rename(Path, Path) - Method in class org.apache.flink.core.fs.FileSystem
-
Renames the file/directory src to dst.
- rename(Path, Path) - Method in class org.apache.flink.core.fs.LimitedConnectionsFileSystem
-
- rename(Path, Path) - Method in class org.apache.flink.core.fs.local.LocalFileSystem
-
- rename(Path, Path) - Method in class org.apache.flink.core.fs.SafetyNetWrapperFileSystem
-
- rename(Path, Path) - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileSystem
-
- reopen(FileInputSplit, Tuple2<Long, Long>) - Method in class org.apache.flink.api.common.io.BinaryInputFormat
-
- reopen(S, T) - Method in interface org.apache.flink.api.common.io.CheckpointableInputFormat
-
Restores the state of a parallel instance reading from an
InputFormat
.
- reopen(FileInputSplit, Long) - Method in class org.apache.flink.api.common.io.DelimitedInputFormat
-
- reopen(FileInputSplit, Tuple2<Long, Long>) - Method in class org.apache.flink.formats.avro.AvroInputFormat
-
- reopen(Iterator<T>) - Method in class org.apache.flink.runtime.operators.resettable.NonReusingBlockResettableIterator
-
- ReOpenableHashPartition<BT,PT> - Class in org.apache.flink.runtime.operators.hash
-
- ReOpenableMutableHashTable<BT,PT> - Class in org.apache.flink.runtime.operators.hash
-
- ReOpenableMutableHashTable(TypeSerializer<BT>, TypeSerializer<PT>, TypeComparator<BT>, TypeComparator<PT>, TypePairComparator<PT, BT>, List<MemorySegment>, IOManager, boolean) - Constructor for class org.apache.flink.runtime.operators.hash.ReOpenableMutableHashTable
-
- reopenProbe(MutableObjectIterator<V2>) - Method in class org.apache.flink.runtime.operators.hash.NonReusingBuildFirstReOpenableHashJoinIterator
-
Set new input for probe side
- reopenProbe(MutableObjectIterator<V1>) - Method in class org.apache.flink.runtime.operators.hash.NonReusingBuildSecondReOpenableHashJoinIterator
-
Set new input for probe side
- reopenProbe(MutableObjectIterator<PT>) - Method in class org.apache.flink.runtime.operators.hash.ReOpenableMutableHashTable
-
- reopenProbe(MutableObjectIterator<V2>) - Method in class org.apache.flink.runtime.operators.hash.ReusingBuildFirstReOpenableHashJoinIterator
-
Set new input for probe side
- reopenProbe(MutableObjectIterator<V1>) - Method in class org.apache.flink.runtime.operators.hash.ReusingBuildSecondReOpenableHashJoinIterator
-
Set new input for probe side
- repartitionState(List<OperatorStateHandle>, int) - Method in interface org.apache.flink.runtime.checkpoint.OperatorStateRepartitioner
-
- repartitionState(List<OperatorStateHandle>, int) - Method in class org.apache.flink.runtime.checkpoint.RoundRobinOperatorStateRepartitioner
-
- repeatChar(AttributedStringBuilder, char, int) - Static method in class org.apache.flink.table.client.cli.CliUtils
-
- replace(String, int, T) - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
-
Replaces a state handle in ZooKeeper and discards the old state handle.
- replace(X) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecord
-
Replace the currently stored value by the given new value.
- replace(X, long) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecord
-
Replace the currently stored value by the given new value and the currently stored
timestamp with the new timestamp.
- replaceNonWordChars(StringValue, char) - Static method in class org.apache.flink.util.StringValueUtils
-
Replaces all non-word characters in a string by a given character.
- ReplicatingInputFormat<OT,S extends InputSplit> - Class in 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>) - Constructor for class org.apache.flink.api.common.io.ReplicatingInputFormat
-
- ReplicatingInputSplitAssigner - Class in org.apache.flink.api.common.io
-
Assigns each InputSplit to each requesting parallel instance.
- ReplicatingInputSplitAssigner(Collection<InputSplit>) - Constructor for class org.apache.flink.api.common.io.ReplicatingInputSplitAssigner
-
- ReplicatingInputSplitAssigner(InputSplit[]) - Constructor for class org.apache.flink.api.common.io.ReplicatingInputSplitAssigner
-
- report() - Method in class org.apache.flink.dropwizard.ScheduledDropwizardReporter
-
- report() - Method in class org.apache.flink.metrics.datadog.DatadogHttpReporter
-
- report() - Method in interface org.apache.flink.metrics.reporter.Scheduled
-
Report the current measurements.
- report() - Method in class org.apache.flink.metrics.slf4j.Slf4jReporter
-
- report() - Method in class org.apache.flink.metrics.statsd.StatsDReporter
-
- reportActiveConnection() - Method in class org.apache.flink.queryablestate.network.stats.AtomicKvStateRequestStats
-
- reportActiveConnection() - Method in class org.apache.flink.queryablestate.network.stats.DisabledKvStateRequestStats
-
- reportActiveConnection() - Method in interface org.apache.flink.queryablestate.network.stats.KvStateRequestStats
-
Reports an active connection.
- reporter - Variable in class org.apache.flink.dropwizard.ScheduledDropwizardReporter
-
- REPORTER_CLASS - Static variable in class org.apache.flink.configuration.MetricOptions
-
- REPORTER_CONFIG_PARAMETER - Static variable in class org.apache.flink.configuration.MetricOptions
-
- REPORTER_INTERVAL - Static variable in class org.apache.flink.configuration.MetricOptions
-
- reporterIndex - Variable in class org.apache.flink.runtime.metrics.groups.FrontMetricGroup
-
- reportError(Throwable) - Method in class org.apache.flink.streaming.connectors.kafka.internal.Handover
-
Reports an exception.
- reportError(Throwable) - Method in class org.apache.flink.streaming.connectors.kafka.internals.ExceptionProxy
-
Sets the exception and interrupts the target thread,
if no other exception has occurred so far.
- REPORTERS_LIST - Static variable in class org.apache.flink.configuration.MetricOptions
-
An optional list of reporter names.
- reportFailedRequest() - Method in class org.apache.flink.queryablestate.network.stats.AtomicKvStateRequestStats
-
- reportFailedRequest() - Method in class org.apache.flink.queryablestate.network.stats.DisabledKvStateRequestStats
-
- reportFailedRequest() - Method in interface org.apache.flink.queryablestate.network.stats.KvStateRequestStats
-
Reports a failure during a request.
- reportHeartBeat() - Method in class org.apache.flink.runtime.instance.Instance
-
Updates the time of last received heart beat to the current system time.
- reportHeartBeat(InstanceID) - Method in class org.apache.flink.runtime.instance.InstanceManager
-
- reportInactiveConnection() - Method in class org.apache.flink.queryablestate.network.stats.AtomicKvStateRequestStats
-
- reportInactiveConnection() - Method in class org.apache.flink.queryablestate.network.stats.DisabledKvStateRequestStats
-
- reportInactiveConnection() - Method in interface org.apache.flink.queryablestate.network.stats.KvStateRequestStats
-
Reports an inactive connection.
- reportLatency(LatencyMarker) - Method in class org.apache.flink.streaming.util.LatencyStats
-
- reportOrForwardLatencyMarker(LatencyMarker) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- reportOrForwardLatencyMarker(LatencyMarker) - Method in class org.apache.flink.streaming.api.operators.StreamSink
-
- reportPayload(ResourceID, I) - Method in interface org.apache.flink.runtime.heartbeat.HeartbeatListener
-
Callback which is called whenever a heartbeat with an associated payload is received.
- reportRequest() - Method in class org.apache.flink.queryablestate.network.stats.AtomicKvStateRequestStats
-
- reportRequest() - Method in class org.apache.flink.queryablestate.network.stats.DisabledKvStateRequestStats
-
- reportRequest() - Method in interface org.apache.flink.queryablestate.network.stats.KvStateRequestStats
-
Reports an incoming request.
- reportSlotStatus(InstanceID, SlotReport) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
-
Reports the current slot allocations for a task manager identified by the given instance id.
- reportSuccessfulRequest(long) - Method in class org.apache.flink.queryablestate.network.stats.AtomicKvStateRequestStats
-
- reportSuccessfulRequest(long) - Method in class org.apache.flink.queryablestate.network.stats.DisabledKvStateRequestStats
-
- reportSuccessfulRequest(long) - Method in interface org.apache.flink.queryablestate.network.stats.KvStateRequestStats
-
Reports a successfully handled request.
- reportTaskStateSnapshots(CheckpointMetaData, CheckpointMetrics, TaskStateSnapshot, TaskStateSnapshot) - Method in interface org.apache.flink.runtime.state.TaskStateManager
-
Report the state snapshots for the operator instances running in the owning task.
- reportTaskStateSnapshots(CheckpointMetaData, CheckpointMetrics, TaskStateSnapshot, TaskStateSnapshot) - Method in class org.apache.flink.runtime.state.TaskStateManagerImpl
-
- requestBlobServerPort(Time) - Method in class org.apache.flink.runtime.akka.AkkaJobManagerGateway
-
- requestBlobServerPort(Time) - Method in interface org.apache.flink.runtime.jobmaster.JobManagerGateway
-
Requests the BlobServer port.
- RequestBody - Interface in org.apache.flink.runtime.rest.messages
-
Marker interface for all requests of the REST API.
- requestBuffer() - Method in interface org.apache.flink.runtime.io.network.buffer.BufferProvider
-
Returns a
Buffer
instance from the buffer provider, if one is available.
- requestBuffer() - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
-
Requests buffer from input channel directly for receiving network data.
- requestBufferBlocking() - Method in interface org.apache.flink.runtime.io.network.buffer.BufferProvider
-
Returns a
Buffer
instance from the buffer provider.
- requestBufferBuilderBlocking() - Method in interface org.apache.flink.runtime.io.network.buffer.BufferProvider
-
- requestClassloadingProps(JobID, Time) - Method in class org.apache.flink.runtime.akka.AkkaJobManagerGateway
-
- requestClassloadingProps(JobID, Time) - Method in interface org.apache.flink.runtime.jobmaster.JobManagerGateway
-
Requests the class loading properties for the given JobID.
- requestClassloadingProps() - Method in class org.apache.flink.runtime.jobmaster.JobMaster
-
- requestClassloadingProps() - Method in interface org.apache.flink.runtime.jobmaster.JobMasterGateway
-
Request the classloading props of this job.
- requestClusterOverview(Time) - Method in class org.apache.flink.runtime.akka.AkkaJobManagerGateway
-
- requestClusterOverview(Time) - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
-
- requestClusterOverview(Time) - Method in interface org.apache.flink.runtime.webmonitor.RestfulGateway
-
Requests the cluster status overview.
- RequestDoneCallback<T> - Interface in org.apache.flink.runtime.io.disk.iomanager
-
Callback to be executed on completion of an asynchronous I/O request.
- RequestedGlobalProperties - Class in org.apache.flink.optimizer.dataproperties
-
This class represents the global properties of the data that are requested by an operator.
- RequestedGlobalProperties() - Constructor for class org.apache.flink.optimizer.dataproperties.RequestedGlobalProperties
-
Initializes the global properties with no partitioning.
- RequestedLocalProperties - Class in org.apache.flink.optimizer.dataproperties
-
This class represents the local properties of the data that are requested by an operator.
- RequestedLocalProperties() - Constructor for class org.apache.flink.optimizer.dataproperties.RequestedLocalProperties
-
Default constructor for trivial local properties.
- RequestedLocalProperties(Ordering) - Constructor for class org.apache.flink.optimizer.dataproperties.RequestedLocalProperties
-
Creates interesting properties for the given ordering.
- RequestedLocalProperties(FieldSet) - Constructor for class org.apache.flink.optimizer.dataproperties.RequestedLocalProperties
-
Creates interesting properties for the given grouping.
- requestFailed(T, IOException) - Method in class org.apache.flink.runtime.io.disk.iomanager.QueuingCallback
-
- requestFailed(T, IOException) - Method in interface org.apache.flink.runtime.io.disk.iomanager.RequestDoneCallback
-
- RequestFailure - Class in org.apache.flink.queryablestate.network.messages
-
A message indicating a protocol-related error.
- RequestFailure(long, Throwable) - Constructor for class org.apache.flink.queryablestate.network.messages.RequestFailure
-
- requestFileUpload(ResourceManagerGateway, ResourceID) - Method in class org.apache.flink.runtime.rest.handler.taskmanager.AbstractTaskManagerFileHandler
-
- requestFileUpload(ResourceManagerGateway, ResourceID) - Method in class org.apache.flink.runtime.rest.handler.taskmanager.TaskManagerLogFileHandler
-
- requestFileUpload(ResourceManagerGateway, ResourceID) - Method in class org.apache.flink.runtime.rest.handler.taskmanager.TaskManagerStdoutFileHandler
-
- requestFileUpload(FileType, Time) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutor
-
- requestFileUpload(FileType, Time) - Method in interface org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
-
Requests the file upload of the specified type to the cluster's
BlobServer
.
- RequestHandler - Interface in org.apache.flink.runtime.rest.handler.legacy
-
Base interface for all request handlers.
- RequestHandlerException - Exception in org.apache.flink.runtime.rest.handler.legacy
-
Base class for request handler exceptions.
- RequestHandlerException(String) - Constructor for exception org.apache.flink.runtime.rest.handler.legacy.RequestHandlerException
-
- requestHeartbeat(ResourceID, I) - Method in class org.apache.flink.runtime.heartbeat.HeartbeatManagerImpl
-
- requestHeartbeat(ResourceID, I) - Method in interface org.apache.flink.runtime.heartbeat.HeartbeatTarget
-
Requests a heartbeat from the target.
- requestIFEQLoopModification() - Method in class org.apache.flink.api.java.sca.ModifiedASMAnalyzer
-
- requestIFNELoopModification() - Method in class org.apache.flink.api.java.sca.ModifiedASMAnalyzer
-
- RequestIndexer - Interface in org.apache.flink.streaming.connectors.elasticsearch
-
Users add multiple
ActionRequests
to a
RequestIndexer
to prepare
them for sending to an Elasticsearch cluster.
- RequestIndexer - Interface in org.apache.flink.streaming.connectors.elasticsearch2
-
- requestJob(JobID, Time) - Method in class org.apache.flink.runtime.akka.AkkaJobManagerGateway
-
- requestJob(JobID, Time) - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
-
- requestJob(JobID, Time) - Method in interface org.apache.flink.runtime.dispatcher.DispatcherGateway
-
- requestJob(Time) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
-
- requestJob(Time) - Method in interface org.apache.flink.runtime.jobmaster.JobMasterGateway
-
- requestJob(JobID, Time) - Method in interface org.apache.flink.runtime.webmonitor.RestfulGateway
-
- requestJobDetails(Time) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
-
- requestJobDetails(Time) - Method in interface org.apache.flink.runtime.jobmaster.JobMasterGateway
-
Request the details of the executed job.
- RequestJobDetails - Class in org.apache.flink.runtime.messages.webmonitor
-
This message requests an overview of the jobs on the JobManager,
including running jobs and/or finished jobs.
- RequestJobDetails(boolean, boolean) - Constructor for class org.apache.flink.runtime.messages.webmonitor.RequestJobDetails
-
- requestJobResult(JobID) - Method in class org.apache.flink.client.program.MiniClusterClient
-
- requestJobResult(JobID) - Method in interface org.apache.flink.client.program.NewClusterClient
-
- requestJobResult(JobID) - Method in class org.apache.flink.client.program.rest.RestClusterClient
-
- requestJobResult(JobID, Time) - Method in class org.apache.flink.runtime.akka.AkkaJobManagerGateway
-
- requestJobResult(JobID, Time) - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
-
- requestJobResult(JobID, Time) - Method in class org.apache.flink.runtime.dispatcher.MiniDispatcher
-
- requestJobResult(JobID) - Method in class org.apache.flink.runtime.minicluster.MiniCluster
-
- requestJobResult(JobID, Time) - Method in interface org.apache.flink.runtime.webmonitor.RestfulGateway
-
Requests the
JobResult
of a job specified by the given jobId.
- requestJobsOverview(Time) - Method in class org.apache.flink.runtime.akka.AkkaJobManagerGateway
-
- requestJobsOverview(Time) - Method in interface org.apache.flink.runtime.jobmaster.JobManagerGateway
-
Requests the job overview from the JobManager.
- RequestJobsOverview - Class in org.apache.flink.runtime.messages.webmonitor
-
This message requests an overview of how many jobs are in which status.
- requestJobStatus(JobID, Time) - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
-
- requestJobStatus(Time) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
-
- requestJobStatus(Time) - Method in interface org.apache.flink.runtime.jobmaster.JobMasterGateway
-
Requests the current job status.
- requestJobStatus(JobID, Time) - Method in interface org.apache.flink.runtime.webmonitor.RestfulGateway
-
- RequestJobsWithIDsOverview - Class in org.apache.flink.runtime.messages.webmonitor
-
This message requests an overview of how many jobs are in which status.
- requestKvStateLocation(JobID, String) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
-
- requestKvStateLocation(JobID, String) - Method in interface org.apache.flink.runtime.jobmaster.KvStateLocationOracle
-
- requestKvStateLocation(JobID, String) - Method in class org.apache.flink.runtime.taskmanager.ActorGatewayKvStateLocationOracle
-
- requestMemorySegment() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
-
- requestMemorySegments(int) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
-
- requestMetricQueryServicePaths(Time) - Method in class org.apache.flink.runtime.akka.AkkaJobManagerGateway
-
- requestMetricQueryServicePaths(Time) - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
-
- requestMetricQueryServicePaths(Time) - Method in interface org.apache.flink.runtime.webmonitor.RestfulGateway
-
- requestMultipleJobDetails(Time) - Method in class org.apache.flink.runtime.akka.AkkaJobManagerGateway
-
- requestMultipleJobDetails(Time) - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
-
- requestMultipleJobDetails(Time) - Method in interface org.apache.flink.runtime.webmonitor.RestfulGateway
-
Requests job details currently being executed on the Flink cluster.
- requestNewWorkers(int) - Method in class org.apache.flink.mesos.runtime.clusterframework.MesosFlinkResourceManager
-
Plan for some additional workers to be launched.
- requestNewWorkers(int) - Method in class org.apache.flink.runtime.clusterframework.FlinkResourceManager
-
Requests to allocate a certain number of new workers.
- requestNewWorkers(int) - Method in class org.apache.flink.runtime.clusterframework.standalone.StandaloneResourceManager
-
- requestNewWorkers(int) - Method in class org.apache.flink.yarn.YarnFlinkResourceManager
-
- requestNextInputSplit(JobVertexID, ExecutionAttemptID) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
-
- requestNextInputSplit(JobVertexID, ExecutionAttemptID) - Method in interface org.apache.flink.runtime.jobmaster.JobMasterGateway
-
- requestOperatorBackPressureStats(JobID, JobVertexID) - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
-
- requestOperatorBackPressureStats(JobVertexID) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
-
- requestOperatorBackPressureStats(JobVertexID) - Method in interface org.apache.flink.runtime.jobmaster.JobMasterGateway
-
Requests the statistics on operator back pressure.
- requestOperatorBackPressureStats(JobID, JobVertexID) - Method in interface org.apache.flink.runtime.webmonitor.RestfulGateway
-
Requests the statistics on operator back pressure.
- requestPartitionProducerState(JobID, IntermediateDataSetID, ResultPartitionID) - Method in interface org.apache.flink.runtime.io.network.netty.PartitionProducerStateChecker
-
Requests the execution state of the execution producing a result partition.
- requestPartitionProducerState(JobID, IntermediateDataSetID, ResultPartitionID) - Method in class org.apache.flink.runtime.taskexecutor.rpc.RpcPartitionStateChecker
-
- requestPartitionProducerState(JobID, IntermediateDataSetID, ResultPartitionID) - Method in class org.apache.flink.runtime.taskmanager.ActorGatewayPartitionProducerStateChecker
-
- requestPartitions() - Method in interface org.apache.flink.runtime.io.network.partition.consumer.InputGate
-
- requestPartitions() - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
-
- requestPartitions() - Method in class org.apache.flink.runtime.io.network.partition.consumer.UnionInputGate
-
- requestPartitionState(IntermediateDataSetID, ResultPartitionID) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
-
- requestPartitionState(IntermediateDataSetID, ResultPartitionID) - Method in interface org.apache.flink.runtime.jobmaster.JobMasterGateway
-
Requests the current state of the partition.
- requestQueue - Variable in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousFileIOChannel
-
A request queue for submitting asynchronous requests to the corresponding IO worker thread.
- RequestQueue<E> - Class in org.apache.flink.runtime.io.disk.iomanager
-
- RequestQueue() - Constructor for class org.apache.flink.runtime.io.disk.iomanager.RequestQueue
-
- requestResourceOverview(Time) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
-
- requestResourceOverview(Time) - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
-
Requests the resource overview.
- requestRestAddress(Time) - Method in class org.apache.flink.runtime.akka.AkkaJobManagerGateway
-
- requestRestAddress(Time) - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
-
- requestRestAddress(Time) - Method in interface org.apache.flink.runtime.webmonitor.RestfulGateway
-
- requestSlot(JobMasterId, SlotRequest, Time) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
-
- requestSlot(JobMasterId, SlotRequest, Time) - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
-
Requests a slot from the resource manager.
- requestSlot(SlotID, JobID, AllocationID, String, ResourceManagerId, Time) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutor
-
- requestSlot(SlotID, JobID, AllocationID, String, ResourceManagerId, Time) - Method in interface org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
-
Requests a slot from the TaskManager.
- requestsNotReturned - Variable in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousFileIOChannel
-
An atomic integer that counts the number of requests that we still wait for to return.
- requestStackTrace(Time) - Method in class org.apache.flink.runtime.jobmanager.slots.ActorTaskManagerGateway
-
- requestStackTrace(Time) - Method in interface org.apache.flink.runtime.jobmanager.slots.TaskManagerGateway
-
Request the stack trace from the task manager.
- requestStackTrace(Time) - Method in class org.apache.flink.runtime.jobmaster.RpcTaskManagerGateway
-
- requestStackTraceSample(int, int, Time, int, Time) - Method in class org.apache.flink.runtime.executiongraph.Execution
-
Request a stack trace sample from the task of this execution.
- requestStackTraceSample(ExecutionAttemptID, int, int, Time, int, Time) - Method in class org.apache.flink.runtime.jobmanager.slots.ActorTaskManagerGateway
-
- requestStackTraceSample(ExecutionAttemptID, int, int, Time, int, Time) - Method in interface org.apache.flink.runtime.jobmanager.slots.TaskManagerGateway
-
Request a stack trace sample from the given task.
- requestStackTraceSample(ExecutionAttemptID, int, int, Time, int, Time) - Method in class org.apache.flink.runtime.jobmaster.RpcTaskManagerGateway
-
- requestStackTraceSample(ExecutionAttemptID, int, int, Time, int, Time) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutor
-
- requestStackTraceSample(ExecutionAttemptID, int, int, Time, int, Time) - Method in interface org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
-
- RequestStatusOverview - Class in org.apache.flink.runtime.messages.webmonitor
-
This message requests an overview of the status, such as how many TaskManagers
are currently connected, how many slots are available, how many are free, ...
- requestSubpartition(ResultPartitionID, int, RemoteInputChannel, int) - Method in class org.apache.flink.runtime.io.network.netty.PartitionRequestClient
-
Requests a remote intermediate result partition queue.
- requestSubpartition(int) - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
-
Requests a remote subpartition.
- requestSubpartitionView(ResultPartitionProvider, ResultPartitionID, int) - Method in interface org.apache.flink.runtime.io.network.NetworkSequenceViewReader
-
- requestSuccessful(T) - Method in class org.apache.flink.runtime.io.disk.iomanager.QueuingCallback
-
- requestSuccessful(T) - Method in interface org.apache.flink.runtime.io.disk.iomanager.RequestDoneCallback
-
- requestTaskManagerFileUpload(ResourceID, FileType, Time) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
-
- requestTaskManagerFileUpload(ResourceID, FileType, Time) - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
-
- requestTaskManagerInfo(Time) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
-
- requestTaskManagerInfo(ResourceID, Time) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
-
- requestTaskManagerInfo(Time) - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
-
- requestTaskManagerInfo(ResourceID, Time) - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
-
- requestTaskManagerInstance(ResourceID, Time) - Method in class org.apache.flink.runtime.akka.AkkaJobManagerGateway
-
- requestTaskManagerInstance(ResourceID, Time) - Method in interface org.apache.flink.runtime.jobmaster.JobManagerGateway
-
Requests the TaskManager instance registered under the given instanceId from the JobManager.
- requestTaskManagerInstances(Time) - Method in class org.apache.flink.runtime.akka.AkkaJobManagerGateway
-
- requestTaskManagerInstances(Time) - Method in interface org.apache.flink.runtime.jobmaster.JobManagerGateway
-
Requests all currently registered TaskManager instances from the JobManager.
- requestTaskManagerLog(Time) - Method in class org.apache.flink.runtime.jobmanager.slots.ActorTaskManagerGateway
-
- requestTaskManagerLog(Time) - Method in interface org.apache.flink.runtime.jobmanager.slots.TaskManagerGateway
-
Request the task manager log from the task manager.
- requestTaskManagerLog(Time) - Method in class org.apache.flink.runtime.jobmaster.RpcTaskManagerGateway
-
- requestTaskManagerMetricQueryServicePaths(Time) - Method in class org.apache.flink.runtime.akka.AkkaJobManagerGateway
-
- requestTaskManagerMetricQueryServicePaths(Time) - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
-
- requestTaskManagerMetricQueryServicePaths(Time) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
-
- requestTaskManagerMetricQueryServicePaths(Time) - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
-
- requestTaskManagerMetricQueryServicePaths(Time) - Method in interface org.apache.flink.runtime.webmonitor.RestfulGateway
-
- requestTaskManagerStdout(Time) - Method in class org.apache.flink.runtime.jobmanager.slots.ActorTaskManagerGateway
-
- requestTaskManagerStdout(Time) - Method in interface org.apache.flink.runtime.jobmanager.slots.TaskManagerGateway
-
Request the task manager stdout from the task manager.
- requestTaskManagerStdout(Time) - Method in class org.apache.flink.runtime.jobmaster.RpcTaskManagerGateway
-
- requestTermination() - Method in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
-
- requestTermination() - Method in class org.apache.flink.runtime.iterative.task.IterationSynchronizationSinkTask
-
- requestTermination() - Method in interface org.apache.flink.runtime.iterative.task.Terminable
-
- require(int) - Method in class org.apache.flink.api.java.typeutils.runtime.NoFetchingInput
-
Require makes sure that at least required number of bytes are kept in the buffer.
- requiredContext() - Method in class org.apache.flink.streaming.connectors.kafka.KafkaJsonTableSourceFactory
-
- RequiredParameters - Class in org.apache.flink.api.java.utils
-
Facility to manage required parameters in user defined functions.
- RequiredParameters() - Constructor for class org.apache.flink.api.java.utils.RequiredParameters
-
- RequiredParametersException - Exception in org.apache.flink.api.java.utils
-
- RequiredParametersException() - Constructor for exception org.apache.flink.api.java.utils.RequiredParametersException
-
- RequiredParametersException(String, List<String>) - Constructor for exception org.apache.flink.api.java.utils.RequiredParametersException
-
- RequiredParametersException(String) - Constructor for exception org.apache.flink.api.java.utils.RequiredParametersException
-
- RequiredParametersException(String, Throwable) - Constructor for exception org.apache.flink.api.java.utils.RequiredParametersException
-
- RequiredParametersException(Throwable) - Constructor for exception org.apache.flink.api.java.utils.RequiredParametersException
-
- requiresComparator() - Method in enum org.apache.flink.runtime.operators.shipping.ShipStrategyType
-
- requiresComparator() - Method in enum org.apache.flink.runtime.operators.util.LocalStrategy
-
- requiresExternalizedCheckpoints() - Method in interface org.apache.flink.runtime.checkpoint.CompletedCheckpointStore
-
This method returns whether the completed checkpoint store requires checkpoints to be
externalized.
- requiresExternalizedCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.StandaloneCompletedCheckpointStore
-
- requiresExternalizedCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.ZooKeeperCompletedCheckpointStore
-
- RequiresLeaderSessionID - Interface in org.apache.flink.runtime.messages
-
Marks messages to be sent wrapped in a
JobManagerMessages.LeaderSessionMessage
- requiresMigration(TypeDeserializer<T>) - Static method in class org.apache.flink.api.common.typeutils.CompatibilityResult
-
Returns a result that signals migration to be performed, and in the case that the preceding serializer
cannot be found or restored to read the previous data during migration, a provided convert deserializer
can be used.
- requiresMigration(TypeSerializer<T>) - Static method in class org.apache.flink.api.common.typeutils.CompatibilityResult
-
Returns a result that signals migration to be performed, and in the case that the preceding serializer
cannot be found or restored to read the previous data during migration, a provided convert serializer
can be used.
- requiresMigration() - Static method in class org.apache.flink.api.common.typeutils.CompatibilityResult
-
Returns a result that signals migration to be performed.
- reregistered(ReRegistered) - Method in class org.apache.flink.mesos.runtime.clusterframework.MesosResourceManager
-
Called when reconnected to Mesos following a failover event.
- ReRegistered - Class in org.apache.flink.mesos.scheduler.messages
-
Message sent by the callback handler to the scheduler actor
when the scheduler re-registers with a newly elected Mesos master.
- ReRegistered(Protos.MasterInfo) - Constructor for class org.apache.flink.mesos.scheduler.messages.ReRegistered
-
- reregistered(SchedulerDriver, Protos.MasterInfo) - Method in class org.apache.flink.mesos.scheduler.SchedulerProxy
-
- rescale() - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Sets the partitioning of the
DataStream
so that the output elements
are distributed evenly to a subset of instances of the next operation in a round-robin
fashion.
- rescaleJob(JobID, int) - Method in class org.apache.flink.client.program.ClusterClient
-
Rescales the specified job such that it will have the new parallelism.
- rescaleJob(JobID, int) - Method in class org.apache.flink.client.program.rest.RestClusterClient
-
- rescaleJob(JobID, int, RescalingBehaviour, Time) - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
-
- rescaleJob(int, RescalingBehaviour, Time) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
-
- rescaleJob(int, RescalingBehaviour, Time) - Method in interface org.apache.flink.runtime.jobmaster.JobMasterGateway
-
Triggers rescaling of the executed job.
- rescaleJob(JobID, int, RescalingBehaviour, Time) - Method in interface org.apache.flink.runtime.webmonitor.RestfulGateway
-
Trigger rescaling of the given job.
- rescaleOperators(Collection<JobVertexID>, int, RescalingBehaviour, Time) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
-
- rescaleOperators(Collection<JobVertexID>, int, RescalingBehaviour, Time) - Method in interface org.apache.flink.runtime.jobmaster.JobMasterGateway
-
Triggers rescaling of the given set of operators.
- RescalePartitioner<T> - Class in org.apache.flink.streaming.runtime.partitioner
-
Partitioner that distributes the data equally by cycling through the output
channels.
- RescalePartitioner() - Constructor for class org.apache.flink.streaming.runtime.partitioner.RescalePartitioner
-
- RescalingBehaviour - Enum in org.apache.flink.runtime.jobmaster
-
Definition of the rescaling behaviour.
- RescalingHandlers - Class in org.apache.flink.runtime.rest.handler.job.rescaling
-
Rest handler to trigger and poll the rescaling of a running job.
- RescalingHandlers() - Constructor for class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingHandlers
-
- RescalingHandlers.RescalingStatusHandler - Class in org.apache.flink.runtime.rest.handler.job.rescaling
-
Handler which reports the status of the rescaling operation.
- RescalingHandlers.RescalingTriggerHandler - Class in org.apache.flink.runtime.rest.handler.job.rescaling
-
Handler which triggers the rescaling of the specified job.
- rescalingParallelismQueryParameter - Variable in class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingTriggerMessageParameters
-
- RescalingParallelismQueryParameter - Class in org.apache.flink.runtime.rest.messages
-
- RescalingParallelismQueryParameter() - Constructor for class org.apache.flink.runtime.rest.messages.RescalingParallelismQueryParameter
-
- RescalingStatusHandler(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>) - Constructor for class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingHandlers.RescalingStatusHandler
-
- RescalingStatusHeaders - Class in org.apache.flink.runtime.rest.handler.job.rescaling
-
Message headers for polling the status of an ongoing rescaling operation.
- RescalingStatusMessageParameters - Class in org.apache.flink.runtime.rest.handler.job.rescaling
-
- RescalingStatusMessageParameters() - Constructor for class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingStatusMessageParameters
-
- RescalingTriggerHandler(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>) - Constructor for class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingHandlers.RescalingTriggerHandler
-
- RescalingTriggerHeaders - Class in org.apache.flink.runtime.rest.handler.job.rescaling
-
Message headers for triggering the rescaling of a job.
- RescalingTriggerMessageParameters - Class in org.apache.flink.runtime.rest.handler.job.rescaling
-
- RescalingTriggerMessageParameters() - Constructor for class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingTriggerMessageParameters
-
- ReservoirSamplerWithoutReplacement<T> - Class in org.apache.flink.api.java.sampling
-
A simple in memory implementation of Reservoir Sampling without replacement, and with only one
pass through the input iteration whose size is unpredictable.
- ReservoirSamplerWithoutReplacement(int, Random) - Constructor for class org.apache.flink.api.java.sampling.ReservoirSamplerWithoutReplacement
-
Create a new sampler with reservoir size and a supplied random number generator.
- ReservoirSamplerWithoutReplacement(int) - Constructor for class org.apache.flink.api.java.sampling.ReservoirSamplerWithoutReplacement
-
Create a new sampler with reservoir size and a default random number generator.
- ReservoirSamplerWithoutReplacement(int, long) - Constructor for class org.apache.flink.api.java.sampling.ReservoirSamplerWithoutReplacement
-
Create a new sampler with reservoir size and the seed for random number generator.
- ReservoirSamplerWithReplacement<T> - Class in org.apache.flink.api.java.sampling
-
A simple in memory implementation of Reservoir Sampling with replacement and with only one pass
through the input iteration whose size is unpredictable.
- ReservoirSamplerWithReplacement(int) - Constructor for class org.apache.flink.api.java.sampling.ReservoirSamplerWithReplacement
-
Create a sampler with fixed sample size and default random number generator.
- ReservoirSamplerWithReplacement(int, long) - Constructor for class org.apache.flink.api.java.sampling.ReservoirSamplerWithReplacement
-
Create a sampler with fixed sample size and random number generator seed.
- ReservoirSamplerWithReplacement(int, Random) - Constructor for class org.apache.flink.api.java.sampling.ReservoirSamplerWithReplacement
-
Create a sampler with fixed sample size and random number generator.
- reset() - Method in interface org.apache.flink.api.common.aggregators.Aggregator
-
Resets the internal state of the aggregator.
- reset() - Method in class org.apache.flink.api.common.aggregators.DoubleSumAggregator
-
- reset() - Method in class org.apache.flink.api.common.aggregators.LongSumAggregator
-
- reset() - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase.TerminationCriterionAggregator
-
- reset() - Method in class org.apache.flink.core.fs.FSDataInputStreamWrapper
-
- reset() - Method in class org.apache.flink.core.memory.ByteArrayInputStreamWithPos
-
- reset() - Method in class org.apache.flink.core.memory.ByteArrayOutputStreamWithPos
-
- reset() - Method in class org.apache.flink.core.testutils.OneShotLatch
-
- reset() - Method in class org.apache.flink.graph.library.Summarization.VertexGroupItem
-
Resets the fields to initial values.
- reset() - Method in class org.apache.flink.graph.types.valuearray.ByteValueArray
-
- reset() - Method in class org.apache.flink.graph.types.valuearray.CharValueArray
-
- reset() - Method in class org.apache.flink.graph.types.valuearray.DoubleValueArray
-
- reset() - Method in class org.apache.flink.graph.types.valuearray.FloatValueArray
-
- reset() - Method in class org.apache.flink.graph.types.valuearray.IntValueArray
-
- reset() - Method in class org.apache.flink.graph.types.valuearray.LongValueArray
-
- reset() - Method in class org.apache.flink.graph.types.valuearray.NullValueArray
-
- reset() - Method in class org.apache.flink.graph.types.valuearray.ShortValueArray
-
- reset() - Method in class org.apache.flink.graph.types.valuearray.StringValueArray
-
- reset() - Method in interface org.apache.flink.graph.types.valuearray.ValueArray
-
Restores the array index to when mark()
was last called.
- reset() - Method in class org.apache.flink.graph.utils.MurmurHash
-
Re-initialize the MurmurHash state.
- reset() - Method in class org.apache.flink.optimizer.dataproperties.GlobalProperties
-
This method resets the properties to a state where no properties are given.
- reset() - Method in class org.apache.flink.optimizer.dataproperties.RequestedGlobalProperties
-
This method resets the properties to a state where no properties are given.
- reset() - Method in class org.apache.flink.optimizer.dataproperties.RequestedLocalProperties
-
This method resets the local properties to a state where no properties are given.
- reset() - Method in class org.apache.flink.python.api.util.SetCache
-
Resets this SetCache, removing any cached sets.
- reset(Collection<MasterTriggerRestoreHook<?>>, Logger) - Static method in class org.apache.flink.runtime.checkpoint.hooks.MasterHooks
-
Resets the master hooks.
- reset() - Method in interface org.apache.flink.runtime.checkpoint.MasterTriggerRestoreHook
-
This method is called by the checkpoint coordinator to reset the hook when
execution is restarted in the absence of any checkpoint state.
- reset() - Method in class org.apache.flink.runtime.io.disk.SimpleCollectingOutputView
-
- reset() - Method in class org.apache.flink.runtime.operators.AbstractCachedBuildSideJoinDriver
-
- reset() - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetFirstDriver
-
- reset() - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetSecondDriver
-
- reset() - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable.HashBucketIterator
-
- reset() - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetFirstDriver
-
- reset() - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetSecondDriver
-
- reset() - Method in class org.apache.flink.runtime.operators.resettable.BlockResettableMutableObjectIterator
-
- reset() - Method in class org.apache.flink.runtime.operators.resettable.NonReusingBlockResettableIterator
-
- reset() - Method in class org.apache.flink.runtime.operators.resettable.SpillingResettableIterator
-
- reset() - Method in class org.apache.flink.runtime.operators.resettable.SpillingResettableMutableObjectIterator
-
- reset() - Method in interface org.apache.flink.runtime.operators.ResettableDriver
-
- reset() - Method in class org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
-
Resets the sort buffer back to the state where it is empty.
- reset() - Method in interface org.apache.flink.runtime.operators.sort.InMemorySorter
-
Resets the sort buffer back to the state where it is empty.
- reset() - Method in class org.apache.flink.runtime.operators.sort.NormalizedKeySorter
-
Resets the sort buffer back to the state where it is empty.
- reset() - Method in class org.apache.flink.runtime.operators.util.BloomFilter
-
- reset() - Method in class org.apache.flink.runtime.state.BoundedInputStream
-
- reset() - Method in class org.apache.flink.runtime.util.ForwardingInputStream
-
- reset() - Method in interface org.apache.flink.runtime.util.ResettableIterator
-
Resets the iterator.
- reset() - Method in interface org.apache.flink.runtime.util.ResettableMutableObjectIterator
-
Resets the iterator.
- resetAllInputs() - Method in class org.apache.flink.runtime.operators.BatchTask
-
- resetAllParts() - Method in class org.apache.flink.table.client.cli.CliView
-
Must be called when values in one or more parts have changed.
- resetConstraints() - Method in class org.apache.flink.runtime.jobmanager.scheduler.CoLocationGroup
-
- resetContextEnvironment() - Static method in class org.apache.flink.api.java.ExecutionEnvironment
-
Un-sets the context environment factory.
- resetContextEnvironment() - Static method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- resetContextEnvironments() - Static method in class org.apache.flink.api.java.ScalaShellRemoteEnvironment
-
- resetContextEnvironments() - Static method in class org.apache.flink.api.java.ScalaShellRemoteStreamEnvironment
-
- resetDate(long) - Static method in class org.apache.calcite.avatica.util.DateTimeUtils
-
Resets to epoch (1970-01-01) the "date" part of a timestamp.
- resetEndOfSuperstep() - Method in class org.apache.flink.runtime.iterative.task.SyncEventHandler
-
- resetErrorStateAndParse(byte[], int, int, byte[], T) - Method in class 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.
- resetForNewExecution(long, long) - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
- resetForNewExecution(long, long) - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
Archives the current Execution and creates a new Execution for this vertex.
- resetLocal() - Method in interface org.apache.flink.api.common.accumulators.Accumulator
-
Reset the local value.
- resetLocal() - Method in class org.apache.flink.api.common.accumulators.AverageAccumulator
-
- resetLocal() - Method in class org.apache.flink.api.common.accumulators.DoubleCounter
-
- resetLocal() - Method in class org.apache.flink.api.common.accumulators.DoubleMaximum
-
- resetLocal() - Method in class org.apache.flink.api.common.accumulators.DoubleMinimum
-
- resetLocal() - Method in class org.apache.flink.api.common.accumulators.Histogram
-
- resetLocal() - Method in class org.apache.flink.api.common.accumulators.IntCounter
-
- resetLocal() - Method in class org.apache.flink.api.common.accumulators.IntMaximum
-
- resetLocal() - Method in class org.apache.flink.api.common.accumulators.IntMinimum
-
- resetLocal() - Method in class org.apache.flink.api.common.accumulators.ListAccumulator
-
- resetLocal() - Method in class org.apache.flink.api.common.accumulators.LongCounter
-
- resetLocal() - Method in class org.apache.flink.api.common.accumulators.LongMaximum
-
- resetLocal() - Method in class org.apache.flink.api.common.accumulators.LongMinimum
-
- resetLocal() - Method in class org.apache.flink.api.common.accumulators.SerializedListAccumulator
-
- resetLocal() - Method in class org.apache.flink.api.java.Utils.ChecksumHashCode
-
- resetLocal() - Method in class org.apache.flink.examples.java.relational.EmptyFieldsCountAccumulator.VectorAccumulator
-
- resetLocal() - Method in class org.apache.flink.graph.asm.dataset.ChecksumHashCode.Checksum
-
- resetMainPart() - Method in class org.apache.flink.table.client.cli.CliView
-
Must be called when values in the main part (main header or main) have changed.
- resetNFAChanged() - Method in class org.apache.flink.cep.nfa.NFA
-
- resetOverflowBuckets() - Method in class org.apache.flink.runtime.operators.hash.InMemoryPartition
-
resets overflow bucket counters and returns freed memory and should only be used for resizing
- resetParameters() - Method in class org.apache.flink.streaming.api.functions.sink.WriteSinkFunction
-
Deprecated.
Statements to be executed after writing a batch goes here.
- resetParameters() - Method in class org.apache.flink.streaming.api.functions.sink.WriteSinkFunctionByMillis
-
Deprecated.
- resetParserState() - Method in class org.apache.flink.types.parser.FieldParser
-
Reset the state of the parser.
- resetRecordCounter() - Method in class org.apache.flink.runtime.operators.hash.InMemoryPartition
-
sets record counter to zero and should only be used on compaction partition
- resetRWViews() - Method in class org.apache.flink.runtime.operators.hash.InMemoryPartition
-
resets read and write views and should only be used on compaction partition
- resetSessionProperties() - Method in class org.apache.flink.table.client.gateway.SessionContext
-
- resetSplitState() - Method in class org.apache.flink.streaming.api.functions.source.TimestampedFileInputSplit
-
Sets the state of the split to null
.
- ResettableDriver<S extends Function,OT> - Interface in org.apache.flink.runtime.operators
-
This interface marks a Driver
as resettable, meaning that will reset part of their internal state but
otherwise reuse existing data structures.
- resettableInputs - Variable in class org.apache.flink.runtime.operators.BatchTask
-
The resettable inputs in the case where no temp barrier is needed.
- ResettableIterator<E> - Interface in org.apache.flink.runtime.util
-
The resettable iterator is a specialization of the iterator, allowing to reset the iterator and re-retrieve elements.
- ResettableMutableObjectIterator<E> - Interface in org.apache.flink.runtime.util
-
The resettable iterator is a specialization of the iterator, allowing to reset the iterator and re-retrieve elements.
- ResettableValue<T extends Value> - Interface in org.apache.flink.types
-
- resetTime(long) - Static method in class org.apache.calcite.avatica.util.DateTimeUtils
-
Resets to zero the "time" part of a timestamp.
- resolve(Path) - Method in interface org.apache.flink.mesos.util.MesosArtifactResolver
-
- resolve(Path) - Method in class org.apache.flink.mesos.util.MesosArtifactServer
-
- resolve(X) - Method in class org.apache.flink.runtime.rest.messages.MessageParameter
-
Resolves this parameter for the given value.
- resolveCheckpoint(String) - Method in class org.apache.flink.contrib.streaming.state.RocksDBStateBackend
-
- resolveCheckpoint(String) - Method in interface org.apache.flink.runtime.state.CheckpointStorage
-
Resolves the given pointer to a checkpoint/savepoint into a checkpoint location.
- resolveCheckpoint(String) - Method in class org.apache.flink.runtime.state.filesystem.AbstractFileStateBackend
-
- resolveCheckpoint(String) - Method in class org.apache.flink.runtime.state.filesystem.AbstractFsCheckpointStorage
-
- resolveCheckpoint(String) - Method in interface org.apache.flink.runtime.state.StateBackend
-
Resolves the given pointer to a checkpoint/savepoint into a checkpoint location.
- resolveCheckpointPointer(String) - Static method in class org.apache.flink.runtime.state.filesystem.AbstractFsCheckpointStorage
-
Takes the given string (representing a pointer to a checkpoint) and resolves it to a file
status for the checkpoint's metadata file.
- resolveCheckpointStorageLocation(long, CheckpointStorageLocationReference) - Method in interface org.apache.flink.runtime.state.CheckpointStorage
-
Resolves a storage location reference into a CheckpointStreamFactory.
- resolveCheckpointStorageLocation(long, CheckpointStorageLocationReference) - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStorage
-
- resolveCheckpointStorageLocation(long, CheckpointStorageLocationReference) - Method in class org.apache.flink.runtime.state.memory.MemoryBackendCheckpointStorage
-
- resolveClass(ObjectStreamClass) - Method in class org.apache.flink.util.InstantiationUtil.ClassLoaderObjectInputStream
-
- resolveCompatibilityResult(TypeSerializer<?>, Class<?>, TypeSerializerConfigSnapshot, TypeSerializer<T>) - Static method in class org.apache.flink.api.common.typeutils.CompatibilityUtil
-
Resolves the final compatibility result of two serializers by taking into account compound information,
including the preceding serializer, the preceding serializer's configuration snapshot, and the new serializer.
- resolveFromString(String) - Method in class org.apache.flink.runtime.rest.messages.MessageParameter
-
Resolves this parameter for the given string value representation.
- resolveKvStateCompatibility(RegisteredKeyedBackendStateMetaInfo.Snapshot<N, S>, TypeSerializer<N>, StateDescriptor<?, S>) - Static method in class org.apache.flink.runtime.state.RegisteredKeyedBackendStateMetaInfo
-
Checks compatibility of a restored k/v state, with the new
StateDescriptor
provided to it.
- resolvePrioritizedAlternatives(StateObjectCollection<T>, List<StateObjectCollection<T>>, BiFunction<T, T, Boolean>) - Method in class org.apache.flink.runtime.checkpoint.PrioritizedOperatorSubtaskState.Builder
-
This helper method resolves the dependencies between the ground truth of the operator state obtained from the
job manager and potential alternatives for recovery, e.g.
- resolveUndefined(boolean) - Method in enum org.apache.flink.util.TernaryBoolean
-
Gets the boolean value corresponding to this value.
- resolveUrl(String, MessageParameters) - Static method in class org.apache.flink.runtime.rest.messages.MessageParameters
-
Resolves the given URL (e.g "jobs/:jobid") using the given path/query parameters.
- Resource - Class in org.apache.flink.api.common.resources
-
Base class for resources one can specify.
- Resource(String, double, Resource.ResourceAggregateType) - Constructor for class org.apache.flink.api.common.resources.Resource
-
- resource() - Method in class org.apache.flink.runtime.rest.handler.async.AsynchronousOperationResult
-
- resource() - Method in class org.apache.flink.runtime.rest.messages.job.JobExecutionResultResponseBody
-
- resource() - Method in interface org.apache.flink.runtime.rest.messages.queue.AsynchronouslyCreatedResource
-
Returns the resource if it is available, null
otherwise.
- Resource.ResourceAggregateType - Enum in org.apache.flink.api.common.resources
-
Enum defining how resources are aggregated.
- RESOURCE_MANAGER_IPC_PORT_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- RESOURCE_MANAGER_NAME - Static variable in class org.apache.flink.runtime.clusterframework.FlinkResourceManager
-
The default name of the resource manager actor
- RESOURCE_MANAGER_NAME - Static variable in class org.apache.flink.runtime.resourcemanager.ResourceManager
-
- RESOURCE_MANAGER_RECONNECT_INTERVAL - Static variable in class org.apache.flink.configuration.JobManagerOptions
-
This option specifies the interval in order to trigger a resource manager reconnection if the connection
to the resource manager has been lost.
- ResourceActions - Interface in org.apache.flink.runtime.resourcemanager.slotmanager
-
Resource related actions which the
SlotManager
can perform.
- ResourceGuard - Class in org.apache.flink.util
-
This class is a guard for shared resources with the following invariants.
- ResourceGuard() - Constructor for class org.apache.flink.util.ResourceGuard
-
- ResourceGuard.Lease - Class in org.apache.flink.util
-
- resourceId() - Method in class org.apache.flink.runtime.clusterframework.messages.RemoveResource
-
Gets the ID under which the resource is registered (for example container ID).
- resourceId() - Method in class org.apache.flink.runtime.clusterframework.messages.ResourceRemoved
-
Gets the ID under which the resource is registered (for example container ID).
- ResourceID - Class in org.apache.flink.runtime.clusterframework.types
-
Class for Resource Ids assigned at the FlinkResourceManager.
- ResourceID(String) - Constructor for class org.apache.flink.runtime.clusterframework.types.ResourceID
-
- ResourceIDDeserializer - Class in org.apache.flink.runtime.rest.messages.json
-
- ResourceIDDeserializer() - Constructor for class org.apache.flink.runtime.rest.messages.json.ResourceIDDeserializer
-
- ResourceIDRetrievable - Interface in org.apache.flink.runtime.clusterframework.types
-
An interface to retrieve the ResourceID of an object.
- ResourceIDSerializer - Class in org.apache.flink.runtime.rest.messages.json
-
- ResourceIDSerializer() - Constructor for class org.apache.flink.runtime.rest.messages.json.ResourceIDSerializer
-
- resourceManager() - Method in class org.apache.flink.runtime.clusterframework.messages.ReconnectResourceManager
-
- resourceManager() - Method in class org.apache.flink.runtime.clusterframework.messages.RegisterResourceManager
-
- ResourceManager<WorkerType extends ResourceIDRetrievable> - Class in org.apache.flink.runtime.resourcemanager
-
ResourceManager implementation.
- ResourceManager(RpcService, String, ResourceID, ResourceManagerConfiguration, HighAvailabilityServices, HeartbeatServices, SlotManager, MetricRegistry, JobLeaderIdService, ClusterInformation, FatalErrorHandler, JobManagerMetricGroup) - Constructor for class org.apache.flink.runtime.resourcemanager.ResourceManager
-
- RESOURCEMANAGER_FRAMEWORK_NAME - Static variable in class org.apache.flink.mesos.configuration.MesosOptions
-
- RESOURCEMANAGER_FRAMEWORK_PRINCIPAL - Static variable in class org.apache.flink.mesos.configuration.MesosOptions
-
- RESOURCEMANAGER_FRAMEWORK_ROLE - Static variable in class org.apache.flink.mesos.configuration.MesosOptions
-
- RESOURCEMANAGER_FRAMEWORK_SECRET - Static variable in class org.apache.flink.mesos.configuration.MesosOptions
-
- RESOURCEMANAGER_FRAMEWORK_USER - Static variable in class org.apache.flink.mesos.configuration.MesosOptions
-
- ResourceManagerAddress - Class in org.apache.flink.runtime.jobmaster
-
Current address and fencing token of the leading ResourceManager.
- ResourceManagerAddress(String, ResourceManagerId) - Constructor for class org.apache.flink.runtime.jobmaster.ResourceManagerAddress
-
- ResourceManagerConfiguration - Class in org.apache.flink.runtime.resourcemanager
-
Resource manager configuration
- ResourceManagerConfiguration(Time, Time) - Constructor for class org.apache.flink.runtime.resourcemanager.ResourceManagerConfiguration
-
- ResourceManagerException - Exception in org.apache.flink.runtime.resourcemanager.exceptions
-
- ResourceManagerException(String) - Constructor for exception org.apache.flink.runtime.resourcemanager.exceptions.ResourceManagerException
-
- ResourceManagerException(String, Throwable) - Constructor for exception org.apache.flink.runtime.resourcemanager.exceptions.ResourceManagerException
-
- ResourceManagerException(Throwable) - Constructor for exception org.apache.flink.runtime.resourcemanager.exceptions.ResourceManagerException
-
- ResourceManagerGateway - Interface in org.apache.flink.runtime.resourcemanager
-
- ResourceManagerId - Class in org.apache.flink.runtime.resourcemanager
-
- ResourceManagerOptions - Class in org.apache.flink.configuration
-
The set of configuration options relating to the ResourceManager.
- ResourceManagerRunner - Class in org.apache.flink.runtime.resourcemanager
-
- ResourceManagerRunner(ResourceID, String, Configuration, RpcService, HighAvailabilityServices, HeartbeatServices, MetricRegistry, ClusterInformation, JobManagerMetricGroup) - Constructor for class org.apache.flink.runtime.resourcemanager.ResourceManagerRunner
-
- ResourceManagerRuntimeServices - Class in org.apache.flink.runtime.resourcemanager
-
- ResourceManagerRuntimeServices(SlotManager, JobLeaderIdService) - Constructor for class org.apache.flink.runtime.resourcemanager.ResourceManagerRuntimeServices
-
- ResourceManagerRuntimeServicesConfiguration - Class in org.apache.flink.runtime.resourcemanager
-
- ResourceManagerRuntimeServicesConfiguration(Time, SlotManagerConfiguration) - Constructor for class org.apache.flink.runtime.resourcemanager.ResourceManagerRuntimeServicesConfiguration
-
- ResourceManagerServices - Interface in org.apache.flink.runtime.resourcemanager
-
Interface which provides access to services of the ResourceManager.
- resourceOffers(ResourceOffers) - Method in class org.apache.flink.mesos.runtime.clusterframework.MesosResourceManager
-
Called when resource offers are made to the framework.
- ResourceOffers - Class in org.apache.flink.mesos.scheduler.messages
-
Message sent by the callback handler to the scheduler actor
when resources have been offered to this framework.
- ResourceOffers(List<Protos.Offer>) - Constructor for class org.apache.flink.mesos.scheduler.messages.ResourceOffers
-
- resourceOffers(SchedulerDriver, List<Protos.Offer>) - Method in class org.apache.flink.mesos.scheduler.SchedulerProxy
-
- ResourceOverview - Class in org.apache.flink.runtime.resourcemanager
-
Class containing information about the available cluster resources.
- ResourceOverview(int, int, int) - Constructor for class org.apache.flink.runtime.resourcemanager.ResourceOverview
-
- ResourceProfile - Class in org.apache.flink.runtime.clusterframework.types
-
Describe the immutable resource profile of the slot, either when requiring or offering it.
- ResourceProfile(double, int, int, int, int, Map<String, Resource>) - Constructor for class org.apache.flink.runtime.clusterframework.types.ResourceProfile
-
Creates a new ResourceProfile.
- ResourceProfile(double, int) - Constructor for class org.apache.flink.runtime.clusterframework.types.ResourceProfile
-
Creates a new simple ResourceProfile used for testing.
- ResourceProfile(ResourceProfile) - Constructor for class org.apache.flink.runtime.clusterframework.types.ResourceProfile
-
Creates a copy of the given ResourceProfile.
- ResourceRemoved - Class in org.apache.flink.runtime.clusterframework.messages
-
Message sent to the JobManager by the Resource Manager to inform
about the removal of a resource.
- ResourceRemoved(ResourceID, String) - Constructor for class org.apache.flink.runtime.clusterframework.messages.ResourceRemoved
-
Constructor for a shutdown of a registered resource.
- resources(Protos.Resource...) - Static method in class org.apache.flink.mesos.Utils
-
Construct a list of resources.
- ResourceSpec - Class in org.apache.flink.api.common.operators
-
Describe the different resource factors of the operator with UDF.
- ResourceSpec(double, int, int, int, int, Resource...) - Constructor for class org.apache.flink.api.common.operators.ResourceSpec
-
Creates a new ResourceSpec with full resources.
- ResourceSpec.Builder - Class in org.apache.flink.api.common.operators
-
- respondAsLeader(ChannelHandlerContext, Routed, T) - Method in class org.apache.flink.runtime.rest.handler.AbstractHandler
-
- respondAsLeader(ChannelHandlerContext, Routed, T) - Method in class org.apache.flink.runtime.rest.handler.legacy.files.StaticFileServerHandler
-
- respondAsLeader(ChannelHandlerContext, Routed, JobManagerGateway) - Method in class org.apache.flink.runtime.rest.handler.legacy.TaskManagerLogHandler
-
Response when running with leading JobManager.
- respondAsLeader(ChannelHandlerContext, Routed, T) - Method in class org.apache.flink.runtime.rest.handler.RedirectHandler
-
- respondAsLeader(ChannelHandlerContext, Routed, JobManagerGateway) - Method in class org.apache.flink.runtime.webmonitor.RuntimeMonitorHandler
-
- respondNotFound(ChannelHandlerContext, HttpRequest) - Method in class org.apache.flink.runtime.rest.handler.RouterHandler
-
- respondToRequest(ChannelHandlerContext, HttpRequest, HandlerRequest<R, M>, T) - Method in class org.apache.flink.runtime.rest.handler.AbstractHandler
-
- respondToRequest(ChannelHandlerContext, HttpRequest, HandlerRequest<R, M>, T) - Method in class org.apache.flink.runtime.rest.handler.AbstractRestHandler
-
- respondToRequest(ChannelHandlerContext, HttpRequest, HandlerRequest<EmptyRequestBody, M>, RestfulGateway) - Method in class org.apache.flink.runtime.rest.handler.taskmanager.AbstractTaskManagerFileHandler
-
- ResponseBody - Interface in org.apache.flink.runtime.rest.messages
-
Marker interface for all responses of the REST API.
- responseHeaders - Variable in class org.apache.flink.runtime.rest.handler.RedirectHandler
-
- responseHeaders - Variable in class org.apache.flink.runtime.rest.RestServerEndpoint
-
- REST_CONTENT_TYPE - Static variable in enum org.apache.flink.runtime.rest.util.RestConstants
-
- restAddress - Variable in class org.apache.flink.runtime.dispatcher.Dispatcher
-
- RestAPIDocGenerator - Class in org.apache.flink.docs.rest
-
Generator for the Rest API documentation.
- RestAPIDocGenerator() - Constructor for class org.apache.flink.docs.rest.RestAPIDocGenerator
-
- restart(long) - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- restart(RestartCallback, ScheduledExecutor) - Method in class org.apache.flink.runtime.executiongraph.restart.FailureRateRestartStrategy
-
- restart(RestartCallback, ScheduledExecutor) - Method in class org.apache.flink.runtime.executiongraph.restart.FixedDelayRestartStrategy
-
- restart(RestartCallback, ScheduledExecutor) - Method in class org.apache.flink.runtime.executiongraph.restart.NoRestartStrategy
-
- restart(RestartCallback, ScheduledExecutor) - Method in interface org.apache.flink.runtime.executiongraph.restart.RestartStrategy
-
Called by the ExecutionGraph to eventually trigger a full recovery.
- RESTART_STRATEGY - Static variable in class org.apache.flink.configuration.ConfigConstants
-
Defines the restart strategy to be used.
- RESTART_STRATEGY_FAILURE_RATE_DELAY - Static variable in class org.apache.flink.configuration.ConfigConstants
-
Delay between two consecutive restart attempts in FailureRateRestartStrategy.
- RESTART_STRATEGY_FAILURE_RATE_FAILURE_RATE_INTERVAL - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- RESTART_STRATEGY_FAILURE_RATE_MAX_FAILURES_PER_INTERVAL - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- RESTART_STRATEGY_FIXED_DELAY_ATTEMPTS - Static variable in class org.apache.flink.configuration.ConfigConstants
-
Maximum number of attempts the fixed delay restart strategy will try before failing a job.
- RESTART_STRATEGY_FIXED_DELAY_DELAY - Static variable in class org.apache.flink.configuration.ConfigConstants
-
Delay between two consecutive restart attempts in FixedDelayRestartStrategy.
- RestartAllStrategy - Class in org.apache.flink.runtime.executiongraph.failover
-
- RestartAllStrategy(ExecutionGraph) - Constructor for class org.apache.flink.runtime.executiongraph.failover.RestartAllStrategy
-
Creates a new failover strategy that recovers from failures by restarting all tasks
of the execution graph.
- RestartAllStrategy.Factory - Class in org.apache.flink.runtime.executiongraph.failover
-
Factory that instantiates the RestartAllStrategy.
- RestartCallback - Interface in org.apache.flink.runtime.executiongraph.restart
-
A callback to trigger restarts, passed to the
RestartStrategy
to
trigger recovery on the ExecutionGraph.
- RestartIndividualStrategy - Class in org.apache.flink.runtime.executiongraph.failover
-
Simple failover strategy that restarts each task individually.
- RestartIndividualStrategy(ExecutionGraph) - Constructor for class org.apache.flink.runtime.executiongraph.failover.RestartIndividualStrategy
-
Creates a new failover strategy that recovers from failures by restarting only the failed task
of the execution graph.
- RestartIndividualStrategy(ExecutionGraph, Executor) - Constructor for class org.apache.flink.runtime.executiongraph.failover.RestartIndividualStrategy
-
Creates a new failover strategy that recovers from failures by restarting only the failed task
of the execution graph.
- RestartIndividualStrategy.Factory - Class in org.apache.flink.runtime.executiongraph.failover
-
Factory that instantiates the RestartAllStrategy.
- RestartPipelinedRegionStrategy - Class in org.apache.flink.runtime.executiongraph.failover
-
A failover strategy that restarts regions of the ExecutionGraph.
- RestartPipelinedRegionStrategy(ExecutionGraph) - Constructor for class org.apache.flink.runtime.executiongraph.failover.RestartPipelinedRegionStrategy
-
Creates a new failover strategy to restart pipelined regions that works on the given
execution graph and uses the execution graph's future executor to call restart actions.
- RestartPipelinedRegionStrategy(ExecutionGraph, Executor) - Constructor for class org.apache.flink.runtime.executiongraph.failover.RestartPipelinedRegionStrategy
-
Creates a new failover strategy to restart pipelined regions that works on the given
execution graph and uses the given executor to call restart actions.
- RestartPipelinedRegionStrategy.Factory - Class in org.apache.flink.runtime.executiongraph.failover
-
Factory that instantiates the RestartPipelinedRegionStrategy.
- RestartStrategies - Class in org.apache.flink.api.common.restartstrategy
-
This class defines methods to generate RestartStrategyConfigurations.
- RestartStrategies() - Constructor for class org.apache.flink.api.common.restartstrategy.RestartStrategies
-
- RestartStrategies.FailureRateRestartStrategyConfiguration - Class in org.apache.flink.api.common.restartstrategy
-
- RestartStrategies.FallbackRestartStrategyConfiguration - Class in org.apache.flink.api.common.restartstrategy
-
Restart strategy configuration that could be used by jobs to use cluster level restart
strategy.
- RestartStrategies.FixedDelayRestartStrategyConfiguration - Class in org.apache.flink.api.common.restartstrategy
-
- RestartStrategies.NoRestartStrategyConfiguration - Class in org.apache.flink.api.common.restartstrategy
-
- RestartStrategies.RestartStrategyConfiguration - Class in org.apache.flink.api.common.restartstrategy
-
- RestartStrategy - Interface in org.apache.flink.runtime.executiongraph.restart
-
- RestartStrategyFactory - Class in org.apache.flink.runtime.executiongraph.restart
-
- RestartStrategyFactory() - Constructor for class org.apache.flink.runtime.executiongraph.restart.RestartStrategyFactory
-
- RestartTimeGauge - Class in org.apache.flink.runtime.executiongraph.metrics
-
Gauge which returns the last restarting time.
- RestartTimeGauge(ExecutionGraph) - Constructor for class org.apache.flink.runtime.executiongraph.metrics.RestartTimeGauge
-
- RestClient - Class in org.apache.flink.runtime.rest
-
- RestClient(RestClientConfiguration, Executor) - Constructor for class org.apache.flink.runtime.rest.RestClient
-
- RestClientConfiguration - Class in org.apache.flink.runtime.rest
-
- RestClientException - Exception in org.apache.flink.runtime.rest.util
-
An exception that is thrown if the failure of a REST operation was detected on the client.
- RestClientException(String, HttpResponseStatus) - Constructor for exception org.apache.flink.runtime.rest.util.RestClientException
-
- RestClientException(String, Throwable, HttpResponseStatus) - Constructor for exception org.apache.flink.runtime.rest.util.RestClientException
-
- RestClusterClient<T> - Class in org.apache.flink.client.program.rest
-
A
ClusterClient
implementation that communicates via HTTP REST requests.
- RestClusterClient(Configuration, T) - Constructor for class org.apache.flink.client.program.rest.RestClusterClient
-
- RestClusterClient(Configuration, T, LeaderRetrievalService) - Constructor for class org.apache.flink.client.program.rest.RestClusterClient
-
- RestClusterClientConfiguration - Class in org.apache.flink.client.program.rest
-
- restConfiguration - Variable in class org.apache.flink.runtime.webmonitor.WebMonitorEndpoint
-
- RestConstants - Enum in org.apache.flink.runtime.rest.util
-
This class contains constants to be used by rest components.
- RestfulGateway - Interface in org.apache.flink.runtime.webmonitor
-
Gateway for restful endpoints.
- RestHandlerConfiguration - Class in org.apache.flink.runtime.rest.handler
-
Configuration object containing values for the rest handler configuration.
- RestHandlerConfiguration(long, int, Time, File) - Constructor for class org.apache.flink.runtime.rest.handler.RestHandlerConfiguration
-
- RestHandlerException - Exception in org.apache.flink.runtime.rest.handler
-
An exception that is thrown if the failure of a REST operation was detected by a handler.
- RestHandlerException(String, HttpResponseStatus) - Constructor for exception org.apache.flink.runtime.rest.handler.RestHandlerException
-
- RestHandlerException(String, HttpResponseStatus, Throwable) - Constructor for exception org.apache.flink.runtime.rest.handler.RestHandlerException
-
- RestHandlerSpecification - Interface in org.apache.flink.runtime.rest.handler
-
Rest handler interface which all rest handler implementation have to implement.
- RestHandlerUrlComparator() - Constructor for class org.apache.flink.runtime.rest.RestServerEndpoint.RestHandlerUrlComparator
-
- RestMapperUtils - Class in org.apache.flink.runtime.rest.util
-
This class contains utilities for mapping requests and responses to/from JSON.
- RestMapperUtils() - Constructor for class org.apache.flink.runtime.rest.util.RestMapperUtils
-
- RestOptions - Class in org.apache.flink.configuration
-
Configuration parameters for REST communication.
- RestOptions() - Constructor for class org.apache.flink.configuration.RestOptions
-
- restore(Collection<KeyedStateHandle>) - Method in class org.apache.flink.contrib.streaming.state.RocksDBKeyedStateBackend
-
- restore(Collection<OperatorStateHandle>) - Method in class org.apache.flink.runtime.state.DefaultOperatorStateBackend
-
- restore(Collection<KeyedStateHandle>) - Method in class org.apache.flink.runtime.state.heap.HeapKeyedStateBackend
-
- restore(R) - Method in interface org.apache.flink.runtime.state.Snapshotable
-
Restores state that was previously snapshotted from the provided parameters.
- restoreCheckpoint(long, T) - Method in interface org.apache.flink.runtime.checkpoint.MasterTriggerRestoreHook
-
This method is called by the checkpoint coordinator prior to restoring the state of a checkpoint.
- RestoredCheckpointStatistics(long, long, boolean, String) - Constructor for class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.RestoredCheckpointStatistics
-
- RestoredCheckpointStats - Class in org.apache.flink.runtime.checkpoint
-
Statistics for a restored checkpoint.
- restoreFunctionState(StateInitializationContext, Function) - Static method in class org.apache.flink.streaming.util.functions.StreamingFunctionUtils
-
- restoreLatestCheckpointedState(Map<JobVertexID, ExecutionJobVertex>, boolean, boolean) - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
Restores the latest checkpointed state.
- restoreLatestCheckpointedState(boolean, boolean) - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
Restores the latest checkpointed state.
- restoreMasterHooks(Map<String, MasterTriggerRestoreHook<?>>, Collection<MasterState>, long, boolean, Logger) - Static method in class org.apache.flink.runtime.checkpoint.hooks.MasterHooks
-
Calls the restore method given checkpoint master hooks and passes the given master
state to them where state with a matching name is found.
- restoreSavepoint(String, boolean, Map<JobVertexID, ExecutionJobVertex>, ClassLoader) - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
Restore the state with given savepoint.
- restoreSavepoint() - Method in class org.apache.flink.runtime.jobgraph.SavepointRestoreSettings
-
Returns whether to restore from savepoint.
- restoreState(List<Long>) - Method in class org.apache.flink.sql.tests.StreamSQLTestProgram.Generator
-
- restoreState(List<Integer>) - Method in class org.apache.flink.sql.tests.StreamSQLTestProgram.KillMapper
-
- restoreState(List<T>) - Method in interface org.apache.flink.streaming.api.checkpoint.ListCheckpointed
-
Restores the state of the function or operator to that of a previous checkpoint.
- restoreState(List<Long>) - Method in class org.apache.flink.streaming.tests.BucketingSinkTestProgram.Generator
-
- restoreStateForKeyGroup(InputStream, int, ClassLoader) - Method in class org.apache.flink.streaming.api.operators.InternalTimeServiceManager
-
- restoreTimersForKeyGroup(InternalTimersSnapshot<?, ?>, int) - Method in class org.apache.flink.streaming.api.operators.HeapInternalTimerService
-
Restore the timers (both processing and event time ones) for a given keyGroupIdx
.
- RestServerEndpoint - Class in org.apache.flink.runtime.rest
-
An abstract class for netty-based REST server endpoints.
- RestServerEndpoint(RestServerEndpointConfiguration) - Constructor for class org.apache.flink.runtime.rest.RestServerEndpoint
-
- RestServerEndpoint.RestHandlerUrlComparator - Class in org.apache.flink.runtime.rest
-
Comparator for Rest URLs.
- RestServerEndpoint.RestHandlerUrlComparator.CaseInsensitiveOrderComparator - Class in org.apache.flink.runtime.rest
-
Comparator for Rest URLs.
- RestServerEndpointConfiguration - Class in org.apache.flink.runtime.rest
-
- result() - Method in interface org.apache.flink.api.java.summarize.aggregation.Aggregator
-
Provide the final result of the aggregation.
- result() - Method in class org.apache.flink.api.java.summarize.aggregation.BooleanSummaryAggregator
-
- result() - Method in class org.apache.flink.api.java.summarize.aggregation.DoubleSummaryAggregator.MaxDoubleAggregator
-
- result() - Method in class org.apache.flink.api.java.summarize.aggregation.DoubleSummaryAggregator.MinDoubleAggregator
-
- result() - Method in class org.apache.flink.api.java.summarize.aggregation.DoubleSummaryAggregator.SumDoubleAggregator
-
- result() - Method in class org.apache.flink.api.java.summarize.aggregation.FloatSummaryAggregator.MaxFloatAggregator
-
- result() - Method in class org.apache.flink.api.java.summarize.aggregation.FloatSummaryAggregator.MinFloatAggregator
-
- result() - Method in class org.apache.flink.api.java.summarize.aggregation.FloatSummaryAggregator.SumFloatAggregator
-
- result() - Method in class org.apache.flink.api.java.summarize.aggregation.IntegerSummaryAggregator.MaxIntegerAggregator
-
- result() - Method in class org.apache.flink.api.java.summarize.aggregation.IntegerSummaryAggregator.MinIntegerAggregator
-
- result() - Method in class org.apache.flink.api.java.summarize.aggregation.IntegerSummaryAggregator.SumIntegerAggregator
-
- result() - Method in class org.apache.flink.api.java.summarize.aggregation.LongSummaryAggregator.MaxLongAggregator
-
- result() - Method in class org.apache.flink.api.java.summarize.aggregation.LongSummaryAggregator.MinLongAggregator
-
- result() - Method in class org.apache.flink.api.java.summarize.aggregation.NumericSummaryAggregator
-
- result() - Method in class org.apache.flink.api.java.summarize.aggregation.ObjectSummaryAggregator
-
- result() - Method in class org.apache.flink.api.java.summarize.aggregation.ShortSummaryAggregator.MaxShortAggregator
-
- result() - Method in class org.apache.flink.api.java.summarize.aggregation.ShortSummaryAggregator.MinShortAggregator
-
- result() - Method in class org.apache.flink.api.java.summarize.aggregation.ShortSummaryAggregator.SumShortAggregator
-
- result() - Method in class org.apache.flink.api.java.summarize.aggregation.StringSummaryAggregator
-
- result() - Method in class org.apache.flink.api.java.summarize.aggregation.TupleSummaryAggregator
-
- result() - Method in class org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator
-
- Result(long, double) - Constructor for class org.apache.flink.graph.library.clustering.directed.AverageClusteringCoefficient.Result
-
Instantiate an immutable result.
- Result(long, long) - Constructor for class org.apache.flink.graph.library.clustering.directed.GlobalClusteringCoefficient.Result
-
Instantiate an immutable result.
- Result() - Constructor for class org.apache.flink.graph.library.clustering.directed.LocalClusteringCoefficient.Result
-
- Result(BigInteger...) - Constructor for class org.apache.flink.graph.library.clustering.directed.TriadicCensus.Result
-
- Result(long...) - Constructor for class org.apache.flink.graph.library.clustering.directed.TriadicCensus.Result
-
- Result() - Constructor for class org.apache.flink.graph.library.clustering.directed.TriangleListing.Result
-
- Result(long, double) - Constructor for class org.apache.flink.graph.library.clustering.undirected.AverageClusteringCoefficient.Result
-
Instantiate an immutable result.
- Result(long, long) - Constructor for class org.apache.flink.graph.library.clustering.undirected.GlobalClusteringCoefficient.Result
-
Instantiate an immutable result.
- Result() - Constructor for class org.apache.flink.graph.library.clustering.undirected.LocalClusteringCoefficient.Result
-
- Result(BigInteger...) - Constructor for class org.apache.flink.graph.library.clustering.undirected.TriadicCensus.Result
-
- Result(long...) - Constructor for class org.apache.flink.graph.library.clustering.undirected.TriadicCensus.Result
-
- Result() - Constructor for class org.apache.flink.graph.library.clustering.undirected.TriangleListing.Result
-
- Result() - Constructor for class org.apache.flink.graph.library.linkanalysis.HITS.Result
-
- Result() - Constructor for class org.apache.flink.graph.library.linkanalysis.PageRank.Result
-
- Result(long, long, long, long) - Constructor for class org.apache.flink.graph.library.metric.directed.EdgeMetrics.Result
-
- Result(long, long, long, long, long, long, long, long) - Constructor for class org.apache.flink.graph.library.metric.directed.VertexMetrics.Result
-
- Result(long, long, long, long) - Constructor for class org.apache.flink.graph.library.metric.undirected.EdgeMetrics.Result
-
- Result(long, long, long, long, long) - Constructor for class org.apache.flink.graph.library.metric.undirected.VertexMetrics.Result
-
- Result() - Constructor for class org.apache.flink.graph.library.similarity.AdamicAdar.Result
-
- Result() - Constructor for class org.apache.flink.graph.library.similarity.JaccardIndex.Result
-
- Result(StreamStateHandle, int) - Constructor for class org.apache.flink.runtime.state.SharedStateRegistry.Result
-
- RESULT_CHANGELOG - Static variable in class org.apache.flink.table.client.cli.CliStrings
-
- RESULT_DEC_REFRESH - Static variable in class org.apache.flink.table.client.cli.CliStrings
-
- RESULT_FIRST - Static variable in class org.apache.flink.table.client.cli.CliStrings
-
- RESULT_GOTO - Static variable in class org.apache.flink.table.client.cli.CliStrings
-
- RESULT_INC_REFRESH - Static variable in class org.apache.flink.table.client.cli.CliStrings
-
- RESULT_LAST - Static variable in class org.apache.flink.table.client.cli.CliStrings
-
- RESULT_LAST_PAGE - Static variable in class org.apache.flink.table.client.cli.CliStrings
-
- RESULT_LAST_REFRESH - Static variable in class org.apache.flink.table.client.cli.CliStrings
-
- RESULT_NEXT - Static variable in class org.apache.flink.table.client.cli.CliStrings
-
- RESULT_OPEN - Static variable in class org.apache.flink.table.client.cli.CliStrings
-
- RESULT_PAGE - Static variable in class org.apache.flink.table.client.cli.CliStrings
-
- RESULT_PAGE_OF - Static variable in class org.apache.flink.table.client.cli.CliStrings
-
- RESULT_PREV - Static variable in class org.apache.flink.table.client.cli.CliStrings
-
- RESULT_QUIT - Static variable in class org.apache.flink.table.client.cli.CliStrings
-
- RESULT_REFRESH - Static variable in class org.apache.flink.table.client.cli.CliStrings
-
- RESULT_REFRESH_INTERVAL - Static variable in class org.apache.flink.table.client.cli.CliStrings
-
- RESULT_REFRESH_UNKNOWN - Static variable in class org.apache.flink.table.client.cli.CliStrings
-
- RESULT_SEARCH - Static variable in class org.apache.flink.table.client.cli.CliStrings
-
- RESULT_STOPPED - Static variable in class org.apache.flink.table.client.cli.CliStrings
-
- RESULT_TABLE - Static variable in class org.apache.flink.table.client.cli.CliStrings
-
- RESULT_TITLE - Static variable in class org.apache.flink.table.client.cli.CliStrings
-
- ResultBase - Class in org.apache.flink.graph.asm.result
-
Base class for algorithm results.
- ResultBase() - Constructor for class org.apache.flink.graph.asm.result.ResultBase
-
- resultDescriptor - Variable in class org.apache.flink.table.client.cli.CliResultView
-
- ResultDescriptor - Class in org.apache.flink.table.client.gateway
-
Describes a result to be expected from a table program.
- ResultDescriptor(String, TableSchema, boolean) - Constructor for class org.apache.flink.table.client.gateway.ResultDescriptor
-
- RESULTED_NUMBER_OF_TRIANGLES - Static variable in class org.apache.flink.graph.examples.data.TriangleCountData
-
- RESULTED_SINGLE_SOURCE_SHORTEST_PATHS - Static variable in class org.apache.flink.graph.examples.data.SingleSourceShortestPathsData
-
- RESULTED_VERTICES - Static variable in class org.apache.flink.graph.examples.data.IncrementalSSSPData
-
- RESULTED_WEIGHTED_EDGES - Static variable in class org.apache.flink.graph.examples.data.EuclideanGraphData
-
- ResultFuture<OUT> - Interface in org.apache.flink.streaming.api.functions.async
-
ResultFuture
collects data / error in user codes while processing async i/o.
- resultHandler - Variable in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousFileIOChannel
-
Handler for completed requests
- resultLock - Variable in class org.apache.flink.table.client.gateway.local.CollectStreamResult
-
- ResultPartition - Class in org.apache.flink.runtime.io.network.partition
-
A result partition for data produced by a single task.
- ResultPartition(String, TaskActions, JobID, ResultPartitionID, ResultPartitionType, int, int, ResultPartitionManager, ResultPartitionConsumableNotifier, IOManager, boolean) - Constructor for class org.apache.flink.runtime.io.network.partition.ResultPartition
-
- ResultPartitionConsumableNotifier - Interface in org.apache.flink.runtime.io.network.partition
-
Interface for notifications about consumable partitions.
- ResultPartitionDeploymentDescriptor - Class in org.apache.flink.runtime.deployment
-
Deployment descriptor for a result partition.
- ResultPartitionDeploymentDescriptor(IntermediateDataSetID, IntermediateResultPartitionID, ResultPartitionType, int, int, boolean) - Constructor for class org.apache.flink.runtime.deployment.ResultPartitionDeploymentDescriptor
-
- ResultPartitionID - Class in org.apache.flink.runtime.io.network.partition
-
- ResultPartitionID() - Constructor for class org.apache.flink.runtime.io.network.partition.ResultPartitionID
-
- ResultPartitionID(IntermediateResultPartitionID, ExecutionAttemptID) - Constructor for class org.apache.flink.runtime.io.network.partition.ResultPartitionID
-
- ResultPartitionLocation - Class in org.apache.flink.runtime.deployment
-
Location of a result partition from the perspective of the consuming task.
- ResultPartitionManager - Class in org.apache.flink.runtime.io.network.partition
-
The result partition manager keeps track of all currently produced/consumed partitions of a
task manager.
- ResultPartitionManager() - Constructor for class org.apache.flink.runtime.io.network.partition.ResultPartitionManager
-
- ResultPartitionMetrics - Class in org.apache.flink.runtime.io.network.partition
-
Collects metrics of a result partition.
- ResultPartitionProvider - Interface in org.apache.flink.runtime.io.network.partition
-
Interface for creating result partitions.
- ResultPartitionType - Enum in org.apache.flink.runtime.io.network.partition
-
Type of a result partition.
- ResultPartitionWriter - Interface in org.apache.flink.runtime.io.network.api.writer
-
A buffer-oriented runtime result writer API for producing results.
- RESULTS - Static variable in class org.apache.flink.streaming.examples.iteration.util.IterateExampleData
-
- RESULTS - Static variable in class org.apache.flink.streaming.examples.ml.util.IncrementalLearningSkeletonData
-
- results - Variable in class org.apache.flink.table.client.cli.CliResultView
-
- resultScanner - Variable in class org.apache.flink.addons.hbase.AbstractTableInputFormat
-
HBase iterator wrapper.
- ResultStore - Class in org.apache.flink.table.client.gateway.local
-
Maintains dynamic results.
- ResultStore(Configuration) - Constructor for class org.apache.flink.table.client.gateway.local.ResultStore
-
- ResultSubpartition - Class in org.apache.flink.runtime.io.network.partition
-
- ResultSubpartition(int, ResultPartition) - Constructor for class org.apache.flink.runtime.io.network.partition.ResultSubpartition
-
- ResultSubpartition.BufferAndBacklog - Class in org.apache.flink.runtime.io.network.partition
-
A combination of a
Buffer
and the backlog length indicating
how many non-event buffers are available in the subpartition.
- ResultSubpartitionView - Interface in org.apache.flink.runtime.io.network.partition
-
- ResultTypeQueryable<T> - Interface in 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.
- resumeTransaction(long, short) - Method in class org.apache.flink.streaming.connectors.kafka.internal.FlinkKafkaProducer
-
Instead of obtaining producerId and epoch from the transaction coordinator, re-use previously obtained ones,
so that we can resume transaction after a restart.
- retainAll(Collection<?>) - Method in class org.apache.flink.runtime.checkpoint.StateObjectCollection
-
- retainAll(Collection<?>) - Method in class org.apache.flink.runtime.jobmanager.scheduler.SetQueue
-
- retainAll(Collection<?>) - Method in class org.apache.flink.types.ListValue
-
- retainBuffer() - Method in interface org.apache.flink.runtime.io.network.buffer.Buffer
-
Retains this buffer for further use, increasing the reference counter by 1.
- retainBuffer() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
-
- retainBuffer() - Method in class org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
-
- rethrow(Throwable) - Static method in class 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) - Static method in class 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) - Static method in class org.apache.flink.util.ExceptionUtils
-
Throws the given Throwable
in scenarios where the signatures do allow to
throw a Exception.
- rethrowException(Throwable) - Static method in class org.apache.flink.util.ExceptionUtils
-
Throws the given Throwable
in scenarios where the signatures do allow to
throw a Exception.
- rethrowIfFatalError(Throwable) - Static method in class org.apache.flink.util.ExceptionUtils
-
Rethrows the given Throwable
, if it represents an error that is fatal to the JVM.
- rethrowIfFatalErrorOrOOM(Throwable) - Static method in class 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) - Static method in class org.apache.flink.util.ExceptionUtils
-
Re-throws the given Throwable
in scenarios where the signatures allows only IOExceptions
(and RuntimeException and Error).
- retireWindow(W) - Method in class org.apache.flink.streaming.runtime.operators.windowing.MergingWindowSet
-
Removes the given window from the set of in-flight windows.
- RetrievableStateHandle<T extends Serializable> - Interface in org.apache.flink.runtime.state
-
- RetrievableStateStorageHelper<T extends Serializable> - Interface in org.apache.flink.runtime.zookeeper
-
State storage helper which is used by
ZooKeeperStateHandleStore
to persist state before
the state handle is written to ZooKeeper.
- RetrievableStreamStateHandle<T extends Serializable> - Class in org.apache.flink.runtime.state
-
Wrapper around a
StreamStateHandle
to make the referenced state object retrievable trough a simple get call.
- RetrievableStreamStateHandle(StreamStateHandle) - Constructor for class org.apache.flink.runtime.state.RetrievableStreamStateHandle
-
- RetrievableStreamStateHandle(Path, long) - Constructor for class org.apache.flink.runtime.state.RetrievableStreamStateHandle
-
- retrieve(T) - Method in interface org.apache.flink.client.deployment.ClusterDescriptor
-
Retrieves an existing Flink Cluster.
- retrieve(StandaloneClusterId) - Method in class org.apache.flink.client.deployment.LegacyStandaloneClusterDescriptor
-
- retrieve(StandaloneClusterId) - Method in class org.apache.flink.client.deployment.StandaloneClusterDescriptor
-
- retrieve(ApplicationId) - Method in class org.apache.flink.yarn.AbstractYarnClusterDescriptor
-
- retrieveBlobServerAddress(JobManagerGateway, Time) - Static method in class org.apache.flink.runtime.client.JobClient
-
Utility method to retrieve the BlobServer address from the given JobManager gateway.
- retrieveChanges() - Method in class org.apache.flink.table.client.gateway.local.ChangelogCollectStreamResult
-
- retrieveChanges() - Method in interface org.apache.flink.table.client.gateway.local.ChangelogResult
-
Retrieves the available result records.
- retrieveClassLoader(JobID, JobManagerGateway, Configuration, HighAvailabilityServices, Time) - Static method in class org.apache.flink.runtime.client.JobClient
-
Reconstructs the class loader by first requesting information about it at the JobManager
and then downloading missing jar files.
- retrieveJob(JobID) - Method in class org.apache.flink.client.program.ClusterClient
-
Reattaches to a running from the supplied job id.
- retrieveJobGraph(Configuration) - Method in class org.apache.flink.mesos.entrypoint.MesosJobClusterEntrypoint
-
- retrieveJobGraph(Configuration) - Method in class org.apache.flink.runtime.entrypoint.JobClusterEntrypoint
-
- retrieveJobGraph(Configuration) - Method in class org.apache.flink.yarn.entrypoint.YarnJobClusterEntrypoint
-
- retrieveLeaderConnectionInfo(LeaderRetrievalService, Time) - Static method in class org.apache.flink.runtime.util.LeaderRetrievalUtils
-
Retrieves the leader akka url and the current leader session ID.
- retrieveLeaderConnectionInfo(LeaderRetrievalService, FiniteDuration) - Static method in class org.apache.flink.runtime.util.LeaderRetrievalUtils
-
Retrieves the leader akka url and the current leader session ID.
- retrieveLeaderGateway(LeaderRetrievalService, ActorSystem, FiniteDuration) - Static method in class org.apache.flink.runtime.util.LeaderRetrievalUtils
-
- retrieveLeaderSessionId(LeaderRetrievalService, FiniteDuration) - Static method in class org.apache.flink.runtime.util.LeaderRetrievalUtils
-
Retrieves the current leader session id of the component identified by the given leader
retrieval service.
- retrieveLocalState(long) - Method in class org.apache.flink.runtime.state.NoOpTaskLocalStateStoreImpl
-
- retrieveLocalState(long) - Method in interface org.apache.flink.runtime.state.TaskLocalStateStore
-
Returns the local state that is stored under the given checkpoint id or null if nothing was stored under the id.
- retrieveLocalState(long) - Method in class org.apache.flink.runtime.state.TaskLocalStateStoreImpl
-
- retrievePage(int) - Method in class org.apache.flink.table.client.gateway.local.MaterializedCollectStreamResult
-
- retrievePage(int) - Method in interface org.apache.flink.table.client.gateway.local.MaterializedResult
-
Retrieves a page of a snapshotted result.
- retrievePayload(ResourceID) - Method in interface org.apache.flink.runtime.heartbeat.HeartbeatListener
-
Retrieves the payload value for the next heartbeat message.
- retrieveResultChanges(SessionContext, String) - Method in interface org.apache.flink.table.client.gateway.Executor
-
Asks for the next changelog results (non-blocking).
- retrieveResultChanges(SessionContext, String) - Method in class org.apache.flink.table.client.gateway.local.LocalExecutor
-
- retrieveResultPage(String, int) - Method in interface org.apache.flink.table.client.gateway.Executor
-
Returns the rows that are part of the current page or throws an exception if the snapshot has been expired.
- retrieveResultPage(String, int) - Method in class org.apache.flink.table.client.gateway.local.LocalExecutor
-
- retrieveService(String) - Method in class org.apache.flink.runtime.webmonitor.retriever.impl.AkkaQueryServiceRetriever
-
- retrieveService(String) - Method in interface org.apache.flink.runtime.webmonitor.retriever.MetricQueryServiceRetriever
-
- retrieveState() - Method in interface org.apache.flink.runtime.state.RetrievableStateHandle
-
Retrieves the object that was previously written to state.
- retrieveState() - Method in class org.apache.flink.runtime.state.RetrievableStreamStateHandle
-
- retriggerPartitionRequest(IntermediateResultPartitionID) - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
-
Retriggers a partition request.
- retry(Supplier<CompletableFuture<T>>, int, Executor) - Static method in class org.apache.flink.runtime.concurrent.FutureUtils
-
Retry the given operation the given number of times in case of a failure.
- retry(Object, int, FiniteDuration, ExecutionContext) - Method in interface org.apache.flink.runtime.instance.ActorGateway
-
Retries to send asynchronously a message up to numberRetries times.
- retry(Object, int, FiniteDuration, ExecutionContext) - Method in class org.apache.flink.runtime.instance.AkkaActorGateway
-
Retries to send asynchronously a message up to numberRetries times.
- RETRY_DELAY - Static variable in class org.apache.flink.configuration.RestOptions
-
The time in ms that the client waits between retries.
- RETRY_GATE_CLOSED_FOR - Static variable in class org.apache.flink.configuration.AkkaOptions
-
Milliseconds a gate should be closed for after a remote connection was disconnected.
- RETRY_MAX_ATTEMPTS - Static variable in class org.apache.flink.configuration.RestOptions
-
The number of retries the client will attempt if a retryable operations fails.
- RetryException(String) - Constructor for exception org.apache.flink.runtime.concurrent.FutureUtils.RetryException
-
- RetryException(String, Throwable) - Constructor for exception org.apache.flink.runtime.concurrent.FutureUtils.RetryException
-
- RetryException(Throwable) - Constructor for exception org.apache.flink.runtime.concurrent.FutureUtils.RetryException
-
- RetryingRegistration<F extends Serializable,G extends RpcGateway,S extends RegistrationResponse.Success> - Class in org.apache.flink.runtime.registration
-
This utility class implements the basis of registering one component at another component,
for example registering the TaskExecutor at the ResourceManager.
- RetryingRegistration(Logger, RpcService, String, Class<G>, String, F) - Constructor for class org.apache.flink.runtime.registration.RetryingRegistration
-
- RetryingRegistration(Logger, RpcService, String, Class<G>, String, F, long, long, long, long) - Constructor for class org.apache.flink.runtime.registration.RetryingRegistration
-
- RetryOnException - Annotation Type in org.apache.flink.testutils.junit
-
- RetryOnFailure - Annotation Type in org.apache.flink.testutils.junit
-
- RetryRejectedExecutionFailureHandler - Class in org.apache.flink.streaming.connectors.elasticsearch.util
-
An
ActionRequestFailureHandler
that re-adds requests that failed due to temporary
EsRejectedExecutionException
s (which means that Elasticsearch node queues are currently full),
and fails for all other failures.
- RetryRejectedExecutionFailureHandler() - Constructor for class org.apache.flink.streaming.connectors.elasticsearch.util.RetryRejectedExecutionFailureHandler
-
- RetryRule - Class in org.apache.flink.testutils.junit
-
A rule to retry failed tests for a fixed number of times.
- RetryRule() - Constructor for class org.apache.flink.testutils.junit.RetryRule
-
- retrySuccesfulWithDelay(Supplier<CompletableFuture<T>>, Time, Deadline, Predicate<T>, ScheduledExecutor) - Static method in class org.apache.flink.runtime.concurrent.FutureUtils
-
Retry the given operation with the given delay in between successful completions where the
result does not match a given predicate.
- retryWithDelay(Supplier<CompletableFuture<T>>, int, Time, Predicate<Throwable>, ScheduledExecutor) - Static method in class org.apache.flink.runtime.concurrent.FutureUtils
-
Retry the given operation with the given delay in between failures.
- retryWithDelay(Supplier<CompletableFuture<T>>, int, Time, ScheduledExecutor) - Static method in class org.apache.flink.runtime.concurrent.FutureUtils
-
Retry the given operation with the given delay in between failures.
- returnAllocatedSlot(LogicalSlot) - Method in class org.apache.flink.runtime.instance.Instance
-
Returns a slot that has been allocated from this instance.
- returnAllocatedSlot(LogicalSlot) - Method in interface org.apache.flink.runtime.jobmaster.SlotOwner
-
Return the given slot to the slot owner.
- returnExclusiveSegments(List<MemorySegment>) - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
-
The exclusive segments are recycled to network buffer pool directly when input channel is released.
- returnOperation(AbstractInsnNode, BasicValue, BasicValue) - Method in class org.apache.flink.api.java.sca.NestedMethodAnalyzer
-
- returns(Class<OUT>) - Method in class org.apache.flink.api.java.operators.SingleInputUdfOperator
-
Adds a type information hint about the return type of this operator.
- returns(TypeHint<OUT>) - Method in class org.apache.flink.api.java.operators.SingleInputUdfOperator
-
Adds a type information hint about the return type of this operator.
- returns(TypeInformation<OUT>) - Method in class org.apache.flink.api.java.operators.SingleInputUdfOperator
-
Adds a type information hint about the return type of this operator.
- returns(String) - Method in class org.apache.flink.api.java.operators.SingleInputUdfOperator
-
- returns(Class<OUT>) - Method in class org.apache.flink.api.java.operators.TwoInputUdfOperator
-
Adds a type information hint about the return type of this operator.
- returns(TypeHint<OUT>) - Method in class org.apache.flink.api.java.operators.TwoInputUdfOperator
-
Adds a type information hint about the return type of this operator.
- returns(TypeInformation<OUT>) - Method in class org.apache.flink.api.java.operators.TwoInputUdfOperator
-
Adds a type information hint about the return type of this operator.
- returns(String) - Method in class org.apache.flink.api.java.operators.TwoInputUdfOperator
-
- returns(Class<T>) - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
-
Adds a type information hint about the return type of this operator.
- returns(TypeHint<T>) - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
-
Adds a type information hint about the return type of this operator.
- returns(TypeInformation<T>) - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
-
Adds a type information hint about the return type of this operator.
- returns(String) - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
-
- reuseInputMetricsForTask() - Method in class org.apache.flink.runtime.metrics.groups.OperatorIOMetricGroup
-
Causes the containing task to use this operators input record counter.
- reuseOutputMetricsForTask() - Method in class org.apache.flink.runtime.metrics.groups.OperatorIOMetricGroup
-
Causes the containing task to use this operators output record counter.
- reuseRecordsInputCounter(Counter) - Method in class org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
-
- reuseRecordsOutputCounter(Counter) - Method in class org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
-
- ReusingBlockResettableIterator<T> - Class in org.apache.flink.runtime.operators.resettable
-
Implementation of an iterator that fetches a block of data into main memory and offers resettable
access to the data in that block.
- ReusingBlockResettableIterator(MemoryManager, Iterator<T>, TypeSerializer<T>, int, AbstractInvokable) - Constructor for class org.apache.flink.runtime.operators.resettable.ReusingBlockResettableIterator
-
- ReusingBlockResettableIterator(MemoryManager, TypeSerializer<T>, int, AbstractInvokable) - Constructor for class org.apache.flink.runtime.operators.resettable.ReusingBlockResettableIterator
-
- ReusingBuildFirstHashJoinIterator<V1,V2,O> - Class in org.apache.flink.runtime.operators.hash
-
An implementation of the
JoinTaskIterator
that uses a hybrid-hash-join
internally to match the records with equal key.
- ReusingBuildFirstHashJoinIterator(MutableObjectIterator<V1>, MutableObjectIterator<V2>, TypeSerializer<V1>, TypeComparator<V1>, TypeSerializer<V2>, TypeComparator<V2>, TypePairComparator<V2, V1>, MemoryManager, IOManager, AbstractInvokable, double, boolean, boolean, boolean) - Constructor for class org.apache.flink.runtime.operators.hash.ReusingBuildFirstHashJoinIterator
-
- ReusingBuildFirstReOpenableHashJoinIterator<V1,V2,O> - Class in org.apache.flink.runtime.operators.hash
-
- ReusingBuildFirstReOpenableHashJoinIterator(MutableObjectIterator<V1>, MutableObjectIterator<V2>, TypeSerializer<V1>, TypeComparator<V1>, TypeSerializer<V2>, TypeComparator<V2>, TypePairComparator<V2, V1>, MemoryManager, IOManager, AbstractInvokable, double, boolean, boolean, boolean) - Constructor for class org.apache.flink.runtime.operators.hash.ReusingBuildFirstReOpenableHashJoinIterator
-
- ReusingBuildSecondHashJoinIterator<V1,V2,O> - Class in org.apache.flink.runtime.operators.hash
-
An implementation of the
JoinTaskIterator
that uses a hybrid-hash-join
internally to match the records with equal key.
- ReusingBuildSecondHashJoinIterator(MutableObjectIterator<V1>, MutableObjectIterator<V2>, TypeSerializer<V1>, TypeComparator<V1>, TypeSerializer<V2>, TypeComparator<V2>, TypePairComparator<V1, V2>, MemoryManager, IOManager, AbstractInvokable, double, boolean, boolean, boolean) - Constructor for class org.apache.flink.runtime.operators.hash.ReusingBuildSecondHashJoinIterator
-
- ReusingBuildSecondReOpenableHashJoinIterator<V1,V2,O> - Class in org.apache.flink.runtime.operators.hash
-
- ReusingBuildSecondReOpenableHashJoinIterator(MutableObjectIterator<V1>, MutableObjectIterator<V2>, TypeSerializer<V1>, TypeComparator<V1>, TypeSerializer<V2>, TypeComparator<V2>, TypePairComparator<V1, V2>, MemoryManager, IOManager, AbstractInvokable, double, boolean, boolean, boolean) - Constructor for class org.apache.flink.runtime.operators.hash.ReusingBuildSecondReOpenableHashJoinIterator
-
- ReusingDeserializationDelegate<T> - Class in org.apache.flink.runtime.plugable
-
- ReusingDeserializationDelegate(TypeSerializer<T>) - Constructor for class org.apache.flink.runtime.plugable.ReusingDeserializationDelegate
-
- ReusingKeyGroupedIterator<E> - Class in org.apache.flink.runtime.util
-
The KeyValueIterator returns a key and all values that belong to the key (share the same key).
- ReusingKeyGroupedIterator(MutableObjectIterator<E>, TypeSerializer<E>, TypeComparator<E>) - Constructor for class org.apache.flink.runtime.util.ReusingKeyGroupedIterator
-
Initializes the KeyGroupedIterator.
- ReusingKeyGroupedIterator.ValuesIterator - Class in org.apache.flink.runtime.util
-
- ReusingMergeInnerJoinIterator<T1,T2,O> - Class in org.apache.flink.runtime.operators.sort
-
- ReusingMergeInnerJoinIterator(MutableObjectIterator<T1>, MutableObjectIterator<T2>, TypeSerializer<T1>, TypeComparator<T1>, TypeSerializer<T2>, TypeComparator<T2>, TypePairComparator<T1, T2>, MemoryManager, IOManager, int, AbstractInvokable) - Constructor for class org.apache.flink.runtime.operators.sort.ReusingMergeInnerJoinIterator
-
- ReusingMergeOuterJoinIterator<T1,T2,O> - Class in org.apache.flink.runtime.operators.sort
-
- ReusingMergeOuterJoinIterator(OuterJoinOperatorBase.OuterJoinType, MutableObjectIterator<T1>, MutableObjectIterator<T2>, TypeSerializer<T1>, TypeComparator<T1>, TypeSerializer<T2>, TypeComparator<T2>, TypePairComparator<T1, T2>, MemoryManager, IOManager, int, AbstractInvokable) - Constructor for class org.apache.flink.runtime.operators.sort.ReusingMergeOuterJoinIterator
-
- ReusingMutableToRegularIteratorWrapper<T> - Class in org.apache.flink.runtime.util
-
- ReusingMutableToRegularIteratorWrapper(MutableObjectIterator<T>, TypeSerializer<T>) - Constructor for class org.apache.flink.runtime.util.ReusingMutableToRegularIteratorWrapper
-
- ReusingSortMergeCoGroupIterator<T1,T2> - Class in org.apache.flink.runtime.operators.sort
-
- ReusingSortMergeCoGroupIterator(MutableObjectIterator<T1>, MutableObjectIterator<T2>, TypeSerializer<T1>, TypeComparator<T1>, TypeSerializer<T2>, TypeComparator<T2>, TypePairComparator<T1, T2>) - Constructor for class org.apache.flink.runtime.operators.sort.ReusingSortMergeCoGroupIterator
-
- reverse() - Method in class org.apache.flink.graph.Edge
-
Reverses the direction of this Edge.
- reverse() - Method in class org.apache.flink.graph.Graph
-
Reverse the direction of the edges in the graph.
- RevisionInformation(String, String) - Constructor for class org.apache.flink.runtime.util.EnvironmentInformation.RevisionInformation
-
- revokeLeadership() - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
-
Callback method when current resourceManager loses leadership.
- revokeLeadership() - Method in class org.apache.flink.runtime.jobmaster.JobManagerRunner
-
- revokeLeadership() - Method in interface org.apache.flink.runtime.leaderelection.LeaderContender
-
Callback method which is called by the
LeaderElectionService
upon revoking the
leadership of a former leader.
- revokeLeadership() - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
-
Callback method when current resourceManager loses leadership.
- revokeLeadership() - Method in class org.apache.flink.runtime.webmonitor.WebMonitorEndpoint
-
- RichAggregateFunction<IN,ACC,OUT> - Class in org.apache.flink.api.common.functions
-
- RichAggregateFunction() - Constructor for class org.apache.flink.api.common.functions.RichAggregateFunction
-
- RichAllWindowFunction<IN,OUT,W extends Window> - Class in org.apache.flink.streaming.api.functions.windowing
-
- RichAllWindowFunction() - Constructor for class org.apache.flink.streaming.api.functions.windowing.RichAllWindowFunction
-
- RichAsyncFunction<IN,OUT> - Class in org.apache.flink.streaming.api.functions.async
-
- RichAsyncFunction() - Constructor for class org.apache.flink.streaming.api.functions.async.RichAsyncFunction
-
- RichCoFlatMapFunction<IN1,IN2,OUT> - Class in org.apache.flink.streaming.api.functions.co
-
A RichCoFlatMapFunction represents a FlatMap transformation with two different input
types.
- RichCoFlatMapFunction() - Constructor for class org.apache.flink.streaming.api.functions.co.RichCoFlatMapFunction
-
- RichCoGroupFunction<IN1,IN2,OUT> - Class in org.apache.flink.api.common.functions
-
- RichCoGroupFunction() - Constructor for class org.apache.flink.api.common.functions.RichCoGroupFunction
-
- RichCoMapFunction<IN1,IN2,OUT> - Class in org.apache.flink.streaming.api.functions.co
-
A RichCoMapFunction represents a Map transformation with two different input
types.
- RichCoMapFunction() - Constructor for class org.apache.flink.streaming.api.functions.co.RichCoMapFunction
-
- RichCombineToGroupCombineWrapper<IN,OUT,F extends RichGroupReduceFunction<IN,OUT> & CombineFunction<IN,IN>> - Class in org.apache.flink.api.java.operators.translation
-
- RichCombineToGroupCombineWrapper(F) - Constructor for class org.apache.flink.api.java.operators.translation.RichCombineToGroupCombineWrapper
-
- RichCrossFunction<IN1,IN2,OUT> - Class in org.apache.flink.api.common.functions
-
- RichCrossFunction() - Constructor for class org.apache.flink.api.common.functions.RichCrossFunction
-
- RichFilterFunction<T> - Class in org.apache.flink.api.common.functions
-
- RichFilterFunction() - Constructor for class org.apache.flink.api.common.functions.RichFilterFunction
-
- RichFlatJoinFunction<IN1,IN2,OUT> - Class in org.apache.flink.api.common.functions
-
- RichFlatJoinFunction() - Constructor for class org.apache.flink.api.common.functions.RichFlatJoinFunction
-
- RichFlatMapFunction<IN,OUT> - Class in org.apache.flink.api.common.functions
-
- RichFlatMapFunction() - Constructor for class org.apache.flink.api.common.functions.RichFlatMapFunction
-
- RichFoldFunction<O,T> - Class in org.apache.flink.api.common.functions
-
- RichFoldFunction() - Constructor for class org.apache.flink.api.common.functions.RichFoldFunction
-
Deprecated.
- RichFunction - Interface in org.apache.flink.api.common.functions
-
An base interface for all rich user-defined functions.
- RichGroupCombineFunction<IN,OUT> - Class in org.apache.flink.api.common.functions
-
- RichGroupCombineFunction() - Constructor for class org.apache.flink.api.common.functions.RichGroupCombineFunction
-
- RichGroupReduceFunction<IN,OUT> - Class in org.apache.flink.api.common.functions
-
- RichGroupReduceFunction() - Constructor for class org.apache.flink.api.common.functions.RichGroupReduceFunction
-
- RichInputFormat<OT,T extends InputSplit> - Class in org.apache.flink.api.common.io
-
An abstract stub implementation for Rich input formats.
- RichInputFormat() - Constructor for class org.apache.flink.api.common.io.RichInputFormat
-
- RichJoinFunction<IN1,IN2,OUT> - Class in org.apache.flink.api.common.functions
-
- RichJoinFunction() - Constructor for class org.apache.flink.api.common.functions.RichJoinFunction
-
- RichMapFunction<IN,OUT> - Class in org.apache.flink.api.common.functions
-
- RichMapFunction() - Constructor for class org.apache.flink.api.common.functions.RichMapFunction
-
- RichMapPartitionFunction<I,O> - Class in org.apache.flink.api.common.functions
-
- RichMapPartitionFunction() - Constructor for class org.apache.flink.api.common.functions.RichMapPartitionFunction
-
- RichOutputFormat<IT> - Class in org.apache.flink.api.common.io
-
An abstract stub implementation for Rich output formats.
- RichOutputFormat() - Constructor for class org.apache.flink.api.common.io.RichOutputFormat
-
- RichParallelSourceFunction<OUT> - Class in org.apache.flink.streaming.api.functions.source
-
Base class for implementing a parallel data source.
- RichParallelSourceFunction() - Constructor for class org.apache.flink.streaming.api.functions.source.RichParallelSourceFunction
-
- RichProcessAllWindowFunction<IN,OUT,W extends Window> - Class in org.apache.flink.streaming.api.functions.windowing
-
- RichProcessAllWindowFunction() - Constructor for class org.apache.flink.streaming.api.functions.windowing.RichProcessAllWindowFunction
-
Deprecated.
- RichProcessWindowFunction<IN,OUT,KEY,W extends Window> - Class in org.apache.flink.streaming.api.functions.windowing
-
- RichProcessWindowFunction() - Constructor for class org.apache.flink.streaming.api.functions.windowing.RichProcessWindowFunction
-
Deprecated.
- RichReduceFunction<T> - Class in org.apache.flink.api.common.functions
-
- RichReduceFunction() - Constructor for class org.apache.flink.api.common.functions.RichReduceFunction
-
- RichSinkFunction<IN> - Class in org.apache.flink.streaming.api.functions.sink
-
- RichSinkFunction() - Constructor for class org.apache.flink.streaming.api.functions.sink.RichSinkFunction
-
- RichSourceFunction<OUT> - Class in org.apache.flink.streaming.api.functions.source
-
- RichSourceFunction() - Constructor for class org.apache.flink.streaming.api.functions.source.RichSourceFunction
-
- RichTranslateFunction<IN,OUT> - Class in org.apache.flink.graph.asm.translate
-
- RichTranslateFunction() - Constructor for class org.apache.flink.graph.asm.translate.RichTranslateFunction
-
- RichWindowFunction<IN,OUT,KEY,W extends Window> - Class in org.apache.flink.streaming.api.functions.windowing
-
- RichWindowFunction() - Constructor for class org.apache.flink.streaming.api.functions.windowing.RichWindowFunction
-
- right() - Method in class org.apache.flink.types.Either.Left
-
- Right(R) - Static method in class org.apache.flink.types.Either
-
Create a Right value of Either
- right() - Method in class org.apache.flink.types.Either
-
Retrieve the Right value of Either.
- Right(R) - Constructor for class org.apache.flink.types.Either.Right
-
- right() - Method in class org.apache.flink.types.Either.Right
-
- rightOuterJoin(DataSet<R>) - Method in class org.apache.flink.api.java.DataSet
-
Initiates a Right Outer Join transformation.
- rightOuterJoin(DataSet<R>, JoinOperatorBase.JoinHint) - Method in class org.apache.flink.api.java.DataSet
-
Initiates a Right Outer Join transformation.
- RightOuterJoinDriver<IT1,IT2,OT> - Class in org.apache.flink.runtime.operators
-
The right outer join driver implements the logic of an outer join operator at runtime.
- RightOuterJoinDriver() - Constructor for class org.apache.flink.runtime.operators.RightOuterJoinDriver
-
- RMatGraph - Class in org.apache.flink.graph.drivers.input
-
- RMatGraph() - Constructor for class org.apache.flink.graph.drivers.input.RMatGraph
-
- RMatGraph<T extends org.apache.commons.math3.random.RandomGenerator> - Class in org.apache.flink.graph.generator
-
- RMatGraph(ExecutionEnvironment, RandomGenerableFactory<T>, long, long) - Constructor for class org.apache.flink.graph.generator.RMatGraph
-
A directed power-law multi
graph
generated using the
stochastic Recursive Matrix (R-Mat) model.
- RMQConnectionConfig - Class in org.apache.flink.streaming.connectors.rabbitmq.common
-
Connection Configuration for RMQ.
- RMQConnectionConfig.Builder - Class in org.apache.flink.streaming.connectors.rabbitmq.common
-
- RMQSink<IN> - Class in org.apache.flink.streaming.connectors.rabbitmq
-
A Sink for publishing data into RabbitMQ.
- RMQSink(RMQConnectionConfig, String, SerializationSchema<IN>) - Constructor for class org.apache.flink.streaming.connectors.rabbitmq.RMQSink
-
- RMQSource<OUT> - Class in org.apache.flink.streaming.connectors.rabbitmq
-
RabbitMQ source (consumer) which reads from a queue and acknowledges messages on checkpoints.
- RMQSource(RMQConnectionConfig, String, DeserializationSchema<OUT>) - Constructor for class org.apache.flink.streaming.connectors.rabbitmq.RMQSource
-
Creates a new RabbitMQ source with at-least-once message processing guarantee when
checkpointing is enabled.
- RMQSource(RMQConnectionConfig, String, boolean, DeserializationSchema<OUT>) - Constructor for class org.apache.flink.streaming.connectors.rabbitmq.RMQSource
-
Creates a new RabbitMQ source.
- RNG - Static variable in class org.apache.flink.api.java.Utils
-
- ROCKSDB_LOCAL_DIRECTORIES - Static variable in class org.apache.flink.configuration.CheckpointingOptions
-
The local directory (on the TaskManager) where RocksDB puts its files.
- ROCKSDB_STATE_BACKEND_NAME - Static variable in class org.apache.flink.runtime.state.StateBackendLoader
-
The shortcut configuration name for the RocksDB State Backend
- RocksDBAggregatingState<K,N,T,ACC,R> - Class in org.apache.flink.contrib.streaming.state
-
- RocksDBAggregatingState(ColumnFamilyHandle, TypeSerializer<N>, TypeSerializer<ACC>, ACC, AggregateFunction<T, ACC, R>, RocksDBKeyedStateBackend<K>) - Constructor for class org.apache.flink.contrib.streaming.state.RocksDBAggregatingState
-
Creates a new RocksDBAggregatingState
.
- RocksDBFoldingState<K,N,T,ACC> - Class in org.apache.flink.contrib.streaming.state
-
- RocksDBFoldingState(ColumnFamilyHandle, TypeSerializer<N>, TypeSerializer<ACC>, ACC, FoldFunction<T, ACC>, RocksDBKeyedStateBackend<K>) - Constructor for class org.apache.flink.contrib.streaming.state.RocksDBFoldingState
-
Deprecated.
Creates a new RocksDBFoldingState
.
- RocksDBKeyedStateBackend<K> - Class in org.apache.flink.contrib.streaming.state
-
- RocksDBKeyedStateBackend(String, ClassLoader, File, DBOptions, ColumnFamilyOptions, TaskKvStateRegistry, TypeSerializer<K>, int, KeyGroupRange, ExecutionConfig, boolean, LocalRecoveryConfig) - Constructor for class org.apache.flink.contrib.streaming.state.RocksDBKeyedStateBackend
-
- RocksDBKeySerializationUtils - Class in org.apache.flink.contrib.streaming.state
-
Utils for RocksDB state serialization and deserialization.
- RocksDBKeySerializationUtils() - Constructor for class org.apache.flink.contrib.streaming.state.RocksDBKeySerializationUtils
-
- RocksDBListState<K,N,V> - Class in org.apache.flink.contrib.streaming.state
-
ListState
implementation that stores state in RocksDB.
- RocksDBListState(ColumnFamilyHandle, TypeSerializer<N>, TypeSerializer<List<V>>, List<V>, TypeSerializer<V>, RocksDBKeyedStateBackend<K>) - Constructor for class org.apache.flink.contrib.streaming.state.RocksDBListState
-
Creates a new RocksDBListState
.
- RocksDBMapState<K,N,UK,UV> - Class in org.apache.flink.contrib.streaming.state
-
MapState
implementation that stores state in RocksDB.
- RocksDBMapState(ColumnFamilyHandle, TypeSerializer<N>, TypeSerializer<Map<UK, UV>>, Map<UK, UV>, RocksDBKeyedStateBackend<K>) - Constructor for class org.apache.flink.contrib.streaming.state.RocksDBMapState
-
Creates a new RocksDBMapState
.
- RocksDBReducingState<K,N,V> - Class in org.apache.flink.contrib.streaming.state
-
- RocksDBReducingState(ColumnFamilyHandle, TypeSerializer<N>, TypeSerializer<V>, V, ReduceFunction<V>, RocksDBKeyedStateBackend<K>) - Constructor for class org.apache.flink.contrib.streaming.state.RocksDBReducingState
-
Creates a new RocksDBReducingState
.
- RocksDBStateBackend - Class in org.apache.flink.contrib.streaming.state
-
A State Backend that stores its state in RocksDB
.
- RocksDBStateBackend(String) - Constructor for class org.apache.flink.contrib.streaming.state.RocksDBStateBackend
-
Creates a new RocksDBStateBackend
that stores its checkpoint data in the
file system and location defined by the given URI.
- RocksDBStateBackend(String, boolean) - Constructor for class org.apache.flink.contrib.streaming.state.RocksDBStateBackend
-
Creates a new RocksDBStateBackend
that stores its checkpoint data in the
file system and location defined by the given URI.
- RocksDBStateBackend(URI) - Constructor for class org.apache.flink.contrib.streaming.state.RocksDBStateBackend
-
Creates a new RocksDBStateBackend
that stores its checkpoint data in the
file system and location defined by the given URI.
- RocksDBStateBackend(URI, boolean) - Constructor for class org.apache.flink.contrib.streaming.state.RocksDBStateBackend
-
Creates a new RocksDBStateBackend
that stores its checkpoint data in the
file system and location defined by the given URI.
- RocksDBStateBackend(StateBackend) - Constructor for class org.apache.flink.contrib.streaming.state.RocksDBStateBackend
-
Creates a new RocksDBStateBackend
that uses the given state backend to store its
checkpoint data streams.
- RocksDBStateBackend(StateBackend, TernaryBoolean) - Constructor for class org.apache.flink.contrib.streaming.state.RocksDBStateBackend
-
Creates a new RocksDBStateBackend
that uses the given state backend to store its
checkpoint data streams.
- RocksDBStateBackend(AbstractStateBackend) - Constructor for class org.apache.flink.contrib.streaming.state.RocksDBStateBackend
-
- RocksDBStateBackend(AbstractStateBackend, boolean) - Constructor for class org.apache.flink.contrib.streaming.state.RocksDBStateBackend
-
- RocksDBStateBackendFactory - Class in org.apache.flink.contrib.streaming.state
-
- RocksDBStateBackendFactory() - Constructor for class org.apache.flink.contrib.streaming.state.RocksDBStateBackendFactory
-
- RocksDBValueState<K,N,V> - Class in org.apache.flink.contrib.streaming.state
-
ValueState
implementation that stores state in RocksDB.
- RocksDBValueState(ColumnFamilyHandle, TypeSerializer<N>, TypeSerializer<V>, V, RocksDBKeyedStateBackend<K>) - Constructor for class org.apache.flink.contrib.streaming.state.RocksDBValueState
-
Creates a new RocksDBValueState
.
- RocksDBWriteBatchWrapper - Class in org.apache.flink.contrib.streaming.state
-
It's a wrapper class around RocksDB's WriteBatch
for writing in bulk.
- RocksDBWriteBatchWrapper(RocksDB) - Constructor for class org.apache.flink.contrib.streaming.state.RocksDBWriteBatchWrapper
-
- RocksDBWriteBatchWrapper(RocksDB, WriteOptions) - Constructor for class org.apache.flink.contrib.streaming.state.RocksDBWriteBatchWrapper
-
- RocksDBWriteBatchWrapper(RocksDB, WriteOptions, int) - Constructor for class org.apache.flink.contrib.streaming.state.RocksDBWriteBatchWrapper
-
- RocksIteratorWrapper - Class in org.apache.flink.contrib.streaming.state
-
This is a wrapper around RocksIterator
to check the iterator status for all the methods mentioned
to require this check in the wiki documentation: seek, next, seekToFirst, seekToLast, seekForPrev, and prev.
- RocksIteratorWrapper(RocksIterator) - Constructor for class org.apache.flink.contrib.streaming.state.RocksIteratorWrapper
-
- roles() - Method in class org.apache.flink.mesos.util.MesosConfiguration
-
Gets the roles associated with the framework.
- RollingSink<T> - Class in org.apache.flink.streaming.connectors.fs
-
- RollingSink(String) - Constructor for class org.apache.flink.streaming.connectors.fs.RollingSink
-
Deprecated.
Creates a new RollingSink
that writes files to the given base directory.
- RollingSink.BucketState - Class in org.apache.flink.streaming.connectors.fs
-
Deprecated.
This is used for keeping track of the current in-progress files and files that we mark
for moving from pending to final location after we get a checkpoint-complete notification.
- rollOverReusingResources() - Method in interface org.apache.flink.streaming.runtime.io.BufferBlocker
-
Starts a new sequence of buffers and event reusing the same resources and
returns the current sequence of buffers for reading.
- rollOverReusingResources() - Method in class org.apache.flink.streaming.runtime.io.BufferSpiller
-
Deprecated.
NOTE: The BufferOrEventSequences created by this method all reuse the same reading memory
(to reduce overhead) and can consequently not be read concurrently with each other.
- rollOverReusingResources() - Method in class org.apache.flink.streaming.runtime.io.CachedBufferBlocker
-
- rollOverWithoutReusingResources() - Method in interface org.apache.flink.streaming.runtime.io.BufferBlocker
-
Starts a new sequence of buffers and event without reusing the same resources and
returns the current sequence of buffers for reading.
- rollOverWithoutReusingResources() - Method in class org.apache.flink.streaming.runtime.io.BufferSpiller
-
Deprecated.
The BufferOrEventSequence returned by this method is safe for concurrent consumption with
any previously returned sequence.
- rollOverWithoutReusingResources() - Method in class org.apache.flink.streaming.runtime.io.CachedBufferBlocker
-
- roundDownToPageSizeMultiple(long) - Method in class org.apache.flink.runtime.memory.MemoryManager
-
Rounds the given value down to a multiple of the memory manager's page size.
- roundDownToPowerOf2(int) - Static method in class org.apache.flink.util.MathUtils
-
Decrements the given number down to the closest power of two.
- RoundRobinChannelSelector<T extends IOReadableWritable> - Class in org.apache.flink.runtime.io.network.api.writer
-
- RoundRobinChannelSelector() - Constructor for class org.apache.flink.runtime.io.network.api.writer.RoundRobinChannelSelector
-
Constructs a new default channel selector.
- RoundRobinOperatorStateRepartitioner - Class in org.apache.flink.runtime.checkpoint
-
- RoundRobinOperatorStateRepartitioner() - Constructor for class org.apache.flink.runtime.checkpoint.RoundRobinOperatorStateRepartitioner
-
- roundUpToPowerOfTwo(int) - Static method in class org.apache.flink.util.MathUtils
-
Round the given number to the next power of two.
- RouterHandler - Class in org.apache.flink.runtime.rest.handler
-
This class is an extension of
Handler
that replaces the standard error response to be identical with those
sent by the
AbstractRestHandler
.
- RouterHandler(Router, Map<String, String>) - Constructor for class org.apache.flink.runtime.rest.handler.RouterHandler
-
- ROW(TypeInformation<?>...) - Static method in class org.apache.flink.api.common.typeinfo.Types
-
Returns type information for
Row
with fields of the given types.
- Row - Class in 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) - Constructor for class org.apache.flink.types.Row
-
Create a new Row instance.
- ROW_HEADER - Static variable in class org.apache.flink.table.client.cli.CliStrings
-
- ROW_NAMED(String[], TypeInformation<?>...) - Static method in class org.apache.flink.api.common.typeinfo.Types
-
Returns type information for
Row
with fields of the given types and
with given names.
- ROW_QUIT - Static variable in class org.apache.flink.table.client.cli.CliStrings
-
- RowComparator - Class in org.apache.flink.api.java.typeutils.runtime
-
- RowComparator(int, int[], TypeComparator<Object>[], TypeSerializer<Object>[], boolean[]) - Constructor for class org.apache.flink.api.java.typeutils.runtime.RowComparator
-
General constructor for RowComparator.
- RowCsvInputFormat - Class in org.apache.flink.api.java.io
-
Input format that reads csv into
Row
.
- RowCsvInputFormat(Path, TypeInformation[], String, String, int[], boolean) - Constructor for class org.apache.flink.api.java.io.RowCsvInputFormat
-
- RowCsvInputFormat(Path, TypeInformation[], String, String, int[]) - Constructor for class org.apache.flink.api.java.io.RowCsvInputFormat
-
- RowCsvInputFormat(Path, TypeInformation[], String, String) - Constructor for class org.apache.flink.api.java.io.RowCsvInputFormat
-
- RowCsvInputFormat(Path, TypeInformation[], int[]) - Constructor for class org.apache.flink.api.java.io.RowCsvInputFormat
-
- RowCsvInputFormat(Path, TypeInformation[], boolean) - Constructor for class org.apache.flink.api.java.io.RowCsvInputFormat
-
- RowCsvInputFormat(Path, TypeInformation[]) - Constructor for class org.apache.flink.api.java.io.RowCsvInputFormat
-
- RowSerializer - Class in org.apache.flink.api.java.typeutils.runtime
-
- RowSerializer(TypeSerializer<?>[]) - Constructor for class org.apache.flink.api.java.typeutils.runtime.RowSerializer
-
- RowSerializer.RowSerializerConfigSnapshot - Class in org.apache.flink.api.java.typeutils.runtime
-
- RowSerializerConfigSnapshot() - Constructor for class org.apache.flink.api.java.typeutils.runtime.RowSerializer.RowSerializerConfigSnapshot
-
This empty nullary constructor is required for deserializing the configuration.
- RowSerializerConfigSnapshot(TypeSerializer[]) - Constructor for class org.apache.flink.api.java.typeutils.runtime.RowSerializer.RowSerializerConfigSnapshot
-
- rowToString(Row) - Static method in class org.apache.flink.table.client.cli.CliUtils
-
- RowTypeInfo - Class in org.apache.flink.api.java.typeutils
-
- RowTypeInfo(TypeInformation<?>...) - Constructor for class org.apache.flink.api.java.typeutils.RowTypeInfo
-
- RowTypeInfo(TypeInformation<?>[], String[]) - Constructor for class org.apache.flink.api.java.typeutils.RowTypeInfo
-
- RPC_PORT - Static variable in class org.apache.flink.configuration.TaskManagerOptions
-
The default network port range the task manager expects incoming IPC connections.
- RpcCheckpointResponder - Class in org.apache.flink.runtime.taskexecutor.rpc
-
- RpcCheckpointResponder(CheckpointCoordinatorGateway) - Constructor for class org.apache.flink.runtime.taskexecutor.rpc.RpcCheckpointResponder
-
- RpcConnectionException - Exception in org.apache.flink.runtime.rpc.exceptions
-
Exception class which is thrown if a rpc connection failed.
- RpcConnectionException(String) - Constructor for exception org.apache.flink.runtime.rpc.exceptions.RpcConnectionException
-
- RpcConnectionException(String, Throwable) - Constructor for exception org.apache.flink.runtime.rpc.exceptions.RpcConnectionException
-
- RpcConnectionException(Throwable) - Constructor for exception org.apache.flink.runtime.rpc.exceptions.RpcConnectionException
-
- RpcEndpoint - Class in org.apache.flink.runtime.rpc
-
Base class for RPC endpoints.
- RpcEndpoint(RpcService, String) - Constructor for class org.apache.flink.runtime.rpc.RpcEndpoint
-
Initializes the RPC endpoint.
- RpcEndpoint(RpcService) - Constructor for class org.apache.flink.runtime.rpc.RpcEndpoint
-
Initializes the RPC endpoint with a random endpoint id.
- RpcEndpoint.MainThreadExecutor - Class in org.apache.flink.runtime.rpc
-
Executor which executes runnables in the main thread context.
- RpcException - Exception in org.apache.flink.runtime.rpc.exceptions
-
Base class for RPC related exceptions.
- RpcException(String) - Constructor for exception org.apache.flink.runtime.rpc.exceptions.RpcException
-
- RpcException(String, Throwable) - Constructor for exception org.apache.flink.runtime.rpc.exceptions.RpcException
-
- RpcException(Throwable) - Constructor for exception org.apache.flink.runtime.rpc.exceptions.RpcException
-
- RpcGateway - Interface in org.apache.flink.runtime.rpc
-
Rpc gateway interface which has to be implemented by Rpc gateways.
- RpcGatewayRetriever<F extends Serializable,T extends FencedRpcGateway<F>> - Class in org.apache.flink.runtime.webmonitor.retriever.impl
-
- RpcGatewayRetriever(RpcService, Class<T>, Function<UUID, F>, int, Time) - Constructor for class org.apache.flink.runtime.webmonitor.retriever.impl.RpcGatewayRetriever
-
- RpcInputSplitProvider - Class in org.apache.flink.runtime.taskexecutor.rpc
-
- RpcInputSplitProvider(JobMasterGateway, JobVertexID, ExecutionAttemptID, Time) - Constructor for class org.apache.flink.runtime.taskexecutor.rpc.RpcInputSplitProvider
-
- RpcInvocation - Interface in org.apache.flink.runtime.rpc.messages
-
Interface for rpc invocation messages.
- RpcKvStateRegistryListener - Class in org.apache.flink.runtime.taskexecutor.rpc
-
- RpcKvStateRegistryListener(KvStateRegistryGateway, InetSocketAddress) - Constructor for class org.apache.flink.runtime.taskexecutor.rpc.RpcKvStateRegistryListener
-
- RpcPartitionStateChecker - Class in org.apache.flink.runtime.taskexecutor.rpc
-
- RpcPartitionStateChecker(JobMasterGateway) - Constructor for class org.apache.flink.runtime.taskexecutor.rpc.RpcPartitionStateChecker
-
- RpcResultPartitionConsumableNotifier - Class in org.apache.flink.runtime.taskexecutor.rpc
-
- RpcResultPartitionConsumableNotifier(JobMasterGateway, Executor, Time) - Constructor for class org.apache.flink.runtime.taskexecutor.rpc.RpcResultPartitionConsumableNotifier
-
- rpcServer - Variable in class org.apache.flink.runtime.rpc.RpcEndpoint
-
Interface to access the underlying rpc server.
- RpcServer - Interface in org.apache.flink.runtime.rpc
-
Interface for self gateways.
- RpcService - Interface in org.apache.flink.runtime.rpc
-
Interface for rpc services.
- RpcTaskManagerGateway - Class in org.apache.flink.runtime.jobmaster
-
- RpcTaskManagerGateway(TaskExecutorGateway, JobMasterId) - Constructor for class org.apache.flink.runtime.jobmaster.RpcTaskManagerGateway
-
- RpcTimeout - Annotation Type in org.apache.flink.runtime.rpc
-
Annotation for
RpcGateway
methods to specify an additional timeout parameter for the
returned future to be completed.
- RpcUtils - Class in org.apache.flink.runtime.rpc
-
Utility functions for Flink's RPC implementation.
- run() - Method in class org.apache.flink.api.common.io.FileInputFormat.InputSplitOpenThread
-
- run(String[]) - Method in class org.apache.flink.client.cli.CliFrontend
-
Executions the run action.
- run(PackagedProgram, int) - Method in class org.apache.flink.client.program.ClusterClient
-
General purpose method to run a user jar from the CliFrontend in either blocking or detached mode, depending
on whether setDetached(true)
or setDetached(false)
.
- run(JobWithJars, int) - Method in class org.apache.flink.client.program.ClusterClient
-
- run(JobWithJars, int, SavepointRestoreSettings) - Method in class org.apache.flink.client.program.ClusterClient
-
Runs a program on the Flink cluster to which this client is connected.
- run(FlinkPlan, List<URL>, List<URL>, ClassLoader) - Method in class org.apache.flink.client.program.ClusterClient
-
- run(FlinkPlan, List<URL>, List<URL>, ClassLoader, SavepointRestoreSettings) - Method in class org.apache.flink.client.program.ClusterClient
-
- run(JobGraph, ClassLoader) - Method in class org.apache.flink.client.program.ClusterClient
-
Submits a JobGraph blocking.
- run() - Method in class org.apache.flink.core.testutils.CheckedThread
-
- run(DataSet<T>) - Method in class org.apache.flink.graph.asm.dataset.ChecksumHashCode
-
- run(DataSet<T>) - Method in class org.apache.flink.graph.asm.dataset.Collect
-
- run(DataSet<T>) - Method in class org.apache.flink.graph.asm.dataset.Count
-
- run(DataSet<T>) - Method in interface org.apache.flink.graph.asm.dataset.DataSetAnalytic
-
All
DataSetAnalytic
processing must be terminated by an
OutputFormat
and obtained via accumulators rather than
returned by a
DataSet
.
- run(DataSet<T>) - Method in class org.apache.flink.graph.asm.dataset.DataSetAnalyticBase
-
- run(Graph<K, Double, Double>) - Method in class org.apache.flink.graph.examples.GSAPageRank
-
- run(Graph<K, Double, Double>) - Method in class org.apache.flink.graph.examples.PageRank
-
- run(GraphAlgorithm<K, VV, EV, T>) - Method in class org.apache.flink.graph.Graph
-
- run(GraphAnalytic<K, VV, EV, T>) - Method in class org.apache.flink.graph.Graph
-
A
GraphAnalytic
is similar to a
GraphAlgorithm
but is terminal
and results are retrieved via accumulators.
- run(Graph<K, VV, EV>) - Method in interface org.apache.flink.graph.GraphAlgorithm
-
- run(Graph<K, VV, EV>) - Method in interface org.apache.flink.graph.GraphAnalytic
-
All
GraphAnalytic
processing must be terminated by an
OutputFormat
.
- run(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.GraphAnalyticBase
-
- run(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.library.clustering.directed.AverageClusteringCoefficient
-
- run(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.library.clustering.directed.GlobalClusteringCoefficient
-
- run(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.library.clustering.directed.TriadicCensus
-
- run(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.library.clustering.undirected.AverageClusteringCoefficient
-
- run(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.library.clustering.undirected.GlobalClusteringCoefficient
-
- run(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.library.clustering.undirected.TriadicCensus
-
- run(Graph<K, Long, Double>) - Method in class org.apache.flink.graph.library.CommunityDetection
-
- run(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.library.ConnectedComponents
-
- run(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.library.GSAConnectedComponents
-
- run(Graph<K, VV, Double>) - Method in class org.apache.flink.graph.library.GSASingleSourceShortestPaths
-
- run(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.library.LabelPropagation
-
- run(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.library.metric.ChecksumHashCode
-
- run(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.library.metric.directed.EdgeMetrics
-
- run(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.library.metric.directed.VertexMetrics
-
- run(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.library.metric.undirected.EdgeMetrics
-
- run(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.library.metric.undirected.VertexMetrics
-
- run(Graph<K, VV, Double>) - Method in class org.apache.flink.graph.library.SingleSourceShortestPaths
-
- run(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.library.Summarization
-
- run(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.library.TriangleEnumerator
-
- run() - Method in class org.apache.flink.graph.Runner
-
Setup the Flink job with the graph input, algorithm, and output.
- run(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.utils.proxy.GraphAlgorithmWrappingDataSet
-
- run(Graph<IN_K, IN_VV, IN_EV>) - Method in class org.apache.flink.graph.utils.proxy.GraphAlgorithmWrappingGraph
-
- run(String[]) - Method in class org.apache.flink.mesos.runtime.clusterframework.MesosApplicationMasterRunner
-
The instance entry point for the Mesos AppMaster.
- run() - Method in class org.apache.flink.python.api.streaming.util.StreamPrinter
-
- run() - Method in class org.apache.flink.runtime.blob.BlobServer
-
- run() - Method in class org.apache.flink.runtime.heartbeat.HeartbeatManagerSenderImpl
-
- run() - Method in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
-
- run() - Method in class org.apache.flink.runtime.iterative.task.IterationHeadTask
-
- run() - Method in class org.apache.flink.runtime.iterative.task.IterationIntermediateTask
-
- run() - Method in class org.apache.flink.runtime.iterative.task.IterationTailTask
-
- run() - Method in class org.apache.flink.runtime.operators.AbstractCachedBuildSideJoinDriver
-
- run() - Method in class org.apache.flink.runtime.operators.AbstractOuterJoinDriver
-
- run() - Method in class org.apache.flink.runtime.operators.AllGroupCombineDriver
-
- run() - Method in class org.apache.flink.runtime.operators.AllGroupReduceDriver
-
- run() - Method in class org.apache.flink.runtime.operators.AllReduceDriver
-
- run() - Method in class org.apache.flink.runtime.operators.BatchTask
-
- run() - Method in class org.apache.flink.runtime.operators.CoGroupDriver
-
- run() - Method in class org.apache.flink.runtime.operators.CoGroupRawDriver
-
- run() - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetFirstDriver
-
- run() - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetSecondDriver
-
- run() - Method in class org.apache.flink.runtime.operators.CrossDriver
-
- run() - Method in interface org.apache.flink.runtime.operators.Driver
-
The main operation method of the task.
- run() - Method in class org.apache.flink.runtime.operators.FlatMapDriver
-
- run() - Method in class org.apache.flink.runtime.operators.GroupReduceCombineDriver
-
- run() - Method in class org.apache.flink.runtime.operators.GroupReduceDriver
-
- run() - Method in class org.apache.flink.runtime.operators.JoinDriver
-
- run() - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetFirstDriver
-
- run() - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetSecondDriver
-
- run() - Method in class org.apache.flink.runtime.operators.MapDriver
-
- run() - Method in class org.apache.flink.runtime.operators.MapPartitionDriver
-
- run() - Method in class org.apache.flink.runtime.operators.NoOpDriver
-
- run() - Method in class org.apache.flink.runtime.operators.ReduceCombineDriver
-
- run() - Method in class org.apache.flink.runtime.operators.ReduceDriver
-
- run() - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.ThreadBase
-
Implements exception handling and delegates to go().
- run() - Method in class org.apache.flink.runtime.operators.UnionWithTempOperator
-
- run() - Method in class org.apache.flink.runtime.state.DoneFuture
-
- run() - Method in class org.apache.flink.runtime.taskmanager.MemoryLogger
-
- run() - Method in class org.apache.flink.runtime.taskmanager.Task
-
The core work method that bootstraps the task and executes its code.
- run() - Method in class org.apache.flink.runtime.util.JvmShutdownSafeguard
-
- run() - Method in class org.apache.flink.runtime.util.ProcessShutDownThread
-
- run() - Method in class org.apache.flink.runtime.webmonitor.history.HistoryServer
-
- run(SourceFunction.SourceContext<Row>) - Method in class org.apache.flink.sql.tests.StreamSQLTestProgram.Generator
-
- run(SourceFunction.SourceContext<OUT>) - Method in class org.apache.flink.storm.wrappers.SpoutWrapper
-
- run(SourceFunction.SourceContext<TimestampedFileInputSplit>) - Method in class org.apache.flink.streaming.api.functions.source.ContinuousFileMonitoringFunction
-
- run(SourceFunction.SourceContext<Tuple3<String, Long, Long>>) - Method in class org.apache.flink.streaming.api.functions.source.FileMonitoringFunction
-
Deprecated.
- run(SourceFunction.SourceContext<T>) - Method in class org.apache.flink.streaming.api.functions.source.FromElementsFunction
-
- run(SourceFunction.SourceContext<T>) - Method in class org.apache.flink.streaming.api.functions.source.FromIteratorFunction
-
- run(SourceFunction.SourceContext<T>) - Method in class org.apache.flink.streaming.api.functions.source.FromSplittableIteratorFunction
-
- run(SourceFunction.SourceContext<OUT>) - Method in class org.apache.flink.streaming.api.functions.source.InputFormatSourceFunction
-
- run(SourceFunction.SourceContext<String>) - Method in class org.apache.flink.streaming.api.functions.source.SocketTextStreamFunction
-
- run(SourceFunction.SourceContext<T>) - Method in interface org.apache.flink.streaming.api.functions.source.SourceFunction
-
Starts the source.
- run(SourceFunction.SourceContext<Long>) - Method in class org.apache.flink.streaming.api.functions.source.StatefulSequenceSource
-
- run() - Method in class org.apache.flink.streaming.api.operators.async.Emitter
-
- run(Object, StreamStatusMaintainer) - Method in class org.apache.flink.streaming.api.operators.StreamSource
-
- run(Object, StreamStatusMaintainer, Output<StreamRecord<OUT>>) - Method in class org.apache.flink.streaming.api.operators.StreamSource
-
- run(SourceFunction.SourceContext<T>) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumerBase
-
- run() - Method in class org.apache.flink.streaming.connectors.kafka.internal.KafkaConsumerThread
-
- run() - Method in class org.apache.flink.streaming.connectors.kafka.internals.PeriodicOffsetCommitter
-
- run(SourceFunction.SourceContext<NiFiDataPacket>) - Method in class org.apache.flink.streaming.connectors.nifi.NiFiSource
-
- run(SourceFunction.SourceContext<OUT>) - Method in class org.apache.flink.streaming.connectors.rabbitmq.RMQSource
-
- run(SourceFunction.SourceContext<String>) - Method in class org.apache.flink.streaming.connectors.twitter.TwitterSource
-
- run(SourceFunction.SourceContext<WikipediaEditEvent>) - Method in class org.apache.flink.streaming.connectors.wikiedits.WikipediaEditsSource
-
- run(SourceFunction.SourceContext<Integer>) - Method in class org.apache.flink.streaming.examples.ml.IncrementalLearningSkeleton.FiniteNewDataSource
-
- run(SourceFunction.SourceContext<Integer>) - Method in class org.apache.flink.streaming.examples.ml.IncrementalLearningSkeleton.FiniteTrainingDataSource
-
- run(SourceFunction.SourceContext<Event>) - Method in class org.apache.flink.streaming.examples.statemachine.generator.EventsGeneratorSource
-
- run(SourceFunction.SourceContext<Object>) - Method in class org.apache.flink.streaming.python.api.functions.PythonGeneratorFunction
-
- run(SourceFunction.SourceContext<Object>) - Method in class org.apache.flink.streaming.python.api.functions.PythonIteratorFunction
-
- run() - Method in class org.apache.flink.streaming.runtime.tasks.OneInputStreamTask
-
- run() - Method in class org.apache.flink.streaming.runtime.tasks.SourceStreamTask
-
- run() - Method in class org.apache.flink.streaming.runtime.tasks.StoppableSourceStreamTask
-
- run() - Method in class org.apache.flink.streaming.runtime.tasks.StreamIterationHead
-
- run() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask.AsyncCheckpointRunnable
-
- run() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- run() - Method in class org.apache.flink.streaming.runtime.tasks.TwoInputStreamTask
-
- run(SourceFunction.SourceContext<Tuple3<Integer, Long, String>>) - Method in class org.apache.flink.streaming.tests.BucketingSinkTestProgram.Generator
-
- run(SourceFunction.SourceContext<Event>) - Method in class org.apache.flink.streaming.tests.SequenceGeneratorSource
-
- run() - Method in interface org.apache.flink.util.function.RunnableWithException
-
The work method.
- run() - Method in interface org.apache.flink.util.function.ThrowingRunnable
-
The work method.
- run(String[]) - Method in class org.apache.flink.yarn.cli.FlinkYarnSessionCli
-
- run(String[]) - Method in class org.apache.flink.yarn.YarnApplicationMasterRunner
-
The instance entry point for the YARN application master.
- runAfterwards(CompletableFuture<?>, RunnableWithException) - Static method in class org.apache.flink.runtime.concurrent.FutureUtils
-
Run the given action after the completion of the given future.
- runAfterwardsAsync(CompletableFuture<?>, RunnableWithException) - Static method in class org.apache.flink.runtime.concurrent.FutureUtils
-
Run the given action after the completion of the given future.
- runAfterwardsAsync(CompletableFuture<?>, RunnableWithException, Executor) - Static method in class org.apache.flink.runtime.concurrent.FutureUtils
-
Run the given action after the completion of the given future.
- runApplicationMaster(Configuration) - Method in class org.apache.flink.yarn.YarnApplicationMasterRunner
-
The main work method, must run as a privileged action.
- runAsync(Runnable) - Method in interface org.apache.flink.runtime.rpc.MainThreadExecutable
-
Execute the runnable in the main thread of the underlying RPC endpoint.
- RunAsync - Class in org.apache.flink.runtime.rpc.messages
-
Message for asynchronous runnable invocations
- RunAsync(Runnable, long) - Constructor for class org.apache.flink.runtime.rpc.messages.RunAsync
-
Creates a new RunAsync
message.
- runAsync(Runnable) - Method in class org.apache.flink.runtime.rpc.RpcEndpoint
-
Execute the runnable in the main thread of the underlying RPC endpoint.
- runAsyncWithoutFencing(Runnable) - Method in class org.apache.flink.runtime.rpc.akka.FencedAkkaInvocationHandler
-
- runAsyncWithoutFencing(Runnable) - Method in interface org.apache.flink.runtime.rpc.FencedMainThreadExecutable
-
Run the given runnable in the main thread without attaching a fencing token.
- runAsyncWithoutFencing(Runnable) - Method in class org.apache.flink.runtime.rpc.FencedRpcEndpoint
-
Run the given runnable in the main thread of the RpcEndpoint without checking the fencing
token.
- runCluster(Configuration) - Method in class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
-
- runDetached(JobGraph, ClassLoader) - Method in class org.apache.flink.client.program.ClusterClient
-
Submits a JobGraph detached.
- runDetached(JobGraph) - Method in class org.apache.flink.runtime.minicluster.MiniCluster
-
This method executes a job in detached mode.
- runFetchLoop() - Method in class org.apache.flink.streaming.connectors.kafka.internal.Kafka09Fetcher
-
- runFetchLoop() - Method in class org.apache.flink.streaming.connectors.kafka.internals.AbstractFetcher
-
- runFetchLoop() - Method in class org.apache.flink.streaming.connectors.kafka.internals.Kafka08Fetcher
-
- runFlinkZkQuorumPeer(String, int) - Static method in class org.apache.flink.runtime.zookeeper.FlinkZooKeeperQuorumPeer
-
Runs a ZooKeeper QuorumPeer
if further peers are configured or a single
ZooKeeperServer
if no further peers are configured.
- runGatherSumApplyIteration(GatherFunction<VV, EV, M>, SumFunction<VV, EV, M>, ApplyFunction<K, VV, M>, int) - Method in class org.apache.flink.graph.Graph
-
Runs a Gather-Sum-Apply iteration on the graph.
- runGatherSumApplyIteration(GatherFunction<VV, EV, M>, SumFunction<VV, EV, M>, ApplyFunction<K, VV, M>, int, GSAConfiguration) - Method in class org.apache.flink.graph.Graph
-
Runs a Gather-Sum-Apply iteration on the graph with configuration options.
- runGenerator(Collector<Event>[]) - Static method in class org.apache.flink.streaming.examples.statemachine.generator.StandaloneThreadedGenerator
-
- runIfNotDoneAndGet(RunnableFuture<T>) - Static method in class org.apache.flink.util.FutureUtil
-
- runInternal(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.asm.degree.annotate.directed.EdgeDegreesPair
-
- runInternal(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.asm.degree.annotate.directed.EdgeSourceDegrees
-
- runInternal(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.asm.degree.annotate.directed.EdgeTargetDegrees
-
- runInternal(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.asm.degree.annotate.directed.VertexDegrees
-
- runInternal(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.asm.degree.annotate.directed.VertexInDegree
-
- runInternal(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.asm.degree.annotate.directed.VertexOutDegree
-
- runInternal(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.asm.degree.annotate.undirected.EdgeDegreePair
-
- runInternal(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.asm.degree.annotate.undirected.EdgeSourceDegree
-
- runInternal(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.asm.degree.annotate.undirected.EdgeTargetDegree
-
- runInternal(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.asm.degree.annotate.undirected.VertexDegree
-
- runInternal(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.asm.degree.filter.undirected.MaximumDegree
-
- runInternal(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.asm.simple.directed.Simplify
-
- runInternal(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.asm.simple.undirected.Simplify
-
- runInternal(Graph<K, VV, OLD>) - Method in class org.apache.flink.graph.asm.translate.TranslateEdgeValues
-
- runInternal(Graph<OLD, VV, EV>) - Method in class org.apache.flink.graph.asm.translate.TranslateGraphIds
-
- runInternal(Graph<K, OLD, EV>) - Method in class org.apache.flink.graph.asm.translate.TranslateVertexValues
-
- runInternal(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.library.clustering.directed.LocalClusteringCoefficient
-
- runInternal(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.library.clustering.directed.TriangleListing
-
- runInternal(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.library.clustering.undirected.LocalClusteringCoefficient
-
- runInternal(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.library.clustering.undirected.TriangleListing
-
- runInternal(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.library.linkanalysis.HITS
-
- runInternal(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.library.linkanalysis.PageRank
-
- runInternal(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.library.similarity.AdamicAdar
-
- runInternal(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.library.similarity.JaccardIndex
-
- runInternal(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.utils.proxy.GraphAlgorithmWrappingDataSet
-
- runInternal(Graph<IN_K, IN_VV, IN_EV>) - Method in class org.apache.flink.graph.utils.proxy.GraphAlgorithmWrappingGraph
-
- RunnableWithException - Interface in org.apache.flink.util.function
-
Similar to a
Runnable
, this interface is used to capture a block of code
to be executed.
- Runner - Class in org.apache.flink.graph
-
This default main class executes Flink drivers.
- Runner(String[]) - Constructor for class org.apache.flink.graph.Runner
-
Create an algorithm runner from the given arguments.
- running - Variable in class org.apache.flink.runtime.operators.AbstractOuterJoinDriver
-
- running - Variable in class org.apache.flink.runtime.operators.BatchTask
-
The flag that tags the task as still running.
- running - Variable in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetFirstDriver
-
- running - Variable in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetSecondDriver
-
- running - Variable in class org.apache.flink.runtime.operators.JoinDriver
-
- running - Variable in class org.apache.flink.runtime.operators.JoinWithSolutionSetFirstDriver
-
- running - Variable in class org.apache.flink.runtime.operators.JoinWithSolutionSetSecondDriver
-
- RunningJobsRegistry - Interface in org.apache.flink.runtime.highavailability
-
A simple registry that tracks if a certain job is pending execution, running, or completed.
- RunningJobsRegistry.JobSchedulingStatus - Enum in org.apache.flink.runtime.highavailability
-
The scheduling status of a job, as maintained by the RunningJobsRegistry
.
- runOperation(CustomUnaryOperation<T, X>) - Method in class org.apache.flink.api.java.DataSet
-
- RunOptions - Class in org.apache.flink.client.cli
-
Command line options for the RUN command.
- RunOptions(CommandLine) - Constructor for class org.apache.flink.client.cli.RunOptions
-
- runPrivileged(Configuration, Configuration) - Method in class org.apache.flink.mesos.runtime.clusterframework.MesosApplicationMasterRunner
-
The main work method, must run as a privileged action.
- runScatterGatherIteration(ScatterFunction<K, VV, M, EV>, GatherFunction<K, VV, M>, int) - Method in class org.apache.flink.graph.Graph
-
Runs a ScatterGather iteration on the graph.
- runScatterGatherIteration(ScatterFunction<K, VV, M, EV>, GatherFunction<K, VV, M>, int, ScatterGatherConfiguration) - Method in class org.apache.flink.graph.Graph
-
Runs a ScatterGather iteration on the graph with configuration options.
- runSecured(Callable<T>) - Method in interface org.apache.flink.runtime.security.SecurityContext
-
- runTaskManager(String[], Class<? extends TaskManager>) - Static method in class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManagerRunner
-
- runTaskManager(Configuration, ResourceID) - Static method in class org.apache.flink.runtime.taskexecutor.TaskManagerRunner
-
- RUNTIME_FAILURE_RETURN_CODE - Static variable in class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
-
- RUNTIME_HASH_JOIN_BLOOM_FILTERS_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- RuntimeAggregatorRegistry - Class in org.apache.flink.runtime.iterative.task
-
- RuntimeAggregatorRegistry(Collection<AggregatorWithName<?>>) - Constructor for class org.apache.flink.runtime.iterative.task.RuntimeAggregatorRegistry
-
- RuntimeComparatorFactory<T> - Class in org.apache.flink.api.java.typeutils.runtime
-
- RuntimeComparatorFactory() - Constructor for class org.apache.flink.api.java.typeutils.runtime.RuntimeComparatorFactory
-
- RuntimeComparatorFactory(TypeComparator<T>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.RuntimeComparatorFactory
-
- RuntimeContext - Interface in org.apache.flink.api.common.functions
-
A RuntimeContext contains information about the context in which functions are executed.
- RuntimeEnvironment - Class in org.apache.flink.runtime.taskmanager
-
- RuntimeEnvironment(JobID, JobVertexID, ExecutionAttemptID, ExecutionConfig, TaskInfo, Configuration, Configuration, ClassLoader, MemoryManager, IOManager, BroadcastVariableManager, TaskStateManager, AccumulatorRegistry, TaskKvStateRegistry, InputSplitProvider, Map<String, Future<Path>>, ResultPartitionWriter[], InputGate[], TaskEventDispatcher, CheckpointResponder, TaskManagerRuntimeInfo, TaskMetricGroup, Task) - Constructor for class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
-
- RuntimeEvent - Class in org.apache.flink.runtime.event
-
Subclasses of this event are recognized as events exchanged by the core runtime.
- RuntimeEvent() - Constructor for class org.apache.flink.runtime.event.RuntimeEvent
-
- RuntimeMonitorHandler - Class in org.apache.flink.runtime.webmonitor
-
The Netty channel handler that processes all HTTP requests.
- RuntimeMonitorHandler(WebMonitorConfig, RequestHandler, GatewayRetriever<JobManagerGateway>, CompletableFuture<String>, Time) - Constructor for class org.apache.flink.runtime.webmonitor.RuntimeMonitorHandler
-
- RuntimePairComparatorFactory<T1,T2> - Class in org.apache.flink.api.java.typeutils.runtime
-
- RuntimePairComparatorFactory() - Constructor for class org.apache.flink.api.java.typeutils.runtime.RuntimePairComparatorFactory
-
- RuntimeSerializerFactory<T> - Class in org.apache.flink.api.java.typeutils.runtime
-
- RuntimeSerializerFactory() - Constructor for class org.apache.flink.api.java.typeutils.runtime.RuntimeSerializerFactory
-
- RuntimeSerializerFactory(TypeSerializer<T>, Class<T>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.RuntimeSerializerFactory
-
- RuntimeUDFContext - Class in 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) - Constructor for class org.apache.flink.api.common.functions.util.RuntimeUDFContext
-
- runtimeUdfContext - Variable in class org.apache.flink.runtime.operators.BatchTask
-
The udf's runtime context.
- runVertexCentricIteration(ComputeFunction<K, VV, EV, M>, MessageCombiner<K, M>, int) - Method in class org.apache.flink.graph.Graph
-
- runVertexCentricIteration(ComputeFunction<K, VV, EV, M>, MessageCombiner<K, M>, int, VertexCentricConfiguration) - Method in class org.apache.flink.graph.Graph
-
- runWindowJoin(DataStream<Tuple2<String, Integer>>, DataStream<Tuple2<String, Integer>>, long) - Static method in class org.apache.flink.streaming.examples.join.WindowJoin
-
- S3FileSystemFactory - Class in org.apache.flink.fs.s3hadoop
-
Simple factory for the S3 file system.
- S3FileSystemFactory() - Constructor for class org.apache.flink.fs.s3hadoop.S3FileSystemFactory
-
- S3FileSystemFactory - Class in org.apache.flink.fs.s3presto
-
Simple factory for the S3 file system.
- S3FileSystemFactory() - Constructor for class org.apache.flink.fs.s3presto.S3FileSystemFactory
-
- SAFE_SCALE_DOWN_FACTOR - Static variable in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer011
-
This coefficient determines what is the safe scale down factor.
- SafetyNetCloseableRegistry - Class in org.apache.flink.core.fs
-
- SafetyNetWrapperFileSystem - Class in org.apache.flink.core.fs
-
- SafetyNetWrapperFileSystem(FileSystem, SafetyNetCloseableRegistry) - Constructor for class org.apache.flink.core.fs.SafetyNetWrapperFileSystem
-
- SalarySource() - Constructor for class org.apache.flink.streaming.examples.join.WindowJoinSampleData.SalarySource
-
- SameTypePairComparator<T> - Class in org.apache.flink.api.common.typeutils
-
- SameTypePairComparator(TypeComparator<T>) - Constructor for class org.apache.flink.api.common.typeutils.SameTypePairComparator
-
- sameTypeVars(Type, Type) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractionUtils
-
Checks whether two types are type variables describing the same.
- sample(Iterator<T>) - Method in class org.apache.flink.api.java.sampling.BernoulliSampler
-
Sample the input elements, for each input element, take a Bernoulli trail for sampling.
- sample(Iterator<T>) - Method in class org.apache.flink.api.java.sampling.DistributedRandomSampler
-
Combine the first phase and second phase in sequence, implemented for test purpose only.
- sample(Iterator<T>) - Method in class org.apache.flink.api.java.sampling.PoissonSampler
-
Sample the input elements, for each input element, generate its count following a poisson
distribution.
- sample(Iterator<T>) - Method in class org.apache.flink.api.java.sampling.RandomSampler
-
Randomly sample the elements from input in sequence, and return the result iterator.
- sample(DataSet<T>, boolean, double) - Static method in class org.apache.flink.api.java.utils.DataSetUtils
-
Generate a sample of DataSet by the probability fraction of each element.
- sample(DataSet<T>, boolean, double, long) - Static method in class org.apache.flink.api.java.utils.DataSetUtils
-
Generate a sample of DataSet by the probability fraction of each element.
- SampleInCoordinator<T> - Class in org.apache.flink.api.java.functions
-
SampleInCoordinator wraps the sample logic of the coordinator side (the second phase of
distributed sample algorithm).
- SampleInCoordinator(boolean, int, long) - Constructor for class org.apache.flink.api.java.functions.SampleInCoordinator
-
Create a function instance of SampleInCoordinator.
- sampleInCoordinator(Iterator<IntermediateSampleData<T>>) - Method in class org.apache.flink.api.java.sampling.DistributedRandomSampler
-
Sample algorithm for the second phase.
- SampleInPartition<T> - Class in org.apache.flink.api.java.functions
-
SampleInPartition wraps the sample logic on the partition side (the first phase of distributed
sample algorithm).
- SampleInPartition(boolean, int, long) - Constructor for class org.apache.flink.api.java.functions.SampleInPartition
-
Create a function instance of SampleInPartition.
- sampleInPartition(Iterator<T>) - Method in class org.apache.flink.api.java.sampling.DistributedRandomSampler
-
Sample algorithm for the first phase.
- sampleInPartition(Iterator<T>) - Method in class org.apache.flink.api.java.sampling.ReservoirSamplerWithoutReplacement
-
- sampleInPartition(Iterator<T>) - Method in class org.apache.flink.api.java.sampling.ReservoirSamplerWithReplacement
-
- Sampler() - Constructor for class org.apache.flink.examples.java.misc.PiEstimation.Sampler
-
- SampleWithFraction<T> - Class in org.apache.flink.api.java.functions
-
A map partition function wrapper for sampling algorithms with fraction, the sample algorithm
takes the partition iterator as input.
- SampleWithFraction(boolean, double, long) - Constructor for class org.apache.flink.api.java.functions.SampleWithFraction
-
Create a function instance of SampleWithFraction.
- sampleWithSize(DataSet<T>, boolean, int) - Static method in class org.apache.flink.api.java.utils.DataSetUtils
-
Generate a sample of DataSet which contains fixed size elements.
- sampleWithSize(DataSet<T>, boolean, int, long) - Static method in class org.apache.flink.api.java.utils.DataSetUtils
-
Generate a sample of DataSet which contains fixed size elements.
- sanityCheck() - Method in class org.apache.flink.streaming.connectors.cassandra.CassandraSink.CassandraPojoSinkBuilder
-
- sanityCheck() - Method in class org.apache.flink.streaming.connectors.cassandra.CassandraSink.CassandraRowSinkBuilder
-
- sanityCheck() - Method in class org.apache.flink.streaming.connectors.cassandra.CassandraSink.CassandraScalaProductSinkBuilder
-
- sanityCheck() - Method in class org.apache.flink.streaming.connectors.cassandra.CassandraSink.CassandraSinkBuilder
-
- sanityCheck() - Method in class org.apache.flink.streaming.connectors.cassandra.CassandraSink.CassandraTupleSinkBuilder
-
- savepoint(String[]) - Method in class org.apache.flink.client.cli.CliFrontend
-
Executes the SAVEPOINT action.
- Savepoint - Interface in org.apache.flink.runtime.checkpoint.savepoint
-
Savepoints are manually-triggered snapshots from which a program can be
resumed on submission.
- SAVEPOINT_DIRECTORY - Static variable in class org.apache.flink.configuration.CheckpointingOptions
-
The default directory for savepoints.
- SAVEPOINT_DIRECTORY_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- SAVEPOINT_FS_DIRECTORY_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- SavepointDisposalHandlers - Class in org.apache.flink.runtime.rest.handler.job.savepoints
-
Handlers to trigger the disposal of a savepoint.
- SavepointDisposalHandlers() - Constructor for class org.apache.flink.runtime.rest.handler.job.savepoints.SavepointDisposalHandlers
-
- SavepointDisposalHandlers.SavepointDisposalStatusHandler - Class in org.apache.flink.runtime.rest.handler.job.savepoints
-
StatusHandler
implementation for the savepoint disposal operation.
- SavepointDisposalHandlers.SavepointDisposalTriggerHandler - Class in org.apache.flink.runtime.rest.handler.job.savepoints
-
TriggerHandler
implementation for the savepoint disposal operation.
- SavepointDisposalRequest - Class in org.apache.flink.runtime.rest.messages.job.savepoints
-
Request body for a savepoint disposal call.
- SavepointDisposalRequest(String) - Constructor for class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalRequest
-
- SavepointDisposalStatusHandler(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>) - Constructor for class org.apache.flink.runtime.rest.handler.job.savepoints.SavepointDisposalHandlers.SavepointDisposalStatusHandler
-
- SavepointDisposalStatusHeaders - Class in org.apache.flink.runtime.rest.messages.job.savepoints
-
- SavepointDisposalStatusMessageParameters - Class in org.apache.flink.runtime.rest.messages.job.savepoints
-
- SavepointDisposalStatusMessageParameters() - Constructor for class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalStatusMessageParameters
-
- SavepointDisposalTriggerHandler(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>) - Constructor for class org.apache.flink.runtime.rest.handler.job.savepoints.SavepointDisposalHandlers.SavepointDisposalTriggerHandler
-
- SavepointDisposalTriggerHeaders - Class in org.apache.flink.runtime.rest.messages.job.savepoints
-
- SavepointHandlers - Class in org.apache.flink.runtime.rest.handler.job.savepoints
-
HTTP handlers for asynchronous triggering of savepoints.
- SavepointHandlers(String) - Constructor for class org.apache.flink.runtime.rest.handler.job.savepoints.SavepointHandlers
-
- SavepointHandlers.SavepointStatusHandler - Class in org.apache.flink.runtime.rest.handler.job.savepoints
-
HTTP handler to query for the status of the savepoint.
- SavepointHandlers.SavepointTriggerHandler - Class in org.apache.flink.runtime.rest.handler.job.savepoints
-
HTTP handler to trigger savepoints.
- SavepointInfo - Class in org.apache.flink.runtime.rest.messages.job.savepoints
-
Represents information about a finished savepoint.
- SavepointInfo(String, SerializedThrowable) - Constructor for class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointInfo
-
- SavepointOptions - Class in org.apache.flink.client.cli
-
Command line options for the SAVEPOINT command.
- SavepointOptions(CommandLine) - Constructor for class org.apache.flink.client.cli.SavepointOptions
-
- savepointPathQueryParameter - Variable in class org.apache.flink.runtime.webmonitor.handlers.JarRunMessageParameters
-
- SavepointPathQueryParameter - Class in org.apache.flink.runtime.webmonitor.handlers
-
Query parameter that specifies the savepoint to restore from.
- SavepointPathQueryParameter() - Constructor for class org.apache.flink.runtime.webmonitor.handlers.SavepointPathQueryParameter
-
- SavepointRestoreSettings - Class in org.apache.flink.runtime.jobgraph
-
Savepoint restore settings.
- SavepointSerializer<T extends Savepoint> - Interface in org.apache.flink.runtime.checkpoint.savepoint
-
- SavepointSerializers - Class in org.apache.flink.runtime.checkpoint.savepoint
-
- savepointSettings - Variable in class org.apache.flink.client.program.ContextEnvironment
-
- SavepointStatusHandler(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>) - Constructor for class org.apache.flink.runtime.rest.handler.job.savepoints.SavepointHandlers.SavepointStatusHandler
-
- SavepointStatusHeaders - Class in org.apache.flink.runtime.rest.messages.job.savepoints
-
These headers define the protocol for triggering a savepoint.
- SavepointStatusMessageParameters - Class in org.apache.flink.runtime.rest.messages.job.savepoints
-
The parameters for triggering a savepoint.
- SavepointStatusMessageParameters() - Constructor for class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointStatusMessageParameters
-
- SavepointTriggerHandler(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>) - Constructor for class org.apache.flink.runtime.rest.handler.job.savepoints.SavepointHandlers.SavepointTriggerHandler
-
- SavepointTriggerHeaders - Class in org.apache.flink.runtime.rest.messages.job.savepoints
-
These headers define the protocol for triggering a savepoint.
- SavepointTriggerMessageParameters - Class in org.apache.flink.runtime.rest.messages.job.savepoints
-
The parameters for triggering a savepoint.
- SavepointTriggerMessageParameters() - Constructor for class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointTriggerMessageParameters
-
- SavepointTriggerRequestBody - Class in org.apache.flink.runtime.rest.messages.job.savepoints
-
- SavepointTriggerRequestBody(String, boolean) - Constructor for class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointTriggerRequestBody
-
- SavepointV1 - Class in org.apache.flink.runtime.checkpoint.savepoint
-
Savepoint version 0.
- SavepointV1(long, Collection<TaskState>) - Constructor for class org.apache.flink.runtime.checkpoint.savepoint.SavepointV1
-
- SavepointV1Serializer - Class in org.apache.flink.runtime.checkpoint.savepoint
-
Deserializer for checkpoints written in format 1
(Flink 1.2.x format)
- SavepointV2 - Class in org.apache.flink.runtime.checkpoint.savepoint
-
The persistent checkpoint metadata, format version 2.
- SavepointV2(long, Collection<TaskState>) - Constructor for class org.apache.flink.runtime.checkpoint.savepoint.SavepointV2
-
- SavepointV2(long, Collection<OperatorState>, Collection<MasterState>) - Constructor for class org.apache.flink.runtime.checkpoint.savepoint.SavepointV2
-
- ScalaAggregateOperator<IN> - Class in org.apache.flink.api.scala.operators
-
This operator represents the application of a "aggregate" operation on a data set, and the
result data set produced by the function.
- ScalaAggregateOperator(DataSet<IN>, Aggregations, int) - Constructor for class org.apache.flink.api.scala.operators.ScalaAggregateOperator
-
Non grouped aggregation.
- ScalaAggregateOperator(Grouping<IN>, Aggregations, int) - Constructor for class org.apache.flink.api.scala.operators.ScalaAggregateOperator
-
Grouped aggregation.
- ScalaCsvOutputFormat<T extends scala.Product> - Class in org.apache.flink.api.scala.operators
-
This is an OutputFormat to serialize Scala Tuples to text.
- ScalaCsvOutputFormat(Path) - Constructor for class org.apache.flink.api.scala.operators.ScalaCsvOutputFormat
-
Creates an instance of CsvOutputFormat.
- ScalaCsvOutputFormat(Path, String) - Constructor for class org.apache.flink.api.scala.operators.ScalaCsvOutputFormat
-
Creates an instance of CsvOutputFormat.
- ScalaCsvOutputFormat(Path, String, String) - Constructor for class org.apache.flink.api.scala.operators.ScalaCsvOutputFormat
-
Creates an instance of CsvOutputFormat.
- ScalaOptionSerializerConfigSnapshot<E> - Class in org.apache.flink.api.scala.typeutils
-
- ScalaOptionSerializerConfigSnapshot() - Constructor for class org.apache.flink.api.scala.typeutils.ScalaOptionSerializerConfigSnapshot
-
This empty nullary constructor is required for deserializing the configuration.
- ScalaOptionSerializerConfigSnapshot(TypeSerializer<E>) - Constructor for class org.apache.flink.api.scala.typeutils.ScalaOptionSerializerConfigSnapshot
-
- scalar(String, String, double) - Static method in class org.apache.flink.mesos.Utils
-
Construct a scalar resource.
- ScalaShellRemoteEnvironment - Class in org.apache.flink.api.java
-
- ScalaShellRemoteEnvironment(String, int, FlinkILoop, Configuration, String...) - Constructor for class org.apache.flink.api.java.ScalaShellRemoteEnvironment
-
Creates new ScalaShellRemoteEnvironment that has a reference to the FlinkILoop.
- ScalaShellRemoteStreamEnvironment - Class in org.apache.flink.api.java
-
- ScalaShellRemoteStreamEnvironment(String, int, FlinkILoop, Configuration, String...) - Constructor for class org.apache.flink.api.java.ScalaShellRemoteStreamEnvironment
-
Creates a new RemoteStreamEnvironment that points to the master
(JobManager) described by the given host name and port.
- ScalaTrySerializerConfigSnapshot<E> - Class in org.apache.flink.api.scala.typeutils
-
- ScalaTrySerializerConfigSnapshot() - Constructor for class org.apache.flink.api.scala.typeutils.ScalaTrySerializerConfigSnapshot
-
This empty nullary constructor is required for deserializing the configuration.
- ScalaTrySerializerConfigSnapshot(TypeSerializer<E>, TypeSerializer<Throwable>) - Constructor for class org.apache.flink.api.scala.typeutils.ScalaTrySerializerConfigSnapshot
-
- ScalaUtils - Class in org.apache.flink.runtime.util
-
Utilities to convert Scala types into Java types.
- scan - Variable in class org.apache.flink.addons.hbase.AbstractTableInputFormat
-
- scannedRows - Variable in class org.apache.flink.addons.hbase.AbstractTableInputFormat
-
- ScatterFunction<K,VV,Message,EV> - Class in org.apache.flink.graph.spargel
-
- ScatterFunction() - Constructor for class org.apache.flink.graph.spargel.ScatterFunction
-
- ScatterGatherConfiguration - Class in org.apache.flink.graph.spargel
-
A ScatterGatherConfiguration object can be used to set the iteration name and
degree of parallelism, to register aggregators and use broadcast sets in
the
GatherFunction
and
ScatterFunction
- ScatterGatherConfiguration() - Constructor for class org.apache.flink.graph.spargel.ScatterGatherConfiguration
-
- ScatterGatherIteration<K,VV,Message,EV> - Class in org.apache.flink.graph.spargel
-
This class represents iterative graph computations, programmed in a scatter-gather perspective.
- schedule(Runnable, long, TimeUnit) - Method in class org.apache.flink.runtime.concurrent.akka.ActorSystemScheduledExecutorAdapter
-
- schedule(Callable<V>, long, TimeUnit) - Method in class org.apache.flink.runtime.concurrent.akka.ActorSystemScheduledExecutorAdapter
-
- schedule(Runnable, long, TimeUnit) - Method in interface org.apache.flink.runtime.concurrent.ScheduledExecutor
-
Executes the given command after the given delay.
- schedule(Callable<V>, long, TimeUnit) - Method in interface org.apache.flink.runtime.concurrent.ScheduledExecutor
-
Executes the given callable after the given delay.
- schedule(Runnable, long, TimeUnit) - Method in class org.apache.flink.runtime.concurrent.ScheduledExecutorServiceAdapter
-
- schedule(Callable<V>, long, TimeUnit) - Method in class org.apache.flink.runtime.concurrent.ScheduledExecutorServiceAdapter
-
- scheduleAll(SlotProvider, boolean, LocationPreferenceConstraint) - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
Schedules all execution vertices of this ExecutionJobVertex.
- scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in class org.apache.flink.runtime.concurrent.akka.ActorSystemScheduledExecutorAdapter
-
- scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in interface org.apache.flink.runtime.concurrent.ScheduledExecutor
-
Executes the given command periodically.
- scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in class org.apache.flink.runtime.concurrent.ScheduledExecutorServiceAdapter
-
- scheduleAtFixedRate(ProcessingTimeCallback, long, long) - Method in class org.apache.flink.streaming.runtime.tasks.ProcessingTimeService
-
Registers a task to be executed repeatedly at a fixed rate.
- scheduleAtFixedRate(ProcessingTimeCallback, long, long) - Method in class org.apache.flink.streaming.runtime.tasks.SystemProcessingTimeService
-
- scheduleAtFixedRate(ProcessingTimeCallback, long, long) - Method in class org.apache.flink.streaming.runtime.tasks.TestProcessingTimeService
-
- Scheduled - Interface in org.apache.flink.metrics.reporter
-
Interface for reporters that actively send out data periodically.
- ScheduledDropwizardReporter - Class in org.apache.flink.dropwizard
-
- ScheduledDropwizardReporter() - Constructor for class org.apache.flink.dropwizard.ScheduledDropwizardReporter
-
- ScheduledExecutor - Interface in org.apache.flink.runtime.concurrent
-
Extension for the
Executor
interface which is enriched by method for scheduling tasks
in the future.
- ScheduledExecutorServiceAdapter - Class in org.apache.flink.runtime.concurrent
-
- ScheduledExecutorServiceAdapter(ScheduledExecutorService) - Constructor for class org.apache.flink.runtime.concurrent.ScheduledExecutorServiceAdapter
-
- ScheduledUnit - Class in org.apache.flink.runtime.jobmanager.scheduler
-
ScheduledUnit contains the information necessary to allocate a slot for the given
JobVertexID
.
- ScheduledUnit(Execution) - Constructor for class org.apache.flink.runtime.jobmanager.scheduler.ScheduledUnit
-
- ScheduledUnit(Execution, SlotSharingGroupId) - Constructor for class org.apache.flink.runtime.jobmanager.scheduler.ScheduledUnit
-
- ScheduledUnit(Execution, SlotSharingGroupId, CoLocationConstraint) - Constructor for class org.apache.flink.runtime.jobmanager.scheduler.ScheduledUnit
-
- ScheduledUnit(JobVertexID, SlotSharingGroupId, CoLocationConstraint) - Constructor for class org.apache.flink.runtime.jobmanager.scheduler.ScheduledUnit
-
- ScheduledUnit(Execution, JobVertexID, SlotSharingGroupId, CoLocationConstraint) - Constructor for class org.apache.flink.runtime.jobmanager.scheduler.ScheduledUnit
-
- scheduleForExecution() - Method in class org.apache.flink.runtime.executiongraph.Execution
-
- scheduleForExecution(SlotProvider, boolean, LocationPreferenceConstraint) - Method in class org.apache.flink.runtime.executiongraph.Execution
-
NOTE: This method only throws exceptions if it is in an illegal state to be scheduled, or if the tasks needs
to be scheduled immediately and no resource is available.
- scheduleForExecution() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- scheduleForExecution(SlotProvider, boolean, LocationPreferenceConstraint) - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
Schedules the current execution of this ExecutionVertex.
- ScheduleMode - Enum in org.apache.flink.runtime.jobgraph
-
The ScheduleMode decides how tasks of an execution graph are started.
- scheduleOrUpdateConsumers(ResultPartitionID) - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
Schedule or updates consumers of the given result partition.
- scheduleOrUpdateConsumers(ResultPartitionID, Time) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
-
- scheduleOrUpdateConsumers(ResultPartitionID, Time) - Method in interface org.apache.flink.runtime.jobmaster.JobMasterGateway
-
Notifies the JobManager about available data for a produced partition.
- Scheduler - Class in org.apache.flink.runtime.jobmanager.scheduler
-
The scheduler is responsible for distributing the ready-to-run tasks among instances and slots.
- Scheduler(Executor) - Constructor for class org.apache.flink.runtime.jobmanager.scheduler.Scheduler
-
Creates a new scheduler.
- SchedulerProxy - Class in org.apache.flink.mesos.scheduler
-
This class reacts to callbacks from the Mesos scheduler driver.
- SchedulerProxy(ActorRef) - Constructor for class org.apache.flink.mesos.scheduler.SchedulerProxy
-
- scheduleRunAsync(Runnable, long) - Method in interface org.apache.flink.runtime.rpc.MainThreadExecutable
-
Execute the runnable in the main thread of the underlying RPC endpoint, with
a delay of the given number of milliseconds.
- scheduleRunAsync(Runnable, Time) - Method in class org.apache.flink.runtime.rpc.RpcEndpoint
-
Execute the runnable in the main thread of the underlying RPC endpoint, with
a delay of the given number of milliseconds.
- scheduleRunAsync(Runnable, long, TimeUnit) - Method in class org.apache.flink.runtime.rpc.RpcEndpoint
-
Execute the runnable in the main thread of the underlying RPC endpoint, with
a delay of the given number of milliseconds.
- scheduleRunnable(Runnable, long, TimeUnit) - Method in class org.apache.flink.runtime.rpc.akka.AkkaRpcService
-
- scheduleRunnable(Runnable, long, TimeUnit) - Method in interface org.apache.flink.runtime.rpc.RpcService
-
Execute the runnable in the execution context of this RPC Service, as returned by
RpcService.getExecutor()
, after a scheduled delay.
- scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in class org.apache.flink.runtime.concurrent.akka.ActorSystemScheduledExecutorAdapter
-
- scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in interface org.apache.flink.runtime.concurrent.ScheduledExecutor
-
Executed the given command repeatedly with the given delay between the end of an execution
and the start of the next execution.
- scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in class org.apache.flink.runtime.concurrent.ScheduledExecutorServiceAdapter
-
- SchedulingStrategy - Interface in org.apache.flink.runtime.jobmaster.slotpool
-
Classes that implement this interface provide a method to match objects to somehow represent slot candidates
against the
SlotProfile
that produced the matcher object.
- schema - Variable in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducerBase
-
(Serializable) SerializationSchema for turning objects used with Flink into.
- schema - Variable in class org.apache.flink.streaming.connectors.rabbitmq.RMQSink
-
- schema - Variable in class org.apache.flink.streaming.connectors.rabbitmq.RMQSource
-
- schema(TypeInformation<?>) - Method in class org.apache.flink.table.descriptors.Json
-
Sets the schema using type information.
- scope - Variable in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo
-
The remaining scope not covered by specific fields.
- SCOPE_DELIMITER - Static variable in class org.apache.flink.configuration.MetricOptions
-
The delimiter used to assemble the metric identifier.
- SCOPE_HOST - Static variable in class org.apache.flink.runtime.metrics.scope.ScopeFormat
-
- SCOPE_INHERIT_PARENT - Static variable in class org.apache.flink.runtime.metrics.scope.ScopeFormat
-
If the scope format starts with this character, then the parent components scope
format will be used as a prefix.
- SCOPE_JOB_ID - Static variable in class org.apache.flink.runtime.metrics.scope.ScopeFormat
-
- SCOPE_JOB_NAME - Static variable in class org.apache.flink.runtime.metrics.scope.ScopeFormat
-
- SCOPE_NAMING_JM - Static variable in class org.apache.flink.configuration.MetricOptions
-
The scope format string that is applied to all metrics scoped to a JobManager.
- SCOPE_NAMING_JM_JOB - Static variable in class 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 - Static variable in class org.apache.flink.configuration.MetricOptions
-
The scope format string that is applied to all metrics scoped to an operator.
- SCOPE_NAMING_TASK - Static variable in class org.apache.flink.configuration.MetricOptions
-
The scope format string that is applied to all metrics scoped to a task.
- SCOPE_NAMING_TM - Static variable in class org.apache.flink.configuration.MetricOptions
-
The scope format string that is applied to all metrics scoped to a TaskManager.
- SCOPE_NAMING_TM_JOB - Static variable in class org.apache.flink.configuration.MetricOptions
-
The scope format string that is applied to all metrics scoped to a job on a TaskManager.
- SCOPE_OPERATOR_ID - Static variable in class org.apache.flink.runtime.metrics.scope.ScopeFormat
-
- SCOPE_OPERATOR_NAME - Static variable in class org.apache.flink.runtime.metrics.scope.ScopeFormat
-
- SCOPE_SEPARATOR - Static variable in class org.apache.flink.runtime.metrics.scope.ScopeFormat
-
- SCOPE_TASK_ATTEMPT_ID - Static variable in class org.apache.flink.runtime.metrics.scope.ScopeFormat
-
- SCOPE_TASK_ATTEMPT_NUM - Static variable in class org.apache.flink.runtime.metrics.scope.ScopeFormat
-
- SCOPE_TASK_NAME - Static variable in class org.apache.flink.runtime.metrics.scope.ScopeFormat
-
- SCOPE_TASK_SUBTASK_INDEX - Static variable in class org.apache.flink.runtime.metrics.scope.ScopeFormat
-
- SCOPE_TASK_VERTEX_ID - Static variable in class org.apache.flink.runtime.metrics.scope.ScopeFormat
-
- SCOPE_TASKMANAGER_ID - Static variable in class org.apache.flink.runtime.metrics.scope.ScopeFormat
-
- ScopeFormat - Class in org.apache.flink.runtime.metrics.scope
-
This class represents the format after which the "scope" (or namespace) of the various
component metric groups is built.
- ScopeFormat(String, ScopeFormat, String[]) - Constructor for class org.apache.flink.runtime.metrics.scope.ScopeFormat
-
- ScopeFormats - Class in org.apache.flink.runtime.metrics.scope
-
A container for component scope formats.
- scopeInfo - Variable in class org.apache.flink.runtime.metrics.dump.MetricDump
-
The scope information for the stored metric.
- scrollDown() - Method in class org.apache.flink.table.client.cli.CliView
-
- scrollDown(int) - Method in class org.apache.flink.table.client.cli.CliView
-
- scrollLeft() - Method in class org.apache.flink.table.client.cli.CliView
-
- scrollRight() - Method in class org.apache.flink.table.client.cli.CliView
-
- scrollUp() - Method in class org.apache.flink.table.client.cli.CliView
-
- secondDam() - Method in enum org.apache.flink.runtime.operators.DriverStrategy
-
- seconds(long) - Static method in class org.apache.flink.api.common.time.Time
-
Creates a new
Time
that represents the given number of seconds.
- seconds(long) - Static method in class org.apache.flink.streaming.api.windowing.time.Time
-
Creates a new
Time
that represents the given number of seconds.
- SecureAclProvider() - Constructor for class org.apache.flink.runtime.util.ZooKeeperUtils.SecureAclProvider
-
- SecureTestEnvironment - Class in org.apache.flink.test.util
-
- SecureTestEnvironment() - Constructor for class org.apache.flink.test.util.SecureTestEnvironment
-
- SECURITY_SSL_ALGORITHMS - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- SECURITY_SSL_ENABLED - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- SECURITY_SSL_KEY_PASSWORD - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- SECURITY_SSL_KEYSTORE - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- SECURITY_SSL_KEYSTORE_PASSWORD - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- SECURITY_SSL_PROTOCOL - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- SECURITY_SSL_TRUSTSTORE - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- SECURITY_SSL_TRUSTSTORE_PASSWORD - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- SECURITY_SSL_VERIFY_HOSTNAME - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- SecurityConfiguration - Class in org.apache.flink.runtime.security
-
The global security configuration.
- SecurityConfiguration(Configuration) - Constructor for class org.apache.flink.runtime.security.SecurityConfiguration
-
Create a security configuration from the global configuration.
- SecurityConfiguration(Configuration, List<SecurityModuleFactory>) - Constructor for class org.apache.flink.runtime.security.SecurityConfiguration
-
Create a security configuration from the global configuration.
- SecurityContext - Interface in org.apache.flink.runtime.security
-
A security context with may be required to run a Callable.
- SecurityInstallException(String) - Constructor for exception org.apache.flink.runtime.security.modules.SecurityModule.SecurityInstallException
-
- SecurityInstallException(String, Throwable) - Constructor for exception org.apache.flink.runtime.security.modules.SecurityModule.SecurityInstallException
-
- SecurityModule - Interface in org.apache.flink.runtime.security.modules
-
An installable security module.
- SecurityModule.SecurityInstallException - Exception in org.apache.flink.runtime.security.modules
-
Indicates a problem with installing or uninstalling a security module.
- SecurityModuleFactory - Interface in org.apache.flink.runtime.security.modules
-
- SecurityOptions - Class in org.apache.flink.configuration
-
The set of configuration options relating to security.
- SecurityOptions() - Constructor for class org.apache.flink.configuration.SecurityOptions
-
- SecurityUtils - Class in org.apache.flink.runtime.security
-
Utils for configuring security.
- seek(long) - Method in class org.apache.flink.api.common.io.InputStreamFSInputWrapper
-
- seek(byte[]) - Method in class org.apache.flink.contrib.streaming.state.RocksIteratorWrapper
-
- seek(long) - Method in class org.apache.flink.core.fs.AbstractMultiFSDataInputStream
-
- seek(long) - Method in class org.apache.flink.core.fs.FSDataInputStream
-
Seek to the given offset from the start of the file.
- seek(long) - Method in class org.apache.flink.core.fs.FSDataInputStreamWrapper
-
- seek(long) - Method in class org.apache.flink.core.fs.local.LocalDataInputStream
-
- seek(long) - Method in class org.apache.flink.formats.avro.utils.FSDataInputStreamWrapper
-
- seek(long) - Method in class org.apache.flink.runtime.fs.hdfs.HadoopDataInputStream
-
- seek(long) - Method in class org.apache.flink.runtime.io.disk.SeekableFileChannelInputView
-
- SeekableDataInputView - Interface in org.apache.flink.core.memory
-
- SeekableDataOutputView - Interface in org.apache.flink.core.memory
-
- SeekableFileChannelInputView - Class in org.apache.flink.runtime.io.disk
-
- SeekableFileChannelInputView(IOManager, FileIOChannel.ID, MemoryManager, List<MemorySegment>, int) - Constructor for class org.apache.flink.runtime.io.disk.SeekableFileChannelInputView
-
- seekInput(MemorySegment, int, int) - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
-
Sets the internal state of the view such that the next bytes will be read from the given memory segment,
starting at the given position.
- seekOutput(MemorySegment, int) - Method in class org.apache.flink.runtime.memory.AbstractPagedOutputView
-
Sets the internal state to the given memory segment and the given position within the segment.
- seekPartitionToBeginning(KafkaConsumer<?, ?>, TopicPartition) - Method in class org.apache.flink.streaming.connectors.kafka.internal.KafkaConsumerCallBridge
-
- seekPartitionToBeginning(KafkaConsumer<?, ?>, TopicPartition) - Method in class org.apache.flink.streaming.connectors.kafka.internal.KafkaConsumerCallBridge010
-
- seekPartitionToEnd(KafkaConsumer<?, ?>, TopicPartition) - Method in class org.apache.flink.streaming.connectors.kafka.internal.KafkaConsumerCallBridge
-
- seekPartitionToEnd(KafkaConsumer<?, ?>, TopicPartition) - Method in class org.apache.flink.streaming.connectors.kafka.internal.KafkaConsumerCallBridge010
-
- seekTo(long) - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBufferFileSegmentReader
-
- seekTo(long) - Method in interface org.apache.flink.runtime.io.disk.iomanager.BufferFileSegmentReader
-
- seekToFirst() - Method in class org.apache.flink.contrib.streaming.state.RocksIteratorWrapper
-
- seekToLast() - Method in class org.apache.flink.contrib.streaming.state.RocksIteratorWrapper
-
- seekToPosition(long) - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBlockReader
-
- seekToPosition(long) - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBufferFileReader
-
- seekToPosition(long) - Method in interface org.apache.flink.runtime.io.disk.iomanager.BlockChannelReader
-
- seekToPosition(long) - Method in interface org.apache.flink.runtime.io.disk.iomanager.BufferFileReader
-
- seekToPosition(long) - Method in class org.apache.flink.runtime.io.disk.iomanager.SynchronousBufferFileReader
-
- segmentSize - Variable in class org.apache.flink.runtime.memory.AbstractPagedOutputView
-
- segmentSize - Variable in class org.apache.flink.runtime.operators.hash.MutableHashTable
-
The size of the segments used by the hash join buckets.
- select(Map<String, List<IN>>) - Method in interface org.apache.flink.cep.PatternSelectFunction
-
Generates a result from the given map of events.
- select(PatternSelectFunction<T, R>) - Method in class org.apache.flink.cep.PatternStream
-
Applies a select function to the detected pattern sequence.
- select(PatternSelectFunction<T, R>, TypeInformation<R>) - Method in class org.apache.flink.cep.PatternStream
-
Applies a select function to the detected pattern sequence.
- select(OutputTag<L>, PatternTimeoutFunction<T, L>, PatternSelectFunction<T, R>) - Method in class org.apache.flink.cep.PatternStream
-
Applies a select function to the detected pattern sequence.
- select(OutputTag<L>, PatternTimeoutFunction<T, L>, TypeInformation<R>, PatternSelectFunction<T, R>) - Method in class org.apache.flink.cep.PatternStream
-
Applies a select function to the detected pattern sequence.
- select(PatternTimeoutFunction<T, L>, PatternSelectFunction<T, R>) - Method in class org.apache.flink.cep.PatternStream
-
- select(ExecutionMode, ShipStrategyType, boolean) - Static method in enum org.apache.flink.runtime.io.network.DataExchangeMode
-
Computes the mode of data exchange to be used for a given execution mode and ship strategy.
- select(SplitStreamType<T>) - Method in class org.apache.flink.storm.util.StormStreamSelector
-
- select(Fields) - Method in class org.apache.flink.storm.wrappers.StormTuple
-
- select(OUT) - Method in interface org.apache.flink.streaming.api.collector.selector.OutputSelector
-
- select(String...) - Method in class org.apache.flink.streaming.api.datastream.SplitStream
-
Sets the output names for which the next operator will receive values.
- select(Tuple5<Integer, Integer, Integer, Integer, Integer>) - Method in class org.apache.flink.streaming.examples.iteration.IterateExample.MySelector
-
- select(String...) - Method in class org.apache.flink.streaming.python.api.datastream.PythonSplitStream
-
- select(PyObject) - Method in class org.apache.flink.streaming.python.api.functions.PythonOutputSelector
-
- SELECT_ALL_CHAR - Static variable in class org.apache.flink.api.common.operators.Keys.ExpressionKeys
-
- SELECT_ALL_CHAR_SCALA - Static variable in class org.apache.flink.api.common.operators.Keys.ExpressionKeys
-
- selectAllocationBaseDirectory(int) - Method in interface org.apache.flink.runtime.state.LocalRecoveryDirectoryProvider
-
Returns a specific allocation base directory.
- selectAllocationBaseDirectory(int) - Method in class org.apache.flink.runtime.state.LocalRecoveryDirectoryProviderImpl
-
- selectAllOutputs - Variable in class org.apache.flink.streaming.api.collector.selector.DirectedOutput
-
- SelectByMaxFunction<T extends Tuple> - Class in org.apache.flink.api.java.functions
-
Function that enables selection by maximal value of a field.
- SelectByMaxFunction(TupleTypeInfo<T>, int...) - Constructor for class org.apache.flink.api.java.functions.SelectByMaxFunction
-
Constructor which is overwriting the default constructor.
- SelectByMinFunction<T extends Tuple> - Class in org.apache.flink.api.java.functions
-
Function that enables selection by minimal value of a field.
- SelectByMinFunction(TupleTypeInfo<T>, int...) - Constructor for class org.apache.flink.api.java.functions.SelectByMinFunction
-
Constructor which is overwriting the default constructor.
- SelectCepOperator<IN,KEY,OUT> - Class in org.apache.flink.cep.operator
-
- SelectCepOperator(TypeSerializer<IN>, boolean, NFACompiler.NFAFactory<IN>, EventComparator<IN>, AfterMatchSkipStrategy, PatternSelectFunction<IN, OUT>) - Constructor for class org.apache.flink.cep.operator.SelectCepOperator
-
- selectChannels(T, int) - Method in interface org.apache.flink.runtime.io.network.api.writer.ChannelSelector
-
Returns the logical channel indexes, to which the given record should be
written.
- selectChannels(T, int) - Method in class org.apache.flink.runtime.io.network.api.writer.RoundRobinChannelSelector
-
- selectChannels(SerializationDelegate<T>, int) - Method in class org.apache.flink.runtime.operators.shipping.OutputEmitter
-
- selectChannels(SerializationDelegate<StreamRecord<T>>, int) - Method in class org.apache.flink.streaming.runtime.partitioner.BroadcastPartitioner
-
- selectChannels(SerializationDelegate<StreamRecord<T>>, int) - Method in class org.apache.flink.streaming.runtime.partitioner.CustomPartitionerWrapper
-
- selectChannels(SerializationDelegate<StreamRecord<T>>, int) - Method in class org.apache.flink.streaming.runtime.partitioner.ForwardPartitioner
-
- selectChannels(SerializationDelegate<StreamRecord<T>>, int) - Method in class org.apache.flink.streaming.runtime.partitioner.GlobalPartitioner
-
- selectChannels(SerializationDelegate<StreamRecord<T>>, int) - Method in class org.apache.flink.streaming.runtime.partitioner.KeyGroupStreamPartitioner
-
- selectChannels(SerializationDelegate<StreamRecord<T>>, int) - Method in class org.apache.flink.streaming.runtime.partitioner.RebalancePartitioner
-
- selectChannels(SerializationDelegate<StreamRecord<T>>, int) - Method in class org.apache.flink.streaming.runtime.partitioner.RescalePartitioner
-
- selectChannels(SerializationDelegate<StreamRecord<T>>, int) - Method in class org.apache.flink.streaming.runtime.partitioner.ShufflePartitioner
-
- selectedRow - Variable in class org.apache.flink.table.client.cli.CliResultView
-
- SelectEnglishAndTokenizeFlatMap() - Constructor for class org.apache.flink.streaming.examples.twitter.TwitterExample.SelectEnglishAndTokenizeFlatMap
-
- selectFields(int...) - Method in class org.apache.flink.orc.OrcRowInputFormat
-
Selects the fields from the ORC schema that are returned by InputFormat.
- SelectNearestCenter() - Constructor for class org.apache.flink.examples.java.clustering.KMeans.SelectNearestCenter
-
- SelectorFunctionKeys(KeySelector<T, K>, TypeInformation<T>, TypeInformation<K>) - Constructor for class org.apache.flink.api.common.operators.Keys.SelectorFunctionKeys
-
- selectOutputs(StreamRecord<OUT>) - Method in class org.apache.flink.streaming.api.collector.selector.DirectedOutput
-
- selectRowDown() - Method in class org.apache.flink.table.client.cli.CliResultView
-
- selectRowUp() - Method in class org.apache.flink.table.client.cli.CliResultView
-
- selectSubtaskBaseDirectory(int) - Method in interface org.apache.flink.runtime.state.LocalRecoveryDirectoryProvider
-
Returns a specific subtask base directory.
- selectSubtaskBaseDirectory(int) - Method in class org.apache.flink.runtime.state.LocalRecoveryDirectoryProviderImpl
-
- SelectTimeoutCepOperator<IN,OUT1,OUT2,KEY> - Class in org.apache.flink.cep.operator
-
- SelectTimeoutCepOperator(TypeSerializer<IN>, boolean, NFACompiler.NFAFactory<IN>, EventComparator<IN>, AfterMatchSkipStrategy, PatternSelectFunction<IN, OUT1>, PatternTimeoutFunction<IN, OUT2>, OutputTag<OUT2>) - Constructor for class org.apache.flink.cep.operator.SelectTimeoutCepOperator
-
- SelectTimeoutCepOperator.SelectWrapper<IN,OUT1,OUT2> - Class in org.apache.flink.cep.operator
-
- SelectTransformation<T> - Class in org.apache.flink.streaming.api.transformations
-
This transformation represents a selection of only certain upstream elements.
- SelectTransformation(StreamTransformation<T>, List<String>) - Constructor for class org.apache.flink.streaming.api.transformations.SelectTransformation
-
Creates a new SelectionTransformation
from the given input that only selects
the streams with the selected names.
- SelectWrapper(PatternSelectFunction<IN, OUT1>, PatternTimeoutFunction<IN, OUT2>) - Constructor for class org.apache.flink.cep.operator.SelectTimeoutCepOperator.SelectWrapper
-
- SemanticProperties - Interface in org.apache.flink.api.common.operators
-
Container for the semantic properties associated to an operator.
- SemanticProperties.EmptySemanticProperties - Class in org.apache.flink.api.common.operators
-
- SemanticProperties.InvalidSemanticAnnotationException - Exception in org.apache.flink.api.common.operators
-
- SemanticPropUtil - Class in org.apache.flink.api.java.functions
-
- SemanticsCheckMapper - Class in org.apache.flink.streaming.tests
-
- send(DatadogHttpReporter.DatadogHttpRequest) - Method in class org.apache.flink.metrics.datadog.DatadogHttpClient
-
- send(IN) - Method in class org.apache.flink.streaming.connectors.cassandra.AbstractCassandraTupleSink
-
- send(IN) - Method in class org.apache.flink.streaming.connectors.cassandra.CassandraPojoSink
-
- send(IN) - Method in class org.apache.flink.streaming.connectors.cassandra.CassandraSinkBase
-
- send(ProducerRecord<K, V>) - Method in class org.apache.flink.streaming.connectors.kafka.internal.FlinkKafkaProducer
-
- send(ProducerRecord<K, V>, Callback) - Method in class org.apache.flink.streaming.connectors.kafka.internal.FlinkKafkaProducer
-
- SEND_RECEIVE_BUFFER_SIZE - Static variable in class org.apache.flink.runtime.io.network.netty.NettyConfig
-
- sendBroadCastVariables(Configuration) - Method in class org.apache.flink.python.api.streaming.data.PythonStreamer
-
Sends all broadcast-variables encoded in the configuration to the external process.
- sendBuffer(SingleElementPushBackIterator<IN>, PythonSender.Serializer<IN>) - Method in class org.apache.flink.python.api.streaming.data.PythonSender
-
Extracts records from an iterator and writes them to the memory-mapped file.
- sendBuffer(SingleElementPushBackIterator<IN>) - Method in class org.apache.flink.python.api.streaming.data.PythonSingleInputSender
-
Extracts records from an iterator and writes them to the memory-mapped file.
- sendBuffer1(SingleElementPushBackIterator<IN1>) - Method in class org.apache.flink.python.api.streaming.data.PythonDualInputSender
-
Extracts records from an iterator and writes them to the memory-mapped file.
- sendBuffer2(SingleElementPushBackIterator<IN2>) - Method in class org.apache.flink.python.api.streaming.data.PythonDualInputSender
-
Extracts records from an iterator and writes them to the memory-mapped file.
- sendCombinedMessage(Message) - Method in class org.apache.flink.graph.pregel.MessageCombiner
-
Sends the combined message to the target vertex.
- sender - Variable in class org.apache.flink.python.api.streaming.data.PythonStreamer
-
- sender - Variable in class org.apache.flink.python.api.streaming.plan.PythonPlanStreamer
-
- sendError(ChannelHandlerContext, HttpResponseStatus) - Static method in class org.apache.flink.runtime.rest.handler.legacy.files.StaticFileServerHandler
-
Writes a simple error response message.
- sendErrorResponse(ChannelHandlerContext, HttpRequest, ErrorResponseBody, HttpResponseStatus, Map<String, String>) - Static method in class org.apache.flink.runtime.rest.handler.util.HandlerUtils
-
Sends the given error response and status code to the given channel.
- sendErrorResponse(ChannelHandlerContext, boolean, ErrorResponseBody, HttpResponseStatus, Map<String, String>) - Static method in class org.apache.flink.runtime.rest.handler.util.HandlerUtils
-
Sends the given error response and status code to the given channel.
- sendInfoMessage(String) - Method in class org.apache.flink.runtime.clusterframework.FlinkResourceManager
-
- sendInfoMessage(String) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
-
- sendMessages(Vertex<Long, Double>) - Method in class org.apache.flink.graph.examples.IncrementalSSSP.InvalidateMessenger
-
- sendMessages(Vertex<K, Double>) - Method in class org.apache.flink.graph.examples.PageRank.RankMessenger
-
- sendMessages(Vertex<K, VV>) - Method in class org.apache.flink.graph.library.ConnectedComponents.CCMessenger
-
- sendMessages(Vertex<K, VV>) - Method in class org.apache.flink.graph.library.LabelPropagation.SendNewLabelToNeighbors
-
- sendMessages(Vertex<K, Double>) - Method in class org.apache.flink.graph.library.SingleSourceShortestPaths.MinDistanceMessenger
-
- sendMessages(Vertex<K, VV>) - Method in class org.apache.flink.graph.spargel.ScatterFunction
-
This method is invoked once per superstep for each vertex that was changed in that superstep.
- sendMessageTo(K, Message) - Method in class org.apache.flink.graph.pregel.ComputeFunction
-
Sends the given message to the vertex identified by the given key.
- sendMessageTo(K, Message) - Method in class org.apache.flink.graph.spargel.ScatterFunction
-
Sends the given message to the vertex identified by the given key.
- sendMessageToAllNeighbors(Message) - Method in class org.apache.flink.graph.pregel.ComputeFunction
-
Sends the given message to all vertices that adjacent to the changed vertex.
- sendMessageToAllNeighbors(Message) - Method in class org.apache.flink.graph.spargel.ScatterFunction
-
Sends the given message to all vertices that are targets of an edge of the changed vertex.
- SendNewLabelToNeighbors(TypeInformation<VV>) - Constructor for class org.apache.flink.graph.library.LabelPropagation.SendNewLabelToNeighbors
-
- sendNotModified(ChannelHandlerContext) - Static method in class org.apache.flink.runtime.rest.handler.legacy.files.StaticFileServerHandler
-
Send the "304 Not Modified" response.
- sendOffsetsToTransaction(Map<TopicPartition, OffsetAndMetadata>, String) - Method in class org.apache.flink.streaming.connectors.kafka.internal.FlinkKafkaProducer
-
- sendReadConfirmation() - Method in class org.apache.flink.python.api.streaming.data.PythonStreamer
-
- sendReadRequest(MemorySegment) - Method in class org.apache.flink.runtime.io.disk.iomanager.ChannelReaderInputView
-
Sends a new read requests, if further requests remain.
- sendRecord(Object) - Method in class org.apache.flink.python.api.streaming.plan.PythonPlanSender
-
- sendRecord(Object) - Method in class org.apache.flink.python.api.streaming.plan.PythonPlanStreamer
-
- sendRequest(InetSocketAddress, REQ) - Method in class org.apache.flink.queryablestate.network.Client
-
- sendRequest(String, int, M, U, R) - Method in class org.apache.flink.runtime.rest.RestClient
-
- sendRequest(String, int, M, U, R, Collection<FileUpload>) - Method in class org.apache.flink.runtime.rest.RestClient
-
- sendResponse(ChannelHandlerContext, HttpRequest, P, HttpResponseStatus, Map<String, String>) - Static method in class org.apache.flink.runtime.rest.handler.util.HandlerUtils
-
Sends the given response and status code to the given channel.
- sendResponse(ChannelHandlerContext, HttpRequest, String, HttpResponseStatus, Map<String, String>) - Static method in class org.apache.flink.runtime.rest.handler.util.HandlerUtils
-
Sends the given response and status code to the given channel.
- sendResponse(ChannelHandlerContext, boolean, String, HttpResponseStatus, Map<String, String>) - Static method in class org.apache.flink.runtime.rest.handler.util.HandlerUtils
-
Sends the given response and status code to the given channel.
- sendScheduleOrUpdateConsumersMessage() - Method in class org.apache.flink.runtime.deployment.ResultPartitionDeploymentDescriptor
-
- sendSlotReport(ResourceID, InstanceID, SlotReport, Time) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
-
- sendSlotReport(ResourceID, InstanceID, SlotReport, Time) - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
-
Sends the given
SlotReport
to the ResourceManager.
- sendTaskEvent(TaskEvent) - Method in class org.apache.flink.runtime.io.network.api.reader.AbstractReader
-
- sendTaskEvent(TaskEvent) - Method in interface org.apache.flink.runtime.io.network.api.reader.ReaderBase
-
- sendTaskEvent(ResultPartitionID, TaskEvent, RemoteInputChannel) - Method in class org.apache.flink.runtime.io.network.netty.PartitionRequestClient
-
Sends a task event backwards to an intermediate result partition producer.
- sendTaskEvent(TaskEvent) - Method in interface org.apache.flink.runtime.io.network.partition.consumer.InputGate
-
- sendTaskEvent(TaskEvent) - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
-
- sendTaskEvent(TaskEvent) - Method in class org.apache.flink.runtime.io.network.partition.consumer.UnionInputGate
-
- sendValues(Iterable<Row>, long, long) - Method in class org.apache.flink.streaming.connectors.cassandra.CassandraRowWriteAheadSink
-
- sendValues(Iterable<IN>, long, long) - Method in class org.apache.flink.streaming.connectors.cassandra.CassandraTupleWriteAheadSink
-
- sendValues(Iterable<IN>, long, long) - Method in class org.apache.flink.streaming.runtime.operators.GenericWriteAheadSink
-
Write the given element into the backend.
- sendWriteNotification(int, boolean) - Method in class org.apache.flink.python.api.streaming.data.PythonStreamer
-
- Sentence() - Constructor for class org.apache.flink.storm.wordcount.operators.WordCountDataPojos.Sentence
-
- Sentence(String) - Constructor for class org.apache.flink.storm.wordcount.operators.WordCountDataPojos.Sentence
-
- SENTENCES - Static variable in class org.apache.flink.storm.wordcount.operators.WordCountDataPojos
-
- SEPARATOR - Static variable in class org.apache.flink.core.fs.Path
-
The directory separator, a slash.
- SEPARATOR_CHAR - Static variable in class org.apache.flink.core.fs.Path
-
The directory separator, a slash (character).
- SequenceFileWriter<K extends org.apache.hadoop.io.Writable,V extends org.apache.hadoop.io.Writable> - Class in org.apache.flink.streaming.connectors.fs
-
A
Writer
that writes the bucket files as Hadoop
SequenceFiles
.
- SequenceFileWriter() - Constructor for class org.apache.flink.streaming.connectors.fs.SequenceFileWriter
-
Creates a new SequenceFileWriter
that writes sequence files without compression.
- SequenceFileWriter(String, SequenceFile.CompressionType) - Constructor for class org.apache.flink.streaming.connectors.fs.SequenceFileWriter
-
Creates a new SequenceFileWriter
that writes sequence with the given
compression codec and compression type.
- SequenceFileWriter(SequenceFileWriter<K, V>) - Constructor for class org.apache.flink.streaming.connectors.fs.SequenceFileWriter
-
- SequenceGeneratorSource - Class in org.apache.flink.streaming.tests
-
This source function generates a sequence of long values per key.
- SerializableObject - Class in org.apache.flink.util
-
A simple object that only implements
Serializable
, so it can be used
in serializable classes.
- SerializableObject() - Constructor for class org.apache.flink.util.SerializableObject
-
- SerializableSerializer(T) - Constructor for class org.apache.flink.api.common.ExecutionConfig.SerializableSerializer
-
- SerializationDelegate<T> - Class in org.apache.flink.runtime.plugable
-
The serialization delegate exposes an arbitrary element as a
IOReadableWritable
for
serialization, with the help of a type serializer.
- SerializationDelegate(TypeSerializer<T>) - Constructor for class org.apache.flink.runtime.plugable.SerializationDelegate
-
- SerializationSchema<T> - Interface in org.apache.flink.api.common.serialization
-
The serialization schema describes how to turn a data object into a different serialized
representation.
- serializationSchema - Variable in class org.apache.flink.streaming.connectors.kafka.KafkaTableSink
-
- SerializationSchema<T> - Interface in org.apache.flink.streaming.util.serialization
-
- SerializationUtils - Class in org.apache.flink.python.api.streaming.util
-
Utility class containing serializers for all supported types.
- SerializationUtils() - Constructor for class org.apache.flink.python.api.streaming.util.SerializationUtils
-
- SerializationUtils - Class in org.apache.flink.streaming.python.util.serialization
-
A generic serialization utility, which turns java objects into their serialization form as
byte arrays and vise versa.
- SerializationUtils() - Constructor for class org.apache.flink.streaming.python.util.serialization.SerializationUtils
-
- SerializationUtils.BooleanSerializer - Class in org.apache.flink.python.api.streaming.util
-
A serializer for booleans.
- SerializationUtils.ByteSerializer - Class in org.apache.flink.python.api.streaming.util
-
A serializer for bytes.
- SerializationUtils.BytesSerializer - Class in org.apache.flink.python.api.streaming.util
-
A serializer for byte arrays.
- SerializationUtils.CustomTypeWrapperSerializer - Class in org.apache.flink.python.api.streaming.util
-
- SerializationUtils.DoubleSerializer - Class in org.apache.flink.python.api.streaming.util
-
A serializer for doubles.
- SerializationUtils.FloatSerializer - Class in org.apache.flink.python.api.streaming.util
-
A serializer for floats.
- SerializationUtils.IntSerializer - Class in org.apache.flink.python.api.streaming.util
-
A serializer for ints.
- SerializationUtils.LongSerializer - Class in org.apache.flink.python.api.streaming.util
-
A serializer for longs.
- SerializationUtils.NullSerializer - Class in org.apache.flink.python.api.streaming.util
-
A serializer for null.
- SerializationUtils.Serializer<IN> - Class in org.apache.flink.python.api.streaming.util
-
Super class for all serializers used to serialize data.
- SerializationUtils.StringSerializer - Class in org.apache.flink.python.api.streaming.util
-
A serializer for strings.
- SerializationUtils.TupleSerializer - Class in org.apache.flink.python.api.streaming.util
-
A serializer for tuples.
- serialize(T, DataOutputView) - Method in class org.apache.flink.api.common.io.BinaryOutputFormat
-
- serialize(T, DataOutputView) - Method in class org.apache.flink.api.common.io.SerializedOutputFormat
-
- serialize(T) - Method in interface org.apache.flink.api.common.serialization.SerializationSchema
-
Serializes the incoming element to a specified type.
- serialize(String) - Method in class org.apache.flink.api.common.serialization.SimpleStringSchema
-
- serialize(T) - Method in class org.apache.flink.api.common.serialization.TypeInformationSerializationSchema
-
- serialize(boolean[], DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.array.BooleanPrimitiveArraySerializer
-
- serialize(byte[], DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.array.BytePrimitiveArraySerializer
-
- serialize(char[], DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.array.CharPrimitiveArraySerializer
-
- serialize(double[], DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.array.DoublePrimitiveArraySerializer
-
- serialize(float[], DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.array.FloatPrimitiveArraySerializer
-
- serialize(int[], DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.array.IntPrimitiveArraySerializer
-
- serialize(long[], DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.array.LongPrimitiveArraySerializer
-
- serialize(short[], DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.array.ShortPrimitiveArraySerializer
-
- serialize(String[], DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.array.StringArraySerializer
-
- serialize(BigDecimal, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.BigDecSerializer
-
- serialize(BigInteger, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.BigIntSerializer
-
- serialize(Boolean, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.BooleanSerializer
-
- serialize(BooleanValue, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueSerializer
-
- serialize(Byte, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.ByteSerializer
-
- serialize(ByteValue, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.ByteValueSerializer
-
- serialize(Character, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.CharSerializer
-
- serialize(CharValue, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.CharValueSerializer
-
- serialize(Date, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.DateSerializer
-
- serialize(Double, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.DoubleSerializer
-
- serialize(DoubleValue, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueSerializer
-
- serialize(T, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.EnumSerializer
-
- serialize(Float, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.FloatSerializer
-
- serialize(FloatValue, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.FloatValueSerializer
-
- serialize(C[], DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.GenericArraySerializer
-
- serialize(Integer, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.IntSerializer
-
- serialize(IntValue, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.IntValueSerializer
-
- serialize(List<T>, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.ListSerializer
-
- serialize(Long, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.LongSerializer
-
- serialize(LongValue, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.LongValueSerializer
-
- serialize(Map<K, V>, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.MapSerializer
-
- serialize(NullValue, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.NullValueSerializer
-
- serialize(Short, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.ShortSerializer
-
- serialize(ShortValue, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.ShortValueSerializer
-
- serialize(Date, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.SqlDateSerializer
-
- serialize(Time, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.SqlTimeSerializer
-
- serialize(Timestamp, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.SqlTimestampSerializer
-
- serialize(String, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.StringSerializer
-
- serialize(StringValue, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.StringValueSerializer
-
- serialize(Void, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.VoidSerializer
-
- serialize(T, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.TypeDeserializerAdapter
-
- serialize(T, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.TypeSerializer
-
Serializes the given record to the given target output view.
- serialize(T, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.UnloadableDummyTypeSerializer
-
- serialize(T, DataOutputView) - Method in class org.apache.flink.api.java.io.TypeSerializerOutputFormat
-
- serialize(T, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.AvroSerializer
-
Deprecated.
- serialize(T, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer
-
- serialize(Either<L, R>, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.EitherSerializer
-
- serialize(T, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer
-
- serialize(T, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer
-
- serialize(Row, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.RowSerializer
-
- serialize(Tuple0, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.Tuple0Serializer
-
- serialize(T, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializer
-
- serialize(T, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.ValueSerializer
-
- serialize(T, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.WritableSerializer
-
- serialize(DeweyNumber, DataOutputView) - Method in class org.apache.flink.cep.nfa.DeweyNumber.DeweyNumberSerializer
-
- serialize(NFA<T>, DataOutputView) - Method in class org.apache.flink.cep.nfa.NFA.NFASerializer
-
- serialize(SharedBuffer<K, V>, DataOutputView) - Method in class org.apache.flink.cep.nfa.SharedBuffer.SharedBufferSerializer
-
- serialize(E) - Method in interface org.apache.flink.core.io.SimpleVersionedSerializer
-
Serializes the given object.
- serialize(Row) - Method in class org.apache.flink.formats.avro.AvroRowSerializationSchema
-
- serialize(T, DataOutputView) - Method in class org.apache.flink.formats.avro.typeutils.AvroSerializer
-
- serialize(T, DataOutputView) - Method in class org.apache.flink.formats.avro.typeutils.BackwardsCompatibleAvroSerializer
-
- serialize(Row) - Method in class org.apache.flink.formats.json.JsonRowSerializationSchema
-
- serialize(LongValueWithProperHashCode, DataOutputView) - Method in class org.apache.flink.graph.drivers.transform.LongValueWithProperHashCode.LongValueWithProperHashCodeSerializer
-
- serialize(ByteValueArray, DataOutputView) - Method in class org.apache.flink.graph.types.valuearray.ByteValueArraySerializer
-
- serialize(CharValueArray, DataOutputView) - Method in class org.apache.flink.graph.types.valuearray.CharValueArraySerializer
-
- serialize(DoubleValueArray, DataOutputView) - Method in class org.apache.flink.graph.types.valuearray.DoubleValueArraySerializer
-
- serialize(FloatValueArray, DataOutputView) - Method in class org.apache.flink.graph.types.valuearray.FloatValueArraySerializer
-
- serialize(IntValueArray, DataOutputView) - Method in class org.apache.flink.graph.types.valuearray.IntValueArraySerializer
-
- serialize(LongValueArray, DataOutputView) - Method in class org.apache.flink.graph.types.valuearray.LongValueArraySerializer
-
- serialize(NullValueArray, DataOutputView) - Method in class org.apache.flink.graph.types.valuearray.NullValueArraySerializer
-
- serialize(ShortValueArray, DataOutputView) - Method in class org.apache.flink.graph.types.valuearray.ShortValueArraySerializer
-
- serialize(StringValueArray, DataOutputView) - Method in class org.apache.flink.graph.types.valuearray.StringValueArraySerializer
-
- serialize(Object) - Static method in class org.apache.flink.metrics.datadog.DatadogHttpClient
-
- serialize(T) - Method in class org.apache.flink.python.api.streaming.data.PythonSender.Serializer
-
- serialize(IN) - Method in class org.apache.flink.python.api.streaming.util.SerializationUtils.Serializer
-
- serialize(VoidNamespace, DataOutputView) - Method in class org.apache.flink.queryablestate.client.VoidNamespaceSerializer
-
- serialize() - Method in class org.apache.flink.queryablestate.messages.KvStateInternalRequest
-
- serialize() - Method in class org.apache.flink.queryablestate.messages.KvStateRequest
-
- serialize() - Method in class org.apache.flink.queryablestate.messages.KvStateResponse
-
- serialize() - Method in class org.apache.flink.queryablestate.network.messages.MessageBody
-
Serializes the message into a byte array.
- serialize(T, DataOutputStream) - Method in interface org.apache.flink.runtime.checkpoint.savepoint.SavepointSerializer
-
Serializes a savepoint to an output stream.
- serialize(SavepointV2, DataOutputStream) - Method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV1Serializer
-
- serialize(JobDetails, JsonGenerator, SerializerProvider) - Method in class org.apache.flink.runtime.messages.webmonitor.JobDetails.JobDetailsSerializer
-
- serialize(Map<Counter, Tuple2<QueryScopeInfo, String>>, Map<Gauge<?>, Tuple2<QueryScopeInfo, String>>, Map<Histogram, Tuple2<QueryScopeInfo, String>>, Map<Meter, Tuple2<QueryScopeInfo, String>>) - Method in class org.apache.flink.runtime.metrics.dump.MetricDumpSerialization.MetricDumpSerializer
-
Serializes the given metrics and returns the resulting byte array.
- serialize(CheckpointConfigInfo.ProcessingMode, JsonGenerator, SerializerProvider) - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigInfo.ProcessingModeSerializer
-
- serialize(AggregatedMetricsResponseBody, JsonGenerator, SerializerProvider) - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedMetricsResponseBody.Serializer
-
- serialize(MetricCollectionResponseBody, JsonGenerator, SerializerProvider) - Method in class org.apache.flink.runtime.rest.messages.job.metrics.MetricCollectionResponseBody.Serializer
-
- serialize(JobConfigInfo, JsonGenerator, SerializerProvider) - Method in class org.apache.flink.runtime.rest.messages.JobConfigInfo.Serializer
-
- serialize(JobPlanInfo.RawJson, JsonGenerator, SerializerProvider) - Method in class org.apache.flink.runtime.rest.messages.JobPlanInfo.RawJson.Serializer
-
- serialize(JobID, JsonGenerator, SerializerProvider) - Method in class org.apache.flink.runtime.rest.messages.json.JobIDSerializer
-
- serialize(JobResult, JsonGenerator, SerializerProvider) - Method in class org.apache.flink.runtime.rest.messages.json.JobResultSerializer
-
- serialize(JobVertexID, JsonGenerator, SerializerProvider) - Method in class org.apache.flink.runtime.rest.messages.json.JobVertexIDKeySerializer
-
- serialize(JobVertexID, JsonGenerator, SerializerProvider) - Method in class org.apache.flink.runtime.rest.messages.json.JobVertexIDSerializer
-
- serialize(ResourceID, JsonGenerator, SerializerProvider) - Method in class org.apache.flink.runtime.rest.messages.json.ResourceIDSerializer
-
- serialize(SerializedThrowable, JsonGenerator, SerializerProvider) - Method in class org.apache.flink.runtime.rest.messages.json.SerializedThrowableSerializer
-
- serialize(SerializedValue<?>, JsonGenerator, SerializerProvider) - Method in class org.apache.flink.runtime.rest.messages.json.SerializedValueSerializer
-
- serialize(TriggerId, JsonGenerator, SerializerProvider) - Method in class org.apache.flink.runtime.rest.messages.TriggerId.TriggerIdSerializer
-
- serialize(ArrayList<T>, DataOutputView) - Method in class org.apache.flink.runtime.state.ArrayListSerializer
-
- serialize(VoidNamespace, DataOutputView) - Method in class org.apache.flink.runtime.state.VoidNamespaceSerializer
-
- serialize(TwoPhaseCommitSinkFunction.State<TXN, CONTEXT>, DataOutputView) - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.StateSerializer
-
- serialize(InternalTimer<K, N>, DataOutputView) - Method in class org.apache.flink.streaming.api.operators.InternalTimer.TimerSerializer
-
- serialize(GlobalWindow, DataOutputView) - Method in class org.apache.flink.streaming.api.windowing.windows.GlobalWindow.Serializer
-
- serialize(TimeWindow, DataOutputView) - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow.Serializer
-
- serialize(FlinkKafkaProducer011.KafkaTransactionContext, DataOutputView) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer011.ContextStateSerializer
-
- serialize(FlinkKafkaProducer011.KafkaTransactionState, DataOutputView) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer011.TransactionStateSerializer
-
- serialize(KafkaEvent) - Method in class org.apache.flink.streaming.examples.kafka.KafkaEventSchema
-
- serialize(Event) - Method in class org.apache.flink.streaming.examples.statemachine.kafka.EventDeSerializer
-
- serialize(PyObject) - Method in class org.apache.flink.streaming.python.util.serialization.PythonSerializationSchema
-
- serialize(StreamElement, DataOutputView) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
-
- serialize(T) - Method in interface org.apache.flink.streaming.util.serialization.SerializationSchema
-
Deprecated.
Serializes the incoming element to a specified type.
- serialize(DataOutputView) - Method in class org.apache.flink.types.Record
-
Writes this record to the given output view.
- serializeAndTryOffload(T, JobID, BlobWriter) - Static method in interface org.apache.flink.runtime.blob.BlobWriter
-
Serializes the given value and offloads it to the BlobServer if its size exceeds the minimum
offloading size of the BlobServer.
- serializedCounters - Variable in class org.apache.flink.runtime.metrics.dump.MetricDumpSerialization.MetricSerializationResult
-
- serializedGauges - Variable in class org.apache.flink.runtime.metrics.dump.MetricDumpSerialization.MetricSerializationResult
-
- serializedHistograms - Variable in class org.apache.flink.runtime.metrics.dump.MetricDumpSerialization.MetricSerializationResult
-
- SerializedInputFormat<T extends IOReadableWritable> - Class in org.apache.flink.api.common.io
-
Reads elements by deserializing them with their regular serialization/deserialization functionality.
- SerializedInputFormat() - Constructor for class org.apache.flink.api.common.io.SerializedInputFormat
-
- SerializedInputSplit - Class in org.apache.flink.runtime.jobmaster
-
- SerializedInputSplit(byte[]) - Constructor for class org.apache.flink.runtime.jobmaster.SerializedInputSplit
-
- SerializedJobExecutionResult - Class in org.apache.flink.runtime.client
-
- SerializedJobExecutionResult(JobID, long, Map<String, SerializedValue<OptionalFailure<Object>>>) - Constructor for class org.apache.flink.runtime.client.SerializedJobExecutionResult
-
Creates a new SerializedJobExecutionResult.
- SerializedListAccumulator<T> - Class in org.apache.flink.api.common.accumulators
-
This accumulator stores a collection of objects in serialized form, so that the stored objects
are not affected by modifications to the original objects.
- SerializedListAccumulator() - Constructor for class org.apache.flink.api.common.accumulators.SerializedListAccumulator
-
- serializedMeters - Variable in class org.apache.flink.runtime.metrics.dump.MetricDumpSerialization.MetricSerializationResult
-
- SerializedOutputFormat<T extends IOReadableWritable> - Class in org.apache.flink.api.common.io
-
Stores elements by serializing them with their regular serialization/deserialization functionality.
- SerializedOutputFormat() - Constructor for class org.apache.flink.api.common.io.SerializedOutputFormat
-
- serializedThrowable(SerializedThrowable) - Method in class org.apache.flink.runtime.jobmaster.JobResult.Builder
-
- SerializedThrowable - Exception in 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) - Constructor for exception org.apache.flink.util.SerializedThrowable
-
Create a new SerializedThrowable.
- SerializedThrowableDeserializer - Class in org.apache.flink.runtime.rest.messages.json
-
- SerializedThrowableDeserializer() - Constructor for class org.apache.flink.runtime.rest.messages.json.SerializedThrowableDeserializer
-
- SerializedThrowableSerializer - Class in org.apache.flink.runtime.rest.messages.json
-
- SerializedThrowableSerializer() - Constructor for class org.apache.flink.runtime.rest.messages.json.SerializedThrowableSerializer
-
- SerializedUpdateBuffer - Class in org.apache.flink.runtime.iterative.io
-
- SerializedUpdateBuffer() - Constructor for class org.apache.flink.runtime.iterative.io.SerializedUpdateBuffer
-
- SerializedUpdateBuffer(List<MemorySegment>, int, IOManager) - Constructor for class org.apache.flink.runtime.iterative.io.SerializedUpdateBuffer
-
- serializedValue - Variable in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor.NonOffloaded
-
The serialized value.
- SerializedValue<T> - Class in org.apache.flink.util
-
This class is used to transfer (via serialization) objects whose classes are not available
in the system class loader.
- SerializedValue(T) - Constructor for class org.apache.flink.util.SerializedValue
-
- SerializedValueDeserializer - Class in org.apache.flink.runtime.rest.messages.json
-
- SerializedValueDeserializer() - Constructor for class org.apache.flink.runtime.rest.messages.json.SerializedValueDeserializer
-
- SerializedValueDeserializer(JavaType) - Constructor for class org.apache.flink.runtime.rest.messages.json.SerializedValueDeserializer
-
- serializedValueKey - Variable in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor.Offloaded
-
The key of the offloaded value BLOB.
- SerializedValueSerializer - Class in org.apache.flink.runtime.rest.messages.json
-
- SerializedValueSerializer() - Constructor for class org.apache.flink.runtime.rest.messages.json.SerializedValueSerializer
-
- SerializedValueSerializer(JavaType) - Constructor for class org.apache.flink.runtime.rest.messages.json.SerializedValueSerializer
-
- serializeField(Field, ObjectOutputStream) - Static method in class org.apache.flink.api.java.typeutils.runtime.FieldSerializer
-
- serializeInternal(T) - Method in class org.apache.flink.python.api.streaming.data.PythonSender.Serializer
-
- serializeKey(T) - Method in interface org.apache.flink.streaming.util.serialization.KeyedSerializationSchema
-
Serializes the key of the incoming element to a byte array
This method might return null if no key is available.
- serializeKey(T) - Method in class org.apache.flink.streaming.util.serialization.KeyedSerializationSchemaWrapper
-
- serializeKey(Tuple2<K, V>) - Method in class org.apache.flink.streaming.util.serialization.TypeInformationKeyValueSerializationSchema
-
- serializeKeyAndNamespace(K, TypeSerializer<K>, N, TypeSerializer<N>) - Static method in class org.apache.flink.queryablestate.client.state.serialization.KvStateSerializer
-
Serializes the key and namespace into a
ByteBuffer
.
- serializeKeyedStateHandle(KeyedStateHandle, DataOutputStream) - Static method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV1Serializer
-
- serializeMap(Iterable<Map.Entry<UK, UV>>, TypeSerializer<UK>, TypeSerializer<UV>) - Static method in class org.apache.flink.queryablestate.client.state.serialization.KvStateSerializer
-
Serializes all values of the Iterable with the given serializer.
- serializeObject(Object) - Static method in class org.apache.flink.streaming.python.util.serialization.SerializationUtils
-
- serializeObject(Object) - Static method in class org.apache.flink.util.InstantiationUtil
-
- serializeObject(OutputStream, Object) - Static method in class org.apache.flink.util.InstantiationUtil
-
- serializeOld(SavepointV1, DataOutputStream) - Method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV1Serializer
-
- serializeOperatorStateHandle(OperatorStateHandle, DataOutputStream) - Static method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV1Serializer
-
- serializer - Variable in class org.apache.flink.api.common.state.StateDescriptor
-
The serializer for the type.
- Serializer() - Constructor for class org.apache.flink.python.api.streaming.data.PythonSender.Serializer
-
- Serializer() - Constructor for class org.apache.flink.python.api.streaming.util.SerializationUtils.Serializer
-
- serializer - Variable in class org.apache.flink.runtime.operators.resettable.SpillingResettableIterator
-
- serializer - Variable in class org.apache.flink.runtime.operators.resettable.SpillingResettableMutableObjectIterator
-
- serializer - Variable in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SpillingThread
-
- Serializer() - Constructor for class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedMetricsResponseBody.Serializer
-
- Serializer() - Constructor for class org.apache.flink.runtime.rest.messages.job.metrics.MetricCollectionResponseBody.Serializer
-
- Serializer() - Constructor for class org.apache.flink.runtime.rest.messages.JobConfigInfo.Serializer
-
- Serializer() - Constructor for class org.apache.flink.runtime.rest.messages.JobPlanInfo.RawJson.Serializer
-
- Serializer() - Constructor for class org.apache.flink.streaming.api.windowing.windows.GlobalWindow.Serializer
-
- Serializer() - Constructor for class org.apache.flink.streaming.api.windowing.windows.TimeWindow.Serializer
-
- serializer - Variable in class org.apache.flink.streaming.connectors.cassandra.CassandraSink.CassandraSinkBuilder
-
- serializer - Variable in class org.apache.flink.streaming.runtime.operators.GenericWriteAheadSink
-
- serializer1 - Variable in class org.apache.flink.runtime.operators.sort.AbstractMergeIterator
-
- serializer2 - Variable in class org.apache.flink.runtime.operators.sort.AbstractMergeIterator
-
- serializeRequest(ByteBufAllocator, long, REQ) - Static method in class org.apache.flink.queryablestate.network.messages.MessageSerializer
-
- serializeRequestFailure(ByteBufAllocator, long, Throwable) - Static method in class org.apache.flink.queryablestate.network.messages.MessageSerializer
-
Serializes the exception containing the failure message sent to the
Client
in case of
protocol related errors.
- serializeResponse(ByteBufAllocator, long, RESP) - Static method in class org.apache.flink.queryablestate.network.messages.MessageSerializer
-
Serializes the response sent to the
Client
.
- SerializerMap<IN> - Class in org.apache.flink.python.api.functions.util
-
Utility function to serialize values, usually directly from data sources.
- SerializerMap() - Constructor for class org.apache.flink.python.api.functions.util.SerializerMap
-
- Serializers - Class in org.apache.flink.api.java.typeutils.runtime.kryo
-
Class containing utilities for the serializers of the Flink Runtime.
- Serializers() - Constructor for class org.apache.flink.api.java.typeutils.runtime.kryo.Serializers
-
- serializers - Variable in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
-
serializers to deserialize the first n fields for comparison
- Serializers.DummyAvroKryoSerializerClass<T> - Class in org.apache.flink.api.java.typeutils.runtime.kryo
-
This is used in case we don't have Avro on the classpath.
- Serializers.DummyAvroRegisteredClass - Class in 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> - Class in org.apache.flink.api.java.typeutils.runtime.kryo
-
Special serializer for Java collections enforcing certain instance types.
- Serializers.SpecificInstanceCollectionSerializerForArrayList - Class in org.apache.flink.api.java.typeutils.runtime.kryo
-
Special serializer for Java's
ArrayList
used for Avro's GenericData.Array.
- serializeServerFailure(ByteBufAllocator, Throwable) - Static method in class org.apache.flink.queryablestate.network.messages.MessageSerializer
-
Serializes the failure message sent to the
Client
in case of
server related errors.
- serializeStreamStateHandle(StreamStateHandle, DataOutputStream) - Static method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV1Serializer
-
- serializeToByteArray(TypeSerializer<T>, T) - Static method in class org.apache.flink.util.InstantiationUtil
-
- serializeValue(T, TypeSerializer<T>) - Static method in class org.apache.flink.queryablestate.client.state.serialization.KvStateSerializer
-
Serializes the value with the given serializer.
- serializeValue(T) - Method in interface org.apache.flink.streaming.util.serialization.KeyedSerializationSchema
-
Serializes the value of the incoming element to a byte array.
- serializeValue(T) - Method in class org.apache.flink.streaming.util.serialization.KeyedSerializationSchemaWrapper
-
- serializeValue(Tuple2<K, V>) - Method in class org.apache.flink.streaming.util.serialization.TypeInformationKeyValueSerializationSchema
-
- serializeWithoutTypeInfo(Boolean) - Method in class org.apache.flink.python.api.streaming.util.SerializationUtils.BooleanSerializer
-
- serializeWithoutTypeInfo(Byte) - Method in class org.apache.flink.python.api.streaming.util.SerializationUtils.ByteSerializer
-
- serializeWithoutTypeInfo(byte[]) - Method in class org.apache.flink.python.api.streaming.util.SerializationUtils.BytesSerializer
-
- serializeWithoutTypeInfo(CustomTypeWrapper) - Method in class org.apache.flink.python.api.streaming.util.SerializationUtils.CustomTypeWrapperSerializer
-
- serializeWithoutTypeInfo(Double) - Method in class org.apache.flink.python.api.streaming.util.SerializationUtils.DoubleSerializer
-
- serializeWithoutTypeInfo(Float) - Method in class org.apache.flink.python.api.streaming.util.SerializationUtils.FloatSerializer
-
- serializeWithoutTypeInfo(Integer) - Method in class org.apache.flink.python.api.streaming.util.SerializationUtils.IntSerializer
-
- serializeWithoutTypeInfo(Long) - Method in class org.apache.flink.python.api.streaming.util.SerializationUtils.LongSerializer
-
- serializeWithoutTypeInfo(Object) - Method in class org.apache.flink.python.api.streaming.util.SerializationUtils.NullSerializer
-
- serializeWithoutTypeInfo(IN) - Method in class org.apache.flink.python.api.streaming.util.SerializationUtils.Serializer
-
- serializeWithoutTypeInfo(String) - Method in class org.apache.flink.python.api.streaming.util.SerializationUtils.StringSerializer
-
- serializeWithoutTypeInfo(Tuple) - Method in class org.apache.flink.python.api.streaming.util.SerializationUtils.TupleSerializer
-
- serialVersionUID - Static variable in interface org.apache.flink.cep.EventComparator
-
- server - Variable in class org.apache.flink.python.api.streaming.data.PythonStreamer
-
- SERVER_ASYNC_QUERY_THREADS - Static variable in class org.apache.flink.configuration.QueryableStateOptions
-
Number of async query threads for the KvStateServerHandler (0 => #slots).
- SERVER_MAX_CONTENT_LENGTH - Static variable in class org.apache.flink.configuration.RestOptions
-
The maximum content length that the server will handle.
- SERVER_NETWORK_THREADS - Static variable in class org.apache.flink.configuration.QueryableStateOptions
-
Number of network (event loop) threads for the KvState server (0 => #slots).
- SERVER_NUM_THREADS - Static variable in class org.apache.flink.configuration.RestOptions
-
- SERVER_PORT_RANGE - Static variable in class org.apache.flink.configuration.QueryableStateOptions
-
The config parameter defining the server port range of the queryable state server.
- SERVER_SOCKET_WORKER_POOL_SIZE_FACTOR - Static variable in class org.apache.flink.configuration.AkkaOptions
-
- SERVER_SOCKET_WORKER_POOL_SIZE_MAX - Static variable in class org.apache.flink.configuration.AkkaOptions
-
- SERVER_SOCKET_WORKER_POOL_SIZE_MIN - Static variable in class org.apache.flink.configuration.AkkaOptions
-
- SERVER_THREAD_PRIORITY - Static variable in class org.apache.flink.configuration.RestOptions
-
- serverAddress - Variable in class org.apache.flink.runtime.blob.AbstractBlobCache
-
- ServicesThreadFactory - Class in org.apache.flink.runtime.highavailability
-
- ServicesThreadFactory() - Constructor for class org.apache.flink.runtime.highavailability.ServicesThreadFactory
-
- session - Variable in class org.apache.flink.streaming.connectors.cassandra.CassandraRowWriteAheadSink
-
- session - Variable in class org.apache.flink.streaming.connectors.cassandra.CassandraSinkBase
-
- session - Variable in class org.apache.flink.streaming.connectors.cassandra.CassandraTupleWriteAheadSink
-
- SessionClusterEntrypoint - Class in org.apache.flink.runtime.entrypoint
-
Base class for session cluster entry points.
- SessionClusterEntrypoint(Configuration) - Constructor for class org.apache.flink.runtime.entrypoint.SessionClusterEntrypoint
-
- SessionContext - Class in org.apache.flink.table.client.gateway
-
Context describing a session.
- SessionContext(String, Environment) - Constructor for class org.apache.flink.table.client.gateway.SessionContext
-
- sessionIds - Variable in class org.apache.flink.streaming.api.functions.source.MultipleIdsMessageAcknowledgingSourceBase
-
- sessionIdsPerSnapshot - Variable in class org.apache.flink.streaming.api.functions.source.MultipleIdsMessageAcknowledgingSourceBase
-
- sessionTimeout - Variable in class org.apache.flink.api.java.ExecutionEnvironment
-
The session timeout in seconds.
- sessionTimeout - Variable in class org.apache.flink.streaming.api.windowing.assigners.EventTimeSessionWindows
-
- sessionTimeout - Variable in class org.apache.flink.streaming.api.windowing.assigners.ProcessingTimeSessionWindows
-
- SessionWindowing - Class in org.apache.flink.streaming.examples.windowing
-
An example of session windowing that keys events by ID and groups and counts them in
session with gaps of 3 milliseconds.
- SessionWindowing() - Constructor for class org.apache.flink.streaming.examples.windowing.SessionWindowing
-
- SessionWindowingData - Class in org.apache.flink.streaming.examples.windowing.util
-
Data for SessionWindowingITCase.
- sessionWindowTimeGapExtractor - Variable in class org.apache.flink.streaming.api.windowing.assigners.DynamicEventTimeSessionWindows
-
- sessionWindowTimeGapExtractor - Variable in class org.apache.flink.streaming.api.windowing.assigners.DynamicProcessingTimeSessionWindows
-
- SessionWindowTimeGapExtractor<T> - Interface in org.apache.flink.streaming.api.windowing.assigners
-
A SessionWindowTimeGapExtractor
extracts session time gaps for Dynamic Session Window Assigners.
- set(Iterator<Tuple3<K1, K2, T>>) - Method in class org.apache.flink.api.java.operators.translation.Tuple3UnwrappingIterator
-
- set(Collector<Tuple3<K1, K2, IN>>) - Method in class org.apache.flink.api.java.operators.translation.Tuple3WrappingCollector
-
- set(Iterator<Tuple2<K, T>>) - Method in class org.apache.flink.api.java.operators.translation.TupleUnwrappingIterator
-
- set(Collector<Tuple2<K, IN>>) - Method in class org.apache.flink.api.java.operators.translation.TupleWrappingCollector
-
- set(boolean) - Method in class org.apache.flink.graph.utils.proxy.OptionalBoolean
-
Set the boolean state.
- set(Iterator<Tuple2<KEY, VALUE>>) - Method in class org.apache.flink.hadoopcompatibility.mapred.wrapper.HadoopTupleUnwrappingIterator
-
Set the Flink iterator to wrap.
- set(int) - Method in class org.apache.flink.runtime.operators.util.BitSet
-
Sets the bit at specified index.
- set(int) - Method in class org.apache.flink.runtime.operators.util.BloomFilter.BitSet
-
Sets the bit at specified index.
- set(int, T) - Method in class org.apache.flink.runtime.util.EvictingBoundedList
-
- set(E) - Method in class org.apache.flink.runtime.util.SingleElementIterator
-
Resets the element.
- set(T, F) - Method in class org.apache.flink.streaming.util.typeutils.FieldAccessor
-
Sets the field (specified in the constructor) of the given record to the given value.
- set(boolean) - Method in class org.apache.flink.types.BooleanValue
-
- set(int, V) - Method in class org.apache.flink.types.ListValue
-
- set(String, String) - Method in class org.apache.hadoop.conf.Configuration
-
Set the value
of the name
property.
- set(String, String, String) - Method in class org.apache.hadoop.conf.Configuration
-
Set the value
of the name
property.
- set_parallelism(int) - Method in class org.apache.flink.streaming.python.api.environment.PythonStreamExecutionEnvironment
-
- setAbsoluteTimestamp(long) - Method in class org.apache.flink.cep.operator.TimestampedSideOutputCollector
-
- setAbsoluteTimestamp(long) - Method in class org.apache.flink.streaming.api.operators.TimestampedCollector
-
- setAccumulatedRecordCount(long) - Method in class org.apache.flink.api.common.io.BlockInfo
-
Sets the accumulatedRecordCount to the specified value.
- setAccumulators(Map<String, Accumulator<?, ?>>) - Method in class org.apache.flink.runtime.executiongraph.Execution
-
Update accumulators (discarded when the Execution has already been terminated).
- setAdamicAdarScore(FloatValue) - Method in class org.apache.flink.graph.library.similarity.AdamicAdar.Result
-
Set the Adamic-Adar score, equal to the sum over common neighbors of
the inverse logarithm of degree.
- setAlignmentDurationNanos(long) - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetrics
-
- setAllocator(ByteBufAllocator) - Method in interface org.apache.flink.runtime.io.network.buffer.Buffer
-
Sets the buffer allocator for use in netty.
- setAllocator(ByteBufAllocator) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
-
- setAllocator(ByteBufAllocator) - Method in class org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
-
- setAllowNullValueProperties(boolean) - Method in class org.apache.hadoop.conf.Configuration
-
Set Configuration to allow keys without values during setup.
- setAllowNullValues(boolean) - Method in class org.apache.flink.api.java.io.CsvOutputFormat
-
Configures the format to either allow null values (writing an empty field),
or to throw an exception when encountering a null field.
- setAllowNullValues(boolean) - Method in class org.apache.flink.api.scala.operators.ScalaCsvOutputFormat
-
Configures the format to either allow null values (writing an empty field),
or to throw an exception when encountering a null field.
- setAllowQueuedScheduling(boolean) - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
- setAnalyzedUdfSemanticsFlag() - Method in class org.apache.flink.api.java.operators.SingleInputUdfOperator
-
- setAnalyzedUdfSemanticsFlag() - Method in class org.apache.flink.api.java.operators.TwoInputUdfOperator
-
- setAndCheckDiscoveredPartition(KafkaTopicPartition) - Method in class org.apache.flink.streaming.connectors.kafka.internals.AbstractPartitionDiscoverer
-
Sets a partition as discovered.
- setAnyDistribution() - Method in class org.apache.flink.optimizer.dataproperties.RequestedGlobalProperties
-
- setAnyPartitioning(FieldList) - Method in class org.apache.flink.optimizer.dataproperties.GlobalProperties
-
- setAnyPartitioning(FieldSet) - Method in class org.apache.flink.optimizer.dataproperties.RequestedGlobalProperties
-
Sets these properties to request some partitioning on the given fields.
- setAsContext() - Method in class org.apache.flink.api.java.ScalaShellRemoteStreamEnvironment
-
- setAsContext() - Method in class org.apache.flink.client.program.PreviewPlanEnvironment
-
- setAsContext(JobExecutor, int, Collection<Path>, Collection<URL>) - Static method in class org.apache.flink.streaming.util.TestStreamEnvironment
-
Sets the streaming context environment to a TestStreamEnvironment that runs its programs on
the given cluster with the given default parallelism and the specified jar files and class
paths.
- setAsContext(JobExecutor, int) - Static method in class org.apache.flink.streaming.util.TestStreamEnvironment
-
Sets the streaming context environment to a TestStreamEnvironment that runs its programs on
the given cluster with the given default parallelism.
- setAsContext() - Method in class org.apache.flink.test.util.CollectionTestEnvironment
-
- setAsContext() - Method in class org.apache.flink.test.util.TestEnvironment
-
- setAsContext(JobExecutor, int, Collection<Path>, Collection<URL>) - Static method in class org.apache.flink.test.util.TestEnvironment
-
- setAsContext(JobExecutor, int) - Static method in class org.apache.flink.test.util.TestEnvironment
-
- setAsyncDurationMillis(long) - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetrics
-
- setAsyncTimeout(long) - Method in class org.apache.flink.streaming.connectors.fs.bucketing.BucketingSink
-
Sets the default timeout for asynchronous operations such as recoverLease and truncate.
- setAsyncTimeout(long) - Method in class org.apache.flink.streaming.connectors.fs.RollingSink
-
Deprecated.
Sets the default timeout for asynchronous operations such as recoverLease and truncate.
- setAuthorityScore(DoubleValue) - Method in class org.apache.flink.graph.library.linkanalysis.HITS.Result
-
Set the authority score.
- setAutomaticRecovery(boolean) - Method in class org.apache.flink.streaming.connectors.rabbitmq.common.RMQConnectionConfig.Builder
-
Enables or disables automatic connection recovery.
- setAutoWatermarkInterval(long) - Method in class org.apache.flink.api.common.ExecutionConfig
-
Sets the interval of the automatic watermark emission.
- setAvgOutputRecordSize(float) - Method in class org.apache.flink.api.common.operators.CompilerHints
-
- setBackoffType(ElasticsearchSinkBase.FlushBackoffType) - Method in class org.apache.flink.streaming.connectors.elasticsearch.ElasticsearchSinkBase.BulkFlushBackoffPolicy
-
- setBatchInterval(int) - Method in class org.apache.flink.api.java.io.jdbc.JDBCOutputFormat.JDBCOutputFormatBuilder
-
- setBatchSize(int) - Method in class org.apache.flink.api.java.io.jdbc.JDBCAppendTableSinkBuilder
-
Specify the size of the batch.
- setBatchSize(long) - Method in class org.apache.flink.streaming.connectors.fs.bucketing.BucketingSink
-
Sets the maximum bucket size in bytes.
- setBatchSize(long) - Method in class org.apache.flink.streaming.connectors.fs.RollingSink
-
Deprecated.
Sets the maximum bucket size in bytes.
- setBitmask(ByteValue) - Method in class org.apache.flink.graph.library.clustering.directed.TriangleListing.Result
-
Set the bitmask indicating the presence of the six potential
connecting edges.
- setBitmask(byte) - Method in class org.apache.flink.graph.library.clustering.directed.TriangleListing.Result
-
- setBitsLocation(MemorySegment, int) - Method in class org.apache.flink.runtime.operators.util.BloomFilter
-
- setBlobServerAddress(InetSocketAddress) - Method in class org.apache.flink.runtime.blob.AbstractBlobCache
-
- setBlobServerAddress(InetSocketAddress) - Method in class org.apache.flink.runtime.blob.BlobCacheService
-
- setBlockSize(long) - Method in class org.apache.flink.api.common.io.BinaryInputFormat
-
- setBoolean(String, boolean) - Method in class org.apache.flink.configuration.Configuration
-
Adds the given key/value pair to the configuration object.
- setBoolean(ConfigOption<Boolean>, boolean) - Method in class org.apache.flink.configuration.Configuration
-
Adds the given value to the configuration object.
- setBoolean(String, boolean) - Method in class org.apache.flink.configuration.DelegatingConfiguration
-
- setBoolean(ConfigOption<Boolean>, boolean) - Method in class org.apache.flink.configuration.DelegatingConfiguration
-
- setBoolean(String, boolean) - Method in class org.apache.hadoop.conf.Configuration
-
Set the value of the name
property to a boolean
.
- setBooleanIfUnset(String, boolean) - Method in class org.apache.hadoop.conf.Configuration
-
Set the given property, if it is currently unset.
- setBottomId(KB) - Method in class org.apache.flink.graph.bipartite.BipartiteEdge
-
- setBroadcastGateIterativeWithNumberOfEventsUntilInterrupt(int, int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setBroadcastHighDegreeVertices(boolean) - Method in class org.apache.flink.graph.asm.degree.filter.undirected.MaximumDegree
-
After filtering high-degree vertices this algorithm must perform joins
on the original graph's vertex set and on both the source and target IDs
of the edge set.
- setBroadcastInputName(String, int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setBroadcastInputs(Map<Operator<?>, OptimizerNode>, ExecutionMode) - Method in class org.apache.flink.optimizer.dag.OptimizerNode
-
This function connects the operators that produce the broadcast inputs to this operator.
- setBroadcastInputs(List<NamedChannel>) - Method in class org.apache.flink.optimizer.plan.PlanNode
-
Sets a list of all broadcast inputs attached to this node.
- setBroadcastInputSerializer(TypeSerializerFactory<?>, int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setBroadcastVariable(String, List<?>) - Method in class org.apache.flink.api.common.functions.util.RuntimeUDFContext
-
- setBroadcastVariable(String, Operator<?>) - Method in class org.apache.flink.api.common.operators.AbstractUdfOperator
-
Binds the result produced by a plan rooted at root
to a variable
used by the UDF wrapped in this operator.
- setBroadcastVariable(String, Operator<?>) - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase
-
The BulkIteration meta operator cannot have broadcast inputs.
- setBroadcastVariable(String, Operator<?>) - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase
-
The DeltaIteration meta operator cannot have broadcast inputs.
- setBroadcastVariable(String, BroadcastVariableMaterialization<?, ?>) - Method in class org.apache.flink.runtime.operators.util.DistributedRuntimeUDFContext
-
- setBroadcastVariables(Map<String, Operator<T>>) - Method in class org.apache.flink.api.common.operators.AbstractUdfOperator
-
Clears all previous broadcast inputs and binds the given inputs as
broadcast variables of this operator.
- setBroadcastVariables(Map<String, Operator<X>>) - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase
-
The BulkIteration meta operator cannot have broadcast inputs.
- setBroadcastVariables(Map<String, Operator<X>>) - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase
-
The DeltaIteration meta operator cannot have broadcast inputs.
- setBucketer(Bucketer<T>) - Method in class org.apache.flink.streaming.connectors.fs.bucketing.BucketingSink
-
Sets the
Bucketer
to use for determining the bucket files to write to.
- setBucketer(Bucketer) - Method in class org.apache.flink.streaming.connectors.fs.RollingSink
-
Deprecated.
Sets the
Bucketer
to use for determining the bucket files to write to.
- setBuffer(ByteBuffer) - Method in class org.apache.flink.core.memory.DataInputDeserializer
-
- setBuffer(byte[], int, int) - Method in class org.apache.flink.core.memory.DataInputDeserializer
-
- setBufferPool(BufferPool) - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
-
- setBufferSize(int) - Method in class org.apache.flink.api.common.io.DelimitedInputFormat
-
- setBufferTimeout(long) - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
-
Sets the buffering timeout for data produced by this operation.
- setBufferTimeout(long) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Sets the maximum time frequency (milliseconds) for the flushing of the
output buffers.
- setBufferTimeout(long) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setBufferTimeout(Integer, long) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- setBufferTimeout(Long) - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- setBufferTimeout(long) - Method in class org.apache.flink.streaming.api.transformations.StreamTransformation
-
Set the buffer timeout of this StreamTransformation
.
- setBytes(String, byte[]) - Method in class org.apache.flink.configuration.Configuration
-
Adds the given byte array to the configuration object.
- setBytes(String, byte[]) - Method in class org.apache.flink.configuration.DelegatingConfiguration
-
- setBytes(int, ByteBuf, int, int) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
-
- setBytes(int, byte[], int, int) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
-
- setBytes(int, ByteBuffer) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
-
- setBytes(int, InputStream, int) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
-
- setBytes(int, ScatteringByteChannel, int) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
-
- setBytesBufferedInAlignment(long) - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetrics
-
- setCachable(boolean) - Method in class org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact.Builder
-
- SetCache - Class in org.apache.flink.python.api.util
-
- SetCache() - Constructor for class org.apache.flink.python.api.util.SetCache
-
- setCancellerHandle(ScheduledFuture<?>) - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
-
Sets the handle for the canceller to this pending checkpoint.
- setCandidateProperties(GlobalProperties, LocalProperties, Channel) - Method in class org.apache.flink.optimizer.dag.BulkPartialSolutionNode
-
- setCandidateProperties(GlobalProperties, LocalProperties, Channel) - Method in class org.apache.flink.optimizer.dag.SolutionSetNode
-
- setCandidateProperties(GlobalProperties, LocalProperties, Channel) - Method in class org.apache.flink.optimizer.dag.WorksetNode
-
- setChainedOutputs(List<StreamEdge>) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setChainEnd() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setChainIndex(int) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setChaining(boolean) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- setChainingStrategy(ChainingStrategy) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- setChainingStrategy(ChainingStrategy) - Method in interface org.apache.flink.streaming.api.operators.StreamOperator
-
- setChainingStrategy(ChainingStrategy) - Method in class org.apache.flink.streaming.api.transformations.CoFeedbackTransformation
-
- setChainingStrategy(ChainingStrategy) - Method in class org.apache.flink.streaming.api.transformations.FeedbackTransformation
-
- setChainingStrategy(ChainingStrategy) - Method in class org.apache.flink.streaming.api.transformations.OneInputTransformation
-
- setChainingStrategy(ChainingStrategy) - Method in class org.apache.flink.streaming.api.transformations.PartitionTransformation
-
- setChainingStrategy(ChainingStrategy) - Method in class org.apache.flink.streaming.api.transformations.SelectTransformation
-
- setChainingStrategy(ChainingStrategy) - Method in class org.apache.flink.streaming.api.transformations.SideOutputTransformation
-
- setChainingStrategy(ChainingStrategy) - Method in class org.apache.flink.streaming.api.transformations.SinkTransformation
-
- setChainingStrategy(ChainingStrategy) - Method in class org.apache.flink.streaming.api.transformations.SourceTransformation
-
- setChainingStrategy(ChainingStrategy) - Method in class org.apache.flink.streaming.api.transformations.SplitTransformation
-
- setChainingStrategy(ChainingStrategy) - Method in class org.apache.flink.streaming.api.transformations.StreamTransformation
-
Sets the chaining strategy of this StreamTransformation
.
- setChainingStrategy(ChainingStrategy) - Method in class org.apache.flink.streaming.api.transformations.TwoInputTransformation
-
- setChainingStrategy(ChainingStrategy) - Method in class org.apache.flink.streaming.api.transformations.UnionTransformation
-
- setChainStart() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setChannelIndex(int) - Method in class org.apache.flink.runtime.io.network.partition.consumer.BufferOrEvent
-
- setCharset(String) - Method in class org.apache.flink.addons.hbase.HBaseTableSource
-
Specifies the charset to parse Strings to HBase byte[] keys and String values.
- setCharset(String) - Method in class org.apache.flink.api.common.io.DelimitedInputFormat
-
Set the name of the character set used for the row delimiter.
- setCharset(String) - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
-
- setCharset(String) - Method in class org.apache.flink.api.java.io.CsvReader
-
Sets the charset of the reader.
- setCharset(Charset) - Method in class org.apache.flink.types.parser.FieldParser
-
Sets the character set used for this parser.
- setCharsetName(String) - Method in class org.apache.flink.api.java.io.CsvOutputFormat
-
Sets the charset with which the CSV strings are written to the file.
- setCharsetName(String) - Method in class org.apache.flink.api.java.io.TextInputFormat
-
- setCharsetName(String) - Method in class org.apache.flink.api.java.io.TextOutputFormat
-
- setCharsetName(String) - Method in class org.apache.flink.api.java.io.TextValueInputFormat
-
- setCharsetName(String) - Method in class org.apache.flink.api.scala.operators.ScalaCsvOutputFormat
-
Sets the charset with which the CSV strings are written to the file.
- setCheckpointingEnabled(boolean) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setCheckpointingMode(CheckpointingMode) - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Sets the checkpointing mode (exactly-once vs.
- setCheckpointInterval(long) - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Sets the interval in which checkpoints are periodically scheduled.
- setCheckpointMode(CheckpointingMode) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setCheckpointStatsTracker(CheckpointStatsTracker) - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
Sets the checkpoint stats tracker.
- setCheckpointTimeout(long) - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Sets the maximum time that a checkpoint may take before being discarded.
- setCheckpointTrigger(ExternallyInducedSource.CheckpointTrigger) - Method in interface org.apache.flink.streaming.api.checkpoint.ExternallyInducedSource
-
Sets the checkpoint trigger through which the source can trigger the checkpoint.
- setClass(String, Class<?>) - Method in class org.apache.flink.configuration.Configuration
-
Adds the given key/value pair to the configuration object.
- setClass(String, Class<?>) - Method in class org.apache.flink.configuration.DelegatingConfiguration
-
- setClass(String, Class<?>, Class<?>) - Method in class org.apache.hadoop.conf.Configuration
-
Set the value of the name
property to the name of a
theClass
implementing the given interface xface
.
- setClassLoader(ClassLoader) - Method in class org.apache.hadoop.conf.Configuration
-
Set the class loader that will be used to load the various objects.
- setClasspaths(List<URL>) - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
Sets the classpaths required to run the job on a task manager.
- setClock(Clock) - Static method in class org.apache.flink.streaming.connectors.fs.DateTimeBucketer
-
Deprecated.
This sets the internal
Clock
implementation.
- setClusterBuilder(ClusterBuilder) - Method in class org.apache.flink.streaming.connectors.cassandra.CassandraSink.CassandraSinkBuilder
-
Sets the ClusterBuilder for this sink.
- setClusterId(C) - Method in class org.apache.flink.table.client.gateway.local.CollectStreamResult
-
- setClusterId(C) - Method in interface org.apache.flink.table.client.gateway.local.DynamicResult
-
Sets the cluster id of the cluster this result comes from.
- setCodeAnalysisMode(CodeAnalysisMode) - Method in class org.apache.flink.api.common.ExecutionConfig
-
- setCodec(AvroOutputFormat.Codec) - Method in class org.apache.flink.formats.avro.AvroOutputFormat
-
Set avro codec for compression.
- setCollector(Collector<PyObject>) - Method in class org.apache.flink.streaming.python.util.PythonCollector
-
- setCombinable(boolean) - Method in class org.apache.flink.api.common.operators.base.GroupReduceOperatorBase
-
Marks the group reduce operation as combinable.
- setCombinable(boolean) - Method in class org.apache.flink.api.java.operators.GroupReduceOperator
-
- setCombinableFirst(boolean) - Method in class org.apache.flink.api.common.operators.base.CoGroupOperatorBase
-
- setCombinableFirst(boolean) - Method in class org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase
-
- setCombinableSecond(boolean) - Method in class org.apache.flink.api.common.operators.base.CoGroupOperatorBase
-
- setCombinableSecond(boolean) - Method in class org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase
-
- setCombineHint(ReduceOperatorBase.CombineHint) - Method in class org.apache.flink.api.common.operators.base.ReduceOperatorBase
-
- setCombineHint(ReduceOperatorBase.CombineHint) - Method in class org.apache.flink.api.java.operators.DistinctOperator
-
Sets the strategy to use for the combine phase of the reduce.
- setCombineHint(ReduceOperatorBase.CombineHint) - Method in class org.apache.flink.api.java.operators.ReduceOperator
-
Sets the strategy to use for the combine phase of the reduce.
- setCommentPrefix(String) - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
-
- setCommitOffsetsOnCheckpoints(boolean) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumerBase
-
Specifies whether or not the consumer should commit offsets back to Kafka on checkpoints.
- setCommittedOffset(long) - Method in class org.apache.flink.streaming.connectors.kafka.internals.KafkaTopicPartitionState
-
- setCommonBindAddress(String) - Method in class org.apache.flink.runtime.minicluster.MiniClusterConfiguration.Builder
-
- setComparator(TypeComparatorFactory<?>, int) - Method in class org.apache.flink.optimizer.plan.SingleInputPlanNode
-
Sets the specified comparator for this PlanNode.
- setComparator1(TypeComparatorFactory<?>) - Method in class org.apache.flink.optimizer.plan.DualInputPlanNode
-
- setComparator2(TypeComparatorFactory<?>) - Method in class org.apache.flink.optimizer.plan.DualInputPlanNode
-
- setCondition(IterativeCondition<T>) - Method in class org.apache.flink.cep.nfa.StateTransition
-
- setConfigDir(String) - Method in class org.apache.flink.runtime.jobmanager.JobManagerCliOptions
-
- setConfigDir(String) - Method in class org.apache.flink.runtime.taskmanager.TaskManagerCliOptions
-
- setConfiguration(Configuration) - Method in class org.apache.flink.runtime.minicluster.MiniClusterConfiguration.Builder
-
- setConnectionTimeout(int) - Method in class org.apache.flink.streaming.connectors.rabbitmq.common.RMQConnectionConfig.Builder
-
Set the connection timeout.
- setConnectionType(StreamPartitioner<T>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Internal function for setting the partitioner for the DataStream.
- setConnectionType(StreamPartitioner<T>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
- setConstants(float, float, float) - Method in class org.apache.flink.graph.generator.RMatGraph
-
The parameters for recursively subdividing the adjacency matrix.
- setContainingIterationNode(BulkIterationPlanNode) - Method in class org.apache.flink.optimizer.plan.BulkPartialSolutionPlanNode
-
- setContainingIterationNode(WorksetIterationPlanNode) - Method in class org.apache.flink.optimizer.plan.SolutionSetPlanNode
-
- setContainingIterationNode(WorksetIterationPlanNode) - Method in class org.apache.flink.optimizer.plan.WorksetPlanNode
-
- setContentTypeHeader(HttpResponse, File) - Static method in class org.apache.flink.runtime.rest.handler.legacy.files.StaticFileServerHandler
-
Sets the content type header for the HTTP Response.
- setContext(Optional<CONTEXT>) - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.State
-
- setConvergenceCriterion(String, ConvergenceCriterion<?>) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setCosts(Costs) - Method in class org.apache.flink.optimizer.plan.BulkIterationPlanNode
-
- setCosts(Costs) - Method in class org.apache.flink.optimizer.plan.PlanNode
-
Sets the basic cost for this node to the given value, and sets the cumulative costs
to those costs plus the cost shares of all inputs (regular and broadcast).
- setCosts(Costs) - Method in class org.apache.flink.optimizer.plan.SinkJoinerPlanNode
-
- setCosts(Costs) - Method in class org.apache.flink.optimizer.plan.WorksetIterationPlanNode
-
- setCount(long) - Method in interface org.apache.flink.runtime.checkpoint.CheckpointIDCounter
-
Sets the current checkpoint ID.
- setCount(long) - Method in class org.apache.flink.runtime.checkpoint.StandaloneCheckpointIDCounter
-
- setCount(long) - Method in class org.apache.flink.runtime.checkpoint.ZooKeeperCheckpointIDCounter
-
- setCpuCores(double) - Method in class org.apache.flink.api.common.operators.ResourceSpec.Builder
-
- setCpuCost(double) - Method in class org.apache.flink.optimizer.costs.Costs
-
Sets the cost for the CPU.
- setCrossHint(CrossOperatorBase.CrossHint) - Method in class org.apache.flink.api.common.operators.base.CrossOperatorBase
-
- setCurrentKey(K) - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
-
- setCurrentKey(K) - Method in interface org.apache.flink.runtime.state.KeyedStateBackend
-
Sets the current key that is used for partitioned state.
- setCurrentKey(Object) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- setCurrentKey(Object) - Method in interface org.apache.flink.streaming.api.operators.KeyContext
-
- setCurrentNamespace(N) - Method in class org.apache.flink.contrib.streaming.state.AbstractRocksDBState
-
- setCurrentNamespace(N) - Method in class org.apache.flink.runtime.state.heap.AbstractHeapState
-
- setCurrentNamespace(N) - Method in interface org.apache.flink.runtime.state.internal.InternalKvState
-
Sets the current namespace, which will be used when using the state access methods.
- setCurrentProgress(float) - Method in class org.apache.flink.yarn.YarnResourceManagerCallbackHandler
-
Sets the current progress.
- setCurrentTime(long) - Method in class org.apache.flink.streaming.runtime.tasks.TestProcessingTimeService
-
- setCurrentWatermark(long) - Method in class org.apache.flink.streaming.runtime.metrics.WatermarkGauge
-
- setCustomEndpointInitializer(TwitterSource.EndpointInitializer) - Method in class org.apache.flink.streaming.connectors.twitter.TwitterSource
-
Set a custom endpoint initializer.
- setCustomPartitioned(FieldList, Partitioner<?>) - Method in class org.apache.flink.optimizer.dataproperties.GlobalProperties
-
- setCustomPartitioned(FieldSet, Partitioner<?>) - Method in class org.apache.flink.optimizer.dataproperties.RequestedGlobalProperties
-
Sets these properties to request a custom partitioning with the given
Partitioner
instance.
- setCustomPartitioner(Partitioner<?>) - Method in class org.apache.flink.api.common.operators.base.CoGroupOperatorBase
-
- setCustomPartitioner(Partitioner<?>) - Method in class org.apache.flink.api.common.operators.base.GroupReduceOperatorBase
-
- setCustomPartitioner(Partitioner<?>) - Method in class org.apache.flink.api.common.operators.base.JoinOperatorBase
-
- setCustomPartitioner(Partitioner<?>) - Method in class org.apache.flink.api.common.operators.base.PartitionOperatorBase
-
- setCustomPartitioner(Partitioner<?>) - Method in class org.apache.flink.api.common.operators.base.ReduceOperatorBase
-
- setCustomPartitioner(Partitioner<?>) - Method in class org.apache.flink.optimizer.operators.AbstractJoinDescriptor
-
- setCustomPartitioner(Partitioner<?>) - Method in class org.apache.flink.optimizer.operators.CoGroupDescriptor
-
- setData(Object) - Method in class org.apache.flink.streaming.python.api.functions.PyKey
-
- setDataDistribution(DataDistribution) - Method in class org.apache.flink.optimizer.plan.Channel
-
- setDataExchangeMode(DataExchangeMode) - Method in class org.apache.flink.optimizer.plan.Channel
-
Sets the data exchange mode (batch / pipelined) to use for the data
exchange of this channel.
- setDateAndCacheHeaders(HttpResponse, File) - Static method in class org.apache.flink.runtime.rest.handler.legacy.files.StaticFileServerHandler
-
Sets the "date" and "cache" headers for the HTTP Response.
- setDateHeader(FullHttpResponse) - Static method in class org.apache.flink.runtime.rest.handler.legacy.files.StaticFileServerHandler
-
Sets the "date" header for the HTTP response.
- setDbStoragePath(String) - Method in class org.apache.flink.contrib.streaming.state.RocksDBStateBackend
-
Sets the path where the RocksDB local database files should be stored on the local
file system.
- setDbStoragePaths(String...) - Method in class org.apache.flink.contrib.streaming.state.RocksDBStateBackend
-
Sets the directories in which the local RocksDB database puts its files (like SST and
metadata files).
- setDBUrl(String) - Method in class org.apache.flink.api.java.io.jdbc.JDBCAppendTableSinkBuilder
-
Specify the URL of the JDBC database.
- setDBUrl(String) - Method in class org.apache.flink.api.java.io.jdbc.JDBCInputFormat.JDBCInputFormatBuilder
-
- setDBUrl(String) - Method in class org.apache.flink.api.java.io.jdbc.JDBCOutputFormat.JDBCOutputFormatBuilder
-
- setDefaultLocalParallelism(int) - Static method in class org.apache.flink.api.java.ExecutionEnvironment
-
- setDefaultLocalParallelism(int) - Static method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- setDefaultOverwriteFiles(boolean) - Method in class org.apache.flink.client.LocalExecutor
-
- setDefaultParallelism(int) - Method in class org.apache.flink.api.common.Plan
-
Sets the default parallelism for this plan.
- setDefaultParallelism(int) - Method in class org.apache.flink.client.RemoteExecutor
-
Sets the parallelism that will be used when neither the program does not define
any parallelism at all.
- setDefaultParallelism(int) - Method in class org.apache.flink.optimizer.Optimizer
-
- setDefaultValue(String) - Method in class org.apache.flink.graph.drivers.parameter.ChoiceParameter
-
- setDefaultValue(double) - Method in class org.apache.flink.graph.drivers.parameter.DoubleParameter
-
Set the default value.
- setDefaultValue(long) - Method in class org.apache.flink.graph.drivers.parameter.LongParameter
-
Set the default value.
- setDefaultValue(T) - Method in class org.apache.flink.graph.drivers.parameter.SimpleParameter
-
Set the default value, used if no value is set by the command-line
configuration.
- setDefaultValue(String) - Method in class org.apache.flink.graph.drivers.parameter.StringParameter
-
- setDegree(LongValue) - Method in class org.apache.flink.graph.library.clustering.directed.LocalClusteringCoefficient.Result
-
Set the vertex degree.
- setDegree(LongValue) - Method in class org.apache.flink.graph.library.clustering.undirected.LocalClusteringCoefficient.Result
-
Set the vertex degree.
- setDelayMillis(long) - Method in class org.apache.flink.streaming.connectors.elasticsearch.ElasticsearchSinkBase.BulkFlushBackoffPolicy
-
- setDelimiter(byte[]) - Method in class org.apache.flink.api.common.io.DelimitedInputFormat
-
- setDelimiter(char) - Method in class org.apache.flink.api.common.io.DelimitedInputFormat
-
- setDelimiter(String) - Method in class org.apache.flink.api.common.io.DelimitedInputFormat
-
- setDeployment(Map<String, Object>) - Method in class org.apache.flink.table.client.config.Environment
-
- setDeprecatedProperties() - Method in class org.apache.hadoop.conf.Configuration
-
Sets all deprecated properties that are not currently set but have a
corresponding new property that is set.
- setDest(Path) - Method in class org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact.Builder
-
- setDetached(boolean) - Method in class org.apache.flink.client.program.ClusterClient
-
Set the mode of this client (detached or blocking job execution).
- setDetachedMode(boolean) - Method in class org.apache.flink.yarn.AbstractYarnClusterDescriptor
-
- setDetachedPlan(FlinkPlan) - Method in class org.apache.flink.client.program.DetachedEnvironment
-
- setDirection(EdgeDirection) - Method in class org.apache.flink.graph.gsa.GSAConfiguration
-
Sets the direction in which neighbors are to be selected
By default the neighbors who are target of the edges are selected.
- setDirection(EdgeDirection) - Method in class org.apache.flink.graph.spargel.ScatterGatherConfiguration
-
Sets the direction in which messages are sent in the ScatterFunction.
- setDirectMemoryInMB(int) - Method in class org.apache.flink.api.common.operators.ResourceSpec.Builder
-
- setDiskCost(double) - Method in class org.apache.flink.optimizer.costs.Costs
-
Sets the costs for disk for this Costs object.
- setDistinctNeighborCount(IntValue) - Method in class org.apache.flink.graph.library.similarity.JaccardIndex.Result
-
Set the distinct neighbor count.
- setDistribution(DataDistribution) - Method in class org.apache.flink.api.common.operators.base.PartitionOperatorBase
-
- setDouble(String, double) - Method in class org.apache.flink.configuration.Configuration
-
Adds the given key/value pair to the configuration object.
- setDouble(ConfigOption<Double>, double) - Method in class org.apache.flink.configuration.Configuration
-
Adds the given value to the configuration object.
- setDouble(String, double) - Method in class org.apache.flink.configuration.DelegatingConfiguration
-
- setDouble(ConfigOption<Double>, double) - Method in class org.apache.flink.configuration.DelegatingConfiguration
-
- setDouble(String, double) - Method in class org.apache.hadoop.conf.Configuration
-
Set the value of the name
property to a double
.
- setDriver(Class<? extends Driver>) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setDriverComparator(TypeComparatorFactory<?>, int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setDriverKeyInfo(FieldList, int) - Method in class org.apache.flink.optimizer.plan.SingleInputPlanNode
-
Sets the key field indexes for the specified driver comparator.
- setDriverKeyInfo(FieldList, boolean[], int) - Method in class org.apache.flink.optimizer.plan.SingleInputPlanNode
-
Sets the key field information for the specified driver comparator.
- setDrivername(String) - Method in class org.apache.flink.api.java.io.jdbc.JDBCAppendTableSinkBuilder
-
Specify the name of the JDBC driver that will be used.
- setDrivername(String) - Method in class org.apache.flink.api.java.io.jdbc.JDBCInputFormat.JDBCInputFormatBuilder
-
- setDrivername(String) - Method in class org.apache.flink.api.java.io.jdbc.JDBCOutputFormat.JDBCOutputFormatBuilder
-
- setDriverPairComparator(TypePairComparatorFactory<?, ?>) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setDriverStrategy(DriverStrategy) - Method in class org.apache.flink.optimizer.plan.PlanNode
-
Sets the driver strategy for this node.
- setDriverStrategy(DriverStrategy) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setDynamicPropertiesEncoded(String) - Method in class org.apache.flink.yarn.AbstractYarnClusterDescriptor
-
- setEdgeGroupCount(Long) - Method in class org.apache.flink.graph.library.Summarization.EdgeValue
-
- setEdgeGroupValue(EV) - Method in class org.apache.flink.graph.library.Summarization.EdgeValue
-
- setEncodeForHTML(boolean) - Method in class org.apache.flink.optimizer.plandump.PlanJSONDumpGenerator
-
- setEndOffsetExclusive(long) - Method in class org.apache.flink.runtime.state.BoundedInputStream
-
- setEnum(String, T) - Method in class org.apache.hadoop.conf.Configuration
-
Set the value of the name
property to the given type.
- setEnv(Map<String, String>) - Static method in class org.apache.flink.core.testutils.CommonTestUtils
-
- setEnv(Map<String, String>, boolean) - Static method in class org.apache.flink.core.testutils.CommonTestUtils
-
- setEnv(Map<String, String>) - Static method in class org.apache.flink.test.util.TestBaseUtils
-
- setError(Throwable) - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputChannel
-
Atomically sets an error for this channel and notifies the input gate about available data to
trigger querying this channel by the task thread.
- setErrorState(FieldParser.ParseErrorState) - Method in class org.apache.flink.types.parser.FieldParser
-
Sets the error state of the parser.
- setEstimatedNumRecords(long) - Method in class org.apache.flink.optimizer.dag.OptimizerNode
-
- setEstimatedOutputSize(long) - Method in class org.apache.flink.optimizer.dag.OptimizerNode
-
- setEventTimeTimers(Set<InternalTimer<K, N>>) - Method in class org.apache.flink.streaming.api.operators.InternalTimersSnapshot
-
- setExceptionHandler(Thread.UncaughtExceptionHandler) - Method in class org.apache.flink.runtime.util.ExecutorThreadFactory.Builder
-
- setExecutable(boolean) - Method in class org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact.Builder
-
- setExecution(Map<String, Object>) - Method in class org.apache.flink.table.client.config.Environment
-
- setExecutionConfig(ExecutionConfig) - Method in class org.apache.flink.api.common.Plan
-
Sets the runtime config object defining execution parameters.
- setExecutionConfig(ExecutionConfig) - Method in class org.apache.flink.queryablestate.client.QueryableStateClient
-
Replaces the existing
ExecutionConfig
(possibly
null
), with the provided one.
- setExecutionConfig(ExecutionConfig) - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
Sets the execution config.
- setExecutionMode(ExecutionMode) - Method in class org.apache.flink.api.common.ExecutionConfig
-
Sets the execution mode to execute the program.
- setExecutionRetryDelay(long) - Method in class org.apache.flink.api.common.ExecutionConfig
-
- setExtract(boolean) - Method in class org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact.Builder
-
- setFailOnCheckpointingErrors(boolean) - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Sets the expected behaviour for tasks in case that they encounter an error in their checkpointing procedure.
- setFailOnMissingField(boolean) - Method in class org.apache.flink.formats.json.JsonRowDeserializationSchema
-
Configures the failure behaviour if a JSON field is missing.
- setFailOnMissingField(boolean) - Method in class org.apache.flink.streaming.connectors.kafka.Kafka010JsonTableSource
-
Sets the flag that specifies the behavior in case of missing fields.
- setFailOnMissingField(boolean) - Method in class org.apache.flink.streaming.connectors.kafka.Kafka011JsonTableSource
-
Sets the flag that specifies the behavior in case of missing fields.
- setFailOnMissingField(boolean) - Method in class org.apache.flink.streaming.connectors.kafka.Kafka08JsonTableSource
-
Sets the flag that specifies the behavior in case of missing fields.
- setFailOnMissingField(boolean) - Method in class org.apache.flink.streaming.connectors.kafka.Kafka09JsonTableSource
-
Sets the flag that specifies the behavior in case of missing fields.
- setFailOnMissingField(boolean) - Method in class org.apache.flink.streaming.connectors.kafka.KafkaJsonTableSource
-
Sets the flag that specifies the behavior in case of missing fields.
- setFailTaskOnCheckpointError(boolean) - Method in class org.apache.flink.api.common.ExecutionConfig
-
This method is visible because of the way the configuration is currently forwarded from the checkpoint config to
the task.
- setFailWhenLegacyStateDetected(boolean) - Static method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointSerializers
-
This is only visible as a temporary solution to keep the stateful job migration it cases working from binary
savepoints that still contain legacy state (<= Flink 1.1).
- setFencingToken(F) - Method in class org.apache.flink.runtime.rpc.FencedRpcEndpoint
-
- setFetchSize(int) - Method in class org.apache.flink.api.java.io.jdbc.JDBCInputFormat.JDBCInputFormatBuilder
-
- setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple
-
Sets the field at the specified position.
- setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple0
-
- setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple1
-
- setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple10
-
- setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple11
-
- setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple12
-
- setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple13
-
- setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple14
-
- setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple15
-
- setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple16
-
- setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple17
-
- setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple18
-
- setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple19
-
- setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple2
-
- setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple20
-
- setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple21
-
- setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple22
-
- setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple23
-
- setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple24
-
- setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple25
-
- setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple3
-
- setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple4
-
- setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple5
-
- setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple6
-
- setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple7
-
- setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple8
-
- setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple9
-
- setField(int, Value) - Method in class org.apache.flink.types.Record
-
Sets the field at the given position to the given value.
- setField(int, Object) - Method in class org.apache.flink.types.Row
-
Sets the field at the specified position.
- setFieldDelimiter(String) - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
-
- setFieldMapping(Map<String, String>) - Method in class org.apache.flink.streaming.connectors.kafka.Kafka010AvroTableSource
-
Sets a mapping from schema fields to fields of the produced Avro record.
- setFieldMapping(Map<String, String>) - Method in class org.apache.flink.streaming.connectors.kafka.Kafka010JsonTableSource
-
Sets the mapping from table schema fields to JSON schema fields.
- setFieldMapping(Map<String, String>) - Method in class org.apache.flink.streaming.connectors.kafka.Kafka011AvroTableSource
-
Sets a mapping from schema fields to fields of the produced Avro record.
- setFieldMapping(Map<String, String>) - Method in class org.apache.flink.streaming.connectors.kafka.Kafka011JsonTableSource
-
Sets the mapping from table schema fields to JSON schema fields.
- setFieldMapping(Map<String, String>) - Method in class org.apache.flink.streaming.connectors.kafka.Kafka08AvroTableSource
-
Sets a mapping from schema fields to fields of the produced Avro record.
- setFieldMapping(Map<String, String>) - Method in class org.apache.flink.streaming.connectors.kafka.Kafka08JsonTableSource
-
Sets the mapping from table schema fields to JSON schema fields.
- setFieldMapping(Map<String, String>) - Method in class org.apache.flink.streaming.connectors.kafka.Kafka09AvroTableSource
-
Sets a mapping from schema fields to fields of the produced Avro record.
- setFieldMapping(Map<String, String>) - Method in class org.apache.flink.streaming.connectors.kafka.Kafka09JsonTableSource
-
Sets the mapping from table schema fields to JSON schema fields.
- setFieldMapping(Map<String, String>) - Method in class org.apache.flink.streaming.connectors.kafka.KafkaAvroTableSource
-
Configures a field mapping for this TableSource.
- setFieldMapping(Map<String, String>) - Method in class org.apache.flink.streaming.connectors.kafka.KafkaJsonTableSource
-
Sets the mapping from table schema fields to JSON schema fields.
- setFields(T0) - Method in class org.apache.flink.api.java.tuple.Tuple1
-
Sets new values to all fields of the tuple.
- setFields(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9) - Method in class org.apache.flink.api.java.tuple.Tuple10
-
Sets new values to all fields of the tuple.
- setFields(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10) - Method in class org.apache.flink.api.java.tuple.Tuple11
-
Sets new values to all fields of the tuple.
- setFields(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11) - Method in class org.apache.flink.api.java.tuple.Tuple12
-
Sets new values to all fields of the tuple.
- setFields(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12) - Method in class org.apache.flink.api.java.tuple.Tuple13
-
Sets new values to all fields of the tuple.
- setFields(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13) - Method in class org.apache.flink.api.java.tuple.Tuple14
-
Sets new values to all fields of the tuple.
- setFields(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14) - Method in class org.apache.flink.api.java.tuple.Tuple15
-
Sets new values to all fields of the tuple.
- setFields(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15) - Method in class org.apache.flink.api.java.tuple.Tuple16
-
Sets new values to all fields of the tuple.
- setFields(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16) - Method in class org.apache.flink.api.java.tuple.Tuple17
-
Sets new values to all fields of the tuple.
- setFields(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17) - Method in class org.apache.flink.api.java.tuple.Tuple18
-
Sets new values to all fields of the tuple.
- setFields(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18) - Method in class org.apache.flink.api.java.tuple.Tuple19
-
Sets new values to all fields of the tuple.
- setFields(T0, T1) - Method in class org.apache.flink.api.java.tuple.Tuple2
-
Sets new values to all fields of the tuple.
- setFields(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19) - Method in class org.apache.flink.api.java.tuple.Tuple20
-
Sets new values to all fields of the tuple.
- setFields(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20) - Method in class org.apache.flink.api.java.tuple.Tuple21
-
Sets new values to all fields of the tuple.
- setFields(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, T21) - Method in class org.apache.flink.api.java.tuple.Tuple22
-
Sets new values to all fields of the tuple.
- setFields(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, T21, T22) - Method in class org.apache.flink.api.java.tuple.Tuple23
-
Sets new values to all fields of the tuple.
- setFields(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, T21, T22, T23) - Method in class org.apache.flink.api.java.tuple.Tuple24
-
Sets new values to all fields of the tuple.
- setFields(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, T21, T22, T23, T24) - Method in class org.apache.flink.api.java.tuple.Tuple25
-
Sets new values to all fields of the tuple.
- setFields(T0, T1, T2) - Method in class org.apache.flink.api.java.tuple.Tuple3
-
Sets new values to all fields of the tuple.
- setFields(T0, T1, T2, T3) - Method in class org.apache.flink.api.java.tuple.Tuple4
-
Sets new values to all fields of the tuple.
- setFields(T0, T1, T2, T3, T4) - Method in class org.apache.flink.api.java.tuple.Tuple5
-
Sets new values to all fields of the tuple.
- setFields(T0, T1, T2, T3, T4, T5) - Method in class org.apache.flink.api.java.tuple.Tuple6
-
Sets new values to all fields of the tuple.
- setFields(T0, T1, T2, T3, T4, T5, T6) - Method in class org.apache.flink.api.java.tuple.Tuple7
-
Sets new values to all fields of the tuple.
- setFields(T0, T1, T2, T3, T4, T5, T6, T7) - Method in class org.apache.flink.api.java.tuple.Tuple8
-
Sets new values to all fields of the tuple.
- setFields(T0, T1, T2, T3, T4, T5, T6, T7, T8) - Method in class org.apache.flink.api.java.tuple.Tuple9
-
Sets new values to all fields of the tuple.
- setFieldsGeneric(int[], Class<?>[]) - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
-
- setFieldsGeneric(boolean[], Class<?>[]) - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
-
- setFieldTypesGeneric(Class<?>...) - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
-
- setFilehandlesDriver(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setFilehandlesInput(int, int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setFilePath(String) - Method in class org.apache.flink.api.common.io.FileInputFormat
-
- setFilePath(Path) - Method in class org.apache.flink.api.common.io.FileInputFormat
-
Sets a single path of a file to be read.
- setFilePaths(String...) - Method in class org.apache.flink.api.common.io.FileInputFormat
-
Sets multiple paths of files to be read.
- setFilePaths(Path...) - Method in class org.apache.flink.api.common.io.FileInputFormat
-
Sets multiple paths of files to be read.
- setFilesFilter(FilePathFilter) - Method in class org.apache.flink.api.common.io.FileInputFormat
-
- setFilterFactor(float) - Method in class org.apache.flink.api.common.operators.CompilerHints
-
- setFirstDegree(Integer) - Method in class org.apache.flink.examples.java.graph.util.EnumTrianglesDataTypes.EdgeWithDegrees
-
- setFirstDegree(Integer) - Method in class org.apache.flink.graph.library.TriangleEnumerator.EdgeWithDegrees
-
- setFirstInput(Operator<IN1>) - Method in class org.apache.flink.api.common.operators.DualInputOperator
-
Clears all previous connections and connects the first input to the task wrapped in this contract
- setFirstInput(Operator<IN1>...) - Method in class org.apache.flink.api.common.operators.DualInputOperator
-
- setFirstInputs(List<Operator<IN1>>) - Method in class org.apache.flink.api.common.operators.DualInputOperator
-
- setFirstRecordStart(long) - Method in class org.apache.flink.api.common.io.BlockInfo
-
Sets the firstRecordStart to the specified value.
- setFirstVertex(Integer) - Method in class org.apache.flink.examples.java.graph.util.EnumTrianglesDataTypes.Edge
-
- setFirstVertex(Integer) - Method in class org.apache.flink.examples.java.graph.util.EnumTrianglesDataTypes.EdgeWithDegrees
-
- setFirstVertex(Integer) - Method in class org.apache.flink.examples.java.graph.util.EnumTrianglesDataTypes.Triad
-
- setFirstVertex(K) - Method in class org.apache.flink.graph.library.TriangleEnumerator.EdgeWithDegrees
-
- setFirstVertex(K) - Method in class org.apache.flink.graph.library.TriangleEnumerator.Triad
-
- setFlinkCollector(Collector<Tuple2<KEY, VALUE>>) - Method in class org.apache.flink.hadoopcompatibility.mapred.wrapper.HadoopOutputCollector
-
Set the wrapped Flink collector.
- setFloat(String, float) - Method in class org.apache.flink.configuration.Configuration
-
Adds the given key/value pair to the configuration object.
- setFloat(ConfigOption<Float>, float) - Method in class org.apache.flink.configuration.Configuration
-
Adds the given value to the configuration object.
- setFloat(String, float) - Method in class org.apache.flink.configuration.DelegatingConfiguration
-
- setFloat(ConfigOption<Float>, float) - Method in class org.apache.flink.configuration.DelegatingConfiguration
-
- setFloat(String, float) - Method in class org.apache.hadoop.conf.Configuration
-
Set the value of the name
property to a float
.
- setFlushOnCheckpoint(boolean) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer010.FlinkKafkaProducer010Configuration
-
Deprecated.
If set to true, the Flink producer will wait for all outstanding messages in the Kafka buffers
to be acknowledged by the Kafka producer on a checkpoint.
- setFlushOnCheckpoint(boolean) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducerBase
-
If set to true, the Flink producer will wait for all outstanding messages in the Kafka buffers
to be acknowledged by the Kafka producer on a checkpoint.
- setForceCheckpointing(boolean) - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
- setForcedRebalanced() - Method in class org.apache.flink.optimizer.dataproperties.GlobalProperties
-
- setForceRebalancing() - Method in class org.apache.flink.optimizer.dataproperties.RequestedGlobalProperties
-
- setFormatDescription(String) - Method in class org.apache.flink.runtime.jobgraph.InputFormatVertex
-
- setFormatDescription(String) - Method in class org.apache.flink.runtime.jobgraph.OutputFormatVertex
-
- setFrameworkID(Option<Protos.FrameworkID>) - Method in interface org.apache.flink.mesos.runtime.clusterframework.store.MesosWorkerStore
-
Set the stored Mesos framework ID.
- setFrameworkID(Option<Protos.FrameworkID>) - Method in class org.apache.flink.mesos.runtime.clusterframework.store.StandaloneMesosWorkerStore
-
- setFrameworkID(Option<Protos.FrameworkID>) - Method in class org.apache.flink.mesos.runtime.clusterframework.store.ZooKeeperMesosWorkerStore
-
Update the persisted framework ID.
- setFrequency(int) - Method in class org.apache.flink.examples.java.wordcount.WordCountPojo.Word
-
- setFrequency(int) - Method in class org.apache.flink.streaming.examples.kafka.KafkaEvent
-
- setFSConfig(Configuration) - Method in class org.apache.flink.streaming.connectors.fs.bucketing.BucketingSink
-
Specify a custom Configuration
that will be used when creating
the FileSystem
for writing.
- setFSConfig(Configuration) - Method in class org.apache.flink.streaming.connectors.fs.bucketing.BucketingSink
-
Specify a custom Configuration
that will be used when creating
the FileSystem
for writing.
- setFSConfig(Configuration) - Method in class org.apache.flink.streaming.connectors.fs.RollingSink
-
Deprecated.
Specify a custom Configuration
that will be used when creating
the FileSystem
for writing.
- setFSConfig(Configuration) - Method in class org.apache.flink.streaming.connectors.fs.RollingSink
-
Deprecated.
Specify a custom Configuration
that will be used when creating
the FileSystem
for writing.
- setFullyReplicated() - Method in class org.apache.flink.optimizer.dataproperties.GlobalProperties
-
- setFullyReplicated() - Method in class org.apache.flink.optimizer.dataproperties.RequestedGlobalProperties
-
- setFunctionRuntimeContext(Function, RuntimeContext) - Static method in class org.apache.flink.api.common.functions.util.FunctionUtils
-
- setFurtherPatitioning(boolean) - Method in class org.apache.flink.runtime.operators.hash.HashPartition
-
- setGateIterativeWithNumberOfEventsUntilInterrupt(int, int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setGlobalJobParameters(ExecutionConfig.GlobalJobParameters) - Method in class org.apache.flink.api.common.ExecutionConfig
-
Register a custom, serializable user configuration object.
- setGPUResource(double) - Method in class org.apache.flink.api.common.operators.ResourceSpec.Builder
-
- setGroupedFields(FieldSet) - Method in class org.apache.flink.optimizer.dataproperties.RequestedLocalProperties
-
Sets the fields that are grouped in these data properties.
- setGroupOrder(int, Ordering) - Method in class org.apache.flink.api.common.operators.base.CoGroupOperatorBase
-
Sets the order of the elements within a group for the given input.
- setGroupOrder(int, Ordering) - Method in class org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase
-
Sets the order of the elements within a group for the given input.
- setGroupOrder(Ordering) - Method in class org.apache.flink.api.common.operators.base.GroupCombineOperatorBase
-
Sets the order of the elements within a reduce group.
- setGroupOrder(Ordering) - Method in class org.apache.flink.api.common.operators.base.GroupReduceOperatorBase
-
Sets the order of the elements within a reduce group.
- setGroupOrderForInputOne(Ordering) - Method in class org.apache.flink.api.common.operators.base.CoGroupOperatorBase
-
Sets the order of the elements within a group for the first input.
- setGroupOrderForInputOne(Ordering) - Method in class org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase
-
Sets the order of the elements within a group for the first input.
- setGroupOrderForInputTwo(Ordering) - Method in class org.apache.flink.api.common.operators.base.CoGroupOperatorBase
-
Sets the order of the elements within a group for the second input.
- setGroupOrderForInputTwo(Ordering) - Method in class org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase
-
Sets the order of the elements within a group for the second input.
- setGroupRepresentativeId(K) - Method in class org.apache.flink.graph.library.Summarization.VertexGroupItem
-
- setGroupRepresentativeId(K) - Method in class org.apache.flink.graph.library.Summarization.VertexWithRepresentative
-
- setGroupSize(int) - Method in class org.apache.flink.graph.library.similarity.JaccardIndex
-
Override the default group size for the quadratic expansion of neighbor
pairs.
- setHashPartitioned(FieldList) - Method in class org.apache.flink.optimizer.dataproperties.GlobalProperties
-
Sets this global properties to represent a hash partitioning.
- setHashPartitioned(FieldSet) - Method in class org.apache.flink.optimizer.dataproperties.RequestedGlobalProperties
-
Sets these properties to request a hash partitioning on the given fields.
- setHeapMemoryInMB(int) - Method in class org.apache.flink.api.common.operators.ResourceSpec.Builder
-
- setHeuristicCpuCost(double) - Method in class org.apache.flink.optimizer.costs.Costs
-
Sets the heuristic cost for the CPU.
- setHeuristicDiskCost(double) - Method in class org.apache.flink.optimizer.costs.Costs
-
Sets the heuristic costs for disk for this Costs object.
- setHeuristicNetworkCost(double) - Method in class org.apache.flink.optimizer.costs.Costs
-
Sets the heuristic network cost for this Costs object.
- setHost(String) - Method in class org.apache.flink.runtime.jobmanager.JobManagerCliOptions
-
- setHost(String) - Method in class org.apache.flink.streaming.connectors.cassandra.CassandraSink.CassandraSinkBuilder
-
Sets the cassandra host to connect to.
- setHost(String, int) - Method in class org.apache.flink.streaming.connectors.cassandra.CassandraSink.CassandraSinkBuilder
-
Sets the cassandra host/port to connect to.
- setHost(String) - Method in class org.apache.flink.streaming.connectors.rabbitmq.common.RMQConnectionConfig.Builder
-
- setHubScore(DoubleValue) - Method in class org.apache.flink.graph.library.linkanalysis.HITS.Result
-
Set the hub score.
- setId(K) - Method in class org.apache.flink.graph.Vertex
-
- setID - Variable in class org.apache.flink.python.api.PythonOperationInfo
-
- setIfUnset(String, String) - Method in class org.apache.hadoop.conf.Configuration
-
Sets a property if it is currently unset.
- setImmediateSolutionSetUpdate(boolean) - Method in class org.apache.flink.optimizer.plan.WorksetIterationPlanNode
-
- setImplicitConvergenceCriterion(String, ConvergenceCriterion<?>) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setIn(DataInput) - Method in class org.apache.flink.formats.avro.utils.DataInputDecoder
-
- setInactiveBucketCheckInterval(long) - Method in class org.apache.flink.streaming.connectors.fs.bucketing.BucketingSink
-
Sets the default time between checks for inactive buckets.
- setInactiveBucketThreshold(long) - Method in class org.apache.flink.streaming.connectors.fs.bucketing.BucketingSink
-
Sets the default threshold for marking a bucket as inactive and closing its part files.
- setIncludeZeroDegreeVertices(boolean) - Method in class org.apache.flink.graph.asm.degree.annotate.directed.VertexDegrees
-
By default only the edge set is processed for the computation of degree.
- setIncludeZeroDegreeVertices(boolean) - Method in class org.apache.flink.graph.asm.degree.annotate.directed.VertexInDegree
-
By default only the edge set is processed for the computation of degree.
- setIncludeZeroDegreeVertices(boolean) - Method in class org.apache.flink.graph.asm.degree.annotate.directed.VertexOutDegree
-
By default only the edge set is processed for the computation of degree.
- setIncludeZeroDegreeVertices(boolean) - Method in class org.apache.flink.graph.asm.degree.annotate.undirected.VertexDegree
-
By default only the edge set is processed for the computation of degree.
- setIncludeZeroDegreeVertices(boolean) - Method in class org.apache.flink.graph.library.clustering.directed.LocalClusteringCoefficient
-
By default the vertex set is checked for zero degree vertices.
- setIncludeZeroDegreeVertices(boolean) - Method in class org.apache.flink.graph.library.clustering.undirected.LocalClusteringCoefficient
-
By default the vertex set is checked for zero degree vertices.
- setIncludeZeroDegreeVertices(boolean) - Method in class org.apache.flink.graph.library.linkanalysis.PageRank
-
This PageRank implementation properly handles both source and sink
vertices which have, respectively, only outgoing and incoming edges.
- setIncludeZeroDegreeVertices(boolean) - Method in class org.apache.flink.graph.library.metric.directed.VertexMetrics
-
By default only the edge set is processed for the computation of degree.
- setIncludeZeroDegreeVertices(boolean) - Method in class org.apache.flink.graph.library.metric.undirected.VertexMetrics
-
By default only the edge set is processed for the computation of degree.
- setIncomingConnection(DagConnection) - Method in class org.apache.flink.optimizer.dag.SingleInputNode
-
Sets the connection through which this node receives its input.
- setInitialSolutionSet(Operator<ST>) - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase
-
Sets the given input as the initial solution set.
- setInitialState(JobManagerTaskRestore) - Method in class org.apache.flink.runtime.executiongraph.Execution
-
Sets the initial state for the execution.
- setInitialWorkset(Operator<WT>) - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase
-
Sets the given input as the initial workset.
- setInPhysicalEdges(List<StreamEdge>) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setInProgressPrefix(String) - Method in class org.apache.flink.streaming.connectors.fs.bucketing.BucketingSink
-
Sets the prefix of in-progress part files.
- setInProgressPrefix(String) - Method in class org.apache.flink.streaming.connectors.fs.RollingSink
-
Deprecated.
Sets the prefix of in-progress part files.
- setInProgressSuffix(String) - Method in class org.apache.flink.streaming.connectors.fs.bucketing.BucketingSink
-
Sets the suffix of in-progress part files.
- setInProgressSuffix(String) - Method in class org.apache.flink.streaming.connectors.fs.RollingSink
-
Deprecated.
Sets the suffix of in-progress part files.
- setInput(Operator<IN>) - Method in class org.apache.flink.api.common.operators.GenericDataSinkBase
-
Sets the given operator as the input to this operator.
- setInput(Operator<IN>) - Method in class org.apache.flink.api.common.operators.SingleInputOperator
-
Sets the given operator as the input to this operator.
- setInput(Operator<IN>...) - Method in class org.apache.flink.api.common.operators.SingleInputOperator
-
- setInput(DataSet<IN>) - Method in interface org.apache.flink.api.java.operators.CustomUnaryOperation
-
- setInput(DataSet<IN>) - Method in class org.apache.flink.api.java.operators.NoOpOperator
-
- setInput(DataSet<Vertex<K, VV>>) - Method in class org.apache.flink.graph.gsa.GatherSumApplyIteration
-
Sets the input data set for this operator.
- setInput(DataSet<Vertex<K, VV>>) - Method in class org.apache.flink.graph.pregel.VertexCentricIteration
-
Sets the input data set for this operator.
- setInput(DataSet<Vertex<K, VV>>) - Method in class org.apache.flink.graph.spargel.ScatterGatherIteration
-
Sets the input data set for this operator.
- setInput(Map<Operator<?>, OptimizerNode>, ExecutionMode) - Method in class org.apache.flink.optimizer.dag.AbstractPartialSolutionNode
-
- setInput(Map<Operator<?>, OptimizerNode>, ExecutionMode) - Method in class org.apache.flink.optimizer.dag.DataSinkNode
-
- setInput(Map<Operator<?>, OptimizerNode>, ExecutionMode) - Method in class org.apache.flink.optimizer.dag.DataSourceNode
-
- setInput(Map<Operator<?>, OptimizerNode>, ExecutionMode) - Method in class org.apache.flink.optimizer.dag.OptimizerNode
-
This function connects the predecessors to this operator.
- setInput(Map<Operator<?>, OptimizerNode>, ExecutionMode) - Method in class org.apache.flink.optimizer.dag.SingleInputNode
-
- setInput(Map<Operator<?>, OptimizerNode>, ExecutionMode) - Method in class org.apache.flink.optimizer.dag.TwoInputNode
-
- setInputAsynchronouslyMaterialized(int, boolean) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setInputCached(int, boolean) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setInputChannel(IntermediateResultPartitionID, InputChannel) - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
-
- setInputComparator(TypeComparatorFactory<?>, int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setInputFormat(Integer, InputFormat<?, ?>) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- setInputFormat(InputFormat<?, ?>) - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- setInputLocalStrategy(int, LocalStrategy) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setInputs(Operator<IN>...) - Method in class org.apache.flink.api.common.operators.GenericDataSinkBase
-
- setInputs(List<Operator<IN>>) - Method in class org.apache.flink.api.common.operators.GenericDataSinkBase
-
- setInputs(List<Operator<IN>>) - Method in class org.apache.flink.api.common.operators.SingleInputOperator
-
- setInputs(DagConnection, DagConnection) - Method in class org.apache.flink.optimizer.dag.WorksetIterationNode.SingleRootJoiner
-
- setInputSerializer(TypeSerializerFactory<?>, int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setInputSplitSource(InputSplitSource<?>) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
- setInputType(TypeInformation<?>, ExecutionConfig) - Method in class org.apache.flink.api.java.io.CsvOutputFormat
-
The purpose of this method is solely to check whether the data type to be processed
is in fact a tuple type.
- setInputType(TypeInformation<?>, ExecutionConfig) - Method in class org.apache.flink.api.java.io.LocalCollectionOutputFormat
-
- setInputType(TypeInformation<?>, ExecutionConfig) - Method in class org.apache.flink.api.java.io.TypeSerializerOutputFormat
-
- setInputType(TypeInformation<?>, ExecutionConfig) - Method in interface org.apache.flink.api.java.typeutils.InputTypeConfigurable
-
Method that is called on an
OutputFormat
when it is passed to
the DataSet's output method.
- setInputType(TypeInformation<?>, ExecutionConfig) - Method in class org.apache.flink.api.scala.operators.ScalaCsvOutputFormat
-
The purpose of this method is solely to check whether the data type to be processed
is in fact a tuple type.
- setInputType(TypeInformation<?>, ExecutionConfig) - Method in class org.apache.flink.streaming.api.functions.sink.OutputFormatSinkFunction
-
Deprecated.
- setInputType(TypeInformation<?>, ExecutionConfig) - Method in class org.apache.flink.streaming.connectors.fs.AvroKeyValueSinkWriter
-
- setInputType(TypeInformation<?>, ExecutionConfig) - Method in class org.apache.flink.streaming.connectors.fs.bucketing.BucketingSink
-
- setInputType(TypeInformation<?>, ExecutionConfig) - Method in class org.apache.flink.streaming.connectors.fs.RollingSink
-
Deprecated.
- setInputType(TypeInformation<?>, ExecutionConfig) - Method in class org.apache.flink.streaming.connectors.fs.SequenceFileWriter
-
- setInstance(T) - Method in interface org.apache.flink.runtime.plugable.DeserializationDelegate
-
- setInstance(T) - Method in class org.apache.flink.runtime.plugable.NonReusingDeserializationDelegate
-
- setInstance(T) - Method in class org.apache.flink.runtime.plugable.ReusingDeserializationDelegate
-
- setInstance(T) - Method in class org.apache.flink.runtime.plugable.SerializationDelegate
-
- setInt(String, int) - Method in class org.apache.hadoop.conf.Configuration
-
Set the value of the name
property to an int
.
- setInteger(String, int) - Method in class org.apache.flink.configuration.Configuration
-
Adds the given key/value pair to the configuration object.
- setInteger(ConfigOption<Integer>, int) - Method in class org.apache.flink.configuration.Configuration
-
Adds the given value to the configuration object.
- setInteger(String, int) - Method in class org.apache.flink.configuration.DelegatingConfiguration
-
- setInteger(ConfigOption<Integer>, int) - Method in class org.apache.flink.configuration.DelegatingConfiguration
-
- setInterestingProperties(InterestingProperties) - Method in class org.apache.flink.optimizer.dag.DagConnection
-
Sets the interesting properties for this pact connection.
- setInvokableClass(Class<? extends AbstractInvokable>) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
- setIsCompacted(boolean) - Method in class org.apache.flink.runtime.operators.hash.InMemoryPartition
-
sets compaction status (should only be set true
directly after compaction and false
when garbage was created)
- setIsSolutionSetUpdate() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setIsSolutionSetUpdateWithoutReprobe() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setIsWorksetIteration() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setIsWorksetUpdate() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setItemCount(long) - Method in class org.apache.flink.formats.avro.utils.DataOutputEncoder
-
- setIterationHeadFinalOutputConfig(TaskConfig) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setIterationHeadIndexOfSyncOutput(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setIterationHeadPartialSolutionOrWorksetInputIndex(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setIterationHeadSolutionSetInputIndex(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setIterationId(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setIterationId(String) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setIterationWaitTime(long) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setIterativeReader() - Method in class org.apache.flink.runtime.io.network.api.reader.AbstractReader
-
- setIterativeReader() - Method in interface org.apache.flink.runtime.io.network.api.reader.ReaderBase
-
- setJobFinished(JobID) - Method in class org.apache.flink.runtime.highavailability.FsNegativeRunningJobsRegistry
-
- setJobFinished(JobID) - Method in class org.apache.flink.runtime.highavailability.nonha.standalone.StandaloneRunningJobsRegistry
-
- setJobFinished(JobID) - Method in interface org.apache.flink.runtime.highavailability.RunningJobsRegistry
-
Marks a job as completed.
- setJobFinished(JobID) - Method in class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperRunningJobsRegistry
-
- setJobId(JobID) - Method in class org.apache.flink.api.common.Plan
-
Sets the ID of the job that the dataflow plan belongs to.
- setJobId(String) - Method in class org.apache.flink.streaming.connectors.cassandra.CassandraCommitter
-
Internally used to set the job ID after instantiation.
- setJobId(String) - Method in class org.apache.flink.streaming.runtime.operators.CheckpointCommitter
-
Internally used to set the job ID after instantiation.
- setJobManagerMode(String) - Method in class org.apache.flink.runtime.jobmanager.JobManagerCliOptions
-
- setJobName(String) - Method in class org.apache.flink.api.common.Plan
-
Sets the jobName for this Plan.
- setJobName(String) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- setJobRunning(JobID) - Method in class org.apache.flink.runtime.highavailability.FsNegativeRunningJobsRegistry
-
- setJobRunning(JobID) - Method in class org.apache.flink.runtime.highavailability.nonha.standalone.StandaloneRunningJobsRegistry
-
- setJobRunning(JobID) - Method in interface org.apache.flink.runtime.highavailability.RunningJobsRegistry
-
Marks a job as running.
- setJobRunning(JobID) - Method in class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperRunningJobsRegistry
-
- setJoinHint(JoinOperatorBase.JoinHint) - Method in class org.apache.flink.api.common.operators.base.JoinOperatorBase
-
- setJsonPlan(String) - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- setKafkaMetric(Metric) - Method in class org.apache.flink.streaming.connectors.kafka.internal.metrics.KafkaMetricMuttableWrapper
-
- setKey(K) - Method in class org.apache.flink.streaming.connectors.fs.AvroKeyValueSinkWriter.AvroKeyValue
-
- setKeyContextElement1(StreamRecord) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- setKeyContextElement1(StreamRecord<?>) - Method in interface org.apache.flink.streaming.api.operators.StreamOperator
-
- setKeyContextElement2(StreamRecord) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- setKeyContextElement2(StreamRecord<?>) - Method in interface org.apache.flink.streaming.api.operators.StreamOperator
-
- setKeyedStateManagedFuture(RunnableFuture<SnapshotResult<KeyedStateHandle>>) - Method in class org.apache.flink.streaming.api.operators.OperatorSnapshotFutures
-
- setKeyedStateRawFuture(RunnableFuture<SnapshotResult<KeyedStateHandle>>) - Method in class org.apache.flink.streaming.api.operators.OperatorSnapshotFutures
-
- setKeyGroupOffset(int, long) - Method in class org.apache.flink.runtime.state.KeyGroupRangeOffsets
-
Sets the offset for the given key-group.
- setKeySerializer(TypeSerializer<K>) - Method in class org.apache.flink.streaming.api.operators.InternalTimersSnapshot
-
- setKeySerializerConfigSnapshot(TypeSerializerConfigSnapshot) - Method in class org.apache.flink.streaming.api.operators.InternalTimersSnapshot
-
- setLastOutputCollector(Collector<OT>) - Method in class org.apache.flink.runtime.operators.BatchTask
-
- setLatencyTrackingInterval(long) - Method in class org.apache.flink.api.common.ExecutionConfig
-
Interval for sending latency tracking marks from the sources to the sinks.
- setLength(int) - Method in class org.apache.flink.types.StringValue
-
Sets a new length for the string.
- setLenient(boolean) - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
-
- setLineLengthLimit(int) - Method in class org.apache.flink.api.common.io.DelimitedInputFormat
-
- setLoadNativeLibraries(Configuration, boolean) - Method in class org.apache.hadoop.util.NativeCodeLoader
-
Set if native hadoop libraries, if present, can be used for this job.
- setLocality(Locality) - Method in class org.apache.flink.runtime.instance.SimpleSlot
-
Attached locality information to this slot.
- setLocalJarPath(Path) - Method in class org.apache.flink.yarn.AbstractYarnClusterDescriptor
-
- setLocalOrder(Ordering) - Method in class org.apache.flink.api.common.operators.GenericDataSinkBase
-
Sets the order in which the sink must write its data within each fragment in the distributed
file system.
- setLocalStrategy(LocalStrategy) - Method in class org.apache.flink.optimizer.plan.Channel
-
- setLocalStrategy(LocalStrategy, FieldList, boolean[]) - Method in class org.apache.flink.optimizer.plan.Channel
-
- setLocalStrategyComparator(TypeComparatorFactory<?>) - Method in class org.apache.flink.optimizer.plan.Channel
-
Sets the local strategy comparator for this Channel.
- setLogFailuresOnly(boolean) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer010.FlinkKafkaProducer010Configuration
-
Deprecated.
Defines whether the producer should fail on errors, or only log them.
- setLogFailuresOnly(boolean) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer011
-
Defines whether the producer should fail on errors, or only log them.
- setLogFailuresOnly(boolean) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducerBase
-
Defines whether the producer should fail on errors, or only log them.
- setLogFailuresOnly(boolean) - Method in class org.apache.flink.streaming.connectors.rabbitmq.RMQSink
-
Defines whether the producer should fail on errors, or only log them.
- setLong(String, long) - Method in class org.apache.flink.configuration.Configuration
-
Adds the given key/value pair to the configuration object.
- setLong(ConfigOption<Long>, long) - Method in class org.apache.flink.configuration.Configuration
-
Adds the given value to the configuration object.
- setLong(String, long) - Method in class org.apache.flink.configuration.DelegatingConfiguration
-
- setLong(ConfigOption<Long>, long) - Method in class org.apache.flink.configuration.DelegatingConfiguration
-
- setLong(String, long) - Method in class org.apache.hadoop.conf.Configuration
-
Set the value of the name
property to a long
.
- setMapperOptions(MapperOptions) - Method in class org.apache.flink.streaming.connectors.cassandra.CassandraSink.CassandraSinkBuilder
-
Sets the mapper options for this sink.
- setMasterMemoryMB(int) - Method in class org.apache.flink.client.deployment.ClusterSpecification.ClusterSpecificationBuilder
-
- setMaterializationMode(TempMode) - Method in class org.apache.flink.optimizer.dag.DagConnection
-
- setMaxConcurrentCheckpoints(int) - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Sets the maximum number of checkpoint attempts that may be in progress at the same time.
- setMaximumNumberOfIterations(int) - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase
-
- setMaximumNumberOfIterations(int) - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase
-
- setMaximumScore(int, int) - Method in class org.apache.flink.graph.library.similarity.JaccardIndex
-
Filter out Jaccard Index scores greater than the given maximum fraction.
- setMaximumValue(double, boolean) - Method in class org.apache.flink.graph.drivers.parameter.DoubleParameter
-
Set the maximum value.
- setMaximumValue(long) - Method in class org.apache.flink.graph.drivers.parameter.LongParameter
-
Set the maximum value.
- setMaxParallelism(int) - Method in class org.apache.flink.api.common.ExecutionConfig
-
Sets the maximum degree of parallelism defined for the program.
- setMaxParallelism(int) - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
- setMaxParallelism(int) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
Sets the maximum parallelism for the task.
- setMaxParallelism(int) - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
-
Sets the maximum parallelism of this operator.
- setMaxParallelism(int) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Sets the maximum degree of parallelism defined for the program.
- setMaxParallelism(int, int) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- setMaxParallelism(int) - Method in class org.apache.flink.streaming.api.transformations.StreamTransformation
-
Sets the maximum parallelism for this stream transformation.
- setMaxRetryCount(int) - Method in class org.apache.flink.streaming.connectors.elasticsearch.ElasticsearchSinkBase.BulkFlushBackoffPolicy
-
- setMemorySegment(MemorySegment, int) - Method in class org.apache.flink.runtime.operators.util.BitSet
-
- setMemorySegment(MemorySegment, int) - Method in class org.apache.flink.runtime.operators.util.BloomFilter.BitSet
-
- setMetaInfo(RegisteredKeyedBackendStateMetaInfo<N, S>) - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateTable
-
- setMetaInfo(RegisteredKeyedBackendStateMetaInfo<N, S>) - Method in class org.apache.flink.runtime.state.heap.StateTable
-
- setMetricGroup(TaskIOMetricGroup) - Method in class org.apache.flink.runtime.io.network.api.writer.RecordWriter
-
Sets the metric group for this RecordWriter.
- setMinimumRatio(float) - Method in class org.apache.flink.graph.library.similarity.AdamicAdar
-
Filter out Adamic-Adar scores less than the given ratio times the average score.
- setMinimumScore(float) - Method in class org.apache.flink.graph.library.similarity.AdamicAdar
-
Filter out Adamic-Adar scores less than the given minimum.
- setMinimumScore(int, int) - Method in class org.apache.flink.graph.library.similarity.JaccardIndex
-
Filter out Jaccard Index scores less than the given minimum fraction.
- setMinimumValue(double, boolean) - Method in class org.apache.flink.graph.drivers.parameter.DoubleParameter
-
Set the minimum value.
- setMinimumValue(long) - Method in class org.apache.flink.graph.drivers.parameter.LongParameter
-
Set the minimum value.
- setMinPauseBetweenCheckpoints(long) - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Sets the minimal pause between checkpointing attempts.
- setMinSplitSize(long) - Method in class org.apache.flink.api.common.io.FileInputFormat
-
- setMirrorResults(boolean) - Method in class org.apache.flink.graph.library.similarity.AdamicAdar
-
By default only one result is output for each pair of vertices.
- setMirrorResults(boolean) - Method in class org.apache.flink.graph.library.similarity.JaccardIndex
-
By default only one result is output for each pair of vertices.
- setMoreAvailable(boolean) - Method in class org.apache.flink.runtime.io.network.partition.consumer.BufferOrEvent
-
- setMutableObjectMode(boolean) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setName(String) - Method in class org.apache.flink.api.common.operators.Operator
-
Sets the name of the contract instance.
- setName(String) - Method in class org.apache.flink.graph.IterationConfiguration
-
Sets the name for the iteration.
- setName(String) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
Sets the name of the vertex
- setName(String) - Method in class org.apache.flink.streaming.api.transformations.StreamTransformation
-
Changes the name of this StreamTransformation
.
- setName(String) - Method in class org.apache.flink.yarn.AbstractYarnClusterDescriptor
-
- setNamespaceSerializer(TypeSerializer<N>) - Method in class org.apache.flink.streaming.api.operators.InternalTimersSnapshot
-
- setNamespaceSerializerConfigSnapshot(TypeSerializerConfigSnapshot) - Method in class org.apache.flink.streaming.api.operators.InternalTimersSnapshot
-
- setNativeMemoryInMB(int) - Method in class org.apache.flink.api.common.operators.ResourceSpec.Builder
-
- setNestedFileEnumeration(boolean) - Method in class org.apache.flink.api.common.io.FileInputFormat
-
- setNetworkCost(double) - Method in class org.apache.flink.optimizer.costs.Costs
-
Sets the network cost for this Costs object.
- setNetworkRecoveryInterval(int) - Method in class org.apache.flink.streaming.connectors.rabbitmq.common.RMQConnectionConfig.Builder
-
Sets connection recovery interval.
- setNewVertexValue(VV) - Method in class org.apache.flink.graph.pregel.ComputeFunction
-
Sets the new value of this vertex.
- setNewVertexValue(VV) - Method in class org.apache.flink.graph.spargel.GatherFunction
-
Sets the new value of this vertex.
- setNextBuffer(Buffer) - Method in interface org.apache.flink.runtime.io.network.api.serialization.RecordDeserializer
-
- setNextBuffer(Buffer) - Method in class org.apache.flink.runtime.io.network.api.serialization.SpillingAdaptiveSpanningRecordDeserializer
-
- setNextPartialSolution(Operator<T>) - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase
-
- setNextPartialSolution(OptimizerNode, OptimizerNode) - Method in class org.apache.flink.optimizer.dag.BulkIterationNode
-
Sets the nextPartialSolution for this BulkIterationNode.
- setNextPartialSolution(OptimizerNode, OptimizerNode, ExecutionMode) - Method in class org.apache.flink.optimizer.dag.WorksetIterationNode
-
- setNextWorkset(Operator<WT>) - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase
-
Sets the contract of the step function that represents the next workset.
- setNoise(boolean, float) - Method in class org.apache.flink.graph.generator.RMatGraph
-
Enable and configure noise.
- setNonChainedOutputs(List<StreamEdge>) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setNull(int) - Method in class org.apache.flink.types.Record
-
Sets the field at the given position to null
.
- setNull(long) - Method in class org.apache.flink.types.Record
-
Sets the fields to null
using the given bit mask.
- setNull(long[]) - Method in class org.apache.flink.types.Record
-
Sets the fields to null
using the given bit mask.
- setNumberOfExecutionRetries(int) - Method in class org.apache.flink.api.common.ExecutionConfig
-
- setNumberOfExecutionRetries(int) - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
- setNumberOfExecutionRetries(int) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- setNumberOfInputs(int) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setNumberOfIterations(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setNumberOfOutputs(int) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setNumberOfTestRepetitions(int) - Method in class org.apache.flink.test.util.JavaProgramTestBase
-
- setNumberTaskManagers(int) - Method in class org.apache.flink.client.deployment.ClusterSpecification.ClusterSpecificationBuilder
-
- setNumBuffers(int) - Method in interface org.apache.flink.runtime.io.network.buffer.BufferPool
-
Sets the current size of this buffer pool.
- setNumFields(int) - Method in class org.apache.flink.types.Record
-
Sets the number of fields in the record.
- setNumLineSamples(int) - Method in class org.apache.flink.api.common.io.DelimitedInputFormat
-
- setNumSlotsPerTaskManager(int) - Method in class org.apache.flink.runtime.minicluster.MiniClusterConfiguration.Builder
-
- setNumSplits(int) - Method in class org.apache.flink.api.common.io.FileInputFormat
-
- setNumTaskManagers(int) - Method in class org.apache.flink.runtime.minicluster.MiniClusterConfiguration.Builder
-
- setOffset(long) - Method in class org.apache.flink.streaming.connectors.kafka.internals.KafkaTopicPartitionState
-
- setOffsetInZooKeeper(CuratorFramework, String, String, int, long) - Static method in class org.apache.flink.streaming.connectors.kafka.internals.ZookeeperOffsetHandler
-
- setOneInputStateKey(Integer, KeySelector<?, ?>, TypeSerializer<?>) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- setOpenTimeout(long) - Method in class org.apache.flink.api.common.io.FileInputFormat
-
- setOperator(Integer, StreamOperator<OUT>) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- setOperator(StreamOperator<?>) - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- setOperatorDescription(String) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
- setOperatorID(OperatorID) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setOperatorId(String) - Method in class org.apache.flink.streaming.runtime.operators.CheckpointCommitter
-
Internally used to set the operator ID after instantiation.
- setOperatorLevelCachingDescription(String) - Method in class org.apache.flink.runtime.jobgraph.JobEdge
-
Sets the operator-level caching description for this input.
- setOperatorName(String) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
- setOperatorName(String) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setOperatorPrettyName(String) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
- setOperatorStateManagedFuture(RunnableFuture<SnapshotResult<OperatorStateHandle>>) - Method in class org.apache.flink.streaming.api.operators.OperatorSnapshotFutures
-
- setOperatorStateRawFuture(RunnableFuture<SnapshotResult<OperatorStateHandle>>) - Method in class org.apache.flink.streaming.api.operators.OperatorSnapshotFutures
-
- setOptDegrees(boolean) - Method in class org.apache.flink.graph.spargel.ScatterGatherConfiguration
-
Sets the degree option.
- setOptions(OptionsFactory) - Method in class org.apache.flink.contrib.streaming.state.RocksDBStateBackend
-
Sets Options
for the RocksDB instances.
- setOptNumVertices(boolean) - Method in class org.apache.flink.graph.IterationConfiguration
-
Sets the number of vertices option.
- setOrdering(Ordering) - Method in class org.apache.flink.api.common.operators.base.PartitionOperatorBase
-
- setOrdering(Ordering) - Method in class org.apache.flink.optimizer.dataproperties.RequestedLocalProperties
-
Sets the order for these interesting local properties.
- setOut(DataOutput) - Method in class org.apache.flink.formats.avro.utils.DataOutputEncoder
-
- setOutEdges(List<StreamEdge>) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setOutEdgesInOrder(List<StreamEdge>) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setOuterJoinType(OuterJoinOperatorBase.OuterJoinType) - Method in class org.apache.flink.api.common.operators.base.OuterJoinOperatorBase
-
- setOutput(Vertex<K, VV>, Collector<Vertex<K, VV>>) - Method in class org.apache.flink.graph.gsa.ApplyFunction
-
- setOutputCardinality(long) - Method in class org.apache.flink.api.common.operators.CompilerHints
-
- setOutputCollector(Collector<?>) - Method in class org.apache.flink.runtime.operators.chaining.ChainedDriver
-
- setOutputComparator(TypeComparatorFactory<?>, int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setOutputDataDistribution(DataDistribution, int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setOutputDirectoryMode(FileOutputFormat.OutputDirectoryMode) - Method in class org.apache.flink.api.common.io.FileOutputFormat
-
- setOutputFilePath(Path) - Method in class org.apache.flink.api.common.io.FileOutputFormat
-
- setOutputPartitioner(Partitioner<?>, int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setOutputSelectors(List<OutputSelector<?>>) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setOutputSerializer(TypeSerializerFactory<?>) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setOutputSize(long) - Method in class org.apache.flink.api.common.operators.CompilerHints
-
- setOutputType(TypeInformation<OUT>, ExecutionConfig) - Method in class org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperator
-
- setOutputType(TypeInformation<R>, ExecutionConfig) - Method in class org.apache.flink.streaming.api.functions.windowing.FoldApplyAllWindowFunction
-
Deprecated.
- setOutputType(TypeInformation<R>, ExecutionConfig) - Method in class org.apache.flink.streaming.api.functions.windowing.FoldApplyProcessAllWindowFunction
-
Deprecated.
- setOutputType(TypeInformation<R>, ExecutionConfig) - Method in class org.apache.flink.streaming.api.functions.windowing.FoldApplyProcessWindowFunction
-
Deprecated.
- setOutputType(TypeInformation<R>, ExecutionConfig) - Method in class org.apache.flink.streaming.api.functions.windowing.FoldApplyWindowFunction
-
Deprecated.
- setOutputType(TypeInformation<OUT>, ExecutionConfig) - Method in class org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
-
- setOutputType(TypeInformation<OUT>, ExecutionConfig) - Method in interface org.apache.flink.streaming.api.operators.OutputTypeConfigurable
-
- setOutputType(TypeInformation<OUT>, ExecutionConfig) - Method in class org.apache.flink.streaming.api.operators.StreamGroupedFold
-
Deprecated.
- setOutputType(TypeInformation<T>) - Method in class org.apache.flink.streaming.api.transformations.StreamTransformation
-
Tries to fill in the type information.
- setOutputType(Function, TypeInformation<T>, ExecutionConfig) - Static method in class org.apache.flink.streaming.util.functions.StreamingFunctionUtils
-
- setOutType(Integer, TypeInformation<OUT>) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- setPageRankScore(DoubleValue) - Method in class org.apache.flink.graph.library.linkanalysis.PageRank.Result
-
Set the PageRank score.
- setPairComparator(TypePairComparatorFactory<?, ?>) - Method in class org.apache.flink.optimizer.plan.DualInputPlanNode
-
- setParallelism(int) - Method in class org.apache.flink.api.common.ExecutionConfig
-
Sets the parallelism for operations executed through this environment.
- setParallelism(int) - Method in class org.apache.flink.api.common.operators.Operator
-
Sets the parallelism for this contract instance.
- setParallelism(int) - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
Sets the parallelism for operations executed through this environment.
- setParallelism(int) - Method in class org.apache.flink.api.java.operators.DataSink
-
Sets the parallelism for this data sink.
- setParallelism(int) - Method in class org.apache.flink.api.java.operators.Operator
-
Sets the parallelism for this operator.
- setParallelism(int) - Method in class org.apache.flink.api.java.operators.UnionOperator
-
- setParallelism(int) - Method in interface org.apache.flink.graph.generator.GraphGenerator
-
Override the operator parallelism.
- setParallelism(int) - Method in class org.apache.flink.graph.generator.GraphGeneratorBase
-
- setParallelism(int) - Method in class org.apache.flink.graph.GraphAnalyticBase
-
Set the parallelism for this analytic's operators.
- setParallelism(int) - Method in class org.apache.flink.graph.IterationConfiguration
-
Sets the parallelism for the iteration.
- setParallelism(int) - Method in class org.apache.flink.graph.utils.proxy.GraphAlgorithmWrappingBase
-
Set the parallelism for this algorithm's operators.
- setParallelism(int) - Method in class org.apache.flink.optimizer.dag.DataSourceNode
-
- setParallelism(int) - Method in class org.apache.flink.optimizer.dag.OptimizerNode
-
Sets the parallelism for this optimizer node.
- setParallelism(int) - Method in class org.apache.flink.optimizer.plan.PlanNode
-
- setParallelism(int) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
Sets the parallelism for the task.
- setParallelism(int) - Method in class org.apache.flink.streaming.api.datastream.DataStreamSink
-
Sets the parallelism for this sink.
- setParallelism(int) - Method in class org.apache.flink.streaming.api.datastream.DataStreamSource
-
- setParallelism(int) - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
-
Sets the parallelism for this operator.
- setParallelism(int) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Sets the parallelism for operations executed through this environment.
- setParallelism(Integer, int) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- setParallelism(Integer) - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- setParallelism(int) - Method in class org.apache.flink.streaming.api.transformations.StreamTransformation
-
Sets the parallelism of this StreamTransformation
.
- setParallelism(int) - Method in class org.apache.flink.streaming.connectors.cassandra.CassandraSink
-
Sets the parallelism for this sink.
- setParallelism(int) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer010.FlinkKafkaProducer010Configuration
-
Deprecated.
- setParameter(String, String) - Method in class org.apache.flink.api.common.operators.Operator
-
Sets a stub parameters in the configuration of this contract.
- setParameter(String, int) - Method in class org.apache.flink.api.common.operators.Operator
-
Sets a stub parameters in the configuration of this contract.
- setParameter(String, boolean) - Method in class org.apache.flink.api.common.operators.Operator
-
Sets a stub parameters in the configuration of this contract.
- setParametersProvider(ParameterValuesProvider) - Method in class org.apache.flink.api.java.io.jdbc.JDBCInputFormat.JDBCInputFormatBuilder
-
- setParameterTypes(TypeInformation<?>...) - Method in class org.apache.flink.api.java.io.jdbc.JDBCAppendTableSinkBuilder
-
Specify the type of the rows that the sink will be accepting.
- setParameterTypes(int...) - Method in class org.apache.flink.api.java.io.jdbc.JDBCAppendTableSinkBuilder
-
Specify the type of the rows that the sink will be accepting.
- setPartialSolution(BulkPartialSolutionNode) - Method in class org.apache.flink.optimizer.dag.BulkIterationNode
-
Sets the partialSolution for this BulkIterationNode.
- setPartialSolution(SolutionSetNode, WorksetNode) - Method in class org.apache.flink.optimizer.dag.WorksetIterationNode
-
- setPartition(int, IntermediateResultPartition) - Method in class org.apache.flink.runtime.executiongraph.IntermediateResult
-
- setPartitioner(StreamPartitioner<?>) - Method in class org.apache.flink.streaming.api.graph.StreamEdge
-
- setPartitionNumber(int) - Method in class org.apache.flink.runtime.operators.hash.InMemoryPartition
-
overwrites partition number and should only be used on compaction partition
- setPartitions(int[]) - Method in class org.apache.flink.streaming.connectors.kafka.partitioner.FlinkKafkaDelegatePartitioner
-
Deprecated.
- setPartPrefix(String) - Method in class org.apache.flink.streaming.connectors.fs.bucketing.BucketingSink
-
Sets the prefix of part files.
- setPartPrefix(String) - Method in class org.apache.flink.streaming.connectors.fs.RollingSink
-
Deprecated.
Sets the prefix of part files.
- setPartSuffix(String) - Method in class org.apache.flink.streaming.connectors.fs.bucketing.BucketingSink
-
Sets the prefix of part files.
- setPassword(String) - Method in class org.apache.flink.api.java.io.jdbc.JDBCAppendTableSinkBuilder
-
Specify the password of the JDBC connection.
- setPassword(String) - Method in class org.apache.flink.api.java.io.jdbc.JDBCInputFormat.JDBCInputFormatBuilder
-
- setPassword(String) - Method in class org.apache.flink.api.java.io.jdbc.JDBCOutputFormat.JDBCOutputFormatBuilder
-
- setPassword(String) - Method in class org.apache.flink.streaming.connectors.rabbitmq.common.RMQConnectionConfig.Builder
-
Set the password.
- setPattern(String, Pattern) - Method in class org.apache.hadoop.conf.Configuration
-
Set the given property to Pattern
.
- setPayload(P) - Method in class org.apache.flink.table.client.gateway.TypedResult
-
- setPendingCommitTransactions(List<TwoPhaseCommitSinkFunction.TransactionHolder<TXN>>) - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.State
-
- setPendingPrefix(String) - Method in class org.apache.flink.streaming.connectors.fs.bucketing.BucketingSink
-
Sets the prefix of pending part files.
- setPendingPrefix(String) - Method in class org.apache.flink.streaming.connectors.fs.RollingSink
-
Deprecated.
Sets the prefix of pending part files.
- setPendingSuffix(String) - Method in class org.apache.flink.streaming.connectors.fs.bucketing.BucketingSink
-
Sets the suffix of pending part files.
- setPendingSuffix(String) - Method in class org.apache.flink.streaming.connectors.fs.RollingSink
-
Deprecated.
Sets the suffix of pending part files.
- setPendingTransaction(TwoPhaseCommitSinkFunction.TransactionHolder<TXN>) - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.State
-
- setPermuteResults(boolean) - Method in class org.apache.flink.graph.library.clustering.TriangleListingBase
-
By default only one result is output for each triangle, whether vertices
are sorted or unsorted.
- setPlan(FlinkPlan) - Method in class org.apache.flink.client.program.OptimizerPlanEnvironment
-
- setPoolName(String) - Method in class org.apache.flink.runtime.util.ExecutorThreadFactory.Builder
-
- setPort(int) - Method in class org.apache.flink.streaming.connectors.rabbitmq.common.RMQConnectionConfig.Builder
-
Set the target port.
- setPosition(int) - Method in class org.apache.flink.core.memory.ByteArrayInputStreamWithPos
-
- setPosition(int) - Method in class org.apache.flink.core.memory.ByteArrayOutputStreamWithPos
-
- setPredefinedOptions(PredefinedOptions) - Method in class org.apache.flink.contrib.streaming.state.RocksDBStateBackend
-
Sets the predefined options for RocksDB.
- setPreProcessingOperationName(String) - Method in class org.apache.flink.runtime.jobgraph.JobEdge
-
Sets the name of the pre-processing operation for this input.
- setPreview(String) - Method in class org.apache.flink.client.program.PreviewPlanEnvironment
-
- setPrintStatusDuringExecution(boolean) - Method in class org.apache.flink.api.common.PlanExecutor
-
Sets whether the executor should print progress results to "standard out" (
System.out
).
- setPrintStatusDuringExecution(boolean) - Method in class org.apache.flink.client.program.ClusterClient
-
Configures whether the client should print progress updates during the execution to System.out
.
- setProcessingTimeTimers(Set<InternalTimer<K, N>>) - Method in class org.apache.flink.streaming.api.operators.InternalTimersSnapshot
-
- setProctimeAttribute(String) - Method in class org.apache.flink.streaming.connectors.kafka.Kafka010AvroTableSource
-
Declares a field of the schema to be a processing time attribute.
- setProctimeAttribute(String) - Method in class org.apache.flink.streaming.connectors.kafka.Kafka010JsonTableSource
-
Declares a field of the schema to be a processing time attribute.
- setProctimeAttribute(String) - Method in class org.apache.flink.streaming.connectors.kafka.Kafka011AvroTableSource
-
Declares a field of the schema to be a processing time attribute.
- setProctimeAttribute(String) - Method in class org.apache.flink.streaming.connectors.kafka.Kafka011JsonTableSource
-
Declares a field of the schema to be a processing time attribute.
- setProctimeAttribute(String) - Method in class org.apache.flink.streaming.connectors.kafka.Kafka08AvroTableSource
-
Declares a field of the schema to be a processing time attribute.
- setProctimeAttribute(String) - Method in class org.apache.flink.streaming.connectors.kafka.Kafka08JsonTableSource
-
Declares a field of the schema to be a processing time attribute.
- setProctimeAttribute(String) - Method in class org.apache.flink.streaming.connectors.kafka.Kafka09AvroTableSource
-
Declares a field of the schema to be a processing time attribute.
- setProctimeAttribute(String) - Method in class org.apache.flink.streaming.connectors.kafka.Kafka09JsonTableSource
-
Declares a field of the schema to be a processing time attribute.
- setProctimeAttribute(String) - Method in class org.apache.flink.streaming.connectors.kafka.KafkaTableSource
-
Declares a field of the schema to be the processing time attribute.
- setProvidedUserJarFiles(List<URL>) - Method in class org.apache.flink.yarn.AbstractYarnClusterDescriptor
-
Sets the user jar which is included in the system classloader of all nodes.
- setPruningMarker() - Method in class org.apache.flink.optimizer.plan.PlanNode
-
Sets the pruning marker to true.
- setQuery(String) - Method in class org.apache.flink.api.java.io.jdbc.JDBCAppendTableSinkBuilder
-
Specify the query that the sink will execute.
- setQuery(String) - Method in class org.apache.flink.api.java.io.jdbc.JDBCInputFormat.JDBCInputFormatBuilder
-
- setQuery(String) - Method in class org.apache.flink.api.java.io.jdbc.JDBCOutputFormat.JDBCOutputFormatBuilder
-
- setQuery(String) - Method in class org.apache.flink.streaming.connectors.cassandra.CassandraSink.CassandraSinkBuilder
-
Sets the query that is to be executed for every record.
- setQueryable(String) - Method in class org.apache.flink.api.common.state.StateDescriptor
-
Sets the name for queries of state created from this descriptor.
- SetQueue<E> - Class in org.apache.flink.runtime.jobmanager.scheduler
-
A queue that maintains set characteristics, i.e., elements
that are already in the queue may not be added another time.
- SetQueue() - Constructor for class org.apache.flink.runtime.jobmanager.scheduler.SetQueue
-
- setQueue(String) - Method in class org.apache.flink.yarn.AbstractYarnClusterDescriptor
-
- setQueuedSchedulingAllowed(boolean) - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- setQuietMode(boolean) - Method in class org.apache.hadoop.conf.Configuration
-
Set the quietness-mode.
- setQuoteStrings(boolean) - Method in class org.apache.flink.api.java.io.CsvOutputFormat
-
Configures whether the output format should quote string values.
- setQuoteStrings(boolean) - Method in class org.apache.flink.api.scala.operators.ScalaCsvOutputFormat
-
Configures whether the output format should quote string values.
- setRandomPartitioned() - Method in class org.apache.flink.optimizer.dataproperties.GlobalProperties
-
- setRandomPartitioning() - Method in class org.apache.flink.optimizer.dataproperties.RequestedGlobalProperties
-
- setRangePartitioned(Ordering) - Method in class org.apache.flink.optimizer.dataproperties.GlobalProperties
-
Set the parameters for range partition.
- setRangePartitioned(Ordering, DataDistribution) - Method in class org.apache.flink.optimizer.dataproperties.GlobalProperties
-
Set the parameters for range partition.
- setRangePartitioned(Ordering) - Method in class org.apache.flink.optimizer.dataproperties.RequestedGlobalProperties
-
- setRangePartitioned(Ordering, DataDistribution) - Method in class org.apache.flink.optimizer.dataproperties.RequestedGlobalProperties
-
- setReaderIndex(int) - Method in interface org.apache.flink.runtime.io.network.buffer.Buffer
-
Sets the reader index of this buffer.
- setReaderIndex(int) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
-
- setReaderIndex(int) - Method in class org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
-
- setReadPosition(long) - Method in interface org.apache.flink.core.memory.SeekableDataInputView
-
Sets the read pointer to the given position.
- setReadPosition(long) - Method in class org.apache.flink.runtime.io.disk.RandomAccessInputView
-
- setReadPosition(long) - Method in class org.apache.flink.runtime.operators.hash.HashPartition
-
- setRecordCount(long) - Method in class org.apache.flink.api.common.io.BlockInfo
-
Sets the recordCount to the specified value.
- setReduceOnSourceId(boolean) - Method in class org.apache.flink.graph.asm.degree.annotate.undirected.EdgeTargetDegree
-
The degree can be counted from either the edge source or target IDs.
- setReduceOnTargetId(boolean) - Method in class org.apache.flink.graph.asm.degree.annotate.undirected.EdgeDegreePair
-
The degree can be counted from either the edge source or target IDs.
- setReduceOnTargetId(boolean) - Method in class org.apache.flink.graph.asm.degree.annotate.undirected.EdgeSourceDegree
-
The degree can be counted from either the edge source or target IDs.
- setReduceOnTargetId(boolean) - Method in class org.apache.flink.graph.asm.degree.annotate.undirected.VertexDegree
-
The degree can be counted from either the edge source or target IDs.
- setReduceOnTargetId(boolean) - Method in class org.apache.flink.graph.asm.degree.filter.undirected.MaximumDegree
-
The degree can be counted from either the edge source or target IDs.
- setReduceOnTargetId(boolean) - Method in class org.apache.flink.graph.library.metric.undirected.EdgeMetrics
-
The degree can be counted from either the edge source or target IDs.
- setReduceOnTargetId(boolean) - Method in class org.apache.flink.graph.library.metric.undirected.VertexMetrics
-
The degree can be counted from either the edge source or target IDs.
- setReference(T) - Method in class org.apache.flink.api.common.typeutils.base.array.PrimitiveArrayComparator
-
- setReference(T) - Method in class org.apache.flink.api.common.typeutils.base.BasicTypeComparator
-
- setReference(BooleanValue) - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueComparator
-
- setReference(ByteValue) - Method in class org.apache.flink.api.common.typeutils.base.ByteValueComparator
-
- setReference(CharValue) - Method in class org.apache.flink.api.common.typeutils.base.CharValueComparator
-
- setReference(DoubleValue) - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueComparator
-
- setReference(FloatValue) - Method in class org.apache.flink.api.common.typeutils.base.FloatValueComparator
-
- setReference(IntValue) - Method in class org.apache.flink.api.common.typeutils.base.IntValueComparator
-
- setReference(LongValue) - Method in class org.apache.flink.api.common.typeutils.base.LongValueComparator
-
- setReference(NullValue) - Method in class org.apache.flink.api.common.typeutils.base.NullValueComparator
-
- setReference(ShortValue) - Method in class org.apache.flink.api.common.typeutils.base.ShortValueComparator
-
- setReference(StringValue) - Method in class org.apache.flink.api.common.typeutils.base.StringValueComparator
-
- setReference(T1) - Method in class org.apache.flink.api.common.typeutils.GenericPairComparator
-
- setReference(T) - Method in class org.apache.flink.api.common.typeutils.SameTypePairComparator
-
- setReference(T) - Method in class org.apache.flink.api.common.typeutils.TypeComparator
-
- setReference(T1) - Method in class org.apache.flink.api.common.typeutils.TypePairComparator
-
Sets the reference for comparisons.
- setReference(T) - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueComparator
-
- setReference(T) - Method in class org.apache.flink.api.java.typeutils.runtime.GenericTypeComparator
-
- setReference(T) - Method in class org.apache.flink.api.java.typeutils.runtime.NullAwareComparator
-
- setReference(T) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoComparator
-
- setReference(Row) - Method in class org.apache.flink.api.java.typeutils.runtime.RowComparator
-
- setReference(T) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparator
-
- setReference(T) - Method in class org.apache.flink.api.java.typeutils.runtime.ValueComparator
-
- setReference(T) - Method in class org.apache.flink.api.java.typeutils.runtime.WritableComparator
-
- setReference(ByteValueArray) - Method in class org.apache.flink.graph.types.valuearray.ByteValueArrayComparator
-
- setReference(CharValueArray) - Method in class org.apache.flink.graph.types.valuearray.CharValueArrayComparator
-
- setReference(DoubleValueArray) - Method in class org.apache.flink.graph.types.valuearray.DoubleValueArrayComparator
-
- setReference(FloatValueArray) - Method in class org.apache.flink.graph.types.valuearray.FloatValueArrayComparator
-
- setReference(IntValueArray) - Method in class org.apache.flink.graph.types.valuearray.IntValueArrayComparator
-
- setReference(LongValueArray) - Method in class org.apache.flink.graph.types.valuearray.LongValueArrayComparator
-
- setReference(NullValueArray) - Method in class org.apache.flink.graph.types.valuearray.NullValueArrayComparator
-
- setReference(ShortValueArray) - Method in class org.apache.flink.graph.types.valuearray.ShortValueArrayComparator
-
- setReference(StringValueArray) - Method in class org.apache.flink.graph.types.valuearray.StringValueArrayComparator
-
- setRegisteredAsAvailable(boolean) - Method in interface org.apache.flink.runtime.io.network.NetworkSequenceViewReader
-
Updates the value to indicate whether the reader is enqueued in the pipeline or not.
- setRelativeBackChannelMemory(double) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setRelativeInputMaterializationMemory(int, double) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setRelativeMemoryDriver(double) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setRelativeMemoryInput(int, double) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setRelativeMemoryLocalStrategy(double) - Method in class org.apache.flink.optimizer.plan.Channel
-
- setRelativeMemoryPerSubtask(double) - Method in class org.apache.flink.optimizer.plan.PlanNode
-
Sets the memory dedicated to each task for this node.
- setRelativeSolutionSetMemory(double) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setRelativeTempMemory(double) - Method in class org.apache.flink.optimizer.plan.Channel
-
Sets the memory for materializing the channel's result from this Channel.
- setReplicationFactor(int) - Method in class org.apache.flink.optimizer.plan.Channel
-
Sets the replication factor of the connection.
- setRequestedChannelMax(int) - Method in class org.apache.flink.streaming.connectors.rabbitmq.common.RMQConnectionConfig.Builder
-
Set the requested maximum channel number.
- setRequestedFrameMax(int) - Method in class org.apache.flink.streaming.connectors.rabbitmq.common.RMQConnectionConfig.Builder
-
Set the requested maximum frame size.
- setRequestedHeartbeat(int) - Method in class org.apache.flink.streaming.connectors.rabbitmq.common.RMQConnectionConfig.Builder
-
Set the requested heartbeat.
- setRequestFuture(CompletableFuture<Acknowledge>) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.PendingSlotRequest
-
- setRequiredGlobalProps(RequestedGlobalProperties) - Method in class org.apache.flink.optimizer.plan.Channel
-
- setRequiredLocalProps(RequestedLocalProperties) - Method in class org.apache.flink.optimizer.plan.Channel
-
- setResources(ResourceSpec, ResourceSpec) - Method in class org.apache.flink.api.common.operators.Operator
-
Sets the minimum and preferred resources for this contract instance.
- setResources(ResourceSpec, ResourceSpec) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
Sets the minimum and preferred resources for the task.
- setResources(int, ResourceSpec, ResourceSpec) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- setResources(ResourceSpec, ResourceSpec) - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- setResources(ResourceSpec, ResourceSpec) - Method in class org.apache.flink.streaming.api.transformations.StreamTransformation
-
Sets the minimum and preferred resources for this stream transformation.
- setRestartStrategy(RestartStrategies.RestartStrategyConfiguration) - Method in class org.apache.flink.api.common.ExecutionConfig
-
Sets the restart strategy to be used for recovery.
- setRestartStrategy(RestartStrategies.RestartStrategyConfiguration) - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
Sets the restart strategy configuration.
- setRestartStrategy(RestartStrategies.RestartStrategyConfiguration) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Sets the restart strategy configuration.
- setResult(VV) - Method in class org.apache.flink.graph.gsa.ApplyFunction
-
Sets the result for the apply function.
- setResultIterator(MutableObjectIterator<E>) - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger
-
Sets the result iterator.
- setResultIteratorException(IOException) - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger
-
Reports an exception to all threads that are waiting for the result iterator.
- setResultOptimizerProperties(String) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
- setResultSetConcurrency(int) - Method in class org.apache.flink.api.java.io.jdbc.JDBCInputFormat.JDBCInputFormatBuilder
-
- setResultSetType(int) - Method in class org.apache.flink.api.java.io.jdbc.JDBCInputFormat.JDBCInputFormatBuilder
-
- setReuseAvroValue(boolean) - Method in class org.apache.flink.formats.avro.AvroInputFormat
-
Sets the flag whether to reuse the Avro value instance for all records.
- setRowtimeAttributeDescriptor(RowtimeAttributeDescriptor) - Method in class org.apache.flink.streaming.connectors.kafka.Kafka010AvroTableSource
-
Declares a field of the schema to be a rowtime attribute.
- setRowtimeAttributeDescriptor(RowtimeAttributeDescriptor) - Method in class org.apache.flink.streaming.connectors.kafka.Kafka010JsonTableSource
-
Declares a field of the schema to be a rowtime attribute.
- setRowtimeAttributeDescriptor(RowtimeAttributeDescriptor) - Method in class org.apache.flink.streaming.connectors.kafka.Kafka011AvroTableSource
-
Declares a field of the schema to be a rowtime attribute.
- setRowtimeAttributeDescriptor(RowtimeAttributeDescriptor) - Method in class org.apache.flink.streaming.connectors.kafka.Kafka011JsonTableSource
-
Declares a field of the schema to be a rowtime attribute.
- setRowtimeAttributeDescriptor(RowtimeAttributeDescriptor) - Method in class org.apache.flink.streaming.connectors.kafka.Kafka08AvroTableSource
-
Declares a field of the schema to be a rowtime attribute.
- setRowtimeAttributeDescriptor(RowtimeAttributeDescriptor) - Method in class org.apache.flink.streaming.connectors.kafka.Kafka08JsonTableSource
-
Declares a field of the schema to be a rowtime attribute.
- setRowtimeAttributeDescriptor(RowtimeAttributeDescriptor) - Method in class org.apache.flink.streaming.connectors.kafka.Kafka09AvroTableSource
-
Declares a field of the schema to be a rowtime attribute.
- setRowtimeAttributeDescriptor(RowtimeAttributeDescriptor) - Method in class org.apache.flink.streaming.connectors.kafka.Kafka09JsonTableSource
-
Declares a field of the schema to be a rowtime attribute.
- setRowtimeAttributeDescriptors(List<RowtimeAttributeDescriptor>) - Method in class org.apache.flink.streaming.connectors.kafka.KafkaTableSource
-
Declares a list of fields to be rowtime attributes.
- setRowTypeInfo(RowTypeInfo) - Method in class org.apache.flink.api.java.io.jdbc.JDBCInputFormat.JDBCInputFormatBuilder
-
- setRpcServiceSharing(MiniClusterConfiguration.RpcServiceSharing) - Method in class org.apache.flink.runtime.minicluster.MiniClusterConfiguration.Builder
-
- setRuntimeContext(RuntimeContext) - Method in class org.apache.flink.api.common.functions.AbstractRichFunction
-
- setRuntimeContext(RuntimeContext) - Method in interface org.apache.flink.api.common.functions.RichFunction
-
Sets the function's runtime context.
- setRuntimeContext(RuntimeContext) - Method in class org.apache.flink.api.common.io.ReplicatingInputFormat
-
- setRuntimeContext(RuntimeContext) - Method in class org.apache.flink.api.common.io.RichInputFormat
-
- setRuntimeContext(RuntimeContext) - Method in class org.apache.flink.api.common.io.RichOutputFormat
-
- setRuntimeContext(RuntimeContext) - Method in class org.apache.flink.api.java.operators.translation.WrappingFunction
-
- setRuntimeContext(RuntimeContext) - Method in class org.apache.flink.streaming.api.functions.async.RichAsyncFunction
-
- setRuntimeContext(RuntimeContext) - Method in class org.apache.flink.streaming.api.functions.sink.OutputFormatSinkFunction
-
Deprecated.
- setRuntimeContext(RuntimeContext) - Method in class org.apache.flink.streaming.api.functions.windowing.FoldApplyProcessAllWindowFunction
-
Deprecated.
- setRuntimeContext(RuntimeContext) - Method in class org.apache.flink.streaming.api.functions.windowing.FoldApplyProcessWindowFunction
-
Deprecated.
- setRuntimeContext(RuntimeContext) - Method in class org.apache.flink.streaming.api.functions.windowing.ReduceApplyProcessAllWindowFunction
-
- setRuntimeContext(RuntimeContext) - Method in class org.apache.flink.streaming.api.functions.windowing.ReduceApplyProcessWindowFunction
-
- setSafetyNetCloseableRegistryForThread(SafetyNetCloseableRegistry) - Static method in class org.apache.flink.core.fs.FileSystemSafetyNet
-
Sets the active safety-net registry for the current thread.
- setSavepointRestoreSettings(SavepointRestoreSettings) - Method in class org.apache.flink.client.program.PackagedProgram
-
- setSavepointRestoreSettings(SavepointRestoreSettings) - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
Sets the savepoint restore settings.
- setScheduleMode(ScheduleMode) - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- setScheduleMode(ScheduleMode) - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
- setSchema(Schema) - Method in class org.apache.flink.formats.avro.AvroOutputFormat
-
- setSecondDegree(Integer) - Method in class org.apache.flink.examples.java.graph.util.EnumTrianglesDataTypes.EdgeWithDegrees
-
- setSecondDegree(Integer) - Method in class org.apache.flink.graph.library.TriangleEnumerator.EdgeWithDegrees
-
- setSecondInput(Operator<IN2>) - Method in class org.apache.flink.api.common.operators.DualInputOperator
-
Clears all previous connections and connects the second input to the task wrapped in this contract
- setSecondInput(Operator<IN2>...) - Method in class org.apache.flink.api.common.operators.DualInputOperator
-
- setSecondInputs(List<Operator<IN2>>) - Method in class org.apache.flink.api.common.operators.DualInputOperator
-
- setSecondVertex(Integer) - Method in class org.apache.flink.examples.java.graph.util.EnumTrianglesDataTypes.Edge
-
- setSecondVertex(Integer) - Method in class org.apache.flink.examples.java.graph.util.EnumTrianglesDataTypes.EdgeWithDegrees
-
- setSecondVertex(Integer) - Method in class org.apache.flink.examples.java.graph.util.EnumTrianglesDataTypes.Triad
-
- setSecondVertex(K) - Method in class org.apache.flink.graph.library.TriangleEnumerator.EdgeWithDegrees
-
- setSecondVertex(K) - Method in class org.apache.flink.graph.library.TriangleEnumerator.Triad
-
- setSemanticProperties(DualInputSemanticProperties) - Method in class org.apache.flink.api.common.operators.DualInputOperator
-
- setSemanticProperties(SingleInputSemanticProperties) - Method in class org.apache.flink.api.common.operators.SingleInputOperator
-
- setSemanticProperties(SingleInputSemanticProperties) - Method in class org.apache.flink.api.java.operators.SingleInputUdfOperator
-
Sets the semantic properties for the user-defined function (UDF).
- setSemanticProperties(DualInputSemanticProperties) - Method in class org.apache.flink.api.java.operators.TwoInputUdfOperator
-
Sets the semantic properties for the user-defined function (UDF).
- setSentence(String) - Method in class org.apache.flink.storm.wordcount.operators.WordCountDataPojos.Sentence
-
- setSerializer(TypeSerializer<T>) - Method in class org.apache.flink.api.java.io.TypeSerializerOutputFormat
-
- setSerializer(TypeSerializerFactory<?>) - Method in class org.apache.flink.optimizer.plan.Channel
-
Sets the serializer for this Channel.
- setSerializer(TypeSerializerFactory<?>) - Method in class org.apache.flink.optimizer.plan.SourcePlanNode
-
Sets the serializer for this PlanNode.
- setSerializerForIterationChannel(TypeSerializerFactory<?>) - Method in class org.apache.flink.optimizer.plan.BulkIterationPlanNode
-
- setSerializerForIterationChannel(TypeSerializerFactory<?>) - Method in class org.apache.flink.optimizer.plan.WorksetIterationPlanNode
-
- setSerializerIn1(TypeSerializer<?>) - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- setSerializerIn2(TypeSerializer<?>) - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- setSerializerOut(TypeSerializer<?>) - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- setSerializers(Integer, TypeSerializer<?>, TypeSerializer<?>, TypeSerializer<?>) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- setSerializersFrom(Integer, Integer) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- setSessionProperty(String, String) - Method in class org.apache.flink.table.client.gateway.SessionContext
-
- setSessionTimeout(long) - Method in class org.apache.flink.api.common.Plan
-
- setSessionTimeout(long) - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
Sets the session timeout to hold the intermediate results of a job.
- setSessionTimeout(long) - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
Sets the timeout of the session in seconds.
- setSharedNeighborCount(IntValue) - Method in class org.apache.flink.graph.library.similarity.JaccardIndex.Result
-
Set the shared neighbor count.
- setSharedSlot(SharedSlot) - Method in class org.apache.flink.runtime.jobmanager.scheduler.CoLocationConstraint
-
Assigns a new shared slot to this co-location constraint.
- setShipStrategy(ShipStrategyType) - Method in class org.apache.flink.optimizer.dag.DagConnection
-
Sets the shipping strategy for this connection.
- setShipStrategy(ShipStrategyType, DataExchangeMode) - Method in class org.apache.flink.optimizer.plan.Channel
-
- setShipStrategy(ShipStrategyType, FieldList, DataExchangeMode) - Method in class org.apache.flink.optimizer.plan.Channel
-
- setShipStrategy(ShipStrategyType, FieldList, boolean[], DataExchangeMode) - Method in class org.apache.flink.optimizer.plan.Channel
-
- setShipStrategy(ShipStrategyType, FieldList, Partitioner<?>, DataExchangeMode) - Method in class org.apache.flink.optimizer.plan.Channel
-
- setShipStrategy(ShipStrategyType, FieldList, boolean[], Partitioner<?>, DataExchangeMode) - Method in class org.apache.flink.optimizer.plan.Channel
-
- setShipStrategyComparator(TypeComparatorFactory<?>) - Method in class org.apache.flink.optimizer.plan.Channel
-
Sets the ship strategy comparator for this Channel.
- setShipStrategyName(String) - Method in class org.apache.flink.runtime.jobgraph.JobEdge
-
Sets the name of the ship strategy for the represented input.
- setSize(int) - Method in interface org.apache.flink.runtime.io.network.buffer.Buffer
-
Sets the size of the written data, i.e.
- setSize(int) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
-
- setSize(int) - Method in class org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
-
- setSkipFirstLineAsHeader(boolean) - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
-
- setSkipInvalidLines(boolean) - Method in class org.apache.flink.api.java.io.TextValueInputFormat
-
- setSlotAvailabilityListener(SlotAvailabilityListener) - Method in class org.apache.flink.runtime.instance.Instance
-
Sets the listener that receives notifications for slot availability.
- setSlotRequestId(SlotRequestId) - Method in class org.apache.flink.runtime.jobmanager.scheduler.CoLocationConstraint
-
Sets the slot request id of the currently assigned slot to the co-location constraint.
- setSlotSharingGroup(SlotSharingGroup) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
Associates this vertex with a slot sharing group for scheduling.
- setSlotSharingGroup(String) - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- setSlotSharingGroup(String) - Method in class org.apache.flink.streaming.api.transformations.StreamTransformation
-
Sets the slot sharing group of this transformation.
- setSlotsPerTaskManager(int) - Method in class org.apache.flink.client.deployment.ClusterSpecification.ClusterSpecificationBuilder
-
- setSnapshotSettings(JobCheckpointingSettings) - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
Sets the settings for asynchronous snapshots.
- setSocketAddr(String, InetSocketAddress) - Method in class org.apache.hadoop.conf.Configuration
-
Set the socket address for the name
property as
a host:port
.
- setSolutionSetComparator(TypeComparatorFactory<?>) - Method in class org.apache.flink.optimizer.plan.WorksetIterationPlanNode
-
- setSolutionSetComparator(TypeComparatorFactory<?>) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setSolutionSetDelta(Operator<ST>) - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase
-
Sets the contract of the step function that represents the solution set delta.
- setSolutionSetSerializer(TypeSerializerFactory<?>) - Method in class org.apache.flink.optimizer.plan.WorksetIterationPlanNode
-
- setSolutionSetSerializer(TypeSerializerFactory<?>) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setSolutionSetUnManaged(boolean) - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase
-
Sets whether to keep the solution set in managed memory (safe against heap exhaustion) or unmanaged memory
(objects on heap).
- setSolutionSetUnManaged(boolean) - Method in class org.apache.flink.api.java.operators.DeltaIteration
-
Sets whether to keep the solution set in managed memory (safe against heap exhaustion) or unmanaged memory
(objects on heap).
- setSolutionSetUnmanaged(boolean) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setSolutionSetUnmanagedMemory(boolean) - Method in class org.apache.flink.graph.IterationConfiguration
-
Defines whether the solution set is kept in managed memory (Flink's internal way of keeping object
in serialized form) or as a simple object map.
- setSortTriangleVertices(boolean) - Method in class org.apache.flink.graph.library.clustering.TriangleListingBase
-
Normalize the triangle listing such that for each result (K0, K1, K2)
the vertex IDs are sorted K0 < K1 < K2.
- setSource(K) - Method in class org.apache.flink.graph.Edge
-
- setSource(PlanNode) - Method in class org.apache.flink.optimizer.plan.Channel
-
- setSource(Path) - Method in class org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact.Builder
-
- setSpecificStartupOffsets(Map<KafkaTopicPartition, Long>) - Method in class org.apache.flink.streaming.connectors.kafka.KafkaTableSource
-
- setSpillingThresholdDriver(float) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setSpillingThresholdInput(int, float) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setSplitDataProperties(GenericDataSourceBase.SplitDataProperties<OUT>) - Method in class org.apache.flink.api.common.operators.GenericDataSourceBase
-
Sets properties of input splits for this data source.
- setSplitState(Serializable) - Method in class org.apache.flink.streaming.api.functions.source.TimestampedFileInputSplit
-
Sets the state of the split.
- setSqlTypes(int[]) - Method in class org.apache.flink.api.java.io.jdbc.JDBCOutputFormat.JDBCOutputFormatBuilder
-
- setSSLVerAndCipherSuites(SSLEngine) - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
-
- setSSLVerAndCipherSuites(ServerSocket, Configuration) - Static method in class org.apache.flink.runtime.net.SSLUtils
-
Sets SSl version and cipher suites for SSLServerSocket.
- setSSLVerAndCipherSuites(SSLEngine, Configuration) - Static method in class org.apache.flink.runtime.net.SSLUtils
-
- setSSLVerifyHostname(SSLParameters) - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
-
- setSSLVerifyHostname(Configuration, SSLParameters) - Static method in class org.apache.flink.runtime.net.SSLUtils
-
Sets SSL options to verify peer's hostname in the certificate.
- setStartFromEarliest() - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumerBase
-
Specifies the consumer to start reading from the earliest offset for all partitions.
- setStartFromGroupOffsets() - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumerBase
-
Specifies the consumer to start reading from any committed group offsets found
in Zookeeper / Kafka brokers.
- setStartFromLatest() - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumerBase
-
Specifies the consumer to start reading from the latest offset for all partitions.
- setStartFromSpecificOffsets(Map<KafkaTopicPartition, Long>) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumerBase
-
Specifies the consumer to start reading partitions from specific offsets, set independently for each partition.
- setStartFromTimestamp(long) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer010
-
- setStartFromTimestamp(long) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumerBase
-
Specifies the consumer to start reading partitions from a specified timestamp.
- setStartupMode(StartupMode) - Method in class org.apache.flink.streaming.connectors.kafka.KafkaTableSource
-
Sets the startup mode of the TableSource.
- setState(int) - Method in class org.apache.flink.api.java.sca.UdfAnalyzer
-
- setStateBackend(StateBackend) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Sets the state backend that describes how to store and checkpoint operator state.
- setStateBackend(AbstractStateBackend) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- setStateBackend(StateBackend) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setStateBackend(StateBackend) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- setStateKeySelector(KeySelector<IN, ?>) - Method in class org.apache.flink.streaming.api.transformations.OneInputTransformation
-
Sets the
KeySelector
that must be used for partitioning keyed state of this operation.
- setStateKeySelector(KeySelector<T, ?>) - Method in class org.apache.flink.streaming.api.transformations.SinkTransformation
-
Sets the
KeySelector
that must be used for partitioning keyed state of this Sink.
- setStateKeySelectors(KeySelector<IN1, ?>, KeySelector<IN2, ?>) - Method in class org.apache.flink.streaming.api.transformations.TwoInputTransformation
-
Sets the
KeySelectors
that must be used for partitioning keyed state of
this transformation.
- setStateKeySerializer(TypeSerializer<?>) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setStateKeySerializer(TypeSerializer<?>) - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- setStateKeyType(TypeInformation<?>) - Method in class org.apache.flink.streaming.api.transformations.OneInputTransformation
-
- setStateKeyType(TypeInformation<?>) - Method in class org.apache.flink.streaming.api.transformations.SinkTransformation
-
- setStateKeyType(TypeInformation<?>) - Method in class org.apache.flink.streaming.api.transformations.TwoInputTransformation
-
- setStateMetaInfo(RegisteredBroadcastBackendStateMetaInfo<K, V>) - Method in interface org.apache.flink.runtime.state.BackendWritableBroadcastState
-
- setStateMetaInfo(RegisteredBroadcastBackendStateMetaInfo<K, V>) - Method in class org.apache.flink.runtime.state.HeapBroadcastState
-
- setStatePartitioner(int, KeySelector<?, ?>) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setStatePartitioner1(KeySelector<?, ?>) - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- setStatePartitioner2(KeySelector<?, ?>) - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- setStateSizeInMB(int) - Method in class org.apache.flink.api.common.operators.ResourceSpec.Builder
-
- setStatisticsKey(String) - Method in class org.apache.flink.api.common.operators.GenericDataSourceBase
-
Sets the key under which statistics about this data source may be obtained from the
statistics cache.
- setStatus(String) - Method in class org.apache.flink.api.java.hadoop.mapred.wrapper.HadoopDummyReporter
-
- setStormTopology(StormTopology) - Method in class org.apache.flink.storm.wrappers.BoltWrapper
-
Sets the original Storm topology.
- setStormTopology(StormTopology) - Method in class org.apache.flink.storm.wrappers.SpoutWrapper
-
Sets the original Storm topology.
- setStreamOperator(StreamOperator<?>) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setStreamTimeCharacteristic(TimeCharacteristic) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Sets the time characteristic for all streams create from this environment, e.g., processing
time, event time, or ingestion time.
- setStrictlyCoLocatedWith(JobVertex) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
Tells this vertex to strictly co locate its subtasks with the subtasks of the given vertex.
- setString(String, String) - Method in class org.apache.flink.configuration.Configuration
-
Adds the given key/value pair to the configuration object.
- setString(ConfigOption<String>, String) - Method in class org.apache.flink.configuration.Configuration
-
Adds the given value to the configuration object.
- setString(String, String) - Method in class org.apache.flink.configuration.DelegatingConfiguration
-
- setString(ConfigOption<String>, String) - Method in class org.apache.flink.configuration.DelegatingConfiguration
-
- setStrings(String, String...) - Method in class org.apache.hadoop.conf.Configuration
-
Set the array of string values for the name
property as
as comma delimited values.
- setStringToTokenize(StringValue) - Method in class org.apache.flink.util.StringValueUtils.WhitespaceTokenizer
-
Sets the string to be tokenized and resets the state of the tokenizer.
- setStubParameter(String, String) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setStubParameters(Configuration) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setStubWrapper(UserCodeWrapper<?>) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setSyncDurationMillis(long) - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetrics
-
- setSyncOnFlush(boolean) - Method in class org.apache.flink.streaming.connectors.fs.StreamWriterBase
-
Controls whether to sync FSDataOutputStream
on flush.
- SettableLeaderRetrievalService - Class in org.apache.flink.runtime.leaderretrieval
-
- SettableLeaderRetrievalService() - Constructor for class org.apache.flink.runtime.leaderretrieval.SettableLeaderRetrievalService
-
- SettableLeaderRetrievalService(String, UUID) - Constructor for class org.apache.flink.runtime.leaderretrieval.SettableLeaderRetrievalService
-
- setTables(List<Map<String, Object>>) - Method in class org.apache.flink.table.client.config.Environment
-
- setTag(TaggedValue.Tag) - Method in class org.apache.flink.api.java.sca.TaggedValue
-
- setTarget(K) - Method in class org.apache.flink.graph.Edge
-
- setTarget(PlanNode) - Method in class org.apache.flink.optimizer.plan.Channel
-
Sets the target of this Channel.
- setTargetToStandardErr() - Method in class org.apache.flink.api.java.io.PrintingOutputFormat
-
- setTargetToStandardErr() - Method in class org.apache.flink.streaming.api.functions.sink.PrintSinkFunction
-
- setTargetToStandardOut() - Method in class org.apache.flink.api.java.io.PrintingOutputFormat
-
- setTargetToStandardOut() - Method in class org.apache.flink.streaming.api.functions.sink.PrintSinkFunction
-
- setTaskCancellationInterval(long) - Method in class 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) - Method in class 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.
- setTaskManagerMemoryMB(int) - Method in class org.apache.flink.client.deployment.ClusterSpecification.ClusterSpecificationBuilder
-
- setTaskManagerNumSlots(int) - Method in class org.apache.flink.client.LocalExecutor
-
- setTaskName(String) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setTempMode(TempMode) - Method in class org.apache.flink.optimizer.plan.Channel
-
Sets the temp mode of the connection.
- setTerminationCriterion(Operator<X>) - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase
-
- setTheta0(double) - Method in class org.apache.flink.examples.java.ml.LinearRegression.Params
-
- setTheta1(double) - Method in class org.apache.flink.examples.java.ml.LinearRegression.Params
-
- setThirdVertex(Integer) - Method in class org.apache.flink.examples.java.graph.util.EnumTrianglesDataTypes.Triad
-
- setThirdVertex(K) - Method in class org.apache.flink.graph.library.TriangleEnumerator.Triad
-
- setThreadPriority(int) - Method in class org.apache.flink.runtime.util.ExecutorThreadFactory.Builder
-
- setTimeCharacteristic(TimeCharacteristic) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setTimeDuration(String, long, TimeUnit) - Method in class org.apache.hadoop.conf.Configuration
-
Set the value of name
to the given time duration.
- setTimestamp(StreamRecord<?>) - Method in class org.apache.flink.cep.operator.TimestampedSideOutputCollector
-
- setTimestamp(StreamRecord<?>) - Method in class org.apache.flink.streaming.api.operators.TimestampedCollector
-
- setTimestamp(long) - Method in class org.apache.flink.streaming.examples.kafka.KafkaEvent
-
- setTimestamp(long) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecord
-
- setTokensFor(ContainerLaunchContext, List<Path>, Configuration) - Static method in class org.apache.flink.yarn.Utils
-
- setTopId(KT) - Method in class org.apache.flink.graph.bipartite.BipartiteEdge
-
- setTopologyRecoveryEnabled(boolean) - Method in class org.apache.flink.streaming.connectors.rabbitmq.common.RMQConnectionConfig.Builder
-
Enables or disables topology recovery.
- setTransactionTimeout(long) - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
-
Sets the transaction timeout.
- setTransitiveChainedTaskConfigs(Map<Integer, StreamConfig>) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setTriangleCount(LongValue) - Method in class org.apache.flink.graph.library.clustering.directed.LocalClusteringCoefficient.Result
-
Set the number of triangles containing this vertex; equivalently,
this is the number of edges between neighbors of this vertex.
- setTriangleCount(LongValue) - Method in class org.apache.flink.graph.library.clustering.undirected.LocalClusteringCoefficient.Result
-
Set the number of triangles containing this vertex; equivalently,
this is the number of edges between neighbors of this vertex.
- setTwoInputStateKey(Integer, KeySelector<?, ?>, KeySelector<?, ?>, TypeSerializer<?>) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
- setType(TypedResult.ResultType) - Method in class org.apache.flink.table.client.gateway.TypedResult
-
- setTypeSerializerIn1(TypeSerializer<?>) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setTypeSerializerIn2(TypeSerializer<?>) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setTypeSerializerOut(TypeSerializer<?>) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setTypeSerializerSideOut(OutputTag<?>, TypeSerializer<?>) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setUdfConfiguration(Configuration) - Method in class org.apache.flink.runtime.operators.sort.CombiningUnilateralSortMerger
-
- setUid(String) - Method in class org.apache.flink.streaming.api.transformations.StreamTransformation
-
- setUidHash(String) - Method in class org.apache.flink.streaming.api.datastream.DataStreamSink
-
Sets an user provided hash for this operator.
- setUidHash(String) - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
-
Sets an user provided hash for this operator.
- setUidHash(String) - Method in class org.apache.flink.streaming.api.transformations.StreamTransformation
-
Sets an user provided hash for this operator.
- setUidHash(String) - Method in class org.apache.flink.streaming.connectors.cassandra.CassandraSink
-
Sets an user provided hash for this operator.
- setUidHash(String) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer010.FlinkKafkaProducer010Configuration
-
Deprecated.
- setUnsplittable(boolean) - Method in class org.apache.flink.formats.avro.AvroInputFormat
-
If set, the InputFormat will only read entire files.
- setup() - Method in class org.apache.flink.runtime.iterative.concurrent.SolutionSetUpdateBarrier
-
- setup() - Method in class org.apache.flink.runtime.iterative.concurrent.SuperstepBarrier
-
Setup the barrier, has to be called at the beginning of each superstep.
- setup(TaskContext<FlatJoinFunction<IT1, IT2, OT>, OT>) - Method in class org.apache.flink.runtime.operators.AbstractOuterJoinDriver
-
- setup(TaskContext<GroupCombineFunction<IN, OUT>, OUT>) - Method in class org.apache.flink.runtime.operators.AllGroupCombineDriver
-
- setup(TaskContext<GroupReduceFunction<IT, OT>, OT>) - Method in class org.apache.flink.runtime.operators.AllGroupReduceDriver
-
- setup(TaskContext<ReduceFunction<T>, T>) - Method in class org.apache.flink.runtime.operators.AllReduceDriver
-
- setup(AbstractInvokable) - Method in class org.apache.flink.runtime.operators.chaining.ChainedAllReduceDriver
-
- setup(TaskConfig, String, Collector<OT>, AbstractInvokable, ClassLoader, ExecutionConfig, Map<String, Accumulator<?, ?>>) - Method in class org.apache.flink.runtime.operators.chaining.ChainedDriver
-
- setup(AbstractInvokable) - Method in class org.apache.flink.runtime.operators.chaining.ChainedDriver
-
- setup(AbstractInvokable) - Method in class org.apache.flink.runtime.operators.chaining.ChainedFlatMapDriver
-
- setup(AbstractInvokable) - Method in class org.apache.flink.runtime.operators.chaining.ChainedMapDriver
-
- setup(AbstractInvokable) - Method in class org.apache.flink.runtime.operators.chaining.ChainedReduceCombineDriver
-
- setup(AbstractInvokable) - Method in class org.apache.flink.runtime.operators.chaining.ChainedTerminationCriterionDriver
-
- setup(AbstractInvokable) - Method in class org.apache.flink.runtime.operators.chaining.GroupCombineChainedDriver
-
- setup(AbstractInvokable) - Method in class org.apache.flink.runtime.operators.chaining.SynchronousChainedCombineDriver
-
- setup(TaskContext<CoGroupFunction<IT1, IT2, OT>, OT>) - Method in class org.apache.flink.runtime.operators.CoGroupDriver
-
- setup(TaskContext<CoGroupFunction<IT1, IT2, OT>, OT>) - Method in class org.apache.flink.runtime.operators.CoGroupRawDriver
-
- setup(TaskContext<CoGroupFunction<IT1, IT2, OT>, OT>) - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetFirstDriver
-
- setup(TaskContext<CoGroupFunction<IT1, IT2, OT>, OT>) - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetSecondDriver
-
- setup(TaskContext<CrossFunction<T1, T2, OT>, OT>) - Method in class org.apache.flink.runtime.operators.CrossDriver
-
- setup(TaskContext<S, OT>) - Method in interface org.apache.flink.runtime.operators.Driver
-
- setup(TaskContext<FlatMapFunction<IT, OT>, OT>) - Method in class org.apache.flink.runtime.operators.FlatMapDriver
-
- setup(TaskContext<GroupCombineFunction<IN, OUT>, OUT>) - Method in class org.apache.flink.runtime.operators.GroupReduceCombineDriver
-
- setup(TaskContext<GroupReduceFunction<IT, OT>, OT>) - Method in class org.apache.flink.runtime.operators.GroupReduceDriver
-
- setup(TaskContext<FlatJoinFunction<IT1, IT2, OT>, OT>) - Method in class org.apache.flink.runtime.operators.JoinDriver
-
- setup(TaskContext<FlatJoinFunction<IT1, IT2, OT>, OT>) - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetFirstDriver
-
- setup(TaskContext<FlatJoinFunction<IT1, IT2, OT>, OT>) - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetSecondDriver
-
- setup(TaskContext<MapFunction<IT, OT>, OT>) - Method in class org.apache.flink.runtime.operators.MapDriver
-
- setup(TaskContext<MapPartitionFunction<IT, OT>, OT>) - Method in class org.apache.flink.runtime.operators.MapPartitionDriver
-
- setup(AbstractInvokable) - Method in class org.apache.flink.runtime.operators.NoOpChainedDriver
-
- setup(TaskContext<AbstractRichFunction, T>) - Method in class org.apache.flink.runtime.operators.NoOpDriver
-
- setup(TaskContext<ReduceFunction<T>, T>) - Method in class org.apache.flink.runtime.operators.ReduceCombineDriver
-
- setup(TaskContext<ReduceFunction<T>, T>) - Method in class org.apache.flink.runtime.operators.ReduceDriver
-
- setup(TaskContext<Function, T>) - Method in class org.apache.flink.runtime.operators.UnionWithTempOperator
-
- setup(StreamTask<?, ?>, StreamConfig, Output<StreamRecord<OUT>>) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- setup(StreamTask<?, ?>, StreamConfig, Output<StreamRecord<OUT>>) - Method in class org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
-
- setup(StreamTask<?, ?>, StreamConfig, Output<StreamRecord<OUT>>) - Method in class org.apache.flink.streaming.api.operators.async.AsyncWaitOperator
-
- setup(StreamTask<?, ?>, StreamConfig, Output<StreamRecord<OUT>>) - Method in interface org.apache.flink.streaming.api.operators.StreamOperator
-
Initializes the operator.
- setupApplicationMasterContainer(String, boolean, boolean, boolean, int) - Method in class org.apache.flink.yarn.AbstractYarnClusterDescriptor
-
- setupConnectionFactory() - Method in class org.apache.flink.streaming.connectors.rabbitmq.RMQSource
-
Initializes the connection to RMQ with a default connection factory.
- setupEnvironment() - Method in class org.apache.flink.test.util.MultipleProgramsTestBase
-
- setupInputGate(SingleInputGate) - Method in class org.apache.flink.runtime.io.network.NetworkEnvironment
-
- setupPartition(ResultPartition) - Method in class org.apache.flink.runtime.io.network.NetworkEnvironment
-
- setupQueue() - Method in class org.apache.flink.streaming.connectors.rabbitmq.RMQSink
-
Sets up the queue.
- setupQueue() - Method in class org.apache.flink.streaming.connectors.rabbitmq.RMQSource
-
Sets up the queue.
- setupYarnClassPath(Configuration, Map<String, String>) - Static method in class org.apache.flink.yarn.Utils
-
- setUri(String) - Method in class org.apache.flink.streaming.connectors.rabbitmq.common.RMQConnectionConfig.Builder
-
Convenience method for setting the fields in an AMQP URI: host,
port, username, password and virtual host.
- setUseLargeRecordHandler(boolean) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setUserCodeClassLoader(ClassLoader) - Method in class org.apache.flink.api.common.typeutils.TypeSerializerConfigSnapshot
-
Set the user code class loader.
- setUserHash(String) - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- setUsername(String) - Method in class org.apache.flink.api.java.io.jdbc.JDBCAppendTableSinkBuilder
-
Specify the username of the JDBC connection.
- setUsername(String) - Method in class org.apache.flink.api.java.io.jdbc.JDBCInputFormat.JDBCInputFormatBuilder
-
- setUsername(String) - Method in class org.apache.flink.api.java.io.jdbc.JDBCOutputFormat.JDBCOutputFormatBuilder
-
- setUserName(String) - Method in class org.apache.flink.streaming.connectors.rabbitmq.common.RMQConnectionConfig.Builder
-
Set the user name.
- setUseSnapshotCompression(boolean) - Method in class org.apache.flink.api.common.ExecutionConfig
-
- setUseTruncate(boolean) - Method in class org.apache.flink.streaming.connectors.fs.bucketing.BucketingSink
-
Sets whether to use FileSystem.truncate()
to truncate written bucket files back to
a consistent state in case of a restore from checkpoint.
- setValidLengthPrefix(String) - Method in class org.apache.flink.streaming.connectors.fs.bucketing.BucketingSink
-
Sets the prefix of valid-length files.
- setValidLengthPrefix(String) - Method in class org.apache.flink.streaming.connectors.fs.RollingSink
-
Deprecated.
Sets the prefix of valid-length files.
- setValidLengthSuffix(String) - Method in class org.apache.flink.streaming.connectors.fs.bucketing.BucketingSink
-
Sets the suffix of valid-length files.
- setValidLengthSuffix(String) - Method in class org.apache.flink.streaming.connectors.fs.RollingSink
-
Deprecated.
Sets the suffix of valid-length files.
- setValue(EV) - Method in class org.apache.flink.graph.bipartite.BipartiteEdge
-
- setValue(V) - Method in class org.apache.flink.graph.Edge
-
- setValue(ValueArray<ByteValue>) - Method in class org.apache.flink.graph.types.valuearray.ByteValueArray
-
- setValue(ValueArray<CharValue>) - Method in class org.apache.flink.graph.types.valuearray.CharValueArray
-
- setValue(ValueArray<DoubleValue>) - Method in class org.apache.flink.graph.types.valuearray.DoubleValueArray
-
- setValue(ValueArray<FloatValue>) - Method in class org.apache.flink.graph.types.valuearray.FloatValueArray
-
- setValue(ValueArray<IntValue>) - Method in class org.apache.flink.graph.types.valuearray.IntValueArray
-
- setValue(ValueArray<LongValue>) - Method in class org.apache.flink.graph.types.valuearray.LongValueArray
-
- setValue(ValueArray<NullValue>) - Method in class org.apache.flink.graph.types.valuearray.NullValueArray
-
- setValue(ValueArray<ShortValue>) - Method in class org.apache.flink.graph.types.valuearray.ShortValueArray
-
- setValue(ValueArray<StringValue>) - Method in class org.apache.flink.graph.types.valuearray.StringValueArray
-
- setValue(V) - Method in class org.apache.flink.graph.Vertex
-
- setValue(byte[]) - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperSharedValue
-
- setValue(V) - Method in class org.apache.flink.streaming.connectors.fs.AvroKeyValueSinkWriter.AvroKeyValue
-
- setValue(boolean) - Method in class org.apache.flink.types.BooleanValue
-
- setValue(BooleanValue) - Method in class org.apache.flink.types.BooleanValue
-
- setValue(byte) - Method in class org.apache.flink.types.ByteValue
-
Sets the encapsulated byte to the specified value.
- setValue(ByteValue) - Method in class org.apache.flink.types.ByteValue
-
- setValue(char) - Method in class org.apache.flink.types.CharValue
-
Sets the encapsulated char to the specified value.
- setValue(CharValue) - Method in class org.apache.flink.types.CharValue
-
- setValue(double) - Method in class org.apache.flink.types.DoubleValue
-
Sets the value of the encapsulated primitive double.
- setValue(DoubleValue) - Method in class org.apache.flink.types.DoubleValue
-
- setValue(L) - Method in class org.apache.flink.types.Either.Left
-
Sets the encapsulated value to another value
- setValue(R) - Method in class org.apache.flink.types.Either.Right
-
Sets the encapsulated value to another value
- setValue(float) - Method in class org.apache.flink.types.FloatValue
-
Sets the value of the encapsulated primitive float.
- setValue(FloatValue) - Method in class org.apache.flink.types.FloatValue
-
- setValue(int) - Method in class org.apache.flink.types.IntValue
-
Sets the encapsulated int to the specified value.
- setValue(IntValue) - Method in class org.apache.flink.types.IntValue
-
- setValue(long) - Method in class org.apache.flink.types.LongValue
-
Sets the value of the encapsulated long to the specified value.
- setValue(LongValue) - Method in class org.apache.flink.types.LongValue
-
- setValue(T) - Method in interface org.apache.flink.types.ResettableValue
-
Sets the encapsulated value to another value
- setValue(short) - Method in class org.apache.flink.types.ShortValue
-
Sets the encapsulated short to the specified value.
- setValue(ShortValue) - Method in class org.apache.flink.types.ShortValue
-
- setValue(CharSequence) - Method in class org.apache.flink.types.StringValue
-
Sets the value of the StringValue to the given string.
- setValue(StringValue) - Method in class org.apache.flink.types.StringValue
-
Sets the value of the StringValue to the given string.
- setValue(StringValue, int, int) - Method in class org.apache.flink.types.StringValue
-
Sets the value of the StringValue to a substring of the given string.
- setValue(CharSequence, int, int) - Method in class org.apache.flink.types.StringValue
-
Sets the value of the StringValue to a substring of the given string.
- setValue(CharBuffer) - Method in class org.apache.flink.types.StringValue
-
Sets the contents of this string to the contents of the given CharBuffer.
- setValue(char[], int, int) - Method in class org.apache.flink.types.StringValue
-
Sets the value of the StringValue to a substring of the given value.
- setValueAscii(byte[], int, int) - Method in class org.apache.flink.types.StringValue
-
Sets the value of this StringValue
, assuming that the binary data is ASCII coded.
- setVerbose(boolean) - Method in class org.apache.flink.api.java.JarHelper
-
- setVertexGroupCount(Long) - Method in class org.apache.flink.graph.library.Summarization.VertexGroupItem
-
- setVertexGroupCount(Long) - Method in class org.apache.flink.graph.library.Summarization.VertexValue
-
- setVertexGroupValue(VGV) - Method in class org.apache.flink.graph.library.Summarization.VertexGroupItem
-
- setVertexGroupValue(VV) - Method in class org.apache.flink.graph.library.Summarization.VertexValue
-
- setVertexId(K) - Method in class org.apache.flink.graph.library.Summarization.VertexGroupItem
-
- setVertexId(K) - Method in class org.apache.flink.graph.library.Summarization.VertexWithRepresentative
-
- setVertexID(Integer) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- setVertexId0(K) - Method in interface org.apache.flink.graph.asm.result.BinaryResult
-
Set the first vertex ID.
- setVertexId0(K) - Method in class org.apache.flink.graph.asm.result.BinaryResultBase
-
- setVertexId0(K) - Method in interface org.apache.flink.graph.asm.result.TertiaryResult
-
Set the first vertex ID.
- setVertexId0(K) - Method in class org.apache.flink.graph.asm.result.TertiaryResultBase
-
- setVertexId0(K) - Method in interface org.apache.flink.graph.asm.result.UnaryResult
-
Set the first vertex ID.
- setVertexId0(K) - Method in class org.apache.flink.graph.asm.result.UnaryResultBase
-
- setVertexId1(K) - Method in interface org.apache.flink.graph.asm.result.BinaryResult
-
Set the second vertex ID.
- setVertexId1(K) - Method in class org.apache.flink.graph.asm.result.BinaryResultBase
-
- setVertexId1(K) - Method in interface org.apache.flink.graph.asm.result.TertiaryResult
-
Set the second vertex ID.
- setVertexId1(K) - Method in class org.apache.flink.graph.asm.result.TertiaryResultBase
-
- setVertexId2(K) - Method in interface org.apache.flink.graph.asm.result.TertiaryResult
-
Set the third vertex ID.
- setVertexId2(K) - Method in class org.apache.flink.graph.asm.result.TertiaryResultBase
-
- setVirtualHost(String) - Method in class org.apache.flink.streaming.connectors.rabbitmq.common.RMQConnectionConfig.Builder
-
Set the virtual host.
- setWaitForSolutionSetUpdate() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setWebUIPort(int) - Method in class org.apache.flink.runtime.jobmanager.JobManagerCliOptions
-
- setWord(String) - Method in class org.apache.flink.examples.java.wordcount.WordCountPojo.Word
-
- setWord(String) - Method in class org.apache.flink.streaming.examples.kafka.KafkaEvent
-
- SetWorkerPoolSize - Class in org.apache.flink.runtime.clusterframework.messages
-
Message sent to the resource master actor to adjust the designated number of
workers it maintains.
- SetWorkerPoolSize(int) - Constructor for class org.apache.flink.runtime.clusterframework.messages.SetWorkerPoolSize
-
- setWorksetSerializer(TypeSerializerFactory<?>) - Method in class org.apache.flink.optimizer.plan.WorksetIterationPlanNode
-
- setWriteMode(FileSystem.WriteMode) - Method in class org.apache.flink.api.common.io.FileOutputFormat
-
- setWritePosition(long) - Method in interface org.apache.flink.core.memory.SeekableDataOutputView
-
Sets the write pointer to the given position.
- setWritePosition(long) - Method in class org.apache.flink.runtime.io.disk.RandomAccessOutputView
-
- setWriter(Writer<T>) - Method in class org.apache.flink.streaming.connectors.fs.bucketing.BucketingSink
-
Sets the
Writer
to be used for writing the incoming elements to bucket files.
- setWriter(Writer<T>) - Method in class org.apache.flink.streaming.connectors.fs.RollingSink
-
Deprecated.
Sets the
Writer
to be used for writing the incoming elements to bucket files.
- setWriteTimestampToKafka(boolean) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer010.FlinkKafkaProducer010Configuration
-
Deprecated.
If set to true, Flink will write the (event time) timestamp attached to each record into Kafka.
- setWriteTimestampToKafka(boolean) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer010
-
If set to true, Flink will write the (event time) timestamp attached to each record into Kafka.
- setWriteTimestampToKafka(boolean) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer011
-
If set to true, Flink will write the (event time) timestamp attached to each record into Kafka.
- setZookeeperNamespace(String) - Method in class org.apache.flink.yarn.AbstractYarnClusterDescriptor
-
- SharedBuffer<K extends Serializable,V> - Class in org.apache.flink.cep.nfa
-
A shared buffer implementation which stores values under a key.
- SharedBuffer() - Constructor for class org.apache.flink.cep.nfa.SharedBuffer
-
- SharedBuffer.SharedBufferSerializer<K extends Serializable,V> - Class in org.apache.flink.cep.nfa
-
- SharedBuffer.SharedBufferSerializerConfigSnapshot<K,V> - Class in org.apache.flink.cep.nfa
-
- SharedBufferSerializer(TypeSerializer<K>, TypeSerializer<V>) - Constructor for class org.apache.flink.cep.nfa.SharedBuffer.SharedBufferSerializer
-
- SharedBufferSerializer(TypeSerializer<K>, TypeSerializer<V>, TypeSerializer<DeweyNumber>) - Constructor for class org.apache.flink.cep.nfa.SharedBuffer.SharedBufferSerializer
-
- SharedBufferSerializerConfigSnapshot() - Constructor for class org.apache.flink.cep.nfa.SharedBuffer.SharedBufferSerializerConfigSnapshot
-
This empty constructor is required for deserializing the configuration.
- SharedBufferSerializerConfigSnapshot(TypeSerializer<K>, TypeSerializer<V>, TypeSerializer<DeweyNumber>) - Constructor for class org.apache.flink.cep.nfa.SharedBuffer.SharedBufferSerializerConfigSnapshot
-
- SharedSlot - Class in org.apache.flink.runtime.instance
-
This class represents a shared slot.
- SharedSlot(SlotOwner, TaskManagerLocation, int, TaskManagerGateway, SlotSharingGroupAssignment) - Constructor for class org.apache.flink.runtime.instance.SharedSlot
-
Creates a new shared slot that has no parent (is a root slot) and does not belong to any task group.
- SharedSlot(SlotOwner, TaskManagerLocation, int, TaskManagerGateway, SlotSharingGroupAssignment, SharedSlot, AbstractID) - Constructor for class org.apache.flink.runtime.instance.SharedSlot
-
Creates a new shared slot that has is a sub-slot of the given parent shared slot, and that belongs
to the given task group.
- SharedSlot(SlotContext, SlotOwner, SlotSharingGroupAssignment) - Constructor for class org.apache.flink.runtime.instance.SharedSlot
-
Creates a new shared slot that has no parent (is a root slot) and does not belong to any task group.
- SharedStateRegistry - Class in org.apache.flink.runtime.state
-
This registry manages state that is shared across (incremental) checkpoints, and is responsible
for deleting shared state that is no longer used in any valid checkpoint.
- SharedStateRegistry() - Constructor for class org.apache.flink.runtime.state.SharedStateRegistry
-
Default uses direct executor to delete unreferenced state
- SharedStateRegistry(Executor) - Constructor for class org.apache.flink.runtime.state.SharedStateRegistry
-
- SharedStateRegistry.Result - Class in org.apache.flink.runtime.state
-
The result of an attempt to (un)/reference state
- SharedStateRegistryFactory - Interface in org.apache.flink.runtime.state
-
- SharedStateRegistryKey - Class in org.apache.flink.runtime.state
-
This class represents a key that uniquely identifies (on a logical level) state handles for
registration in the
SharedStateRegistry
.
- SharedStateRegistryKey(String, StateHandleID) - Constructor for class org.apache.flink.runtime.state.SharedStateRegistryKey
-
- SharedStateRegistryKey(String) - Constructor for class org.apache.flink.runtime.state.SharedStateRegistryKey
-
- SHIP_STRATEGY - Static variable in class org.apache.flink.streaming.api.graph.JSONGenerator
-
- shipFiles - Variable in class org.apache.flink.yarn.AbstractYarnClusterDescriptor
-
Lazily initialized list of files to ship.
- ShipStrategyType - Enum in org.apache.flink.runtime.operators.shipping
-
Enumeration defining the different shipping types of the output, such as local forward, re-partitioning by hash,
or re-partitioning by range.
- SHORT - Static variable in class org.apache.flink.api.common.typeinfo.Types
-
Returns type information for both a primitive
short
and
Short
.
- SHORT_ARRAY_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
-
- SHORT_PRIMITIVE_ARRAY_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
-
- SHORT_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
-
- SHORT_VALUE_TYPE_INFO - Static variable in class org.apache.flink.api.java.typeutils.ValueTypeInfo
-
- ShortComparator - Class in org.apache.flink.api.common.typeutils.base
-
- ShortComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.ShortComparator
-
- ShortParser - Class in org.apache.flink.types.parser
-
Parses a decimal text field into a
Short
.
- ShortParser() - Constructor for class org.apache.flink.types.parser.ShortParser
-
- ShortPrimitiveArrayComparator - Class in org.apache.flink.api.common.typeutils.base.array
-
- ShortPrimitiveArrayComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.array.ShortPrimitiveArrayComparator
-
- ShortPrimitiveArraySerializer - Class in org.apache.flink.api.common.typeutils.base.array
-
A serializer for short arrays.
- ShortPrimitiveArraySerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.array.ShortPrimitiveArraySerializer
-
- ShortSerializer - Class in org.apache.flink.api.common.typeutils.base
-
- ShortSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.ShortSerializer
-
- ShortSummaryAggregator - Class in org.apache.flink.api.java.summarize.aggregation
-
Aggregator that can handle Short types.
- ShortSummaryAggregator() - Constructor for class org.apache.flink.api.java.summarize.aggregation.ShortSummaryAggregator
-
- ShortSummaryAggregator.MaxShortAggregator - Class in org.apache.flink.api.java.summarize.aggregation
-
Aggregator for max operation.
- ShortSummaryAggregator.MinShortAggregator - Class in org.apache.flink.api.java.summarize.aggregation
-
Aggregator for min operation.
- ShortSummaryAggregator.SumShortAggregator - Class in org.apache.flink.api.java.summarize.aggregation
-
Aggregator for sum operation.
- ShortValue - Class in org.apache.flink.types
-
Boxed serializable and comparable short integer type, representing the primitive
type short
.
- ShortValue() - Constructor for class org.apache.flink.types.ShortValue
-
Initializes the encapsulated short with 0.
- ShortValue(short) - Constructor for class org.apache.flink.types.ShortValue
-
Initializes the encapsulated short with the provided value.
- ShortValueArray - Class in org.apache.flink.graph.types.valuearray
-
- ShortValueArray() - Constructor for class org.apache.flink.graph.types.valuearray.ShortValueArray
-
Initializes an expandable array with default capacity.
- ShortValueArray(int) - Constructor for class org.apache.flink.graph.types.valuearray.ShortValueArray
-
Initializes a fixed-size array with the provided number of shorts.
- ShortValueArrayComparator - Class in org.apache.flink.graph.types.valuearray
-
Specialized comparator for ShortValueArray based on CopyableValueComparator.
- ShortValueArrayComparator(boolean) - Constructor for class org.apache.flink.graph.types.valuearray.ShortValueArrayComparator
-
- ShortValueArraySerializer - Class in org.apache.flink.graph.types.valuearray
-
Specialized serializer for ShortValueArray
.
- ShortValueArraySerializer() - Constructor for class org.apache.flink.graph.types.valuearray.ShortValueArraySerializer
-
- ShortValueComparator - Class in org.apache.flink.api.common.typeutils.base
-
Specialized comparator for ShortValue based on CopyableValueComparator.
- ShortValueComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.ShortValueComparator
-
- ShortValueParser - Class in org.apache.flink.types.parser
-
- ShortValueParser() - Constructor for class org.apache.flink.types.parser.ShortValueParser
-
- ShortValueSerializer - Class in org.apache.flink.api.common.typeutils.base
-
- ShortValueSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.ShortValueSerializer
-
- ShortValueSummaryAggregator() - Constructor for class org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator.ShortValueSummaryAggregator
-
- shouldAutocastTo(BasicTypeInfo<?>) - Method in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
-
Returns whether this type should be automatically casted to
the target type in an arithmetic operation.
- shouldExitJvmOnOutOfMemoryError() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
-
- shouldExitJvmOnOutOfMemoryError() - Method in interface org.apache.flink.runtime.taskmanager.TaskManagerRuntimeInfo
-
Checks whether the TaskManager should exit the JVM when the task thread throws
an OutOfMemoryError.
- shouldIncludeFinished() - Method in class org.apache.flink.runtime.messages.webmonitor.RequestJobDetails
-
- shouldIncludeRunning() - Method in class org.apache.flink.runtime.messages.webmonitor.RequestJobDetails
-
- shouldStartNewBucket(Path, Path) - Method in interface org.apache.flink.streaming.connectors.fs.Bucketer
-
Deprecated.
Returns true
when a new bucket should be started.
- shouldStartNewBucket(Path, Path) - Method in class org.apache.flink.streaming.connectors.fs.DateTimeBucketer
-
Deprecated.
- shouldStartNewBucket(Path, Path) - Method in class org.apache.flink.streaming.connectors.fs.NonRollingBucketer
-
Deprecated.
- showControlCharacters(String) - Static method in class org.apache.flink.util.StringUtils
-
Replaces control characters by their escape-coded version.
- shuffle() - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Sets the partitioning of the
DataStream
so that the output elements
are shuffled uniformly randomly to the next operation.
- ShufflePartitioner<T> - Class in org.apache.flink.streaming.runtime.partitioner
-
Partitioner that distributes the data equally by selecting one output channel
randomly.
- ShufflePartitioner() - Constructor for class org.apache.flink.streaming.runtime.partitioner.ShufflePartitioner
-
- shutdown() - Method in class org.apache.flink.client.program.ClusterClient.LazyActorSystemLoader
-
- shutdown() - Method in class org.apache.flink.client.program.ClusterClient
-
Shuts down the client.
- shutdown() - Method in class org.apache.flink.client.program.MiniClusterClient
-
- shutdown() - Method in class org.apache.flink.client.program.rest.RestClusterClient
-
- shutdown() - Method in class org.apache.flink.queryablestate.client.proxy.KvStateClientProxyHandler
-
- shutdown() - Method in class org.apache.flink.queryablestate.client.proxy.KvStateClientProxyImpl
-
- shutdown() - Method in class org.apache.flink.queryablestate.network.AbstractServerHandler
-
Shuts down any handler-specific resources, e.g.
- shutdown() - Method in class org.apache.flink.queryablestate.network.Client
-
Shuts down the client and closes all connections.
- shutdown() - Method in class org.apache.flink.queryablestate.server.KvStateServerHandler
-
- shutdown() - Method in class org.apache.flink.queryablestate.server.KvStateServerImpl
-
- shutdown(JobStatus) - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
Shuts down the checkpoint coordinator.
- shutdown(JobStatus) - Method in interface org.apache.flink.runtime.checkpoint.CheckpointIDCounter
-
- shutdown(JobStatus) - Method in interface org.apache.flink.runtime.checkpoint.CompletedCheckpointStore
-
Shuts down the store.
- shutdown(JobStatus) - Method in class org.apache.flink.runtime.checkpoint.StandaloneCheckpointIDCounter
-
- shutdown(JobStatus) - Method in class org.apache.flink.runtime.checkpoint.StandaloneCompletedCheckpointStore
-
- shutdown(JobStatus) - Method in class org.apache.flink.runtime.checkpoint.ZooKeeperCheckpointIDCounter
-
- shutdown(JobStatus) - Method in class org.apache.flink.runtime.checkpoint.ZooKeeperCompletedCheckpointStore
-
- shutdown() - Method in class org.apache.flink.runtime.execution.librarycache.BlobLibraryCacheManager
-
- shutdown() - Method in interface org.apache.flink.runtime.execution.librarycache.LibraryCacheManager
-
Shutdown method which may release created class loaders.
- shutdown() - Method in class org.apache.flink.runtime.filecache.FileCache
-
Shuts down the file cache by cancelling all.
- shutdown() - Method in class org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedLeaderService
-
Shuts down this leader election service.
- shutdown() - Method in class org.apache.flink.runtime.highavailability.nonha.leaderelection.SingleLeaderElectionService
-
- shutdown() - Method in class org.apache.flink.runtime.instance.InstanceManager
-
- shutdown() - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManager
-
Close method, marks the I/O manager as closed
and removed all temporary files.
- shutdown() - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManagerAsync
-
Close method.
- shutdown() - Method in interface org.apache.flink.runtime.io.network.ConnectionManager
-
- shutdown() - Method in class org.apache.flink.runtime.io.network.LocalConnectionManager
-
- shutdown() - Method in class org.apache.flink.runtime.io.network.netty.NettyConnectionManager
-
- shutdown() - Method in class org.apache.flink.runtime.io.network.NetworkEnvironment
-
Tries to shut down all network I/O components.
- shutdown() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartitionManager
-
- shutdown() - Method in class org.apache.flink.runtime.jobmanager.scheduler.Scheduler
-
Shuts the scheduler down.
- shutdown() - Method in class org.apache.flink.runtime.jobmaster.JobManagerSharedServices
-
- shutdown() - Method in class org.apache.flink.runtime.memory.MemoryManager
-
Shuts the memory manager down, trying to release all the memory it managed.
- shutdown() - Method in class org.apache.flink.runtime.metrics.MetricRegistryImpl
-
- shutdown() - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.ThreadBase
-
Forces an immediate shutdown of the thread.
- shutdown() - Method in interface org.apache.flink.runtime.query.KvStateServer
-
Shuts down the server and all related thread pools.
- shutDown() - Method in interface org.apache.flink.runtime.rest.handler.legacy.backpressure.BackPressureStatsTracker
-
Shuts the BackPressureStatsTracker down.
- shutDown() - Method in class org.apache.flink.runtime.rest.handler.legacy.backpressure.BackPressureStatsTrackerImpl
-
Shuts down the stats tracker.
- shutDown() - Method in class org.apache.flink.runtime.rest.handler.legacy.backpressure.StackTraceSampleCoordinator
-
Shuts down the coordinator.
- shutdown(Time) - Method in class org.apache.flink.runtime.rest.RestClient
-
- shutDown() - Method in class org.apache.flink.runtime.rpc.RpcEndpoint
-
Triggers the shut down of the rpc endpoint.
- shutdown() - Method in class org.apache.flink.runtime.state.TaskExecutorLocalStateStoresManager
-
- shutDown() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServices
-
- shutdown() - Method in class org.apache.flink.runtime.taskmanager.MemoryLogger
-
- shutdown() - Method in class org.apache.flink.runtime.webmonitor.utils.WebFrontendBootstrap
-
- shutdown() - Method in class org.apache.flink.storm.api.FlinkLocalCluster
-
- shutdown() - Method in class org.apache.flink.streaming.connectors.kafka.internal.KafkaConsumerThread
-
Shuts this thread down, waking up the thread gracefully if blocked (without Thread.interrupt() calls).
- shutdown() - Method in class org.apache.flink.streaming.connectors.kafka.internals.PeriodicOffsetCommitter
-
- SHUTDOWN_IF_ATTACHED_OPTION - Static variable in class org.apache.flink.client.cli.CliFrontendParser
-
- shutdownAndAwaitPending(long, TimeUnit) - Method in class org.apache.flink.streaming.runtime.tasks.ProcessingTimeService
-
Shuts down and clean up the timer service provider hard and immediately.
- shutdownAndAwaitPending(long, TimeUnit) - Method in class org.apache.flink.streaming.runtime.tasks.SystemProcessingTimeService
-
- shutdownAndAwaitPending(long, TimeUnit) - Method in class org.apache.flink.streaming.runtime.tasks.TestProcessingTimeService
-
- shutdownAndHandle() - Method in class org.apache.flink.queryablestate.client.QueryableStateClient
-
Shuts down the client and returns a
CompletableFuture
that
will be completed when the shutdown process is completed.
- shutDownAndTerminate(int, ApplicationStatus, String, boolean) - Method in class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
-
- shutdownAndWait() - Method in class org.apache.flink.queryablestate.client.QueryableStateClient
-
Shuts down the client and waits until shutdown is completed.
- shutdownApplication(ApplicationStatus, String) - Method in class org.apache.flink.mesos.runtime.clusterframework.MesosFlinkResourceManager
-
Called to shut down the cluster (not a failover situation).
- shutdownApplication(ApplicationStatus, String) - Method in class org.apache.flink.runtime.clusterframework.FlinkResourceManager
-
The framework specific code for shutting down the application.
- shutdownApplication(ApplicationStatus, String) - Method in class org.apache.flink.runtime.clusterframework.standalone.StandaloneResourceManager
-
- shutdownApplication(ApplicationStatus, String) - Method in class org.apache.flink.yarn.YarnFlinkResourceManager
-
- shutDownCluster() - Method in class org.apache.flink.client.program.ClusterClient
-
- shutDownCluster() - Method in class org.apache.flink.client.program.rest.RestClusterClient
-
- shutDownCluster() - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
-
- shutDownCluster() - Method in interface org.apache.flink.runtime.webmonitor.RestfulGateway
-
- shutDownCluster() - Method in class org.apache.flink.yarn.YarnClusterClient
-
- ShutdownClusterAfterJob - Class in org.apache.flink.runtime.clusterframework.messages
-
Message sent to the cluster framework master to signal it that the cluster
should be shut down upon completion of a certain job identified by a job id.
- ShutdownClusterAfterJob(JobID) - Constructor for class org.apache.flink.runtime.clusterframework.messages.ShutdownClusterAfterJob
-
- ShutdownHandler - Class in org.apache.flink.runtime.rest.handler.cluster
-
REST handler which allows to shut down the cluster.
- ShutdownHandler(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MessageHeaders<EmptyRequestBody, EmptyResponseBody, EmptyMessageParameters>) - Constructor for class org.apache.flink.runtime.rest.handler.cluster.ShutdownHandler
-
- ShutdownHeaders - Class in org.apache.flink.runtime.rest.messages.cluster
-
- ShutdownHeaders() - Constructor for class org.apache.flink.runtime.rest.messages.cluster.ShutdownHeaders
-
- shutdownHook - Variable in class org.apache.flink.runtime.blob.AbstractBlobCache
-
Shutdown hook thread to ensure deletion of the local storage directory.
- ShutdownHookUtil - Class in org.apache.flink.util
-
Utils class for dealing with JVM shutdown hooks.
- shutDownInternal() - Method in class org.apache.flink.runtime.dispatcher.DispatcherRestEndpoint
-
- shutDownInternal() - Method in class org.apache.flink.runtime.rest.RestServerEndpoint
-
Stops this REST server endpoint.
- shutDownInternal() - Method in class org.apache.flink.runtime.webmonitor.WebMonitorEndpoint
-
- shutdownRequested - Variable in class org.apache.flink.runtime.blob.AbstractBlobCache
-
- shutdownServer() - Method in class org.apache.flink.queryablestate.network.AbstractServerBase
-
Shuts down the server and all related thread pools.
- shutdownService() - Method in class org.apache.flink.streaming.runtime.tasks.ProcessingTimeService
-
Shuts down and clean up the timer service provider hard and immediately.
- shutdownService() - Method in class org.apache.flink.streaming.runtime.tasks.SystemProcessingTimeService
-
- shutdownService() - Method in class org.apache.flink.streaming.runtime.tasks.TestProcessingTimeService
-
- shutdownServiceUninterruptible(long) - Method in class org.apache.flink.streaming.runtime.tasks.ProcessingTimeService
-
Shuts down and clean up the timer service provider hard and immediately.
- shutdownServiceUninterruptible(long) - Method in class org.apache.flink.streaming.runtime.tasks.SystemProcessingTimeService
-
- shutdownServiceUninterruptible(long) - Method in class org.apache.flink.streaming.runtime.tasks.TestProcessingTimeService
-
- SIDE - Static variable in class org.apache.flink.streaming.api.graph.JSONGenerator
-
- sideOutput(StreamRecord<IN>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
Write skipped late arriving element to SideOutput.
- SideOutputExample - Class in org.apache.flink.streaming.examples.sideoutput
-
An example that illustrates the use of side outputs.
- SideOutputExample() - Constructor for class org.apache.flink.streaming.examples.sideoutput.SideOutputExample
-
- SideOutputExample.Tokenizer - Class in org.apache.flink.streaming.examples.sideoutput
-
Implements the string tokenizer that splits sentences into words as a
user-defined FlatMapFunction.
- sideOutputLateData(OutputTag<T>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Send late arriving data to the side output identified by the given
OutputTag
.
- sideOutputLateData(OutputTag<T>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Send late arriving data to the side output identified by the given
OutputTag
.
- SideOutputTransformation<T> - Class in org.apache.flink.streaming.api.transformations
-
This transformation represents a selection of a side output of an upstream operation with a
given
OutputTag
.
- SideOutputTransformation(StreamTransformation<?>, OutputTag<T>) - Constructor for class org.apache.flink.streaming.api.transformations.SideOutputTransformation
-
- SIGNAL_BUFFER_REQUEST - Static variable in class org.apache.flink.python.api.streaming.data.PythonStreamer
-
- SIGNAL_BUFFER_REQUEST_G0 - Static variable in class org.apache.flink.python.api.streaming.data.PythonStreamer
-
- SIGNAL_BUFFER_REQUEST_G1 - Static variable in class org.apache.flink.python.api.streaming.data.PythonStreamer
-
- SIGNAL_ERROR - Static variable in class org.apache.flink.python.api.streaming.data.PythonStreamer
-
- SIGNAL_FINISHED - Static variable in class org.apache.flink.python.api.streaming.data.PythonStreamer
-
- SIGNAL_LAST - Static variable in class org.apache.flink.python.api.streaming.data.PythonStreamer
-
- SignalHandler - Class in org.apache.flink.runtime.util
-
This signal handler / signal logger is based on Apache Hadoop's org.apache.hadoop.util.SignalLogger.
- SignalHandler() - Constructor for class org.apache.flink.runtime.util.SignalHandler
-
- signalTermination() - Method in class org.apache.flink.runtime.iterative.concurrent.SuperstepKickoffLatch
-
- SignatureVisitorImpl(int) - Constructor for class org.apache.flink.runtime.util.DependencyVisitor.SignatureVisitorImpl
-
- SimpleAccumulator<T extends Serializable> - Interface in org.apache.flink.api.common.accumulators
-
Similar to Accumulator, but the type of items to add and the result value
must be the same.
- SimpleCloseableInputProvider<E> - Class in org.apache.flink.runtime.operators.util
-
A simple iterator provider that returns a supplied iterator and does nothing when closed.
- SimpleCloseableInputProvider(MutableObjectIterator<E>) - Constructor for class org.apache.flink.runtime.operators.util.SimpleCloseableInputProvider
-
Creates a new simple input provider that will return the given iterator.
- SimpleCollectingOutputView - Class in org.apache.flink.runtime.io.disk
-
The list with the full segments contains at any point all completely full segments, plus the segment that is
currently filled.
- SimpleCollectingOutputView(List<MemorySegment>, MemorySegmentSource, int) - Constructor for class org.apache.flink.runtime.io.disk.SimpleCollectingOutputView
-
- SimpleCondition<T> - Class in org.apache.flink.cep.pattern.conditions
-
A user-defined condition that decides if an element should be accepted in the pattern or not.
- SimpleCondition() - Constructor for class org.apache.flink.cep.pattern.conditions.SimpleCondition
-
- SimpleCounter - Class in org.apache.flink.metrics
-
A simple low-overhead
Counter
that is not thread-safe.
- SimpleCounter() - Constructor for class org.apache.flink.metrics.SimpleCounter
-
- SimpleIterable(IN, MutableObjectIterator<IN>) - Constructor for class org.apache.flink.runtime.operators.CoGroupRawDriver.SimpleIterable
-
- SimpleIterator(IN, MutableObjectIterator<IN>) - Constructor for class org.apache.flink.runtime.operators.CoGroupRawDriver.SimpleIterable.SimpleIterator
-
- SimpleListIterable(List<IN>, TypeComparator<IN>, TypeSerializer<IN>) - Constructor for class org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase.SimpleListIterable
-
- SimpleListIterator(List<IN>, TypeSerializer<IN>) - Constructor for class org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase.SimpleListIterable.SimpleListIterator
-
- SimpleOutputFormatter - Class in org.apache.flink.storm.util
-
- SimpleOutputFormatter() - Constructor for class org.apache.flink.storm.util.SimpleOutputFormatter
-
- SimpleParameter<T> - Class in org.apache.flink.graph.drivers.parameter
-
- SimpleParameter(ParameterizedBase, String) - Constructor for class org.apache.flink.graph.drivers.parameter.SimpleParameter
-
Set the parameter name and add this parameter to the list of parameters
stored by owner.
- SimpleSlot - Class in org.apache.flink.runtime.instance
-
A SimpleSlot represents a single slot on a TaskManager instance, or a slot within a shared slot.
- SimpleSlot(SlotOwner, TaskManagerLocation, int, TaskManagerGateway) - Constructor for class org.apache.flink.runtime.instance.SimpleSlot
-
Creates a new simple slot that stands alone and does not belong to shared slot.
- SimpleSlot(SlotOwner, TaskManagerLocation, int, TaskManagerGateway, SharedSlot, AbstractID) - Constructor for class org.apache.flink.runtime.instance.SimpleSlot
-
Creates a new simple slot that belongs to the given shared slot and
is identified by the given ID.
- SimpleSlot(SlotContext, SlotOwner, int) - Constructor for class org.apache.flink.runtime.instance.SimpleSlot
-
Creates a new simple slot that stands alone and does not belong to shared slot.
- SimpleSlot(SharedSlot, SlotOwner, int, AbstractID) - Constructor for class org.apache.flink.runtime.instance.SimpleSlot
-
Creates a new simple slot that belongs to the given shared slot and
is identified by the given ID..
- SimpleSlotContext - Class in org.apache.flink.runtime.instance
-
Simple implementation of the
SlotContext
interface for the legacy code.
- SimpleSlotContext(AllocationID, TaskManagerLocation, int, TaskManagerGateway) - Constructor for class org.apache.flink.runtime.instance.SimpleSlotContext
-
- SimpleStringSchema - Class in org.apache.flink.api.common.serialization
-
Very simple serialization schema for strings.
- SimpleStringSchema() - Constructor for class org.apache.flink.api.common.serialization.SimpleStringSchema
-
Creates a new SimpleStringSchema that uses "UTF-8" as the encoding.
- SimpleStringSchema(Charset) - Constructor for class org.apache.flink.api.common.serialization.SimpleStringSchema
-
Creates a new SimpleStringSchema that uses the given charset to convert between strings and bytes.
- SimpleStringSchema - Class in org.apache.flink.streaming.util.serialization
-
- SimpleStringSchema() - Constructor for class org.apache.flink.streaming.util.serialization.SimpleStringSchema
-
Deprecated.
- SimpleStringSchema(Charset) - Constructor for class org.apache.flink.streaming.util.serialization.SimpleStringSchema
-
Deprecated.
Creates a new SimpleStringSchema that uses the given charset to convert between strings and bytes.
- SimpleTimerService - Class in org.apache.flink.streaming.api
-
- SimpleTimerService(InternalTimerService<VoidNamespace>) - Constructor for class org.apache.flink.streaming.api.SimpleTimerService
-
- SimpleVersionedSerializer<E> - Interface in org.apache.flink.core.io
-
A simple serializer interface for versioned serialization.
- Simplify<K extends Comparable<K>,VV,EV> - Class in org.apache.flink.graph.asm.simple.directed
-
Remove self-loops and duplicate edges from a directed graph.
- Simplify() - Constructor for class org.apache.flink.graph.asm.simple.directed.Simplify
-
- Simplify<K extends Comparable<K>,VV,EV> - Class in org.apache.flink.graph.asm.simple.undirected
-
Add symmetric edges and remove self-loops and duplicate edges from an
undirected graph.
- Simplify(boolean) - Constructor for class org.apache.flink.graph.asm.simple.undirected.Simplify
-
Simplifies an undirected graph by adding reverse edges and removing
self-loops and duplicate edges.
- Simplify - Class in org.apache.flink.graph.drivers.parameter
-
A simple graph has no self-loops (edges where the source and target vertices
are the same) and no duplicate edges.
- Simplify(ParameterizedBase) - Constructor for class org.apache.flink.graph.drivers.parameter.Simplify
-
Add this parameter to the list of parameters stored by owner.
- simplify(Graph<T, NullValue, NullValue>, int) - Method in class org.apache.flink.graph.drivers.parameter.Simplify
-
Simplify the given graph based on the configured value.
- Simplify.Ordering - Enum in org.apache.flink.graph.drivers.parameter
-
Whether and how to simplify the graph.
- SingleElementIterator<E> - Class in org.apache.flink.runtime.util
-
An
Iterator
that contains only a single element.
- SingleElementIterator() - Constructor for class org.apache.flink.runtime.util.SingleElementIterator
-
- SingleInputGate - Class in org.apache.flink.runtime.io.network.partition.consumer
-
An input gate consumes one or more partitions of a single produced intermediate result.
- SingleInputGate(String, JobID, IntermediateDataSetID, ResultPartitionType, int, int, TaskActions, TaskIOMetricGroup, boolean) - Constructor for class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
-
- SingleInputNode - Class in org.apache.flink.optimizer.dag
-
A node in the optimizer's program representation for an operation with a single input.
- SingleInputNode(SingleInputOperator<?, ?, ?>) - Constructor for class org.apache.flink.optimizer.dag.SingleInputNode
-
Creates a new node with a single input for the optimizer plan.
- SingleInputNode(FieldSet) - Constructor for class org.apache.flink.optimizer.dag.SingleInputNode
-
- SingleInputNode() - Constructor for class org.apache.flink.optimizer.dag.SingleInputNode
-
- SingleInputNode(SingleInputNode) - Constructor for class org.apache.flink.optimizer.dag.SingleInputNode
-
- SingleInputOperator<IN,OUT,FT extends Function> - Class in org.apache.flink.api.common.operators
-
Abstract superclass for for all operators that have one input like "map" or "reduce".
- SingleInputOperator(UserCodeWrapper<FT>, UnaryOperatorInformation<IN, OUT>, int[], String) - Constructor for class org.apache.flink.api.common.operators.SingleInputOperator
-
Creates a new abstract single-input operator with the given name wrapping the given user function.
- SingleInputOperator(UserCodeWrapper<FT>, UnaryOperatorInformation<IN, OUT>, String) - Constructor for class org.apache.flink.api.common.operators.SingleInputOperator
-
Creates a new abstract single-input operator with the given name wrapping the given user function.
- SingleInputOperator<IN,OUT,O extends SingleInputOperator<IN,OUT,O>> - Class in org.apache.flink.api.java.operators
-
Base class for operations that operates on a single input data set.
- SingleInputOperator(DataSet<IN>, TypeInformation<OUT>) - Constructor for class org.apache.flink.api.java.operators.SingleInputOperator
-
- SingleInputPlanNode - Class in org.apache.flink.optimizer.plan
-
- SingleInputPlanNode(OptimizerNode, String, Channel, DriverStrategy) - Constructor for class org.apache.flink.optimizer.plan.SingleInputPlanNode
-
- SingleInputPlanNode(OptimizerNode, String, Channel, DriverStrategy, FieldList) - Constructor for class org.apache.flink.optimizer.plan.SingleInputPlanNode
-
- SingleInputPlanNode(OptimizerNode, String, Channel, DriverStrategy, FieldList, boolean[]) - Constructor for class org.apache.flink.optimizer.plan.SingleInputPlanNode
-
- SingleInputSemanticProperties - Class in org.apache.flink.api.common.operators
-
Container for the semantic properties associated to a single input operator.
- SingleInputSemanticProperties() - Constructor for class org.apache.flink.api.common.operators.SingleInputSemanticProperties
-
- SingleInputSemanticProperties.AllFieldsForwardedProperties - Class in org.apache.flink.api.common.operators
-
- SingleInputUdfOperator<IN,OUT,O extends SingleInputUdfOperator<IN,OUT,O>> - Class in org.apache.flink.api.java.operators
-
The SingleInputUdfOperator is the base class of all unary operators that execute
user-defined functions (UDFs).
- SingleInputUdfOperator(DataSet<IN>, TypeInformation<OUT>) - Constructor for class org.apache.flink.api.java.operators.SingleInputUdfOperator
-
Creates a new operators with the given data set as input.
- SingleJobSubmittedJobGraphStore - Class in org.apache.flink.runtime.dispatcher
-
- SingleJobSubmittedJobGraphStore(JobGraph) - Constructor for class org.apache.flink.runtime.dispatcher.SingleJobSubmittedJobGraphStore
-
- SingleJoinExample - Class in org.apache.flink.storm.join
-
Implements a simple example where 2 input streams are being joined.
- SingleJoinExample() - Constructor for class org.apache.flink.storm.join.SingleJoinExample
-
- SingleLeaderElectionService - Class in org.apache.flink.runtime.highavailability.nonha.leaderelection
-
- SingleLeaderElectionService(Executor, UUID) - Constructor for class org.apache.flink.runtime.highavailability.nonha.leaderelection.SingleLeaderElectionService
-
Creates a new leader election service.
- SingleLogicalSlot - Class in org.apache.flink.runtime.jobmaster.slotpool
-
- SingleLogicalSlot(SlotRequestId, SlotContext, SlotSharingGroupId, Locality, SlotOwner) - Constructor for class org.apache.flink.runtime.jobmaster.slotpool.SingleLogicalSlot
-
- SingleOutputStreamOperator<T> - Class in org.apache.flink.streaming.api.datastream
-
SingleOutputStreamOperator
represents a user defined transformation
applied on a
DataStream
with one predefined output type.
- SingleOutputStreamOperator(StreamExecutionEnvironment, StreamTransformation<T>) - Constructor for class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
-
- SingleSourceShortestPaths - Class in org.apache.flink.graph.examples
-
This example shows how to use Gelly's scatter-gather iterations.
- SingleSourceShortestPaths() - Constructor for class org.apache.flink.graph.examples.SingleSourceShortestPaths
-
- SingleSourceShortestPaths<K,VV> - Class in org.apache.flink.graph.library
-
This is an implementation of the Single-Source-Shortest Paths algorithm, using a scatter-gather iteration.
- SingleSourceShortestPaths(K, Integer) - Constructor for class org.apache.flink.graph.library.SingleSourceShortestPaths
-
Creates an instance of the SingleSourceShortestPaths algorithm.
- SingleSourceShortestPaths.MinDistanceMessenger<K> - Class in org.apache.flink.graph.library
-
Distributes the minimum distance associated with a given vertex among all
the target vertices summed up with the edge's value.
- SingleSourceShortestPaths.VertexDistanceUpdater<K> - Class in org.apache.flink.graph.library
-
Function that updates the value of a vertex by picking the minimum
distance from all incoming messages.
- SingleSourceShortestPathsData - Class in org.apache.flink.graph.examples.data
-
Provides the default data set used for the Single Source Shortest Paths example program.
- singleton(T) - Static method in class org.apache.flink.runtime.checkpoint.StateObjectCollection
-
- SingletonEdgeGraph - Class in org.apache.flink.graph.drivers.input
-
- SingletonEdgeGraph() - Constructor for class org.apache.flink.graph.drivers.input.SingletonEdgeGraph
-
- SingletonEdgeGraph - Class in org.apache.flink.graph.generator
-
A singleton-edge
Graph
contains one or more isolated two-paths.
- SingletonEdgeGraph(ExecutionEnvironment, long) - Constructor for class org.apache.flink.graph.generator.SingletonEdgeGraph
-
An undirected
Graph
containing one or more isolated two-paths.
- SinkContextUtil - Class in org.apache.flink.streaming.api.functions.sink
-
- SinkContextUtil() - Constructor for class org.apache.flink.streaming.api.functions.sink.SinkContextUtil
-
- SinkFunction<IN> - Interface in org.apache.flink.streaming.api.functions.sink
-
Interface for implementing user defined sink functionality.
- SinkFunction.Context<T> - Interface in org.apache.flink.streaming.api.functions.sink
-
Context that
SinkFunctions
can use for getting additional data about
an input record.
- SinkJoiner - Class in org.apache.flink.optimizer.dag
-
This class represents a utility node that is not part of the actual plan.
- SinkJoiner(OptimizerNode, OptimizerNode) - Constructor for class org.apache.flink.optimizer.dag.SinkJoiner
-
- SinkJoinerPlanNode - Class in org.apache.flink.optimizer.plan
-
- SinkJoinerPlanNode(SinkJoiner, Channel, Channel) - Constructor for class org.apache.flink.optimizer.plan.SinkJoinerPlanNode
-
- SinkPlanNode - Class in org.apache.flink.optimizer.plan
-
Plan candidate node for data flow sinks.
- SinkPlanNode(DataSinkNode, String, Channel) - Constructor for class org.apache.flink.optimizer.plan.SinkPlanNode
-
Constructs a new sink candidate node that uses NONE as its local strategy.
- sinks - Variable in class org.apache.flink.api.common.Plan
-
A collection of all sinks in the plan.
- SinkTransformation<T> - Class in org.apache.flink.streaming.api.transformations
-
This Transformation represents a Sink.
- SinkTransformation(StreamTransformation<T>, String, StreamSink<T>, int) - Constructor for class org.apache.flink.streaming.api.transformations.SinkTransformation
-
Creates a new SinkTransformation
from the given input StreamTransformation
.
- size() - Method in class org.apache.flink.api.common.operators.util.FieldSet
-
- size() - Method in class org.apache.flink.core.memory.ByteArrayOutputStreamWithPos
-
- size - Variable in class org.apache.flink.core.memory.MemorySegment
-
The size in bytes of the memory segment.
- size() - Method in class org.apache.flink.core.memory.MemorySegment
-
Gets the size of the memory segment, in bytes.
- size() - Method in class org.apache.flink.graph.types.valuearray.ByteValueArray
-
- size() - Method in class org.apache.flink.graph.types.valuearray.CharValueArray
-
- size() - Method in class org.apache.flink.graph.types.valuearray.DoubleValueArray
-
- size() - Method in class org.apache.flink.graph.types.valuearray.FloatValueArray
-
- size() - Method in class org.apache.flink.graph.types.valuearray.IntValueArray
-
- size() - Method in class org.apache.flink.graph.types.valuearray.LongValueArray
-
- size() - Method in class org.apache.flink.graph.types.valuearray.NullValueArray
-
- size() - Method in class org.apache.flink.graph.types.valuearray.ShortValueArray
-
- size() - Method in class org.apache.flink.graph.types.valuearray.StringValueArray
-
- size() - Method in interface org.apache.flink.graph.types.valuearray.ValueArray
-
Returns the number of elements stored in the array.
- size() - Method in class org.apache.flink.metrics.HistogramStatistics
-
Returns the size of the statistics' sample.
- SIZE - Static variable in class org.apache.flink.runtime.blob.BlobKey
-
Size of the internal BLOB key in bytes.
- size() - Method in class org.apache.flink.runtime.checkpoint.StateObjectCollection
-
- size() - Method in interface org.apache.flink.runtime.dispatcher.ArchivedExecutionGraphStore
-
- size() - Method in class org.apache.flink.runtime.dispatcher.FileArchivedExecutionGraphStore
-
- size() - Method in class org.apache.flink.runtime.dispatcher.MemoryArchivedExecutionGraphStore
-
- size() - Method in class org.apache.flink.runtime.jobmanager.scheduler.LifoSetQueue
-
- size() - Method in class org.apache.flink.runtime.jobmanager.scheduler.SetQueue
-
- size() - Method in class org.apache.flink.runtime.jobmaster.slotpool.DualKeyMap
-
- size() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotPool.AvailableSlots
-
- size() - Method in class org.apache.flink.runtime.metrics.DescriptiveStatisticsHistogramStatistics
-
- size() - Method in class org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
-
- size() - Method in interface org.apache.flink.runtime.operators.sort.IndexedSortable
-
Gets the number of elements in the sortable.
- size() - Method in class org.apache.flink.runtime.operators.sort.NormalizedKeySorter
-
- size() - Method in class org.apache.flink.runtime.operators.sort.PartialOrderPriorityQueue
-
Returns the number of elements currently stored in the PriorityQueue.
- size() - Method in class org.apache.flink.runtime.rest.handler.legacy.ExecutionGraphCache
-
Gets the number of cache entries.
- size() - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateTable
-
- size() - Method in class org.apache.flink.runtime.state.heap.NestedMapsStateTable
-
- size() - Method in class org.apache.flink.runtime.state.heap.StateTable
-
- size() - Method in class org.apache.flink.runtime.util.EvictingBoundedList
-
- size() - Method in class org.apache.flink.runtime.util.IntArrayList
-
- size() - Method in class org.apache.flink.runtime.util.LongArrayList
-
- size() - Method in class org.apache.flink.storm.util.StormConfig
-
- size() - Method in class org.apache.flink.storm.wrappers.StormTuple
-
- size() - Method in class org.apache.flink.streaming.api.operators.async.queue.OrderedStreamElementQueue
-
- size() - Method in interface org.apache.flink.streaming.api.operators.async.queue.StreamElementQueue
-
Return the size of the queue.
- size() - Method in class org.apache.flink.streaming.api.operators.async.queue.UnorderedStreamElementQueue
-
- size() - Method in class org.apache.flink.streaming.connectors.kafka.internals.ClosableBlockingQueue
-
Gets the number of elements currently in the queue.
- size() - Method in interface org.apache.flink.streaming.runtime.io.BufferOrEventSequence
-
Gets the size of the sequence.
- size() - Method in class org.apache.flink.streaming.runtime.io.BufferSpiller.SpilledBufferOrEventSequence
-
Deprecated.
- size() - Method in class org.apache.flink.streaming.runtime.io.CachedBufferBlocker.CachedBufferOrEventSequence
-
- size() - Method in class org.apache.flink.streaming.runtime.operators.windowing.KeyMap
-
Gets the number of elements currently in the map.
- size() - Method in class org.apache.flink.types.ListValue
-
- size() - Method in class org.apache.flink.types.MapValue
-
- SIZE - Static variable in class org.apache.flink.util.AbstractID
-
The size of the ID in byte.
- size() - Method in class org.apache.hadoop.conf.Configuration
-
Return the number of keys in the configuration.
- SIZE_MISMATCH_MESSAGE - Static variable in exception org.apache.flink.api.common.operators.Keys.IncompatibleKeysException
-
- SIZE_UNKNOWN - Static variable in interface org.apache.flink.api.common.io.statistics.BaseStatistics
-
Constant indicating that the input size is unknown.
- sizeOfNamespace(Object) - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateTable
-
- sizeOfNamespace(Object) - Method in class org.apache.flink.runtime.state.heap.NestedMapsStateTable
-
- sizeOfNamespace(Object) - Method in class org.apache.flink.runtime.state.heap.StateTable
-
- skip(long) - Method in class org.apache.flink.api.java.typeutils.runtime.DataInputViewStream
-
- skip(int) - Method in class org.apache.flink.api.java.typeutils.runtime.NoFetchingInput
-
- skip(long) - Method in class org.apache.flink.core.fs.AbstractMultiFSDataInputStream
-
- skip(long) - Method in class org.apache.flink.core.fs.FSDataInputStreamWrapper
-
- skip(long) - Method in class org.apache.flink.core.fs.local.LocalDataInputStream
-
- skip(long) - Method in class org.apache.flink.core.memory.ByteArrayInputStreamWithPos
-
- skip(long) - Method in class org.apache.flink.runtime.fs.hdfs.HadoopDataInputStream
-
- skip(long) - Method in class org.apache.flink.runtime.state.BoundedInputStream
-
- skip(long) - Method in class org.apache.flink.runtime.util.ForwardingInputStream
-
- skipArray() - Method in class org.apache.flink.formats.avro.utils.DataInputDecoder
-
- skipBytes(int) - Method in class org.apache.flink.core.memory.DataInputDeserializer
-
- skipBytes() - Method in class org.apache.flink.formats.avro.utils.DataInputDecoder
-
- skipBytes(int) - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
-
- skipBytesToRead(int) - Method in class org.apache.flink.core.memory.DataInputDeserializer
-
- skipBytesToRead(int) - Method in interface org.apache.flink.core.memory.DataInputView
-
Skips numBytes
bytes of memory.
- skipBytesToRead(int) - Method in class org.apache.flink.core.memory.DataInputViewStreamWrapper
-
- skipBytesToRead(int) - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
-
- skipBytesToWrite(int) - Method in class org.apache.flink.core.memory.DataOutputSerializer
-
- skipBytesToWrite(int) - Method in interface org.apache.flink.core.memory.DataOutputView
-
Skips numBytes
bytes memory.
- skipBytesToWrite(int) - Method in class org.apache.flink.core.memory.DataOutputViewStreamWrapper
-
- skipBytesToWrite(int) - Method in class org.apache.flink.runtime.memory.AbstractPagedOutputView
-
- skipCollectionExecution() - Method in class org.apache.flink.test.util.JavaProgramTestBase
-
- skipFields(byte[], int, int, byte[]) - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
-
- skipFirstLineAsHeader - Variable in class org.apache.flink.api.java.io.CsvReader
-
- skipFixed(int) - Method in class org.apache.flink.formats.avro.utils.DataInputDecoder
-
- skipFully(long) - Method in class org.apache.flink.runtime.fs.hdfs.HadoopDataInputStream
-
Skips over a given amount of bytes in the stream.
- skipFully(InputStream, long) - Static method in class org.apache.flink.util.IOUtils
-
Similar to readFully().
- skipMap() - Method in class org.apache.flink.formats.avro.utils.DataInputDecoder
-
- skipPastLastEvent() - Static method in class org.apache.flink.cep.nfa.AfterMatchSkipStrategy
-
Discards every partial match that contains event of the match.
- skipString() - Method in class org.apache.flink.formats.avro.utils.DataInputDecoder
-
- skipToFirst(String) - Static method in class org.apache.flink.cep.nfa.AfterMatchSkipStrategy
-
Discards every partial match that contains event of the match preceding the first of *PatternName*.
- skipToLast(String) - Static method in class org.apache.flink.cep.nfa.AfterMatchSkipStrategy
-
Discards every partial match that contains event of the match preceding the last of *PatternName*.
- slaveID() - Method in class org.apache.flink.mesos.runtime.clusterframework.store.MesosWorkerStore.Worker
-
Get the worker's assigned slave ID.
- slaveId() - Method in class org.apache.flink.mesos.scheduler.messages.ExecutorLost
-
- slaveId() - Method in class org.apache.flink.mesos.scheduler.messages.FrameworkMessage
-
- slaveId() - Method in class org.apache.flink.mesos.scheduler.messages.SlaveLost
-
- slaveLost(SlaveLost) - Method in class org.apache.flink.mesos.runtime.clusterframework.MesosResourceManager
-
- SlaveLost - Class in org.apache.flink.mesos.scheduler.messages
-
Message sent by the callback handler to the scheduler actor
when a slave has been determined unreachable (e.g., machine failure, network partition).
- SlaveLost(Protos.SlaveID) - Constructor for class org.apache.flink.mesos.scheduler.messages.SlaveLost
-
- slaveLost(SchedulerDriver, Protos.SlaveID) - Method in class org.apache.flink.mesos.scheduler.SchedulerProxy
-
- sleepTime(long) - Method in class org.apache.flink.client.program.rest.retry.ExponentialWaitStrategy
-
- sleepTime(long) - Method in interface org.apache.flink.client.program.rest.retry.WaitStrategy
-
Returns the time to wait until the next attempt.
- Slf4jReporter - Class in org.apache.flink.metrics.slf4j
-
- Slf4jReporter() - Constructor for class org.apache.flink.metrics.slf4j.Slf4jReporter
-
- SlidingAlignedProcessingTimeWindows - Class in org.apache.flink.streaming.api.windowing.assigners
-
This is a special window assigner used to tell the system to use the
"Fast Aligned Processing Time Window Operator" for windowing.
- SlidingAlignedProcessingTimeWindows(long, long) - Constructor for class org.apache.flink.streaming.api.windowing.assigners.SlidingAlignedProcessingTimeWindows
-
- SlidingEventTimeWindows - Class in org.apache.flink.streaming.api.windowing.assigners
-
A
WindowAssigner
that windows elements into sliding windows based on the timestamp of the
elements.
- SlidingEventTimeWindows(long, long, long) - Constructor for class org.apache.flink.streaming.api.windowing.assigners.SlidingEventTimeWindows
-
- SlidingProcessingTimeWindows - Class in org.apache.flink.streaming.api.windowing.assigners
-
A
WindowAssigner
that windows elements into sliding windows based on the current
system time of the machine the operation is running on.
- SlidingTimeWindows - Class in org.apache.flink.streaming.api.windowing.assigners
-
- Slot - Class in org.apache.flink.runtime.instance
-
Base class for slots that the Scheduler / ExecutionGraph take from the SlotPool and use to place
tasks to execute into.
- Slot(SlotOwner, TaskManagerLocation, int, TaskManagerGateway, SharedSlot, AbstractID) - Constructor for class org.apache.flink.runtime.instance.Slot
-
Base constructor for slots.
- Slot(SlotContext, SlotOwner, int, SharedSlot, AbstractID) - Constructor for class org.apache.flink.runtime.instance.Slot
-
Base constructor for slots.
- SLOT_IDLE_TIMEOUT - Static variable in class org.apache.flink.configuration.JobManagerOptions
-
- SLOT_REQUEST_TIMEOUT - Static variable in class org.apache.flink.configuration.JobManagerOptions
-
- SLOT_REQUEST_TIMEOUT - Static variable in class org.apache.flink.configuration.ResourceManagerOptions
-
The timeout for a slot request to be discarded, in milliseconds.
- SlotActions - Interface in org.apache.flink.runtime.taskexecutor.slot
-
- SlotAllocationException - Exception in org.apache.flink.runtime.taskexecutor.exceptions
-
Exception indicating that the slot allocation on the task manager failed.
- SlotAllocationException(String) - Constructor for exception org.apache.flink.runtime.taskexecutor.exceptions.SlotAllocationException
-
- SlotAllocationException(String, Throwable) - Constructor for exception org.apache.flink.runtime.taskexecutor.exceptions.SlotAllocationException
-
- SlotAllocationException(Throwable) - Constructor for exception org.apache.flink.runtime.taskexecutor.exceptions.SlotAllocationException
-
- SlotAndLocality - Class in org.apache.flink.runtime.jobmaster.slotpool
-
A combination of a
AllocatedSlot
and a
Locality
.
- SlotAndLocality(AllocatedSlot, Locality) - Constructor for class org.apache.flink.runtime.jobmaster.slotpool.SlotAndLocality
-
- SlotAvailabilityListener - Interface in org.apache.flink.runtime.jobmanager.scheduler
-
A SlotAvailabilityListener can be notified when new
Slot
s become available on an
Instance
.
- SlotContext - Interface in org.apache.flink.runtime.jobmaster
-
- SlotException - Exception in org.apache.flink.runtime.jobmanager.slots
-
Base class for slot related exceptions.
- SlotException(String) - Constructor for exception org.apache.flink.runtime.jobmanager.slots.SlotException
-
- SlotException(Throwable) - Constructor for exception org.apache.flink.runtime.jobmanager.slots.SlotException
-
- SlotException(String, Throwable) - Constructor for exception org.apache.flink.runtime.jobmanager.slots.SlotException
-
- SlotID - Class in org.apache.flink.runtime.clusterframework.types
-
Unique identifier for a slot on a TaskManager.
- SlotID(ResourceID, int) - Constructor for class org.apache.flink.runtime.clusterframework.types.SlotID
-
- SlotManager - Class in org.apache.flink.runtime.resourcemanager.slotmanager
-
The slot manager is responsible for maintaining a view on all registered task manager slots,
their allocation and all pending slot requests.
- SlotManager(ScheduledExecutor, Time, Time, Time) - Constructor for class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
-
- SlotManagerConfiguration - Class in org.apache.flink.runtime.resourcemanager.slotmanager
-
- SlotManagerConfiguration(Time, Time, Time) - Constructor for class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerConfiguration
-
- SlotManagerException - Exception in org.apache.flink.runtime.resourcemanager.slotmanager
-
- SlotManagerException(String) - Constructor for exception org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerException
-
- SlotManagerException(String, Throwable) - Constructor for exception org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerException
-
- SlotNotActiveException - Exception in org.apache.flink.runtime.taskexecutor.slot
-
Exception indicating that the given
TaskSlot
was not in state active.
- SlotNotActiveException(JobID, AllocationID) - Constructor for exception org.apache.flink.runtime.taskexecutor.slot.SlotNotActiveException
-
- SlotNotFoundException - Exception in org.apache.flink.runtime.taskexecutor.slot
-
Exception indicating that a
TaskSlot
could not be found.
- SlotNotFoundException(AllocationID) - Constructor for exception org.apache.flink.runtime.taskexecutor.slot.SlotNotFoundException
-
- SlotNotFoundException(String) - Constructor for exception org.apache.flink.runtime.taskexecutor.slot.SlotNotFoundException
-
- SlotOccupiedException - Exception in org.apache.flink.runtime.taskexecutor.exceptions
-
Exception which signals that a slot is already occupied by the given
AllocationID
.
- SlotOccupiedException(String, AllocationID, JobID) - Constructor for exception org.apache.flink.runtime.taskexecutor.exceptions.SlotOccupiedException
-
- SlotOffer - Class in org.apache.flink.runtime.taskexecutor.slot
-
Describe the slot offering to job manager provided by task manager.
- SlotOffer(AllocationID, int, ResourceProfile) - Constructor for class org.apache.flink.runtime.taskexecutor.slot.SlotOffer
-
- SlotOwner - Interface in org.apache.flink.runtime.jobmaster
-
Interface for components that hold slots and to which slots get released / recycled.
- SlotPool - Class in org.apache.flink.runtime.jobmaster.slotpool
-
- SlotPool(RpcService, JobID, SchedulingStrategy) - Constructor for class org.apache.flink.runtime.jobmaster.slotpool.SlotPool
-
- SlotPool(RpcService, JobID, SchedulingStrategy, Clock, Time, Time) - Constructor for class org.apache.flink.runtime.jobmaster.slotpool.SlotPool
-
- SlotPool.AvailableSlots - Class in org.apache.flink.runtime.jobmaster.slotpool
-
Organize all available slots from different points of view.
- SlotPoolFactory - Interface in org.apache.flink.runtime.jobmaster.slotpool
-
- SlotPoolGateway - Interface in org.apache.flink.runtime.jobmaster.slotpool
-
- SlotProfile - Class in org.apache.flink.runtime.clusterframework.types
-
A slot profile describes the profile of a slot into which a task wants to be scheduled.
- SlotProfile(ResourceProfile, Collection<TaskManagerLocation>, Collection<AllocationID>) - Constructor for class org.apache.flink.runtime.clusterframework.types.SlotProfile
-
- SlotProvider - Interface in org.apache.flink.runtime.jobmaster.slotpool
-
The slot provider is responsible for preparing slots for ready-to-run tasks.
- SlotReport - Class in org.apache.flink.runtime.taskexecutor
-
A report about the current status of all slots of the TaskExecutor, describing
which slots are available and allocated, and what jobs (JobManagers) the allocated slots
have been allocated to.
- SlotReport() - Constructor for class org.apache.flink.runtime.taskexecutor.SlotReport
-
- SlotReport(SlotStatus) - Constructor for class org.apache.flink.runtime.taskexecutor.SlotReport
-
- SlotReport(Collection<SlotStatus>) - Constructor for class org.apache.flink.runtime.taskexecutor.SlotReport
-
- SlotRequest - Class in org.apache.flink.runtime.resourcemanager
-
This describes the requirement of the slot, mainly used by JobManager requesting slot from ResourceManager.
- SlotRequest(JobID, AllocationID, ResourceProfile, String) - Constructor for class org.apache.flink.runtime.resourcemanager.SlotRequest
-
- SlotRequestId - Class in org.apache.flink.runtime.jobmaster
-
This ID identifies the request for a logical slot from the Execution to the
SlotPool
oe
SlotProvider
.
- SlotRequestId(long, long) - Constructor for class org.apache.flink.runtime.jobmaster.SlotRequestId
-
- SlotRequestId() - Constructor for class org.apache.flink.runtime.jobmaster.SlotRequestId
-
- SlotSharingGroup - Class in org.apache.flink.runtime.jobmanager.scheduler
-
A slot sharing units defines which different task (from different job vertices) can be
deployed together within a slot.
- SlotSharingGroup() - Constructor for class org.apache.flink.runtime.jobmanager.scheduler.SlotSharingGroup
-
- SlotSharingGroup(JobVertexID...) - Constructor for class org.apache.flink.runtime.jobmanager.scheduler.SlotSharingGroup
-
- slotSharingGroup(String) - Method in class org.apache.flink.streaming.api.datastream.DataStreamSink
-
Sets the slot sharing group of this operation.
- slotSharingGroup(String) - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
-
Sets the slot sharing group of this operation.
- slotSharingGroup(String) - Method in class org.apache.flink.streaming.connectors.cassandra.CassandraSink
-
Sets the slot sharing group of this operation.
- slotSharingGroup(String) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer010.FlinkKafkaProducer010Configuration
-
Deprecated.
- SlotSharingGroupAssignment - Class in org.apache.flink.runtime.instance
-
The SlotSharingGroupAssignment manages a set of shared slots, which are shared between
tasks of a
SlotSharingGroup
.
- SlotSharingGroupAssignment() - Constructor for class org.apache.flink.runtime.instance.SlotSharingGroupAssignment
-
- SlotSharingGroupId - Class in org.apache.flink.runtime.instance
-
- SlotSharingGroupId(long, long) - Constructor for class org.apache.flink.runtime.instance.SlotSharingGroupId
-
- SlotSharingGroupId() - Constructor for class org.apache.flink.runtime.instance.SlotSharingGroupId
-
- SlotSharingManager - Class in org.apache.flink.runtime.jobmaster.slotpool
-
Manager which is responsible for slot sharing.
- SlotSharingManager.MultiTaskSlot - Class in org.apache.flink.runtime.jobmaster.slotpool
-
- SlotSharingManager.SingleTaskSlot - Class in org.apache.flink.runtime.jobmaster.slotpool
-
- SlotSharingManager.TaskSlot - Class in org.apache.flink.runtime.jobmaster.slotpool
-
Base class for all task slots.
- slotSharingManagers - Variable in class org.apache.flink.runtime.jobmaster.slotpool.SlotPool
-
Managers for the different slot sharing groups.
- SlotStatus - Class in org.apache.flink.runtime.taskexecutor
-
This describes the slot current status which located in TaskManager.
- SlotStatus(SlotID, ResourceProfile) - Constructor for class org.apache.flink.runtime.taskexecutor.SlotStatus
-
- SlotStatus(SlotID, ResourceProfile, JobID, AllocationID) - Constructor for class org.apache.flink.runtime.taskexecutor.SlotStatus
-
- SnappyStreamCompressionDecorator - Class in org.apache.flink.runtime.state
-
This implementation decorates the stream with snappy compression.
- SnappyStreamCompressionDecorator() - Constructor for class org.apache.flink.runtime.state.SnappyStreamCompressionDecorator
-
- snapshot(long, long, CheckpointStreamFactory, CheckpointOptions) - Method in class org.apache.flink.contrib.streaming.state.RocksDBKeyedStateBackend
-
Triggers an asynchronous snapshot of the keyed state backend from RocksDB.
- snapshot(long, long, CheckpointStreamFactory, CheckpointOptions) - Method in class org.apache.flink.runtime.state.DefaultOperatorStateBackend
-
- snapshot(long, long, CheckpointStreamFactory, CheckpointOptions) - Method in class org.apache.flink.runtime.state.heap.HeapKeyedStateBackend
-
- snapshot() - Method in class org.apache.flink.runtime.state.RegisteredBroadcastBackendStateMetaInfo
-
- snapshot() - Method in class org.apache.flink.runtime.state.RegisteredKeyedBackendStateMetaInfo
-
- snapshot() - Method in class org.apache.flink.runtime.state.RegisteredOperatorBackendStateMetaInfo
-
- snapshot(long, long, CheckpointStreamFactory, CheckpointOptions) - Method in interface org.apache.flink.runtime.state.Snapshotable
-
- snapshot(int) - Method in class org.apache.flink.table.client.gateway.local.MaterializedCollectStreamResult
-
- snapshot(int) - Method in interface org.apache.flink.table.client.gateway.local.MaterializedResult
-
Takes a snapshot of the current table and returns the number of pages for navigating
through the snapshot.
- Snapshotable<S extends StateObject,R> - Interface in org.apache.flink.runtime.state
-
Interface for operators that can perform snapshots of their state.
- snapshotConfiguration() - Method in class org.apache.flink.api.common.typeutils.base.EnumSerializer
-
- snapshotConfiguration() - Method in class org.apache.flink.api.common.typeutils.base.GenericArraySerializer
-
- snapshotConfiguration() - Method in class org.apache.flink.api.common.typeutils.base.ListSerializer
-
- snapshotConfiguration() - Method in class org.apache.flink.api.common.typeutils.base.MapSerializer
-
- snapshotConfiguration() - Method in class org.apache.flink.api.common.typeutils.base.TypeSerializerSingleton
-
- snapshotConfiguration() - Method in class org.apache.flink.api.common.typeutils.TypeDeserializerAdapter
-
- snapshotConfiguration() - Method in class org.apache.flink.api.common.typeutils.TypeSerializer
-
Create a snapshot of the serializer's current configuration to be stored along with the managed state it is
registered to (if any - this method is only relevant if this serializer is registered for serialization of
managed state).
- snapshotConfiguration() - Method in class org.apache.flink.api.common.typeutils.UnloadableDummyTypeSerializer
-
- snapshotConfiguration() - Method in class org.apache.flink.api.java.typeutils.runtime.AvroSerializer
-
Deprecated.
- snapshotConfiguration() - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer
-
- snapshotConfiguration() - Method in class org.apache.flink.api.java.typeutils.runtime.EitherSerializer
-
- snapshotConfiguration() - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer
-
- snapshotConfiguration() - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer
-
- snapshotConfiguration() - Method in class org.apache.flink.api.java.typeutils.runtime.RowSerializer
-
- snapshotConfiguration() - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializerBase
-
- snapshotConfiguration() - Method in class org.apache.flink.api.java.typeutils.runtime.ValueSerializer
-
- snapshotConfiguration() - Method in class org.apache.flink.api.java.typeutils.runtime.WritableSerializer
-
- snapshotConfiguration() - Method in class org.apache.flink.cep.nfa.NFA.NFASerializer
-
- snapshotConfiguration() - Method in class org.apache.flink.cep.nfa.SharedBuffer.SharedBufferSerializer
-
- snapshotConfiguration() - Method in class org.apache.flink.formats.avro.typeutils.AvroSerializer
-
- snapshotConfiguration() - Method in class org.apache.flink.formats.avro.typeutils.BackwardsCompatibleAvroSerializer
-
- snapshotConfiguration() - Method in class org.apache.flink.runtime.state.ArrayListSerializer
-
- snapshotConfiguration() - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.StateSerializer
-
- snapshotConfiguration() - Method in class org.apache.flink.streaming.api.operators.InternalTimer.TimerSerializer
-
- snapshotConfiguration() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
-
- snapshotCurrentState() - Method in class org.apache.flink.streaming.connectors.kafka.internals.AbstractFetcher
-
Takes a snapshot of the partition offsets.
- SnapshotDirectory - Class in org.apache.flink.runtime.state
-
This class represents a directory that is the target for a state snapshot.
- snapshotFunctionState(StateSnapshotContext, OperatorStateBackend, Function) - Static method in class org.apache.flink.streaming.util.functions.StreamingFunctionUtils
-
- SnapshotResult<T extends StateObject> - Class in org.apache.flink.runtime.state
-
This class contains the combined results from the snapshot of a state backend:
A state object representing the state that will be reported to the Job Manager to acknowledge the checkpoint.
A state object that represents the state for the
TaskLocalStateStoreImpl
.
Both state objects are optional and can be null, e.g.
- snapshotResult(SessionContext, String, int) - Method in interface org.apache.flink.table.client.gateway.Executor
-
Creates an immutable result snapshot of the running Flink job.
- snapshotResult(SessionContext, String, int) - Method in class org.apache.flink.table.client.gateway.local.LocalExecutor
-
- snapshotState(long, long) - Method in class org.apache.flink.sql.tests.StreamSQLTestProgram.Generator
-
- snapshotState(long, long) - Method in class org.apache.flink.sql.tests.StreamSQLTestProgram.KillMapper
-
- snapshotState(FunctionSnapshotContext) - Method in interface org.apache.flink.streaming.api.checkpoint.CheckpointedFunction
-
This method is called when a snapshot for a checkpoint is requested.
- snapshotState(long, long) - Method in interface org.apache.flink.streaming.api.checkpoint.ListCheckpointed
-
Gets the current state of the function.
- snapshotState(FunctionSnapshotContext) - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
-
- snapshotState(FunctionSnapshotContext) - Method in class org.apache.flink.streaming.api.functions.source.ContinuousFileMonitoringFunction
-
- snapshotState(StateSnapshotContext) - Method in class org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperator
-
- snapshotState(FunctionSnapshotContext) - Method in class org.apache.flink.streaming.api.functions.source.FromElementsFunction
-
- snapshotState(FunctionSnapshotContext) - Method in class org.apache.flink.streaming.api.functions.source.MessageAcknowledgingSourceBase
-
- snapshotState(FunctionSnapshotContext) - Method in class org.apache.flink.streaming.api.functions.source.MultipleIdsMessageAcknowledgingSourceBase
-
- snapshotState(FunctionSnapshotContext) - Method in class org.apache.flink.streaming.api.functions.source.StatefulSequenceSource
-
- snapshotState(long, long, CheckpointOptions, CheckpointStreamFactory) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- snapshotState(StateSnapshotContext) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
Stream operators with state, which want to participate in a snapshot need to override this hook method.
- snapshotState(StateSnapshotContext) - Method in class org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
-
- snapshotState(StateSnapshotContext) - Method in class org.apache.flink.streaming.api.operators.async.AsyncWaitOperator
-
- snapshotState(long, long, CheckpointOptions, CheckpointStreamFactory) - Method in interface org.apache.flink.streaming.api.operators.StreamOperator
-
Called to draw a state snapshot from the operator.
- snapshotState(FunctionSnapshotContext) - Method in class org.apache.flink.streaming.connectors.cassandra.CassandraSinkBase
-
- snapshotState(FunctionSnapshotContext) - Method in class org.apache.flink.streaming.connectors.elasticsearch.ElasticsearchSinkBase
-
- snapshotState(FunctionSnapshotContext) - Method in class org.apache.flink.streaming.connectors.fs.bucketing.BucketingSink
-
- snapshotState(FunctionSnapshotContext) - Method in class org.apache.flink.streaming.connectors.fs.RollingSink
-
Deprecated.
- snapshotState(FunctionSnapshotContext) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumerBase
-
- snapshotState(FunctionSnapshotContext) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer011
-
- snapshotState(FunctionSnapshotContext) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducerBase
-
- snapshotState(StateSnapshotContext) - Method in class org.apache.flink.streaming.runtime.operators.GenericWriteAheadSink
-
- snapshotState(FunctionSnapshotContext) - Method in class org.apache.flink.streaming.tests.artificialstate.ArtificalOperatorStateMapper
-
- snapshotState(FunctionSnapshotContext) - Method in class org.apache.flink.streaming.tests.artificialstate.ArtificialKeyedStateMapper
-
- snapshotState(long, long) - Method in class org.apache.flink.streaming.tests.BucketingSinkTestProgram.Generator
-
- snapshotState(FunctionSnapshotContext) - Method in class org.apache.flink.streaming.tests.SequenceGeneratorSource
-
- snapshotStateForKeyGroup(DataOutputView, int) - Method in class org.apache.flink.streaming.api.operators.InternalTimeServiceManager
-
- SnapshotStrategy<S extends StateObject> - Interface in org.apache.flink.runtime.state
-
Interface for different snapshot approaches in state backends.
- snapshotTimersForKeyGroup(int) - Method in class org.apache.flink.streaming.api.operators.HeapInternalTimerService
-
Snapshots the timers (both processing and event time ones) for a given keyGroupIdx
.
- socket - Variable in class org.apache.flink.python.api.streaming.data.PythonStreamer
-
- socket_text_stream(String, int) - Method in class org.apache.flink.streaming.python.api.environment.PythonStreamExecutionEnvironment
-
- socketAddressToUrlString(InetSocketAddress) - Static method in class org.apache.flink.util.NetUtils
-
Encodes an IP address and port to be included in URL.
- SocketClientSink<IN> - Class in org.apache.flink.streaming.api.functions.sink
-
Socket client that acts as a streaming sink.
- SocketClientSink(String, int, SerializationSchema<IN>) - Constructor for class org.apache.flink.streaming.api.functions.sink.SocketClientSink
-
Creates a new SocketClientSink.
- SocketClientSink(String, int, SerializationSchema<IN>, int) - Constructor for class org.apache.flink.streaming.api.functions.sink.SocketClientSink
-
Creates a new SocketClientSink that retries connections upon failure up to a given number of times.
- SocketClientSink(String, int, SerializationSchema<IN>, int, boolean) - Constructor for class org.apache.flink.streaming.api.functions.sink.SocketClientSink
-
Creates a new SocketClientSink that retries connections upon failure up to a given number of times.
- SocketStreamIterator<T> - Class in org.apache.flink.streaming.experimental
-
An iterator that returns the data from a socket stream.
- SocketStreamIterator(TypeSerializer<T>) - Constructor for class org.apache.flink.streaming.experimental.SocketStreamIterator
-
Creates an iterator that returns the data from a socket stream with automatic port and bind address.
- SocketStreamIterator(int, InetAddress, TypeSerializer<T>) - Constructor for class org.apache.flink.streaming.experimental.SocketStreamIterator
-
Creates an iterator that returns the data from a socket stream with custom port and bind address.
- socketTextStream(String, int, char, long) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- socketTextStream(String, int, String, long) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Creates a new data stream that contains the strings received infinitely from a socket.
- socketTextStream(String, int, char) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- socketTextStream(String, int, String) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Creates a new data stream that contains the strings received infinitely from a socket.
- socketTextStream(String, int) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Creates a new data stream that contains the strings received infinitely from a socket.
- SocketTextStreamFunction - Class in org.apache.flink.streaming.api.functions.source
-
A source function that reads strings from a socket.
- SocketTextStreamFunction(String, int, String, long) - Constructor for class org.apache.flink.streaming.api.functions.source.SocketTextStreamFunction
-
- SocketTextStreamFunction(String, int, String, long, long) - Constructor for class org.apache.flink.streaming.api.functions.source.SocketTextStreamFunction
-
- SocketWindowWordCount - Class in org.apache.flink.streaming.examples.socket
-
Implements a streaming windowed version of the "WordCount" program.
- SocketWindowWordCount() - Constructor for class org.apache.flink.streaming.examples.socket.SocketWindowWordCount
-
- SocketWindowWordCount.WordWithCount - Class in org.apache.flink.streaming.examples.socket
-
Data type for words with count.
- SolutionSetBroker - Class in org.apache.flink.runtime.iterative.concurrent
-
Used to hand over the hash-join from the iteration head to the solution-set match.
- SolutionSetDeltaOperator - Class in org.apache.flink.optimizer.operators
-
- SolutionSetDeltaOperator(FieldList) - Constructor for class org.apache.flink.optimizer.operators.SolutionSetDeltaOperator
-
- SolutionSetFastUpdateOutputCollector<T> - Class in org.apache.flink.runtime.iterative.io
-
A
Collector
to update the solution set of a workset iteration.
- SolutionSetFastUpdateOutputCollector(CompactingHashTable<T>) - Constructor for class org.apache.flink.runtime.iterative.io.SolutionSetFastUpdateOutputCollector
-
- SolutionSetFastUpdateOutputCollector(CompactingHashTable<T>, Collector<T>) - Constructor for class org.apache.flink.runtime.iterative.io.SolutionSetFastUpdateOutputCollector
-
- SolutionSetNode - Class in org.apache.flink.optimizer.dag
-
The optimizer's internal representation of the solution set of a workset iteration.
- SolutionSetNode(DeltaIterationBase.SolutionSetPlaceHolder<?>, WorksetIterationNode) - Constructor for class org.apache.flink.optimizer.dag.SolutionSetNode
-
- SolutionSetObjectsUpdateOutputCollector<T> - Class in org.apache.flink.runtime.iterative.io
-
A
Collector
to update the solution set of a workset iteration.
- SolutionSetObjectsUpdateOutputCollector(JoinHashMap<T>) - Constructor for class org.apache.flink.runtime.iterative.io.SolutionSetObjectsUpdateOutputCollector
-
- SolutionSetObjectsUpdateOutputCollector(JoinHashMap<T>, Collector<T>) - Constructor for class org.apache.flink.runtime.iterative.io.SolutionSetObjectsUpdateOutputCollector
-
- SolutionSetPlaceHolder(DeltaIterationBase<ST, ?>, OperatorInformation<ST>) - Constructor for class org.apache.flink.api.common.operators.base.DeltaIterationBase.SolutionSetPlaceHolder
-
- SolutionSetPlanNode - Class in org.apache.flink.optimizer.plan
-
Plan candidate node for partial solution of a bulk iteration.
- SolutionSetPlanNode(SolutionSetNode, String, GlobalProperties, LocalProperties, Channel) - Constructor for class org.apache.flink.optimizer.plan.SolutionSetPlanNode
-
- SolutionSetUpdateBarrier - Class in org.apache.flink.runtime.iterative.concurrent
-
- SolutionSetUpdateBarrier() - Constructor for class org.apache.flink.runtime.iterative.concurrent.SolutionSetUpdateBarrier
-
- SolutionSetUpdateBarrierBroker - Class in org.apache.flink.runtime.iterative.concurrent
-
- SolutionSetUpdateOutputCollector<T> - Class in org.apache.flink.runtime.iterative.io
-
A
Collector
to update the solution set of a workset iteration.
- SolutionSetUpdateOutputCollector(CompactingHashTable<T>) - Constructor for class org.apache.flink.runtime.iterative.io.SolutionSetUpdateOutputCollector
-
- SolutionSetUpdateOutputCollector(CompactingHashTable<T>, Collector<T>) - Constructor for class org.apache.flink.runtime.iterative.io.SolutionSetUpdateOutputCollector
-
- sort(IndexedSortable, int, int) - Method in class org.apache.flink.runtime.operators.sort.HeapSort
-
- sort(IndexedSortable) - Method in class org.apache.flink.runtime.operators.sort.HeapSort
-
- sort(IndexedSortable, int, int) - Method in interface org.apache.flink.runtime.operators.sort.IndexedSorter
-
Sort the items accessed through the given IndexedSortable over the given
range of logical indices.
- sort(IndexedSortable) - Method in interface org.apache.flink.runtime.operators.sort.IndexedSorter
-
- sort(IndexedSortable, int, int) - Method in class org.apache.flink.runtime.operators.sort.QuickSort
-
Sort the given range of items using quick sort.
- sort(IndexedSortable) - Method in class org.apache.flink.runtime.operators.sort.QuickSort
-
- SORT_SPILLING_THRESHOLD - Static variable in class org.apache.flink.configuration.AlgorithmOptions
-
- SortedGrouping<T> - Class in org.apache.flink.api.java.operators
-
SortedGrouping is an intermediate step for a transformation on a grouped and sorted DataSet.
- SortedGrouping(DataSet<T>, Keys<T>, int, Order) - Constructor for class org.apache.flink.api.java.operators.SortedGrouping
-
- SortedGrouping(DataSet<T>, Keys<T>, String, Order) - Constructor for class org.apache.flink.api.java.operators.SortedGrouping
-
- SortedGrouping(DataSet<T>, Keys<T>, Keys.SelectorFunctionKeys<T, K>, Order) - Constructor for class org.apache.flink.api.java.operators.SortedGrouping
-
- Sorter<E> - Interface in org.apache.flink.runtime.operators.sort
-
The SortMerger interface representing the public interface to all specific Sort-Merge implementations.
- sortFirstGroup(int, Order) - Method in class org.apache.flink.api.java.operators.CoGroupOperator.CoGroupOperatorSets.CoGroupOperatorSetsPredicate.CoGroupOperatorWithoutFunction
-
Sorts
Tuple
elements within a group in the first input on the
specified field in the specified
Order
.
- sortFirstGroup(String, Order) - Method in class org.apache.flink.api.java.operators.CoGroupOperator.CoGroupOperatorSets.CoGroupOperatorSetsPredicate.CoGroupOperatorWithoutFunction
-
Sorts Pojo or
Tuple
elements within a group in the first input on the
specified field in the specified
Order
.
- sortGroup(int, Order) - Method in class org.apache.flink.api.java.operators.SortedGrouping
-
Sorts
Tuple
elements within a group on the specified field in the specified
Order
.
- sortGroup(String, Order) - Method in class org.apache.flink.api.java.operators.SortedGrouping
-
Sorts
Tuple
or POJO elements within a group on the specified field in the specified
Order
.
- sortGroup(int, Order) - Method in class org.apache.flink.api.java.operators.UnsortedGrouping
-
Sorts
Tuple
elements within a group on the specified field in the specified
Order
.
- sortGroup(String, Order) - Method in class org.apache.flink.api.java.operators.UnsortedGrouping
-
Sorts Pojos within a group on the specified field in the specified
Order
.
- sortGroup(KeySelector<T, K>, Order) - Method in class org.apache.flink.api.java.operators.UnsortedGrouping
-
Sorts elements within a group on a key extracted by the specified
KeySelector
in the specified
Order
.
- SortingThread(ExceptionHandler<IOException>, UnilateralSortMerger.CircularQueues<E>, AbstractInvokable) - Constructor for class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SortingThread
-
Creates a new sorting thread.
- sortLocalOutput(int, Order) - Method in class org.apache.flink.api.java.operators.DataSink
-
- sortLocalOutput(String, Order) - Method in class org.apache.flink.api.java.operators.DataSink
-
- SortMergeFullOuterJoinDescriptor - Class in org.apache.flink.optimizer.operators
-
- SortMergeFullOuterJoinDescriptor(FieldList, FieldList) - Constructor for class org.apache.flink.optimizer.operators.SortMergeFullOuterJoinDescriptor
-
- SortMergeInnerJoinDescriptor - Class in org.apache.flink.optimizer.operators
-
- SortMergeInnerJoinDescriptor(FieldList, FieldList) - Constructor for class org.apache.flink.optimizer.operators.SortMergeInnerJoinDescriptor
-
- SortMergeInnerJoinDescriptor(FieldList, FieldList, boolean, boolean, boolean) - Constructor for class org.apache.flink.optimizer.operators.SortMergeInnerJoinDescriptor
-
- SortMergeLeftOuterJoinDescriptor - Class in org.apache.flink.optimizer.operators
-
- SortMergeLeftOuterJoinDescriptor(FieldList, FieldList) - Constructor for class org.apache.flink.optimizer.operators.SortMergeLeftOuterJoinDescriptor
-
- SortMergeLeftOuterJoinDescriptor(FieldList, FieldList, boolean) - Constructor for class org.apache.flink.optimizer.operators.SortMergeLeftOuterJoinDescriptor
-
- SortMergeRightOuterJoinDescriptor - Class in org.apache.flink.optimizer.operators
-
- SortMergeRightOuterJoinDescriptor(FieldList, FieldList) - Constructor for class org.apache.flink.optimizer.operators.SortMergeRightOuterJoinDescriptor
-
- SortMergeRightOuterJoinDescriptor(FieldList, FieldList, boolean) - Constructor for class org.apache.flink.optimizer.operators.SortMergeRightOuterJoinDescriptor
-
- sortOrders - Variable in class org.apache.flink.optimizer.plan.DualInputPlanNode
-
- sortPartition(int, Order) - Method in class org.apache.flink.api.java.DataSet
-
Locally sorts the partitions of the DataSet on the specified field in the specified order.
- sortPartition(String, Order) - Method in class org.apache.flink.api.java.DataSet
-
Locally sorts the partitions of the DataSet on the specified field in the specified order.
- sortPartition(KeySelector<T, K>, Order) - Method in class org.apache.flink.api.java.DataSet
-
Locally sorts the partitions of the DataSet on the extracted key in the specified order.
- sortPartition(int, Order) - Method in class org.apache.flink.api.java.operators.SortPartitionOperator
-
Appends an additional sort order with the specified field in the specified order to the
local partition sorting of the DataSet.
- sortPartition(String, Order) - Method in class org.apache.flink.api.java.operators.SortPartitionOperator
-
Appends an additional sort order with the specified field in the specified order to the
local partition sorting of the DataSet.
- sortPartition(KeySelector<T, K>, Order) - Method in class org.apache.flink.api.java.operators.SortPartitionOperator
-
- SortPartitionDescriptor(Ordering) - Constructor for class org.apache.flink.optimizer.dag.SortPartitionNode.SortPartitionDescriptor
-
- SortPartitionNode - Class in org.apache.flink.optimizer.dag
-
The optimizer's internal representation of a SortPartition operator node.
- SortPartitionNode(SortPartitionOperatorBase<?>) - Constructor for class org.apache.flink.optimizer.dag.SortPartitionNode
-
- SortPartitionNode.SortPartitionDescriptor - Class in org.apache.flink.optimizer.dag
-
- SortPartitionOperator<T> - Class in org.apache.flink.api.java.operators
-
This operator represents a DataSet with locally sorted partitions.
- SortPartitionOperator(DataSet<T>, int, Order, String) - Constructor for class org.apache.flink.api.java.operators.SortPartitionOperator
-
- SortPartitionOperator(DataSet<T>, String, Order, String) - Constructor for class org.apache.flink.api.java.operators.SortPartitionOperator
-
- SortPartitionOperator(DataSet<T>, Keys.SelectorFunctionKeys<T, K>, Order, String) - Constructor for class org.apache.flink.api.java.operators.SortPartitionOperator
-
- SortPartitionOperatorBase<IN> - Class in org.apache.flink.api.common.operators.base
-
- SortPartitionOperatorBase(UnaryOperatorInformation<IN, IN>, Ordering, String) - Constructor for class org.apache.flink.api.common.operators.base.SortPartitionOperatorBase
-
- sortReadMemory - Variable in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger
-
The memory segments used first for sorting and later for reading/pre-fetching
during the external merge.
- sortSecondGroup(int, Order) - Method in class org.apache.flink.api.java.operators.CoGroupOperator.CoGroupOperatorSets.CoGroupOperatorSetsPredicate.CoGroupOperatorWithoutFunction
-
Sorts
Tuple
elements within a group in the second input on the
specified field in the specified
Order
.
- sortSecondGroup(String, Order) - Method in class org.apache.flink.api.java.operators.CoGroupOperator.CoGroupOperatorSets.CoGroupOperatorSetsPredicate.CoGroupOperatorWithoutFunction
-
Sorts Pojo or
Tuple
elements within a group in the second input on the
specified field in the specified
Order
.
- sortTriangleVertices - Variable in class org.apache.flink.graph.library.clustering.TriangleListingBase
-
- source - Variable in class org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact.Builder
-
- source - Variable in class org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact
-
- source - Variable in class org.apache.flink.storm.util.InMemorySpout
-
- Source - Class in org.apache.flink.table.client.config
-
Configuration of a table source.
- sourceAddress() - Method in class org.apache.flink.streaming.examples.statemachine.event.Event
-
Gets the event's source address.
- sourceContext - Variable in class org.apache.flink.streaming.connectors.kafka.internals.AbstractFetcher
-
The source context to emit records and watermarks to.
- SourceFunction<T> - Interface in org.apache.flink.streaming.api.functions.source
-
Base interface for all stream data sources in Flink.
- SourceFunction.SourceContext<T> - Interface in org.apache.flink.streaming.api.functions.source
-
Interface that source functions use to emit elements, and possibly watermarks.
- SourcePartitionerMarker(String) - Constructor for class org.apache.flink.api.java.io.SplitDataProperties.SourcePartitionerMarker
-
- SourcePlanNode - Class in org.apache.flink.optimizer.plan
-
Plan candidate node for data flow sources that have no input and no special strategies.
- SourcePlanNode(DataSourceNode, String) - Constructor for class org.apache.flink.optimizer.plan.SourcePlanNode
-
Constructs a new source candidate node that uses NONE as its local strategy.
- SourcePlanNode(DataSourceNode, String, GlobalProperties, LocalProperties) - Constructor for class org.apache.flink.optimizer.plan.SourcePlanNode
-
- SourceStreamTask<OUT,SRC extends SourceFunction<OUT>,OP extends StreamSource<OUT,SRC>> - Class in org.apache.flink.streaming.runtime.tasks
-
- SourceStreamTask(Environment) - Constructor for class org.apache.flink.streaming.runtime.tasks.SourceStreamTask
-
- SourceTransformation<T> - Class in org.apache.flink.streaming.api.transformations
-
This represents a Source.
- SourceTransformation(String, StreamSource<T, ?>, TypeInformation<T>, int) - Constructor for class org.apache.flink.streaming.api.transformations.SourceTransformation
-
Creates a new SourceTransformation
from the given operator.
- SpanningRecordSerializer<T extends IOReadableWritable> - Class in org.apache.flink.runtime.io.network.api.serialization
-
- SpanningRecordSerializer() - Constructor for class org.apache.flink.runtime.io.network.api.serialization.SpanningRecordSerializer
-
- SpecificInstanceCollectionSerializer(Class<T>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.kryo.Serializers.SpecificInstanceCollectionSerializer
-
- SpecificInstanceCollectionSerializerForArrayList() - Constructor for class org.apache.flink.api.java.typeutils.runtime.kryo.Serializers.SpecificInstanceCollectionSerializerForArrayList
-
- spillHeadCopy - Variable in class org.apache.flink.runtime.operators.sort.AbstractMergeIterator
-
- SPILLING_MAX_FAN - Static variable in class org.apache.flink.configuration.AlgorithmOptions
-
- SpillingAdaptiveSpanningRecordDeserializer<T extends IOReadableWritable> - Class in org.apache.flink.runtime.io.network.api.serialization
-
- SpillingAdaptiveSpanningRecordDeserializer(String[]) - Constructor for class org.apache.flink.runtime.io.network.api.serialization.SpillingAdaptiveSpanningRecordDeserializer
-
- SpillingBuffer - Class in org.apache.flink.runtime.io.disk
-
An output view that buffers written data in memory pages and spills them when they are full.
- SpillingBuffer(IOManager, MemorySegmentSource, int) - Constructor for class org.apache.flink.runtime.io.disk.SpillingBuffer
-
- spillingMarker() - Static method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger
-
Gets the element that is passed as marker for signal beginning of spilling.
- SpillingResettableIterator<T> - Class in org.apache.flink.runtime.operators.resettable
-
Implementation of a resettable iterator.
- SpillingResettableIterator(Iterator<T>, TypeSerializer<T>, MemoryManager, IOManager, int, AbstractInvokable) - Constructor for class org.apache.flink.runtime.operators.resettable.SpillingResettableIterator
-
- SpillingResettableIterator(Iterator<T>, TypeSerializer<T>, MemoryManager, IOManager, List<MemorySegment>) - Constructor for class org.apache.flink.runtime.operators.resettable.SpillingResettableIterator
-
- SpillingResettableMutableObjectIterator<T> - Class in org.apache.flink.runtime.operators.resettable
-
Implementation of a resettable iterator.
- SpillingResettableMutableObjectIterator(MutableObjectIterator<T>, TypeSerializer<T>, MemoryManager, IOManager, int, AbstractInvokable) - Constructor for class org.apache.flink.runtime.operators.resettable.SpillingResettableMutableObjectIterator
-
- SpillingResettableMutableObjectIterator(MutableObjectIterator<T>, TypeSerializer<T>, MemoryManager, IOManager, List<MemorySegment>) - Constructor for class org.apache.flink.runtime.operators.resettable.SpillingResettableMutableObjectIterator
-
- SpillingThread(ExceptionHandler<IOException>, UnilateralSortMerger.CircularQueues<E>, AbstractInvokable, MemoryManager, IOManager, TypeSerializer<E>, TypeComparator<E>, List<MemorySegment>, List<MemorySegment>, int) - Constructor for class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SpillingThread
-
Creates the spilling thread.
- spillPartition(List<MemorySegment>, IOManager, FileIOChannel.ID, LinkedBlockingQueue<MemorySegment>) - Method in class org.apache.flink.runtime.operators.hash.HashPartition
-
Spills this partition to disk and sets it up such that it continues spilling records that are added to
it.
- spillPartition() - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
-
Selects a partition and spills it.
- split(OutputSelector<T>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Operator used for directing tuples to specific named outputs using an
OutputSelector
.
- split(OutputSelector<T>) - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
-
- split(OutputSelector<PyObject>) - Method in class org.apache.flink.streaming.python.api.datastream.PythonDataStream
-
- split(int) - Method in class org.apache.flink.util.LongValueSequenceIterator
-
- split(int) - Method in class org.apache.flink.util.NumberSequenceIterator
-
- split(int) - Method in class org.apache.flink.util.SplittableIterator
-
Splits this iterator into a number disjoint iterators.
- SplitDataProperties<T> - Class in org.apache.flink.api.java.io
-
- SplitDataProperties(TypeInformation<T>) - Constructor for class org.apache.flink.api.java.io.SplitDataProperties
-
Creates SplitDataProperties for the given data types.
- SplitDataProperties(DataSource<T>) - Constructor for class org.apache.flink.api.java.io.SplitDataProperties
-
Creates SplitDataProperties for the given data types.
- SplitDataProperties.SourcePartitionerMarker<T> - Class in org.apache.flink.api.java.io
-
A custom partitioner to mark compatible split partitionings.
- splitLength - Variable in class org.apache.flink.api.common.io.FileInputFormat
-
The length of the split that this parallel instance must consume.
- splitsGroupedBy(int...) - Method in class org.apache.flink.api.java.io.SplitDataProperties
-
Defines that the data within an input split is grouped on the fields defined by the field positions.
- splitsGroupedBy(String) - Method in class org.apache.flink.api.java.io.SplitDataProperties
-
Defines that the data within an input split is grouped on the fields defined by the field expressions.
- splitsOrderedBy(int[], Order[]) - Method in class org.apache.flink.api.java.io.SplitDataProperties
-
Defines that the data within an input split is sorted on the fields defined by the field positions
in the specified orders.
- splitsOrderedBy(String, Order[]) - Method in class org.apache.flink.api.java.io.SplitDataProperties
-
Defines that the data within an input split is sorted on the fields defined by the field expressions
in the specified orders.
- splitsPartitionedBy(int...) - Method in class org.apache.flink.api.java.io.SplitDataProperties
-
Defines that data is partitioned across input splits on the fields defined by field positions.
- splitsPartitionedBy(String, int...) - Method in class org.apache.flink.api.java.io.SplitDataProperties
-
Defines that data is partitioned using a specific partitioning method
across input splits on the fields defined by field positions.
- splitsPartitionedBy(String) - Method in class org.apache.flink.api.java.io.SplitDataProperties
-
Defines that data is partitioned across input splits on the fields defined by field expressions.
- splitsPartitionedBy(String, String) - Method in class org.apache.flink.api.java.io.SplitDataProperties
-
Defines that data is partitioned using an identifiable method
across input splits on the fields defined by field expressions.
- splitStart - Variable in class org.apache.flink.api.common.io.FileInputFormat
-
The start of the split that this parallel instance must consume.
- SplitStream<OUT> - Class in org.apache.flink.streaming.api.datastream
-
The SplitStream represents an operator that has been split using an
OutputSelector
.
- SplitStream(DataStream<OUT>, OutputSelector<OUT>) - Constructor for class org.apache.flink.streaming.api.datastream.SplitStream
-
- SplitStreamMapper<T> - Class in org.apache.flink.storm.util
-
- SplitStreamMapper() - Constructor for class org.apache.flink.storm.util.SplitStreamMapper
-
- SplitStreamType<T> - Class in org.apache.flink.storm.util
-
Used by org.apache.flink.storm.wrappers.AbstractStormCollector to wrap
output tuples if multiple output streams are declared.
- SplitStreamType() - Constructor for class org.apache.flink.storm.util.SplitStreamType
-
- SplittableIterator<T> - Class in org.apache.flink.util
-
Abstract base class for iterators that can split themselves into multiple disjoint
iterators.
- SplittableIterator() - Constructor for class org.apache.flink.util.SplittableIterator
-
- SplitTransformation<T> - Class in org.apache.flink.streaming.api.transformations
-
- SplitTransformation(StreamTransformation<T>, OutputSelector<T>) - Constructor for class org.apache.flink.streaming.api.transformations.SplitTransformation
-
Creates a new SplitTransformation
from the given input and OutputSelector
.
- SpoutSourceWordCount - Class in org.apache.flink.storm.wordcount
-
Implements the "WordCount" program that computes a simple word occurrence histogram over text files in a streaming
fashion.
- SpoutSourceWordCount() - Constructor for class org.apache.flink.storm.wordcount.SpoutSourceWordCount
-
- SpoutSourceWordCount.Tokenizer - Class in org.apache.flink.storm.wordcount
-
Implements the string tokenizer that splits sentences into words as a user-defined FlatMapFunction.
- SpoutSplitExample - Class in org.apache.flink.storm.split
-
Implements a simple example with two declared output streams for the embedded spout.
- SpoutSplitExample() - Constructor for class org.apache.flink.storm.split.SpoutSplitExample
-
- SpoutSplitExample.Enrich - Class in org.apache.flink.storm.split
-
- SpoutWrapper<OUT> - Class in org.apache.flink.storm.wrappers
-
A
SpoutWrapper
wraps an
IRichSpout
in order to execute it within a Flink Streaming program.
- SpoutWrapper(IRichSpout) - Constructor for class org.apache.flink.storm.wrappers.SpoutWrapper
-
Instantiates a new
SpoutWrapper
that calls the
nextTuple()
method of
the given
spout
in an infinite loop.
- SpoutWrapper(IRichSpout, Integer) - Constructor for class org.apache.flink.storm.wrappers.SpoutWrapper
-
Instantiates a new
SpoutWrapper
that calls the
nextTuple()
method of
the given
spout
a finite number of times.
- SpoutWrapper(IRichSpout, String[]) - Constructor for class org.apache.flink.storm.wrappers.SpoutWrapper
-
Instantiates a new
SpoutWrapper
that calls the
nextTuple()
method of
the given
spout
in an infinite loop.
- SpoutWrapper(IRichSpout, String[], Integer) - Constructor for class org.apache.flink.storm.wrappers.SpoutWrapper
-
Instantiates a new
SpoutWrapper
that calls the
nextTuple()
method of
the given
spout
a finite number of times.
- SpoutWrapper(IRichSpout, Collection<String>) - Constructor for class org.apache.flink.storm.wrappers.SpoutWrapper
-
Instantiates a new
SpoutWrapper
that calls the
nextTuple()
method of
the given
spout
in an infinite loop.
- SpoutWrapper(IRichSpout, Collection<String>, Integer) - Constructor for class org.apache.flink.storm.wrappers.SpoutWrapper
-
Instantiates a new
SpoutWrapper
that calls the
nextTuple()
method of
the given
spout
a finite number of times.
- SpoutWrapper(IRichSpout, String, Collection<String>, Integer) - Constructor for class org.apache.flink.storm.wrappers.SpoutWrapper
-
Instantiates a new
SpoutWrapper
that calls the
nextTuple()
method of
the given
spout
a finite number of times.
- SQL_DATE - Static variable in class org.apache.flink.api.common.typeinfo.Types
-
Returns type information for
Date
.
- SQL_TIME - Static variable in class org.apache.flink.api.common.typeinfo.Types
-
Returns type information for
Time
.
- SQL_TIMESTAMP - Static variable in class org.apache.flink.api.common.typeinfo.Types
-
- SqlClient - Class in org.apache.flink.table.client
-
SQL Client for submitting SQL statements.
- SqlClient(boolean, CliOptions) - Constructor for class org.apache.flink.table.client.SqlClient
-
- SqlClientException - Exception in org.apache.flink.table.client
-
General exception for SQL client related errors.
- SqlClientException(String) - Constructor for exception org.apache.flink.table.client.SqlClientException
-
- SqlClientException(String, Throwable) - Constructor for exception org.apache.flink.table.client.SqlClientException
-
- SqlClientException(Throwable) - Constructor for exception org.apache.flink.table.client.SqlClientException
-
- SqlCommandCall(SqlCommandParser.SqlCommand, String[]) - Constructor for class org.apache.flink.table.client.cli.SqlCommandParser.SqlCommandCall
-
- SqlCommandParser - Class in org.apache.flink.table.client.cli
-
Simple parser for determining the type of command and its parameters.
- SqlCommandParser.SqlCommandCall - Class in org.apache.flink.table.client.cli
-
Call of SQL command with operands and command type.
- SqlDateParser - Class in org.apache.flink.types.parser
-
Parses a text field into a
Date
.
- SqlDateParser() - Constructor for class org.apache.flink.types.parser.SqlDateParser
-
- SqlDateSerializer - Class in org.apache.flink.api.common.typeutils.base
-
- SqlDateSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.SqlDateSerializer
-
- SqlExecutionException - Exception in org.apache.flink.table.client.gateway
-
Exception thrown during the execution of SQL statements.
- SqlExecutionException(String) - Constructor for exception org.apache.flink.table.client.gateway.SqlExecutionException
-
- SqlExecutionException(String, Throwable) - Constructor for exception org.apache.flink.table.client.gateway.SqlExecutionException
-
- SqlTimeParser - Class in org.apache.flink.types.parser
-
Parses a text field into a
Time
.
- SqlTimeParser() - Constructor for class org.apache.flink.types.parser.SqlTimeParser
-
- SqlTimeSerializer - Class in org.apache.flink.api.common.typeutils.base
-
- SqlTimeSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.SqlTimeSerializer
-
- SqlTimestampComparator - Class in org.apache.flink.api.common.typeutils.base
-
Comparator for comparing Java SQL Timestamps.
- SqlTimestampComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.SqlTimestampComparator
-
- SqlTimestampParser - Class in org.apache.flink.types.parser
-
- SqlTimestampParser() - Constructor for class org.apache.flink.types.parser.SqlTimestampParser
-
- SqlTimestampSerializer - Class in org.apache.flink.api.common.typeutils.base
-
- SqlTimestampSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.SqlTimestampSerializer
-
- SqlTimeTypeInfo<T> - Class in org.apache.flink.api.common.typeinfo
-
Type information for Java SQL Date/Time/Timestamp.
- SqlTimeTypeInfo(Class<T>, TypeSerializer<T>, Class<? extends TypeComparator<T>>) - Constructor for class org.apache.flink.api.common.typeinfo.SqlTimeTypeInfo
-
- SRC_EDGE_TO_BE_REMOVED - Static variable in class org.apache.flink.graph.examples.data.IncrementalSSSPData
-
- SRC_VERTEX_ID - Static variable in class org.apache.flink.graph.examples.data.SingleSourceShortestPathsData
-
- SSL_ALGORITHMS - Static variable in class org.apache.flink.configuration.SecurityOptions
-
The standard SSL algorithms to be supported.
- SSL_CLOSE_NOTIFY_FLUSH_TIMEOUT - Static variable in class org.apache.flink.configuration.SecurityOptions
-
SSL session timeout after flushing the close_notify message.
- SSL_ENABLED - Static variable in class org.apache.flink.configuration.AkkaOptions
-
Override SSL support for the Akka transport.
- SSL_ENABLED - Static variable in class org.apache.flink.configuration.BlobServerOptions
-
Flag to override ssl support for the blob service transport.
- SSL_ENABLED - Static variable in class org.apache.flink.configuration.SecurityOptions
-
Enable SSL support.
- SSL_ENABLED - Static variable in class org.apache.flink.configuration.WebOptions
-
Config parameter to override SSL support for the JobManager Web UI.
- SSL_HANDSHAKE_TIMEOUT - Static variable in class org.apache.flink.configuration.SecurityOptions
-
SSL session timeout during handshakes.
- SSL_KEY_PASSWORD - Static variable in class org.apache.flink.configuration.SecurityOptions
-
Secret to decrypt the server key.
- SSL_KEYSTORE - Static variable in class org.apache.flink.configuration.SecurityOptions
-
The Java keystore file containing the flink endpoint key and certificate.
- SSL_KEYSTORE_PASSWORD - Static variable in class org.apache.flink.configuration.SecurityOptions
-
Secret to decrypt the keystore file.
- SSL_PROTOCOL - Static variable in class org.apache.flink.configuration.SecurityOptions
-
SSL protocol version to be supported.
- SSL_SESSION_CACHE_SIZE - Static variable in class org.apache.flink.configuration.SecurityOptions
-
SSL session cache size.
- SSL_SESSION_TIMEOUT - Static variable in class org.apache.flink.configuration.SecurityOptions
-
SSL session timeout.
- SSL_TRUSTSTORE - Static variable in class org.apache.flink.configuration.SecurityOptions
-
The truststore file containing the public CA certificates to verify the ssl peers.
- SSL_TRUSTSTORE_PASSWORD - Static variable in class org.apache.flink.configuration.SecurityOptions
-
Secret to decrypt the truststore.
- SSL_VERIFY_HOSTNAME - Static variable in class org.apache.flink.configuration.SecurityOptions
-
Flag to enable/disable hostname verification for the ssl connections.
- SSLContext(SSLContext, int, int) - Constructor for class org.apache.flink.runtime.net.SSLUtils.SSLContext
-
- SSLEngineFactory - Class in org.apache.flink.runtime.net
-
- SSLEngineFactory(SSLContext, String[], String[], boolean) - Constructor for class org.apache.flink.runtime.net.SSLEngineFactory
-
- SSLStoreOverlay - Class in org.apache.flink.runtime.clusterframework.overlays
-
Overlays an SSL keystore/truststore into a container.
- SSLStoreOverlay(File, File) - Constructor for class org.apache.flink.runtime.clusterframework.overlays.SSLStoreOverlay
-
- SSLStoreOverlay.Builder - Class in org.apache.flink.runtime.clusterframework.overlays
-
- SSLUtils - Class in org.apache.flink.runtime.net
-
Common utilities to manage SSL transport settings.
- SSLUtils() - Constructor for class org.apache.flink.runtime.net.SSLUtils
-
- SSLUtils.SSLContext - Class in org.apache.flink.runtime.net
-
Wrapper around javax.net.ssl.SSLContext, adding SSL handshake and close notify timeouts
which cannot be set on the SSL context directly.
- SSSPCombiner() - Constructor for class org.apache.flink.graph.examples.PregelSSSP.SSSPCombiner
-
- SSSPComputeFunction(long) - Constructor for class org.apache.flink.graph.examples.PregelSSSP.SSSPComputeFunction
-
- StackTrace - Class in org.apache.flink.runtime.messages
-
- StackTrace(InstanceID, String) - Constructor for class org.apache.flink.runtime.messages.StackTrace
-
- StackTraceSample - Class in org.apache.flink.runtime.rest.handler.legacy.backpressure
-
A sample of stack traces for one or more tasks.
- StackTraceSample(int, long, long, Map<ExecutionAttemptID, List<StackTraceElement[]>>) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.backpressure.StackTraceSample
-
Creates a stack trace sample.
- StackTraceSampleCoordinator - Class in org.apache.flink.runtime.rest.handler.legacy.backpressure
-
A coordinator for triggering and collecting stack traces of running tasks.
- StackTraceSampleCoordinator(Executor, long) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.backpressure.StackTraceSampleCoordinator
-
Creates a new coordinator for the job.
- StackTraceSampleResponse - Class in org.apache.flink.runtime.messages
-
Response to the TriggerStackTraceSample message.
- StackTraceSampleResponse(int, ExecutionAttemptID, List<StackTraceElement[]>) - Constructor for class org.apache.flink.runtime.messages.StackTraceSampleResponse
-
- StandaloneCheckpointIDCounter - Class in org.apache.flink.runtime.checkpoint
-
- StandaloneCheckpointIDCounter() - Constructor for class org.apache.flink.runtime.checkpoint.StandaloneCheckpointIDCounter
-
- StandaloneCheckpointRecoveryFactory - Class in org.apache.flink.runtime.checkpoint
-
- StandaloneCheckpointRecoveryFactory() - Constructor for class org.apache.flink.runtime.checkpoint.StandaloneCheckpointRecoveryFactory
-
- StandaloneClusterClient - Class in org.apache.flink.client.program
-
Cluster client for communication with an standalone (on-premise) cluster or an existing cluster that has been
brought up independently of a specific job.
- StandaloneClusterClient(Configuration) - Constructor for class org.apache.flink.client.program.StandaloneClusterClient
-
- StandaloneClusterClient(Configuration, HighAvailabilityServices, boolean) - Constructor for class org.apache.flink.client.program.StandaloneClusterClient
-
- StandaloneClusterDescriptor - Class in org.apache.flink.client.deployment
-
A deployment descriptor for an existing cluster.
- StandaloneClusterDescriptor(Configuration) - Constructor for class org.apache.flink.client.deployment.StandaloneClusterDescriptor
-
- StandaloneClusterId - Class in org.apache.flink.client.deployment
-
Identifier for standalone clusters.
- StandaloneCompletedCheckpointStore - Class in org.apache.flink.runtime.checkpoint
-
- StandaloneCompletedCheckpointStore(int) - Constructor for class org.apache.flink.runtime.checkpoint.StandaloneCompletedCheckpointStore
-
- StandaloneDispatcher - Class in org.apache.flink.runtime.dispatcher
-
Dispatcher implementation which spawns a
JobMaster
for each
submitted
JobGraph
within in the same process.
- StandaloneDispatcher(RpcService, String, Configuration, HighAvailabilityServices, ResourceManagerGateway, BlobServer, HeartbeatServices, JobManagerMetricGroup, String, ArchivedExecutionGraphStore, Dispatcher.JobManagerRunnerFactory, FatalErrorHandler, String, HistoryServerArchivist) - Constructor for class org.apache.flink.runtime.dispatcher.StandaloneDispatcher
-
- StandaloneHaServices - Class in org.apache.flink.runtime.highavailability.nonha.standalone
-
- StandaloneHaServices(String, String, String, String) - Constructor for class org.apache.flink.runtime.highavailability.nonha.standalone.StandaloneHaServices
-
Creates a new services class for the fix pre-defined leaders.
- StandaloneLeaderElectionService - Class in org.apache.flink.runtime.leaderelection
-
- StandaloneLeaderElectionService() - Constructor for class org.apache.flink.runtime.leaderelection.StandaloneLeaderElectionService
-
- StandaloneLeaderRetrievalService - Class in org.apache.flink.runtime.leaderretrieval
-
- StandaloneLeaderRetrievalService(String) - Constructor for class org.apache.flink.runtime.leaderretrieval.StandaloneLeaderRetrievalService
-
- StandaloneLeaderRetrievalService(String, UUID) - Constructor for class org.apache.flink.runtime.leaderretrieval.StandaloneLeaderRetrievalService
-
Creates a StandaloneLeaderRetrievalService with the given leader address.
- StandaloneMesosServices - Class in org.apache.flink.mesos.runtime.clusterframework.services
-
- StandaloneMesosServices(ActorSystem, MesosArtifactServer) - Constructor for class org.apache.flink.mesos.runtime.clusterframework.services.StandaloneMesosServices
-
- StandaloneMesosWorkerStore - Class in org.apache.flink.mesos.runtime.clusterframework.store
-
A standalone Mesos worker store.
- StandaloneMesosWorkerStore() - Constructor for class org.apache.flink.mesos.runtime.clusterframework.store.StandaloneMesosWorkerStore
-
- StandaloneMiniCluster - Class in org.apache.flink.runtime.minicluster
-
Mini cluster to run the old JobManager code without embedded high availability services.
- StandaloneMiniCluster(Configuration) - Constructor for class org.apache.flink.runtime.minicluster.StandaloneMiniCluster
-
- StandaloneResourceManager - Class in org.apache.flink.runtime.clusterframework.standalone
-
A standalone implementation of the resource manager.
- StandaloneResourceManager(Configuration, LeaderRetrievalService) - Constructor for class org.apache.flink.runtime.clusterframework.standalone.StandaloneResourceManager
-
- StandaloneResourceManager - Class in org.apache.flink.runtime.resourcemanager
-
A standalone implementation of the resource manager.
- StandaloneResourceManager(RpcService, String, ResourceID, ResourceManagerConfiguration, HighAvailabilityServices, HeartbeatServices, SlotManager, MetricRegistry, JobLeaderIdService, ClusterInformation, FatalErrorHandler, JobManagerMetricGroup) - Constructor for class org.apache.flink.runtime.resourcemanager.StandaloneResourceManager
-
- StandaloneRunningJobsRegistry - Class in org.apache.flink.runtime.highavailability.nonha.standalone
-
A registry for running jobs, not-highly available.
- StandaloneRunningJobsRegistry() - Constructor for class org.apache.flink.runtime.highavailability.nonha.standalone.StandaloneRunningJobsRegistry
-
- StandaloneSessionClusterEntrypoint - Class in org.apache.flink.runtime.entrypoint
-
Entry point for the standalone session cluster.
- StandaloneSessionClusterEntrypoint(Configuration) - Constructor for class org.apache.flink.runtime.entrypoint.StandaloneSessionClusterEntrypoint
-
- StandaloneSubmittedJobGraphStore - Class in org.apache.flink.runtime.jobmanager
-
- StandaloneSubmittedJobGraphStore() - Constructor for class org.apache.flink.runtime.jobmanager.StandaloneSubmittedJobGraphStore
-
- StandaloneThreadedGenerator - Class in org.apache.flink.streaming.examples.statemachine.generator
-
Base for standalone generators that use the state machine to create event
sequences and push them for example into Kafka.
- StandaloneThreadedGenerator() - Constructor for class org.apache.flink.streaming.examples.statemachine.generator.StandaloneThreadedGenerator
-
- StandaloneUtils - Class in org.apache.flink.runtime.util
-
Utility class to work with Flink standalone mode.
- StandardNiFiDataPacket - Class in org.apache.flink.streaming.connectors.nifi
-
An implementation of NiFiDataPacket.
- StandardNiFiDataPacket(byte[], Map<String, String>) - Constructor for class org.apache.flink.streaming.connectors.nifi.StandardNiFiDataPacket
-
- StarGraph - Class in org.apache.flink.graph.drivers.input
-
- StarGraph() - Constructor for class org.apache.flink.graph.drivers.input.StarGraph
-
- StarGraph - Class in org.apache.flink.graph.generator
-
- StarGraph(ExecutionEnvironment, long) - Constructor for class org.apache.flink.graph.generator.StarGraph
-
An undirected
Graph
with
n
vertices where the single
central node has degree
n-1
, connecting to the other
n-1
vertices which have degree
1
.
- start() - Method in class org.apache.flink.api.common.PlanExecutor
-
Starts the program executor.
- start() - Method in class org.apache.flink.client.LocalExecutor
-
- start() - Method in class org.apache.flink.client.RemoteExecutor
-
- start() - Method in interface org.apache.flink.mesos.runtime.clusterframework.store.MesosWorkerStore
-
Start the worker store.
- start() - Method in class org.apache.flink.mesos.runtime.clusterframework.store.StandaloneMesosWorkerStore
-
- start() - Method in class org.apache.flink.mesos.runtime.clusterframework.store.ZooKeeperMesosWorkerStore
-
- start() - Method in class org.apache.flink.queryablestate.client.proxy.KvStateClientProxyImpl
-
- start() - Method in class org.apache.flink.queryablestate.network.AbstractServerBase
-
Starts the server by binding to the configured bind address (blocking).
- start() - Method in class org.apache.flink.queryablestate.server.KvStateServerImpl
-
- start() - Method in interface org.apache.flink.runtime.checkpoint.CheckpointIDCounter
-
- start() - Method in class org.apache.flink.runtime.checkpoint.StandaloneCheckpointIDCounter
-
- start() - Method in class org.apache.flink.runtime.checkpoint.ZooKeeperCheckpointIDCounter
-
- start() - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
-
- start(SubmittedJobGraphStore.SubmittedJobGraphListener) - Method in class org.apache.flink.runtime.dispatcher.SingleJobSubmittedJobGraphStore
-
- start(LeaderContender) - Method in class org.apache.flink.runtime.highavailability.nonha.leaderelection.SingleLeaderElectionService
-
- start(ResultPartitionProvider, TaskEventDispatcher) - Method in interface org.apache.flink.runtime.io.network.ConnectionManager
-
- start(ResultPartitionProvider, TaskEventDispatcher) - Method in class org.apache.flink.runtime.io.network.LocalConnectionManager
-
- start(ResultPartitionProvider, TaskEventDispatcher) - Method in class org.apache.flink.runtime.io.network.netty.NettyConnectionManager
-
- start() - Method in class org.apache.flink.runtime.io.network.NetworkEnvironment
-
- start(SubmittedJobGraphStore.SubmittedJobGraphListener) - Method in class org.apache.flink.runtime.jobmanager.StandaloneSubmittedJobGraphStore
-
- start(SubmittedJobGraphStore.SubmittedJobGraphListener) - Method in interface org.apache.flink.runtime.jobmanager.SubmittedJobGraphStore
-
- start(SubmittedJobGraphStore.SubmittedJobGraphListener) - Method in class org.apache.flink.runtime.jobmanager.ZooKeeperSubmittedJobGraphStore
-
- start() - Method in class org.apache.flink.runtime.jobmaster.JobManagerRunner
-
- start() - Method in class org.apache.flink.runtime.jobmaster.JobMaster
-
- start(JobMasterId, Time) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
-
Start the rpc service and begin to run the job.
- start() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotPool
-
- start(JobMasterId, String) - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotPool
-
Start the slot pool to accept RPC calls.
- start(LeaderContender) - Method in interface org.apache.flink.runtime.leaderelection.LeaderElectionService
-
Starts the leader election service.
- start(LeaderContender) - Method in class org.apache.flink.runtime.leaderelection.StandaloneLeaderElectionService
-
- start(LeaderContender) - Method in class org.apache.flink.runtime.leaderelection.ZooKeeperLeaderElectionService
-
- start(LeaderRetrievalListener) - Method in interface org.apache.flink.runtime.leaderretrieval.LeaderRetrievalService
-
Starts the leader retrieval service with the given listener to listen for new leaders.
- start(LeaderRetrievalListener) - Method in class org.apache.flink.runtime.leaderretrieval.SettableLeaderRetrievalService
-
- start(LeaderRetrievalListener) - Method in class org.apache.flink.runtime.leaderretrieval.StandaloneLeaderRetrievalService
-
- start(LeaderRetrievalListener) - Method in class org.apache.flink.runtime.leaderretrieval.ZooKeeperLeaderRetrievalService
-
- start() - Method in class org.apache.flink.runtime.minicluster.MiniCluster
-
Starts the mini cluster, based on the configured properties.
- start() - Method in interface org.apache.flink.runtime.query.KvStateServer
-
Starts the server.
- start() - Method in class org.apache.flink.runtime.registration.RegisteredRpcConnection
-
- start(JobLeaderIdActions) - Method in class org.apache.flink.runtime.resourcemanager.JobLeaderIdService
-
Start the service with the given job leader actions.
- start() - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
-
- start() - Method in class org.apache.flink.runtime.resourcemanager.ResourceManagerRunner
-
- start(ResourceManagerId, Executor, ResourceActions) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
-
Starts the slot manager with the given leader id and resource manager actions.
- start() - Method in class org.apache.flink.runtime.rest.RestServerEndpoint
-
Starts this REST server endpoint.
- start() - Method in class org.apache.flink.runtime.rpc.RpcEndpoint
-
Starts the rpc endpoint.
- start() - Method in interface org.apache.flink.runtime.rpc.StartStoppable
-
Starts the processing of remote procedure calls.
- start(String, RpcService, HighAvailabilityServices, JobLeaderListener) - Method in class org.apache.flink.runtime.taskexecutor.JobLeaderService
-
Start the job leader service with the given services.
- start(SlotActions) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
-
Start the task slot table with the given slot actions and slot timeout value.
- start(TimeoutListener<K>) - Method in class org.apache.flink.runtime.taskexecutor.slot.TimerService
-
- start() - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutor
-
- start() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerRunner
-
- start() - Method in interface org.apache.flink.runtime.webmonitor.WebMonitor
-
Starts the web monitor.
- start() - Method in class org.apache.flink.runtime.webmonitor.WebRuntimeMonitor
-
- start() - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperSharedCount
-
- start() - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperSharedValue
-
- start() - Method in interface org.apache.flink.table.client.gateway.Executor
-
Starts the executor and ensures that its is ready for commands to be executed.
- start() - Method in class org.apache.flink.table.client.gateway.local.LocalExecutor
-
- startActorSystem(Configuration, String, String, Logger) - Static method in class org.apache.flink.runtime.clusterframework.BootstrapTools
-
Starts an ActorSystem with the given configuration listening at the address/ports.
- startActorSystem(Configuration, String, int, Logger) - Static method in class org.apache.flink.runtime.clusterframework.BootstrapTools
-
Starts an Actor System at a specific port.
- startAppMaster(Configuration, String, String, JobGraph, YarnClient, YarnClientApplication, ClusterSpecification) - Method in class org.apache.flink.yarn.AbstractYarnClusterDescriptor
-
- startCheckpointScheduler() - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
- startCluster() - Method in class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
-
- startCluster(int, int, boolean, boolean, boolean) - Static method in class org.apache.flink.test.util.TestBaseUtils
-
- startCluster(Configuration, boolean) - Static method in class org.apache.flink.test.util.TestBaseUtils
-
- startClusterComponents(Configuration, RpcService, HighAvailabilityServices, BlobServer, HeartbeatServices, MetricRegistry) - Method in class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
-
- startCuratorFramework(Configuration) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
-
Starts a CuratorFramework
instance and connects it to the given ZooKeeper
quorum.
- startFromEarliest() - Method in class org.apache.flink.table.descriptors.Kafka
-
Configures to start reading from the earliest offset for all partitions.
- startFromGroupOffsets() - Method in class org.apache.flink.table.descriptors.Kafka
-
Configures to start reading from any committed group offsets found in Zookeeper / Kafka brokers.
- startFromLatest() - Method in class org.apache.flink.table.descriptors.Kafka
-
Configures to start reading from the latest offset for all partitions.
- startFromSpecificOffset(int, long) - Method in class org.apache.flink.table.descriptors.Kafka
-
Configures to start reading partitions from specific offsets and specifies the given offset for
the given partition.
- startFromSpecificOffsets(Map<Integer, Long>) - Method in class org.apache.flink.table.descriptors.Kafka
-
Configures to start reading partitions from specific offsets, set independently for each partition.
- startIfConfigured(Logger, Configuration, ActorSystem) - Static method in class org.apache.flink.runtime.taskmanager.MemoryLogger
-
- startInternal() - Method in class org.apache.flink.runtime.rest.RestServerEndpoint
-
Hook to start sub class specific services.
- startInternal() - Method in class org.apache.flink.runtime.webmonitor.WebMonitorEndpoint
-
- startItem() - Method in class org.apache.flink.formats.avro.utils.DataOutputEncoder
-
- startJobClientActorSystem(Configuration, String) - Static method in class org.apache.flink.runtime.client.JobClient
-
- startMetricQueryService(ActorSystem, ResourceID, long) - Static method in class org.apache.flink.runtime.metrics.dump.MetricQueryService
-
Starts the MetricQueryService actor in the given actor system.
- startNewChain() - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
-
Starts a new task chain beginning at this operator.
- startNewKey(K) - Method in interface org.apache.flink.streaming.runtime.operators.windowing.KeyMap.TraversalEvaluator
-
Called whenever the traversal starts with a new key.
- startNewKeyGroup(int) - Method in class org.apache.flink.runtime.state.KeyedStateCheckpointOutputStream
-
User code can call this method to signal that it begins to write a new key group with the given key group id.
- startNewPartition() - Method in class org.apache.flink.runtime.state.OperatorStateCheckpointOutputStream
-
User code can call this method to signal that it begins to write a new partition of operator state.
- startNewSession() - Method in class org.apache.flink.api.java.CollectionEnvironment
-
- startNewSession() - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
Starts a new session, discarding the previous data flow and all of its intermediate results.
- startNewSession() - Method in class org.apache.flink.api.java.LocalEnvironment
-
- startNewSession() - Method in class org.apache.flink.api.java.RemoteEnvironment
-
- startNewSession() - Method in class org.apache.flink.client.program.ContextEnvironment
-
- startNewSession() - Method in class org.apache.flink.client.program.OptimizerPlanEnvironment
-
- startNewSession() - Method in class org.apache.flink.client.program.PreviewPlanEnvironment
-
- startNewSession() - Method in class org.apache.flink.test.util.TestEnvironment
-
- startNewWorker(ResourceProfile) - Method in class org.apache.flink.mesos.runtime.clusterframework.MesosResourceManager
-
- startNewWorker(ResourceProfile) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
-
Allocates a resource using the resource profile.
- startNewWorker(ResourceProfile) - Method in class org.apache.flink.runtime.resourcemanager.StandaloneResourceManager
-
- startNewWorker(ResourceProfile) - Method in class org.apache.flink.yarn.YarnResourceManager
-
- startNextSuperstep() - Method in class org.apache.flink.runtime.io.network.api.reader.AbstractReader
-
- startNextSuperstep() - Method in interface org.apache.flink.runtime.io.network.api.reader.ReaderBase
-
- startQueryService(ActorSystem, ResourceID) - Method in class org.apache.flink.runtime.metrics.MetricRegistryImpl
-
Initializes the MetricQueryService.
- startReading() - Method in class org.apache.flink.runtime.operators.TempBarrier
-
- startRecord() - Method in class org.apache.flink.api.common.io.BinaryOutputFormat.BlockBasedOutput
-
- startRegistration() - Method in class org.apache.flink.runtime.registration.RetryingRegistration
-
This method resolves the target address to a callable gateway and starts the
registration after that.
- startResourceManager(Configuration, HighAvailabilityServices, HeartbeatServices, MetricRegistry, RpcService, ClusterInformation, JobManagerMetricGroup) - Method in class org.apache.flink.runtime.minicluster.MiniCluster
-
- startResourceManagerActors(Configuration, ActorSystem, LeaderRetrievalService, Class<? extends FlinkResourceManager<?>>) - Static method in class org.apache.flink.runtime.clusterframework.FlinkResourceManager
-
Starts the resource manager actors.
- startResourceManagerActors(Configuration, ActorSystem, LeaderRetrievalService, Class<? extends FlinkResourceManager<?>>, String) - Static method in class org.apache.flink.runtime.clusterframework.FlinkResourceManager
-
Starts the resource manager actors.
- startRetrieval(Runnable) - Method in class org.apache.flink.table.client.gateway.local.CollectStreamResult
-
- startRetrieval(Runnable) - Method in interface org.apache.flink.table.client.gateway.local.DynamicResult
-
Starts the table program using the given runnable and monitors it's execution.
- startServer(C) - Method in class org.apache.flink.runtime.rpc.akka.AkkaRpcService
-
- startServer(C) - Method in interface org.apache.flink.runtime.rpc.RpcService
-
Start a rpc server which forwards the remote procedure calls to the provided rpc endpoint.
- StartStoppable - Interface in org.apache.flink.runtime.rpc
-
Interface to start and stop the processing of rpc calls in the rpc server.
- startsWith(CharSequence, int) - Method in class org.apache.flink.types.StringValue
-
Checks whether the substring, starting at the specified index, starts with the given prefix string.
- startsWith(CharSequence) - Method in class org.apache.flink.types.StringValue
-
Checks whether this StringValue starts with the given prefix string.
- startTaskManager(Configuration, ResourceID, RpcService, HighAvailabilityServices, HeartbeatServices, MetricRegistry, BlobCacheService, boolean, FatalErrorHandler) - Static method in class org.apache.flink.runtime.taskexecutor.TaskManagerRunner
-
- startTaskManagers(Configuration, HighAvailabilityServices, HeartbeatServices, MetricRegistry, BlobCacheService, int, RpcService[]) - Method in class org.apache.flink.runtime.minicluster.MiniCluster
-
- startTaskThread() - Method in class org.apache.flink.runtime.taskmanager.Task
-
Starts the task's thread.
- startThreads() - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger
-
Starts all the threads that are used by this sort-merger.
- startTimerService(TypeSerializer<K>, TypeSerializer<N>, Triggerable<K, N>) - Method in class org.apache.flink.streaming.api.operators.HeapInternalTimerService
-
Starts the local
HeapInternalTimerService
by:
Setting the
keySerialized
and
namespaceSerializer
for the timers it will contain.
Setting the
triggerTarget
which contains the action to be performed when a timer fires.
Re-registering timers that were retrieved after recovering from a node failure, if any.
This method can be called multiple times, as long as it is called with the same serializers.
- STARTUP_FAILURE_RETURN_CODE - Static variable in class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
-
- STARTUP_TIMEOUT - Static variable in class org.apache.flink.configuration.AkkaOptions
-
Timeout for the startup of the actor system.
- StartupMode - Enum in org.apache.flink.streaming.connectors.kafka.config
-
Startup modes for the Kafka Consumer.
- startWebMonitorIfConfigured(Configuration, HighAvailabilityServices, LeaderGatewayRetriever<JobManagerGateway>, MetricQueryServiceRetriever, Time, ScheduledExecutor, Logger) - Static method in class org.apache.flink.runtime.clusterframework.BootstrapTools
-
Starts the web frontend.
- startWebRuntimeMonitor(Configuration, HighAvailabilityServices, LeaderGatewayRetriever<JobManagerGateway>, MetricQueryServiceRetriever, Time, ScheduledExecutor) - Static method in class org.apache.flink.runtime.webmonitor.WebMonitorUtils
-
Starts the web runtime monitor.
- State - Interface in org.apache.flink.api.common.state
-
Interface that different types of partitioned state must implement.
- State<T> - Class in org.apache.flink.cep.nfa
-
Represents a state of the
NFA
.
- State(String, State.StateType) - Constructor for class org.apache.flink.cep.nfa.State
-
- state() - Method in class org.apache.flink.mesos.runtime.clusterframework.store.MesosWorkerStore.Worker
-
Get the worker's state.
- state - Variable in class org.apache.flink.runtime.state.SnapshotDirectory
-
This reference tracks the lifecycle state of the snapshot directory.
- state - Variable in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
-
- State() - Constructor for class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.State
-
- State(TwoPhaseCommitSinkFunction.TransactionHolder<TXN>, List<TwoPhaseCommitSinkFunction.TransactionHolder<TXN>>, Optional<CONTEXT>) - Constructor for class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.State
-
- state - Variable in class org.apache.flink.streaming.examples.statemachine.dfa.EventTypeAndState
-
- State - Enum in org.apache.flink.streaming.examples.statemachine.dfa
-
The State captures the main functionality of the state machine.
- state() - Method in class org.apache.flink.streaming.examples.statemachine.event.Alert
-
- State.StateType - Enum in org.apache.flink.cep.nfa
-
Set of valid state types.
- STATE_BACKEND - Static variable in class org.apache.flink.configuration.CheckpointingOptions
-
The state backend to be used to store and checkpoint state.
- STATE_BACKEND - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- StateAssignmentOperation - Class in org.apache.flink.runtime.checkpoint
-
This class encapsulates the operation of assigning restored state when restoring from a checkpoint.
- StateAssignmentOperation(long, Map<JobVertexID, ExecutionJobVertex>, Map<OperatorID, OperatorState>, boolean) - Constructor for class org.apache.flink.runtime.checkpoint.StateAssignmentOperation
-
- StateBackend - Interface in org.apache.flink.runtime.state
-
A State Backend defines how the state of a streaming application is stored and
checkpointed.
- stateBackend - Variable in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
Our state backend.
- StateBackendFactory<T extends StateBackend> - Interface in org.apache.flink.runtime.state
-
A factory to create a specific state backend.
- StateBackendLoader - Class in org.apache.flink.runtime.state
-
This class contains utility methods to load state backends from configurations.
- StateBinder - Interface in org.apache.flink.api.common.state
-
- StateDescriptor<S extends State,T> - Class in org.apache.flink.api.common.state
-
Base class for state descriptors.
- StateDescriptor(String, TypeSerializer<T>, T) - Constructor for class org.apache.flink.api.common.state.StateDescriptor
-
Create a new StateDescriptor
with the given name and the given type serializer.
- StateDescriptor(String, TypeInformation<T>, T) - Constructor for class org.apache.flink.api.common.state.StateDescriptor
-
Create a new StateDescriptor
with the given name and the given type information.
- StateDescriptor(String, Class<T>, T) - Constructor for class org.apache.flink.api.common.state.StateDescriptor
-
Create a new StateDescriptor
with the given name and the given type information.
- StateDescriptor.Type - Enum in org.apache.flink.api.common.state
-
An enumeration of the types of supported states.
- StateEntry<K,N,S> - Interface in org.apache.flink.runtime.state.heap
-
Interface of entries in a state table.
- StatefulSequenceSource - Class in org.apache.flink.streaming.api.functions.source
-
A stateful streaming source that emits each number from a given interval exactly once,
possibly in parallel.
- StatefulSequenceSource(long, long) - Constructor for class org.apache.flink.streaming.api.functions.source.StatefulSequenceSource
-
Creates a source that emits all numbers from the given interval exactly once.
- StatefulStreamJobUpgradeTestProgram - Class in org.apache.flink.streaming.tests
-
Test upgrade of generic stateful job for Flink's DataStream API operators and primitives.
- StatefulStreamJobUpgradeTestProgram() - Constructor for class org.apache.flink.streaming.tests.StatefulStreamJobUpgradeTestProgram
-
- StateHandleID - Class in org.apache.flink.runtime.state
-
Unique ID that allows for logical comparison between state handles.
- StateHandleID(String) - Constructor for class org.apache.flink.runtime.state.StateHandleID
-
- StateInitializationContext - Interface in org.apache.flink.runtime.state
-
This interface provides a context in which operators can initialize by registering to managed state (i.e.
- StateInitializationContextImpl - Class in org.apache.flink.runtime.state
-
- StateInitializationContextImpl(boolean, OperatorStateStore, KeyedStateStore, Iterable<KeyGroupStatePartitionStreamProvider>, Iterable<StatePartitionStreamProvider>) - Constructor for class org.apache.flink.runtime.state.StateInitializationContextImpl
-
- stateLock - Variable in class org.apache.flink.runtime.operators.hash.AbstractMutableHashTable
-
The lock to synchronize state changes (open / close) on
- StateMachineExample - Class in org.apache.flink.streaming.examples.statemachine
-
Main class of the state machine example.
- StateMachineExample() - Constructor for class org.apache.flink.streaming.examples.statemachine.StateMachineExample
-
- stateMetaInfo - Variable in class org.apache.flink.runtime.state.OperatorBackendStateMetaInfoSnapshotReaderWriters.AbstractOperatorBackendStateMetaInfoWriter
-
- StateMetaInfo(long[], OperatorStateHandle.Mode) - Constructor for class org.apache.flink.runtime.state.OperatorStateHandle.StateMetaInfo
-
- StateMigrationException - Exception in org.apache.flink.util
-
Base class for state migration related exceptions.
- StateMigrationException(String) - Constructor for exception org.apache.flink.util.StateMigrationException
-
- StateMigrationException(Throwable) - Constructor for exception org.apache.flink.util.StateMigrationException
-
- StateMigrationException(String, Throwable) - Constructor for exception org.apache.flink.util.StateMigrationException
-
- stateName - Variable in class org.apache.flink.streaming.tests.artificialstate.builder.ArtificialStateBuilder
-
- StateObject - Interface in org.apache.flink.runtime.state
-
Base of all handles that represent checkpointed state in some form.
- StateObjectCollection<T extends StateObject> - Class in org.apache.flink.runtime.checkpoint
-
This class represents a generic collection for
StateObject
s.
- StateObjectCollection() - Constructor for class org.apache.flink.runtime.checkpoint.StateObjectCollection
-
Creates a new StateObjectCollection that is backed by an
ArrayList
.
- StateObjectCollection(Collection<T>) - Constructor for class org.apache.flink.runtime.checkpoint.StateObjectCollection
-
Creates a new StateObjectCollection wraps the given collection and delegates to it.
- StatePartitionStreamProvider - Class in org.apache.flink.runtime.state
-
This class provides access to input streams that contain data of one state partition of a partitionable state.
- StatePartitionStreamProvider(IOException) - Constructor for class org.apache.flink.runtime.state.StatePartitionStreamProvider
-
- StatePartitionStreamProvider(InputStream) - Constructor for class org.apache.flink.runtime.state.StatePartitionStreamProvider
-
- StateSerializer(TypeSerializer<TXN>, TypeSerializer<CONTEXT>) - Constructor for class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.StateSerializer
-
- StateSerializerConfigSnapshot() - Constructor for class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.StateSerializerConfigSnapshot
-
This empty nullary constructor is required for deserializing the configuration.
- StateSerializerConfigSnapshot(TypeSerializer<TXN>, TypeSerializer<CONTEXT>) - Constructor for class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.StateSerializerConfigSnapshot
-
- StateSnapshotContext - Interface in org.apache.flink.runtime.state
-
This interface provides a context in which operators that use managed (i.e.
- StateSnapshotContextSynchronousImpl - Class in org.apache.flink.runtime.state
-
This class is a default implementation for StateSnapshotContext.
- StateSnapshotContextSynchronousImpl(long, long) - Constructor for class org.apache.flink.runtime.state.StateSnapshotContextSynchronousImpl
-
- StateSnapshotContextSynchronousImpl(long, long, CheckpointStreamFactory, KeyGroupRange, CloseableRegistry) - Constructor for class org.apache.flink.runtime.state.StateSnapshotContextSynchronousImpl
-
- stateTable - Variable in class org.apache.flink.runtime.state.heap.AbstractHeapState
-
Map containing the actual key/value pairs.
- StateTable<K,N,S> - Class in org.apache.flink.runtime.state.heap
-
Base class for state tables.
- StateTable(InternalKeyContext<K>, RegisteredKeyedBackendStateMetaInfo<N, S>) - Constructor for class org.apache.flink.runtime.state.heap.StateTable
-
- StateTransformationFunction<S,T> - Interface in org.apache.flink.runtime.state
-
Interface for a binary function that is used for push-down of state transformation into state backends.
- StateTransition<T> - Class in org.apache.flink.cep.nfa
-
Represents a transition from one
State
to another.
- StateTransition(State<T>, StateTransitionAction, State<T>, IterativeCondition<T>) - Constructor for class org.apache.flink.cep.nfa.StateTransition
-
- StateTransitionAction - Enum in org.apache.flink.cep.nfa
-
Set of actions when doing a state transition from a
State
to another.
- StateUtil - Class in org.apache.flink.runtime.state
-
- StaticDynamicPathIdentifier - Class in org.apache.flink.optimizer.traversals
-
A traversal that goes over the program data flow of an iteration and makes the nodes
that depend on the partial solution (the data set recomputed in each iteration) as "dynamic"
and the other nodes as "static".
- StaticDynamicPathIdentifier(int) - Constructor for class org.apache.flink.optimizer.traversals.StaticDynamicPathIdentifier
-
- StaticFileServerHandler<T extends RestfulGateway> - Class in org.apache.flink.runtime.rest.handler.legacy.files
-
Simple file server handler that serves requests to web frontend's static files, such as
HTML, CSS, or JS files.
- StaticFileServerHandler(GatewayRetriever<? extends T>, CompletableFuture<String>, Time, File) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.files.StaticFileServerHandler
-
- statisticsKey - Variable in class org.apache.flink.api.common.operators.GenericDataSourceBase
-
- StatsDReporter - Class in org.apache.flink.metrics.statsd
-
Largely based on the StatsDReporter class by ReadyTalk.
- StatsDReporter() - Constructor for class org.apache.flink.metrics.statsd.StatsDReporter
-
- status() - Method in class org.apache.flink.contrib.streaming.state.RocksIteratorWrapper
-
- status() - Method in class org.apache.flink.mesos.scheduler.messages.ExecutorLost
-
- status() - Method in class org.apache.flink.mesos.scheduler.messages.StatusUpdate
-
- status - Variable in class org.apache.flink.streaming.runtime.streamstatus.StreamStatus
-
- StatusHandler(CompletableFuture<String>, GatewayRetriever<? extends T>, Time, Map<String, String>, MessageHeaders<EmptyRequestBody, AsynchronousOperationResult<V>, M>) - Constructor for class org.apache.flink.runtime.rest.handler.async.AbstractAsynchronousOperationHandlers.StatusHandler
-
- StatusListenerMessenger - Class in org.apache.flink.runtime.executiongraph
-
A JobStatusListener
and ExecutionStatusListener
that sends an actor message
for each status change.
- StatusListenerMessenger(ActorRef, UUID) - Constructor for class org.apache.flink.runtime.executiongraph.StatusListenerMessenger
-
- statusUpdate(StatusUpdate) - Method in class org.apache.flink.mesos.runtime.clusterframework.MesosResourceManager
-
Handles a task status update from Mesos.
- StatusUpdate - Class in org.apache.flink.mesos.scheduler.messages
-
Message sent by the callback handler to the scheduler actor
when the status of a task has changed (e.g., a slave is lost and so the task is lost,
a task finishes and an executor sends a status update saying so, etc).
- StatusUpdate(Protos.TaskStatus) - Constructor for class org.apache.flink.mesos.scheduler.messages.StatusUpdate
-
- statusUpdate(SchedulerDriver, Protos.TaskStatus) - Method in class org.apache.flink.mesos.scheduler.SchedulerProxy
-
- StatusWatermarkValve - Class in org.apache.flink.streaming.runtime.streamstatus
-
A
StatusWatermarkValve
embodies the logic of how
Watermark
and
StreamStatus
are propagated to
downstream outputs, given a set of one or multiple input channels that continuously receive them.
- StatusWatermarkValve(int, StatusWatermarkValve.ValveOutputHandler) - Constructor for class org.apache.flink.streaming.runtime.streamstatus.StatusWatermarkValve
-
Returns a new StatusWatermarkValve
.
- StatusWatermarkValve.InputChannelStatus - Class in org.apache.flink.streaming.runtime.streamstatus
-
An InputChannelStatus
keeps track of an input channel's last watermark, stream
status, and whether or not the channel's current watermark is aligned with the overall
watermark output from the valve.
- StatusWatermarkValve.ValveOutputHandler - Interface in org.apache.flink.streaming.runtime.streamstatus
-
Usages of StatusWatermarkValve
should implement a ValveOutputHandler
to handle watermark and stream status outputs from the valve.
- stddev - Variable in class org.apache.flink.runtime.metrics.dump.MetricDump.HistogramDump
-
- stdOutFile - Variable in class org.apache.flink.runtime.webmonitor.WebMonitorUtils.LogFileLocation
-
- StdoutFileHandlerSpecification - Class in org.apache.flink.runtime.rest.handler.legacy.files
-
Rest handler specification for the stdout file of the main cluster component.
- Step() - Constructor for class org.apache.flink.streaming.examples.iteration.IterateExample.Step
-
- StepFunctionValidator - Class in org.apache.flink.optimizer.traversals
-
A traversal that checks if the Workset of a delta iteration is used in the data flow
of its step function.
- StepFunctionValidator() - Constructor for class org.apache.flink.optimizer.traversals.StepFunctionValidator
-
- STEPS - Static variable in class org.apache.flink.streaming.api.graph.JSONGenerator
-
- StickyAllocationAndLocalRecoveryTestJob - Class in org.apache.flink.streaming.tests
-
Automatic end-to-end test for local recovery (including sticky allocation).
- StickyAllocationAndLocalRecoveryTestJob() - Constructor for class org.apache.flink.streaming.tests.StickyAllocationAndLocalRecoveryTestJob
-
- StickyAllocationAndLocalRecoveryTestJob.MapperSchedulingAndFailureInfo - Class in org.apache.flink.streaming.tests
-
Records the information required to check sticky scheduling after a restart.
- stop() - Method in interface org.apache.flink.api.common.functions.StoppableFunction
-
Stops the source.
- stop() - Method in class org.apache.flink.api.common.PlanExecutor
-
Shuts down the plan executor and releases all local resources.
- stop(String[]) - Method in class org.apache.flink.client.cli.CliFrontend
-
Executes the STOP action.
- stop() - Method in class org.apache.flink.client.LocalExecutor
-
- stop(JobID) - Method in class org.apache.flink.client.program.ClusterClient
-
Stops a program on Flink cluster whose job-manager is configured in this client's configuration.
- stop(JobID) - Method in class org.apache.flink.client.program.MiniClusterClient
-
- stop(JobID) - Method in class org.apache.flink.client.program.rest.RestClusterClient
-
- stop() - Method in class org.apache.flink.client.RemoteExecutor
-
- stop(boolean) - Method in interface org.apache.flink.mesos.runtime.clusterframework.store.MesosWorkerStore
-
Stop the worker store.
- stop(boolean) - Method in class org.apache.flink.mesos.runtime.clusterframework.store.StandaloneMesosWorkerStore
-
- stop(boolean) - Method in class org.apache.flink.mesos.runtime.clusterframework.store.ZooKeeperMesosWorkerStore
-
- stop() - Method in class org.apache.flink.mesos.util.MesosArtifactServer
-
Stops the artifact server.
- stop() - Method in class org.apache.flink.runtime.dispatcher.SingleJobSubmittedJobGraphStore
-
- stop() - Method in class org.apache.flink.runtime.executiongraph.Execution
-
Sends stop RPC call.
- stop() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- stop() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- stop() - Method in interface org.apache.flink.runtime.heartbeat.HeartbeatManager
-
Stops the heartbeat manager.
- stop() - Method in class org.apache.flink.runtime.heartbeat.HeartbeatManagerImpl
-
- stop() - Method in class org.apache.flink.runtime.heartbeat.HeartbeatManagerSenderImpl
-
- stop() - Method in class org.apache.flink.runtime.highavailability.nonha.leaderelection.SingleLeaderElectionService
-
- stop() - Method in class org.apache.flink.runtime.io.async.AbstractAsyncCallableWithResources
-
Stops the I/O operation by closing the I/O handle.
- stop() - Method in interface org.apache.flink.runtime.io.async.AsyncStoppable
-
Stop the operation
- stop() - Method in interface org.apache.flink.runtime.jobgraph.tasks.StoppableTask
-
Called on STOP signal.
- stop() - Method in class org.apache.flink.runtime.jobmanager.StandaloneSubmittedJobGraphStore
-
- stop() - Method in interface org.apache.flink.runtime.jobmanager.SubmittedJobGraphStore
-
- stop() - Method in class org.apache.flink.runtime.jobmanager.ZooKeeperSubmittedJobGraphStore
-
- stop(Time) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
-
- stop(Time) - Method in interface org.apache.flink.runtime.jobmaster.JobMasterGateway
-
Cancel the currently executed job.
- stop() - Method in interface org.apache.flink.runtime.leaderelection.LeaderElectionService
-
Stops the leader election service.
- stop() - Method in class org.apache.flink.runtime.leaderelection.StandaloneLeaderElectionService
-
- stop() - Method in class org.apache.flink.runtime.leaderelection.ZooKeeperLeaderElectionService
-
- stop() - Method in interface org.apache.flink.runtime.leaderretrieval.LeaderRetrievalService
-
Stops the leader retrieval service.
- stop() - Method in class org.apache.flink.runtime.leaderretrieval.SettableLeaderRetrievalService
-
- stop() - Method in class org.apache.flink.runtime.leaderretrieval.StandaloneLeaderRetrievalService
-
- stop() - Method in class org.apache.flink.runtime.leaderretrieval.ZooKeeperLeaderRetrievalService
-
- stop() - Method in class org.apache.flink.runtime.resourcemanager.JobLeaderIdService
-
Stop the service.
- stop() - Method in class org.apache.flink.runtime.rpc.RpcEndpoint
-
Stops the rpc endpoint.
- stop() - Method in interface org.apache.flink.runtime.rpc.StartStoppable
-
Stops the processing of remote procedure calls.
- stop() - Method in class org.apache.flink.runtime.taskexecutor.JobLeaderService
-
Stop the job leader services.
- stop() - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
-
Stop the task slot table.
- stop() - Method in class org.apache.flink.runtime.taskexecutor.slot.TimerService
-
- stop() - Method in interface org.apache.flink.runtime.webmonitor.WebMonitor
-
Stops the web server.
- stop() - Method in class org.apache.flink.runtime.webmonitor.WebRuntimeMonitor
-
- stop() - Method in class org.apache.flink.storm.wrappers.SpoutWrapper
-
Stops the source.
- stop() - Method in class org.apache.flink.streaming.api.operators.async.Emitter
-
- stop() - Method in class org.apache.flink.streaming.api.operators.StoppableStreamSource
-
- stop() - Method in class org.apache.flink.streaming.connectors.nifi.NiFiSource
-
- stop() - Method in class org.apache.flink.streaming.connectors.twitter.TwitterSource
-
- stop() - Method in class org.apache.flink.streaming.runtime.tasks.StoppableSourceStreamTask
-
- stop(SessionContext) - Method in interface org.apache.flink.table.client.gateway.Executor
-
Stops the executor.
- stop(SessionContext) - Method in class org.apache.flink.table.client.gateway.local.LocalExecutor
-
- stopActor(AkkaActorGateway) - Static method in class org.apache.flink.runtime.akka.ActorUtils
-
- stopActor(ActorRef) - Static method in class org.apache.flink.runtime.akka.ActorUtils
-
- stopCheckpointScheduler() - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
- StopCluster - Class in org.apache.flink.runtime.clusterframework.messages
-
Generic message to signal the cluster framework to shut the cluster down.
- StopCluster(ApplicationStatus, String) - Constructor for class org.apache.flink.runtime.clusterframework.messages.StopCluster
-
- stopCluster(ApplicationStatus, String) - Method in class org.apache.flink.runtime.jobmanager.slots.ActorTaskManagerGateway
-
- stopCluster(ApplicationStatus, String) - Method in interface org.apache.flink.runtime.jobmanager.slots.TaskManagerGateway
-
Stop the cluster.
- stopCluster(ApplicationStatus, String) - Method in class org.apache.flink.runtime.jobmaster.RpcTaskManagerGateway
-
- stopCluster(LocalFlinkMiniCluster, FiniteDuration) - Static method in class org.apache.flink.test.util.TestBaseUtils
-
- stopClusterComponents() - Method in class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
-
- stopClusterServices(boolean) - Method in class org.apache.flink.mesos.entrypoint.MesosJobClusterEntrypoint
-
- stopClusterServices(boolean) - Method in class org.apache.flink.mesos.entrypoint.MesosSessionClusterEntrypoint
-
- stopClusterServices(boolean) - Method in class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
-
- StopClusterSuccessful - Class in org.apache.flink.runtime.clusterframework.messages
-
Generic message to signal the cluster listener that the cluster has been shut down.
- stopExecution() - Method in class org.apache.flink.runtime.taskmanager.Task
-
- stopJob(JobID, Time) - Method in class org.apache.flink.runtime.akka.AkkaJobManagerGateway
-
- stopJob(JobID, Time) - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
-
- stopJob(JobID, Time) - Method in interface org.apache.flink.runtime.jobmaster.JobManagerGateway
-
Stops the given job.
- stopJob(JobID) - Method in class org.apache.flink.runtime.minicluster.MiniCluster
-
- stopJob(JobID, Time) - Method in interface org.apache.flink.runtime.webmonitor.RestfulGateway
-
Stop the given job.
- stopOperation() - Method in class org.apache.flink.runtime.io.async.AbstractAsyncCallableWithResources
-
This method implements how the operation is stopped.
- StopOptions - Class in org.apache.flink.client.cli
-
Command line options for the STOP command.
- StopOptions(CommandLine) - Constructor for class org.apache.flink.client.cli.StopOptions
-
- stoppableCallbackCallable - Variable in class org.apache.flink.runtime.io.async.AsyncStoppableTaskWithCallback
-
- StoppableCallbackCallable<V> - Interface in org.apache.flink.runtime.io.async
-
A
Callable
that can be stopped and offers a callback on termination.
- StoppableFunction - Interface in org.apache.flink.api.common.functions
-
Must be implemented by stoppable functions, eg, source functions of streaming jobs.
- StoppableSourceStreamTask<OUT,SRC extends SourceFunction<OUT> & StoppableFunction> - Class in org.apache.flink.streaming.runtime.tasks
-
Stoppable task for executing stoppable streaming sources.
- StoppableSourceStreamTask(Environment) - Constructor for class org.apache.flink.streaming.runtime.tasks.StoppableSourceStreamTask
-
- StoppableStreamSource<OUT,SRC extends SourceFunction<OUT> & StoppableFunction> - Class in org.apache.flink.streaming.api.operators
-
- StoppableStreamSource(SRC) - Constructor for class org.apache.flink.streaming.api.operators.StoppableStreamSource
-
- StoppableTask - Interface in org.apache.flink.runtime.jobgraph.tasks
-
Implemented by tasks that can receive STOP signal.
- stopped - Variable in class org.apache.flink.runtime.heartbeat.HeartbeatManagerImpl
-
Running state of the heartbeat manager.
- StoppingException - Exception in org.apache.flink.runtime
-
Indicates that a job is not stoppable.
- StoppingException(String) - Constructor for exception org.apache.flink.runtime.StoppingException
-
- StoppingException(String, Throwable) - Constructor for exception org.apache.flink.runtime.StoppingException
-
- StoppingSupervisorWithoutLoggingActorKilledExceptionStrategy - Class in org.apache.flink.runtime.akka
-
Stopping supervisor strategy which logs ActorKilledException
only on debug log level.
- StoppingSupervisorWithoutLoggingActorKilledExceptionStrategy() - Constructor for class org.apache.flink.runtime.akka.StoppingSupervisorWithoutLoggingActorKilledExceptionStrategy
-
- stopRetrieval() - Method in class org.apache.flink.table.client.cli.CliResultView
-
- stopServer(RpcServer) - Method in class org.apache.flink.runtime.rpc.akka.AkkaRpcService
-
- stopServer(RpcServer) - Method in interface org.apache.flink.runtime.rpc.RpcService
-
Stop the underlying rpc server of the provided self gateway.
- stopService() - Method in class org.apache.flink.runtime.rpc.akka.AkkaRpcService
-
- stopService() - Method in interface org.apache.flink.runtime.rpc.RpcService
-
Trigger the asynchronous stopping of the
RpcService
.
- stopTask(ExecutionAttemptID, Time) - Method in class org.apache.flink.runtime.jobmanager.slots.ActorTaskManagerGateway
-
- stopTask(ExecutionAttemptID, Time) - Method in interface org.apache.flink.runtime.jobmanager.slots.TaskManagerGateway
-
Stop the given task.
- stopTask(ExecutionAttemptID, Time) - Method in class org.apache.flink.runtime.jobmaster.RpcTaskManagerGateway
-
- stopTask(ExecutionAttemptID, Time) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutor
-
- stopTask(ExecutionAttemptID, Time) - Method in interface org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
-
Stop the given task.
- stopWorker(RegisteredMesosWorkerNode) - Method in class org.apache.flink.mesos.runtime.clusterframework.MesosResourceManager
-
- stopWorker(WorkerType) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
-
Stops the given worker.
- stopWorker(ResourceID) - Method in class org.apache.flink.runtime.resourcemanager.StandaloneResourceManager
-
- stopWorker(YarnWorkerNode) - Method in class org.apache.flink.yarn.YarnResourceManager
-
- STORAGE_DIRECTORY - Static variable in class org.apache.flink.configuration.BlobServerOptions
-
The config parameter defining the storage directory to be used by the blob server.
- storageDir - Variable in class org.apache.flink.runtime.blob.AbstractBlobCache
-
Root directory for local file storage.
- store(T) - Method in class org.apache.flink.runtime.zookeeper.filesystem.FileSystemStateStorageHelper
-
- store(T) - Method in interface org.apache.flink.runtime.zookeeper.RetrievableStateStorageHelper
-
Stores the given state and returns a state handle to it.
- storeCheckpointMetadata(T, OutputStream) - Static method in class org.apache.flink.runtime.checkpoint.Checkpoints
-
- storeCheckpointMetadata(T, DataOutputStream) - Static method in class org.apache.flink.runtime.checkpoint.Checkpoints
-
- storeLocalState(long, TaskStateSnapshot) - Method in class org.apache.flink.runtime.state.NoOpTaskLocalStateStoreImpl
-
- storeLocalState(long, TaskStateSnapshot) - Method in interface org.apache.flink.runtime.state.TaskLocalStateStore
-
Stores the local state for the given checkpoint id.
- storeLocalState(long, TaskStateSnapshot) - Method in class org.apache.flink.runtime.state.TaskLocalStateStoreImpl
-
- storeResult(String, DynamicResult) - Method in class org.apache.flink.table.client.gateway.local.ResultStore
-
- StormConfig - Class in org.apache.flink.storm.util
-
StormConfig
is used to provide a user-defined Storm configuration (ie, a raw
Map
or
Config
object) for embedded Spouts and Bolts.
- StormConfig() - Constructor for class org.apache.flink.storm.util.StormConfig
-
Creates an empty configuration.
- StormConfig(Map) - Constructor for class org.apache.flink.storm.util.StormConfig
-
Creates an configuration with initial values provided by the given Map
.
- StormStreamSelector<T> - Class in org.apache.flink.storm.util
-
Used by
FlinkTopology
to split multiple declared output streams within Flink.
- StormStreamSelector() - Constructor for class org.apache.flink.storm.util.StormStreamSelector
-
- StormTuple<IN> - Class in org.apache.flink.storm.wrappers
-
StormTuple
converts a Flink tuple of type
IN
into a Storm tuple.
- StormTuple(IN, Fields, int, String, String, MessageId) - Constructor for class org.apache.flink.storm.wrappers.StormTuple
-
Create a new Storm tuple from the given Flink tuple.
- stream - Variable in class org.apache.flink.api.common.io.FileInputFormat
-
The input stream reading from the input file.
- stream - Variable in class org.apache.flink.api.common.io.FileOutputFormat
-
The stream to which the data is written;
- stream - Variable in class org.apache.flink.streaming.python.api.datastream.PythonDataStream
-
- streamBufferWithGroups(Iterator<IN1>, Iterator<IN2>, Collector<OUT>) - Method in class org.apache.flink.python.api.streaming.data.PythonDualInputStreamer
-
Sends all values contained in both iterators to the external process and collects all results.
- streamBufferWithoutGroups(Iterator<IN>, Collector<OUT>) - Method in class org.apache.flink.python.api.streaming.data.PythonSingleInputStreamer
-
Sends all values contained in the iterator to the external process and collects all results.
- StreamCompressionDecorator - Class in org.apache.flink.runtime.state
-
Implementations of this interface decorate streams with a compression scheme.
- StreamCompressionDecorator() - Constructor for class org.apache.flink.runtime.state.StreamCompressionDecorator
-
- StreamConfig - Class in org.apache.flink.streaming.api.graph
-
- StreamConfig(Configuration) - Constructor for class org.apache.flink.streaming.api.graph.StreamConfig
-
- StreamContextEnvironment - Class in org.apache.flink.streaming.api.environment
-
- StreamContextEnvironment(ContextEnvironment) - Constructor for class org.apache.flink.streaming.api.environment.StreamContextEnvironment
-
- StreamEdge - Class in org.apache.flink.streaming.api.graph
-
An edge in the streaming topology.
- StreamEdge(StreamNode, StreamNode, int, List<String>, StreamPartitioner<?>, OutputTag) - Constructor for class org.apache.flink.streaming.api.graph.StreamEdge
-
- StreamElement - Class in org.apache.flink.streaming.runtime.streamrecord
-
An element in a data stream.
- StreamElement() - Constructor for class org.apache.flink.streaming.runtime.streamrecord.StreamElement
-
- StreamElementQueue - Interface in org.apache.flink.streaming.api.operators.async.queue
-
- StreamElementQueueEntry<T> - Class in org.apache.flink.streaming.api.operators.async.queue
-
- StreamElementQueueEntry(StreamElement) - Constructor for class org.apache.flink.streaming.api.operators.async.queue.StreamElementQueueEntry
-
- StreamElementSerializer<T> - Class in org.apache.flink.streaming.runtime.streamrecord
-
- StreamElementSerializer(TypeSerializer<T>) - Constructor for class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
-
- StreamElementSerializer.StreamElementSerializerConfigSnapshot<T> - Class in org.apache.flink.streaming.runtime.streamrecord
-
- StreamElementSerializerConfigSnapshot() - Constructor for class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer.StreamElementSerializerConfigSnapshot
-
This empty nullary constructor is required for deserializing the configuration.
- StreamElementSerializerConfigSnapshot(TypeSerializer<T>) - Constructor for class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer.StreamElementSerializerConfigSnapshot
-
- StreamExecutionEnvironment - Class in org.apache.flink.streaming.api.environment
-
The StreamExecutionEnvironment is the context in which a streaming program is executed.
- StreamExecutionEnvironment() - Constructor for class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- StreamExecutionEnvironmentFactory - Interface in org.apache.flink.streaming.api.environment
-
Factory class for stream execution environments.
- StreamFilter<IN> - Class in org.apache.flink.streaming.api.operators
-
- StreamFilter(FilterFunction<IN>) - Constructor for class org.apache.flink.streaming.api.operators.StreamFilter
-
- StreamFlatMap<IN,OUT> - Class in org.apache.flink.streaming.api.operators
-
- StreamFlatMap(FlatMapFunction<IN, OUT>) - Constructor for class org.apache.flink.streaming.api.operators.StreamFlatMap
-
- StreamGraph - Class in org.apache.flink.streaming.api.graph
-
Class representing the streaming topology.
- StreamGraph(StreamExecutionEnvironment) - Constructor for class org.apache.flink.streaming.api.graph.StreamGraph
-
- StreamGraphGenerator - Class in org.apache.flink.streaming.api.graph
-
- StreamGraphHasher - Interface in org.apache.flink.streaming.api.graph
-
Interface for different implementations of generating hashes over a stream graph.
- StreamGraphHasherV2 - Class in org.apache.flink.streaming.api.graph
-
StreamGraphHasher from Flink 1.2.
- StreamGraphHasherV2() - Constructor for class org.apache.flink.streaming.api.graph.StreamGraphHasherV2
-
- StreamGraphUserHashHasher - Class in org.apache.flink.streaming.api.graph
-
StreamGraphHasher that works with user provided hashes.
- StreamGraphUserHashHasher() - Constructor for class org.apache.flink.streaming.api.graph.StreamGraphUserHashHasher
-
- StreamGroupedFold<IN,OUT,KEY> - Class in org.apache.flink.streaming.api.operators
-
- StreamGroupedFold(FoldFunction<IN, OUT>, OUT) - Constructor for class org.apache.flink.streaming.api.operators.StreamGroupedFold
-
Deprecated.
- StreamGroupedReduce<IN> - Class in org.apache.flink.streaming.api.operators
-
- StreamGroupedReduce(ReduceFunction<IN>, TypeSerializer<IN>) - Constructor for class org.apache.flink.streaming.api.operators.StreamGroupedReduce
-
- streamId - Variable in class org.apache.flink.storm.util.SplitStreamType
-
The stream ID this tuple belongs to.
- streamInactivityTimeout - Variable in class org.apache.flink.core.fs.LimitedConnectionsFileSystem.ConnectionLimitingSettings
-
The inactivity timeout for a stream, in milliseconds.
- STREAMING_COUNTS_AS_TUPLES - Static variable in class org.apache.flink.streaming.examples.twitter.util.TwitterExampleData
-
- STREAMING_COUNTS_AS_TUPLES - Static variable in class org.apache.flink.test.testdata.WordCountData
-
- StreamingFunctionUtils - Class in org.apache.flink.streaming.util.functions
-
Utility class that contains helper methods to work with Flink Streaming
Functions
.
- StreamingJobGraphGenerator - Class in org.apache.flink.streaming.api.graph
-
- StreamingPlan - Class in org.apache.flink.optimizer.plan
-
Abstract class representing Flink Streaming plans
- StreamingPlan() - Constructor for class org.apache.flink.optimizer.plan.StreamingPlan
-
- StreamingProgramTestBase - Class in org.apache.flink.streaming.util
-
Base class for unit tests that run a single test.
- StreamingProgramTestBase() - Constructor for class org.apache.flink.streaming.util.StreamingProgramTestBase
-
- StreamingRuntimeContext - Class in org.apache.flink.streaming.api.operators
-
- StreamingRuntimeContext(AbstractStreamOperator<?>, Environment, Map<String, Accumulator<?, ?>>) - Constructor for class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
-
- StreamInputProcessor<IN> - Class in org.apache.flink.streaming.runtime.io
-
- StreamInputProcessor(InputGate[], TypeSerializer<IN>, StreamTask<?, ?>, CheckpointingMode, Object, IOManager, Configuration, StreamStatusMaintainer, OneInputStreamOperator<IN, ?>, TaskIOMetricGroup, WatermarkGauge) - Constructor for class org.apache.flink.streaming.runtime.io.StreamInputProcessor
-
- StreamIterationHead<OUT> - Class in org.apache.flink.streaming.runtime.tasks
-
A special
StreamTask
that is used for executing feedback edges.
- StreamIterationHead(Environment) - Constructor for class org.apache.flink.streaming.runtime.tasks.StreamIterationHead
-
- StreamIterationTail<IN> - Class in org.apache.flink.streaming.runtime.tasks
-
A special
StreamTask
that is used for executing feedback edges.
- StreamIterationTail(Environment) - Constructor for class org.apache.flink.streaming.runtime.tasks.StreamIterationTail
-
- StreamMap<IN,OUT> - Class in org.apache.flink.streaming.api.operators
-
- StreamMap(MapFunction<IN, OUT>) - Constructor for class org.apache.flink.streaming.api.operators.StreamMap
-
- StreamNode - Class in org.apache.flink.streaming.api.graph
-
Class representing the operators in the streaming programs, with all their properties.
- StreamNode(StreamExecutionEnvironment, Integer, String, StreamOperator<?>, String, List<OutputSelector<?>>, Class<? extends AbstractInvokable>) - Constructor for class org.apache.flink.streaming.api.graph.StreamNode
-
- streamOpenTimeout - Variable in class org.apache.flink.core.fs.LimitedConnectionsFileSystem.ConnectionLimitingSettings
-
The stream opening timeout for a stream, in milliseconds.
- StreamOperator<OUT> - Interface in org.apache.flink.streaming.api.operators
-
Basic interface for stream operators.
- StreamOperatorStateContext - Interface in org.apache.flink.streaming.api.operators
-
This interface represents a context from which a stream operator can initialize everything connected to state such
as e.g.
- streamOperatorStateContext(OperatorID, String, KeyContext, TypeSerializer<?>, CloseableRegistry) - Method in interface org.apache.flink.streaming.api.operators.StreamTaskStateInitializer
-
- streamOperatorStateContext(OperatorID, String, KeyContext, TypeSerializer<?>, CloseableRegistry) - Method in class org.apache.flink.streaming.api.operators.StreamTaskStateInitializerImpl
-
- StreamPartitioner<T> - Class in org.apache.flink.streaming.runtime.partitioner
-
- StreamPartitioner() - Constructor for class org.apache.flink.streaming.runtime.partitioner.StreamPartitioner
-
- StreamPlanEnvironment - Class in org.apache.flink.streaming.api.environment
-
A special
StreamExecutionEnvironment
that is used in the web frontend when generating
a user-inspectable graph of a streaming job.
- StreamPlanEnvironment(ExecutionEnvironment) - Constructor for class org.apache.flink.streaming.api.environment.StreamPlanEnvironment
-
- StreamPrinter - Class in org.apache.flink.python.api.streaming.util
-
Simple utility class to print all contents of an inputstream to stdout.
- StreamPrinter(InputStream) - Constructor for class org.apache.flink.python.api.streaming.util.StreamPrinter
-
- StreamPrinter(InputStream, AtomicReference<String>) - Constructor for class org.apache.flink.python.api.streaming.util.StreamPrinter
-
- StreamProject<IN,OUT extends Tuple> - Class in org.apache.flink.streaming.api.operators
-
- StreamProject(int[], TypeSerializer<OUT>) - Constructor for class org.apache.flink.streaming.api.operators.StreamProject
-
- StreamProjection<IN> - Class in org.apache.flink.streaming.api.datastream
-
- StreamProjection(DataStream<IN>, int[]) - Constructor for class org.apache.flink.streaming.api.datastream.StreamProjection
-
- StreamRecord<T> - Class in org.apache.flink.streaming.runtime.streamrecord
-
One value in a data stream.
- StreamRecord(T) - Constructor for class org.apache.flink.streaming.runtime.streamrecord.StreamRecord
-
Creates a new StreamRecord.
- StreamRecord(T, long) - Constructor for class org.apache.flink.streaming.runtime.streamrecord.StreamRecord
-
Creates a new StreamRecord wrapping the given value.
- StreamRecordComparator<IN> - Class in org.apache.flink.cep.operator
-
- StreamRecordComparator() - Constructor for class org.apache.flink.cep.operator.StreamRecordComparator
-
- StreamRecordQueueEntry<OUT> - Class in org.apache.flink.streaming.api.operators.async.queue
-
- StreamRecordQueueEntry(StreamRecord<?>) - Constructor for class org.apache.flink.streaming.api.operators.async.queue.StreamRecordQueueEntry
-
- StreamRecordWriter<T extends IOReadableWritable> - Class in org.apache.flink.streaming.runtime.io
-
This record writer keeps data in buffers at most for a certain timeout.
- StreamRecordWriter(ResultPartitionWriter, ChannelSelector<T>, long) - Constructor for class org.apache.flink.streaming.runtime.io.StreamRecordWriter
-
- StreamRecordWriter(ResultPartitionWriter, ChannelSelector<T>, long, String) - Constructor for class org.apache.flink.streaming.runtime.io.StreamRecordWriter
-
- StreamSink<IN> - Class in org.apache.flink.streaming.api.operators
-
- StreamSink(SinkFunction<IN>) - Constructor for class org.apache.flink.streaming.api.operators.StreamSink
-
- StreamSource<OUT,SRC extends SourceFunction<OUT>> - Class in org.apache.flink.streaming.api.operators
-
- StreamSource(SRC) - Constructor for class org.apache.flink.streaming.api.operators.StreamSource
-
- StreamSourceContexts - Class in org.apache.flink.streaming.api.operators
-
Source contexts for various stream time characteristics.
- StreamSourceContexts() - Constructor for class org.apache.flink.streaming.api.operators.StreamSourceContexts
-
- StreamSQLExample - Class in org.apache.flink.table.examples.java
-
Simple example for demonstrating the use of SQL on a Stream Table in Java.
- StreamSQLExample() - Constructor for class org.apache.flink.table.examples.java.StreamSQLExample
-
- StreamSQLExample.Order - Class in org.apache.flink.table.examples.java
-
Simple POJO.
- StreamSQLTestProgram - Class in org.apache.flink.sql.tests
-
End-to-end test for Stream SQL queries.
- StreamSQLTestProgram() - Constructor for class org.apache.flink.sql.tests.StreamSQLTestProgram
-
- StreamSQLTestProgram.Generator - Class in org.apache.flink.sql.tests
-
Data-generating source function.
- StreamSQLTestProgram.GeneratorTableSource - Class in org.apache.flink.sql.tests
-
TableSource for generated data.
- StreamSQLTestProgram.KillMapper - Class in org.apache.flink.sql.tests
-
Kills the first execution attempt of an application when it receives the second record.
- StreamStateHandle - Interface in org.apache.flink.runtime.state
-
A
StateObject
that represents state that was written to a stream.
- streamStatus - Variable in class org.apache.flink.streaming.runtime.streamstatus.StatusWatermarkValve.InputChannelStatus
-
- StreamStatus - Class in org.apache.flink.streaming.runtime.streamstatus
-
A Stream Status element informs stream tasks whether or not they should continue to expect records and watermarks
from the input stream that sent them.
- StreamStatus(int) - Constructor for class org.apache.flink.streaming.runtime.streamstatus.StreamStatus
-
- StreamStatusMaintainer - Interface in org.apache.flink.streaming.runtime.streamstatus
-
Interface that allows toggling the current
StreamStatus
as well as retrieving it.
- StreamStatusProvider - Interface in org.apache.flink.streaming.runtime.streamstatus
-
- StreamTask<OUT,OP extends StreamOperator<OUT>> - Class in org.apache.flink.streaming.runtime.tasks
-
Base class for all streaming tasks.
- StreamTask(Environment) - Constructor for class org.apache.flink.streaming.runtime.tasks.StreamTask
-
Constructor for initialization, possibly with initial state (recovery / savepoint / etc).
- StreamTask(Environment, ProcessingTimeService) - Constructor for class org.apache.flink.streaming.runtime.tasks.StreamTask
-
Constructor for initialization, possibly with initial state (recovery / savepoint / etc).
- StreamTask.AsyncCheckpointRunnable - Class in org.apache.flink.streaming.runtime.tasks
-
This runnable executes the asynchronous parts of all involved backend snapshots for the subtask.
- StreamTaskException - Exception in org.apache.flink.streaming.runtime.tasks
-
An exception that is thrown by the stream vertices when encountering an
illegal condition.
- StreamTaskException() - Constructor for exception org.apache.flink.streaming.runtime.tasks.StreamTaskException
-
Creates a compiler exception with no message and no cause.
- StreamTaskException(String) - Constructor for exception org.apache.flink.streaming.runtime.tasks.StreamTaskException
-
Creates a compiler exception with the given message and no cause.
- StreamTaskException(Throwable) - Constructor for exception org.apache.flink.streaming.runtime.tasks.StreamTaskException
-
Creates a compiler exception with the given cause and no message.
- StreamTaskException(String, Throwable) - Constructor for exception org.apache.flink.streaming.runtime.tasks.StreamTaskException
-
Creates a compiler exception with the given message and cause.
- StreamTaskStateInitializer - Interface in org.apache.flink.streaming.api.operators
-
- StreamTaskStateInitializerImpl - Class in org.apache.flink.streaming.api.operators
-
- StreamTaskStateInitializerImpl(Environment, StateBackend, ProcessingTimeService) - Constructor for class org.apache.flink.streaming.api.operators.StreamTaskStateInitializerImpl
-
- StreamTimeoutException() - Constructor for exception org.apache.flink.core.fs.LimitedConnectionsFileSystem.StreamTimeoutException
-
- StreamTimeoutException(LimitedConnectionsFileSystem.StreamTimeoutException) - Constructor for exception org.apache.flink.core.fs.LimitedConnectionsFileSystem.StreamTimeoutException
-
- StreamTransformation<T> - Class in org.apache.flink.streaming.api.transformations
-
A
StreamTransformation
represents the operation that creates a
DataStream
.
- StreamTransformation(String, TypeInformation<T>, int) - Constructor for class org.apache.flink.streaming.api.transformations.StreamTransformation
-
Creates a new StreamTransformation
with the given name, output type and parallelism.
- StreamTwoInputProcessor<IN1,IN2> - Class in org.apache.flink.streaming.runtime.io
-
- StreamTwoInputProcessor(Collection<InputGate>, Collection<InputGate>, TypeSerializer<IN1>, TypeSerializer<IN2>, TwoInputStreamTask<IN1, IN2, ?>, CheckpointingMode, Object, IOManager, Configuration, StreamStatusMaintainer, TwoInputStreamOperator<IN1, IN2, ?>, TaskIOMetricGroup, WatermarkGauge, WatermarkGauge) - Constructor for class org.apache.flink.streaming.runtime.io.StreamTwoInputProcessor
-
- StreamWriterBase<T> - Class in org.apache.flink.streaming.connectors.fs
-
Base class for
Writers
that write to a
FSDataOutputStream
.
- StreamWriterBase() - Constructor for class org.apache.flink.streaming.connectors.fs.StreamWriterBase
-
- StreamWriterBase(StreamWriterBase<T>) - Constructor for class org.apache.flink.streaming.connectors.fs.StreamWriterBase
-
- STRING - Static variable in class org.apache.flink.api.common.typeinfo.Types
-
Returns type information for
String
.
- STRING_ARRAY_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
-
- STRING_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
-
- STRING_VALUE_ARRAY_TYPE_INFO - Static variable in class org.apache.flink.graph.types.valuearray.ValueArrayTypeInfo
-
- STRING_VALUE_TYPE_INFO - Static variable in class org.apache.flink.api.java.typeutils.ValueTypeInfo
-
- StringArraySerializer - Class in org.apache.flink.api.common.typeutils.base.array
-
A serializer for String arrays.
- StringArraySerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.array.StringArraySerializer
-
- StringBasedID - Class in org.apache.flink.util
-
Base class for typed IDs that are internally represented by a string.
- StringBasedID(String) - Constructor for class org.apache.flink.util.StringBasedID
-
Protected constructor to enforce that subclassing.
- StringColumnSummary - Class in org.apache.flink.api.java.summarize
-
Summary for a column of Strings.
- StringColumnSummary(long, long, long, Integer, Integer, Double) - Constructor for class org.apache.flink.api.java.summarize.StringColumnSummary
-
- StringComparator - Class in org.apache.flink.api.common.typeutils.base
-
- StringComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.StringComparator
-
- StringDeserializerMap - Class in org.apache.flink.python.api.functions.util
-
Utility function to deserialize strings, used for non-CSV sinks.
- StringDeserializerMap() - Constructor for class org.apache.flink.python.api.functions.util.StringDeserializerMap
-
- STRINGIFIED_NULL_EXCEPTION - Static variable in class org.apache.flink.util.ExceptionUtils
-
The stringified representation of a null exception reference.
- StringifiedAccumulatorResult - Class in org.apache.flink.runtime.accumulators
-
Container class that transports the result of an accumulator as set of strings.
- StringifiedAccumulatorResult(String, String, String) - Constructor for class org.apache.flink.runtime.accumulators.StringifiedAccumulatorResult
-
- stringifyAccumulatorResults(Map<String, OptionalFailure<Accumulator<?, ?>>>) - Static method in class org.apache.flink.runtime.accumulators.StringifiedAccumulatorResult
-
Flatten a map of accumulator names to Accumulator instances into an array of StringifiedAccumulatorResult values.
- stringifyException(Throwable) - Static method in class org.apache.flink.util.ExceptionUtils
-
Makes a string representation of the exception's stack trace, or "(null)", if the
exception is null.
- StringParameter - Class in org.apache.flink.graph.drivers.parameter
-
- StringParameter(ParameterizedBase, String) - Constructor for class org.apache.flink.graph.drivers.parameter.StringParameter
-
Set the parameter name and add this parameter to the list of parameters
stored by owner.
- StringParser - Class in org.apache.flink.types.parser
-
Converts a variable length field of a byte array into a
String
.
- StringParser() - Constructor for class org.apache.flink.types.parser.StringParser
-
- StringQueryParameter - Class in org.apache.flink.runtime.webmonitor.handlers
-
Abstract super class for
String
query parameters.
- StringQueryParameter(String, MessageParameter.MessageParameterRequisiteness) - Constructor for class org.apache.flink.runtime.webmonitor.handlers.StringQueryParameter
-
- StringSerializer - Class in org.apache.flink.api.common.typeutils.base
-
- StringSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.StringSerializer
-
- StringSerializer() - Constructor for class org.apache.flink.python.api.streaming.util.SerializationUtils.StringSerializer
-
- StringSummaryAggregator - Class in org.apache.flink.api.java.summarize.aggregation
-
- StringSummaryAggregator() - Constructor for class org.apache.flink.api.java.summarize.aggregation.StringSummaryAggregator
-
- StringTriple() - Constructor for class org.apache.flink.examples.java.relational.EmptyFieldsCountAccumulator.StringTriple
-
- StringTriple(String, String, String) - Constructor for class org.apache.flink.examples.java.relational.EmptyFieldsCountAccumulator.StringTriple
-
- StringTupleDeserializerMap - Class in org.apache.flink.python.api.functions.util
-
Utility function to deserialize strings, used for CSV sinks.
- StringTupleDeserializerMap() - Constructor for class org.apache.flink.python.api.functions.util.StringTupleDeserializerMap
-
- StringUtils - Class in org.apache.flink.util
-
Utility class to convert objects into strings in vice-versa.
- StringValue - Class in org.apache.flink.types
-
Mutable string data type that implements the Key interface.
- StringValue() - Constructor for class org.apache.flink.types.StringValue
-
Initializes the encapsulated String object with an empty string.
- StringValue(CharSequence) - Constructor for class org.apache.flink.types.StringValue
-
Initializes this StringValue to the value of the given string.
- StringValue(StringValue) - Constructor for class org.apache.flink.types.StringValue
-
Initializes this StringValue to a copy the given StringValue.
- StringValue(StringValue, int, int) - Constructor for class org.apache.flink.types.StringValue
-
Initializes the StringValue to a sub-string of the given StringValue.
- StringValueArray - Class in org.apache.flink.graph.types.valuearray
-
- StringValueArray() - Constructor for class org.apache.flink.graph.types.valuearray.StringValueArray
-
Initializes an expandable array with default capacity.
- StringValueArray(int) - Constructor for class org.apache.flink.graph.types.valuearray.StringValueArray
-
Initializes a fixed-size array with the provided number of bytes.
- StringValueArrayComparator - Class in org.apache.flink.graph.types.valuearray
-
Specialized comparator for StringValueArray based on CopyableValueComparator.
- StringValueArrayComparator(boolean) - Constructor for class org.apache.flink.graph.types.valuearray.StringValueArrayComparator
-
- StringValueArraySerializer - Class in org.apache.flink.graph.types.valuearray
-
Specialized serializer for StringValueArray
.
- StringValueArraySerializer() - Constructor for class org.apache.flink.graph.types.valuearray.StringValueArraySerializer
-
- StringValueComparator - Class in org.apache.flink.api.common.typeutils.base
-
Specialized comparator for StringValue based on CopyableValueComparator.
- StringValueComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.StringValueComparator
-
- StringValueParser - Class in org.apache.flink.types.parser
-
Converts a variable length field of a byte array into a
StringValue
.
- StringValueParser() - Constructor for class org.apache.flink.types.parser.StringValueParser
-
- StringValueSerializer - Class in org.apache.flink.api.common.typeutils.base
-
- StringValueSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.StringValueSerializer
-
- StringValueSummaryAggregator() - Constructor for class org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator.StringValueSummaryAggregator
-
- StringValueUtils - Class in org.apache.flink.util
-
- StringValueUtils.WhitespaceTokenizer - Class in org.apache.flink.util
-
A tokenizer for string values that uses whitespace characters as token delimiters.
- StringWriter<T> - Class in org.apache.flink.streaming.connectors.fs
-
A
Writer
that uses
toString()
on the input elements and writes them to
the output bucket file separated by newline.
- StringWriter() - Constructor for class org.apache.flink.streaming.connectors.fs.StringWriter
-
Creates a new StringWriter
that uses "UTF-8"
charset to convert
strings to bytes.
- StringWriter(String) - Constructor for class org.apache.flink.streaming.connectors.fs.StringWriter
-
Creates a new StringWriter
that uses the given charset to convert
strings to bytes.
- StringWriter(StringWriter<T>) - Constructor for class org.apache.flink.streaming.connectors.fs.StringWriter
-
- stripCompletionException(Throwable) - Static method in class org.apache.flink.util.ExceptionUtils
-
- stripExecutionException(Throwable) - Static method in class org.apache.flink.util.ExceptionUtils
-
- stripProxy(T) - Static method in class org.apache.flink.util.WrappingProxyUtil
-
- stub - Variable in class org.apache.flink.runtime.operators.BatchTask
-
The instantiated user code of this task's main operator (driver).
- subComponents() - Method in class org.apache.flink.runtime.metrics.groups.ComponentMetricGroup
-
Gets all component metric groups that are contained in this component metric group.
- subComponents() - Method in class org.apache.flink.runtime.metrics.groups.JobManagerJobMetricGroup
-
- subComponents() - Method in class org.apache.flink.runtime.metrics.groups.JobManagerMetricGroup
-
- subComponents() - Method in class org.apache.flink.runtime.metrics.groups.OperatorMetricGroup
-
- subComponents() - Method in class org.apache.flink.runtime.metrics.groups.TaskManagerJobMetricGroup
-
- subComponents() - Method in class org.apache.flink.runtime.metrics.groups.TaskManagerMetricGroup
-
- subComponents() - Method in class org.apache.flink.runtime.metrics.groups.TaskMetricGroup
-
- subgraph(FilterFunction<Vertex<K, VV>>, FilterFunction<Edge<K, EV>>) - Method in class org.apache.flink.graph.Graph
-
Apply filtering functions to the graph and return a sub-graph that
satisfies the predicates for both vertices and edges.
- subject - Variable in class org.apache.flink.examples.java.misc.CollectionExecutionExample.EMail
-
- subList(int, int) - Method in class org.apache.flink.types.ListValue
-
- SUBMIT_BLOCKING - Static variable in class org.apache.flink.storm.api.FlinkLocalCluster
-
Configuration key to submit topology in blocking mode if flag is set to true
.
- SUBMIT_ENABLE - Static variable in class org.apache.flink.configuration.WebOptions
-
Config parameter indicating whether jobs can be uploaded and run from the web-frontend.
- submitJar(Map, String) - Static method in class org.apache.flink.storm.api.FlinkSubmitter
-
In Flink, jar files are submitted directly when a program is started.
- submitJar(String) - Static method in class org.apache.flink.storm.api.FlinkSubmitter
-
In Flink, jar files are submitted directly when a program is started.
- submitJob(JobGraph, ClassLoader) - Method in class org.apache.flink.client.program.ClusterClient
-
Calls the subclasses' submitJob method.
- submitJob(JobGraph, ClassLoader) - Method in class org.apache.flink.client.program.MiniClusterClient
-
- submitJob(JobGraph) - Method in class org.apache.flink.client.program.MiniClusterClient
-
- submitJob(JobGraph) - Method in interface org.apache.flink.client.program.NewClusterClient
-
Submit the given
JobGraph
to the cluster.
- submitJob(JobGraph, ClassLoader) - Method in class org.apache.flink.client.program.rest.RestClusterClient
-
- submitJob(JobGraph) - Method in class org.apache.flink.client.program.rest.RestClusterClient
-
Submits the given
JobGraph
to the dispatcher.
- submitJob(JobGraph, ClassLoader) - Method in class org.apache.flink.client.program.StandaloneClusterClient
-
- submitJob(JobGraph, ListeningBehaviour, Time) - Method in class org.apache.flink.runtime.akka.AkkaJobManagerGateway
-
- submitJob(ActorSystem, Configuration, HighAvailabilityServices, JobGraph, FiniteDuration, boolean, ClassLoader) - Static method in class org.apache.flink.runtime.client.JobClient
-
Submits a job to a Flink cluster (non-blocking) and returns a JobListeningContext which can be
passed to awaitJobResult
to get the result of the submission.
- submitJob(JobGraph, Time) - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
-
- submitJob(JobGraph, Time) - Method in interface org.apache.flink.runtime.dispatcher.DispatcherGateway
-
Submit a job to the dispatcher.
- submitJob(JobGraph, Time) - Method in class org.apache.flink.runtime.dispatcher.MiniDispatcher
-
- submitJob(JobGraph, ListeningBehaviour, Time) - Method in interface org.apache.flink.runtime.jobmaster.JobManagerGateway
-
Submits a job to the JobManager.
- submitJob(JobGraph) - Method in class org.apache.flink.runtime.minicluster.MiniCluster
-
- submitJob(JobGraph, ClassLoader) - Method in class org.apache.flink.yarn.YarnClusterClient
-
- submitJobAndWait(ActorSystem, Configuration, HighAvailabilityServices, JobGraph, FiniteDuration, boolean, ClassLoader) - Static method in class org.apache.flink.runtime.client.JobClient
-
Sends a [[JobGraph]] to the JobClient actor specified by jobClient which submits it then to
the JobManager.
- submitJobDetached(JobManagerGateway, Configuration, JobGraph, Time, ClassLoader) - Static method in class org.apache.flink.runtime.client.JobClient
-
Submits a job in detached mode.
- submitTask(TaskDeploymentDescriptor, Time) - Method in class org.apache.flink.runtime.jobmanager.slots.ActorTaskManagerGateway
-
- submitTask(TaskDeploymentDescriptor, Time) - Method in interface org.apache.flink.runtime.jobmanager.slots.TaskManagerGateway
-
Submit a task to the task manager.
- submitTask(TaskDeploymentDescriptor, Time) - Method in class org.apache.flink.runtime.jobmaster.RpcTaskManagerGateway
-
- submitTask(TaskDeploymentDescriptor, JobMasterId, Time) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutor
-
- submitTask(TaskDeploymentDescriptor, JobMasterId, Time) - Method in interface org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
-
- SubmittedJobGraph - Class in org.apache.flink.runtime.jobmanager
-
- SubmittedJobGraph(JobGraph, JobInfo) - Constructor for class org.apache.flink.runtime.jobmanager.SubmittedJobGraph
-
- SubmittedJobGraphStore - Interface in org.apache.flink.runtime.jobmanager
-
- SubmittedJobGraphStore.SubmittedJobGraphListener - Interface in org.apache.flink.runtime.jobmanager
-
- submitTopology(String, String, FlinkTopology) - Method in class org.apache.flink.storm.api.FlinkClient
-
Parameter uploadedJarLocation
is actually used to point to the local jar, because Flink does not support
uploading a jar file before hand.
- submitTopology(String, Map, FlinkTopology) - Method in class org.apache.flink.storm.api.FlinkLocalCluster
-
- submitTopology(String, Map<?, ?>, FlinkTopology, SubmitOptions) - Static method in class org.apache.flink.storm.api.FlinkSubmitter
-
Submits a topology to run on the cluster.
- submitTopology(String, Map, FlinkTopology) - Static method in class org.apache.flink.storm.api.FlinkSubmitter
-
Submits a topology to run on the cluster.
- submitTopologyWithOpts(String, String, FlinkTopology) - Method in class org.apache.flink.storm.api.FlinkClient
-
Parameter uploadedJarLocation
is actually used to point to the local jar, because Flink does not support
uploading a jar file before hand.
- submitTopologyWithOpts(String, Map, FlinkTopology, SubmitOptions) - Method in class org.apache.flink.storm.api.FlinkLocalCluster
-
- submitTopologyWithProgressBar(String, Map<?, ?>, FlinkTopology) - Static method in class org.apache.flink.storm.api.FlinkSubmitter
-
- subscribe(EventListener<TaskEvent>, Class<? extends TaskEvent>) - Method in class org.apache.flink.runtime.io.network.api.TaskEventHandler
-
- subscribedPartitionStates() - Method in class org.apache.flink.streaming.connectors.kafka.internals.AbstractFetcher
-
Gets all partitions (with partition state) that this fetcher is subscribed to.
- subscribeToEvent(ResultPartitionID, EventListener<TaskEvent>, Class<? extends TaskEvent>) - Method in class org.apache.flink.runtime.io.network.TaskEventDispatcher
-
Subscribes a listener to this dispatcher for events on a partition.
- subSequence(int, int) - Method in class org.apache.flink.types.StringValue
-
- substituteDeprecatedConfigKey(Configuration, String, String) - Static method in class org.apache.flink.runtime.clusterframework.BootstrapTools
-
Sets the value of a new config key to the value of a deprecated config key.
- substituteDeprecatedConfigPrefix(Configuration, String, String) - Static method in class org.apache.flink.runtime.clusterframework.BootstrapTools
-
Sets the value of a new config key to the value of a deprecated config key.
- substring(int) - Method in class org.apache.flink.types.StringValue
-
Returns a new StringValuestring that is a substring of this string.
- substring(int, int) - Method in class org.apache.flink.types.StringValue
-
Returns a new StringValuestring that is a substring of this string.
- substring(StringValue, int) - Method in class org.apache.flink.types.StringValue
-
Copies a substring of this string into the given target StringValue.
- substring(StringValue, int, int) - Method in class org.apache.flink.types.StringValue
-
Copies a substring of this string into the given target StringValue.
- SUBTASK_CURRENT_ATTEMPT_DETAILS_REST_PATH - Static variable in class org.apache.flink.runtime.rest.handler.legacy.SubtaskCurrentAttemptDetailsHandler
-
- SubtaskAccumulatorsInfo(int, int, String, Collection<UserAccumulator>) - Constructor for class org.apache.flink.runtime.rest.messages.job.SubtasksAllAccumulatorsInfo.SubtaskAccumulatorsInfo
-
- SubtaskAttemptMessageParameters - Class in org.apache.flink.runtime.rest.messages.job
-
The type Subtask attempt message parameters.
- SubtaskAttemptMessageParameters() - Constructor for class org.apache.flink.runtime.rest.messages.job.SubtaskAttemptMessageParameters
-
- subtaskAttemptPathParameter - Variable in class org.apache.flink.runtime.rest.messages.job.SubtaskAttemptMessageParameters
-
- SubtaskAttemptPathParameter - Class in org.apache.flink.runtime.rest.messages.job
-
Path parameter identifying subtask attempt.
- SubtaskAttemptPathParameter() - Constructor for class org.apache.flink.runtime.rest.messages.job.SubtaskAttemptPathParameter
-
Instantiates a new Subtask attempt path parameter.
- SubtaskBackPressureInfo(int, JobVertexBackPressureInfo.VertexBackPressureLevel, double) - Constructor for class org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo.SubtaskBackPressureInfo
-
- subtaskBaseDirectory(long) - Method in interface org.apache.flink.runtime.state.LocalRecoveryDirectoryProvider
-
Returns the local state directory for the owning subtask the given checkpoint id w.r.t.
- subtaskBaseDirectory(long) - Method in class org.apache.flink.runtime.state.LocalRecoveryDirectoryProviderImpl
-
- SubtaskCheckpointStatistics - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
Checkpoint statistics for a subtask.
- SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
Checkpoint statistics for a completed subtask checkpoint.
- SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics.CheckpointAlignment - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
Alignment statistics of the checkpoint.
- SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics.CheckpointDuration - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
Duration of the checkpoint.
- SubtaskCheckpointStatistics.PendingSubtaskCheckpointStatistics - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
Checkpoint statistics for a pending subtask checkpoint.
- SubtaskCurrentAttemptDetailsHandler - Class in org.apache.flink.runtime.rest.handler.job
-
Request handler providing details about a single task execution attempt.
- SubtaskCurrentAttemptDetailsHandler(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MessageHeaders<EmptyRequestBody, SubtaskExecutionAttemptDetailsInfo, SubtaskMessageParameters>, ExecutionGraphCache, Executor, MetricFetcher<?>) - Constructor for class org.apache.flink.runtime.rest.handler.job.SubtaskCurrentAttemptDetailsHandler
-
- SubtaskCurrentAttemptDetailsHandler - Class in org.apache.flink.runtime.rest.handler.legacy
-
Request handler providing details about a single task execution attempt.
- SubtaskCurrentAttemptDetailsHandler(ExecutionGraphCache, Executor, MetricFetcher) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.SubtaskCurrentAttemptDetailsHandler
-
- SubtaskCurrentAttemptDetailsHeaders - Class in org.apache.flink.runtime.rest.messages.job
-
- SubtaskCurrentAttemptDetailsHeaders() - Constructor for class org.apache.flink.runtime.rest.messages.job.SubtaskCurrentAttemptDetailsHeaders
-
- SubtaskExecutionAttemptAccumulatorsHandler - Class in org.apache.flink.runtime.rest.handler.job
-
Request handler for the subtask execution attempt accumulators.
- SubtaskExecutionAttemptAccumulatorsHandler(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MessageHeaders<EmptyRequestBody, SubtaskExecutionAttemptAccumulatorsInfo, SubtaskAttemptMessageParameters>, ExecutionGraphCache, Executor) - Constructor for class org.apache.flink.runtime.rest.handler.job.SubtaskExecutionAttemptAccumulatorsHandler
-
Instantiates a new Abstract job vertex handler.
- SubtaskExecutionAttemptAccumulatorsHandler - Class in org.apache.flink.runtime.rest.handler.legacy
-
Base class for request handlers whose response depends on a specific job vertex (defined
via the "vertexid" parameter) in a specific job, defined via (defined voa the "jobid" parameter).
- SubtaskExecutionAttemptAccumulatorsHandler(ExecutionGraphCache, Executor) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.SubtaskExecutionAttemptAccumulatorsHandler
-
- SubtaskExecutionAttemptAccumulatorsHandler.SubtaskExecutionAttemptAccumulatorsJsonArchivist - Class in org.apache.flink.runtime.rest.handler.legacy
-
Archivist for the SubtaskExecutionAttemptAccumulatorsHandler.
- SubtaskExecutionAttemptAccumulatorsHeaders - Class in org.apache.flink.runtime.rest.messages.job
-
- SubtaskExecutionAttemptAccumulatorsHeaders() - Constructor for class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptAccumulatorsHeaders
-
- SubtaskExecutionAttemptAccumulatorsInfo - Class in org.apache.flink.runtime.rest.messages.job
-
- SubtaskExecutionAttemptAccumulatorsInfo(int, int, String, Collection<UserAccumulator>) - Constructor for class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptAccumulatorsInfo
-
- SubtaskExecutionAttemptAccumulatorsJsonArchivist() - Constructor for class org.apache.flink.runtime.rest.handler.legacy.SubtaskExecutionAttemptAccumulatorsHandler.SubtaskExecutionAttemptAccumulatorsJsonArchivist
-
- SubtaskExecutionAttemptDetailsHandler - Class in org.apache.flink.runtime.rest.handler.job
-
Handler of specific sub task execution attempt.
- SubtaskExecutionAttemptDetailsHandler(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MessageHeaders<EmptyRequestBody, SubtaskExecutionAttemptDetailsInfo, SubtaskAttemptMessageParameters>, ExecutionGraphCache, Executor, MetricFetcher<?>) - Constructor for class org.apache.flink.runtime.rest.handler.job.SubtaskExecutionAttemptDetailsHandler
-
Instantiates a new subtask execution attempt details handler.
- SubtaskExecutionAttemptDetailsHandler - Class in org.apache.flink.runtime.rest.handler.legacy
-
Request handler providing details about a single task execution attempt.
- SubtaskExecutionAttemptDetailsHandler(ExecutionGraphCache, Executor, MetricFetcher) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.SubtaskExecutionAttemptDetailsHandler
-
- SubtaskExecutionAttemptDetailsHandler.SubtaskExecutionAttemptDetailsJsonArchivist - Class in org.apache.flink.runtime.rest.handler.legacy
-
Archivist for the SubtaskExecutionAttemptDetailsHandler.
- SubtaskExecutionAttemptDetailsHeaders - Class in org.apache.flink.runtime.rest.messages.job
-
- SubtaskExecutionAttemptDetailsHeaders() - Constructor for class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsHeaders
-
- SubtaskExecutionAttemptDetailsInfo - Class in org.apache.flink.runtime.rest.messages.job
-
The sub task execution attempt response.
- SubtaskExecutionAttemptDetailsInfo(int, ExecutionState, int, String, long, long, long, IOMetricsInfo) - Constructor for class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsInfo
-
- SubtaskExecutionAttemptDetailsJsonArchivist() - Constructor for class org.apache.flink.runtime.rest.handler.legacy.SubtaskExecutionAttemptDetailsHandler.SubtaskExecutionAttemptDetailsJsonArchivist
-
- subtaskIndex - Variable in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.OperatorQueryScopeInfo
-
- subtaskIndex - Variable in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.TaskQueryScopeInfo
-
- subtaskIndex - Variable in class org.apache.flink.runtime.metrics.groups.TaskMetricGroup
-
- subtaskIndex() - Method in class org.apache.flink.runtime.metrics.groups.TaskMetricGroup
-
- subtaskIndexPathParameter - Variable in class org.apache.flink.runtime.rest.messages.job.SubtaskMessageParameters
-
- SubtaskIndexPathParameter - Class in org.apache.flink.runtime.rest.messages
-
Path parameter specifying the index of a subtask.
- SubtaskIndexPathParameter() - Constructor for class org.apache.flink.runtime.rest.messages.SubtaskIndexPathParameter
-
- SubtaskMessageParameters - Class in org.apache.flink.runtime.rest.messages.job
-
Message parameters for subtask REST handlers.
- SubtaskMessageParameters() - Constructor for class org.apache.flink.runtime.rest.messages.job.SubtaskMessageParameters
-
- SubtaskMetricsHandler - Class in org.apache.flink.runtime.rest.handler.job.metrics
-
Handler that returns subtask metrics.
- SubtaskMetricsHandler(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MetricFetcher) - Constructor for class org.apache.flink.runtime.rest.handler.job.metrics.SubtaskMetricsHandler
-
- SubtaskMetricsHandler - Class in org.apache.flink.runtime.rest.handler.legacy.metrics
-
Request handler that returns, aggregated across all subtasks of a single tasks, a list of all available metrics or the
values for a set of metrics.
- SubtaskMetricsHandler(Executor, MetricFetcher) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.metrics.SubtaskMetricsHandler
-
- SubtaskMetricsHeaders - Class in org.apache.flink.runtime.rest.messages.job.metrics
-
- SubtaskMetricsMessageParameters - Class in org.apache.flink.runtime.rest.messages.job.metrics
-
- SubtaskMetricsMessageParameters() - Constructor for class org.apache.flink.runtime.rest.messages.job.metrics.SubtaskMetricsMessageParameters
-
- SubtasksAllAccumulatorsHandler - Class in org.apache.flink.runtime.rest.handler.job
-
Request handler for the subtasks all accumulators.
- SubtasksAllAccumulatorsHandler(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MessageHeaders<EmptyRequestBody, SubtasksAllAccumulatorsInfo, JobVertexMessageParameters>, ExecutionGraphCache, Executor) - Constructor for class org.apache.flink.runtime.rest.handler.job.SubtasksAllAccumulatorsHandler
-
- SubtasksAllAccumulatorsHandler - Class in org.apache.flink.runtime.rest.handler.legacy
-
Request handler that returns the accumulators for all subtasks of job vertex.
- SubtasksAllAccumulatorsHandler(ExecutionGraphCache, Executor) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.SubtasksAllAccumulatorsHandler
-
- SubtasksAllAccumulatorsHandler.SubtasksAllAccumulatorsJsonArchivist - Class in org.apache.flink.runtime.rest.handler.legacy
-
Archivist for the SubtasksAllAccumulatorsHandler.
- SubtasksAllAccumulatorsHeaders - Class in org.apache.flink.runtime.rest.messages
-
- SubtasksAllAccumulatorsInfo - Class in org.apache.flink.runtime.rest.messages.job
-
- SubtasksAllAccumulatorsInfo(JobVertexID, int, Collection<SubtasksAllAccumulatorsInfo.SubtaskAccumulatorsInfo>) - Constructor for class org.apache.flink.runtime.rest.messages.job.SubtasksAllAccumulatorsInfo
-
- SubtasksAllAccumulatorsInfo.SubtaskAccumulatorsInfo - Class in org.apache.flink.runtime.rest.messages.job
-
Detailed information about subtask accumulators.
- SubtasksAllAccumulatorsJsonArchivist() - Constructor for class org.apache.flink.runtime.rest.handler.legacy.SubtasksAllAccumulatorsHandler.SubtasksAllAccumulatorsJsonArchivist
-
- SubtasksFilterQueryParameter - Class in org.apache.flink.runtime.rest.messages.job.metrics
-
- subtaskSpecificCheckpointDirectory(long) - Method in interface org.apache.flink.runtime.state.LocalRecoveryDirectoryProvider
-
Returns the local state directory for the specific operator subtask and the given checkpoint id w.r.t.
- subtaskSpecificCheckpointDirectory(long) - Method in class org.apache.flink.runtime.state.LocalRecoveryDirectoryProviderImpl
-
- SubtaskState - Class in org.apache.flink.runtime.checkpoint
-
Container for the chained state of one parallel subtask of an operator/task.
- SubtaskState(ChainedStateHandle<OperatorStateHandle>, ChainedStateHandle<OperatorStateHandle>, KeyedStateHandle, KeyedStateHandle) - Constructor for class org.apache.flink.runtime.checkpoint.SubtaskState
-
- SubtaskStateStats - Class in org.apache.flink.runtime.checkpoint
-
Statistics for a single subtask that is part of a checkpoint.
- SubtasksTimesHandler - Class in org.apache.flink.runtime.rest.handler.job
-
Request handler for the subtasks times info.
- SubtasksTimesHandler(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MessageHeaders<EmptyRequestBody, SubtasksTimesInfo, JobVertexMessageParameters>, ExecutionGraphCache, Executor) - Constructor for class org.apache.flink.runtime.rest.handler.job.SubtasksTimesHandler
-
- SubtasksTimesHandler - Class in org.apache.flink.runtime.rest.handler.legacy
-
Request handler that returns the state transition timestamps for all subtasks, plus their
location and duration.
- SubtasksTimesHandler(ExecutionGraphCache, Executor) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.SubtasksTimesHandler
-
- SubtasksTimesHandler.SubtasksTimesJsonArchivist - Class in org.apache.flink.runtime.rest.handler.legacy
-
Archivist for the SubtasksTimesHandler.
- SubtasksTimesHeaders - Class in org.apache.flink.runtime.rest.messages
-
- SubtasksTimesHeaders() - Constructor for class org.apache.flink.runtime.rest.messages.SubtasksTimesHeaders
-
- SubtasksTimesInfo - Class in org.apache.flink.runtime.rest.messages
-
- SubtasksTimesInfo(String, String, long, List<SubtasksTimesInfo.SubtaskTimeInfo>) - Constructor for class org.apache.flink.runtime.rest.messages.SubtasksTimesInfo
-
- SubtasksTimesInfo.SubtaskTimeInfo - Class in org.apache.flink.runtime.rest.messages
-
Nested class to encapsulate the sub task times info.
- SubtasksTimesJsonArchivist() - Constructor for class org.apache.flink.runtime.rest.handler.legacy.SubtasksTimesHandler.SubtasksTimesJsonArchivist
-
- SubtaskTimeInfo(int, String, long, Map<ExecutionState, Long>) - Constructor for class org.apache.flink.runtime.rest.messages.SubtasksTimesInfo.SubtaskTimeInfo
-
- subtractCosts(Costs) - Method in class org.apache.flink.optimizer.costs.Costs
-
Subtracts the given costs from these costs.
- SubtractingMapper(long) - Constructor for class org.apache.flink.streaming.tests.BucketingSinkTestProgram.SubtractingMapper
-
- subtractMonths(int, int) - Static method in class org.apache.calcite.avatica.util.DateTimeUtils
-
Finds the number of months between two dates, each represented as the
number of days since the epoch.
- subtractMonths(long, long) - Static method in class org.apache.calcite.avatica.util.DateTimeUtils
-
- subtype(Class<S>) - Method in class org.apache.flink.cep.pattern.GroupPattern
-
- subtype(Class<S>) - Method in class org.apache.flink.cep.pattern.Pattern
-
Applies a subtype constraint on the current pattern.
- SubtypeCondition<T> - Class in org.apache.flink.cep.pattern.conditions
-
A
condition
which filters elements of the given type.
- SubtypeCondition(Class<? extends T>) - Constructor for class org.apache.flink.cep.pattern.conditions.SubtypeCondition
-
- SubUpdate() - Constructor for class org.apache.flink.examples.java.ml.LinearRegression.SubUpdate
-
- Success() - Constructor for class org.apache.flink.runtime.registration.RegistrationResponse.Success
-
- SUCCESS_RETURN_CODE - Static variable in class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
-
- suffix(String) - Method in class org.apache.flink.core.fs.Path
-
Adds a suffix to the final name in the path.
- sum(int) - Method in class org.apache.flink.api.java.DataSet
-
Syntactic sugar for aggregate (SUM, field).
- sum(int) - Method in class org.apache.flink.api.java.operators.UnsortedGrouping
-
Syntactic sugar for aggregate (SUM, field).
- sum(M, M) - Method in class org.apache.flink.graph.gsa.SumFunction
-
- sum(int) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies an aggregation that sums every window of the data stream at the
given position.
- sum(String) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies an aggregation that sums every window of the pojo data stream at
the given field for every window.
- sum(int) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Applies an aggregation that gives a rolling sum of the data stream at the
given position grouped by the given key.
- sum(String) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Applies an aggregation that gives the current sum of the data
stream at the given field by the given key.
- sum(int) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies an aggregation that sums every window of the data stream at the
given position.
- sum(String) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies an aggregation that sums every window of the pojo data stream at the given field for
every window.
- SumAggregationFunction<T> - Class in org.apache.flink.api.java.aggregation
-
Definitions of sum functions for different numerical types.
- SumAggregationFunction() - Constructor for class org.apache.flink.api.java.aggregation.SumAggregationFunction
-
- SumAggregationFunction.SumAggregationFunctionFactory - Class in org.apache.flink.api.java.aggregation
-
- SumAggregationFunctionFactory() - Constructor for class org.apache.flink.api.java.aggregation.SumAggregationFunction.SumAggregationFunctionFactory
-
- SumAggregator<T> - Class in org.apache.flink.streaming.api.functions.aggregation
-
- SumAggregator(int, TypeInformation<T>, ExecutionConfig) - Constructor for class org.apache.flink.streaming.api.functions.aggregation.SumAggregator
-
- SumAggregator(String, TypeInformation<T>, ExecutionConfig) - Constructor for class org.apache.flink.streaming.api.functions.aggregation.SumAggregator
-
- SumDoubleAggregator() - Constructor for class org.apache.flink.api.java.summarize.aggregation.DoubleSummaryAggregator.SumDoubleAggregator
-
- SumFloatAggregator() - Constructor for class org.apache.flink.api.java.summarize.aggregation.FloatSummaryAggregator.SumFloatAggregator
-
- SumFunction<VV,EV,M> - Class in org.apache.flink.graph.gsa
-
- SumFunction() - Constructor for class org.apache.flink.graph.gsa.SumFunction
-
- SumFunction - Class in org.apache.flink.streaming.api.functions.aggregation
-
Internal function for summing up contents of fields.
- SumFunction() - Constructor for class org.apache.flink.streaming.api.functions.aggregation.SumFunction
-
- SumIntegerAggregator() - Constructor for class org.apache.flink.api.java.summarize.aggregation.IntegerSummaryAggregator.SumIntegerAggregator
-
- Summarization<K,VV,EV> - Class in org.apache.flink.graph.library
-
The summarization algorithm computes a condensed version of the input graph
by grouping vertices and edges based on their values.
- Summarization() - Constructor for class org.apache.flink.graph.library.Summarization
-
- Summarization.EdgeValue<EV> - Class in org.apache.flink.graph.library
-
Value that is stored at a summarized edge.
- Summarization.VertexGroupItem<K,VGV> - Class in org.apache.flink.graph.library
-
Represents a single vertex in a vertex group.
- Summarization.VertexValue<VV> - Class in org.apache.flink.graph.library
-
Value that is stored at a summarized vertex.
- Summarization.VertexWithRepresentative<K> - Class in org.apache.flink.graph.library
-
Represents a vertex identifier and its corresponding vertex group identifier.
- SummarizationData - Class in org.apache.flink.graph.examples.data
-
Provides the default data set used for Summarization tests.
- summarize(DataSet<T>) - Static method in class org.apache.flink.api.java.utils.DataSetUtils
-
Summarize a DataSet of Tuples by collecting single pass statistics for all columns.
- Summary(MinMaxAvgStatistics, MinMaxAvgStatistics, MinMaxAvgStatistics) - Constructor for class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.Summary
-
- Summary(MinMaxAvgStatistics, MinMaxAvgStatistics, TaskCheckpointStatisticsWithSubtaskDetails.CheckpointDuration, TaskCheckpointStatisticsWithSubtaskDetails.CheckpointAlignment) - Constructor for class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.Summary
-
- SummaryAggregatorFactory - Class in org.apache.flink.api.java.summarize.aggregation
-
Factory for creating Summary Aggregators.
- SummaryAggregatorFactory() - Constructor for class org.apache.flink.api.java.summarize.aggregation.SummaryAggregatorFactory
-
- SumReducer() - Constructor for class org.apache.flink.examples.java.misc.PiEstimation.SumReducer
-
- SumShortAggregator() - Constructor for class org.apache.flink.api.java.summarize.aggregation.ShortSummaryAggregator.SumShortAggregator
-
- SuperstepBarrier - Class in org.apache.flink.runtime.iterative.concurrent
-
A resettable one-shot latch.
- SuperstepBarrier(ClassLoader) - Constructor for class org.apache.flink.runtime.iterative.concurrent.SuperstepBarrier
-
- SuperstepKickoffLatch - Class in org.apache.flink.runtime.iterative.concurrent
-
Latch used to wait for the previous superstep to complete.
- SuperstepKickoffLatch() - Constructor for class org.apache.flink.runtime.iterative.concurrent.SuperstepKickoffLatch
-
- SuperstepKickoffLatchBroker - Class in org.apache.flink.runtime.iterative.concurrent
-
- SupplierWithException<R,E extends Throwable> - Interface in org.apache.flink.util.function
-
A functional interface for a
Supplier
that may
throw exceptions.
- supplyAsync(SupplierWithException<T, ?>, Executor) - Static method in class org.apache.flink.runtime.concurrent.FutureUtils
-
- supportedProperties() - Method in class org.apache.flink.streaming.connectors.kafka.KafkaJsonTableSourceFactory
-
- supportsAsynchronousSnapshots() - Method in class org.apache.flink.contrib.streaming.state.RocksDBKeyedStateBackend
-
- supportsAsynchronousSnapshots() - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
-
- supportsAsynchronousSnapshots() - Method in class org.apache.flink.runtime.state.heap.HeapKeyedStateBackend
-
- supportsCompareAgainstReference() - Method in class org.apache.flink.api.common.typeutils.TypeComparator
-
- supportsHighlyAvailableStorage() - Method in interface org.apache.flink.runtime.state.CheckpointStorage
-
Checks whether this backend supports highly available storage of data.
- supportsHighlyAvailableStorage() - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStorage
-
- supportsHighlyAvailableStorage() - Method in class org.apache.flink.runtime.state.memory.MemoryBackendCheckpointStorage
-
- supportsKafkaTimestamps() - Method in class org.apache.flink.streaming.connectors.kafka.Kafka010AvroTableSource.Builder
-
- supportsKafkaTimestamps() - Method in class org.apache.flink.streaming.connectors.kafka.Kafka010JsonTableSource.Builder
-
- supportsKafkaTimestamps() - Method in class org.apache.flink.streaming.connectors.kafka.Kafka011AvroTableSource.Builder
-
- supportsKafkaTimestamps() - Method in class org.apache.flink.streaming.connectors.kafka.Kafka011JsonTableSource.Builder
-
- supportsKafkaTimestamps() - Method in class org.apache.flink.streaming.connectors.kafka.Kafka08AvroTableSource.Builder
-
- supportsKafkaTimestamps() - Method in class org.apache.flink.streaming.connectors.kafka.Kafka08JsonTableSource.Builder
-
- supportsKafkaTimestamps() - Method in class org.apache.flink.streaming.connectors.kafka.Kafka09AvroTableSource.Builder
-
- supportsKafkaTimestamps() - Method in class org.apache.flink.streaming.connectors.kafka.Kafka09JsonTableSource.Builder
-
- supportsKafkaTimestamps() - Method in class org.apache.flink.streaming.connectors.kafka.KafkaTableSource.Builder
-
True if the KafkaSource supports Kafka timestamps, false otherwise.
- supportsMultiPaths() - Method in class org.apache.flink.api.common.io.FileInputFormat
-
- supportsMultiPaths() - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
-
- supportsMultiPaths() - Method in class org.apache.flink.api.java.io.TextInputFormat
-
- supportsMultiPaths() - Method in class org.apache.flink.api.java.io.TextValueInputFormat
-
- supportsMultiPaths() - Method in class org.apache.flink.formats.avro.AvroInputFormat
-
- supportsMultiPaths() - Method in class org.apache.flink.orc.OrcRowInputFormat
-
- supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.array.PrimitiveArrayComparator
-
- supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.BigDecComparator
-
- supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.BigIntComparator
-
- supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.BooleanComparator
-
- supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueComparator
-
- supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.ByteComparator
-
- supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.ByteValueComparator
-
- supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.CharComparator
-
- supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.CharValueComparator
-
- supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.DateComparator
-
- supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.DoubleComparator
-
- supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueComparator
-
- supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.EnumComparator
-
- supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.FloatComparator
-
- supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.FloatValueComparator
-
- supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.IntComparator
-
- supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.IntValueComparator
-
- supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.LongComparator
-
- supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.LongValueComparator
-
- supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.NullValueComparator
-
- supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.ShortComparator
-
- supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.ShortValueComparator
-
- supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.SqlTimestampComparator
-
- supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.StringComparator
-
- supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.StringValueComparator
-
- supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.TypeComparator
-
Checks whether the data type supports the creation of a normalized key for comparison.
- supportsNormalizedKey() - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueComparator
-
- supportsNormalizedKey() - Method in class org.apache.flink.api.java.typeutils.runtime.GenericTypeComparator
-
- supportsNormalizedKey() - Method in class org.apache.flink.api.java.typeutils.runtime.NullAwareComparator
-
- supportsNormalizedKey() - Method in class org.apache.flink.api.java.typeutils.runtime.PojoComparator
-
- supportsNormalizedKey() - Method in class org.apache.flink.api.java.typeutils.runtime.RowComparator
-
- supportsNormalizedKey() - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
-
- supportsNormalizedKey() - Method in class org.apache.flink.api.java.typeutils.runtime.ValueComparator
-
- supportsNormalizedKey() - Method in class org.apache.flink.api.java.typeutils.runtime.WritableComparator
-
- supportsNormalizedKey() - Method in class org.apache.flink.graph.types.valuearray.ByteValueArrayComparator
-
- supportsNormalizedKey() - Method in class org.apache.flink.graph.types.valuearray.CharValueArrayComparator
-
- supportsNormalizedKey() - Method in class org.apache.flink.graph.types.valuearray.DoubleValueArrayComparator
-
- supportsNormalizedKey() - Method in class org.apache.flink.graph.types.valuearray.FloatValueArrayComparator
-
- supportsNormalizedKey() - Method in class org.apache.flink.graph.types.valuearray.IntValueArrayComparator
-
- supportsNormalizedKey() - Method in class org.apache.flink.graph.types.valuearray.LongValueArrayComparator
-
- supportsNormalizedKey() - Method in class org.apache.flink.graph.types.valuearray.NullValueArrayComparator
-
- supportsNormalizedKey() - Method in class org.apache.flink.graph.types.valuearray.ShortValueArrayComparator
-
- supportsNormalizedKey() - Method in class org.apache.flink.graph.types.valuearray.StringValueArrayComparator
-
- supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.common.typeutils.base.array.PrimitiveArrayComparator
-
- supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.common.typeutils.base.BasicTypeComparator
-
- supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.common.typeutils.base.BigDecComparator
-
- supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.common.typeutils.base.BigIntComparator
-
- supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueComparator
-
- supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.common.typeutils.base.ByteValueComparator
-
- supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.common.typeutils.base.CharValueComparator
-
- supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueComparator
-
- supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.common.typeutils.base.FloatValueComparator
-
- supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.common.typeutils.base.IntValueComparator
-
- supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.common.typeutils.base.LongValueComparator
-
- supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.common.typeutils.base.NullValueComparator
-
- supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.common.typeutils.base.ShortValueComparator
-
- supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.common.typeutils.base.StringComparator
-
- supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.common.typeutils.base.StringValueComparator
-
- supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.common.typeutils.TypeComparator
-
Check whether this comparator supports to serialize the record in a format that replaces its keys by a normalized
key.
- supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueComparator
-
- supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.java.typeutils.runtime.GenericTypeComparator
-
- supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.java.typeutils.runtime.NullAwareComparator
-
- supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.java.typeutils.runtime.PojoComparator
-
- supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.java.typeutils.runtime.RowComparator
-
- supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
-
- supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.java.typeutils.runtime.ValueComparator
-
- supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.java.typeutils.runtime.WritableComparator
-
- supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.graph.types.valuearray.ByteValueArrayComparator
-
- supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.graph.types.valuearray.CharValueArrayComparator
-
- supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.graph.types.valuearray.DoubleValueArrayComparator
-
- supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.graph.types.valuearray.FloatValueArrayComparator
-
- supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.graph.types.valuearray.IntValueArrayComparator
-
- supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.graph.types.valuearray.LongValueArrayComparator
-
- supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.graph.types.valuearray.NullValueArrayComparator
-
- supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.graph.types.valuearray.ShortValueArrayComparator
-
- supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.graph.types.valuearray.StringValueArrayComparator
-
- suppressExceptions(RunnableWithException) - Static method in class org.apache.flink.util.ExceptionUtils
-
- SuppressRestartsException - Exception in org.apache.flink.runtime.execution
-
Exception thrown in order to suppress job restarts.
- SuppressRestartsException(Throwable) - Constructor for exception org.apache.flink.runtime.execution.SuppressRestartsException
-
- suspend(Throwable) - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
Suspends the current ExecutionGraph.
- suspend(Exception, Time) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
-
Suspending job, all the running tasks will be cancelled, and communication with other components
will be disposed.
- suspend() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotPool
-
Suspends this pool, meaning it has lost its authority to accept and distribute slots.
- suspend() - Method in interface org.apache.flink.runtime.jobmaster.slotpool.SlotPoolGateway
-
- suspend() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
-
Suspends the component.
- swap() - Method in class org.apache.flink.api.java.tuple.Tuple2
-
Returns a shallow copy of the tuple with swapped values.
- swap(int, int) - Method in class org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
-
- swap(int, int, int, int) - Method in class org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
-
- swap(int, int) - Method in interface org.apache.flink.runtime.operators.sort.IndexedSortable
-
Swap items at the given addresses.
- swap(int, int, int, int) - Method in interface org.apache.flink.runtime.operators.sort.IndexedSortable
-
Swap records at the given addresses.
- swap(int, int) - Method in class org.apache.flink.runtime.operators.sort.NormalizedKeySorter
-
- swap(int, int, int, int) - Method in class org.apache.flink.runtime.operators.sort.NormalizedKeySorter
-
- swapBytes(byte[], MemorySegment, int, int, int) - Method in class org.apache.flink.core.memory.MemorySegment
-
Swaps bytes between two memory segments, using the given auxiliary buffer.
- swapUnionNodes(PlanNode) - Method in class org.apache.flink.optimizer.plan.Channel
-
Utility method used while swapping binary union nodes for n-ary union nodes.
- SwiftFileSystemFactory - Class in org.apache.flink.fs.openstackhadoop
-
Simple factory for the Swift file system.
- SwiftFileSystemFactory() - Constructor for class org.apache.flink.fs.openstackhadoop.SwiftFileSystemFactory
-
- switchBuffers() - Method in class org.apache.flink.runtime.iterative.io.SerializedUpdateBuffer
-
- sync() - Method in class org.apache.flink.core.fs.FSDataOutputStream
-
Flushes the data all the way to the persistent non-volatile storage (for example disks).
- sync() - Method in class org.apache.flink.core.fs.FSDataOutputStreamWrapper
-
- sync() - Method in class org.apache.flink.core.fs.local.LocalDataOutputStream
-
- sync() - Method in class org.apache.flink.core.testutils.CheckedThread
-
Waits until the thread is completed and checks whether any error occurred during
the execution.
- sync(long) - Method in class org.apache.flink.core.testutils.CheckedThread
-
Waits with timeout until the thread is completed and checks whether any error
occurred during the execution.
- sync() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopDataOutputStream
-
- sync() - Method in class org.apache.flink.runtime.state.DuplicatingCheckpointOutputStream
-
- sync() - Method in class org.apache.flink.runtime.state.filesystem.FileBasedStateOutputStream
-
- sync() - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointMetadataOutputStream
-
- sync() - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStreamFactory.FsCheckpointStateOutputStream
-
- sync() - Method in class org.apache.flink.runtime.state.memory.MemCheckpointStreamFactory.MemoryCheckpointOutputStream
-
- SyncEventHandler - Class in org.apache.flink.runtime.iterative.task
-
Listener for
WorkerDoneEvent
which also aggregates all aggregators
from iteration tasks and signals the end of the superstep.
- SyncEventHandler(int, Map<String, Aggregator<?>>, ClassLoader) - Constructor for class org.apache.flink.runtime.iterative.task.SyncEventHandler
-
- SynchronousBufferFileReader - Class in org.apache.flink.runtime.io.disk.iomanager
-
- SynchronousBufferFileReader(FileIOChannel.ID, boolean) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.SynchronousBufferFileReader
-
- SynchronousChainedCombineDriver<IN,OUT> - Class in org.apache.flink.runtime.operators.chaining
-
The chained variant of the combine driver which is also implemented in GroupReduceCombineDriver.
- SynchronousChainedCombineDriver() - Constructor for class org.apache.flink.runtime.operators.chaining.SynchronousChainedCombineDriver
-
- SynchronousFileIOChannel - Class in org.apache.flink.runtime.io.disk.iomanager
-
A base class for synchronous readers and writers.
- SynchronousFileIOChannel(FileIOChannel.ID, boolean) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.SynchronousFileIOChannel
-
- SystemClock - Class in org.apache.flink.runtime.util.clock
-
A clock that returns the time of the system / process.
- SystemClock - Class in org.apache.flink.streaming.connectors.fs
-
A
Clock
that uses
System.currentTimeMillis()
to determine the system time.
- SystemClock() - Constructor for class org.apache.flink.streaming.connectors.fs.SystemClock
-
- SystemProcessingTimeService - Class in org.apache.flink.streaming.runtime.tasks
-
- SystemProcessingTimeService(AsyncExceptionHandler, Object) - Constructor for class org.apache.flink.streaming.runtime.tasks.SystemProcessingTimeService
-
- SystemProcessingTimeService(AsyncExceptionHandler, Object, ThreadFactory) - Constructor for class org.apache.flink.streaming.runtime.tasks.SystemProcessingTimeService
-
- table - Variable in class org.apache.flink.addons.hbase.AbstractTableInputFormat
-
- TableInputFormat<T extends Tuple> - Class in org.apache.flink.addons.hbase
-
InputFormat
subclass that wraps the access for HTables.
- TableInputFormat() - Constructor for class org.apache.flink.addons.hbase.TableInputFormat
-
- TableInputSplit - Class in org.apache.flink.addons.hbase
-
This class implements a input splits for HBase.
- TableType - Annotation Type in org.apache.flink.table.annotation
-
- tagAsEvent() - Method in interface org.apache.flink.runtime.io.network.buffer.Buffer
-
Tags this buffer to represent an event.
- tagAsEvent() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
-
- tagAsEvent() - Method in class org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
-
- tagged(Value) - Static method in class org.apache.flink.api.java.sca.UdfAnalyzerUtils
-
- TaggedValue - Class in org.apache.flink.api.java.sca
-
Extension of ASM's BasicValue that allows to assign "tags"
to values and add additional information depending on the tag to the Value.
- TaggedValue(Type) - Constructor for class org.apache.flink.api.java.sca.TaggedValue
-
- TaggedValue(Type, TaggedValue.Tag) - Constructor for class org.apache.flink.api.java.sca.TaggedValue
-
- TaggedValue(Type, TaggedValue.Input, String, boolean, boolean) - Constructor for class org.apache.flink.api.java.sca.TaggedValue
-
- TaggedValue(Type, Map<String, TaggedValue>) - Constructor for class org.apache.flink.api.java.sca.TaggedValue
-
- TaggedValue(int) - Constructor for class org.apache.flink.api.java.sca.TaggedValue
-
- TaggedValue.Input - Enum in org.apache.flink.api.java.sca
-
Distinguishes between inputs in case of two input operators.
- TaggedValue.Tag - Enum in org.apache.flink.api.java.sca
-
Possible tags.
- TAGS - Static variable in class org.apache.flink.metrics.datadog.DatadogHttpReporter
-
- takeNext(BlockingQueue<UnilateralSortMerger.CircularElement<E>>, Queue<UnilateralSortMerger.CircularElement<E>>) - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SpillingThread
-
- takeRanges(String, int, Set<String>) - Method in class org.apache.flink.mesos.util.MesosResourceAllocation
-
Takes some amount of range resources (e.g.
- takeScalar(String, double, Set<String>) - Method in class org.apache.flink.mesos.util.MesosResourceAllocation
-
Takes some amount of scalar resources (e.g.
- targetPartition - Variable in class org.apache.flink.runtime.io.network.api.writer.RecordWriter
-
- targetState() - Method in class org.apache.flink.streaming.examples.statemachine.dfa.Transition
-
- Task - Class in org.apache.flink.runtime.taskmanager
-
The Task represents one execution of a parallel subtask on a TaskManager.
- Task(JobInformation, TaskInformation, ExecutionAttemptID, AllocationID, int, int, Collection<ResultPartitionDeploymentDescriptor>, Collection<InputGateDeploymentDescriptor>, int, MemoryManager, IOManager, NetworkEnvironment, BroadcastVariableManager, TaskStateManager, TaskManagerActions, InputSplitProvider, CheckpointResponder, BlobCacheService, LibraryCacheManager, FileCache, TaskManagerRuntimeInfo, TaskMetricGroup, ResultPartitionConsumableNotifier, PartitionProducerStateChecker, Executor) - Constructor for class org.apache.flink.runtime.taskmanager.Task
-
IMPORTANT: This constructor may not start any work that would need to
be undone in the case of a failing task deployment.
- TASK_CANCELLATION_INTERVAL - Static variable in class org.apache.flink.configuration.TaskManagerOptions
-
Time interval in milliseconds between two successive task cancellation
attempts.
- TASK_CANCELLATION_INTERVAL_MILLIS - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- TASK_CANCELLATION_TIMEOUT - Static variable in class 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 - Static variable in class org.apache.flink.configuration.TaskManagerOptions
-
This configures how long we wait for the timers to finish all pending timer threads
when the stream task is cancelled .
- TASK_CHECKPOINT_ALIGNMENT_BYTES_LIMIT - Static variable in class org.apache.flink.configuration.TaskManagerOptions
-
The maximum number of bytes that a checkpoint alignment may buffer.
- TASK_ID_PATTERN - Static variable in class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManagerParameters
-
- TASK_MANAGER_DATA_PORT_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- TASK_MANAGER_DATA_SSL_ENABLED - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- TASK_MANAGER_DEBUG_MEMORY_USAGE_LOG_INTERVAL_MS - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- TASK_MANAGER_DEBUG_MEMORY_USAGE_START_LOG_THREAD - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- TASK_MANAGER_HEAP_MEMORY - Static variable in class org.apache.flink.configuration.TaskManagerOptions
-
JVM heap size (in megabytes) for the TaskManagers.
- TASK_MANAGER_HOSTNAME_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- TASK_MANAGER_ID_KEY - Static variable in class org.apache.flink.runtime.rest.handler.legacy.TaskManagersHandler
-
- TASK_MANAGER_INITIAL_REGISTRATION_PAUSE - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- TASK_MANAGER_IPC_PORT_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- TASK_MANAGER_LOG_PATH_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
-
The config parameter defining the taskmanager log file location.
- TASK_MANAGER_MAX_REGISTARTION_PAUSE - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- TASK_MANAGER_MAX_REGISTRATION_DURATION - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- TASK_MANAGER_MEMORY_FRACTION_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- TASK_MANAGER_MEMORY_OFF_HEAP_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- TASK_MANAGER_MEMORY_PRE_ALLOCATE_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- TASK_MANAGER_MEMORY_SEGMENT_SIZE_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- TASK_MANAGER_MEMORY_SIZE - Static variable in class org.apache.flink.test.util.TestBaseUtils
-
- TASK_MANAGER_MEMORY_SIZE_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- TASK_MANAGER_NAME - Static variable in class org.apache.flink.runtime.taskexecutor.TaskExecutor
-
- TASK_MANAGER_NETWORK_DEFAULT_IO_MODE - Static variable in class org.apache.flink.configuration.ConfigConstants
-
The implementation to use for spillable/spilled intermediate results, which have both
synchronous and asynchronous implementations: "sync" or "async".
- TASK_MANAGER_NETWORK_NUM_BUFFERS_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- TASK_MANAGER_NUM_TASK_SLOTS - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- TASK_MANAGER_REFUSED_REGISTRATION_PAUSE - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- TASK_MANAGER_TIMEOUT - Static variable in class org.apache.flink.configuration.ResourceManagerOptions
-
The timeout for an idle task manager to be released, in milliseconds.
- TASK_MANAGER_TMP_DIR_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
-
- TASK_MANAGERS_FIELD_DURATION - Static variable in class org.apache.flink.runtime.rest.messages.JobVertexTaskManagersInfo.TaskManagersInfo
-
- TASK_MANAGERS_FIELD_END_TIME - Static variable in class org.apache.flink.runtime.rest.messages.JobVertexTaskManagersInfo.TaskManagersInfo
-
- TASK_MANAGERS_FIELD_HOST - Static variable in class org.apache.flink.runtime.rest.messages.JobVertexTaskManagersInfo.TaskManagersInfo
-
- TASK_MANAGERS_FIELD_METRICS - Static variable in class org.apache.flink.runtime.rest.messages.JobVertexTaskManagersInfo.TaskManagersInfo
-
- TASK_MANAGERS_FIELD_START_TIME - Static variable in class org.apache.flink.runtime.rest.messages.JobVertexTaskManagersInfo.TaskManagersInfo
-
- TASK_MANAGERS_FIELD_STATUS - Static variable in class org.apache.flink.runtime.rest.messages.JobVertexTaskManagersInfo.TaskManagersInfo
-
- TASK_MANAGERS_FIELD_STATUS_COUNTS - Static variable in class org.apache.flink.runtime.rest.messages.JobVertexTaskManagersInfo.TaskManagersInfo
-
- TASK_SLOTS_AVAILABLE - Static variable in class org.apache.flink.runtime.metrics.MetricNames
-
- TASK_SLOTS_TOTAL - Static variable in class org.apache.flink.runtime.metrics.MetricNames
-
- TaskActions - Interface in org.apache.flink.runtime.taskmanager
-
Actions which can be performed on a
Task
.
- TaskCheckpointMessageParameters - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
Message parameters for subtask related checkpoint message.
- TaskCheckpointMessageParameters() - Constructor for class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointMessageParameters
-
- TaskCheckpointStatisticDetailsHandler - Class in org.apache.flink.runtime.rest.handler.job.checkpoints
-
REST handler which serves checkpoint statistics for subtasks.
- TaskCheckpointStatisticDetailsHandler(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MessageHeaders<EmptyRequestBody, TaskCheckpointStatisticsWithSubtaskDetails, TaskCheckpointMessageParameters>, ExecutionGraphCache, Executor, CheckpointStatsCache) - Constructor for class org.apache.flink.runtime.rest.handler.job.checkpoints.TaskCheckpointStatisticDetailsHandler
-
- TaskCheckpointStatistics - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
Checkpoint statistics for a single task.
- TaskCheckpointStatistics(long, CheckpointStatsStatus, long, long, long, long, int, int) - Constructor for class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatistics
-
- TaskCheckpointStatisticsHeaders - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
- TaskCheckpointStatisticsWithSubtaskDetails - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
Task checkpoint statistics which also includes information about the sub task
checkpoint statistics.
- TaskCheckpointStatisticsWithSubtaskDetails(long, CheckpointStatsStatus, long, long, long, long, int, int, TaskCheckpointStatisticsWithSubtaskDetails.Summary, List<SubtaskCheckpointStatistics>) - Constructor for class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails
-
- TaskCheckpointStatisticsWithSubtaskDetails.CheckpointAlignment - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
Alignment information for a specific checkpoint at a given task.
- TaskCheckpointStatisticsWithSubtaskDetails.CheckpointDuration - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
Duration of a checkpoint split up into its synchronous and asynchronous part.
- TaskCheckpointStatisticsWithSubtaskDetails.Summary - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
Summary of the checkpoint statistics for a given task.
- TaskConfig - Class in org.apache.flink.runtime.operators.util
-
Configuration class which stores all relevant parameters required to set up the Pact tasks.
- TaskConfig(Configuration) - Constructor for class org.apache.flink.runtime.operators.util.TaskConfig
-
Creates a new Task Config that wraps the given configuration.
- taskContext - Variable in class org.apache.flink.runtime.operators.AbstractOuterJoinDriver
-
- taskContext - Variable in class org.apache.flink.runtime.operators.JoinDriver
-
- TaskContext<S,OT> - Interface in org.apache.flink.runtime.operators
-
The task context gives a driver (e.g.,
MapDriver
, or
JoinDriver
) access to
the runtime components and configuration that they can use to fulfil their task.
- TaskDeploymentDescriptor - Class in org.apache.flink.runtime.deployment
-
A task deployment descriptor contains all the information necessary to deploy a task on a task manager.
- TaskDeploymentDescriptor(JobID, TaskDeploymentDescriptor.MaybeOffloaded<JobInformation>, TaskDeploymentDescriptor.MaybeOffloaded<TaskInformation>, ExecutionAttemptID, AllocationID, int, int, int, JobManagerTaskRestore, Collection<ResultPartitionDeploymentDescriptor>, Collection<InputGateDeploymentDescriptor>) - Constructor for class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
-
- TaskDeploymentDescriptor.MaybeOffloaded<T> - Class in org.apache.flink.runtime.deployment
-
Wrapper class for serialized values which may be offloaded to the
BlobServer
or not.
- TaskDeploymentDescriptor.NonOffloaded<T> - Class in org.apache.flink.runtime.deployment
-
A serialized value that is not offloaded to the
BlobServer
.
- TaskDeploymentDescriptor.Offloaded<T> - Class in org.apache.flink.runtime.deployment
-
Reference to a serialized value that was offloaded to the
BlobServer
.
- TaskEvent - Class in org.apache.flink.runtime.event
-
Subclasses of this event are recognized as custom events that are not part of the core
flink runtime.
- TaskEvent() - Constructor for class org.apache.flink.runtime.event.TaskEvent
-
- TaskEventDispatcher - Class in org.apache.flink.runtime.io.network
-
The task event dispatcher dispatches events flowing backwards from a consuming task to the task
producing the consumed result.
- TaskEventDispatcher() - Constructor for class org.apache.flink.runtime.io.network.TaskEventDispatcher
-
- TaskEventHandler - Class in org.apache.flink.runtime.io.network.api
-
The event handler manages
EventListener
instances and allows to
to publish events to them.
- TaskEventHandler() - Constructor for class org.apache.flink.runtime.io.network.api.TaskEventHandler
-
- TaskException - Exception in org.apache.flink.runtime.taskexecutor.exceptions
-
Exception indicating a task related problem on the
TaskExecutor
.
- TaskException(String) - Constructor for exception org.apache.flink.runtime.taskexecutor.exceptions.TaskException
-
- TaskException(String, Throwable) - Constructor for exception org.apache.flink.runtime.taskexecutor.exceptions.TaskException
-
- TaskException(Throwable) - Constructor for exception org.apache.flink.runtime.taskexecutor.exceptions.TaskException
-
- TaskExecutionState - Class in org.apache.flink.runtime.taskmanager
-
This class represents an update about a task's execution state.
- TaskExecutionState(JobID, ExecutionAttemptID, ExecutionState) - Constructor for class org.apache.flink.runtime.taskmanager.TaskExecutionState
-
Creates a new task execution state update, with no attached exception and no accumulators.
- TaskExecutionState(JobID, ExecutionAttemptID, ExecutionState, Throwable) - Constructor for class org.apache.flink.runtime.taskmanager.TaskExecutionState
-
Creates a new task execution state update, with an attached exception but no accumulators.
- TaskExecutionState(JobID, ExecutionAttemptID, ExecutionState, Throwable, AccumulatorSnapshot, IOMetrics) - Constructor for class org.apache.flink.runtime.taskmanager.TaskExecutionState
-
Creates a new task execution state update, with an attached exception.
- TaskExecutionStateListener - Interface in org.apache.flink.runtime.taskmanager
-
- TaskExecutor - Class in org.apache.flink.runtime.taskexecutor
-
TaskExecutor implementation.
- TaskExecutor(RpcService, TaskManagerConfiguration, HighAvailabilityServices, TaskManagerServices, HeartbeatServices, TaskManagerMetricGroup, BlobCacheService, FatalErrorHandler) - Constructor for class org.apache.flink.runtime.taskexecutor.TaskExecutor
-
- TaskExecutorConnection - Class in org.apache.flink.runtime.resourcemanager.registration
-
This class is responsible for grouping the TaskExecutorGateway and the InstanceID
of a registered task executor.
- TaskExecutorConnection(ResourceID, TaskExecutorGateway) - Constructor for class org.apache.flink.runtime.resourcemanager.registration.TaskExecutorConnection
-
- TaskExecutorGateway - Interface in org.apache.flink.runtime.taskexecutor
-
- TaskExecutorLocalStateStoresManager - Class in org.apache.flink.runtime.state
-
- TaskExecutorLocalStateStoresManager(boolean, File[], Executor) - Constructor for class org.apache.flink.runtime.state.TaskExecutorLocalStateStoresManager
-
- TaskExecutorRegistrationSuccess - Class in org.apache.flink.runtime.taskexecutor
-
Base class for responses from the ResourceManager to a registration attempt by a
TaskExecutor.
- TaskExecutorRegistrationSuccess(InstanceID, ResourceID, long, ClusterInformation) - Constructor for class org.apache.flink.runtime.taskexecutor.TaskExecutorRegistrationSuccess
-
Create a new TaskExecutorRegistrationSuccess
message.
- TaskExecutorToResourceManagerConnection - Class in org.apache.flink.runtime.taskexecutor
-
The connection between a TaskExecutor and the ResourceManager.
- TaskExecutorToResourceManagerConnection(Logger, RpcService, String, ResourceID, int, HardwareDescription, String, ResourceManagerId, Executor, RegistrationConnectionListener<TaskExecutorToResourceManagerConnection, TaskExecutorRegistrationSuccess>) - Constructor for class org.apache.flink.runtime.taskexecutor.TaskExecutorToResourceManagerConnection
-
- taskID() - Method in class org.apache.flink.mesos.runtime.clusterframework.LaunchableMesosWorker
-
- taskID() - Method in class org.apache.flink.mesos.runtime.clusterframework.store.MesosWorkerStore.Worker
-
Get the worker's task ID.
- taskID - Variable in class org.apache.flink.runtime.accumulators.AccumulatorRegistry
-
- TASKID_FORMAT - Static variable in interface org.apache.flink.mesos.runtime.clusterframework.store.MesosWorkerStore
-
The template for naming the worker.
- TaskInfo - Class in org.apache.flink.api.common
-
Encapsulates task-specific information: name, index of subtask, parallelism and attempt number.
- TaskInfo(String, int, int, int, int) - Constructor for class org.apache.flink.api.common.TaskInfo
-
- TaskInfo(String, int, int, int, int, String) - Constructor for class org.apache.flink.api.common.TaskInfo
-
- TaskInformation - Class in org.apache.flink.runtime.executiongraph
-
Container class for operator/task specific information which are stored at the
ExecutionJobVertex
.
- TaskInformation(JobVertexID, String, int, int, String, Configuration) - Constructor for class org.apache.flink.runtime.executiongraph.TaskInformation
-
- TaskInputSplitProvider - Class in org.apache.flink.runtime.taskmanager
-
- TaskInputSplitProvider(ActorGateway, JobID, JobVertexID, ExecutionAttemptID, FiniteDuration) - Constructor for class org.apache.flink.runtime.taskmanager.TaskInputSplitProvider
-
- TaskIOMetricGroup - Class in org.apache.flink.runtime.metrics.groups
-
Metric group that contains shareable pre-defined IO-related metrics.
- TaskIOMetricGroup(TaskMetricGroup) - Constructor for class org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
-
- TaskKvStateRegistry - Class in org.apache.flink.runtime.query
-
A helper for KvState registrations of a single task.
- TaskLocalStateStore - Interface in org.apache.flink.runtime.state
-
Classes that implement this interface serve as a task-manager-level local storage for local checkpointed state.
- TaskLocalStateStoreImpl - Class in org.apache.flink.runtime.state
-
- TaskLocalStateStoreImpl(JobID, AllocationID, JobVertexID, int, LocalRecoveryConfig, Executor) - Constructor for class org.apache.flink.runtime.state.TaskLocalStateStoreImpl
-
- TaskManager - Class in org.apache.flink.runtime.taskmanager
-
A
Taskmanager
in the same package as the proper Flink
TaskManager
.
- TaskManager() - Constructor for class org.apache.flink.runtime.taskmanager.TaskManager
-
- TaskManagerActions - Interface in org.apache.flink.runtime.taskmanager
-
- TaskManagerCliOptions - Class in org.apache.flink.runtime.taskmanager
-
The command line parameters passed to the TaskManager.
- TaskManagerCliOptions() - Constructor for class org.apache.flink.runtime.taskmanager.TaskManagerCliOptions
-
- TaskManagerConfiguration - Class in org.apache.flink.runtime.taskexecutor
-
- TaskManagerConfiguration(int, String[], Time, Time, Time, Time, Time, Configuration, boolean, FlinkUserCodeClassLoaders.ResolveOrder, String[], String, String) - Constructor for class org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
-
- TaskManagerDetailsHandler - Class in org.apache.flink.runtime.rest.handler.taskmanager
-
Handler which serves detailed TaskManager information.
- TaskManagerDetailsHandler(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MessageHeaders<EmptyRequestBody, TaskManagerDetailsInfo, TaskManagerMessageParameters>, GatewayRetriever<ResourceManagerGateway>, MetricFetcher) - Constructor for class org.apache.flink.runtime.rest.handler.taskmanager.TaskManagerDetailsHandler
-
- TaskManagerDetailsHeaders - Class in org.apache.flink.runtime.rest.messages.taskmanager
-
- TaskManagerDetailsInfo - Class in org.apache.flink.runtime.rest.messages.taskmanager
-
Message containing base information about a
TaskExecutor
and more
detailed metrics.
- TaskManagerDetailsInfo(ResourceID, String, int, long, int, int, HardwareDescription, TaskManagerMetricsInfo) - Constructor for class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerDetailsInfo
-
- TaskManagerDetailsInfo(TaskManagerInfo, TaskManagerMetricsInfo) - Constructor for class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerDetailsInfo
-
- taskManagerDirectMemoryLimitMB() - Method in class org.apache.flink.runtime.clusterframework.ContaineredTaskManagerParameters
-
- taskManagerEnv() - Method in class org.apache.flink.runtime.clusterframework.ContaineredTaskManagerParameters
-
- TaskManagerException - Exception in org.apache.flink.runtime.taskexecutor.exceptions
-
- TaskManagerException(String) - Constructor for exception org.apache.flink.runtime.taskexecutor.exceptions.TaskManagerException
-
- TaskManagerException(String, Throwable) - Constructor for exception org.apache.flink.runtime.taskexecutor.exceptions.TaskManagerException
-
- TaskManagerException(Throwable) - Constructor for exception org.apache.flink.runtime.taskexecutor.exceptions.TaskManagerException
-
- TaskManagerGateway - Interface in org.apache.flink.runtime.jobmanager.slots
-
Task manager gateway interface to communicate with the task manager.
- taskManagerHeapSizeMB() - Method in class org.apache.flink.runtime.clusterframework.ContaineredTaskManagerParameters
-
- taskManagerID - Variable in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.TaskManagerQueryScopeInfo
-
- taskManagerId() - Method in class org.apache.flink.runtime.metrics.groups.TaskManagerMetricGroup
-
- TaskManagerIdPathParameter - Class in org.apache.flink.runtime.rest.messages.taskmanager
-
TaskManager id path parameter used by TaskManager related handlers.
- TaskManagerIdPathParameter() - Constructor for class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerIdPathParameter
-
- TaskManagerInfo - Class in org.apache.flink.runtime.rest.messages.taskmanager
-
- TaskManagerInfo(ResourceID, String, int, long, int, int, HardwareDescription) - Constructor for class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerInfo
-
- TaskManagerJobMetricGroup - Class in org.apache.flink.runtime.metrics.groups
-
Special
MetricGroup
representing everything belonging to
a specific job, running on the TaskManager.
- TaskManagerJobMetricGroup(MetricRegistry, TaskManagerMetricGroup, JobID, String) - Constructor for class org.apache.flink.runtime.metrics.groups.TaskManagerJobMetricGroup
-
- TaskManagerJobScopeFormat - Class in org.apache.flink.runtime.metrics.scope
-
- TaskManagerJobScopeFormat(String, TaskManagerScopeFormat) - Constructor for class org.apache.flink.runtime.metrics.scope.TaskManagerJobScopeFormat
-
- TaskManagerLocation - Class in org.apache.flink.runtime.taskmanager
-
This class encapsulates the connection information of a TaskManager.
- TaskManagerLocation(ResourceID, InetAddress, int) - Constructor for class org.apache.flink.runtime.taskmanager.TaskManagerLocation
-
Constructs a new instance connection info object.
- TaskManagerLogFileHandler - Class in org.apache.flink.runtime.rest.handler.taskmanager
-
- TaskManagerLogFileHandler(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, UntypedResponseMessageHeaders<EmptyRequestBody, TaskManagerMessageParameters>, GatewayRetriever<ResourceManagerGateway>, TransientBlobService, Time) - Constructor for class org.apache.flink.runtime.rest.handler.taskmanager.TaskManagerLogFileHandler
-
- TaskManagerLogFileHeaders - Class in org.apache.flink.runtime.rest.messages.taskmanager
-
- TaskManagerLogHandler - Class in org.apache.flink.runtime.rest.handler.legacy
-
Request handler that returns the TaskManager log/out files.
- TaskManagerLogHandler(GatewayRetriever<JobManagerGateway>, Executor, CompletableFuture<String>, Time, TaskManagerLogHandler.FileMode, Configuration) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.TaskManagerLogHandler
-
- TaskManagerLogHandler.FileMode - Enum in org.apache.flink.runtime.rest.handler.legacy
-
Used to control whether this handler serves the .log or .out file.
- TaskManagerMessageParameters - Class in org.apache.flink.runtime.rest.messages.taskmanager
-
Message parameter for a TaskManager specific handler.
- TaskManagerMessageParameters() - Constructor for class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMessageParameters
-
- TaskManagerMetricGroup - Class in org.apache.flink.runtime.metrics.groups
-
- TaskManagerMetricGroup(MetricRegistry, String, String) - Constructor for class org.apache.flink.runtime.metrics.groups.TaskManagerMetricGroup
-
- TaskManagerMetricsHandler - Class in org.apache.flink.runtime.rest.handler.job.metrics
-
Handler that returns TaskManager metrics.
- TaskManagerMetricsHandler(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MetricFetcher) - Constructor for class org.apache.flink.runtime.rest.handler.job.metrics.TaskManagerMetricsHandler
-
- TaskManagerMetricsHandler - Class in org.apache.flink.runtime.rest.handler.legacy.metrics
-
Request handler that returns for a given task manager a list of all available metrics or the values for a set of metrics.
- TaskManagerMetricsHandler(Executor, MetricFetcher) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.metrics.TaskManagerMetricsHandler
-
- TaskManagerMetricsHeaders - Class in org.apache.flink.runtime.rest.messages.job.metrics
-
- TaskManagerMetricsInfo - Class in org.apache.flink.runtime.rest.messages.taskmanager
-
Contains information about the TaskManager metrics.
- TaskManagerMetricsInfo(long, long, long, long, long, long, long, long, long, long, long, long, long, long, List<TaskManagerMetricsInfo.GarbageCollectorInfo>) - Constructor for class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMetricsInfo
-
- TaskManagerMetricsInfo.GarbageCollectorInfo - Class in org.apache.flink.runtime.rest.messages.taskmanager
-
Information about the garbage collector metrics.
- TaskManagerMetricsMessageParameters - Class in org.apache.flink.runtime.rest.messages.job.metrics
-
- TaskManagerMetricsMessageParameters() - Constructor for class org.apache.flink.runtime.rest.messages.job.metrics.TaskManagerMetricsMessageParameters
-
- TaskManagerOptions - Class in org.apache.flink.configuration
-
The set of configuration options relating to TaskManager and Task settings.
- TaskManagerQueryScopeInfo(String) - Constructor for class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.TaskManagerQueryScopeInfo
-
- TaskManagerQueryScopeInfo(String, String) - Constructor for class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.TaskManagerQueryScopeInfo
-
- TaskManagerRegistration - Class in org.apache.flink.runtime.resourcemanager.slotmanager
-
- TaskManagerRegistration(TaskExecutorConnection, Collection<SlotID>) - Constructor for class org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerRegistration
-
- TaskManagerRunner - Class in org.apache.flink.runtime.taskexecutor
-
This class is the executable entry point for the task manager in yarn or standalone mode.
- TaskManagerRunner(Configuration, ResourceID) - Constructor for class org.apache.flink.runtime.taskexecutor.TaskManagerRunner
-
- TaskManagerRuntimeInfo - Interface in org.apache.flink.runtime.taskmanager
-
- TaskManagerScopeFormat - Class in org.apache.flink.runtime.metrics.scope
-
- TaskManagerScopeFormat(String) - Constructor for class org.apache.flink.runtime.metrics.scope.TaskManagerScopeFormat
-
- TaskManagerServices - Class in org.apache.flink.runtime.taskexecutor
-
- TaskManagerServicesConfiguration - Class in org.apache.flink.runtime.taskexecutor
-
Configuration for the task manager services such as the network environment, the memory manager,
the io manager and the metric registry.
- TaskManagerServicesConfiguration(InetAddress, String[], String[], boolean, NetworkEnvironmentConfiguration, QueryableStateConfiguration, int, long, MemoryType, boolean, float, long) - Constructor for class org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
-
- TaskManagersFilterQueryParameter - Class in org.apache.flink.runtime.rest.messages.job.metrics
-
- TaskManagersHandler - Class in org.apache.flink.runtime.rest.handler.legacy
-
A request handler that provides an overview over all taskmanagers or details for a single one.
- TaskManagersHandler(Executor, Time, MetricFetcher) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.TaskManagersHandler
-
- TaskManagersHandler - Class in org.apache.flink.runtime.rest.handler.taskmanager
-
Returns an overview over all registered TaskManagers of the cluster.
- TaskManagersHandler(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MessageHeaders<EmptyRequestBody, TaskManagersInfo, EmptyMessageParameters>, GatewayRetriever<ResourceManagerGateway>) - Constructor for class org.apache.flink.runtime.rest.handler.taskmanager.TaskManagersHandler
-
- TaskManagersHeaders - Class in org.apache.flink.runtime.rest.messages.taskmanager
-
- TaskManagersInfo(String, ExecutionState, long, long, long, IOMetricsInfo, Map<ExecutionState, Integer>) - Constructor for class org.apache.flink.runtime.rest.messages.JobVertexTaskManagersInfo.TaskManagersInfo
-
- TaskManagersInfo - Class in org.apache.flink.runtime.rest.messages.taskmanager
-
- TaskManagersInfo(Collection<TaskManagerInfo>) - Constructor for class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagersInfo
-
- TaskManagerSlot - Class in org.apache.flink.runtime.clusterframework.types
-
A TaskManagerSlot represents a slot located in a TaskManager.
- TaskManagerSlot(SlotID, ResourceProfile, TaskExecutorConnection) - Constructor for class org.apache.flink.runtime.clusterframework.types.TaskManagerSlot
-
- TaskManagerSlot.State - Enum in org.apache.flink.runtime.clusterframework.types
-
- TaskManagerStdoutFileHandler - Class in org.apache.flink.runtime.rest.handler.taskmanager
-
Rest handler which serves the stdout file of the
TaskExecutor
.
- TaskManagerStdoutFileHandler(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, UntypedResponseMessageHeaders<EmptyRequestBody, TaskManagerMessageParameters>, GatewayRetriever<ResourceManagerGateway>, TransientBlobService, Time) - Constructor for class org.apache.flink.runtime.rest.handler.taskmanager.TaskManagerStdoutFileHandler
-
- TaskManagerStdoutFileHeaders - Class in org.apache.flink.runtime.rest.messages.taskmanager
-
- taskManagerTotalMemoryMB() - Method in class org.apache.flink.runtime.clusterframework.ContaineredTaskManagerParameters
-
- TaskMetricGroup - Class in org.apache.flink.runtime.metrics.groups
-
- TaskMetricGroup(MetricRegistry, TaskManagerJobMetricGroup, JobVertexID, AbstractID, String, int, int) - Constructor for class org.apache.flink.runtime.metrics.groups.TaskMetricGroup
-
- taskName() - Method in class org.apache.flink.runtime.metrics.groups.TaskMetricGroup
-
- taskName - Variable in class org.apache.flink.runtime.operators.chaining.ChainedDriver
-
- taskNumber - Variable in class org.apache.flink.api.java.hadoop.mapreduce.HadoopOutputFormatBase
-
- TaskQueryScopeInfo(String, String, int) - Constructor for class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.TaskQueryScopeInfo
-
- TaskQueryScopeInfo(String, String, int, String) - Constructor for class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.TaskQueryScopeInfo
-
- taskRequest() - Method in class org.apache.flink.mesos.runtime.clusterframework.LaunchableMesosWorker
-
- taskRequest() - Method in interface org.apache.flink.mesos.scheduler.LaunchableTask
-
Get a representation of the task requirements as understood by Fenzo.
- TaskSchedulerBuilder - Interface in org.apache.flink.mesos.scheduler
-
A builder for the Fenzo task scheduler.
- TaskScopeFormat - Class in org.apache.flink.runtime.metrics.scope
-
- TaskScopeFormat(String, TaskManagerJobScopeFormat) - Constructor for class org.apache.flink.runtime.metrics.scope.TaskScopeFormat
-
- TaskSlot - Class in org.apache.flink.runtime.taskexecutor.slot
-
Container for multiple
Task
belonging to the same slot.
- TaskSlotTable - Class in org.apache.flink.runtime.taskexecutor.slot
-
Container for multiple
TaskSlot
instances.
- TaskSlotTable(Collection<ResourceProfile>, TimerService<AllocationID>) - Constructor for class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
-
- TaskState - Class in org.apache.flink.runtime.checkpoint
-
- TaskState(JobVertexID, int, int, int) - Constructor for class org.apache.flink.runtime.checkpoint.TaskState
-
Deprecated.
- TaskStateManager - Interface in org.apache.flink.runtime.state
-
This interface provides methods to report and retrieve state for a task.
- TaskStateManagerImpl - Class in org.apache.flink.runtime.state
-
- TaskStateManagerImpl(JobID, ExecutionAttemptID, TaskLocalStateStore, JobManagerTaskRestore, CheckpointResponder) - Constructor for class org.apache.flink.runtime.state.TaskStateManagerImpl
-
- TaskStateSnapshot - Class in org.apache.flink.runtime.checkpoint
-
This class encapsulates state handles to the snapshots of all operator instances executed within one task.
- TaskStateSnapshot() - Constructor for class org.apache.flink.runtime.checkpoint.TaskStateSnapshot
-
- TaskStateSnapshot(int) - Constructor for class org.apache.flink.runtime.checkpoint.TaskStateSnapshot
-
- TaskStateSnapshot(Map<OperatorID, OperatorSubtaskState>) - Constructor for class org.apache.flink.runtime.checkpoint.TaskStateSnapshot
-
- TaskStateStats - Class in org.apache.flink.runtime.checkpoint
-
Statistics for a single task/operator that gathers all statistics of its
subtasks and provides summary statistics about all subtasks.
- TaskStateStats.TaskStateStatsSummary - Class in org.apache.flink.runtime.checkpoint
-
Summary of the subtask stats of a single task/operator.
- TaskStateStatsSummary() - Constructor for class org.apache.flink.runtime.checkpoint.TaskStateStats.TaskStateStatsSummary
-
- TaskSubmissionException - Exception in org.apache.flink.runtime.taskexecutor.exceptions
-
- TaskSubmissionException(String) - Constructor for exception org.apache.flink.runtime.taskexecutor.exceptions.TaskSubmissionException
-
- TaskSubmissionException(String, Throwable) - Constructor for exception org.apache.flink.runtime.taskexecutor.exceptions.TaskSubmissionException
-
- TaskSubmissionException(Throwable) - Constructor for exception org.apache.flink.runtime.taskexecutor.exceptions.TaskSubmissionException
-
- taskTerminated(TaskMonitor.TaskTerminated) - Method in class org.apache.flink.mesos.runtime.clusterframework.MesosResourceManager
-
Handles a termination notification from a task monitor.
- taskTerminated(TaskMonitor.TaskTerminated) - Method in interface org.apache.flink.mesos.runtime.clusterframework.MesosResourceManagerActions
-
Notify that the given Mesos task has been terminated.
- TCP_TIMEOUT - Static variable in class org.apache.flink.configuration.AkkaOptions
-
The Akka tcp connection timeout.
- teardown() - Method in class org.apache.flink.runtime.operators.AbstractCachedBuildSideJoinDriver
-
- teardown() - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetFirstDriver
-
- teardown() - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetSecondDriver
-
- teardown() - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetFirstDriver
-
- teardown() - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetSecondDriver
-
- teardown() - Method in interface org.apache.flink.runtime.operators.ResettableDriver
-
- teardownEnvironment() - Method in class org.apache.flink.test.util.MultipleProgramsTestBase
-
- tell() - Method in class org.apache.flink.formats.avro.utils.FSDataInputStreamWrapper
-
- tell(Object) - Method in interface org.apache.flink.runtime.instance.ActorGateway
-
Sends a message asynchronously without a result.
- tell(Object, ActorGateway) - Method in interface org.apache.flink.runtime.instance.ActorGateway
-
Sends a message asynchronously without a result with sender being the sender.
- tell(Object) - Method in class org.apache.flink.runtime.instance.AkkaActorGateway
-
Sends a message asynchronously without a result.
- tell(Object, ActorGateway) - Method in class org.apache.flink.runtime.instance.AkkaActorGateway
-
Sends a message asynchronously without a result with sender being the sender.
- tell(Object) - Method in class org.apache.flink.runtime.rpc.akka.FencedAkkaInvocationHandler
-
- TempBarrier<T> - Class in org.apache.flink.runtime.operators
-
- TempBarrier(AbstractInvokable, MutableObjectIterator<T>, TypeSerializerFactory<T>, MemoryManager, IOManager, int) - Constructor for class org.apache.flink.runtime.operators.TempBarrier
-
- tempBarriers - Variable in class org.apache.flink.runtime.operators.BatchTask
-
The optional temp barriers on the inputs for dead-lock breaking.
- tempFileCounter - Variable in class org.apache.flink.runtime.blob.AbstractBlobCache
-
Counter to generate unique names for temporary files.
- template - Variable in class org.apache.flink.optimizer.plan.PlanNode
-
- TempMode - Enum in org.apache.flink.optimizer.dag
-
Enumeration to indicate the mode of temporarily materializing the data that flows across a connection.
- temporary(Path) - Static method in class org.apache.flink.runtime.state.SnapshotDirectory
-
Creates a temporary snapshot directory for the given path.
- TEMPORARY_FOLDER - Static variable in class org.apache.flink.test.util.AbstractTestBase
-
- Terminable - Interface in org.apache.flink.runtime.iterative.task
-
Models the functionality that the termination of an iterative task can be requested from outside.
- terminate() - Method in class org.apache.flink.runtime.client.JobClientActor
-
- TERMINATED_PAYLOAD - Static variable in interface org.apache.flink.runtime.jobmaster.LogicalSlot
-
- terminateJVM() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerRunner
-
- terminateRpcEndpoint(RpcEndpoint, Time) - Static method in class org.apache.flink.runtime.rpc.RpcUtils
-
Shuts the given
RpcEndpoint
down and awaits its termination.
- terminateRpcService(RpcService, Time) - Static method in class org.apache.flink.runtime.rpc.RpcUtils
-
Shuts the given rpc service down and waits for its termination.
- terminateRpcServices(Time, RpcService...) - Static method in class org.apache.flink.runtime.rpc.RpcUtils
-
Shuts the given rpc services down and waits for their termination.
- TERMINATION_CRITERION_AGGREGATOR_NAME - Static variable in class org.apache.flink.api.common.operators.base.BulkIterationBase
-
- terminationCriterion - Variable in class org.apache.flink.api.common.operators.base.BulkIterationBase
-
- TerminationCriterionAggregationConvergence() - Constructor for class org.apache.flink.api.common.operators.base.BulkIterationBase.TerminationCriterionAggregationConvergence
-
- TerminationCriterionAggregator() - Constructor for class org.apache.flink.api.common.operators.base.BulkIterationBase.TerminationCriterionAggregator
-
- TerminationCriterionMapper() - Constructor for class org.apache.flink.api.common.operators.base.BulkIterationBase.TerminationCriterionMapper
-
- TerminationEvent - Class in org.apache.flink.runtime.iterative.event
-
Signals that the iteration is completely executed, participating tasks must terminate now.
- TerminationEvent() - Constructor for class org.apache.flink.runtime.iterative.event.TerminationEvent
-
- terminationModeQueryParameter - Variable in class org.apache.flink.runtime.rest.messages.JobTerminationMessageParameters
-
- TerminationModeQueryParameter - Class in org.apache.flink.runtime.rest.messages
-
- TerminationModeQueryParameter() - Constructor for class org.apache.flink.runtime.rest.messages.TerminationModeQueryParameter
-
- TerminationModeQueryParameter.TerminationMode - Enum in org.apache.flink.runtime.rest.messages
-
Supported termination modes.
- terminationRequested() - Method in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
-
- terminationRequested() - Method in class org.apache.flink.runtime.iterative.task.IterationSynchronizationSinkTask
-
- terminationRequested() - Method in interface org.apache.flink.runtime.iterative.task.Terminable
-
- terminationSignaled() - Method in class org.apache.flink.runtime.iterative.concurrent.SuperstepBarrier
-
- TernaryBoolean - Enum in org.apache.flink.util
-
A ternary boolean, which can have the values 'true', 'false', or 'undefined'.
- ternaryOperation(AbstractInsnNode, BasicValue, BasicValue, BasicValue) - Method in class org.apache.flink.api.java.sca.NestedMethodAnalyzer
-
- TertiaryResult<K> - Interface in org.apache.flink.graph.asm.result
-
- TertiaryResultBase<K> - Class in org.apache.flink.graph.asm.result
-
Base class for algorithm results for three vertices.
- TertiaryResultBase() - Constructor for class org.apache.flink.graph.asm.result.TertiaryResultBase
-
- TestBaseUtils - Class in org.apache.flink.test.util
-
Utility class containing various methods for testing purposes.
- TestBaseUtils() - Constructor for class org.apache.flink.test.util.TestBaseUtils
-
- TestBaseUtils.TupleComparator<T extends Tuple> - Class in org.apache.flink.test.util
-
Comparator for comparable Tuples.
- TestEnvironment - Class in org.apache.flink.test.util
-
- TestEnvironment(JobExecutor, int, boolean, Collection<Path>, Collection<URL>) - Constructor for class org.apache.flink.test.util.TestEnvironment
-
- TestEnvironment(JobExecutor, int, boolean) - Constructor for class org.apache.flink.test.util.TestEnvironment
-
- testForUnsplittable(FileStatus) - Method in class org.apache.flink.api.common.io.FileInputFormat
-
- testHash(int) - Method in class org.apache.flink.runtime.operators.util.BloomFilter
-
- TestingSecurityContext - Class in org.apache.flink.test.util
-
Test security context to support handling both client and server principals in MiniKDC.
- TestingSecurityContext() - Constructor for class org.apache.flink.test.util.TestingSecurityContext
-
- testJob() - Method in class org.apache.flink.streaming.util.StreamingProgramTestBase
-
- testJobCollectionExecution() - Method in class org.apache.flink.test.util.JavaProgramTestBase
-
- testJobWithObjectReuse() - Method in class org.apache.flink.test.util.JavaProgramTestBase
-
- testJobWithoutObjectReuse() - Method in class org.apache.flink.test.util.JavaProgramTestBase
-
- TestLogger - Class in org.apache.flink.util
-
Adds automatic test name logging.
- TestLogger() - Constructor for class org.apache.flink.util.TestLogger
-
- TestProcessingTimeService - Class in org.apache.flink.streaming.runtime.tasks
-
- TestProcessingTimeService() - Constructor for class org.apache.flink.streaming.runtime.tasks.TestProcessingTimeService
-
- testProgram() - Method in class org.apache.flink.streaming.util.StreamingProgramTestBase
-
- testProgram() - Method in class org.apache.flink.test.util.JavaProgramTestBase
-
- TestStreamEnvironment - Class in org.apache.flink.streaming.util
-
- TestStreamEnvironment(JobExecutor, int, Collection<Path>, Collection<URL>) - Constructor for class org.apache.flink.streaming.util.TestStreamEnvironment
-
- TestStreamEnvironment(JobExecutor, int) - Constructor for class org.apache.flink.streaming.util.TestStreamEnvironment
-
- TEXT - Static variable in class org.apache.flink.test.testdata.WordCountData
-
- TextInputFormat - Class in org.apache.flink.api.java.io
-
Input Format that reads text files.
- TextInputFormat(Path) - Constructor for class org.apache.flink.api.java.io.TextInputFormat
-
- TextOutputFormat<T> - Class in org.apache.flink.api.java.io
-
- TextOutputFormat(Path) - Constructor for class org.apache.flink.api.java.io.TextOutputFormat
-
- TextOutputFormat(Path, String) - Constructor for class org.apache.flink.api.java.io.TextOutputFormat
-
- TextOutputFormat.TextFormatter<IN> - Interface in org.apache.flink.api.java.io
-
Formatter that transforms values into their
String
representations.
- TEXTS - Static variable in class org.apache.flink.streaming.examples.twitter.util.TwitterExampleData
-
- TextValueInputFormat - Class in org.apache.flink.api.java.io
-
Input format that reads text files.
- TextValueInputFormat(Path) - Constructor for class org.apache.flink.api.java.io.TextValueInputFormat
-
- ThreadBase(ExceptionHandler<IOException>, String, UnilateralSortMerger.CircularQueues<E>, AbstractInvokable) - Constructor for class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.ThreadBase
-
Creates a new thread.
- ThrottledIterator<T> - Class in org.apache.flink.streaming.examples.utils
-
A variant of the collection source (emits a sequence of elements as a stream)
that supports throttling the emission rate.
- ThrottledIterator(Iterator<T>, long) - Constructor for class org.apache.flink.streaming.examples.utils.ThrottledIterator
-
- ThrowingConsumer<T,E extends Throwable> - Interface in 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> - Interface in org.apache.flink.util.function
-
Similar to a
Runnable
, this interface is used to capture a block of code
to be executed.
- ticketCacheEntry() - Static method in class org.apache.flink.runtime.security.KerberosUtils
-
- Time - Class in org.apache.flink.api.common.time
-
The definition of a time interval.
- TIME - Static variable in class org.apache.flink.api.common.typeinfo.SqlTimeTypeInfo
-
- Time - Class in org.apache.flink.streaming.api.windowing.time
-
The definition of a time interval for windowing.
- TIME_FORMAT_STRING - Static variable in class org.apache.calcite.avatica.util.DateTimeUtils
-
The SimpleDateFormat string for ISO times, "HH:mm:ss".
- TIME_FORMATTER - Static variable in class org.apache.flink.table.client.cli.CliUtils
-
- time_window(Time) - Method in class org.apache.flink.streaming.python.api.datastream.PythonKeyedStream
-
- time_window(Time, Time) - Method in class org.apache.flink.streaming.python.api.datastream.PythonKeyedStream
-
- TimeCharacteristic - Enum in org.apache.flink.streaming.api
-
The time characteristic defines how the system determines time for time-dependent
order and operations that depend on time (such as time windows).
- timeDomain() - Method in class org.apache.flink.streaming.api.functions.co.CoProcessFunction.OnTimerContext
-
- timeDomain() - Method in class org.apache.flink.streaming.api.functions.co.KeyedBroadcastProcessFunction.OnTimerContext
-
- timeDomain() - Method in class org.apache.flink.streaming.api.functions.KeyedProcessFunction.OnTimerContext
-
- timeDomain() - Method in class org.apache.flink.streaming.api.functions.ProcessFunction.OnTimerContext
-
- TimeDomain - Enum in org.apache.flink.streaming.api
-
TimeDomain
specifies whether a firing timer is based on event time or processing time.
- TimeEvictor<W extends Window> - Class in org.apache.flink.streaming.api.windowing.evictors
-
An
Evictor
that keeps elements for a certain amount of time.
- TimeEvictor(long) - Constructor for class org.apache.flink.streaming.api.windowing.evictors.TimeEvictor
-
- TimeEvictor(long, boolean) - Constructor for class org.apache.flink.streaming.api.windowing.evictors.TimeEvictor
-
- timeLeft() - Method in class org.apache.flink.api.common.time.Deadline
-
Returns the time left between the deadline and now.
- timeout(Map<String, List<IN>>, long, Collector<OUT>) - Method in interface org.apache.flink.cep.PatternFlatTimeoutFunction
-
Generates zero or more resulting timeout elements given a map of partial pattern events and
the timestamp of the timeout.
- timeout(Map<String, List<IN>>, long) - Method in interface org.apache.flink.cep.PatternTimeoutFunction
-
Generates a timeout result from the given map of events and timeout timestamp.
- timeout - Variable in class org.apache.flink.client.program.ClusterClient
-
Timeout for futures.
- TIMEOUT - Static variable in class org.apache.flink.configuration.WebOptions
-
Timeout for asynchronous operations by the WebRuntimeMonitor in milliseconds.
- timeout - Variable in class org.apache.flink.runtime.client.JobClientActor
-
timeout for futures
- timeout - Variable in class org.apache.flink.runtime.rest.handler.RedirectHandler
-
- timeout(IN, ResultFuture<OUT>) - Method in interface org.apache.flink.streaming.api.functions.async.AsyncFunction
-
- TimeoutListener<K> - Interface in org.apache.flink.runtime.taskexecutor.slot
-
- timeoutPendingSlotRequest(SlotRequestId) - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotPool
-
- timeoutSlot(AllocationID, UUID) - Method in interface org.apache.flink.runtime.taskexecutor.slot.SlotActions
-
Timeout the task slot for the given allocation id.
- Timer(long, K, W) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Timer
-
- TimerException - Exception in org.apache.flink.streaming.runtime.tasks
-
RuntimeException
for wrapping exceptions that are thrown in the timer callback of
the timer service in
StreamTask
.
- TimerException(Throwable) - Constructor for exception org.apache.flink.streaming.runtime.tasks.TimerException
-
- TimerService<K> - Class in org.apache.flink.runtime.taskexecutor.slot
-
Service to register timeouts for a given key.
- TimerService(ScheduledExecutorService, long) - Constructor for class org.apache.flink.runtime.taskexecutor.slot.TimerService
-
- timerService() - Method in class org.apache.flink.streaming.api.functions.co.CoProcessFunction.Context
-
- timerService() - Method in class org.apache.flink.streaming.api.functions.co.KeyedBroadcastProcessFunction.ReadOnlyContext
-
- timerService() - Method in class org.apache.flink.streaming.api.functions.KeyedProcessFunction.Context
-
- timerService() - Method in class org.apache.flink.streaming.api.functions.ProcessFunction.Context
-
- TimerService - Interface in org.apache.flink.streaming.api
-
Interface for working with time and timers.
- timerService - Variable in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
The internal
ProcessingTimeService
used to define the current
processing time (default =
System.currentTimeMillis()
) and
register timers for tasks to be executed in the future.
- times(int) - Method in class org.apache.flink.cep.pattern.Pattern
-
Specifies exact number of times that this pattern should be matched.
- times(int, int) - Method in class org.apache.flink.cep.pattern.Pattern
-
Specifies that the pattern can occur between from and to times.
- times(Quantifier.ConsumingStrategy) - Static method in class org.apache.flink.cep.pattern.Quantifier
-
- timeServiceManager - Variable in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
- timesOrMore(int) - Method in class org.apache.flink.cep.pattern.Pattern
-
Specifies that this pattern can occur the specified times at least.
- TIMESTAMP - Static variable in class org.apache.flink.api.common.typeinfo.SqlTimeTypeInfo
-
- timestamp() - Method in class org.apache.flink.streaming.api.functions.co.CoProcessFunction.Context
-
Timestamp of the element currently being processed or timestamp of a firing timer.
- timestamp() - Method in class org.apache.flink.streaming.api.functions.KeyedProcessFunction.Context
-
Timestamp of the element currently being processed or timestamp of a firing timer.
- timestamp() - Method in class org.apache.flink.streaming.api.functions.ProcessFunction.Context
-
Timestamp of the element currently being processed or timestamp of a firing timer.
- timestamp() - Method in interface org.apache.flink.streaming.api.functions.sink.SinkFunction.Context
-
Returns the timestamp of the current input record or null
if the element does not
have an assigned timestamp.
- timestamp - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Timer
-
- timestamp() - Method in class org.apache.flink.yarn.YarnContainerInLaunch
-
- TIMESTAMP_FORMAT_STRING - Static variable in class org.apache.calcite.avatica.util.DateTimeUtils
-
The SimpleDateFormat string for ISO timestamps, "yyyy-MM-dd HH:mm:ss".
- TimestampAssigner<T> - Interface in org.apache.flink.streaming.api.functions
-
A TimestampAssigner
assigns event time timestamps to elements.
- TimestampedCollector<T> - Class in org.apache.flink.streaming.api.operators
-
- TimestampedCollector(Output<StreamRecord<T>>) - Constructor for class org.apache.flink.streaming.api.operators.TimestampedCollector
-
- timestampedCollector - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
This is given to the InternalWindowFunction
for emitting elements with a given
timestamp.
- TimestampedFileInputSplit - Class in org.apache.flink.streaming.api.functions.source
-
- TimestampedFileInputSplit(long, int, Path, long, long, String[]) - Constructor for class org.apache.flink.streaming.api.functions.source.TimestampedFileInputSplit
-
- TimestampedSideOutputCollector<T> - Class in org.apache.flink.cep.operator
-
- TimestampedSideOutputCollector(OutputTag<T>, Output<?>) - Constructor for class org.apache.flink.cep.operator.TimestampedSideOutputCollector
-
- TimestampedValue<T> - Class in org.apache.flink.streaming.runtime.operators.windowing
-
Stores the value and the timestamp of the record.
- TimestampedValue(T) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.TimestampedValue
-
Creates a new TimestampedValue.
- TimestampedValue(T, long) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.TimestampedValue
-
Creates a new TimestampedValue wrapping the given value.
- TimestampExtractor<T> - Interface in org.apache.flink.streaming.api.functions
-
- TimestampsAndPeriodicWatermarksOperator<T> - Class in org.apache.flink.streaming.runtime.operators
-
A stream operator that extracts timestamps from stream elements and
generates periodic watermarks.
- TimestampsAndPeriodicWatermarksOperator(AssignerWithPeriodicWatermarks<T>) - Constructor for class org.apache.flink.streaming.runtime.operators.TimestampsAndPeriodicWatermarksOperator
-
- TimestampsAndPunctuatedWatermarksOperator<T> - Class in org.apache.flink.streaming.runtime.operators
-
A stream operator that extracts timestamps from stream elements and
generates watermarks based on punctuation elements.
- TimestampsAndPunctuatedWatermarksOperator(AssignerWithPunctuatedWatermarks<T>) - Constructor for class org.apache.flink.streaming.runtime.operators.TimestampsAndPunctuatedWatermarksOperator
-
- timestampStringToUnixDate(String) - Static method in class org.apache.calcite.avatica.util.DateTimeUtils
-
- timeStringToUnixDate(String) - Static method in class org.apache.calcite.avatica.util.DateTimeUtils
-
- timeStringToUnixDate(String, int) - Static method in class org.apache.calcite.avatica.util.DateTimeUtils
-
- timeWindow(Time) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Windows this KeyedStream
into tumbling time windows.
- timeWindow(Time, Time) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Windows this KeyedStream
into sliding time windows.
- TimeWindow - Class in org.apache.flink.streaming.api.windowing.windows
-
A
Window
that represents a time interval from
start
(inclusive) to
end
(exclusive).
- TimeWindow(long, long) - Constructor for class org.apache.flink.streaming.api.windowing.windows.TimeWindow
-
- TimeWindow.Serializer - Class in org.apache.flink.streaming.api.windowing.windows
-
The serializer used to write the TimeWindow type.
- timeWindowAll(Time) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Windows this DataStream
into tumbling time windows.
- timeWindowAll(Time, Time) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Windows this DataStream
into sliding time windows.
- TMP_DIR - Static variable in class org.apache.flink.configuration.WebOptions
-
The config parameter defining the flink web directory to be used by the webmonitor.
- TMP_DIRS - Static variable in class org.apache.flink.configuration.CoreOptions
-
The config parameter defining the directories for temporary files, separated by
",", "|", or the system's
File.pathSeparator
.
- to - Variable in class org.apache.flink.python.api.PythonOperationInfo
-
- toArray() - Method in class org.apache.flink.api.common.operators.util.FieldSet
-
Transforms the field set into an array of field IDs.
- toArray() - Method in class org.apache.flink.runtime.checkpoint.StateObjectCollection
-
- toArray(T1[]) - Method in class org.apache.flink.runtime.checkpoint.StateObjectCollection
-
- toArray() - Method in class org.apache.flink.runtime.util.IntArrayList
-
- toArray() - Method in class org.apache.flink.runtime.util.LongArrayList
-
- toArray() - Method in class org.apache.flink.types.ListValue
-
- toArray(T[]) - Method in class org.apache.flink.types.ListValue
-
- toBooleanMask(int[]) - Static method in class org.apache.flink.api.java.io.CsvInputFormat
-
- toBuffer(AbstractEvent) - Static method in class org.apache.flink.runtime.io.network.api.serialization.EventSerializer
-
- toBufferConsumer(AbstractEvent) - Static method in class org.apache.flink.runtime.io.network.api.serialization.EventSerializer
-
- toByteArray() - Method in class org.apache.flink.core.memory.ByteArrayOutputStreamWithPos
-
- toError - Variable in class org.apache.flink.python.api.PythonOperationInfo
-
- toFieldList() - Method in class org.apache.flink.api.common.operators.util.FieldList
-
- toFieldList() - Method in class org.apache.flink.api.common.operators.util.FieldSet
-
Turns the FieldSet into an ordered FieldList.
- toFiniteDuration(Time) - Static method in class org.apache.flink.runtime.concurrent.FutureUtils
-
Converts Flink time into a FiniteDuration
.
- toForwardedFieldsExpression(TaggedValue.Input) - Method in class org.apache.flink.api.java.sca.TaggedValue
-
- toggleStreamStatus(StreamStatus) - Method in interface org.apache.flink.streaming.runtime.streamstatus.StreamStatusMaintainer
-
Toggles the current stream status.
- toggleStreamStatus(StreamStatus) - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
-
- toJava(Future<U>) - Static method in class org.apache.flink.runtime.concurrent.FutureUtils
-
- toJava(Option<T>) - Static method in class org.apache.flink.runtime.util.ScalaUtils
-
- toJobExecutionResult(ClassLoader) - Method in class org.apache.flink.runtime.client.SerializedJobExecutionResult
-
- toJobExecutionResult(ClassLoader) - Method in class org.apache.flink.runtime.jobmaster.JobResult
-
- TOKEN - Static variable in class org.apache.flink.streaming.connectors.twitter.TwitterSource
-
- TOKEN_SECRET - Static variable in class org.apache.flink.streaming.connectors.twitter.TwitterSource
-
- tokenizeArguments(String) - Static method in class org.apache.flink.runtime.webmonitor.handlers.utils.JarHandlerUtils
-
Takes program arguments as a single string, and splits them into a list of string.
- Tokenizer() - Constructor for class org.apache.flink.examples.java.wordcount.WordCount.Tokenizer
-
- Tokenizer() - Constructor for class org.apache.flink.examples.java.wordcount.WordCountPojo.Tokenizer
-
- Tokenizer() - Constructor for class org.apache.flink.storm.wordcount.SpoutSourceWordCount.Tokenizer
-
- Tokenizer() - Constructor for class org.apache.flink.streaming.examples.sideoutput.SideOutputExample.Tokenizer
-
- Tokenizer() - Constructor for class org.apache.flink.streaming.examples.wordcount.WordCount.Tokenizer
-
- toKeyedStateHandleSnapshotResult(SnapshotResult<StreamStateHandle>, KeyGroupRangeOffsets) - Static method in interface org.apache.flink.runtime.state.CheckpointStreamWithResultProvider
-
Helper method that takes a
SnapshotResult
and a
KeyGroupRangeOffsets
and
creates a
SnapshotResult
by combining the key groups offsets with all the
present stream state handles.
- toLowerCase(StringValue) - Static method in class org.apache.flink.util.StringValueUtils
-
Converts the given StringValue
into a lower case variant.
- toMap() - Method in class org.apache.flink.api.common.ExecutionConfig.GlobalJobParameters
-
Convert UserConfig into a Map<String, String>
representation.
- toMap() - Method in class org.apache.flink.api.java.utils.ParameterTool
-
- toMap() - Method in class org.apache.flink.configuration.Configuration
-
- toMap() - Method in class org.apache.flink.configuration.DelegatingConfiguration
-
- toMap() - Method in class org.apache.flink.streaming.python.api.environment.PythonStreamExecutionEnvironment.PythonJobParameters
-
- toMilliseconds() - Method in class org.apache.flink.api.common.time.Time
-
Converts the time interval to milliseconds.
- toMilliseconds() - Method in class org.apache.flink.streaming.api.windowing.time.Time
-
Converts the time interval to milliseconds.
- ToNullValue<T> - Class in org.apache.flink.graph.asm.translate.translators
-
- ToNullValue() - Constructor for class org.apache.flink.graph.asm.translate.translators.ToNullValue
-
- TOP_CASE_CLASS_SPEEDS - Static variable in class org.apache.flink.streaming.examples.windowing.util.TopSpeedWindowingExampleData
-
- TOP_SONGS_RESULT - Static variable in class org.apache.flink.graph.examples.data.MusicProfilesData
-
- TOP_SPEEDS - Static variable in class org.apache.flink.streaming.examples.windowing.util.TopSpeedWindowingExampleData
-
- toParameterList(Configuration...) - Static method in class org.apache.flink.test.util.TestBaseUtils
-
- toParameterList(List<Configuration>) - Static method in class org.apache.flink.test.util.TestBaseUtils
-
- topic - Variable in class org.apache.flink.streaming.connectors.kafka.KafkaTableSink
-
- TOPIC - Static variable in class org.apache.flink.streaming.examples.statemachine.kafka.KafkaStandaloneGenerator
-
- topic(String) - Method in class org.apache.flink.table.descriptors.Kafka
-
Sets the topic from which the table is read.
- topicPartitionsMap - Variable in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducerBase
-
Partitions of each topic.
- TOPOLOGY_ID - Static variable in class org.apache.flink.storm.exclamation.ExclamationLocal
-
- toPrintableString() - Method in interface org.apache.flink.graph.asm.result.PrintableResult
-
A human-readable representation of this value.
- toPrintableString() - Method in class org.apache.flink.graph.library.clustering.directed.AverageClusteringCoefficient.Result
-
- toPrintableString() - Method in class org.apache.flink.graph.library.clustering.directed.GlobalClusteringCoefficient.Result
-
- toPrintableString() - Method in class org.apache.flink.graph.library.clustering.directed.LocalClusteringCoefficient.Result
-
Format values into a human-readable string.
- toPrintableString() - Method in class org.apache.flink.graph.library.clustering.directed.TriadicCensus.Result
-
- toPrintableString() - Method in class org.apache.flink.graph.library.clustering.directed.TriangleListing.Result
-
- toPrintableString() - Method in class org.apache.flink.graph.library.clustering.undirected.AverageClusteringCoefficient.Result
-
- toPrintableString() - Method in class org.apache.flink.graph.library.clustering.undirected.GlobalClusteringCoefficient.Result
-
- toPrintableString() - Method in class org.apache.flink.graph.library.clustering.undirected.LocalClusteringCoefficient.Result
-
Format values into a human-readable string.
- toPrintableString() - Method in class org.apache.flink.graph.library.clustering.undirected.TriadicCensus.Result
-
- toPrintableString() - Method in class org.apache.flink.graph.library.clustering.undirected.TriangleListing.Result
-
- toPrintableString() - Method in class org.apache.flink.graph.library.linkanalysis.HITS.Result
-
- toPrintableString() - Method in class org.apache.flink.graph.library.linkanalysis.PageRank.Result
-
- toPrintableString() - Method in class org.apache.flink.graph.library.metric.directed.EdgeMetrics.Result
-
- toPrintableString() - Method in class org.apache.flink.graph.library.metric.directed.VertexMetrics.Result
-
- toPrintableString() - Method in class org.apache.flink.graph.library.metric.undirected.EdgeMetrics.Result
-
- toPrintableString() - Method in class org.apache.flink.graph.library.metric.undirected.VertexMetrics.Result
-
- toPrintableString() - Method in class org.apache.flink.graph.library.similarity.AdamicAdar.Result
-
- toPrintableString() - Method in class org.apache.flink.graph.library.similarity.JaccardIndex.Result
-
- toProperties() - Method in class org.apache.flink.table.client.config.Deployment
-
- toProperties() - Method in class org.apache.flink.table.client.config.Execution
-
- TopSpeedWindowing - Class in org.apache.flink.streaming.examples.windowing
-
An example of grouped stream windowing where different eviction and trigger
policies can be used.
- TopSpeedWindowing() - Constructor for class org.apache.flink.streaming.examples.windowing.TopSpeedWindowing
-
- TopSpeedWindowingExampleData - Class in org.apache.flink.streaming.examples.windowing.util
-
Data for TopSpeedWindowingExampleITCase.
- toResultMap(Map<String, Accumulator<?, ?>>) - Static method in class org.apache.flink.api.common.accumulators.AccumulatorHelper
-
Transform the Map with accumulators into a Map containing only the
results.
- toSerializedEvent(AbstractEvent) - Static method in class org.apache.flink.runtime.io.network.api.serialization.EventSerializer
-
- toString() - Method in class org.apache.flink.api.common.accumulators.AverageAccumulator
-
- toString() - Method in class org.apache.flink.api.common.accumulators.DoubleCounter
-
- toString() - Method in class org.apache.flink.api.common.accumulators.DoubleMaximum
-
- toString() - Method in class org.apache.flink.api.common.accumulators.DoubleMinimum
-
- toString() - Method in class org.apache.flink.api.common.accumulators.Histogram
-
- toString() - Method in class org.apache.flink.api.common.accumulators.IntCounter
-
- toString() - Method in class org.apache.flink.api.common.accumulators.IntMaximum
-
- toString() - Method in class org.apache.flink.api.common.accumulators.IntMinimum
-
- toString() - Method in class org.apache.flink.api.common.accumulators.ListAccumulator
-
- toString() - Method in class org.apache.flink.api.common.accumulators.LongCounter
-
- toString() - Method in class org.apache.flink.api.common.accumulators.LongMaximum
-
- toString() - Method in class org.apache.flink.api.common.accumulators.LongMinimum
-
- toString() - Method in class org.apache.flink.api.common.accumulators.SerializedListAccumulator
-
- toString() - Method in class org.apache.flink.api.common.io.FileInputFormat.FileBaseStatistics
-
- toString() - Method in class org.apache.flink.api.common.io.FileInputFormat
-
- toString() - Method in class org.apache.flink.api.common.operators.DualInputSemanticProperties
-
- toString() - Method in class org.apache.flink.api.common.operators.GenericDataSinkBase
-
- toString() - Method in class org.apache.flink.api.common.operators.GenericDataSourceBase
-
- toString() - Method in class org.apache.flink.api.common.operators.Keys.ExpressionKeys
-
- toString() - Method in class org.apache.flink.api.common.operators.Keys.SelectorFunctionKeys
-
- toString() - Method in class org.apache.flink.api.common.operators.Operator
-
- toString() - Method in class org.apache.flink.api.common.operators.OperatorInformation
-
- toString() - Method in class org.apache.flink.api.common.operators.Ordering
-
- toString() - Method in class org.apache.flink.api.common.operators.ResourceSpec
-
- toString() - Method in class org.apache.flink.api.common.operators.SingleInputSemanticProperties
-
- toString() - Method in class org.apache.flink.api.common.operators.util.FieldSet
-
- toString() - Method in class org.apache.flink.api.common.state.StateDescriptor
-
- toString() - Method in class org.apache.flink.api.common.time.Time
-
- toString() - Method in class org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
-
- toString() - Method in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
-
- toString() - Method in class org.apache.flink.api.common.typeinfo.NothingTypeInfo
-
- toString() - Method in class org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
-
- toString() - Method in class org.apache.flink.api.common.typeinfo.SqlTimeTypeInfo
-
- toString() - Method in class org.apache.flink.api.common.typeinfo.TypeHint
-
- toString() - Method in class org.apache.flink.api.common.typeinfo.TypeInformation
-
- toString() - Method in class org.apache.flink.api.common.typeutils.base.GenericArraySerializer
-
- toString() - Method in class org.apache.flink.api.common.typeutils.CompositeType.FlatFieldDescriptor
-
- toString() - Method in class org.apache.flink.api.common.typeutils.CompositeType
-
- toString() - Method in class org.apache.flink.api.java.aggregation.MaxAggregationFunction
-
- toString() - Method in class org.apache.flink.api.java.aggregation.MinAggregationFunction
-
- toString() - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction
-
- toString() - Method in class org.apache.flink.api.java.io.CollectionInputFormat
-
- toString() - Method in class org.apache.flink.api.java.io.CsvInputFormat
-
- toString() - Method in class org.apache.flink.api.java.io.CsvOutputFormat
-
- toString() - Method in class org.apache.flink.api.java.io.PrintingOutputFormat
-
- toString() - Method in class org.apache.flink.api.java.io.TextInputFormat
-
- toString() - Method in class org.apache.flink.api.java.io.TextOutputFormat
-
- toString() - Method in class org.apache.flink.api.java.io.TextValueInputFormat
-
- toString() - Method in class org.apache.flink.api.java.LocalEnvironment
-
- toString() - Method in class org.apache.flink.api.java.operators.DataSink
-
- toString() - Method in class org.apache.flink.api.java.RemoteEnvironment
-
- toString() - Method in class org.apache.flink.api.java.sca.ModifiedASMFrame
-
- toString() - Method in class org.apache.flink.api.java.sca.TaggedValue
-
- toString() - Method in class org.apache.flink.api.java.summarize.BooleanColumnSummary
-
- toString() - Method in class org.apache.flink.api.java.summarize.NumericColumnSummary
-
- toString() - Method in class org.apache.flink.api.java.summarize.ObjectColumnSummary
-
- toString() - Method in class org.apache.flink.api.java.summarize.StringColumnSummary
-
- toString() - Method in class org.apache.flink.api.java.tuple.Tuple0
-
Creates a string representation of the tuple in the form "()".
- toString() - Method in class org.apache.flink.api.java.tuple.Tuple1
-
Creates a string representation of the tuple in the form
(f0),
where the individual fields are the value returned by calling
Object.toString()
on that field.
- toString() - Method in class org.apache.flink.api.java.tuple.Tuple10
-
Creates a string representation of the tuple in the form
(f0, f1, f2, f3, f4, f5, f6, f7, f8, f9),
where the individual fields are the value returned by calling
Object.toString()
on that field.
- toString() - Method in class org.apache.flink.api.java.tuple.Tuple11
-
Creates a string representation of the tuple in the form
(f0, f1, f2, f3, f4, f5, f6, f7, f8, f9, f10),
where the individual fields are the value returned by calling
Object.toString()
on that field.
- toString() - Method in class org.apache.flink.api.java.tuple.Tuple12
-
Creates a string representation of the tuple in the form
(f0, f1, f2, f3, f4, f5, f6, f7, f8, f9, f10, f11),
where the individual fields are the value returned by calling
Object.toString()
on that field.
- toString() - Method in class org.apache.flink.api.java.tuple.Tuple13
-
Creates a string representation of the tuple in the form
(f0, f1, f2, f3, f4, f5, f6, f7, f8, f9, f10, f11, f12),
where the individual fields are the value returned by calling
Object.toString()
on that field.
- toString() - Method in class org.apache.flink.api.java.tuple.Tuple14
-
Creates a string representation of the tuple in the form
(f0, f1, f2, f3, f4, f5, f6, f7, f8, f9, f10, f11, f12, f13),
where the individual fields are the value returned by calling
Object.toString()
on that field.
- toString() - Method in class org.apache.flink.api.java.tuple.Tuple15
-
Creates a string representation of the tuple in the form
(f0, f1, f2, f3, f4, f5, f6, f7, f8, f9, f10, f11, f12, f13, f14),
where the individual fields are the value returned by calling
Object.toString()
on that field.
- toString() - Method in class org.apache.flink.api.java.tuple.Tuple16
-
Creates a string representation of the tuple in the form
(f0, f1, f2, f3, f4, f5, f6, f7, f8, f9, f10, f11, f12, f13, f14, f15),
where the individual fields are the value returned by calling
Object.toString()
on that field.
- toString() - Method in class org.apache.flink.api.java.tuple.Tuple17
-
Creates a string representation of the tuple in the form
(f0, f1, f2, f3, f4, f5, f6, f7, f8, f9, f10, f11, f12, f13, f14, f15, f16),
where the individual fields are the value returned by calling
Object.toString()
on that field.
- toString() - Method in class org.apache.flink.api.java.tuple.Tuple18
-
Creates a string representation of the tuple in the form
(f0, f1, f2, f3, f4, f5, f6, f7, f8, f9, f10, f11, f12, f13, f14, f15, f16, f17),
where the individual fields are the value returned by calling
Object.toString()
on that field.
- toString() - Method in class org.apache.flink.api.java.tuple.Tuple19
-
Creates a string representation of the tuple in the form
(f0, f1, f2, f3, f4, f5, f6, f7, f8, f9, f10, f11, f12, f13, f14, f15, f16, f17, f18),
where the individual fields are the value returned by calling
Object.toString()
on that field.
- toString() - Method in class org.apache.flink.api.java.tuple.Tuple2
-
Creates a string representation of the tuple in the form
(f0, f1),
where the individual fields are the value returned by calling
Object.toString()
on that field.
- toString() - Method in class org.apache.flink.api.java.tuple.Tuple20
-
Creates a string representation of the tuple in the form
(f0, f1, f2, f3, f4, f5, f6, f7, f8, f9, f10, f11, f12, f13, f14, f15, f16, f17, f18, f19),
where the individual fields are the value returned by calling
Object.toString()
on that field.
- toString() - Method in class org.apache.flink.api.java.tuple.Tuple21
-
Creates a string representation of the tuple in the form
(f0, f1, f2, f3, f4, f5, f6, f7, f8, f9, f10, f11, f12, f13, f14, f15, f16, f17, f18, f19, f20),
where the individual fields are the value returned by calling
Object.toString()
on that field.
- toString() - Method in class org.apache.flink.api.java.tuple.Tuple22
-
Creates a string representation of the tuple in the form
(f0, f1, f2, f3, f4, f5, f6, f7, f8, f9, f10, f11, f12, f13, f14, f15, f16, f17, f18, f19, f20, f21),
where the individual fields are the value returned by calling
Object.toString()
on that field.
- toString() - Method in class org.apache.flink.api.java.tuple.Tuple23
-
Creates a string representation of the tuple in the form
(f0, f1, f2, f3, f4, f5, f6, f7, f8, f9, f10, f11, f12, f13, f14, f15, f16, f17, f18, f19, f20, f21, f22),
where the individual fields are the value returned by calling
Object.toString()
on that field.
- toString() - Method in class org.apache.flink.api.java.tuple.Tuple24
-
Creates a string representation of the tuple in the form
(f0, f1, f2, f3, f4, f5, f6, f7, f8, f9, f10, f11, f12, f13, f14, f15, f16, f17, f18, f19, f20, f21, f22, f23),
where the individual fields are the value returned by calling
Object.toString()
on that field.
- toString() - Method in class org.apache.flink.api.java.tuple.Tuple25
-
Creates a string representation of the tuple in the form
(f0, f1, f2, f3, f4, f5, f6, f7, f8, f9, f10, f11, f12, f13, f14, f15, f16, f17, f18, f19, f20, f21, f22, f23, f24),
where the individual fields are the value returned by calling
Object.toString()
on that field.
- toString() - Method in class org.apache.flink.api.java.tuple.Tuple3
-
Creates a string representation of the tuple in the form
(f0, f1, f2),
where the individual fields are the value returned by calling
Object.toString()
on that field.
- toString() - Method in class org.apache.flink.api.java.tuple.Tuple4
-
Creates a string representation of the tuple in the form
(f0, f1, f2, f3),
where the individual fields are the value returned by calling
Object.toString()
on that field.
- toString() - Method in class org.apache.flink.api.java.tuple.Tuple5
-
Creates a string representation of the tuple in the form
(f0, f1, f2, f3, f4),
where the individual fields are the value returned by calling
Object.toString()
on that field.
- toString() - Method in class org.apache.flink.api.java.tuple.Tuple6
-
Creates a string representation of the tuple in the form
(f0, f1, f2, f3, f4, f5),
where the individual fields are the value returned by calling
Object.toString()
on that field.
- toString() - Method in class org.apache.flink.api.java.tuple.Tuple7
-
Creates a string representation of the tuple in the form
(f0, f1, f2, f3, f4, f5, f6),
where the individual fields are the value returned by calling
Object.toString()
on that field.
- toString() - Method in class org.apache.flink.api.java.tuple.Tuple8
-
Creates a string representation of the tuple in the form
(f0, f1, f2, f3, f4, f5, f6, f7),
where the individual fields are the value returned by calling
Object.toString()
on that field.
- toString() - Method in class org.apache.flink.api.java.tuple.Tuple9
-
Creates a string representation of the tuple in the form
(f0, f1, f2, f3, f4, f5, f6, f7, f8),
where the individual fields are the value returned by calling
Object.toString()
on that field.
- toString() - Method in class org.apache.flink.api.java.typeutils.EitherTypeInfo
-
- toString() - Method in class org.apache.flink.api.java.typeutils.EnumTypeInfo
-
- toString() - Method in class org.apache.flink.api.java.typeutils.GenericTypeInfo
-
- toString() - Method in class org.apache.flink.api.java.typeutils.ListTypeInfo
-
- toString() - Method in class org.apache.flink.api.java.typeutils.MapTypeInfo
-
- toString() - Method in class org.apache.flink.api.java.typeutils.MissingTypeInfo
-
- toString() - Method in class org.apache.flink.api.java.typeutils.MultisetTypeInfo
-
- toString() - Method in class org.apache.flink.api.java.typeutils.ObjectArrayTypeInfo
-
- toString() - Method in class org.apache.flink.api.java.typeutils.PojoField
-
- toString() - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo.NamedFlatFieldDescriptor
-
- toString() - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo
-
- toString() - Method in class org.apache.flink.api.java.typeutils.RowTypeInfo
-
- toString() - Method in class org.apache.flink.api.java.typeutils.runtime.Tuple0Serializer
-
- toString() - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfo
-
- toString() - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfoBase
-
- toString() - Method in class org.apache.flink.api.java.typeutils.ValueTypeInfo
-
- toString() - Method in class org.apache.flink.api.java.typeutils.WritableTypeInfo
-
- toString() - Method in class org.apache.flink.api.java.Utils.ChecksumHashCode
-
- toString() - Method in class org.apache.flink.api.scala.operators.ScalaCsvOutputFormat
-
- toString() - Method in class org.apache.flink.cep.nfa.AfterMatchSkipStrategy
-
- toString() - Method in class org.apache.flink.cep.nfa.DeweyNumber
-
- toString() - Method in class org.apache.flink.cep.nfa.SharedBuffer
-
- toString() - Method in class org.apache.flink.cep.nfa.State
-
- toString() - Method in class org.apache.flink.cep.nfa.StateTransition
-
- toString() - Method in class org.apache.flink.client.deployment.ClusterSpecification
-
- toString() - Method in class org.apache.flink.client.program.ContextEnvironment
-
- toString() - Method in class org.apache.flink.configuration.ConfigOption
-
- toString() - Method in class org.apache.flink.configuration.Configuration
-
- toString() - Method in class org.apache.flink.configuration.DelegatingConfiguration
-
- toString() - Method in class org.apache.flink.configuration.MemorySize
-
- toString() - Method in class org.apache.flink.contrib.streaming.state.RocksDBStateBackend
-
- toString() - Method in class org.apache.flink.core.fs.ClosingFSDataInputStream
-
- toString() - Method in class org.apache.flink.core.fs.ClosingFSDataOutputStream
-
- toString() - Method in class org.apache.flink.core.fs.FileInputSplit
-
- toString() - Method in class org.apache.flink.core.fs.local.LocalFileStatus
-
- toString() - Method in class org.apache.flink.core.fs.Path
-
- toString() - Method in class org.apache.flink.core.io.GenericInputSplit
-
- toString() - Method in class org.apache.flink.core.io.LocatableInputSplit
-
- toString() - Method in class org.apache.flink.core.memory.ByteArrayOutputStreamWithPos
-
- toString() - Method in class org.apache.flink.core.memory.DataOutputSerializer
-
- toString() - Method in class org.apache.flink.core.testutils.OneShotLatch
-
- toString() - Method in class org.apache.flink.examples.java.clustering.KMeans.Centroid
-
- toString() - Method in class org.apache.flink.examples.java.clustering.KMeans.Point
-
- toString() - Method in class org.apache.flink.examples.java.distcp.FileCopyTask
-
- toString() - Method in class org.apache.flink.examples.java.misc.CollectionExecutionExample.EMail
-
- toString() - Method in class org.apache.flink.examples.java.misc.CollectionExecutionExample.User
-
- toString() - Method in class org.apache.flink.examples.java.ml.LinearRegression.Data
-
- toString() - Method in class org.apache.flink.examples.java.ml.LinearRegression.Params
-
- toString() - Method in class org.apache.flink.examples.java.relational.EmptyFieldsCountAccumulator.VectorAccumulator
-
- toString() - Method in class org.apache.flink.examples.java.wordcount.WordCountPojo.Word
-
- toString() - Method in class org.apache.flink.formats.avro.typeutils.AvroSerializer.AvroSchemaSerializerConfigSnapshot
-
- toString() - Method in class org.apache.flink.formats.avro.typeutils.AvroSerializer
-
- toString() - Method in class org.apache.flink.formats.avro.typeutils.BackwardsCompatibleAvroSerializer
-
- toString() - Method in class org.apache.flink.graph.asm.dataset.ChecksumHashCode.Checksum
-
- toString() - Method in class org.apache.flink.graph.asm.result.ResultBase
-
- toString() - Method in class org.apache.flink.graph.drivers.parameter.BooleanParameter
-
- toString() - Method in class org.apache.flink.graph.drivers.parameter.ChoiceParameter
-
- toString() - Method in class org.apache.flink.graph.drivers.parameter.DoubleParameter
-
- toString() - Method in class org.apache.flink.graph.drivers.parameter.LongParameter
-
- toString() - Method in class org.apache.flink.graph.drivers.parameter.StringParameter
-
- toString() - Method in class org.apache.flink.graph.drivers.transform.LongValueWithProperHashCode.LongValueWithProperHashCodeTypeInfo
-
- toString() - Method in class org.apache.flink.graph.examples.EuclideanGraphWeighing.Point
-
- toString() - Method in class org.apache.flink.graph.generator.CirculantGraph.OffsetRange
-
- toString() - Method in class org.apache.flink.graph.library.clustering.directed.AverageClusteringCoefficient.Result
-
- toString() - Method in class org.apache.flink.graph.library.clustering.directed.GlobalClusteringCoefficient.Result
-
- toString() - Method in class org.apache.flink.graph.library.clustering.directed.LocalClusteringCoefficient.Result
-
- toString() - Method in class org.apache.flink.graph.library.clustering.directed.TriadicCensus.Result
-
- toString() - Method in class org.apache.flink.graph.library.clustering.directed.TriangleListing.Result
-
- toString() - Method in class org.apache.flink.graph.library.clustering.undirected.AverageClusteringCoefficient.Result
-
- toString() - Method in class org.apache.flink.graph.library.clustering.undirected.GlobalClusteringCoefficient.Result
-
- toString() - Method in class org.apache.flink.graph.library.clustering.undirected.LocalClusteringCoefficient.Result
-
- toString() - Method in class org.apache.flink.graph.library.clustering.undirected.TriadicCensus.Result
-
- toString() - Method in class org.apache.flink.graph.library.clustering.undirected.TriangleListing.Result
-
- toString() - Method in class org.apache.flink.graph.library.linkanalysis.HITS.Result
-
- toString() - Method in class org.apache.flink.graph.library.linkanalysis.PageRank.Result
-
- toString() - Method in class org.apache.flink.graph.library.metric.directed.EdgeMetrics.Result
-
- toString() - Method in class org.apache.flink.graph.library.metric.directed.VertexMetrics.Result
-
- toString() - Method in class org.apache.flink.graph.library.metric.undirected.EdgeMetrics.Result
-
- toString() - Method in class org.apache.flink.graph.library.metric.undirected.VertexMetrics.Result
-
- toString() - Method in class org.apache.flink.graph.library.similarity.AdamicAdar.Result
-
- toString() - Method in class org.apache.flink.graph.library.similarity.JaccardIndex.Result
-
- toString() - Method in class org.apache.flink.graph.types.valuearray.ByteValueArray
-
- toString() - Method in class org.apache.flink.graph.types.valuearray.CharValueArray
-
- toString() - Method in class org.apache.flink.graph.types.valuearray.DoubleValueArray
-
- toString() - Method in class org.apache.flink.graph.types.valuearray.FloatValueArray
-
- toString() - Method in class org.apache.flink.graph.types.valuearray.IntValueArray
-
- toString() - Method in class org.apache.flink.graph.types.valuearray.LongValueArray
-
- toString() - Method in class org.apache.flink.graph.types.valuearray.NullValueArray
-
- toString() - Method in class org.apache.flink.graph.types.valuearray.ShortValueArray
-
- toString() - Method in class org.apache.flink.graph.types.valuearray.StringValueArray
-
- toString() - Method in class org.apache.flink.graph.types.valuearray.ValueArrayTypeInfo
-
- toString() - Method in class org.apache.flink.mesos.runtime.clusterframework.LaunchableMesosWorker
-
- toString() - Method in class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManagerParameters
-
- toString() - Method in class org.apache.flink.mesos.runtime.clusterframework.RegisteredMesosWorkerNode
-
- toString() - Method in class org.apache.flink.mesos.runtime.clusterframework.store.MesosWorkerStore.Worker
-
- toString() - Method in class org.apache.flink.mesos.scheduler.messages.AcceptOffers
-
- toString() - Method in class org.apache.flink.mesos.scheduler.messages.Disconnected
-
- toString() - Method in class org.apache.flink.mesos.scheduler.messages.Error
-
- toString() - Method in class org.apache.flink.mesos.scheduler.messages.ExecutorLost
-
- toString() - Method in class org.apache.flink.mesos.scheduler.messages.FrameworkMessage
-
- toString() - Method in class org.apache.flink.mesos.scheduler.messages.OfferRescinded
-
- toString() - Method in class org.apache.flink.mesos.scheduler.messages.Registered
-
- toString() - Method in class org.apache.flink.mesos.scheduler.messages.ReRegistered
-
- toString() - Method in class org.apache.flink.mesos.scheduler.messages.ResourceOffers
-
- toString() - Method in class org.apache.flink.mesos.scheduler.messages.SlaveLost
-
- toString() - Method in class org.apache.flink.mesos.scheduler.messages.StatusUpdate
-
- toString() - Method in class org.apache.flink.mesos.scheduler.Offer
-
- toString() - Method in class org.apache.flink.mesos.util.MesosConfiguration
-
- toString() - Method in class org.apache.flink.mesos.util.MesosResourceAllocation
-
- toString(Collection<Protos.Resource>) - Static method in class org.apache.flink.mesos.Utils
-
Gets a string representation of a collection of resources.
- toString(Protos.Resource) - Static method in class org.apache.flink.mesos.Utils
-
Gets a string representation of a resource.
- toString(Protos.Value.Ranges) - Static method in class org.apache.flink.mesos.Utils
-
Gets a string representation of a collection of ranges.
- toString(Protos.Value.Range) - Static method in class org.apache.flink.mesos.Utils
-
Gets a string representation of a range.
- toString() - Method in class org.apache.flink.optimizer.costs.Costs
-
- toString() - Method in class org.apache.flink.optimizer.dag.DagConnection
-
- toString() - Method in class org.apache.flink.optimizer.dag.OptimizerNode
-
- toString() - Method in class org.apache.flink.optimizer.dag.OptimizerNode.UnclosedBranchDescriptor
-
- toString() - Method in class org.apache.flink.optimizer.dataproperties.GlobalProperties
-
- toString() - Method in class org.apache.flink.optimizer.dataproperties.InterestingProperties
-
- toString() - Method in class org.apache.flink.optimizer.dataproperties.LocalProperties
-
- toString() - Method in class org.apache.flink.optimizer.dataproperties.RequestedGlobalProperties
-
- toString() - Method in class org.apache.flink.optimizer.dataproperties.RequestedLocalProperties
-
- toString() - Method in class org.apache.flink.optimizer.operators.OperatorDescriptorDual.GlobalPropertiesPair
-
- toString() - Method in class org.apache.flink.optimizer.operators.OperatorDescriptorDual.LocalPropertiesPair
-
- toString() - Method in class org.apache.flink.optimizer.plan.Channel
-
- toString() - Method in class org.apache.flink.optimizer.plan.PlanNode
-
- toString() - Method in class org.apache.flink.orc.OrcRowInputFormat.Between
-
- toString() - Method in class org.apache.flink.orc.OrcRowInputFormat.Equals
-
- toString() - Method in class org.apache.flink.orc.OrcRowInputFormat.In
-
- toString() - Method in class org.apache.flink.orc.OrcRowInputFormat.IsNull
-
- toString() - Method in class org.apache.flink.orc.OrcRowInputFormat.LessThan
-
- toString() - Method in class org.apache.flink.orc.OrcRowInputFormat.LessThanEquals
-
- toString() - Method in class org.apache.flink.orc.OrcRowInputFormat.Not
-
- toString() - Method in class org.apache.flink.orc.OrcRowInputFormat.NullSafeEquals
-
- toString() - Method in class org.apache.flink.orc.OrcRowInputFormat.Or
-
- toString() - Method in class org.apache.flink.python.api.PythonOperationInfo
-
- toString() - Method in class org.apache.flink.queryablestate.client.VoidNamespace
-
- toString() - Method in class org.apache.flink.queryablestate.client.VoidNamespaceTypeInfo
-
- toString() - Method in class org.apache.flink.queryablestate.messages.KvStateRequest
-
- toString() - Method in class org.apache.flink.queryablestate.network.ChunkedByteBuf
-
- toString() - Method in class org.apache.flink.queryablestate.network.messages.RequestFailure
-
- toString() - Method in class org.apache.flink.queryablestate.network.stats.AtomicKvStateRequestStats
-
- toString() - Method in class org.apache.flink.runtime.blob.BlobKey
-
- toString() - Method in class org.apache.flink.runtime.broadcast.BroadcastVariableKey
-
- toString() - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetaData
-
- toString() - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetrics
-
- toString() - Method in class org.apache.flink.runtime.checkpoint.CheckpointOptions
-
- toString() - Method in class org.apache.flink.runtime.checkpoint.CheckpointProperties
-
- toString() - Method in class org.apache.flink.runtime.checkpoint.CheckpointTriggerResult
-
- toString() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
-
- toString() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpointStats
-
- toString() - Method in class org.apache.flink.runtime.checkpoint.JobManagerTaskRestore
-
- toString() - Method in class org.apache.flink.runtime.checkpoint.MasterState
-
- toString() - Method in class org.apache.flink.runtime.checkpoint.OperatorState
-
- toString() - Method in class org.apache.flink.runtime.checkpoint.OperatorSubtaskState
-
- toString() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
-
- toString() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpointStats
-
- toString() - Method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV1
-
- toString() - Method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV2
-
- toString() - Method in class org.apache.flink.runtime.checkpoint.StateObjectCollection
-
- toString() - Method in class org.apache.flink.runtime.checkpoint.SubtaskState
-
- toString() - Method in class org.apache.flink.runtime.checkpoint.TaskState
-
Deprecated.
- toString() - Method in class org.apache.flink.runtime.checkpoint.TaskStateSnapshot
-
- toString() - Method in class org.apache.flink.runtime.clusterframework.ContaineredTaskManagerParameters
-
- toString() - Method in class org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact
-
- toString() - Method in class org.apache.flink.runtime.clusterframework.ContainerSpecification
-
- toString() - Method in class org.apache.flink.runtime.clusterframework.messages.CheckAndAllocateContainers
-
- toString() - Method in class org.apache.flink.runtime.clusterframework.messages.FatalErrorOccurred
-
- toString() - Method in class org.apache.flink.runtime.clusterframework.messages.GetClusterStatus
-
- toString() - Method in class org.apache.flink.runtime.clusterframework.messages.GetClusterStatusResponse
-
- toString() - Method in class org.apache.flink.runtime.clusterframework.messages.InfoMessage
-
- toString() - Method in class org.apache.flink.runtime.clusterframework.messages.NewLeaderAvailable
-
- toString() - Method in class org.apache.flink.runtime.clusterframework.messages.NotifyResourceStarted
-
- toString() - Method in class org.apache.flink.runtime.clusterframework.messages.ReconnectResourceManager
-
- toString() - Method in class org.apache.flink.runtime.clusterframework.messages.RegisterInfoMessageListener
-
- toString() - Method in class org.apache.flink.runtime.clusterframework.messages.RegisterInfoMessageListenerSuccessful
-
- toString() - Method in class org.apache.flink.runtime.clusterframework.messages.RegisterResourceManager
-
- toString() - Method in class org.apache.flink.runtime.clusterframework.messages.RegisterResourceManagerSuccessful
-
- toString() - Method in class org.apache.flink.runtime.clusterframework.messages.RemoveResource
-
- toString() - Method in class org.apache.flink.runtime.clusterframework.messages.ResourceRemoved
-
- toString() - Method in class org.apache.flink.runtime.clusterframework.messages.SetWorkerPoolSize
-
- toString() - Method in class org.apache.flink.runtime.clusterframework.messages.ShutdownClusterAfterJob
-
- toString() - Method in class org.apache.flink.runtime.clusterframework.messages.StopCluster
-
- toString() - Method in class org.apache.flink.runtime.clusterframework.messages.StopClusterSuccessful
-
- toString() - Method in class org.apache.flink.runtime.clusterframework.messages.TriggerRegistrationAtJobManager
-
- toString() - Method in class org.apache.flink.runtime.clusterframework.messages.UnRegisterInfoMessageListener
-
- toString() - Method in class org.apache.flink.runtime.clusterframework.types.AllocationID
-
- toString() - Method in class org.apache.flink.runtime.clusterframework.types.ResourceID
-
- toString() - Method in class org.apache.flink.runtime.clusterframework.types.ResourceProfile
-
- toString() - Method in class org.apache.flink.runtime.clusterframework.types.SlotID
-
- toString() - Method in class org.apache.flink.runtime.deployment.InputChannelDeploymentDescriptor
-
- toString() - Method in class org.apache.flink.runtime.deployment.InputGateDeploymentDescriptor
-
- toString() - Method in class org.apache.flink.runtime.deployment.ResultPartitionDeploymentDescriptor
-
- toString() - Method in class org.apache.flink.runtime.deployment.ResultPartitionLocation
-
- toString() - Method in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
-
- toString() - Method in class org.apache.flink.runtime.entrypoint.ClusterInformation
-
- toString() - Method in class org.apache.flink.runtime.executiongraph.Execution
-
- toString() - Method in class org.apache.flink.runtime.executiongraph.ExecutionAndAllocationFuture
-
- toString() - Method in class org.apache.flink.runtime.executiongraph.ExecutionEdge
-
- toString() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- toString() - Method in class org.apache.flink.runtime.executiongraph.IntermediateResult
-
- toString() - Method in class org.apache.flink.runtime.executiongraph.JobInformation
-
- toString() - Method in class org.apache.flink.runtime.executiongraph.restart.FailureRateRestartStrategy
-
- toString() - Method in class org.apache.flink.runtime.executiongraph.restart.FixedDelayRestartStrategy
-
- toString() - Method in class org.apache.flink.runtime.executiongraph.restart.NoRestartStrategy
-
- toString() - Method in class org.apache.flink.runtime.instance.AkkaActorGateway
-
- toString() - Method in class org.apache.flink.runtime.instance.HardwareDescription
-
- toString() - Method in class org.apache.flink.runtime.instance.Instance
-
- toString() - Method in class org.apache.flink.runtime.instance.SharedSlot
-
- toString() - Method in class org.apache.flink.runtime.instance.SimpleSlot
-
- toString() - Method in class org.apache.flink.runtime.instance.Slot
-
- toString() - Method in class org.apache.flink.runtime.io.disk.iomanager.FileIOChannel.ID
-
- toString() - Method in class org.apache.flink.runtime.io.network.api.CancelCheckpointMarker
-
- toString() - Method in class org.apache.flink.runtime.io.network.api.CheckpointBarrier
-
- toString() - Method in class org.apache.flink.runtime.io.network.api.EndOfPartitionEvent
-
- toString() - Method in class org.apache.flink.runtime.io.network.api.EndOfSuperstepEvent
-
- toString() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
-
- toString() - Method in class org.apache.flink.runtime.io.network.ConnectionID
-
- toString() - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
-
- toString() - Method in class org.apache.flink.runtime.io.network.partition.consumer.BufferOrEvent
-
- toString() - Method in class org.apache.flink.runtime.io.network.partition.consumer.LocalInputChannel
-
- toString() - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
-
- toString() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
-
- toString() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartitionID
-
- toString() - Method in class org.apache.flink.runtime.jobgraph.IntermediateDataSet
-
- toString() - Method in class org.apache.flink.runtime.jobgraph.JobEdge
-
- toString() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
- toString() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
- toString() - Method in class org.apache.flink.runtime.jobgraph.OperatorInstanceID
-
- toString() - Method in class org.apache.flink.runtime.jobgraph.SavepointRestoreSettings
-
- toString() - Method in class org.apache.flink.runtime.jobgraph.tasks.CheckpointCoordinatorConfiguration
-
- toString() - Method in class org.apache.flink.runtime.jobgraph.tasks.JobCheckpointingSettings
-
- toString() - Method in class org.apache.flink.runtime.jobmanager.scheduler.CoLocationConstraint
-
- toString() - Method in class org.apache.flink.runtime.jobmanager.scheduler.ScheduledUnit
-
- toString() - Method in class org.apache.flink.runtime.jobmanager.scheduler.SetQueue
-
- toString() - Method in class org.apache.flink.runtime.jobmanager.scheduler.SlotSharingGroup
-
- toString() - Method in class org.apache.flink.runtime.jobmanager.SubmittedJobGraph
-
- toString() - Method in class org.apache.flink.runtime.jobmaster.JobMasterRegistrationSuccess
-
- toString() - Method in class org.apache.flink.runtime.jobmaster.ResourceManagerAddress
-
- toString() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotAndLocality
-
- toString() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotSharingManager.MultiTaskSlot
-
- toString() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotSharingManager.SingleTaskSlot
-
- toString() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotSharingManager
-
- toString() - Method in class org.apache.flink.runtime.jobmaster.SlotRequestId
-
- toString() - Method in class org.apache.flink.runtime.leaderelection.LeaderAddressAndId
-
- toString() - Method in class org.apache.flink.runtime.leaderelection.ZooKeeperLeaderElectionService
-
- toString() - Method in class org.apache.flink.runtime.messages.Acknowledge
-
- toString() - Method in class org.apache.flink.runtime.messages.checkpoint.AbstractCheckpointMessage
-
- toString() - Method in class org.apache.flink.runtime.messages.checkpoint.AcknowledgeCheckpoint
-
- toString() - Method in class org.apache.flink.runtime.messages.checkpoint.DeclineCheckpoint
-
- toString() - Method in class org.apache.flink.runtime.messages.checkpoint.NotifyCheckpointComplete
-
- toString() - Method in class org.apache.flink.runtime.messages.checkpoint.TriggerCheckpoint
-
- toString() - Method in class org.apache.flink.runtime.messages.webmonitor.ClusterOverview
-
- toString() - Method in class org.apache.flink.runtime.messages.webmonitor.JobDetails
-
- toString() - Method in class org.apache.flink.runtime.messages.webmonitor.JobIdsWithStatusOverview
-
- toString() - Method in class org.apache.flink.runtime.messages.webmonitor.JobsOverview
-
- toString() - Method in class org.apache.flink.runtime.messages.webmonitor.MultipleJobsDetails
-
- toString() - Method in class org.apache.flink.runtime.messages.webmonitor.RequestJobDetails
-
- toString() - Method in class org.apache.flink.runtime.messages.webmonitor.RequestJobsOverview
-
- toString() - Method in class org.apache.flink.runtime.messages.webmonitor.RequestJobsWithIDsOverview
-
- toString() - Method in class org.apache.flink.runtime.messages.webmonitor.RequestStatusOverview
-
- toString() - Method in class org.apache.flink.runtime.metrics.dump.MetricDump
-
- toString() - Method in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo
-
- toString() - Method in class org.apache.flink.runtime.metrics.scope.ScopeFormat
-
- toString() - Method in class org.apache.flink.runtime.minicluster.MiniClusterConfiguration
-
- toString() - Method in class org.apache.flink.runtime.operators.hash.InMemoryPartition
-
- toString() - Method in class org.apache.flink.runtime.operators.util.BitSet
-
- toString() - Method in class org.apache.flink.runtime.operators.util.BloomFilter.BitSet
-
- toString() - Method in class org.apache.flink.runtime.operators.util.BloomFilter
-
- toString() - Method in class org.apache.flink.runtime.query.KvStateLocation
-
- toString() - Method in class org.apache.flink.runtime.query.KvStateMessage.LookupKvStateLocation
-
- toString() - Method in class org.apache.flink.runtime.query.KvStateMessage.NotifyKvStateRegistered
-
- toString() - Method in class org.apache.flink.runtime.query.KvStateMessage.NotifyKvStateUnregistered
-
- toString() - Method in class org.apache.flink.runtime.registration.RegisteredRpcConnection
-
- toString() - Method in class org.apache.flink.runtime.registration.RegistrationResponse.Decline
-
- toString() - Method in class org.apache.flink.runtime.registration.RegistrationResponse.Success
-
- toString() - Method in class org.apache.flink.runtime.rest.handler.legacy.backpressure.OperatorBackPressureStats
-
- toString() - Method in class org.apache.flink.runtime.rest.handler.legacy.backpressure.StackTraceSample
-
- toString() - Method in class org.apache.flink.runtime.rest.messages.ClusterConfigurationInfoEntry
-
- toString() - Method in class org.apache.flink.runtime.rest.messages.job.JobSubmitRequestBody
-
- toString() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedMetric
-
- toString() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.Metric
-
- toString() - Method in class org.apache.flink.runtime.rest.messages.JobPlanInfo.RawJson
-
- toString() - Method in class org.apache.flink.runtime.rest.messages.JobPlanInfo
-
- toString() - Method in enum org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo.VertexBackPressureLevel
-
- toString() - Method in enum org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo.VertexBackPressureStatus
-
- toString() - Method in class org.apache.flink.runtime.rpc.messages.LocalFencedMessage
-
- toString() - Method in class org.apache.flink.runtime.rpc.messages.LocalRpcInvocation
-
- toString() - Method in class org.apache.flink.runtime.rpc.messages.RemoteFencedMessage
-
- toString() - Method in class org.apache.flink.runtime.rpc.messages.RemoteRpcInvocation
-
- toString() - Method in class org.apache.flink.runtime.rpc.messages.UnfencedMessage
-
- toString() - Method in class org.apache.flink.runtime.state.BoundedInputStream
-
- toString() - Method in class org.apache.flink.runtime.state.CheckpointStorageLocationReference
-
- toString() - Method in class org.apache.flink.runtime.state.DirectoryKeyedStateHandle
-
- toString() - Method in class org.apache.flink.runtime.state.DirectoryStateHandle
-
- toString() - Method in class org.apache.flink.runtime.state.filesystem.FileStateHandle
-
- toString() - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStorageLocation
-
- toString() - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStreamFactory
-
- toString() - Method in class org.apache.flink.runtime.state.filesystem.FsStateBackend
-
- toString() - Method in class org.apache.flink.runtime.state.heap.HeapKeyedStateBackend
-
- toString() - Method in class org.apache.flink.runtime.state.HeapBroadcastState
-
- toString() - Method in class org.apache.flink.runtime.state.IncrementalKeyedStateHandle
-
- toString() - Method in class org.apache.flink.runtime.state.IncrementalLocalKeyedStateHandle
-
- toString() - Method in class org.apache.flink.runtime.state.KeyGroupRange
-
- toString() - Method in class org.apache.flink.runtime.state.KeyGroupRangeOffsets
-
- toString() - Method in class org.apache.flink.runtime.state.KeyGroupsStateHandle
-
- toString() - Method in class org.apache.flink.runtime.state.LocalRecoveryConfig
-
- toString() - Method in class org.apache.flink.runtime.state.LocalRecoveryDirectoryProviderImpl
-
- toString() - Method in class org.apache.flink.runtime.state.memory.ByteStreamStateHandle
-
- toString() - Method in class org.apache.flink.runtime.state.memory.MemCheckpointStreamFactory
-
- toString() - Method in class org.apache.flink.runtime.state.memory.MemoryBackendCheckpointStorage
-
- toString() - Method in class org.apache.flink.runtime.state.memory.MemoryStateBackend
-
- toString() - Method in class org.apache.flink.runtime.state.OperatorStateHandle.StateMetaInfo
-
- toString() - Method in class org.apache.flink.runtime.state.OperatorStreamStateHandle
-
- toString() - Method in class org.apache.flink.runtime.state.RegisteredBroadcastBackendStateMetaInfo
-
- toString() - Method in class org.apache.flink.runtime.state.RegisteredKeyedBackendStateMetaInfo
-
- toString() - Method in class org.apache.flink.runtime.state.RegisteredOperatorBackendStateMetaInfo
-
- toString() - Method in class org.apache.flink.runtime.state.SharedStateRegistry.Result
-
- toString() - Method in class org.apache.flink.runtime.state.SharedStateRegistry
-
- toString() - Method in class org.apache.flink.runtime.state.SnapshotDirectory
-
- toString() - Method in class org.apache.flink.runtime.state.TaskLocalStateStoreImpl
-
- toString() - Method in class org.apache.flink.runtime.state.VoidNamespace
-
- toString() - Method in class org.apache.flink.runtime.state.VoidNamespaceTypeInfo
-
- toString() - Method in class org.apache.flink.runtime.taskexecutor.QueryableStateConfiguration
-
- toString() - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlot
-
- toString() - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorRegistrationSuccess
-
- toString() - Method in class org.apache.flink.runtime.taskmanager.NetworkEnvironmentConfiguration
-
- toString() - Method in class org.apache.flink.runtime.taskmanager.Task
-
- toString() - Method in class org.apache.flink.runtime.taskmanager.TaskExecutionState
-
- toString() - Method in class org.apache.flink.runtime.taskmanager.TaskManagerLocation
-
- toString() - Method in class org.apache.flink.runtime.util.LeaderConnectionInfo
-
- toString() - Method in class org.apache.flink.runtime.util.OperatorSubtaskDescriptionText
-
- toString() - Method in class org.apache.flink.runtime.webmonitor.history.ArchivedJson
-
- toString() - Method in class org.apache.flink.storm.util.SplitStreamType
-
- toString() - Method in class org.apache.flink.storm.wordcount.operators.WordCountDataPojos.Sentence
-
- toString() - Method in class org.apache.flink.storm.wrappers.StormTuple
-
- toString() - Method in class org.apache.flink.streaming.api.environment.RemoteStreamEnvironment
-
- toString() - Method in class org.apache.flink.streaming.api.functions.sink.PrintSinkFunction
-
- toString() - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.TransactionHolder
-
- toString() - Method in class org.apache.flink.streaming.api.functions.source.TimestampedFileInputSplit
-
- toString() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
- toString() - Method in class org.apache.flink.streaming.api.graph.StreamEdge
-
- toString() - Method in class org.apache.flink.streaming.api.graph.StreamNode
-
- toString() - Method in class org.apache.flink.streaming.api.operators.InternalTimer
-
- toString() - Method in class org.apache.flink.streaming.api.transformations.StreamTransformation
-
- toString() - Method in class org.apache.flink.streaming.api.watermark.Watermark
-
- toString() - Method in class org.apache.flink.streaming.api.windowing.assigners.DynamicEventTimeSessionWindows
-
- toString() - Method in class org.apache.flink.streaming.api.windowing.assigners.DynamicProcessingTimeSessionWindows
-
- toString() - Method in class org.apache.flink.streaming.api.windowing.assigners.EventTimeSessionWindows
-
- toString() - Method in class org.apache.flink.streaming.api.windowing.assigners.GlobalWindows
-
- toString() - Method in class org.apache.flink.streaming.api.windowing.assigners.ProcessingTimeSessionWindows
-
- toString() - Method in class org.apache.flink.streaming.api.windowing.assigners.SlidingEventTimeWindows
-
- toString() - Method in class org.apache.flink.streaming.api.windowing.assigners.SlidingProcessingTimeWindows
-
- toString() - Method in class org.apache.flink.streaming.api.windowing.assigners.TumblingEventTimeWindows
-
- toString() - Method in class org.apache.flink.streaming.api.windowing.assigners.TumblingProcessingTimeWindows
-
- toString() - Method in class org.apache.flink.streaming.api.windowing.evictors.DeltaEvictor
-
- toString() - Method in class org.apache.flink.streaming.api.windowing.evictors.TimeEvictor
-
- toString() - Method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousEventTimeTrigger
-
- toString() - Method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousProcessingTimeTrigger
-
- toString() - Method in class org.apache.flink.streaming.api.windowing.triggers.CountTrigger
-
- toString() - Method in class org.apache.flink.streaming.api.windowing.triggers.DeltaTrigger
-
- toString() - Method in class org.apache.flink.streaming.api.windowing.triggers.EventTimeTrigger
-
- toString() - Method in class org.apache.flink.streaming.api.windowing.triggers.ProcessingTimeTrigger
-
- toString() - Method in class org.apache.flink.streaming.api.windowing.triggers.PurgingTrigger
-
- toString() - Method in class org.apache.flink.streaming.api.windowing.windows.GlobalWindow
-
- toString() - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow
-
- toString() - Method in class org.apache.flink.streaming.connectors.fs.bucketing.BasePathBucketer
-
- toString() - Method in class org.apache.flink.streaming.connectors.fs.bucketing.DateTimeBucketer
-
- toString() - Method in class org.apache.flink.streaming.connectors.fs.DateTimeBucketer
-
Deprecated.
- toString() - Method in class org.apache.flink.streaming.connectors.fs.NonRollingBucketer
-
Deprecated.
- toString() - Method in class org.apache.flink.streaming.connectors.fs.RollingSink.BucketState
-
Deprecated.
- toString() - Method in class org.apache.flink.streaming.connectors.kafka.internals.ClosableBlockingQueue
-
- toString() - Method in class org.apache.flink.streaming.connectors.kafka.internals.KafkaTopicPartition
-
- toString(Map<KafkaTopicPartition, Long>) - Static method in class org.apache.flink.streaming.connectors.kafka.internals.KafkaTopicPartition
-
- toString(List<KafkaTopicPartition>) - Static method in class org.apache.flink.streaming.connectors.kafka.internals.KafkaTopicPartition
-
- toString() - Method in class org.apache.flink.streaming.connectors.kafka.internals.KafkaTopicPartitionLeader
-
- toString() - Method in class org.apache.flink.streaming.connectors.kafka.internals.KafkaTopicPartitionState
-
- toString() - Method in class org.apache.flink.streaming.connectors.kafka.internals.KafkaTopicPartitionStateWithPeriodicWatermarks
-
- toString() - Method in class org.apache.flink.streaming.connectors.kafka.internals.KafkaTopicPartitionStateWithPunctuatedWatermarks
-
- toString() - Method in class org.apache.flink.streaming.connectors.kafka.internals.KafkaTopicsDescriptor
-
- toString() - Method in class org.apache.flink.streaming.connectors.wikiedits.WikipediaEditEvent
-
- toString() - Method in class org.apache.flink.streaming.examples.kafka.KafkaEvent
-
- toString() - Method in class org.apache.flink.streaming.examples.socket.SocketWindowWordCount.WordWithCount
-
- toString() - Method in class org.apache.flink.streaming.examples.statemachine.dfa.Transition
-
- toString() - Method in class org.apache.flink.streaming.examples.statemachine.event.Alert
-
- toString() - Method in class org.apache.flink.streaming.examples.statemachine.event.Event
-
- toString() - Method in class org.apache.flink.streaming.runtime.io.BarrierBuffer
-
- toString() - Method in class org.apache.flink.streaming.runtime.operators.windowing.MergingWindowSet
-
- toString() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
-
- toString() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Timer
-
- toString() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.WindowContext
-
- toString() - Method in class org.apache.flink.streaming.runtime.partitioner.BroadcastPartitioner
-
- toString() - Method in class org.apache.flink.streaming.runtime.partitioner.CustomPartitionerWrapper
-
- toString() - Method in class org.apache.flink.streaming.runtime.partitioner.ForwardPartitioner
-
- toString() - Method in class org.apache.flink.streaming.runtime.partitioner.GlobalPartitioner
-
- toString() - Method in class org.apache.flink.streaming.runtime.partitioner.KeyGroupStreamPartitioner
-
- toString() - Method in class org.apache.flink.streaming.runtime.partitioner.RebalancePartitioner
-
- toString() - Method in class org.apache.flink.streaming.runtime.partitioner.RescalePartitioner
-
- toString() - Method in class org.apache.flink.streaming.runtime.partitioner.ShufflePartitioner
-
- toString() - Method in class org.apache.flink.streaming.runtime.streamrecord.LatencyMarker
-
- toString() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecord
-
- toString() - Method in class org.apache.flink.streaming.runtime.streamstatus.StreamStatus
-
- toString() - Method in exception org.apache.flink.streaming.runtime.tasks.AsynchronousException
-
- toString() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- toString() - Method in exception org.apache.flink.streaming.runtime.tasks.TimerException
-
- toString() - Method in class org.apache.flink.streaming.tests.Event
-
- toString() - Method in class org.apache.flink.streaming.tests.StickyAllocationAndLocalRecoveryTestJob.MapperSchedulingAndFailureInfo
-
- toString() - Method in class org.apache.flink.table.client.config.Environment
-
- toString() - Method in class org.apache.flink.table.client.gateway.TypedResult
-
- toString() - Method in class org.apache.flink.table.examples.java.StreamSQLExample.Order
-
- toString() - Method in class org.apache.flink.table.examples.java.WordCountSQL.WC
-
- toString() - Method in class org.apache.flink.table.examples.java.WordCountTable.WC
-
- toString() - Method in class org.apache.flink.types.BooleanValue
-
- toString() - Method in class org.apache.flink.types.ByteValue
-
- toString() - Method in class org.apache.flink.types.CharValue
-
- toString() - Method in class org.apache.flink.types.DoubleValue
-
- toString() - Method in class org.apache.flink.types.Either.Left
-
- toString() - Method in class org.apache.flink.types.Either.Right
-
- toString() - Method in class org.apache.flink.types.FloatValue
-
- toString() - Method in class org.apache.flink.types.IntValue
-
- toString() - Method in class org.apache.flink.types.ListValue
-
- toString() - Method in class org.apache.flink.types.LongValue
-
- toString() - Method in class org.apache.flink.types.MapValue
-
- toString() - Method in class org.apache.flink.types.NullValue
-
- toString() - Method in class org.apache.flink.types.Row
-
- toString() - Method in class org.apache.flink.types.ShortValue
-
- toString() - Method in class org.apache.flink.types.StringValue
-
- toString() - Method in class org.apache.flink.util.AbstractID
-
- toString() - Method in class org.apache.flink.util.OptionalFailure
-
- toString() - Method in class org.apache.flink.util.OutputTag
-
- toString() - Method in class org.apache.flink.util.ReflectionUtil.FullTypeInfo
-
- toString() - Method in exception org.apache.flink.util.SerializedThrowable
-
- toString() - Method in class org.apache.flink.util.SerializedValue
-
- toString() - Method in class org.apache.flink.util.StringBasedID
-
- toString() - Method in class org.apache.flink.yarn.messages.ContainersAllocated
-
- toString() - Method in class org.apache.flink.yarn.messages.ContainersComplete
-
- toString() - Method in class org.apache.flink.yarn.RegisteredYarnWorkerNode
-
- toString() - Method in class org.apache.flink.yarn.YarnContainerInLaunch
-
- toString() - Method in class org.apache.hadoop.conf.Configuration.IntegerRanges
-
- toString() - Method in class org.apache.hadoop.conf.Configuration
-
- totalAvailable - Variable in class org.apache.flink.core.fs.AbstractMultiFSDataInputStream
-
Total available bytes in the virtual global stream.
- totalNumberOfSlots() - Method in class org.apache.flink.runtime.clusterframework.messages.GetClusterStatusResponse
-
- totalPos - Variable in class org.apache.flink.core.fs.AbstractMultiFSDataInputStream
-
Position in the virtual global stream.
- toTime(FiniteDuration) - Static method in class org.apache.flink.runtime.concurrent.FutureUtils
-
Converts FiniteDuration
into Flink time.
- toUri() - Method in class org.apache.flink.core.fs.Path
-
Converts the path object to a
URI
.
- toUUID() - Method in class org.apache.flink.runtime.dispatcher.DispatcherId
-
- toUUID() - Method in class org.apache.flink.runtime.jobmaster.JobMasterId
-
Creates a UUID with the bits from this JobMasterId.
- toUUID() - Method in class org.apache.flink.runtime.resourcemanager.ResourceManagerId
-
Creates a UUID with the bits from this ResourceManagerId.
- TPCHQuery10 - Class in org.apache.flink.examples.java.relational
-
This program implements a modified version of the TPC-H query 10.
- TPCHQuery10() - Constructor for class org.apache.flink.examples.java.relational.TPCHQuery10
-
- TPCHQuery10 - Class in org.apache.flink.examples.java8.relational
-
This program implements a modified version of the TPC-H query 10.
- TPCHQuery10() - Constructor for class org.apache.flink.examples.java8.relational.TPCHQuery10
-
- TPCHQuery3 - Class in org.apache.flink.examples.java.relational
-
This program implements a modified version of the TPC-H query 3.
- TPCHQuery3() - Constructor for class org.apache.flink.examples.java.relational.TPCHQuery3
-
- TPCHQuery3.Customer - Class in org.apache.flink.examples.java.relational
-
Customer.
- TPCHQuery3.Lineitem - Class in org.apache.flink.examples.java.relational
-
Lineitem.
- TPCHQuery3.Order - Class in org.apache.flink.examples.java.relational
-
Order.
- TransactionalIdsGenerator - Class in org.apache.flink.streaming.connectors.kafka.internal
-
Class responsible for generating transactional ids to use when communicating with Kafka.
- TransactionalIdsGenerator(String, int, int, int, int) - Constructor for class org.apache.flink.streaming.connectors.kafka.internal.TransactionalIdsGenerator
-
- TransactionHolder(TXN, long) - Constructor for class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.TransactionHolder
-
- TransactionStateSerializer() - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer011.TransactionStateSerializer
-
- Transform<II,IO,RI,RO> - Interface in org.apache.flink.graph.drivers.transform
-
A transform is executed both before and after algorithm execution.
- transform(N, T, StateTransformationFunction<S, T>) - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateTable
-
- transform(N, T, StateTransformationFunction<S, T>) - Method in class org.apache.flink.runtime.state.heap.NestedMapsStateTable
-
- transform(N, T, StateTransformationFunction<S, T>) - Method in class org.apache.flink.runtime.state.heap.StateTable
-
- transform(String, TypeInformation<R>, TwoInputStreamOperator<IN1, IN2, R>) - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
-
- transform(String, TypeInformation<R>, OneInputStreamOperator<T, R>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Method for passing user defined operators along with the type
information that will transform the DataStream.
- transform(String, TypeInformation<R>, OneInputStreamOperator<T, R>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
- Transformable - Interface in org.apache.flink.graph.drivers.transform
-
A transformable input or algorithm returns a list of
Transform
to be
applied before and after execution of the algorithm.
- transformation - Variable in class org.apache.flink.streaming.api.datastream.DataStream
-
- transformations - Variable in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
- transformInput(Graph<LongValue, VV, EV>) - Method in class org.apache.flink.graph.drivers.transform.GraphKeyTypeTransform
-
- transformInput(II) - Method in interface org.apache.flink.graph.drivers.transform.Transform
-
Apply the forward transformation to the input graph.
- transformResult(DataSet<TranslatableResult<?>>) - Method in class org.apache.flink.graph.drivers.transform.GraphKeyTypeTransform
-
- transformResult(RI) - Method in interface org.apache.flink.graph.drivers.transform.Transform
-
Apply the reverse transformation to the algorithm result.
- TransientBlobCache - Class in org.apache.flink.runtime.blob
-
Provides access to transient BLOB files stored at the
BlobServer
.
- TransientBlobCache(Configuration, InetSocketAddress) - Constructor for class org.apache.flink.runtime.blob.TransientBlobCache
-
Instantiates a new BLOB cache.
- TransientBlobKey - Class in org.apache.flink.runtime.blob
-
BLOB key referencing transient BLOB files.
- TransientBlobKey() - Constructor for class org.apache.flink.runtime.blob.TransientBlobKey
-
Constructs a new BLOB key.
- TransientBlobService - Interface in org.apache.flink.runtime.blob
-
A service to retrieve transient binary large objects (BLOBs) which are deleted on the
BlobServer
when they are retrieved.
- transition(EventType) - Method in enum org.apache.flink.streaming.examples.statemachine.dfa.State
-
Gets the state after transitioning from this state based on the given event.
- Transition - Class in org.apache.flink.streaming.examples.statemachine.dfa
-
A possible transition on a given event into a target state.
- Transition(EventType, State, float) - Constructor for class org.apache.flink.streaming.examples.statemachine.dfa.Transition
-
Creates a new transition.
- transition() - Method in class org.apache.flink.streaming.examples.statemachine.event.Alert
-
- TransitiveClosureData - Class in org.apache.flink.test.testdata
-
Test data for TransitiveClosure programs.
- TransitiveClosureNaive - Class in org.apache.flink.examples.java.graph
-
The transitive closure of a graph contains an edge for each pair of vertices
which are endpoints of at least one path in the graph.
- TransitiveClosureNaive() - Constructor for class org.apache.flink.examples.java.graph.TransitiveClosureNaive
-
- TranslatableResult<K> - Interface in org.apache.flink.graph.asm.result
-
A transformable result can transform its ID type.
- translate(TranslateFunction<K, T>, TranslatableResult<T>, Collector<TranslatableResult<T>>) - Method in class org.apache.flink.graph.asm.result.BinaryResultBase
-
- translate(TranslateFunction<K, T>, TranslatableResult<T>, Collector<TranslatableResult<T>>) - Method in class org.apache.flink.graph.asm.result.TertiaryResultBase
-
- translate(TranslateFunction<K, T>, TranslatableResult<T>, Collector<TranslatableResult<T>>) - Method in interface org.apache.flink.graph.asm.result.TranslatableResult
-
Output the result after transforming the vertex ID type.
- translate(TranslateFunction<K, T>, TranslatableResult<T>, Collector<TranslatableResult<T>>) - Method in class org.apache.flink.graph.asm.result.UnaryResultBase
-
- translate(IN, OUT) - Method in class org.apache.flink.graph.asm.translate.RichTranslateFunction
-
- Translate - Class in org.apache.flink.graph.asm.translate
-
Methods for translation of the type or modification of the data of graph
IDs, vertex values, and edge values.
- Translate() - Constructor for class org.apache.flink.graph.asm.translate.Translate
-
- translate(T, O) - Method in interface org.apache.flink.graph.asm.translate.TranslateFunction
-
The translating method.
- translate(Long, LongValue) - Method in class org.apache.flink.graph.asm.translate.translators.LongToLongValue
-
- translate(LongValue, LongValue) - Method in class org.apache.flink.graph.asm.translate.translators.LongValueAddOffset
-
- translate(LongValue, IntValue) - Method in class org.apache.flink.graph.asm.translate.translators.LongValueToSignedIntValue
-
- translate(LongValue, StringValue) - Method in class org.apache.flink.graph.asm.translate.translators.LongValueToStringValue
-
- translate(LongValue, IntValue) - Method in class org.apache.flink.graph.asm.translate.translators.LongValueToUnsignedIntValue
-
- translate(T, NullValue) - Method in class org.apache.flink.graph.asm.translate.translators.ToNullValue
-
- translate(I, O) - Method in class org.apache.flink.graph.utils.GraphUtils.MapTo
-
- translateEdgeIds(DataSet<Edge<OLD, EV>>, TranslateFunction<OLD, NEW>) - Static method in class org.apache.flink.graph.asm.translate.Translate
-
- translateEdgeIds(DataSet<Edge<OLD, EV>>, TranslateFunction<OLD, NEW>, int) - Static method in class org.apache.flink.graph.asm.translate.Translate
-
- translateEdgeValues(DataSet<Edge<K, OLD>>, TranslateFunction<OLD, NEW>) - Static method in class org.apache.flink.graph.asm.translate.Translate
-
- translateEdgeValues(DataSet<Edge<K, OLD>>, TranslateFunction<OLD, NEW>, int) - Static method in class org.apache.flink.graph.asm.translate.Translate
-
- TranslateEdgeValues<K,VV,OLD,NEW> - Class in org.apache.flink.graph.asm.translate
-
- TranslateEdgeValues(TranslateFunction<OLD, NEW>) - Constructor for class org.apache.flink.graph.asm.translate.TranslateEdgeValues
-
- translateEdgeValues(TranslateFunction<EV, NEW>) - Method in class org.apache.flink.graph.Graph
-
- TranslateFunction<T,O> - Interface in org.apache.flink.graph.asm.translate
-
Base interface for Translate functions.
- TranslateGraphIds<OLD,NEW,VV,EV> - Class in org.apache.flink.graph.asm.translate
-
- TranslateGraphIds(TranslateFunction<OLD, NEW>) - Constructor for class org.apache.flink.graph.asm.translate.TranslateGraphIds
-
- translateGraphIds(TranslateFunction<K, NEW>) - Method in class org.apache.flink.graph.Graph
-
- translateToDataFlow(Operator<IN>) - Method in class org.apache.flink.api.java.operators.AggregateOperator
-
- translateToDataFlow(Operator<I1>, Operator<I2>) - Method in class org.apache.flink.api.java.operators.CoGroupOperator
-
- translateToDataFlow(Operator<I1>, Operator<I2>) - Method in class org.apache.flink.api.java.operators.CoGroupRawOperator
-
- translateToDataFlow(Operator<I1>, Operator<I2>) - Method in class org.apache.flink.api.java.operators.CrossOperator
-
- translateToDataFlow(Operator<T>) - Method in class org.apache.flink.api.java.operators.DataSink
-
- translateToDataFlow() - Method in class org.apache.flink.api.java.operators.DataSource
-
- translateToDataFlow(Operator<T>) - Method in class org.apache.flink.api.java.operators.DistinctOperator
-
- translateToDataFlow(Operator<T>) - Method in class org.apache.flink.api.java.operators.FilterOperator
-
- translateToDataFlow(Operator<IN>) - Method in class org.apache.flink.api.java.operators.FlatMapOperator
-
- translateToDataFlow(Operator<IN>) - Method in class org.apache.flink.api.java.operators.GroupCombineOperator
-
- translateToDataFlow(Operator<IN>) - Method in class org.apache.flink.api.java.operators.GroupReduceOperator
-
- translateToDataFlow(Operator<T>) - Method in class org.apache.flink.api.java.operators.IterativeDataSet
-
- translateToDataFlow(Operator<I1>, Operator<I2>) - Method in class org.apache.flink.api.java.operators.JoinOperator.EquiJoin
-
- translateToDataFlow(Operator<IN>) - Method in class org.apache.flink.api.java.operators.MapOperator
-
- translateToDataFlow(Operator<IN>) - Method in class org.apache.flink.api.java.operators.MapPartitionOperator
-
- translateToDataFlow(Operator<T>) - Method in class org.apache.flink.api.java.operators.PartitionOperator
-
- translateToDataFlow(Operator<IN>) - Method in class org.apache.flink.api.java.operators.ProjectOperator
-
- translateToDataFlow(Operator<IN>) - Method in class org.apache.flink.api.java.operators.ReduceOperator
-
- translateToDataFlow(Operator<IN>) - Method in class org.apache.flink.api.java.operators.SingleInputOperator
-
Translates this operation to a data flow operator of the common data flow API.
- translateToDataFlow(Operator<T>) - Method in class org.apache.flink.api.java.operators.SortPartitionOperator
-
- translateToDataFlow(Operator<IN1>, Operator<IN2>) - Method in class org.apache.flink.api.java.operators.TwoInputOperator
-
Translates this java API operator into a common API operator with two inputs.
- translateToDataFlow(Operator<T>, Operator<T>) - Method in class org.apache.flink.api.java.operators.UnionOperator
-
Returns the BinaryNodeTranslation of the Union.
- translateToDataFlow(Operator<IN>) - Method in class org.apache.flink.api.scala.operators.ScalaAggregateOperator
-
- translateToPlan(List<DataSink<?>>, String) - Method in class org.apache.flink.api.java.operators.OperatorTranslation
-
- translateVertexIds(DataSet<Vertex<OLD, VV>>, TranslateFunction<OLD, NEW>) - Static method in class org.apache.flink.graph.asm.translate.Translate
-
- translateVertexIds(DataSet<Vertex<OLD, VV>>, TranslateFunction<OLD, NEW>, int) - Static method in class org.apache.flink.graph.asm.translate.Translate
-
- translateVertexValues(DataSet<Vertex<K, OLD>>, TranslateFunction<OLD, NEW>) - Static method in class org.apache.flink.graph.asm.translate.Translate
-
- translateVertexValues(DataSet<Vertex<K, OLD>>, TranslateFunction<OLD, NEW>, int) - Static method in class org.apache.flink.graph.asm.translate.Translate
-
- TranslateVertexValues<K,OLD,NEW,EV> - Class in org.apache.flink.graph.asm.translate
-
- TranslateVertexValues(TranslateFunction<OLD, NEW>) - Constructor for class org.apache.flink.graph.asm.translate.TranslateVertexValues
-
- translateVertexValues(TranslateFunction<VV, NEW>) - Method in class org.apache.flink.graph.Graph
-
- TRANSPORT_HEARTBEAT_INTERVAL - Static variable in class org.apache.flink.configuration.AkkaOptions
-
Heartbeat interval of the transport failure detector.
- TRANSPORT_HEARTBEAT_PAUSE - Static variable in class org.apache.flink.configuration.AkkaOptions
-
Allowed heartbeat pause for the transport failure detector.
- TRANSPORT_THRESHOLD - Static variable in class org.apache.flink.configuration.AkkaOptions
-
Detection threshold of transport failure detector.
- TRANSPORT_TYPE - Static variable in class org.apache.flink.runtime.io.network.netty.NettyConfig
-
- TransportException - Exception in org.apache.flink.runtime.io.network.netty.exception
-
- TransportException(String, SocketAddress) - Constructor for exception org.apache.flink.runtime.io.network.netty.exception.TransportException
-
- TransportException(String, SocketAddress, Throwable) - Constructor for exception org.apache.flink.runtime.io.network.netty.exception.TransportException
-
- TraversableOnceException - Exception in org.apache.flink.util
-
An exception, indicating that an
Iterable
can only be traversed once, but has been attempted
to traverse an additional time.
- TraversableOnceException() - Constructor for exception org.apache.flink.util.TraversableOnceException
-
Creates a new exception with a default message.
- TraversableSerializerConfigSnapshot<E> - Class in org.apache.flink.api.scala.typeutils
-
- TraversableSerializerConfigSnapshot() - Constructor for class org.apache.flink.api.scala.typeutils.TraversableSerializerConfigSnapshot
-
This empty nullary constructor is required for deserializing the configuration.
- TraversableSerializerConfigSnapshot(TypeSerializer<E>) - Constructor for class org.apache.flink.api.scala.typeutils.TraversableSerializerConfigSnapshot
-
- traverse(PlanNode) - Method in class org.apache.flink.optimizer.postpass.JavaApiPostPass
-
- traverseMaps(KeyMap<K, V>[], KeyMap.TraversalEvaluator<K, V>, long) - Static method in class org.apache.flink.streaming.runtime.operators.windowing.KeyMap
-
Performs a traversal about logical the multi-map that results from the union of the
given maps.
- traverseStreamGraphAndGenerateHashes(StreamGraph) - Method in interface org.apache.flink.streaming.api.graph.StreamGraphHasher
-
- traverseStreamGraphAndGenerateHashes(StreamGraph) - Method in class org.apache.flink.streaming.api.graph.StreamGraphHasherV2
-
- traverseStreamGraphAndGenerateHashes(StreamGraph) - Method in class org.apache.flink.streaming.api.graph.StreamGraphUserHashHasher
-
- TRG_EDGE_TO_BE_REMOVED - Static variable in class org.apache.flink.graph.examples.data.IncrementalSSSPData
-
- Triad() - Constructor for class org.apache.flink.examples.java.graph.util.EnumTrianglesDataTypes.Triad
-
- Triad() - Constructor for class org.apache.flink.graph.library.TriangleEnumerator.Triad
-
- TriadicCensus<K extends Comparable<K> & CopyableValue<K>,VV,EV> - Class in org.apache.flink.graph.library.clustering.directed
-
A triad is formed by three connected or unconnected vertices in a graph.
- TriadicCensus() - Constructor for class org.apache.flink.graph.library.clustering.directed.TriadicCensus
-
- TriadicCensus<K extends Comparable<K> & CopyableValue<K>,VV,EV> - Class in org.apache.flink.graph.library.clustering.undirected
-
A triad is formed by three connected or unconnected vertices in a graph.
- TriadicCensus() - Constructor for class org.apache.flink.graph.library.clustering.undirected.TriadicCensus
-
- TriadicCensus.Result - Class in org.apache.flink.graph.library.clustering.directed
-
Wraps triadic census metrics.
- TriadicCensus.Result - Class in org.apache.flink.graph.library.clustering.undirected
-
Wraps triadic census metrics.
- TriangleCountData - Class in org.apache.flink.graph.examples.data
-
Provides the default data sets used for the Triangle Count test program.
- TriangleEnumerator<K extends Comparable<K>,VV,EV> - Class in org.apache.flink.graph.library
-
This library method enumerates unique triangles present in the input graph.
- TriangleEnumerator() - Constructor for class org.apache.flink.graph.library.TriangleEnumerator
-
- TriangleEnumerator.EdgeWithDegrees<K> - Class in org.apache.flink.graph.library
-
POJO storing two vertex IDs with degree.
- TriangleEnumerator.Triad<K> - Class in org.apache.flink.graph.library
-
Tuple storing three vertex IDs.
- TriangleListing<K extends Comparable<K> & CopyableValue<K>,VV,EV> - Class in org.apache.flink.graph.drivers
-
Driver for directed and undirected triangle listing algorithm and analytic.
- TriangleListing() - Constructor for class org.apache.flink.graph.drivers.TriangleListing
-
- TriangleListing<K extends Comparable<K> & CopyableValue<K>,VV,EV> - Class in org.apache.flink.graph.library.clustering.directed
-
Generates a listing of distinct triangles from the input graph.
- TriangleListing() - Constructor for class org.apache.flink.graph.library.clustering.directed.TriangleListing
-
- TriangleListing<K extends Comparable<K> & CopyableValue<K>,VV,EV> - Class in org.apache.flink.graph.library.clustering.undirected
-
Generates a listing of distinct triangles from the input graph.
- TriangleListing() - Constructor for class org.apache.flink.graph.library.clustering.undirected.TriangleListing
-
- TriangleListing.Result<T> - Class in org.apache.flink.graph.library.clustering.directed
-
A result for the directed Triangle Listing algorithm.
- TriangleListing.Result<T> - Class in org.apache.flink.graph.library.clustering.undirected
-
A result for the undirected Triangle Listing algorithm.
- TriangleListingBase<K,VV,EV,R> - Class in org.apache.flink.graph.library.clustering
-
Common configuration for directed and undirected Triangle Listing algorithms.
- TriangleListingBase() - Constructor for class org.apache.flink.graph.library.clustering.TriangleListingBase
-
- TRIANGLES_BY_DEGREE - Static variable in class org.apache.flink.test.testdata.EnumTriangleData
-
- TRIANGLES_BY_ID - Static variable in class org.apache.flink.test.testdata.EnumTriangleData
-
- TriConsumer<S,T,U> - Interface in org.apache.flink.util.function
-
Operation which is performed on three given arguments.
- TriFunction<S,T,U,R> - Interface in org.apache.flink.util.function
-
Function which takes three arguments.
- trigger() - Method in class org.apache.flink.core.testutils.ManuallyTriggeredDirectExecutor
-
Triggers the next queued runnable and executes it synchronously.
- trigger() - Method in class org.apache.flink.core.testutils.MultiShotLatch
-
Fires the latch.
- trigger() - Method in class org.apache.flink.core.testutils.OneShotLatch
-
Fires the latch.
- trigger(Trigger<? super T, ? super W>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Sets the Trigger
that should be used to trigger window emission.
- trigger(Trigger<? super CoGroupedStreams.TaggedUnion<T1, T2>, ? super W>) - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.WithWindow
-
Sets the Trigger
that should be used to trigger window emission.
- trigger(Trigger<? super CoGroupedStreams.TaggedUnion<T1, T2>, ? super W>) - Method in class org.apache.flink.streaming.api.datastream.JoinedStreams.WithWindow
-
Sets the Trigger
that should be used to trigger window emission.
- trigger(Trigger<? super T, ? super W>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Sets the Trigger
that should be used to trigger window emission.
- Trigger<T,W extends Window> - Class in org.apache.flink.streaming.api.windowing.triggers
-
A Trigger
determines when a pane of a window should be evaluated to emit the
results for that part of the window.
- Trigger() - Constructor for class org.apache.flink.streaming.api.windowing.triggers.Trigger
-
- Trigger.OnMergeContext - Interface in org.apache.flink.streaming.api.windowing.triggers
-
- Trigger.TriggerContext - Interface in org.apache.flink.streaming.api.windowing.triggers
-
A context object that is given to
Trigger
methods to allow them to register timer
callbacks and deal with state.
- TRIGGER_THREAD_GROUP - Static variable in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
The thread group that holds all trigger timer threads.
- Triggerable<K,N> - Interface in org.apache.flink.streaming.api.operators
-
- triggerCheckpoint(long, boolean) - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
Triggers a new standard checkpoint and uses the given timestamp as the checkpoint
timestamp.
- triggerCheckpoint(long, CheckpointProperties, String, boolean) - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
- triggerCheckpoint(long, long, Executor) - Method in interface org.apache.flink.runtime.checkpoint.MasterTriggerRestoreHook
-
This method is called by the checkpoint coordinator prior when triggering a checkpoint, prior
to sending the "trigger checkpoint" messages to the source tasks.
- triggerCheckpoint(long, long, CheckpointOptions) - Method in class org.apache.flink.runtime.executiongraph.Execution
-
Trigger a new checkpoint on the task of this execution.
- triggerCheckpoint(CheckpointMetaData, CheckpointOptions) - Method in class org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
-
This method is called to trigger a checkpoint, asynchronously by the checkpoint
coordinator.
- triggerCheckpoint(ExecutionAttemptID, JobID, long, long, CheckpointOptions) - Method in class org.apache.flink.runtime.jobmanager.slots.ActorTaskManagerGateway
-
- triggerCheckpoint(ExecutionAttemptID, JobID, long, long, CheckpointOptions) - Method in interface org.apache.flink.runtime.jobmanager.slots.TaskManagerGateway
-
Trigger for the given task a checkpoint.
- triggerCheckpoint(ExecutionAttemptID, JobID, long, long, CheckpointOptions) - Method in class org.apache.flink.runtime.jobmaster.RpcTaskManagerGateway
-
- TriggerCheckpoint - Class in org.apache.flink.runtime.messages.checkpoint
-
This message is sent from the
JobManager
to the
TaskManager
to tell a certain task to trigger its
checkpoint.
- TriggerCheckpoint(JobID, ExecutionAttemptID, long, long, CheckpointOptions) - Constructor for class org.apache.flink.runtime.messages.checkpoint.TriggerCheckpoint
-
- triggerCheckpoint(ExecutionAttemptID, long, long, CheckpointOptions) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutor
-
- triggerCheckpoint(ExecutionAttemptID, long, long, CheckpointOptions) - Method in interface org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
-
Trigger the checkpoint for the given task.
- triggerCheckpoint(long) - Method in interface org.apache.flink.streaming.api.checkpoint.ExternallyInducedSource.CheckpointTrigger
-
Triggers a checkpoint.
- triggerCheckpoint(CheckpointMetaData, CheckpointOptions) - Method in class org.apache.flink.streaming.runtime.tasks.SourceStreamTask
-
- triggerCheckpoint(CheckpointMetaData, CheckpointOptions) - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- triggerCheckpointBarrier(long, long, CheckpointOptions) - Method in class org.apache.flink.runtime.taskmanager.Task
-
Calls the invokable to trigger a checkpoint.
- triggerCheckpointOnBarrier(CheckpointMetaData, CheckpointOptions, CheckpointMetrics) - Method in class org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
-
This method is called when a checkpoint is triggered as a result of receiving checkpoint
barriers on all input streams.
- triggerCheckpointOnBarrier(CheckpointMetaData, CheckpointOptions, CheckpointMetrics) - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
- triggerCheckWorkers() - Method in class org.apache.flink.runtime.clusterframework.FlinkResourceManager
-
This method causes the resource framework master to asynchronouslyre-examine
the set of available and pending workers containers, and release or allocate
containers if needed.
- triggerConnectingToJobManager(String) - Method in class org.apache.flink.runtime.clusterframework.FlinkResourceManager
-
Causes the resource manager to announce itself at the new leader JobManager and
obtains its connection information and currently known TaskManagers.
- triggerConnectingToJobManager(String) - Method in class org.apache.flink.runtime.clusterframework.standalone.StandaloneResourceManager
-
- triggerContext - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
- triggerFullRecovery() - Method in class org.apache.flink.runtime.executiongraph.restart.ExecutionGraphRestartCallback
-
- triggerFullRecovery() - Method in interface org.apache.flink.runtime.executiongraph.restart.RestartCallback
-
Triggers a full recovery in the target ExecutionGraph.
- TriggerHandler(CompletableFuture<String>, GatewayRetriever<? extends T>, Time, Map<String, String>, MessageHeaders<B, TriggerResponse, M>) - Constructor for class org.apache.flink.runtime.rest.handler.async.AbstractAsynchronousOperationHandlers.TriggerHandler
-
- TriggerId - Class in org.apache.flink.runtime.rest.messages
-
Identifies a savepoint trigger request.
- TriggerId() - Constructor for class org.apache.flink.runtime.rest.messages.TriggerId
-
- TriggerId.TriggerIdDeserializer - Class in org.apache.flink.runtime.rest.messages
-
- TriggerId.TriggerIdSerializer - Class in org.apache.flink.runtime.rest.messages
-
- TriggerIdDeserializer() - Constructor for class org.apache.flink.runtime.rest.messages.TriggerId.TriggerIdDeserializer
-
- triggerIdPathParameter - Variable in class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingStatusMessageParameters
-
- triggerIdPathParameter - Variable in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalStatusMessageParameters
-
- triggerIdPathParameter - Variable in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointStatusMessageParameters
-
- TriggerIdPathParameter - Class in org.apache.flink.runtime.rest.messages
-
- TriggerIdPathParameter() - Constructor for class org.apache.flink.runtime.rest.messages.TriggerIdPathParameter
-
- TriggerIdSerializer() - Constructor for class org.apache.flink.runtime.rest.messages.TriggerId.TriggerIdSerializer
-
- triggerMasterHooks(Collection<MasterTriggerRestoreHook<?>>, long, long, Executor, Time) - Static method in class org.apache.flink.runtime.checkpoint.hooks.MasterHooks
-
Triggers all given master hooks and returns state objects for each hook that
produced a state.
- triggerNextSuperstep() - Method in class org.apache.flink.runtime.iterative.concurrent.SuperstepKickoffLatch
-
- triggerOperation(HandlerRequest<B, M>, T) - Method in class org.apache.flink.runtime.rest.handler.async.AbstractAsynchronousOperationHandlers.TriggerHandler
-
Trigger the asynchronous operation and return its future result.
- triggerOperation(HandlerRequest<EmptyRequestBody, RescalingTriggerMessageParameters>, RestfulGateway) - Method in class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingHandlers.RescalingTriggerHandler
-
- triggerOperation(HandlerRequest<SavepointDisposalRequest, EmptyMessageParameters>, RestfulGateway) - Method in class org.apache.flink.runtime.rest.handler.job.savepoints.SavepointDisposalHandlers.SavepointDisposalTriggerHandler
-
- triggerOperation(HandlerRequest<SavepointTriggerRequestBody, SavepointTriggerMessageParameters>, RestfulGateway) - Method in class org.apache.flink.runtime.rest.handler.job.savepoints.SavepointHandlers.SavepointTriggerHandler
-
- triggerPartitionProducerStateCheck(JobID, IntermediateDataSetID, ResultPartitionID) - Method in class org.apache.flink.runtime.taskmanager.Task
-
- triggerPartitionProducerStateCheck(JobID, IntermediateDataSetID, ResultPartitionID) - Method in interface org.apache.flink.runtime.taskmanager.TaskActions
-
Check the execution state of the execution producing a result partition.
- TriggerRegistrationAtJobManager - Class in org.apache.flink.runtime.clusterframework.messages
-
Causes the resource manager to try and apply at the leader JobManager.
- TriggerRegistrationAtJobManager(ActorRef) - Constructor for class org.apache.flink.runtime.clusterframework.messages.TriggerRegistrationAtJobManager
-
- TriggerRegistrationAtJobManager(String) - Constructor for class org.apache.flink.runtime.clusterframework.messages.TriggerRegistrationAtJobManager
-
- TriggerResponse - Class in org.apache.flink.runtime.rest.handler.async
-
Response to the triggering of an asynchronous operation.
- TriggerResponse(TriggerId) - Constructor for class org.apache.flink.runtime.rest.handler.async.TriggerResponse
-
- TriggerResult - Enum in org.apache.flink.streaming.api.windowing.triggers
-
Result type for trigger methods.
- triggerSavepoint(JobID, String) - Method in class org.apache.flink.client.program.ClusterClient
-
Triggers a savepoint for the job identified by the job id.
- triggerSavepoint(JobID, String) - Method in class org.apache.flink.client.program.MiniClusterClient
-
- triggerSavepoint(JobID, String) - Method in class org.apache.flink.client.program.rest.RestClusterClient
-
- triggerSavepoint(long, String) - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
Triggers a savepoint with the given savepoint directory as a target.
- triggerSavepoint(JobID, String, boolean, Time) - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
-
- triggerSavepoint(String, boolean, Time) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
-
- triggerSavepoint(String, boolean, Time) - Method in interface org.apache.flink.runtime.jobmaster.JobMasterGateway
-
Triggers taking a savepoint of the executed job.
- triggerSavepoint(JobID, String, boolean) - Method in class org.apache.flink.runtime.minicluster.MiniCluster
-
- triggerSavepoint(JobID, String, boolean, Time) - Method in interface org.apache.flink.runtime.webmonitor.RestfulGateway
-
Triggers a savepoint with the given savepoint directory as a target.
- triggerStackTraceSample(ExecutionJobVertex) - Method in class org.apache.flink.runtime.rest.handler.legacy.backpressure.BackPressureStatsTrackerImpl
-
- triggerStackTraceSample(ExecutionVertex[], int, Time, int) - Method in class org.apache.flink.runtime.rest.handler.legacy.backpressure.StackTraceSampleCoordinator
-
Triggers a stack trace sample to all tasks.
- Triplet<K,VV,EV> - Class in org.apache.flink.graph
-
A Triplet stores and retrieves the edges along with their corresponding source and target vertices.
- Triplet() - Constructor for class org.apache.flink.graph.Triplet
-
- Triplet(Vertex<K, VV>, Vertex<K, VV>, Edge<K, EV>) - Constructor for class org.apache.flink.graph.Triplet
-
Constructs a Triplet from a given source vertex, target vertex, and edge.
- Triplet(K, K, VV, VV, EV) - Constructor for class org.apache.flink.graph.Triplet
-
Constructs a Triplet from its src vertex id, src target id, src vertex value,
src target value and edge value respectively.
- TRUE - Static variable in class org.apache.flink.types.BooleanValue
-
- trueFunction() - Static method in class org.apache.flink.cep.pattern.conditions.BooleanConditions
-
- tryAdd(AbstractCheckpointStats) - Method in class org.apache.flink.runtime.rest.handler.job.checkpoints.CheckpointStatsCache
-
Try to add the checkpoint to the cache.
- tryAssignPayload(LogicalSlot.Payload) - Method in class org.apache.flink.runtime.instance.SharedSlot
-
- tryAssignPayload(LogicalSlot.Payload) - Method in class org.apache.flink.runtime.instance.SimpleSlot
-
Atomically sets the executed vertex, if no vertex has been assigned to this slot so far.
- tryAssignPayload(LogicalSlot.Payload) - Method in interface org.apache.flink.runtime.jobmaster.LogicalSlot
-
Tries to assign a payload to this slot.
- tryAssignPayload(LogicalSlot.Payload) - Method in class org.apache.flink.runtime.jobmaster.slotpool.SingleLogicalSlot
-
- tryCleanupOnError() - Method in interface org.apache.flink.api.common.io.CleanupWhenUnsuccessful
-
Hook that is called upon an unsuccessful execution.
- tryCleanupOnError() - Method in class org.apache.flink.api.common.io.FileOutputFormat
-
- tryDeserializeAndThrow(Throwable, ClassLoader) - Static method in class org.apache.flink.util.ExceptionUtils
-
Tries to find a
SerializedThrowable
as the cause of the given throwable and throws its
deserialized value.
- tryGet(long) - Method in class org.apache.flink.runtime.rest.handler.job.checkpoints.CheckpointStatsCache
-
Try to look up a checkpoint by it's ID in the cache.
- tryHandleCheckpointException(CheckpointMetaData, Exception) - Method in interface org.apache.flink.streaming.runtime.tasks.CheckpointExceptionHandler
-
Offers the exception for handling.
- tryLoadWebContent(GatewayRetriever<? extends T>, CompletableFuture<String>, Time, File) - Static method in class org.apache.flink.runtime.webmonitor.WebMonitorUtils
-
Checks whether the flink-runtime-web dependency is available and if so returns a
StaticFileServerHandler which can serve the static file contents.
- tryMarkSlotActive(JobID, AllocationID) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
-
Try to mark the specified slot as active if it has been allocated by the given job.
- tryPut(StreamElementQueueEntry<T>) - Method in class org.apache.flink.streaming.api.operators.async.queue.OrderedStreamElementQueue
-
- tryPut(StreamElementQueueEntry<T>) - Method in interface org.apache.flink.streaming.api.operators.async.queue.StreamElementQueue
-
Try to put the given element in the queue.
- tryPut(StreamElementQueueEntry<T>) - Method in class org.apache.flink.streaming.api.operators.async.queue.UnorderedStreamElementQueue
-
- tryReadSerializer(DataInputView, ClassLoader) - Static method in class org.apache.flink.api.common.typeutils.TypeSerializerSerializationUtil
-
- tryReadSerializer(DataInputView, ClassLoader, boolean) - Static method in class org.apache.flink.api.common.typeutils.TypeSerializerSerializationUtil
-
- tryReconnect() - Method in class org.apache.flink.runtime.registration.RegisteredRpcConnection
-
- tryRethrowIOException(Throwable) - Static method in class org.apache.flink.util.ExceptionUtils
-
Tries to throw the given Throwable
in scenarios where the signatures allows only IOExceptions
(and RuntimeException and Error).
- trySetCount(ZooKeeperVersionedValue<Integer>, int) - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperSharedCount
-
- trySync(long) - Method in class org.apache.flink.core.testutils.CheckedThread
-
Waits with timeout until the thread is completed and checks whether any error
occurred during the execution.
- TumblingEventTimeWindows - Class in org.apache.flink.streaming.api.windowing.assigners
-
A
WindowAssigner
that windows elements into windows based on the timestamp of the
elements.
- TumblingEventTimeWindows(long, long) - Constructor for class org.apache.flink.streaming.api.windowing.assigners.TumblingEventTimeWindows
-
- TumblingProcessingTimeWindows - Class in org.apache.flink.streaming.api.windowing.assigners
-
A
WindowAssigner
that windows elements into windows based on the current
system time of the machine the operation is running on.
- TumblingTimeWindows - Class in org.apache.flink.streaming.api.windowing.assigners
-
- TUPLE(TypeInformation<?>...) - Static method in class 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>) - Static method in class org.apache.flink.api.common.typeinfo.Types
-
Returns type information for typed subclasses of Flink's
Tuple
.
- Tuple - Class in org.apache.flink.api.java.tuple
-
The base class of all tuples.
- Tuple() - Constructor for class org.apache.flink.api.java.tuple.Tuple
-
- Tuple0 - Class in org.apache.flink.api.java.tuple
-
A tuple with 0 fields.
- Tuple0() - Constructor for class org.apache.flink.api.java.tuple.Tuple0
-
- Tuple0Builder - Class in org.apache.flink.api.java.tuple.builder
-
- Tuple0Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple0Builder
-
- Tuple0Serializer - Class in org.apache.flink.api.java.typeutils.runtime
-
- Tuple1<T0> - Class in org.apache.flink.api.java.tuple
-
A tuple with 1 fields.
- Tuple1() - Constructor for class org.apache.flink.api.java.tuple.Tuple1
-
Creates a new tuple where all fields are null.
- Tuple1(T0) - Constructor for class org.apache.flink.api.java.tuple.Tuple1
-
Creates a new tuple and assigns the given values to the tuple's fields.
- Tuple10<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9> - Class in org.apache.flink.api.java.tuple
-
A tuple with 10 fields.
- Tuple10() - Constructor for class org.apache.flink.api.java.tuple.Tuple10
-
Creates a new tuple where all fields are null.
- Tuple10(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9) - Constructor for class org.apache.flink.api.java.tuple.Tuple10
-
Creates a new tuple and assigns the given values to the tuple's fields.
- Tuple10Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9> - Class in org.apache.flink.api.java.tuple.builder
-
- Tuple10Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple10Builder
-
- Tuple11<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10> - Class in org.apache.flink.api.java.tuple
-
A tuple with 11 fields.
- Tuple11() - Constructor for class org.apache.flink.api.java.tuple.Tuple11
-
Creates a new tuple where all fields are null.
- Tuple11(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10) - Constructor for class org.apache.flink.api.java.tuple.Tuple11
-
Creates a new tuple and assigns the given values to the tuple's fields.
- Tuple11Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10> - Class in org.apache.flink.api.java.tuple.builder
-
- Tuple11Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple11Builder
-
- Tuple12<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11> - Class in org.apache.flink.api.java.tuple
-
A tuple with 12 fields.
- Tuple12() - Constructor for class org.apache.flink.api.java.tuple.Tuple12
-
Creates a new tuple where all fields are null.
- Tuple12(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11) - Constructor for class org.apache.flink.api.java.tuple.Tuple12
-
Creates a new tuple and assigns the given values to the tuple's fields.
- Tuple12Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11> - Class in org.apache.flink.api.java.tuple.builder
-
- Tuple12Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple12Builder
-
- Tuple13<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12> - Class in org.apache.flink.api.java.tuple
-
A tuple with 13 fields.
- Tuple13() - Constructor for class org.apache.flink.api.java.tuple.Tuple13
-
Creates a new tuple where all fields are null.
- Tuple13(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12) - Constructor for class org.apache.flink.api.java.tuple.Tuple13
-
Creates a new tuple and assigns the given values to the tuple's fields.
- Tuple13Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12> - Class in org.apache.flink.api.java.tuple.builder
-
- Tuple13Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple13Builder
-
- Tuple14<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13> - Class in org.apache.flink.api.java.tuple
-
A tuple with 14 fields.
- Tuple14() - Constructor for class org.apache.flink.api.java.tuple.Tuple14
-
Creates a new tuple where all fields are null.
- Tuple14(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13) - Constructor for class org.apache.flink.api.java.tuple.Tuple14
-
Creates a new tuple and assigns the given values to the tuple's fields.
- Tuple14Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13> - Class in org.apache.flink.api.java.tuple.builder
-
- Tuple14Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple14Builder
-
- Tuple15<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14> - Class in org.apache.flink.api.java.tuple
-
A tuple with 15 fields.
- Tuple15() - Constructor for class org.apache.flink.api.java.tuple.Tuple15
-
Creates a new tuple where all fields are null.
- Tuple15(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14) - Constructor for class org.apache.flink.api.java.tuple.Tuple15
-
Creates a new tuple and assigns the given values to the tuple's fields.
- Tuple15Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14> - Class in org.apache.flink.api.java.tuple.builder
-
- Tuple15Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple15Builder
-
- Tuple16<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15> - Class in org.apache.flink.api.java.tuple
-
A tuple with 16 fields.
- Tuple16() - Constructor for class org.apache.flink.api.java.tuple.Tuple16
-
Creates a new tuple where all fields are null.
- Tuple16(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15) - Constructor for class org.apache.flink.api.java.tuple.Tuple16
-
Creates a new tuple and assigns the given values to the tuple's fields.
- Tuple16Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15> - Class in org.apache.flink.api.java.tuple.builder
-
- Tuple16Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple16Builder
-
- Tuple17<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16> - Class in org.apache.flink.api.java.tuple
-
A tuple with 17 fields.
- Tuple17() - Constructor for class org.apache.flink.api.java.tuple.Tuple17
-
Creates a new tuple where all fields are null.
- Tuple17(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16) - Constructor for class org.apache.flink.api.java.tuple.Tuple17
-
Creates a new tuple and assigns the given values to the tuple's fields.
- Tuple17Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16> - Class in org.apache.flink.api.java.tuple.builder
-
- Tuple17Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple17Builder
-
- Tuple18<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17> - Class in org.apache.flink.api.java.tuple
-
A tuple with 18 fields.
- Tuple18() - Constructor for class org.apache.flink.api.java.tuple.Tuple18
-
Creates a new tuple where all fields are null.
- Tuple18(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17) - Constructor for class org.apache.flink.api.java.tuple.Tuple18
-
Creates a new tuple and assigns the given values to the tuple's fields.
- Tuple18Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17> - Class in org.apache.flink.api.java.tuple.builder
-
- Tuple18Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple18Builder
-
- Tuple19<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18> - Class in org.apache.flink.api.java.tuple
-
A tuple with 19 fields.
- Tuple19() - Constructor for class org.apache.flink.api.java.tuple.Tuple19
-
Creates a new tuple where all fields are null.
- Tuple19(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18) - Constructor for class org.apache.flink.api.java.tuple.Tuple19
-
Creates a new tuple and assigns the given values to the tuple's fields.
- Tuple19Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18> - Class in org.apache.flink.api.java.tuple.builder
-
- Tuple19Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple19Builder
-
- Tuple1Builder<T0> - Class in org.apache.flink.api.java.tuple.builder
-
- Tuple1Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple1Builder
-
- Tuple2<T0,T1> - Class in org.apache.flink.api.java.tuple
-
A tuple with 2 fields.
- Tuple2() - Constructor for class org.apache.flink.api.java.tuple.Tuple2
-
Creates a new tuple where all fields are null.
- Tuple2(T0, T1) - Constructor for class org.apache.flink.api.java.tuple.Tuple2
-
Creates a new tuple and assigns the given values to the tuple's fields.
- Tuple20<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19> - Class in org.apache.flink.api.java.tuple
-
A tuple with 20 fields.
- Tuple20() - Constructor for class org.apache.flink.api.java.tuple.Tuple20
-
Creates a new tuple where all fields are null.
- Tuple20(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19) - Constructor for class org.apache.flink.api.java.tuple.Tuple20
-
Creates a new tuple and assigns the given values to the tuple's fields.
- Tuple20Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19> - Class in org.apache.flink.api.java.tuple.builder
-
- Tuple20Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple20Builder
-
- Tuple21<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20> - Class in org.apache.flink.api.java.tuple
-
A tuple with 21 fields.
- Tuple21() - Constructor for class org.apache.flink.api.java.tuple.Tuple21
-
Creates a new tuple where all fields are null.
- Tuple21(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20) - Constructor for class org.apache.flink.api.java.tuple.Tuple21
-
Creates a new tuple and assigns the given values to the tuple's fields.
- Tuple21Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20> - Class in org.apache.flink.api.java.tuple.builder
-
- Tuple21Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple21Builder
-
- Tuple22<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20,T21> - Class in org.apache.flink.api.java.tuple
-
A tuple with 22 fields.
- Tuple22() - Constructor for class org.apache.flink.api.java.tuple.Tuple22
-
Creates a new tuple where all fields are null.
- Tuple22(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, T21) - Constructor for class org.apache.flink.api.java.tuple.Tuple22
-
Creates a new tuple and assigns the given values to the tuple's fields.
- Tuple22Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20,T21> - Class in org.apache.flink.api.java.tuple.builder
-
- Tuple22Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple22Builder
-
- Tuple23<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20,T21,T22> - Class in org.apache.flink.api.java.tuple
-
A tuple with 23 fields.
- Tuple23() - Constructor for class org.apache.flink.api.java.tuple.Tuple23
-
Creates a new tuple where all fields are null.
- Tuple23(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, T21, T22) - Constructor for class org.apache.flink.api.java.tuple.Tuple23
-
Creates a new tuple and assigns the given values to the tuple's fields.
- Tuple23Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20,T21,T22> - Class in org.apache.flink.api.java.tuple.builder
-
- Tuple23Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple23Builder
-
- Tuple24<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20,T21,T22,T23> - Class in org.apache.flink.api.java.tuple
-
A tuple with 24 fields.
- Tuple24() - Constructor for class org.apache.flink.api.java.tuple.Tuple24
-
Creates a new tuple where all fields are null.
- Tuple24(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, T21, T22, T23) - Constructor for class org.apache.flink.api.java.tuple.Tuple24
-
Creates a new tuple and assigns the given values to the tuple's fields.
- Tuple24Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20,T21,T22,T23> - Class in org.apache.flink.api.java.tuple.builder
-
- Tuple24Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple24Builder
-
- Tuple25<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20,T21,T22,T23,T24> - Class in org.apache.flink.api.java.tuple
-
A tuple with 25 fields.
- Tuple25() - Constructor for class org.apache.flink.api.java.tuple.Tuple25
-
Creates a new tuple where all fields are null.
- Tuple25(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, T21, T22, T23, T24) - Constructor for class org.apache.flink.api.java.tuple.Tuple25
-
Creates a new tuple and assigns the given values to the tuple's fields.
- Tuple25Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20,T21,T22,T23,T24> - Class in org.apache.flink.api.java.tuple.builder
-
- Tuple25Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple25Builder
-
- Tuple2Builder<T0,T1> - Class in org.apache.flink.api.java.tuple.builder
-
- Tuple2Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple2Builder
-
- Tuple2ToEdgeMap<K> - Class in org.apache.flink.graph.utils
-
Create an Edge from a Tuple2.
- Tuple2ToEdgeMap() - Constructor for class org.apache.flink.graph.utils.Tuple2ToEdgeMap
-
- Tuple2ToVertexMap<K,VV> - Class in org.apache.flink.graph.utils
-
Create a Vertex DataSet from a Tuple2 DataSet.
- Tuple2ToVertexMap() - Constructor for class org.apache.flink.graph.utils.Tuple2ToVertexMap
-
- Tuple3<T0,T1,T2> - Class in org.apache.flink.api.java.tuple
-
A tuple with 3 fields.
- Tuple3() - Constructor for class org.apache.flink.api.java.tuple.Tuple3
-
Creates a new tuple where all fields are null.
- Tuple3(T0, T1, T2) - Constructor for class org.apache.flink.api.java.tuple.Tuple3
-
Creates a new tuple and assigns the given values to the tuple's fields.
- Tuple3Builder<T0,T1,T2> - Class in org.apache.flink.api.java.tuple.builder
-
- Tuple3Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple3Builder
-
- Tuple3ToEdgeMap<K,EV> - Class in org.apache.flink.graph.utils
-
Create an Edge DataSet from a Tuple3 DataSet.
- Tuple3ToEdgeMap() - Constructor for class org.apache.flink.graph.utils.Tuple3ToEdgeMap
-
- Tuple3UnwrappingIterator<T,K1,K2> - Class in org.apache.flink.api.java.operators.translation
-
An iterator that reads 3-tuples (groupKey, sortKey, value) and returns only the values (third field).
- Tuple3UnwrappingIterator() - Constructor for class org.apache.flink.api.java.operators.translation.Tuple3UnwrappingIterator
-
- Tuple3WrappingCollector<IN,K1,K2> - Class in org.apache.flink.api.java.operators.translation
-
Needed to wrap tuples to Tuple3<groupKey, sortKey, value>
for combine method of group reduce with key selector sorting.
- Tuple3WrappingCollector(Tuple3UnwrappingIterator<IN, K1, K2>) - Constructor for class org.apache.flink.api.java.operators.translation.Tuple3WrappingCollector
-
- Tuple4<T0,T1,T2,T3> - Class in org.apache.flink.api.java.tuple
-
A tuple with 4 fields.
- Tuple4() - Constructor for class org.apache.flink.api.java.tuple.Tuple4
-
Creates a new tuple where all fields are null.
- Tuple4(T0, T1, T2, T3) - Constructor for class org.apache.flink.api.java.tuple.Tuple4
-
Creates a new tuple and assigns the given values to the tuple's fields.
- Tuple4Builder<T0,T1,T2,T3> - Class in org.apache.flink.api.java.tuple.builder
-
- Tuple4Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple4Builder
-
- Tuple5<T0,T1,T2,T3,T4> - Class in org.apache.flink.api.java.tuple
-
A tuple with 5 fields.
- Tuple5() - Constructor for class org.apache.flink.api.java.tuple.Tuple5
-
Creates a new tuple where all fields are null.
- Tuple5(T0, T1, T2, T3, T4) - Constructor for class org.apache.flink.api.java.tuple.Tuple5
-
Creates a new tuple and assigns the given values to the tuple's fields.
- Tuple5Builder<T0,T1,T2,T3,T4> - Class in org.apache.flink.api.java.tuple.builder
-
- Tuple5Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple5Builder
-
- Tuple6<T0,T1,T2,T3,T4,T5> - Class in org.apache.flink.api.java.tuple
-
A tuple with 6 fields.
- Tuple6() - Constructor for class org.apache.flink.api.java.tuple.Tuple6
-
Creates a new tuple where all fields are null.
- Tuple6(T0, T1, T2, T3, T4, T5) - Constructor for class org.apache.flink.api.java.tuple.Tuple6
-
Creates a new tuple and assigns the given values to the tuple's fields.
- Tuple6Builder<T0,T1,T2,T3,T4,T5> - Class in org.apache.flink.api.java.tuple.builder
-
- Tuple6Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple6Builder
-
- Tuple7<T0,T1,T2,T3,T4,T5,T6> - Class in org.apache.flink.api.java.tuple
-
A tuple with 7 fields.
- Tuple7() - Constructor for class org.apache.flink.api.java.tuple.Tuple7
-
Creates a new tuple where all fields are null.
- Tuple7(T0, T1, T2, T3, T4, T5, T6) - Constructor for class org.apache.flink.api.java.tuple.Tuple7
-
Creates a new tuple and assigns the given values to the tuple's fields.
- Tuple7Builder<T0,T1,T2,T3,T4,T5,T6> - Class in org.apache.flink.api.java.tuple.builder
-
- Tuple7Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple7Builder
-
- Tuple8<T0,T1,T2,T3,T4,T5,T6,T7> - Class in org.apache.flink.api.java.tuple
-
A tuple with 8 fields.
- Tuple8() - Constructor for class org.apache.flink.api.java.tuple.Tuple8
-
Creates a new tuple where all fields are null.
- Tuple8(T0, T1, T2, T3, T4, T5, T6, T7) - Constructor for class org.apache.flink.api.java.tuple.Tuple8
-
Creates a new tuple and assigns the given values to the tuple's fields.
- Tuple8Builder<T0,T1,T2,T3,T4,T5,T6,T7> - Class in org.apache.flink.api.java.tuple.builder
-
- Tuple8Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple8Builder
-
- Tuple9<T0,T1,T2,T3,T4,T5,T6,T7,T8> - Class in org.apache.flink.api.java.tuple
-
A tuple with 9 fields.
- Tuple9() - Constructor for class org.apache.flink.api.java.tuple.Tuple9
-
Creates a new tuple where all fields are null.
- Tuple9(T0, T1, T2, T3, T4, T5, T6, T7, T8) - Constructor for class org.apache.flink.api.java.tuple.Tuple9
-
Creates a new tuple and assigns the given values to the tuple's fields.
- Tuple9Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8> - Class in org.apache.flink.api.java.tuple.builder
-
- Tuple9Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple9Builder
-
- tupleClass - Variable in class org.apache.flink.api.java.typeutils.runtime.TupleSerializerBase
-
- TupleComparator<T extends Tuple> - Class in org.apache.flink.api.java.typeutils.runtime
-
- TupleComparator(int[], TypeComparator<?>[], TypeSerializer<?>[]) - Constructor for class org.apache.flink.api.java.typeutils.runtime.TupleComparator
-
- TupleComparator() - Constructor for class org.apache.flink.test.util.TestBaseUtils.TupleComparator
-
- TupleComparatorBase<T> - Class in org.apache.flink.api.java.typeutils.runtime
-
- TupleComparatorBase(int[], TypeComparator<?>[], TypeSerializer<?>[]) - Constructor for class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
-
- TupleComparatorBase(TupleComparatorBase<T>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
-
- TupleCsvInputFormat<OUT> - Class in org.apache.flink.api.java.io
-
Input format that reads csv into tuples.
- TupleCsvInputFormat(Path, TupleTypeInfoBase<OUT>) - Constructor for class org.apache.flink.api.java.io.TupleCsvInputFormat
-
- TupleCsvInputFormat(Path, String, String, TupleTypeInfoBase<OUT>) - Constructor for class org.apache.flink.api.java.io.TupleCsvInputFormat
-
- TupleCsvInputFormat(Path, TupleTypeInfoBase<OUT>, int[]) - Constructor for class org.apache.flink.api.java.io.TupleCsvInputFormat
-
- TupleCsvInputFormat(Path, String, String, TupleTypeInfoBase<OUT>, int[]) - Constructor for class org.apache.flink.api.java.io.TupleCsvInputFormat
-
- TupleCsvInputFormat(Path, TupleTypeInfoBase<OUT>, boolean[]) - Constructor for class org.apache.flink.api.java.io.TupleCsvInputFormat
-
- TupleCsvInputFormat(Path, String, String, TupleTypeInfoBase<OUT>, boolean[]) - Constructor for class org.apache.flink.api.java.io.TupleCsvInputFormat
-
- TupleEdgeConverter() - Constructor for class org.apache.flink.examples.java.graph.EnumTriangles.TupleEdgeConverter
-
- TupleLeftUnwrappingJoiner<I1,I2,OUT,K> - Class in org.apache.flink.api.java.operators.translation
-
Joiner that unwraps values from the left set before applying the join operation.
- TupleLeftUnwrappingJoiner(FlatJoinFunction<I1, I2, OUT>) - Constructor for class org.apache.flink.api.java.operators.translation.TupleLeftUnwrappingJoiner
-
- tupleList - Variable in class org.apache.flink.streaming.api.functions.sink.WriteSinkFunction
-
Deprecated.
- TupleOutputFormatter - Class in org.apache.flink.storm.util
-
OutputFormatter
implementation that converts
Tuples
of arbitrary size to a string.
- TupleOutputFormatter() - Constructor for class org.apache.flink.storm.util.TupleOutputFormatter
-
- TupleRightUnwrappingJoiner<I1,I2,OUT,K> - Class in org.apache.flink.api.java.operators.translation
-
Joiner that unwraps values from the right set before applying the join operation.
- TupleRightUnwrappingJoiner(FlatJoinFunction<I1, I2, OUT>) - Constructor for class org.apache.flink.api.java.operators.translation.TupleRightUnwrappingJoiner
-
- TUPLES - Static variable in class org.apache.flink.storm.wordcount.operators.WordCountDataTuple
-
- TupleSerializer<T extends Tuple> - Class in org.apache.flink.api.java.typeutils.runtime
-
- TupleSerializer(Class<T>, TypeSerializer<?>[]) - Constructor for class org.apache.flink.api.java.typeutils.runtime.TupleSerializer
-
- TupleSerializer(Tuple) - Constructor for class org.apache.flink.python.api.streaming.util.SerializationUtils.TupleSerializer
-
- TupleSerializerBase<T> - Class in org.apache.flink.api.java.typeutils.runtime
-
- TupleSerializerBase(Class<T>, TypeSerializer<?>[]) - Constructor for class org.apache.flink.api.java.typeutils.runtime.TupleSerializerBase
-
- TupleSerializerConfigSnapshot<T> - Class in org.apache.flink.api.java.typeutils.runtime
-
Snapshot of a tuple serializer's configuration.
- TupleSerializerConfigSnapshot() - Constructor for class org.apache.flink.api.java.typeutils.runtime.TupleSerializerConfigSnapshot
-
This empty nullary constructor is required for deserializing the configuration.
- TupleSerializerConfigSnapshot(Class<T>, TypeSerializer<?>[]) - Constructor for class org.apache.flink.api.java.typeutils.runtime.TupleSerializerConfigSnapshot
-
- TupleSummaryAggregator<R extends Tuple> - Class in org.apache.flink.api.java.summarize.aggregation
-
Aggregate tuples using an array of aggregators, one for each "column" or position within the Tuple.
- TupleSummaryAggregator(Aggregator[]) - Constructor for class org.apache.flink.api.java.summarize.aggregation.TupleSummaryAggregator
-
- tupleType(Class<T>) - Method in class org.apache.flink.api.java.io.CsvReader
-
Configures the reader to read the CSV data and parse it to the given type.
- TupleTypeInfo<T extends Tuple> - Class in org.apache.flink.api.java.typeutils
-
- TupleTypeInfo(TypeInformation<?>...) - Constructor for class org.apache.flink.api.java.typeutils.TupleTypeInfo
-
- TupleTypeInfo(Class<T>, TypeInformation<?>...) - Constructor for class org.apache.flink.api.java.typeutils.TupleTypeInfo
-
- TupleTypeInfoBase<T> - Class in org.apache.flink.api.java.typeutils
-
- TupleTypeInfoBase(Class<T>, TypeInformation<?>...) - Constructor for class org.apache.flink.api.java.typeutils.TupleTypeInfoBase
-
- TupleUnwrappingIterator<T,K> - Class in org.apache.flink.api.java.operators.translation
-
An iterator that reads 2-tuples (key value pairs) and returns only the values (second field).
- TupleUnwrappingIterator() - Constructor for class org.apache.flink.api.java.operators.translation.TupleUnwrappingIterator
-
- TupleUnwrappingJoiner<I1,I2,OUT,K> - Class in org.apache.flink.api.java.operators.translation
-
Joiner that unwraps both values before applying the join operation.
- TupleUnwrappingJoiner(FlatJoinFunction<I1, I2, OUT>) - Constructor for class org.apache.flink.api.java.operators.translation.TupleUnwrappingJoiner
-
- TupleWrappingCollector<IN,K> - Class in org.apache.flink.api.java.operators.translation
-
Needed to wrap tuples to Tuple2<key, value>
pairs for combine method of group reduce with key selector function.
- TupleWrappingCollector(TupleUnwrappingIterator<IN, K>) - Constructor for class org.apache.flink.api.java.operators.translation.TupleWrappingCollector
-
- TwitterExample - Class in org.apache.flink.streaming.examples.twitter
-
Implements the "TwitterStream" program that computes a most used word
occurrence over JSON objects in a streaming fashion.
- TwitterExample() - Constructor for class org.apache.flink.streaming.examples.twitter.TwitterExample
-
- TwitterExample.SelectEnglishAndTokenizeFlatMap - Class in org.apache.flink.streaming.examples.twitter
-
Deserialize JSON from twitter source
- TwitterExampleData - Class in org.apache.flink.streaming.examples.twitter.util
-
Example data looking like tweets, but not acquired from Twitter.
- TwitterSource - Class in org.apache.flink.streaming.connectors.twitter
-
Implementation of
SourceFunction
specialized to emit tweets from
Twitter.
- TwitterSource(Properties) - Constructor for class org.apache.flink.streaming.connectors.twitter.TwitterSource
-
- TwitterSource.EndpointInitializer - Interface in org.apache.flink.streaming.connectors.twitter
-
Implementing this interface allows users of this source to set a custom endpoint.
- two(T2) - Static method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.TaggedUnion
-
- TwoInputNode - Class in org.apache.flink.optimizer.dag
-
A node in the optimizer plan that represents an operator with a two different inputs, such as Join,
Cross, CoGroup, or Union.
- TwoInputNode(DualInputOperator<?, ?, ?, ?>) - Constructor for class org.apache.flink.optimizer.dag.TwoInputNode
-
Creates a new two input node for the optimizer plan, representing the given operator.
- TwoInputOperator<IN1,IN2,OUT,O extends TwoInputOperator<IN1,IN2,OUT,O>> - Class in org.apache.flink.api.java.operators
-
Base class for operations that operates on two input data sets.
- TwoInputOperator(DataSet<IN1>, DataSet<IN2>, TypeInformation<OUT>) - Constructor for class org.apache.flink.api.java.operators.TwoInputOperator
-
- TwoInputStreamOperator<IN1,IN2,OUT> - Interface in org.apache.flink.streaming.api.operators
-
Interface for stream operators with two inputs.
- TwoInputStreamTask<IN1,IN2,OUT> - Class in org.apache.flink.streaming.runtime.tasks
-
- TwoInputStreamTask(Environment) - Constructor for class org.apache.flink.streaming.runtime.tasks.TwoInputStreamTask
-
Constructor for initialization, possibly with initial state (recovery / savepoint / etc).
- TwoInputTransformation<IN1,IN2,OUT> - Class in org.apache.flink.streaming.api.transformations
-
This Transformation represents the application of a
TwoInputStreamOperator
to two input
StreamTransformations
.
- TwoInputTransformation(StreamTransformation<IN1>, StreamTransformation<IN2>, String, TwoInputStreamOperator<IN1, IN2, OUT>, TypeInformation<OUT>, int) - Constructor for class org.apache.flink.streaming.api.transformations.TwoInputTransformation
-
Creates a new TwoInputTransformation
from the given inputs and operator.
- TwoInputUdfOperator<IN1,IN2,OUT,O extends TwoInputUdfOperator<IN1,IN2,OUT,O>> - Class in org.apache.flink.api.java.operators
-
The TwoInputUdfOperator is the base class of all binary operators that execute
user-defined functions (UDFs).
- TwoInputUdfOperator(DataSet<IN1>, DataSet<IN2>, TypeInformation<OUT>) - Constructor for class org.apache.flink.api.java.operators.TwoInputUdfOperator
-
Creates a new operators with the two given data sets as inputs.
- TwoKeyExtractingMapper<T,K1,K2> - Class in org.apache.flink.api.java.operators.translation
-
Mapper that extracts two keys of a value.
- TwoKeyExtractingMapper(KeySelector<T, K1>, KeySelector<T, K2>) - Constructor for class org.apache.flink.api.java.operators.translation.TwoKeyExtractingMapper
-
- TwoPhaseCommitSinkFunction<IN,TXN,CONTEXT> - Class in org.apache.flink.streaming.api.functions.sink
-
This is a recommended base class for all of the
SinkFunction
that intend to implement exactly-once semantic.
- TwoPhaseCommitSinkFunction(TypeSerializer<TXN>, TypeSerializer<CONTEXT>) - Constructor for class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
-
- TwoPhaseCommitSinkFunction.State<TXN,CONTEXT> - Class in org.apache.flink.streaming.api.functions.sink
-
State POJO class coupling pendingTransaction, context and pendingCommitTransactions.
- TwoPhaseCommitSinkFunction.StateSerializer<TXN,CONTEXT> - Class in org.apache.flink.streaming.api.functions.sink
-
- TwoPhaseCommitSinkFunction.StateSerializerConfigSnapshot<TXN,CONTEXT> - Class in org.apache.flink.streaming.api.functions.sink
-
- TwoPhaseCommitSinkFunction.TransactionHolder<TXN> - Class in org.apache.flink.streaming.api.functions.sink
-
Adds metadata (currently only the start time of the transaction) to the transaction object.
- type(OptionType) - Method in class org.apache.flink.api.java.utils.Option
-
Define the type of the Option.
- TYPE - Static variable in class org.apache.flink.streaming.api.graph.JSONGenerator
-
- type() - Method in class org.apache.flink.streaming.examples.statemachine.event.Event
-
Gets the event's type.
- TYPE_ARRAY - Static variable in class org.apache.flink.python.api.streaming.data.PythonSender
-
- TYPE_BOOLEAN - Static variable in class org.apache.flink.python.api.streaming.util.SerializationUtils
-
- TYPE_BYTE - Static variable in class org.apache.flink.python.api.streaming.util.SerializationUtils
-
- TYPE_BYTES - Static variable in class org.apache.flink.python.api.streaming.util.SerializationUtils
-
- TYPE_DOUBLE - Static variable in class org.apache.flink.python.api.streaming.util.SerializationUtils
-
- TYPE_FLOAT - Static variable in class org.apache.flink.python.api.streaming.util.SerializationUtils
-
- TYPE_INTEGER - Static variable in class org.apache.flink.python.api.streaming.util.SerializationUtils
-
- TYPE_KEY_VALUE - Static variable in class org.apache.flink.python.api.streaming.data.PythonSender
-
- TYPE_LONG - Static variable in class org.apache.flink.python.api.streaming.util.SerializationUtils
-
- TYPE_NULL - Static variable in class org.apache.flink.python.api.streaming.util.SerializationUtils
-
- TYPE_STRING - Static variable in class org.apache.flink.python.api.streaming.util.SerializationUtils
-
- TYPE_VALUE_VALUE - Static variable in class org.apache.flink.python.api.streaming.data.PythonSender
-
- TypeComparable<T> - Class in org.apache.flink.api.common.operators.util
-
Wrapper that is used to store elements for which we have a TypeComparator in a Hash Map.
- TypeComparable(T, TypeComparator<T>) - Constructor for class org.apache.flink.api.common.operators.util.TypeComparable
-
- TypeComparator<T> - Class in org.apache.flink.api.common.typeutils
-
This interface describes the methods that are required for a data type to be handled by the pact
runtime.
- TypeComparator() - Constructor for class org.apache.flink.api.common.typeutils.TypeComparator
-
- TypeComparatorFactory<T> - Interface in org.apache.flink.api.common.typeutils
-
- TypeDeserializer<T> - Interface in org.apache.flink.api.common.typeutils
-
This interface describes the methods that are required for a data type to be read by the Flink runtime.
- TypeDeserializerAdapter<T> - Class in org.apache.flink.api.common.typeutils
-
- TypeDeserializerAdapter(TypeDeserializer<T>) - Constructor for class org.apache.flink.api.common.typeutils.TypeDeserializerAdapter
-
- TypeDeserializerAdapter(TypeSerializer<T>) - Constructor for class org.apache.flink.api.common.typeutils.TypeDeserializerAdapter
-
- TypedResult<P> - Class in org.apache.flink.table.client.gateway
-
Result with an attached type (actual payload, EOS, etc.).
- TypedResult.ResultType - Enum in org.apache.flink.table.client.gateway
-
Result types.
- TypeExtractionException - Exception in org.apache.flink.api.java.typeutils
-
Type extraction always contains some uncertainty due to unpredictable JVM differences
between vendors or versions.
- TypeExtractionException() - Constructor for exception org.apache.flink.api.java.typeutils.TypeExtractionException
-
Creates a new exception with no message.
- TypeExtractionException(String) - Constructor for exception org.apache.flink.api.java.typeutils.TypeExtractionException
-
Creates a new exception with the given message.
- TypeExtractionException(String, Throwable) - Constructor for exception org.apache.flink.api.java.typeutils.TypeExtractionException
-
Creates a new exception with the given message and cause.
- TypeExtractionUtils - Class in org.apache.flink.api.java.typeutils
-
- TypeExtractionUtils.LambdaExecutable - Class in org.apache.flink.api.java.typeutils
-
Similar to a Java 8 Executable but with a return type.
- TypeExtractor - Class in org.apache.flink.api.java.typeutils
-
A utility for reflection analysis on classes, to determine the return type of implementations of transformation
functions.
- TypeExtractor() - Constructor for class org.apache.flink.api.java.typeutils.TypeExtractor
-
- TypeHint<T> - Class in org.apache.flink.api.common.typeinfo
-
A utility class for describing generic types.
- TypeHint() - Constructor for class org.apache.flink.api.common.typeinfo.TypeHint
-
Creates a hint for the generic type in the class signature.
- TypeInfo - Annotation Type in org.apache.flink.api.common.typeinfo
-
- typeInfo - Variable in class org.apache.flink.streaming.connectors.cassandra.CassandraSink.CassandraSinkBuilder
-
- TypeInfoFactory<T> - Class in org.apache.flink.api.common.typeinfo
-
Base class for implementing a type information factory.
- TypeInfoFactory() - Constructor for class org.apache.flink.api.common.typeinfo.TypeInfoFactory
-
- TypeInfoParser - Class in org.apache.flink.api.java.typeutils
-
- TypeInfoParser() - Constructor for class org.apache.flink.api.java.typeutils.TypeInfoParser
-
Deprecated.
- TypeInformation<T> - Class in org.apache.flink.api.common.typeinfo
-
TypeInformation is the core class of Flink's type system.
- TypeInformation() - Constructor for class org.apache.flink.api.common.typeinfo.TypeInformation
-
- TypeInformationKeyValueSerializationSchema<K,V> - Class in org.apache.flink.streaming.util.serialization
-
A serialization and deserialization schema for Key Value Pairs that uses Flink's serialization stack to
transform typed from and to byte arrays.
- TypeInformationKeyValueSerializationSchema(TypeInformation<K>, TypeInformation<V>, ExecutionConfig) - Constructor for class org.apache.flink.streaming.util.serialization.TypeInformationKeyValueSerializationSchema
-
Creates a new de-/serialization schema for the given types.
- TypeInformationKeyValueSerializationSchema(Class<K>, Class<V>, ExecutionConfig) - Constructor for class org.apache.flink.streaming.util.serialization.TypeInformationKeyValueSerializationSchema
-
Creates a new de-/serialization schema for the given types.
- TypeInformationSerializationSchema<T> - Class in 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) - Constructor for class org.apache.flink.api.common.serialization.TypeInformationSerializationSchema
-
Creates a new de-/serialization schema for the given type.
- TypeInformationSerializationSchema(TypeInformation<T>, TypeSerializer<T>) - Constructor for class org.apache.flink.api.common.serialization.TypeInformationSerializationSchema
-
Creates a new de-/serialization schema for the given type.
- TypeInformationSerializationSchema<T> - Class in org.apache.flink.streaming.util.serialization
-
- TypeInformationSerializationSchema(TypeInformation<T>, ExecutionConfig) - Constructor for class org.apache.flink.streaming.util.serialization.TypeInformationSerializationSchema
-
Deprecated.
Creates a new de-/serialization schema for the given type.
- TypePairComparator<T1,T2> - Class in org.apache.flink.api.common.typeutils
-
This interface defines the method required by the runtime to use data types in join-like operations.
- TypePairComparator() - Constructor for class org.apache.flink.api.common.typeutils.TypePairComparator
-
- TypePairComparatorFactory<T1,T2> - Interface in org.apache.flink.api.common.typeutils
-
- types - Variable in class org.apache.flink.api.common.operators.Ordering
-
- Types - Class in 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() - Constructor for class org.apache.flink.api.common.typeinfo.Types
-
- types(Class<T0>) - Method in class org.apache.flink.api.java.io.CsvReader
-
Specifies the types for the CSV fields.
- types(Class<T0>, Class<T1>) - Method in class org.apache.flink.api.java.io.CsvReader
-
Specifies the types for the CSV fields.
- types(Class<T0>, Class<T1>, Class<T2>) - Method in class org.apache.flink.api.java.io.CsvReader
-
Specifies the types for the CSV fields.
- types(Class<T0>, Class<T1>, Class<T2>, Class<T3>) - Method in class org.apache.flink.api.java.io.CsvReader
-
Specifies the types for the CSV fields.
- types(Class<T0>, Class<T1>, Class<T2>, Class<T3>, Class<T4>) - Method in class org.apache.flink.api.java.io.CsvReader
-
Specifies the types for the CSV fields.
- types(Class<T0>, Class<T1>, Class<T2>, Class<T3>, Class<T4>, Class<T5>) - Method in class org.apache.flink.api.java.io.CsvReader
-
Specifies the types for the CSV fields.
- types(Class<T0>, Class<T1>, Class<T2>, Class<T3>, Class<T4>, Class<T5>, Class<T6>) - Method in class org.apache.flink.api.java.io.CsvReader
-
Specifies the types for the CSV fields.
- types(Class<T0>, Class<T1>, Class<T2>, Class<T3>, Class<T4>, Class<T5>, Class<T6>, Class<T7>) - Method in class org.apache.flink.api.java.io.CsvReader
-
Specifies the types for the CSV fields.
- types(Class<T0>, Class<T1>, Class<T2>, Class<T3>, Class<T4>, Class<T5>, Class<T6>, Class<T7>, Class<T8>) - Method in class org.apache.flink.api.java.io.CsvReader
-
Specifies the types for the CSV fields.
- types(Class<T0>, Class<T1>, Class<T2>, Class<T3>, Class<T4>, Class<T5>, Class<T6>, Class<T7>, Class<T8>, Class<T9>) - Method in class org.apache.flink.api.java.io.CsvReader
-
Specifies the types for the CSV fields.
- types(Class<T0>, Class<T1>, Class<T2>, Class<T3>, Class<T4>, Class<T5>, Class<T6>, Class<T7>, Class<T8>, Class<T9>, Class<T10>) - Method in class org.apache.flink.api.java.io.CsvReader
-
Specifies the types for the CSV fields.
- types(Class<T0>, Class<T1>, Class<T2>, Class<T3>, Class<T4>, Class<T5>, Class<T6>, Class<T7>, Class<T8>, Class<T9>, Class<T10>, Class<T11>) - Method in class org.apache.flink.api.java.io.CsvReader
-
Specifies the types for the CSV fields.
- types(Class<T0>, Class<T1>, Class<T2>, Class<T3>, Class<T4>, Class<T5>, Class<T6>, Class<T7>, Class<T8>, Class<T9>, Class<T10>, Class<T11>, Class<T12>) - Method in class org.apache.flink.api.java.io.CsvReader
-
Specifies the types for the CSV fields.
- types(Class<T0>, Class<T1>, Class<T2>, Class<T3>, Class<T4>, Class<T5>, Class<T6>, Class<T7>, Class<T8>, Class<T9>, Class<T10>, Class<T11>, Class<T12>, Class<T13>) - Method in class org.apache.flink.api.java.io.CsvReader
-
Specifies the types for the CSV fields.
- types(Class<T0>, Class<T1>, Class<T2>, Class<T3>, Class<T4>, Class<T5>, Class<T6>, Class<T7>, Class<T8>, Class<T9>, Class<T10>, Class<T11>, Class<T12>, Class<T13>, Class<T14>) - Method in class org.apache.flink.api.java.io.CsvReader
-
Specifies the types for the CSV fields.
- types(Class<T0>, Class<T1>, Class<T2>, Class<T3>, Class<T4>, Class<T5>, Class<T6>, Class<T7>, Class<T8>, Class<T9>, Class<T10>, Class<T11>, Class<T12>, Class<T13>, Class<T14>, Class<T15>) - Method in class org.apache.flink.api.java.io.CsvReader
-
Specifies the types for the CSV fields.
- types(Class<T0>, Class<T1>, Class<T2>, Class<T3>, Class<T4>, Class<T5>, Class<T6>, Class<T7>, Class<T8>, Class<T9>, Class<T10>, Class<T11>, Class<T12>, Class<T13>, Class<T14>, Class<T15>, Class<T16>) - Method in class org.apache.flink.api.java.io.CsvReader
-
Specifies the types for the CSV fields.
- types(Class<T0>, Class<T1>, Class<T2>, Class<T3>, Class<T4>, Class<T5>, Class<T6>, Class<T7>, Class<T8>, Class<T9>, Class<T10>, Class<T11>, Class<T12>, Class<T13>, Class<T14>, Class<T15>, Class<T16>, Class<T17>) - Method in class org.apache.flink.api.java.io.CsvReader
-
Specifies the types for the CSV fields.
- types(Class<T0>, Class<T1>, Class<T2>, Class<T3>, Class<T4>, Class<T5>, Class<T6>, Class<T7>, Class<T8>, Class<T9>, Class<T10>, Class<T11>, Class<T12>, Class<T13>, Class<T14>, Class<T15>, Class<T16>, Class<T17>, Class<T18>) - Method in class org.apache.flink.api.java.io.CsvReader
-
Specifies the types for the CSV fields.
- types(Class<T0>, Class<T1>, Class<T2>, Class<T3>, Class<T4>, Class<T5>, Class<T6>, Class<T7>, Class<T8>, Class<T9>, Class<T10>, Class<T11>, Class<T12>, Class<T13>, Class<T14>, Class<T15>, Class<T16>, Class<T17>, Class<T18>, Class<T19>) - Method in class org.apache.flink.api.java.io.CsvReader
-
Specifies the types for the CSV fields.
- types(Class<T0>, Class<T1>, Class<T2>, Class<T3>, Class<T4>, Class<T5>, Class<T6>, Class<T7>, Class<T8>, Class<T9>, Class<T10>, Class<T11>, Class<T12>, Class<T13>, Class<T14>, Class<T15>, Class<T16>, Class<T17>, Class<T18>, Class<T19>, Class<T20>) - Method in class org.apache.flink.api.java.io.CsvReader
-
Specifies the types for the CSV fields.
- types(Class<T0>, Class<T1>, Class<T2>, Class<T3>, Class<T4>, Class<T5>, Class<T6>, Class<T7>, Class<T8>, Class<T9>, Class<T10>, Class<T11>, Class<T12>, Class<T13>, Class<T14>, Class<T15>, Class<T16>, Class<T17>, Class<T18>, Class<T19>, Class<T20>, Class<T21>) - Method in class org.apache.flink.api.java.io.CsvReader
-
Specifies the types for the CSV fields.
- types(Class<T0>, Class<T1>, Class<T2>, Class<T3>, Class<T4>, Class<T5>, Class<T6>, Class<T7>, Class<T8>, Class<T9>, Class<T10>, Class<T11>, Class<T12>, Class<T13>, Class<T14>, Class<T15>, Class<T16>, Class<T17>, Class<T18>, Class<T19>, Class<T20>, Class<T21>, Class<T22>) - Method in class org.apache.flink.api.java.io.CsvReader
-
Specifies the types for the CSV fields.
- types(Class<T0>, Class<T1>, Class<T2>, Class<T3>, Class<T4>, Class<T5>, Class<T6>, Class<T7>, Class<T8>, Class<T9>, Class<T10>, Class<T11>, Class<T12>, Class<T13>, Class<T14>, Class<T15>, Class<T16>, Class<T17>, Class<T18>, Class<T19>, Class<T20>, Class<T21>, Class<T22>, Class<T23>) - Method in class org.apache.flink.api.java.io.CsvReader
-
Specifies the types for the CSV fields.
- types(Class<T0>, Class<T1>, Class<T2>, Class<T3>, Class<T4>, Class<T5>, Class<T6>, Class<T7>, Class<T8>, Class<T9>, Class<T10>, Class<T11>, Class<T12>, Class<T13>, Class<T14>, Class<T15>, Class<T16>, Class<T17>, Class<T18>, Class<T19>, Class<T20>, Class<T21>, Class<T22>, Class<T23>, Class<T24>) - Method in class org.apache.flink.api.java.io.CsvReader
-
Specifies the types for the CSV fields.
- types(Class<?>...) - Method in class org.apache.flink.api.java.operators.CrossOperator.ProjectCross
-
- types(Class<?>...) - Method in class org.apache.flink.api.java.operators.JoinOperator.ProjectJoin
-
- types(Class<?>...) - Method in class org.apache.flink.api.java.operators.ProjectOperator
-
- types - Variable in class org.apache.flink.api.java.typeutils.TupleTypeInfoBase
-
- types(Class<K>, Class<VV>, Class<EV>) - Method in class org.apache.flink.graph.GraphCsvReader
-
Creates a Graph from CSV input with vertex values and edge values.
- types - Variable in class org.apache.flink.python.api.PythonOperationInfo
-
- TypeSerializer<T> - Class in org.apache.flink.api.common.typeutils
-
This interface describes the methods that are required for a data type to be handled by the Flink
runtime.
- TypeSerializer() - Constructor for class org.apache.flink.api.common.typeutils.TypeSerializer
-
- TypeSerializerConfigSnapshot - Class in org.apache.flink.api.common.typeutils
-
A TypeSerializerConfigSnapshot
is a point-in-time view of a TypeSerializer's
configuration.
- TypeSerializerConfigSnapshot() - Constructor for class org.apache.flink.api.common.typeutils.TypeSerializerConfigSnapshot
-
- TypeSerializerFactory<T> - Interface in org.apache.flink.api.common.typeutils
-
- TypeSerializerInputFormat<T> - Class in org.apache.flink.api.java.io
-
Reads elements by deserializing them with a given type serializer.
- TypeSerializerInputFormat(TypeInformation<T>) - Constructor for class org.apache.flink.api.java.io.TypeSerializerInputFormat
-
- TypeSerializerOutputFormat<T> - Class in org.apache.flink.api.java.io
-
Stores elements by serializing them with their type serializer.
- TypeSerializerOutputFormat() - Constructor for class org.apache.flink.api.java.io.TypeSerializerOutputFormat
-
- TypeSerializerSerializationProxy(ClassLoader) - Constructor for class org.apache.flink.api.common.typeutils.TypeSerializerSerializationUtil.TypeSerializerSerializationProxy
-
- TypeSerializerSerializationProxy(TypeSerializer<T>) - Constructor for class org.apache.flink.api.common.typeutils.TypeSerializerSerializationUtil.TypeSerializerSerializationProxy
-
- TypeSerializerSerializationUtil - Class in org.apache.flink.api.common.typeutils
-
- TypeSerializerSerializationUtil() - Constructor for class org.apache.flink.api.common.typeutils.TypeSerializerSerializationUtil
-
- TypeSerializerSerializationUtil.TypeSerializerSerializationProxy<T> - Class in org.apache.flink.api.common.typeutils
-
- TypeSerializerSingleton<T> - Class in org.apache.flink.api.common.typeutils.base
-
- TypeSerializerSingleton() - Constructor for class org.apache.flink.api.common.typeutils.base.TypeSerializerSingleton
-
- typesToString(TypeInformation<?>[]) - Static method in class org.apache.flink.table.client.cli.CliUtils
-
- typeToClass(Type) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractionUtils
-
Convert ParameterizedType or Class to a Class.
- typeUsed - Variable in class org.apache.flink.streaming.api.transformations.StreamTransformation
-
- V1 - Static variable in class org.apache.flink.examples.java.graph.util.EnumTrianglesDataTypes.Edge
-
- V1 - Static variable in class org.apache.flink.examples.java.graph.util.EnumTrianglesDataTypes.EdgeWithDegrees
-
- V1 - Static variable in class org.apache.flink.examples.java.graph.util.EnumTrianglesDataTypes.Triad
-
- V1 - Static variable in class org.apache.flink.graph.library.TriangleEnumerator.EdgeWithDegrees
-
- V1 - Static variable in class org.apache.flink.graph.library.TriangleEnumerator.Triad
-
- V2 - Static variable in class org.apache.flink.examples.java.graph.util.EnumTrianglesDataTypes.Edge
-
- V2 - Static variable in class org.apache.flink.examples.java.graph.util.EnumTrianglesDataTypes.EdgeWithDegrees
-
- V2 - Static variable in class org.apache.flink.examples.java.graph.util.EnumTrianglesDataTypes.Triad
-
- V2 - Static variable in class org.apache.flink.graph.library.TriangleEnumerator.EdgeWithDegrees
-
- V2 - Static variable in class org.apache.flink.graph.library.TriangleEnumerator.Triad
-
- V3 - Static variable in class org.apache.flink.examples.java.graph.util.EnumTrianglesDataTypes.Triad
-
- V3 - Static variable in class org.apache.flink.graph.library.TriangleEnumerator.Triad
-
- VAL_EDGE_TO_BE_REMOVED - Static variable in class org.apache.flink.graph.examples.data.IncrementalSSSPData
-
- validate() - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase
-
- validate(GraphValidator<K, VV, EV>) - Method in class org.apache.flink.graph.Graph
-
Function that checks whether a Graph is a valid Graph,
as defined by the given
GraphValidator
.
- validate(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.validation.GraphValidator
-
- validate(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.validation.InvalidVertexIdsValidator
-
Checks that the edge set input contains valid vertex Ids, i.e.
- validate(DescriptorProperties) - Method in class org.apache.flink.table.descriptors.JsonValidator
-
- validate(DescriptorProperties) - Method in class org.apache.flink.table.descriptors.KafkaValidator
-
- validateAndNormalizeUri(URI) - Static method in class org.apache.flink.runtime.webmonitor.WebMonitorUtils
-
Checks and normalizes the given URI.
- validateClassLoadable(ClassNotFoundException, ClassLoader) - Static method in class org.apache.flink.runtime.util.ClassLoaderUtil
-
Checks, whether the class that was not found in the given exception, can be resolved through
the given class loader.
- validateClusterResources(ClusterSpecification, int, Resource, AbstractYarnClusterDescriptor.ClusterResourceDescription) - Method in class org.apache.flink.yarn.AbstractYarnClusterDescriptor
-
- validateCustomPartitioner(Partitioner<E>, TypeInformation<E>) - Method in class org.apache.flink.api.common.operators.Keys.ExpressionKeys
-
- validateCustomPartitioner(Partitioner<E>, TypeInformation<E>) - Method in class org.apache.flink.api.common.operators.Keys.SelectorFunctionKeys
-
- validateCustomPartitioner(Partitioner<E>, TypeInformation<E>) - Method in class org.apache.flink.api.common.operators.Keys
-
- validateRunsInMainThread() - Method in class org.apache.flink.runtime.rpc.RpcEndpoint
-
Validates that the method call happens in the RPC endpoint's main thread.
- validateZooKeeperConfig(Properties) - Static method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer08
-
Validate the ZK configuration, checking for required parameters.
- value() - Method in interface org.apache.flink.api.common.state.ValueState
-
Returns the current value for the state.
- VALUE(Class<V>) - Static method in class org.apache.flink.api.common.typeinfo.Types
-
Returns type information for Flink value types (classes that implement
Value
).
- value - Variable in class org.apache.flink.api.java.hadoop.mapred.HadoopInputFormatBase
-
- value() - Method in class org.apache.flink.api.java.summarize.aggregation.CompensatedSum
-
The value of the sum.
- value() - Method in class org.apache.flink.contrib.streaming.state.RocksDBValueState
-
- value() - Method in class org.apache.flink.contrib.streaming.state.RocksIteratorWrapper
-
- Value() - Constructor for class org.apache.flink.graph.drivers.parameter.IterationConvergence.Value
-
- value - Variable in class org.apache.flink.graph.drivers.parameter.SimpleParameter
-
- value() - Method in class org.apache.flink.queryablestate.client.state.ImmutableValueState
-
- value - Variable in class org.apache.flink.runtime.metrics.dump.MetricDump.GaugeDump
-
- value() - Method in class org.apache.flink.runtime.state.heap.HeapValueState
-
- value - Variable in class org.apache.flink.storm.util.SplitStreamType
-
The actual data value.
- Value - Interface in org.apache.flink.types
-
Basic value interface for types that act as serializable values.
- VALUE_FIELD - Static variable in class org.apache.flink.streaming.connectors.fs.AvroKeyValueSinkWriter.AvroKeyValue
-
The name of the generic record field containing the value.
- VALUE_NOT_SET - Static variable in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
- ValueArray<T> - Interface in org.apache.flink.graph.types.valuearray
-
Basic interface for array types which reuse objects during serialization.
- ValueArrayFactory - Class in org.apache.flink.graph.types.valuearray
-
A factory generator for
ValueArray
types is necessary because the
contained
Value
types do not currently implement a common interface
for creating a
ValueArray
.
- ValueArrayFactory() - Constructor for class org.apache.flink.graph.types.valuearray.ValueArrayFactory
-
- ValueArrayTypeInfo<T> - Class in org.apache.flink.graph.types.valuearray
-
- ValueArrayTypeInfo(TypeInformation<T>) - Constructor for class org.apache.flink.graph.types.valuearray.ValueArrayTypeInfo
-
- ValueArrayTypeInfoFactory<T> - Class in org.apache.flink.graph.types.valuearray
-
- ValueArrayTypeInfoFactory() - Constructor for class org.apache.flink.graph.types.valuearray.ValueArrayTypeInfoFactory
-
- valueClass - Variable in class org.apache.flink.api.java.hadoop.mapred.HadoopInputFormatBase
-
- valueClass - Variable in class org.apache.flink.api.java.hadoop.mapreduce.HadoopInputFormatBase
-
- ValueComparator<T extends Value & Comparable<T>> - Class in org.apache.flink.api.java.typeutils.runtime
-
Comparator for all Value types that extend Key
- ValueComparator(boolean, Class<T>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.ValueComparator
-
- valueOf(String) - Static method in enum org.apache.flink.api.common.CodeAnalysisMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.api.common.ExecutionMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.api.common.io.FileOutputFormat.OutputDirectoryMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.api.common.operators.base.CrossOperatorBase.CrossHint
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.api.common.operators.base.JoinOperatorBase.JoinHint
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.api.common.operators.base.OuterJoinOperatorBase.OuterJoinType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.api.common.operators.base.PartitionOperatorBase.PartitionMethod
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.api.common.operators.base.ReduceOperatorBase.CombineHint
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.api.common.operators.Order
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.api.common.resources.Resource.ResourceAggregateType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.api.common.state.StateDescriptor.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.api.java.aggregation.Aggregations
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.api.java.operators.join.JoinType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.api.java.sca.TaggedValue.Input
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.api.java.sca.TaggedValue.Tag
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.api.java.typeutils.runtime.KryoRegistration.SerializerDefinitionType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.api.java.utils.OptionType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.cep.nfa.AfterMatchSkipStrategy.SkipStrategy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.cep.nfa.State.StateType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.cep.nfa.StateTransitionAction
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.cep.pattern.Quantifier.ConsumingStrategy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.cep.pattern.Quantifier.QuantifierProperty
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.contrib.streaming.state.PredefinedOptions
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.core.fs.FileSystem.WriteMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.core.fs.FileSystemKind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.core.memory.MemoryType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.docs.util.Utils
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.formats.avro.AvroOutputFormat.Codec
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.graph.drivers.parameter.Simplify.Ordering
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.graph.EdgeDirection
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.graph.EdgeOrder
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.graph.utils.proxy.OptionalBoolean.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.mesos.runtime.clusterframework.MesosTaskManagerParameters.ContainerType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.mesos.runtime.clusterframework.store.MesosWorkerStore.WorkerState
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.metrics.datadog.MetricType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.optimizer.dag.TempMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.optimizer.dataproperties.PartitioningProperty
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.optimizer.plan.PlanNode.FeedbackPropertiesMeetRequirementsReport
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.optimizer.plan.PlanNode.SourceAndDamReport
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.python.api.PythonPlanBinder.Operation
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.queryablestate.network.messages.MessageType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.akka.ListeningBehaviour
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.checkpoint.CheckpointDeclineReason
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.checkpoint.CheckpointRetentionPolicy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.checkpoint.CheckpointStatsStatus
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.checkpoint.CheckpointType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.checkpoint.PendingCheckpoint.TaskAcknowledgeResult
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.clusterframework.ApplicationStatus
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.clusterframework.types.TaskManagerSlot.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.dispatcher.Dispatcher.DefaultJobManagerRunnerFactory
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.dispatcher.VoidHistoryServerArchivist
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.entrypoint.ClusterEntrypoint.ExecutionMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.execution.ExecutionState
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.execution.librarycache.FlinkUserCodeClassLoaders.ResolveOrder
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.highavailability.HighAvailabilityServicesUtils.AddressResolution
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.highavailability.RunningJobsRegistry.JobSchedulingStatus
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.io.disk.iomanager.IOManager.IOMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.io.network.api.serialization.RecordDeserializer.DeserializationResult
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.io.network.api.serialization.RecordSerializer.SerializationResult
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.io.network.DataExchangeMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.io.network.partition.ResultPartitionType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.jobgraph.DistributionPattern
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.jobgraph.JobStatus
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.jobgraph.ScheduleMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.jobmanager.HighAvailabilityMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.jobmanager.JobManagerMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.jobmanager.scheduler.Locality
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.jobmanager.scheduler.LocationPreferenceConstraint
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.jobmaster.factories.UnregisteredJobManagerJobMetricGroupFactory
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.jobmaster.RescalingBehaviour
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.metrics.groups.AbstractMetricGroup.ChildType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.minicluster.MiniClusterConfiguration.RpcServiceSharing
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.operators.DamBehavior
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.operators.DriverStrategy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.operators.shipping.ShipStrategyType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.operators.util.LocalStrategy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.rest.handler.legacy.backpressure.VoidBackPressureStatsTracker
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.rest.handler.legacy.TaskManagerLogHandler.FileMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.rest.HttpMethodWrapper
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigInfo.ProcessingMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.rest.messages.job.metrics.MetricsAggregationParameter.AggregationMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo.VertexBackPressureLevel
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo.VertexBackPressureStatus
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.rest.messages.MessageParameter.MessageParameterRequisiteness
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.rest.messages.queue.QueueStatus.Id
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.rest.messages.TerminationModeQueryParameter.TerminationMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.rest.util.RestConstants
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.rpc.akka.AkkaRpcServiceUtils.AkkaProtocol
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.rpc.akka.messages.Processing
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.rpc.messages.HandshakeSuccessMessage
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.state.CheckpointedStateScope
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.state.OperatorStateHandle.Mode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.taskexecutor.FileType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.util.ZooKeeperUtils.ZkClientACLMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.webmonitor.WebMonitorExtension.EmptyWebMonitorExtension
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.streaming.api.CheckpointingMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.streaming.api.datastream.AsyncDataStream.OutputMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.streaming.api.environment.CheckpointConfig.ExternalizedCheckpointCleanup
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.streaming.api.functions.aggregation.AggregationFunction.AggregationType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.streaming.api.functions.source.FileMonitoringFunction.WatchType
-
Deprecated.
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.streaming.api.functions.source.FileProcessingMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.streaming.api.operators.ChainingStrategy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.streaming.api.TimeCharacteristic
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.streaming.api.TimeDomain
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.streaming.api.windowing.triggers.TriggerResult
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.streaming.connectors.elasticsearch.ElasticsearchSinkBase.FlushBackoffType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.streaming.connectors.kafka.config.OffsetCommitMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.streaming.connectors.kafka.config.StartupMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.streaming.connectors.kafka.FlinkKafka011ErrorCode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer011.Semantic
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.streaming.examples.statemachine.dfa.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.streaming.examples.statemachine.event.EventType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.streaming.util.LatencyStats.Granularity
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.table.client.cli.CliChangelogResultView.ResultChangelogOperation
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.table.client.cli.CliInputView.InputOperation
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.table.client.cli.CliRowView.RowOperation
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.table.client.cli.CliTableResultView.ResultTableOperation
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.table.client.gateway.TypedResult.ResultType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.test.util.MiniClusterResource.MiniClusterType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.test.util.MultipleProgramsTestBase.TestExecutionMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.types.parser.FieldParser.ParseErrorState
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.util.OperatingSystem
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.util.TernaryBoolean
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.yarn.configuration.YarnConfigOptions.UserJarInclusion
-
Returns the enum constant of this type with the specified name.
- valueOrNull(Object) - Static method in class org.apache.flink.runtime.metrics.scope.ScopeFormat
-
- values() - Static method in enum org.apache.flink.api.common.CodeAnalysisMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.api.common.ExecutionMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.api.common.io.FileOutputFormat.OutputDirectoryMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.api.common.operators.base.CrossOperatorBase.CrossHint
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.api.common.operators.base.JoinOperatorBase.JoinHint
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.api.common.operators.base.OuterJoinOperatorBase.OuterJoinType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.api.common.operators.base.PartitionOperatorBase.PartitionMethod
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.api.common.operators.base.ReduceOperatorBase.CombineHint
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.api.common.operators.Order
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.api.common.resources.Resource.ResourceAggregateType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Method in interface org.apache.flink.api.common.state.MapState
-
Returns all the values in the state.
- values() - Static method in enum org.apache.flink.api.common.state.StateDescriptor.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.api.java.aggregation.Aggregations
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.api.java.operators.join.JoinType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.api.java.sca.TaggedValue.Input
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.api.java.sca.TaggedValue.Tag
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.api.java.typeutils.runtime.KryoRegistration.SerializerDefinitionType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.api.java.utils.OptionType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.cep.nfa.AfterMatchSkipStrategy.SkipStrategy
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.cep.nfa.State.StateType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.cep.nfa.StateTransitionAction
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.cep.pattern.Quantifier.ConsumingStrategy
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.cep.pattern.Quantifier.QuantifierProperty
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.contrib.streaming.state.PredefinedOptions
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Method in class org.apache.flink.contrib.streaming.state.RocksDBMapState
-
- values() - Static method in enum org.apache.flink.core.fs.FileSystem.WriteMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.core.fs.FileSystemKind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.core.memory.MemoryType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.docs.util.Utils
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.formats.avro.AvroOutputFormat.Codec
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.graph.drivers.parameter.Simplify.Ordering
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.graph.EdgeDirection
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.graph.EdgeOrder
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.graph.utils.proxy.OptionalBoolean.State
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.mesos.runtime.clusterframework.MesosTaskManagerParameters.ContainerType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.mesos.runtime.clusterframework.store.MesosWorkerStore.WorkerState
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.metrics.datadog.MetricType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.optimizer.dag.TempMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.optimizer.dataproperties.PartitioningProperty
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.optimizer.plan.PlanNode.FeedbackPropertiesMeetRequirementsReport
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.optimizer.plan.PlanNode.SourceAndDamReport
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values - Variable in class org.apache.flink.python.api.PythonOperationInfo
-
- values() - Static method in enum org.apache.flink.python.api.PythonPlanBinder.Operation
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Method in class org.apache.flink.queryablestate.client.state.ImmutableMapState
-
- values() - Static method in enum org.apache.flink.queryablestate.network.messages.MessageType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.akka.ListeningBehaviour
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.checkpoint.CheckpointDeclineReason
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.checkpoint.CheckpointRetentionPolicy
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.checkpoint.CheckpointStatsStatus
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.checkpoint.CheckpointType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.checkpoint.PendingCheckpoint.TaskAcknowledgeResult
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.clusterframework.ApplicationStatus
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.clusterframework.types.TaskManagerSlot.State
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.dispatcher.Dispatcher.DefaultJobManagerRunnerFactory
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.dispatcher.VoidHistoryServerArchivist
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.entrypoint.ClusterEntrypoint.ExecutionMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.execution.ExecutionState
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.execution.librarycache.FlinkUserCodeClassLoaders.ResolveOrder
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.highavailability.HighAvailabilityServicesUtils.AddressResolution
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.highavailability.RunningJobsRegistry.JobSchedulingStatus
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.io.disk.iomanager.IOManager.IOMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.io.network.api.serialization.RecordDeserializer.DeserializationResult
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.io.network.api.serialization.RecordSerializer.SerializationResult
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.io.network.DataExchangeMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.io.network.partition.ResultPartitionType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.jobgraph.DistributionPattern
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.jobgraph.JobStatus
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.jobgraph.ScheduleMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.jobmanager.HighAvailabilityMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.jobmanager.JobManagerMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.jobmanager.scheduler.Locality
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.jobmanager.scheduler.LocationPreferenceConstraint
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.jobmaster.factories.UnregisteredJobManagerJobMetricGroupFactory
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.jobmaster.RescalingBehaviour
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Method in class org.apache.flink.runtime.jobmaster.slotpool.DualKeyMap
-
- values() - Static method in enum org.apache.flink.runtime.metrics.groups.AbstractMetricGroup.ChildType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.minicluster.MiniClusterConfiguration.RpcServiceSharing
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.operators.DamBehavior
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.operators.DriverStrategy
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.operators.shipping.ShipStrategyType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.operators.util.LocalStrategy
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.rest.handler.legacy.backpressure.VoidBackPressureStatsTracker
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.rest.handler.legacy.TaskManagerLogHandler.FileMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.rest.HttpMethodWrapper
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigInfo.ProcessingMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.rest.messages.job.metrics.MetricsAggregationParameter.AggregationMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo.VertexBackPressureLevel
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo.VertexBackPressureStatus
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.rest.messages.MessageParameter.MessageParameterRequisiteness
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.rest.messages.queue.QueueStatus.Id
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.rest.messages.TerminationModeQueryParameter.TerminationMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.rest.util.RestConstants
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.rpc.akka.AkkaRpcServiceUtils.AkkaProtocol
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.rpc.akka.messages.Processing
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.rpc.messages.HandshakeSuccessMessage
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.state.CheckpointedStateScope
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Method in class org.apache.flink.runtime.state.heap.HeapMapState
-
- values() - Static method in enum org.apache.flink.runtime.state.OperatorStateHandle.Mode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.taskexecutor.FileType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.util.ZooKeeperUtils.ZkClientACLMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.webmonitor.WebMonitorExtension.EmptyWebMonitorExtension
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Method in class org.apache.flink.storm.util.StormConfig
-
- values() - Static method in enum org.apache.flink.streaming.api.CheckpointingMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.streaming.api.datastream.AsyncDataStream.OutputMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.streaming.api.environment.CheckpointConfig.ExternalizedCheckpointCleanup
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.streaming.api.functions.aggregation.AggregationFunction.AggregationType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.streaming.api.functions.source.FileMonitoringFunction.WatchType
-
Deprecated.
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.streaming.api.functions.source.FileProcessingMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Method in class org.apache.flink.streaming.api.operators.async.queue.OrderedStreamElementQueue
-
- values() - Method in interface org.apache.flink.streaming.api.operators.async.queue.StreamElementQueue
-
- values() - Method in class org.apache.flink.streaming.api.operators.async.queue.UnorderedStreamElementQueue
-
- values() - Static method in enum org.apache.flink.streaming.api.operators.ChainingStrategy
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.streaming.api.TimeCharacteristic
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.streaming.api.TimeDomain
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.streaming.api.windowing.triggers.TriggerResult
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.streaming.connectors.elasticsearch.ElasticsearchSinkBase.FlushBackoffType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.streaming.connectors.kafka.config.OffsetCommitMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.streaming.connectors.kafka.config.StartupMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.streaming.connectors.kafka.FlinkKafka011ErrorCode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer011.Semantic
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.streaming.examples.statemachine.dfa.State
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.streaming.examples.statemachine.event.EventType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.streaming.util.LatencyStats.Granularity
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.table.client.cli.CliChangelogResultView.ResultChangelogOperation
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.table.client.cli.CliInputView.InputOperation
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.table.client.cli.CliRowView.RowOperation
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.table.client.cli.CliTableResultView.ResultTableOperation
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.table.client.gateway.TypedResult.ResultType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.test.util.MiniClusterResource.MiniClusterType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.test.util.MultipleProgramsTestBase.TestExecutionMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Method in class org.apache.flink.types.MapValue
-
- values() - Static method in enum org.apache.flink.types.parser.FieldParser.ParseErrorState
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.util.OperatingSystem
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.util.TernaryBoolean
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.yarn.configuration.YarnConfigOptions.UserJarInclusion
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- ValueSerializer<T extends Value> - Class in org.apache.flink.api.java.typeutils.runtime
-
Serializer for
Value
types.
- ValueSerializer(Class<T>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.ValueSerializer
-
- valueSerializer - Variable in class org.apache.flink.runtime.state.heap.AbstractHeapState
-
- ValueSerializer.ValueSerializerConfigSnapshot<T extends Value> - Class in org.apache.flink.api.java.typeutils.runtime
-
- ValueSerializerConfigSnapshot() - Constructor for class org.apache.flink.api.java.typeutils.runtime.ValueSerializer.ValueSerializerConfigSnapshot
-
This empty nullary constructor is required for deserializing the configuration.
- ValueSerializerConfigSnapshot(Class<T>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.ValueSerializer.ValueSerializerConfigSnapshot
-
- ValueState<T> - Interface in org.apache.flink.api.common.state
-
State
interface for partitioned single-value state.
- ValueStateDescriptor<T> - Class in org.apache.flink.api.common.state
-
- ValueStateDescriptor(String, Class<T>, T) - Constructor for class org.apache.flink.api.common.state.ValueStateDescriptor
-
- ValueStateDescriptor(String, TypeInformation<T>, T) - Constructor for class org.apache.flink.api.common.state.ValueStateDescriptor
-
- ValueStateDescriptor(String, TypeSerializer<T>, T) - Constructor for class org.apache.flink.api.common.state.ValueStateDescriptor
-
- ValueStateDescriptor(String, Class<T>) - Constructor for class org.apache.flink.api.common.state.ValueStateDescriptor
-
Creates a new ValueStateDescriptor
with the given name and type
- ValueStateDescriptor(String, TypeInformation<T>) - Constructor for class org.apache.flink.api.common.state.ValueStateDescriptor
-
Creates a new ValueStateDescriptor
with the given name and type.
- ValueStateDescriptor(String, TypeSerializer<T>) - Constructor for class org.apache.flink.api.common.state.ValueStateDescriptor
-
Creates a new ValueStateDescriptor
with the given name and the specific serializer.
- ValueSummaryAggregator<VT extends Value,PT,R,A extends Aggregator<PT,R>> - Class in org.apache.flink.api.java.summarize.aggregation
-
This is a generic Aggregator for Value types like StringValue, DoubleValue, etc.
- ValueSummaryAggregator() - Constructor for class org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator
-
- ValueSummaryAggregator.BooleanValueSummaryAggregator - Class in org.apache.flink.api.java.summarize.aggregation
-
- ValueSummaryAggregator.DoubleValueSummaryAggregator - Class in org.apache.flink.api.java.summarize.aggregation
-
- ValueSummaryAggregator.FloatValueSummaryAggregator - Class in org.apache.flink.api.java.summarize.aggregation
-
- ValueSummaryAggregator.IntegerValueSummaryAggregator - Class in org.apache.flink.api.java.summarize.aggregation
-
- ValueSummaryAggregator.LongValueSummaryAggregator - Class in org.apache.flink.api.java.summarize.aggregation
-
- ValueSummaryAggregator.ShortValueSummaryAggregator - Class in org.apache.flink.api.java.summarize.aggregation
-
- ValueSummaryAggregator.StringValueSummaryAggregator - Class in org.apache.flink.api.java.summarize.aggregation
-
- ValueTypeInfo<T extends Value> - Class in org.apache.flink.api.java.typeutils
-
Type information for data types that extend the
Value
interface.
- ValueTypeInfo(Class<T>) - Constructor for class org.apache.flink.api.java.typeutils.ValueTypeInfo
-
- variable(String, String) - Static method in class org.apache.flink.mesos.Utils
-
Construct a Mesos environment variable.
- variables - Variable in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
-
The map containing all variables and their associated values, lazily computed.
- VCORES - Static variable in class org.apache.flink.yarn.configuration.YarnConfigOptions
-
The vcores exposed by YARN.
- VectorAccumulator() - Constructor for class org.apache.flink.examples.java.relational.EmptyFieldsCountAccumulator.VectorAccumulator
-
- VectorAccumulator(ArrayList<Integer>) - Constructor for class org.apache.flink.examples.java.relational.EmptyFieldsCountAccumulator.VectorAccumulator
-
- VerifyAndEnrichBolt - Class in org.apache.flink.storm.split.operators
-
Verifies that incoming numbers are either even or odd, controlled by the constructor argument.
- VerifyAndEnrichBolt(boolean) - Constructor for class org.apache.flink.storm.split.operators.VerifyAndEnrichBolt
-
- verifyEmpty() - Method in class org.apache.flink.runtime.memory.MemoryManager
-
Checks if the memory manager all memory available.
- verifyEndOfSuperstepState() - Method in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
-
- version() - Method in class org.apache.flink.runtime.checkpoint.MasterState
-
- VERSION - Static variable in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV1
-
The savepoint version.
- VERSION - Static variable in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV2
-
The savepoint version.
- VERSION - Static variable in class org.apache.flink.runtime.state.KeyedBackendSerializationProxy
-
- VERSION - Static variable in class org.apache.flink.runtime.state.OperatorBackendSerializationProxy
-
- VERSION - Static variable in class org.apache.flink.streaming.api.operators.InternalTimerServiceSerializationProxy
-
- version(String) - Method in class org.apache.flink.table.descriptors.Kafka
-
Sets the Kafka version to be used.
- Versioned - Interface in org.apache.flink.core.io
-
This interface is implemented by classes that provide a version number.
- VersionedIOReadableWritable - Class in org.apache.flink.core.io
-
This is the abstract base class for
IOReadableWritable
which allows to differentiate between serialization
versions.
- VersionedIOReadableWritable() - Constructor for class org.apache.flink.core.io.VersionedIOReadableWritable
-
- VersionMismatchException - Exception in org.apache.flink.core.io
-
This exception signals that incompatible versions have been found during serialization.
- VersionMismatchException() - Constructor for exception org.apache.flink.core.io.VersionMismatchException
-
- VersionMismatchException(String) - Constructor for exception org.apache.flink.core.io.VersionMismatchException
-
- VersionMismatchException(String, Throwable) - Constructor for exception org.apache.flink.core.io.VersionMismatchException
-
- VersionMismatchException(Throwable) - Constructor for exception org.apache.flink.core.io.VersionMismatchException
-
- Vertex<K,V> - Class in org.apache.flink.graph
-
Represents the graph's nodes.
- Vertex() - Constructor for class org.apache.flink.graph.Vertex
-
- Vertex(K, V) - Constructor for class org.apache.flink.graph.Vertex
-
- VERTEX_TASK_FIELD_ID - Static variable in class org.apache.flink.runtime.rest.messages.JobVertexTaskManagersInfo
-
- VERTEX_TASK_FIELD_NAME - Static variable in class org.apache.flink.runtime.rest.messages.JobVertexTaskManagersInfo
-
- VERTEX_TASK_FIELD_NOW - Static variable in class org.apache.flink.runtime.rest.messages.JobVertexTaskManagersInfo
-
- VERTEX_TASK_FIELD_TASK_MANAGERS - Static variable in class org.apache.flink.runtime.rest.messages.JobVertexTaskManagersInfo
-
- VertexCentricConfiguration - Class in org.apache.flink.graph.pregel
-
A VertexCentricConfiguration object can be used to set the iteration name and
degree of parallelism, to register aggregators and use broadcast sets in
the
ComputeFunction
.
- VertexCentricConfiguration() - Constructor for class org.apache.flink.graph.pregel.VertexCentricConfiguration
-
- VertexCentricIteration<K,VV,EV,Message> - Class in org.apache.flink.graph.pregel
-
This class represents iterative graph computations, programmed in a vertex-centric perspective.
- vertexCount() - Method in class org.apache.flink.graph.drivers.input.CirculantGraph
-
- vertexCount() - Method in class org.apache.flink.graph.drivers.input.CompleteGraph
-
- vertexCount() - Method in class org.apache.flink.graph.drivers.input.CycleGraph
-
- vertexCount() - Method in class org.apache.flink.graph.drivers.input.EchoGraph
-
- vertexCount() - Method in class org.apache.flink.graph.drivers.input.EmptyGraph
-
- vertexCount() - Method in class org.apache.flink.graph.drivers.input.GeneratedGraph
-
The vertex count is verified to be no greater than the capacity of the
selected data type.
- vertexCount() - Method in class org.apache.flink.graph.drivers.input.GridGraph
-
- vertexCount() - Method in class org.apache.flink.graph.drivers.input.HypercubeGraph
-
- vertexCount() - Method in class org.apache.flink.graph.drivers.input.PathGraph
-
- vertexCount() - Method in class org.apache.flink.graph.drivers.input.RMatGraph
-
- vertexCount() - Method in class org.apache.flink.graph.drivers.input.SingletonEdgeGraph
-
- vertexCount() - Method in class org.apache.flink.graph.drivers.input.StarGraph
-
- VertexDegree<K,VV,EV> - Class in org.apache.flink.graph.asm.degree.annotate.undirected
-
Annotates vertices of an undirected graph with the degree.
- VertexDegree() - Constructor for class org.apache.flink.graph.asm.degree.annotate.undirected.VertexDegree
-
- VertexDegrees<K,VV,EV> - Class in org.apache.flink.graph.asm.degree.annotate.directed
-
Annotates vertices of a directed graph with the degree, out-, and in-degree.
- VertexDegrees() - Constructor for class org.apache.flink.graph.asm.degree.annotate.directed.VertexDegrees
-
- VertexDegrees.Degrees - Class in org.apache.flink.graph.asm.degree.annotate.directed
-
Wraps the vertex degree, out-degree, and in-degree.
- VertexDistanceUpdater() - Constructor for class org.apache.flink.graph.examples.IncrementalSSSP.VertexDistanceUpdater
-
- VertexDistanceUpdater() - Constructor for class org.apache.flink.graph.library.SingleSourceShortestPaths.VertexDistanceUpdater
-
- VertexGroupItem() - Constructor for class org.apache.flink.graph.library.Summarization.VertexGroupItem
-
- vertexID - Variable in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.OperatorQueryScopeInfo
-
- vertexID - Variable in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.TaskQueryScopeInfo
-
- vertexId - Variable in class org.apache.flink.runtime.metrics.groups.TaskMetricGroup
-
- vertexId() - Method in class org.apache.flink.runtime.metrics.groups.TaskMetricGroup
-
- vertexIDtoBrokerID - Variable in class org.apache.flink.streaming.api.graph.StreamGraph
-
- vertexIDtoLoopTimeout - Variable in class org.apache.flink.streaming.api.graph.StreamGraph
-
- VertexInDegree<K,VV,EV> - Class in org.apache.flink.graph.asm.degree.annotate.directed
-
Annotates vertices of a directed graph with the in-degree.
- VertexInDegree() - Constructor for class org.apache.flink.graph.asm.degree.annotate.directed.VertexInDegree
-
- vertexJoin(VV, T) - Method in interface org.apache.flink.graph.VertexJoinFunction
-
Applies a transformation on the current vertex value
and the value of the matched tuple of the input DataSet.
- VertexJoinFunction<VV,T> - Interface in org.apache.flink.graph
-
- VertexMetrics<K extends Comparable<K>,VV,EV> - Class in org.apache.flink.graph.library.metric.directed
-
Compute the following vertex metrics in a directed graph.
- VertexMetrics() - Constructor for class org.apache.flink.graph.library.metric.directed.VertexMetrics
-
- VertexMetrics<K extends Comparable<K>,VV,EV> - Class in org.apache.flink.graph.library.metric.undirected
-
Compute the following vertex metrics in an undirected graph.
- VertexMetrics() - Constructor for class org.apache.flink.graph.library.metric.undirected.VertexMetrics
-
- VertexMetrics.Result - Class in org.apache.flink.graph.library.metric.directed
-
Wraps vertex metrics.
- VertexMetrics.Result - Class in org.apache.flink.graph.library.metric.undirected
-
Wraps vertex metrics.
- VertexOutDegree<K,VV,EV> - Class in org.apache.flink.graph.asm.degree.annotate.directed
-
Annotates vertices of a directed graph with the out-degree.
- VertexOutDegree() - Constructor for class org.apache.flink.graph.asm.degree.annotate.directed.VertexOutDegree
-
- VertexRankUpdater(double) - Constructor for class org.apache.flink.graph.examples.PageRank.VertexRankUpdater
-
- vertexReader - Variable in class org.apache.flink.graph.GraphCsvReader
-
- vertexSequence(ExecutionEnvironment, int, long) - Static method in class org.apache.flink.graph.generator.GraphGeneratorUtils
-
Generates
Vertices
with sequential, numerical labels.
- vertexSet(DataSet<Edge<K, EV>>, int) - Static method in class org.apache.flink.graph.generator.GraphGeneratorUtils
-
- VertexTaskDetail(int, ExecutionState, int, String, long, long, long, IOMetricsInfo) - Constructor for class org.apache.flink.runtime.rest.messages.JobVertexDetailsInfo.VertexTaskDetail
-
- VertexToTuple2Map<K,VV> - Class in org.apache.flink.graph.utils
-
Create a Tuple2 DataSet from a Vertex DataSet.
- VertexToTuple2Map() - Constructor for class org.apache.flink.graph.utils.VertexToTuple2Map
-
- vertexTypes(Class<K>, Class<VV>) - Method in class org.apache.flink.graph.GraphCsvReader
-
Creates a Graph from CSV input without edge values.
- VertexValue() - Constructor for class org.apache.flink.graph.library.Summarization.VertexValue
-
- VertexWithRepresentative() - Constructor for class org.apache.flink.graph.library.Summarization.VertexWithRepresentative
-
- VERTICES - Static variable in class org.apache.flink.examples.java.graph.util.ConnectedComponentsData
-
- VERTICES - Static variable in class org.apache.flink.graph.examples.data.EuclideanGraphData
-
- VERTICES - Static variable in class org.apache.flink.graph.examples.data.IncrementalSSSPData
-
- VERTICES - Static variable in class org.apache.flink.test.testdata.PageRankData
-
- VERTICES_WITH_MIN_ID - Static variable in class org.apache.flink.graph.examples.data.ConnectedComponentsDefaultData
-
- View - Interface in org.apache.flink.metrics
-
An interface for metrics which should be updated in regular intervals by a background thread.
- ViewUpdater - Class in org.apache.flink.runtime.metrics
-
The ViewUpdater is responsible for updating all metrics that implement the
View
interface.
- ViewUpdater(ScheduledExecutorService) - Constructor for class org.apache.flink.runtime.metrics.ViewUpdater
-
- VirtualFileServerHandler(Path) - Constructor for class org.apache.flink.mesos.util.MesosArtifactServer.VirtualFileServerHandler
-
- VisibleForTesting - Annotation Type in org.apache.flink.annotation
-
This annotations declares that a function, field, constructor, or entire type, is only visible for
testing purposes.
- visit(String, Object) - Method in class org.apache.flink.runtime.util.DependencyVisitor.AnnotationVisitorImpl
-
- visit(int, int, String, String, String, String[]) - Method in class org.apache.flink.runtime.util.DependencyVisitor
-
- Visitable<T extends Visitable<T>> - Interface in org.apache.flink.util
-
This interface marks types as visitable during a traversal.
- visitAnnotation(String, String) - Method in class org.apache.flink.runtime.util.DependencyVisitor.AnnotationVisitorImpl
-
- visitAnnotation(String, boolean) - Method in class org.apache.flink.runtime.util.DependencyVisitor.MethodVisitorImpl
-
- visitAnnotation(String, boolean) - Method in class org.apache.flink.runtime.util.DependencyVisitor
-
- visitAnnotationDefault() - Method in class org.apache.flink.runtime.util.DependencyVisitor.MethodVisitorImpl
-
- visitArray(String) - Method in class org.apache.flink.runtime.util.DependencyVisitor.AnnotationVisitorImpl
-
- visitClassType(String) - Method in class org.apache.flink.runtime.util.DependencyVisitor.SignatureVisitorImpl
-
- visitEnum(String, String, String) - Method in class org.apache.flink.runtime.util.DependencyVisitor.AnnotationVisitorImpl
-
- visitField(int, String, String, String, Object) - Method in class org.apache.flink.runtime.util.DependencyVisitor
-
- visitFieldInsn(int, String, String, String) - Method in class org.apache.flink.runtime.util.DependencyVisitor.MethodVisitorImpl
-
- visitInnerClassType(String) - Method in class org.apache.flink.runtime.util.DependencyVisitor.SignatureVisitorImpl
-
- visitLdcInsn(Object) - Method in class org.apache.flink.runtime.util.DependencyVisitor.MethodVisitorImpl
-
- visitLocalVariable(String, String, String, Label, Label, int) - Method in class org.apache.flink.runtime.util.DependencyVisitor.MethodVisitorImpl
-
- visitMethod(int, String, String, String, String[]) - Method in class org.apache.flink.runtime.util.DependencyVisitor
-
- visitMethodInsn(int, String, String, String) - Method in class org.apache.flink.runtime.util.DependencyVisitor.MethodVisitorImpl
-
- visitMethodInsn(int, String, String, String, boolean) - Method in class org.apache.flink.runtime.util.DependencyVisitor.MethodVisitorImpl
-
- visitMultiANewArrayInsn(String, int) - Method in class org.apache.flink.runtime.util.DependencyVisitor.MethodVisitorImpl
-
- Visitor<T extends Visitable<T>> - Interface in org.apache.flink.util
-
A visitor encapsulates functionality that is applied to each node in the process of a traversal of a tree or DAG.
- visitParameterAnnotation(int, String, boolean) - Method in class org.apache.flink.runtime.util.DependencyVisitor.MethodVisitorImpl
-
- visitParameterType() - Method in class org.apache.flink.runtime.util.DependencyVisitor.SignatureVisitorImpl
-
- visitReturnType() - Method in class org.apache.flink.runtime.util.DependencyVisitor.SignatureVisitorImpl
-
- VISITS - Static variable in class org.apache.flink.examples.java.relational.util.WebLogData
-
- VISITS - Static variable in class org.apache.flink.test.testdata.WebLogAnalysisData
-
- visitTryCatchBlock(Label, Label, Label, String) - Method in class org.apache.flink.runtime.util.DependencyVisitor.MethodVisitorImpl
-
- visitTypeAnnotation(int, TypePath, String, boolean) - Method in class org.apache.flink.runtime.util.DependencyVisitor.FieldVisitorImpl
-
- visitTypeInsn(int, String) - Method in class org.apache.flink.runtime.util.DependencyVisitor.MethodVisitorImpl
-
- VOID - Static variable in class org.apache.flink.api.common.typeinfo.Types
-
Returns type information for
Void
.
- VOID_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
-
- VoidBackPressureStatsTracker - Enum in org.apache.flink.runtime.rest.handler.legacy.backpressure
-
- VoidBlobStore - Class in org.apache.flink.runtime.blob
-
A blob store doing nothing.
- VoidBlobStore() - Constructor for class org.apache.flink.runtime.blob.VoidBlobStore
-
- VoidBlobWriter - Class in org.apache.flink.runtime.blob
-
BlobWriter which does not support writing BLOBs to a store.
- VoidBlobWriter() - Constructor for class org.apache.flink.runtime.blob.VoidBlobWriter
-
- VoidHistoryServerArchivist - Enum in org.apache.flink.runtime.dispatcher
-
- VoidNamespace - Class in org.apache.flink.queryablestate.client
-
Singleton placeholder class for state without a namespace.
- VoidNamespace - Class in org.apache.flink.runtime.state
-
Singleton placeholder class for state without a namespace.
- VoidNamespaceSerializer - Class in org.apache.flink.queryablestate.client
-
- VoidNamespaceSerializer() - Constructor for class org.apache.flink.queryablestate.client.VoidNamespaceSerializer
-
- VoidNamespaceSerializer - Class in org.apache.flink.runtime.state
-
- VoidNamespaceSerializer() - Constructor for class org.apache.flink.runtime.state.VoidNamespaceSerializer
-
- VoidNamespaceTypeInfo - Class in org.apache.flink.queryablestate.client
-
- VoidNamespaceTypeInfo() - Constructor for class org.apache.flink.queryablestate.client.VoidNamespaceTypeInfo
-
- VoidNamespaceTypeInfo - Class in org.apache.flink.runtime.state
-
- VoidNamespaceTypeInfo() - Constructor for class org.apache.flink.runtime.state.VoidNamespaceTypeInfo
-
- VoidSerializer - Class in org.apache.flink.api.common.typeutils.base
-
- VoidSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.VoidSerializer
-