- 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.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.
- AbstractCachedBuildSideJoinDriver<IT1,IT2,OT> - Class in org.apache.flink.runtime.operators
-
- AbstractCachedBuildSideJoinDriver(int, int) - Constructor for class org.apache.flink.runtime.operators.AbstractCachedBuildSideJoinDriver
-
- 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
-
- 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
-
- 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.
- AbstractFileStateHandle - Class in org.apache.flink.runtime.state.filesystem
-
Base class for state that is stored in a file.
- AbstractFileStateHandle(Path) - Constructor for class org.apache.flink.runtime.state.filesystem.AbstractFileStateHandle
-
Creates a new file state for the given file path.
- AbstractFlinkYarnClient - Class in org.apache.flink.runtime.yarn
-
Abstract interface for an implementation of a Flink on YARN client to deploy.
- AbstractFlinkYarnClient() - Constructor for class org.apache.flink.runtime.yarn.AbstractFlinkYarnClient
-
- AbstractFlinkYarnCluster - Class in org.apache.flink.runtime.yarn
-
Abstract class for interacting with a running Flink cluster within YARN.
- AbstractFlinkYarnCluster() - Constructor for class org.apache.flink.runtime.yarn.AbstractFlinkYarnCluster
-
- AbstractFsState<K,N,SV,S extends org.apache.flink.api.common.state.State,SD extends org.apache.flink.api.common.state.StateDescriptor<S,?>> - Class in org.apache.flink.runtime.state.filesystem
-
Base class for partitioned ListState
implementations that are backed by a regular
heap hash map.
- AbstractFsState(FsStateBackend, TypeSerializer<K>, TypeSerializer<N>, TypeSerializer<SV>, SD) - Constructor for class org.apache.flink.runtime.state.filesystem.AbstractFsState
-
- AbstractFsState(FsStateBackend, TypeSerializer<K>, TypeSerializer<N>, TypeSerializer<SV>, SD, HashMap<N, Map<K, SV>>) - Constructor for class org.apache.flink.runtime.state.filesystem.AbstractFsState
-
- AbstractFsStateSnapshot<K,N,SV,S extends org.apache.flink.api.common.state.State,SD extends org.apache.flink.api.common.state.StateDescriptor<S,?>> - Class in org.apache.flink.runtime.state.filesystem
-
A snapshot of a heap key/value state stored in a file.
- AbstractFsStateSnapshot(TypeSerializer<K>, TypeSerializer<N>, TypeSerializer<SV>, SD, Path) - Constructor for class org.apache.flink.runtime.state.filesystem.AbstractFsStateSnapshot
-
Creates a new state snapshot with data in the file system.
- 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
-
- AbstractHeapState<K,N,SV,S extends org.apache.flink.api.common.state.State,SD extends org.apache.flink.api.common.state.StateDescriptor<S,?>,Backend extends AbstractStateBackend> - Class in org.apache.flink.runtime.state
-
Base class for partitioned ListState
implementations that are backed by a regular
heap hash map.
- AbstractHeapState(TypeSerializer<K>, TypeSerializer<N>, TypeSerializer<SV>, SD) - Constructor for class org.apache.flink.runtime.state.AbstractHeapState
-
Creates a new empty key/value state.
- AbstractHeapState(TypeSerializer<K>, TypeSerializer<N>, TypeSerializer<SV>, SD, HashMap<N, Map<K, SV>>) - Constructor for class org.apache.flink.runtime.state.AbstractHeapState
-
Creates a new key/value state for the given hash map of key/value pairs.
- 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() - Constructor for class org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
-
- AbstractIterativeTask<S extends org.apache.flink.api.common.functions.Function,OT> - Class in org.apache.flink.runtime.iterative.task
-
The abstract base class for all tasks able to participate in an iteration.
- AbstractIterativeTask() - Constructor for class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
-
- AbstractMemState<K,N,SV,S extends org.apache.flink.api.common.state.State,SD extends org.apache.flink.api.common.state.StateDescriptor<S,?>> - Class in org.apache.flink.runtime.state.memory
-
Base class for partitioned ListState
implementations that are backed by a regular
heap hash map.
- AbstractMemState(TypeSerializer<K>, TypeSerializer<N>, TypeSerializer<SV>, SD) - Constructor for class org.apache.flink.runtime.state.memory.AbstractMemState
-
- AbstractMemState(TypeSerializer<K>, TypeSerializer<N>, TypeSerializer<SV>, SD, HashMap<N, Map<K, SV>>) - Constructor for class org.apache.flink.runtime.state.memory.AbstractMemState
-
- AbstractMemStateSnapshot<K,N,SV,S extends org.apache.flink.api.common.state.State,SD extends org.apache.flink.api.common.state.StateDescriptor<S,?>> - Class in org.apache.flink.runtime.state.memory
-
- AbstractMemStateSnapshot(TypeSerializer<K>, TypeSerializer<N>, TypeSerializer<SV>, SD, byte[]) - Constructor for class org.apache.flink.runtime.state.memory.AbstractMemStateSnapshot
-
Creates a new heap memory state snapshot.
- 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
-
- 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
-
- 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
-
- 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
-
- AbstractStateBackend - Class in org.apache.flink.runtime.state
-
A state backend defines how state is stored and snapshotted during checkpoints.
- AbstractStateBackend() - Constructor for class org.apache.flink.runtime.state.AbstractStateBackend
-
- AbstractStateBackend.CheckpointStateOutputStream - Class in org.apache.flink.runtime.state
-
- AbstractStateBackend.CheckpointStateOutputView - Class in org.apache.flink.runtime.state
-
A dedicated DataOutputView stream that produces a StateHandle<DataInputView>
when closed.
- 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 internal and user-defined accumulators.
- AccumulatorRegistry(JobID, ExecutionAttemptID) - Constructor for class org.apache.flink.runtime.accumulators.AccumulatorRegistry
-
- AccumulatorRegistry.Metric - Enum in org.apache.flink.runtime.accumulators
-
Flink metrics supported
- AccumulatorRegistry.Reporter - Interface in org.apache.flink.runtime.accumulators
-
Interface for Flink's internal accumulators.
- AccumulatorSnapshot - Class in org.apache.flink.runtime.accumulators
-
This class encapsulates a map of accumulators for a single task.
- AccumulatorSnapshot(JobID, ExecutionAttemptID, Map<AccumulatorRegistry.Metric, Accumulator<?, ?>>, Map<String, Accumulator<?, ?>>) - Constructor for class org.apache.flink.runtime.accumulators.AccumulatorSnapshot
-
- acknowledgeCheckpoint(long) - 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, StateHandle<?>) - 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 - 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) - Constructor for class org.apache.flink.runtime.messages.checkpoint.AcknowledgeCheckpoint
-
- AcknowledgeCheckpoint(JobID, ExecutionAttemptID, long, SerializedValue<StateHandle<?>>, long) - Constructor for class org.apache.flink.runtime.messages.checkpoint.AcknowledgeCheckpoint
-
- acknowledgeCheckpoint(long) - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
-
- acknowledgeCheckpoint(long, StateHandle<?>) - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
-
- acknowledgeTask(ExecutionAttemptID, SerializedValue<StateHandle<?>>, long) - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
-
- 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.
- AdaptiveSpanningRecordDeserializer<T extends org.apache.flink.core.io.IOReadableWritable> - Class in org.apache.flink.runtime.io.network.api.serialization
-
- AdaptiveSpanningRecordDeserializer() - Constructor for class org.apache.flink.runtime.io.network.api.serialization.AdaptiveSpanningRecordDeserializer
-
- add(Buffer, int) - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
-
Adds a buffer to the subpartition with the given index.
- add(Buffer) - Method in class org.apache.flink.runtime.io.network.partition.ResultSubpartition
-
- add(T) - Method in class org.apache.flink.runtime.state.filesystem.FsFoldingState
-
- add(V) - Method in class org.apache.flink.runtime.state.filesystem.FsListState
-
- add(V) - Method in class org.apache.flink.runtime.state.filesystem.FsReducingState
-
- add(T) - Method in class org.apache.flink.runtime.state.GenericFoldingState
-
- add(T) - Method in class org.apache.flink.runtime.state.GenericListState
-
- add(T) - Method in class org.apache.flink.runtime.state.GenericReducingState
-
- add(T) - Method in class org.apache.flink.runtime.state.memory.MemFoldingState
-
- add(V) - Method in class org.apache.flink.runtime.state.memory.MemListState
-
- add(V) - Method in class org.apache.flink.runtime.state.memory.MemReducingState
-
- add(int) - Method in class org.apache.flink.runtime.util.IntArrayList
-
- add(long) - Method in class org.apache.flink.runtime.util.LongArrayList
-
- add(V) - Method in class org.apache.flink.runtime.util.LRUCache
-
- add(String, T) - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
-
Creates a state handle and stores it in ZooKeeper with create mode CreateMode.PERSISTENT
.
- add(String, T, CreateMode) - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
-
Creates a state handle and stores it in ZooKeeper.
- addAll(Configuration) - Method in class org.apache.flink.runtime.operators.util.TaskConfig.DelegatingConfiguration
-
- addAll(Configuration, String) - Method in class org.apache.flink.runtime.operators.util.TaskConfig.DelegatingConfiguration
-
- addBlob(BlobKey) - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
Adds the BLOB referenced by the key to the JobGraph's dependencies.
- addBroadcastInputToGroup(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- 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.ZooKeeperCompletedCheckpointStore
-
Synchronously writes the new checkpoints to ZooKeeper and asynchronously removes older ones.
- 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.
- addConsumer(JobEdge) - Method in class org.apache.flink.runtime.jobgraph.IntermediateDataSet
-
- addHash(int) - Method in class org.apache.flink.runtime.operators.util.BloomFilter
-
- addInputToGroup(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- addInstanceListener(InstanceListener) - Method in class org.apache.flink.runtime.instance.InstanceManager
-
- 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.
- addList(List<T>) - Method in class org.apache.flink.runtime.util.UnionIterator
-
- addListener(EventListener<Buffer>) - Method in interface org.apache.flink.runtime.io.network.buffer.BufferProvider
-
Adds a buffer availability listener to the buffer provider.
- addNameSpace(Set<String>) - Method in class org.apache.flink.runtime.util.DependencyVisitor
-
- 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.
- addRecord(T) - Method in interface org.apache.flink.runtime.io.network.api.serialization.RecordSerializer
-
- addRecord(T) - Method in class org.apache.flink.runtime.io.network.api.serialization.SpanningRecordSerializer
-
- 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
-
- address() - Method in class org.apache.flink.runtime.instance.InstanceConnectionInfo
-
Returns the network address the instance's task manager binds its sockets to.
- 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
-
- addToMessageDigest(MessageDigest) - Method in class org.apache.flink.runtime.blob.BlobKey
-
- 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
-
- 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.
- aggregateUserAccumulators() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
Merges all accumulator results from the tasks previously executed in the Executions.
- AGGREGATOR_NAME - Static variable in class org.apache.flink.runtime.iterative.convergence.WorksetEmptyConvergenceCriterion
-
- 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
-
- allBufferPools - Variable in class org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
-
- 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
-
- 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
-
- 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.
- 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(JobID, SlotSharingGroupAssignment) - Method in class org.apache.flink.runtime.instance.Instance
-
Allocates a shared slot on this TaskManager instance.
- allocateSimpleSlot(JobID) - Method in class org.apache.flink.runtime.instance.Instance
-
Allocates a simple slot on this TaskManager instance.
- 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
-
- AllWorkersDoneEvent - Class in org.apache.flink.runtime.iterative.event
-
- 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
-
- AnnotationVisitorImpl(int) - Constructor for class org.apache.flink.runtime.util.DependencyVisitor.AnnotationVisitorImpl
-
- appendRecord(T) - Method in class org.apache.flink.runtime.operators.hash.InMemoryPartition
-
Inserts the given object into the current buffer.
- ArrayListSerializer<T> - Class in org.apache.flink.runtime.state
-
- ArrayListSerializer(TypeSerializer<T>) - Constructor for class org.apache.flink.runtime.state.ArrayListSerializer
-
- 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.
- assignPartition(int, byte) - Static method in class org.apache.flink.runtime.operators.hash.MutableHashTable
-
Assigns a partition to a bucket.
- 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
-
- associateWithTaskManagerAndJobManager(ActorGateway, ActorGateway) - Method in class org.apache.flink.runtime.io.network.NetworkEnvironment
-
This associates the network environment with a TaskManager and JobManager.
- 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
-
- 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.
- AsynchronousKvStateSnapshot<K,N,S extends org.apache.flink.api.common.state.State,SD extends org.apache.flink.api.common.state.StateDescriptor<S,?>,Backend extends AbstractStateBackend> - Class in org.apache.flink.runtime.state
-
KvStateSnapshot
that asynchronously materializes the state that it represents.
- AsynchronousKvStateSnapshot() - Constructor for class org.apache.flink.runtime.state.AsynchronousKvStateSnapshot
-
- AsynchronousStateHandle<T> - Class in org.apache.flink.runtime.state
-
StateHandle
that can asynchronously materialize the state that it represents.
- AsynchronousStateHandle() - Constructor for class org.apache.flink.runtime.state.AsynchronousStateHandle
-
- 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
-
- attachJobGraph(List<JobVertex>) - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- available() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopDataInputStream
-
- availableMemory - Variable in class org.apache.flink.runtime.operators.hash.MutableHashTable
-
The free memory segments currently available to the hash join.
- awaitStartOfSuperstepOrTermination(int) - Method in class org.apache.flink.runtime.iterative.concurrent.SuperstepKickoffLatch
-
- cachePartitionInfo(PartialInputChannelDeploymentDescriptor) - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- 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.
- 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
-
- cancel() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- 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() - 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
-
- cancelAndReleaseAllSlots() - Method in class org.apache.flink.runtime.instance.Instance
-
- cancelChainedTasks(List<ChainedDriver<?, ?>>) - Static method in class org.apache.flink.runtime.operators.BatchTask
-
- cancelExecution() - Method in class org.apache.flink.runtime.taskmanager.Task
-
Cancels the task execution.
- 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.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
-
- 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
-
- canEqual(Object) - Method in class org.apache.flink.runtime.state.ArrayListSerializer
-
- 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
.
- 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
-
- 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
-
- channelIndex - Variable in class org.apache.flink.runtime.io.network.partition.consumer.InputChannel
-
- ChannelReaderInputView - Class in org.apache.flink.runtime.io.disk.iomanager
-
A
DataInputView
that is backed by a
BlockChannelReader
, making it effectively a data input
stream.
- 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 org.apache.flink.core.io.IOReadableWritable> - Interface in org.apache.flink.runtime.io.network.api.writer
-
The
ChannelSelector
determines to which logical channels a record
should be written to.
- 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
-
A
DataOutputView
that is backed by a
BlockChannelWriter
, making it effectively a data output
stream.
- 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.
- checkedDownCast(long) - Static method in class org.apache.flink.runtime.util.MathUtils
-
Casts the given value to a 32 bit integer, if it can be safely done.
- checkErroneous() - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousFileIOChannel
-
Checks the exception state of this channel.
- checkError() - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputChannel
-
Checks for an error and rethrows it if one was reported.
- CHECKPOINT_DIRECTORY_URI_CONF_KEY - Static variable in class org.apache.flink.runtime.state.filesystem.FsStateBackendFactory
-
The key under which the config stores the directory where checkpoints should be stored
- CheckpointBarrier - Class in org.apache.flink.runtime.io.network.api
-
Checkpoint barriers are used to align checkpoints throughout the streaming topology.
- CheckpointBarrier() - Constructor for class org.apache.flink.runtime.io.network.api.CheckpointBarrier
-
- CheckpointBarrier(long, long) - Constructor for class org.apache.flink.runtime.io.network.api.CheckpointBarrier
-
- CheckpointCoordinator - Class in org.apache.flink.runtime.checkpoint
-
The checkpoint coordinator coordinates the distributed snapshots of operators and state.
- CheckpointCoordinator(JobID, long, long, ExecutionVertex[], ExecutionVertex[], ExecutionVertex[], ClassLoader, CheckpointIDCounter, CompletedCheckpointStore, RecoveryMode) - Constructor for class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
- CheckpointCoordinator(JobID, long, long, long, int, ExecutionVertex[], ExecutionVertex[], ExecutionVertex[], ClassLoader, CheckpointIDCounter, CompletedCheckpointStore, RecoveryMode, CheckpointStatsTracker) - Constructor for class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
- 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, UUID) - Constructor for class org.apache.flink.runtime.checkpoint.CheckpointCoordinatorDeActivator
-
- checkpointIdCounter - Variable in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
Checkpoint ID counter to ensure ascending IDs.
- CheckpointIDCounter - Interface in org.apache.flink.runtime.checkpoint
-
A checkpoint ID counter.
- 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.
- CheckpointRecoveryFactory - Interface in org.apache.flink.runtime.checkpoint
-
A factory for per Job checkpoint recovery components.
- CheckpointStateOutputStream() - Constructor for class org.apache.flink.runtime.state.AbstractStateBackend.CheckpointStateOutputStream
-
- CheckpointStateOutputView(AbstractStateBackend.CheckpointStateOutputStream) - Constructor for class org.apache.flink.runtime.state.AbstractStateBackend.CheckpointStateOutputView
-
- checkpointStateSerializable(S, long, long) - Method in class org.apache.flink.runtime.state.AbstractStateBackend
-
Writes the given state into the checkpoint, and returns a handle that can retrieve the state back.
- checkpointStateSerializable(S, long, long) - Method in class org.apache.flink.runtime.state.filesystem.FsStateBackend
-
- checkpointStateSerializable(S, long, long) - Method in class org.apache.flink.runtime.state.memory.MemoryStateBackend
-
Serialized the given state into bytes using Java serialization and creates a state handle that
can re-create that state.
- CheckpointStats - Class in org.apache.flink.runtime.checkpoint.stats
-
Statistics for a specific checkpoint.
- CheckpointStats(long, long, long, long) - Constructor for class org.apache.flink.runtime.checkpoint.stats.CheckpointStats
-
Creates a checkpoint statistic.
- CheckpointStatsTracker - Interface in org.apache.flink.runtime.checkpoint.stats
-
A tracker for checkpoint statistics.
- 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
-
- 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.
- 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(Logger, Closeable...) - Static method in class org.apache.flink.runtime.util.IOUtils
-
Close the Closeable objects and
ignore any
IOException
or
null pointers.
- clear() - Method in class org.apache.flink.runtime.io.network.api.serialization.AdaptiveSpanningRecordDeserializer
-
- 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() - 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.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.state.AbstractHeapState
-
- clear() - Method in class org.apache.flink.runtime.state.GenericFoldingState
-
- clear() - Method in class org.apache.flink.runtime.state.GenericListState
-
- clear() - Method in class org.apache.flink.runtime.state.GenericReducingState
-
- clear() - Method in class org.apache.flink.runtime.util.DataOutputSerializer
-
- 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.runtime.util.UnionIterator
-
- clearAll() - Method in class org.apache.flink.runtime.io.network.TaskEventDispatcher
-
- 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.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
-
- clearCurrentBuffer() - Method in interface org.apache.flink.runtime.io.network.api.serialization.RecordSerializer
-
- clearCurrentBuffer() - Method in class org.apache.flink.runtime.io.network.api.serialization.SpanningRecordSerializer
-
- clearPartitions() - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
-
This method clears all partitions currently residing (partially) in memory.
- clearReaders(MutableReader<?>[]) - Static method in class org.apache.flink.runtime.operators.BatchTask
-
- clearTaskAssignment() - Method in class org.apache.flink.runtime.jobmanager.scheduler.SlotSharingGroup
-
- clearWriters(List<RecordWriter<?>>) - Static method in class org.apache.flink.runtime.operators.BatchTask
-
- CLIENT_CONNECT_TIMEOUT_SECONDS - Static variable in class org.apache.flink.runtime.io.network.netty.NettyConfig
-
- close() - Method in class org.apache.flink.runtime.blob.BlobClient
-
- 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 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(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.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.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
-
- 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.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.SimpleCloseableInputProvider
-
- close() - Method in class org.apache.flink.runtime.state.AbstractStateBackend.CheckpointStateOutputView
-
- close() - Method in class org.apache.flink.runtime.state.AbstractStateBackend
-
Closes the state backend, releasing all internal resources, but does not delete any persistent
checkpoint data.
- close() - Method in class org.apache.flink.runtime.state.filesystem.FsStateBackend
-
- close() - Method in class org.apache.flink.runtime.state.filesystem.FsStateBackend.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.memory.MemoryStateBackend
-
- close() - Method in class org.apache.flink.runtime.state.memory.MemoryStateBackend.MemoryCheckpointOutputStream
-
- CloseableInputProvider<E> - Interface in org.apache.flink.runtime.operators.util
-
Utility interface for a provider of an input that can be closed.
- 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
-
- closeAndGetBytes() - Method in class org.apache.flink.runtime.state.memory.MemoryStateBackend.MemoryCheckpointOutputStream
-
Closes the stream and returns the byte array containing the stream's data.
- closeAndGetHandle() - Method in class org.apache.flink.runtime.state.AbstractStateBackend.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.AbstractStateBackend.CheckpointStateOutputView
-
Closes the stream and gets a state handle that can create a DataInputView.
- closeAndGetHandle() - Method in class org.apache.flink.runtime.state.filesystem.FsStateBackend.FsCheckpointStateOutputStream
-
- closeAndGetHandle() - Method in class org.apache.flink.runtime.state.memory.MemoryStateBackend.MemoryCheckpointOutputStream
-
- closeAndGetPath() - Method in class org.apache.flink.runtime.state.filesystem.FsStateBackend.FsCheckpointStateOutputStream
-
Closes the stream and returns the path to the file that contains the stream's data.
- 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.
- 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.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.
- 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
-
- closeSocket(Socket) - Static method in class org.apache.flink.runtime.util.IOUtils
-
- closeStream(Closeable) - Static method in class org.apache.flink.runtime.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.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
-
- closeUserCode(Function) - Static method in class org.apache.flink.runtime.operators.BatchTask
-
Closes the given stub using its RichFunction.close()
method.
- 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
-
- 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
-
- 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.
- CoGroupWithSolutionSetFirstDriver<IT1,IT2,OT> - Class in org.apache.flink.runtime.operators
-
- CoGroupWithSolutionSetFirstDriver() - Constructor for class org.apache.flink.runtime.operators.CoGroupWithSolutionSetFirstDriver
-
- 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.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(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.
- 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
-
- CombiningSpillingThread(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.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) - 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) - 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
-
- 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)
- 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
-
- comparator - Variable in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SpillingThread
-
- compare(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) - Method in class org.apache.flink.runtime.operators.sort.NormalizedKeySorter
-
- compareTo(BlobKey) - Method in class org.apache.flink.runtime.blob.BlobKey
-
- compareTo(BlockLocation) - Method in class org.apache.flink.runtime.fs.hdfs.HadoopBlockLocation
-
- compareTo(InstanceConnectionInfo) - Method in class org.apache.flink.runtime.instance.InstanceConnectionInfo
-
- CompletedCheckpoint - Class in org.apache.flink.runtime.checkpoint
-
A successful checkpoint describes a checkpoint after all required tasks acknowledged it (with their state)
and that is considered completed.
- CompletedCheckpoint(JobID, long, long, long, ArrayList<StateForTask>) - Constructor for class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
-
- CompletedCheckpointStore - Interface in org.apache.flink.runtime.checkpoint
-
- compositeBuffer() - Method in class org.apache.flink.runtime.io.network.netty.NettyBufferPool
-
- compositeBuffer(int) - Method in class org.apache.flink.runtime.io.network.netty.NettyBufferPool
-
- compositeDirectBuffer() - Method in class org.apache.flink.runtime.io.network.netty.NettyBufferPool
-
- compositeDirectBuffer(int) - Method in class org.apache.flink.runtime.io.network.netty.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
-
- 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.
- 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
-
- 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
-
- connecDataSet(IntermediateDataSet) - Method in class org.apache.flink.runtime.jobgraph.JobEdge
-
- 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
-
- connectIdInput(IntermediateDataSetID, DistributionPattern) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
- 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(InstanceConnectionInfo, int) - Constructor for class org.apache.flink.runtime.io.network.ConnectionID
-
- ConnectionID(InetSocketAddress, int) - Constructor for class org.apache.flink.runtime.io.network.ConnectionID
-
- 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) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
- connectNewDataSetAsInput(JobVertex, DistributionPattern, ResultPartitionType) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
- connectNewDataSetAsInput(JobVertex, DistributionPattern, ResultPartitionType, boolean) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
- connectSource(int, IntermediateResult, JobEdge, int) - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- connectToCluster() - Method in class org.apache.flink.runtime.yarn.AbstractFlinkYarnCluster
-
Connect the FlinkYarnCluster to the ApplicationMaster.
- connectToPredecessors(Map<IntermediateDataSetID, IntermediateResult>) - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
- constructLogString(String, String, AbstractInvokable) - Static method in class org.apache.flink.runtime.operators.BatchTask
-
Utility function that composes a string for logging purposes.
- consumeAndCacheRemainingData() - Method in class org.apache.flink.runtime.operators.resettable.SpillingResettableMutableObjectIterator
-
- contains(Object) - Method in class org.apache.flink.runtime.jobmanager.scheduler.SetQueue
-
- containsAll(Collection<?>) - Method in class org.apache.flink.runtime.jobmanager.scheduler.SetQueue
-
- containsKey(K) - Method in class org.apache.flink.runtime.util.LRUCacheMap
-
- copy(Path, Path, boolean) - Static method in class org.apache.flink.runtime.filecache.FileCache
-
- 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
-
- copy1 - Variable in class org.apache.flink.runtime.operators.sort.AbstractMergeIterator
-
- copy2 - Variable in class org.apache.flink.runtime.operators.sort.AbstractMergeIterator
-
- copyBytes(InputStream, OutputStream, int, boolean) - Static method in class org.apache.flink.runtime.util.IOUtils
-
Copies from one stream to another.
- copyBytes(InputStream, OutputStream) - Static method in class org.apache.flink.runtime.util.IOUtils
-
Copies from one stream to another.
- copyBytes(InputStream, OutputStream, boolean) - Static method in class org.apache.flink.runtime.util.IOUtils
-
Copies from one stream to another.
- 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
-
- countBuffers() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
-
- create(Configuration) - Static method in class org.apache.flink.runtime.executiongraph.restart.FixedDelayRestartStrategy
-
Creates a FixedDelayRestartStrategy from the given Configuration.
- create(Configuration) - Static method in class org.apache.flink.runtime.executiongraph.restart.NoRestartStrategy
-
Creates a NoRestartStrategy instance.
- create(Path, boolean, int, short, long) - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileSystem
-
- create(Path, boolean) - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileSystem
-
- create(Path, boolean, int, short, long) - Method in class org.apache.flink.runtime.fs.maprfs.MapRFileSystem
-
- create(Path, boolean) - Method in class org.apache.flink.runtime.fs.maprfs.MapRFileSystem
-
- create(String, JobID, ExecutionAttemptID, InputGateDeploymentDescriptor, NetworkEnvironment) - Static method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
-
Creates an input gate and all of its input channels.
- create() - Static method in class org.apache.flink.runtime.state.memory.MemoryStateBackend
-
Gets the default instance of this state backend, using the default maximal state size.
- create() - Static method in class org.apache.flink.runtime.util.LRUCache
-
- create() - Static method in class org.apache.flink.runtime.util.LRUCacheMap
-
- createActivatorDeactivator(ActorSystem, UUID) - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
- createActivatorDeactivator(ActorSystem, UUID) - Method in class org.apache.flink.runtime.checkpoint.SavepointCoordinator
-
- createAndAddResultDataSet(ResultPartitionType) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
- createAndAddResultDataSet(IntermediateDataSetID, ResultPartitionType) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
- 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
-
- 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, boolean) - 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, boolean) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
-
- 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.
- 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.
- 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(long, long) - Method in class org.apache.flink.runtime.state.AbstractStateBackend
-
Creates an output stream that writes into the state of the given checkpoint.
- createCheckpointStateOutputStream(long, long) - Method in class org.apache.flink.runtime.state.filesystem.FsStateBackend
-
- createCheckpointStateOutputStream(long, long) - Method in class org.apache.flink.runtime.state.memory.MemoryStateBackend
-
- createCheckpointStateOutputView(long, long) - Method in class org.apache.flink.runtime.state.AbstractStateBackend
-
Creates a DataOutputView
stream that writes into the state of the given checkpoint.
- createCompletedCheckpoints(JobID, ClassLoader) - Method in interface org.apache.flink.runtime.checkpoint.CheckpointRecoveryFactory
-
- createCompletedCheckpoints(JobID, ClassLoader) - Method in class org.apache.flink.runtime.checkpoint.StandaloneCheckpointRecoveryFactory
-
- createCompletedCheckpoints(JobID, ClassLoader) - Method in class org.apache.flink.runtime.checkpoint.ZooKeeperCheckpointRecoveryFactory
-
- createCompletedCheckpoints(CuratorFramework, Configuration, JobID, int, ClassLoader) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
-
- 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
-
- createDetailsForJob(ExecutionGraph) - Static method in class org.apache.flink.runtime.webmonitor.WebMonitorUtils
-
- createFoldingState(TypeSerializer<N>, FoldingStateDescriptor<T, ACC>) - Method in class org.apache.flink.runtime.state.AbstractStateBackend
-
Creates and returns a new FoldingState
.
- createFoldingState(TypeSerializer<N>, FoldingStateDescriptor<T, ACC>) - Method in class org.apache.flink.runtime.state.filesystem.FsStateBackend
-
- createFoldingState(TypeSerializer<N>, FoldingStateDescriptor<T, ACC>) - Method in class org.apache.flink.runtime.state.memory.MemoryStateBackend
-
- createFromConfig(Configuration) - Static method in class org.apache.flink.runtime.checkpoint.SavepointStoreFactory
-
- createFromConfig(Configuration) - Static method in class org.apache.flink.runtime.executiongraph.restart.RestartStrategyFactory
-
- createFromConfig(Configuration) - Method in class org.apache.flink.runtime.state.filesystem.FsStateBackendFactory
-
- createFromConfig(Configuration) - Method in interface org.apache.flink.runtime.state.StateBackendFactory
-
Creates the state backend, optionally using the given configuration.
- createFsState(FsStateBackend, HashMap<N, Map<K, SV>>) - Method in class org.apache.flink.runtime.state.filesystem.AbstractFsStateSnapshot
-
- createFsState(FsStateBackend, HashMap<N, Map<K, ACC>>) - Method in class org.apache.flink.runtime.state.filesystem.FsFoldingState.Snapshot
-
- createFsState(FsStateBackend, HashMap<N, Map<K, ArrayList<V>>>) - Method in class org.apache.flink.runtime.state.filesystem.FsListState.Snapshot
-
- createFsState(FsStateBackend, HashMap<N, Map<K, V>>) - Method in class org.apache.flink.runtime.state.filesystem.FsReducingState.Snapshot
-
- createFsState(FsStateBackend, HashMap<N, Map<K, V>>) - Method in class org.apache.flink.runtime.state.filesystem.FsValueState.Snapshot
-
- createHeapSnapshot(Path) - Method in class org.apache.flink.runtime.state.filesystem.AbstractFsState
-
- createHeapSnapshot(Path) - Method in class org.apache.flink.runtime.state.filesystem.FsFoldingState
-
- createHeapSnapshot(Path) - Method in class org.apache.flink.runtime.state.filesystem.FsListState
-
- createHeapSnapshot(Path) - Method in class org.apache.flink.runtime.state.filesystem.FsReducingState
-
- createHeapSnapshot(Path) - Method in class org.apache.flink.runtime.state.filesystem.FsValueState
-
- createHeapSnapshot(byte[]) - Method in class org.apache.flink.runtime.state.memory.AbstractMemState
-
- createHeapSnapshot(byte[]) - Method in class org.apache.flink.runtime.state.memory.MemFoldingState
-
- createHeapSnapshot(byte[]) - Method in class org.apache.flink.runtime.state.memory.MemListState
-
- createHeapSnapshot(byte[]) - Method in class org.apache.flink.runtime.state.memory.MemReducingState
-
- createHeapSnapshot(byte[]) - Method in class org.apache.flink.runtime.state.memory.MemValueState
-
- createInputChannelDeploymentDescriptor(Execution) - Method in class org.apache.flink.runtime.deployment.PartialInputChannelDeploymentDescriptor
-
Creates a channel deployment descriptor by completing the partition location.
- createInputIterator(MutableReader<?>, TypeSerializerFactory<?>) - Method in class org.apache.flink.runtime.operators.BatchTask
-
- createInstance() - Method in class org.apache.flink.runtime.state.ArrayListSerializer
-
- createJarFile() - Method in class org.apache.flink.runtime.util.JarFileCreator
-
Creates a jar file which contains the previously added class.
- createJobClientActorProps(LeaderRetrievalService, FiniteDuration, boolean) - Static method in class org.apache.flink.runtime.client.JobClientActor
-
- 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
-
- createLeaderElectionService(Configuration) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
-
- createLeaderElectionService(CuratorFramework, Configuration) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
-
- createLeaderRetrievalService(Configuration) - Static method in class org.apache.flink.runtime.util.LeaderRetrievalUtils
-
- createLeaderRetrievalService(Configuration) - Static method in class org.apache.flink.runtime.util.StandaloneUtils
-
- createLeaderRetrievalService(Configuration, String) - Static method in class org.apache.flink.runtime.util.StandaloneUtils
-
- createLeaderRetrievalService(Configuration) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
-
- createListState(TypeSerializer<N>, ListStateDescriptor<T>) - Method in class org.apache.flink.runtime.state.AbstractStateBackend
-
Creates and returns a new ListState
.
- createListState(TypeSerializer<N>, ListStateDescriptor<T>) - Method in class org.apache.flink.runtime.state.filesystem.FsStateBackend
-
- createListState(TypeSerializer<N>, ListStateDescriptor<T>) - Method in class org.apache.flink.runtime.state.memory.MemoryStateBackend
-
- createLocal() - Static method in class org.apache.flink.runtime.deployment.ResultPartitionLocation
-
- createMemState(HashMap<N, Map<K, SV>>) - Method in class org.apache.flink.runtime.state.memory.AbstractMemStateSnapshot
-
- createMemState(HashMap<N, Map<K, ACC>>) - Method in class org.apache.flink.runtime.state.memory.MemFoldingState.Snapshot
-
- createMemState(HashMap<N, Map<K, ArrayList<V>>>) - Method in class org.apache.flink.runtime.state.memory.MemListState.Snapshot
-
- createMemState(HashMap<N, Map<K, V>>) - Method in class org.apache.flink.runtime.state.memory.MemReducingState.Snapshot
-
- createMemState(HashMap<N, Map<K, V>>) - Method in class org.apache.flink.runtime.state.memory.MemValueState.Snapshot
-
- 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
-
- createReadView(BufferProvider) - Method in class org.apache.flink.runtime.io.network.partition.ResultSubpartition
-
- createReducingState(TypeSerializer<N>, ReducingStateDescriptor<T>) - Method in class org.apache.flink.runtime.state.AbstractStateBackend
-
Creates and returns a new ReducingState
.
- createReducingState(TypeSerializer<N>, ReducingStateDescriptor<T>) - Method in class org.apache.flink.runtime.state.filesystem.FsStateBackend
-
- createReducingState(TypeSerializer<N>, ReducingStateDescriptor<T>) - Method in class org.apache.flink.runtime.state.memory.MemoryStateBackend
-
- createRemote(ConnectionID) - Static method in class org.apache.flink.runtime.deployment.ResultPartitionLocation
-
- createRestartStrategy(RestartStrategies.RestartStrategyConfiguration) - Static method in class org.apache.flink.runtime.executiongraph.restart.RestartStrategyFactory
-
Creates a
RestartStrategy
instance from the given
RestartStrategies.RestartStrategyConfiguration
.
- createRuntimeContext() - Method in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
-
- createRuntimeContext() - 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
-
- createSolutionSetUpdateOutputCollector(Collector<OT>) - Method in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
-
Creates a new solution set update output collector.
- createSubmittedJobGraphs(CuratorFramework, Configuration) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
-
- createSubpartitionView(int, BufferProvider) - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
-
Returns the requested subpartition.
- createSubpartitionView(ResultPartitionID, int, BufferProvider) - Method in class org.apache.flink.runtime.io.network.partition.ResultPartitionManager
-
- createSubpartitionView(ResultPartitionID, int, BufferProvider) - Method in interface org.apache.flink.runtime.io.network.partition.ResultPartitionProvider
-
Returns the requested intermediate result partition input view.
- 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.
- createUnknown() - Static method in class org.apache.flink.runtime.deployment.ResultPartitionLocation
-
- createValueState(TypeSerializer<N>, ValueStateDescriptor<T>) - Method in class org.apache.flink.runtime.state.AbstractStateBackend
-
Creates and returns a new ValueState
.
- createValueState(TypeSerializer<N>, ValueStateDescriptor<V>) - Method in class org.apache.flink.runtime.state.filesystem.FsStateBackend
-
- createValueState(TypeSerializer<N>, ValueStateDescriptor<V>) - Method in class org.apache.flink.runtime.state.memory.MemoryStateBackend
-
- createWorksetUpdateOutputCollector(Collector<OT>) - Method in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
-
- createWorksetUpdateOutputCollector() - Method in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
-
- 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
-
- crossMatchingGroup(Iterator<T1>, Iterator<T2>, FlatJoinFunction<T1, T2, O>, Collector<O>) - Method in class org.apache.flink.runtime.operators.sort.AbstractMergeIterator
-
- 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.
- currentIteration() - Method in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
-
- currentKey - Variable in class org.apache.flink.runtime.state.AbstractHeapState
-
The current key, which the next value methods will refer to
- currentKey - Variable in class org.apache.flink.runtime.state.AbstractStateBackend
-
- currentNamespace - Variable in class org.apache.flink.runtime.state.AbstractHeapState
-
The current namespace, which the access methods will refer to.
- currentNSState - Variable in class org.apache.flink.runtime.state.AbstractHeapState
-
Cache the state map for the current key.
- currentRecursionDepth - Variable in class org.apache.flink.runtime.operators.hash.MutableHashTable
-
The recursion depth of the partition that is currently processed.
- generatePlan(JobGraph) - Static method in class org.apache.flink.runtime.jobgraph.jsonplan.JsonPlanGenerator
-
- GenericFoldingState<K,N,T,ACC,Backend extends AbstractStateBackend,W extends org.apache.flink.api.common.state.ValueState<ACC> & KvState<K,N,org.apache.flink.api.common.state.ValueState<ACC>,org.apache.flink.api.common.state.ValueStateDescriptor<ACC>,Backend>> - Class in org.apache.flink.runtime.state
-
Generic implementation of FoldingState
based on a wrapped ValueState
.
- GenericFoldingState(ValueState<ACC>, FoldFunction<T, ACC>) - Constructor for class org.apache.flink.runtime.state.GenericFoldingState
-
Creates a new FoldingState
that wraps the given ValueState
.
- GenericListState<K,N,T,Backend extends AbstractStateBackend,W extends org.apache.flink.api.common.state.ValueState<ArrayList<T>> & KvState<K,N,org.apache.flink.api.common.state.ValueState<ArrayList<T>>,org.apache.flink.api.common.state.ValueStateDescriptor<ArrayList<T>>,Backend>> - Class in org.apache.flink.runtime.state
-
Generic implementation of ListState
based on a wrapped ValueState
.
- GenericListState(ValueState<ArrayList<T>>) - Constructor for class org.apache.flink.runtime.state.GenericListState
-
Creates a new ListState
that wraps the given ValueState
.
- GenericReducingState<K,N,T,Backend extends AbstractStateBackend,W extends org.apache.flink.api.common.state.ValueState<T> & KvState<K,N,org.apache.flink.api.common.state.ValueState<T>,org.apache.flink.api.common.state.ValueStateDescriptor<T>,Backend>> - Class in org.apache.flink.runtime.state
-
Generic implementation of ReducingState
based on a wrapped ValueState
.
- GenericReducingState(ValueState<T>, ReduceFunction<T>) - Constructor for class org.apache.flink.runtime.state.GenericReducingState
-
Creates a new ReducingState
that wraps the given ValueState
.
- get(JobID, String) - Method in class org.apache.flink.runtime.blob.BlobClient
-
Downloads the BLOB identified by the given job ID and key from the BLOB server.
- get(BlobKey) - Method in class org.apache.flink.runtime.blob.BlobClient
-
Downloads the BLOB identified by the given BLOB key from the BLOB server.
- get(String) - Method in class org.apache.flink.runtime.iterative.concurrent.Broker
-
blocking retrieval and removal of the object to share
- 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() - Method in class org.apache.flink.runtime.state.filesystem.FsFoldingState
-
- get() - Method in class org.apache.flink.runtime.state.filesystem.FsListState
-
- get() - Method in class org.apache.flink.runtime.state.filesystem.FsReducingState
-
- get() - Method in class org.apache.flink.runtime.state.GenericFoldingState
-
- get() - Method in class org.apache.flink.runtime.state.GenericListState
-
- get() - Method in class org.apache.flink.runtime.state.GenericReducingState
-
- get() - Method in class org.apache.flink.runtime.state.memory.MemFoldingState
-
- get() - Method in class org.apache.flink.runtime.state.memory.MemListState
-
- get() - Method in class org.apache.flink.runtime.state.memory.MemReducingState
-
- 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(K) - Method in class org.apache.flink.runtime.util.LRUCacheMap
-
- get(Throwable, ClassLoader) - Static method in exception org.apache.flink.runtime.util.SerializedThrowable
-
- get(String) - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
-
Gets a state handle from ZooKeeper.
- getAccessTime() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileStatus
-
- 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
-
- getAccumulatorResultsStringified() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
Returns the a stringified version of the user-defined accumulators.
- getAccumulators() - Method in class org.apache.flink.runtime.taskmanager.TaskExecutionState
-
Gets flink and user-defined accumulators in serialized form.
- getAccumulatorsSerialized() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
Gets a serialized accumulator map.
- getActorGateway() - Method in class org.apache.flink.runtime.instance.Instance
-
Returns the InstanceGateway of this Instance.
- getActorGatewayFuture() - Method in class org.apache.flink.runtime.util.LeaderRetrievalUtils.LeaderGatewayListener
-
- 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 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.util.LeaderConnectionInfo
-
- getAggregatedMetricAccumulators() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
- getAggregatedUserAccumulatorsStringified() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
- getAggregateJobVertexState(int[], int) - Static method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
- 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 class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
- 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
-
- getAll() - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
-
Gets all available state handles from ZooKeeper.
- getAllAggregators() - Method in class org.apache.flink.runtime.iterative.task.RuntimeAggregatorRegistry
-
- getAllCheckpoints() - Method in interface org.apache.flink.runtime.checkpoint.CompletedCheckpointStore
-
- getAllCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.ZooKeeperCompletedCheckpointStore
-
- 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
-
- getAllowQueuedScheduling() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
- getAllRegisteredInstances() - Method in class org.apache.flink.runtime.instance.InstanceManager
-
- getAllSortedByName() - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
-
Gets all available state handles from ZooKeeper sorted by name (ascending).
- 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
-
- getAllWriters() - Method in class org.apache.flink.runtime.taskmanager.Task
-
- 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
-
- getAndIncrementCheckpointId() - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
- getAndRemove(String) - Method in class org.apache.flink.runtime.iterative.concurrent.Broker
-
blocking retrieval and removal of the object to share
- getApplicationId() - Method in class org.apache.flink.runtime.yarn.AbstractFlinkYarnCluster
-
Returns a string representation of the ApplicationID assigned by YARN.
- getAssignedResource() - Method in class org.apache.flink.runtime.executiongraph.Execution
-
- getAssignedResourceLocation() - Method in class org.apache.flink.runtime.executiongraph.Execution
-
- getAttemptId() - Method in class org.apache.flink.runtime.executiongraph.Execution
-
- getAttemptNumber() - Method in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
-
Returns the attempt number of the subtask
- getAttemptNumber() - Method in class org.apache.flink.runtime.executiongraph.Execution
-
- getAverageDuration() - Method in interface org.apache.flink.runtime.checkpoint.stats.JobCheckpointStats
-
Returns the average checkpoint duration ever seen over all completed
checkpoints.
- getAverageStateSize() - Method in interface org.apache.flink.runtime.checkpoint.stats.JobCheckpointStats
-
Average the minimum checkpoint state size ever seen over all completed
checkpoints.
- getBasePath() - Method in class org.apache.flink.runtime.state.filesystem.FsStateBackend
-
Gets the base directory where all state-containing files are stored.
- getBlobServerPort() - Method in class org.apache.flink.runtime.execution.librarycache.BlobLibraryCacheManager
-
- 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
-
- getBlockSize() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileStatus
-
- getBoolean(String, boolean) - Method in class org.apache.flink.runtime.operators.util.TaskConfig.DelegatingConfiguration
-
- getBroadcastGroupSize(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getBroadcastInputName(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getBroadcastInputSerializer(int, ClassLoader) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getBroadcastVariable(String) - Method in class org.apache.flink.runtime.operators.util.DistributedRuntimeUDFContext
-
- getBroadcastVariableManager() - Method in interface org.apache.flink.runtime.execution.Environment
-
- getBroadcastVariableManager() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
-
- getBroadcastVariableWithInitializer(String, BroadcastVariableInitializer<T, C>) - Method in class org.apache.flink.runtime.operators.util.DistributedRuntimeUDFContext
-
- getBuffer() - Method in class org.apache.flink.runtime.io.network.partition.consumer.BufferOrEvent
-
- getBufferProvider() - Method in class 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
-
- 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
-
- getByteArray() - Method in class org.apache.flink.runtime.util.DataOutputSerializer
-
- getBytes(String, byte[]) - Method in class org.apache.flink.runtime.operators.util.TaskConfig.DelegatingConfiguration
-
- 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.
- getBytesWritten() - Method in class org.apache.flink.runtime.io.disk.iomanager.ChannelWriterOutputView
-
Gets the number of pay-load bytes already written.
- 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
-
- getCause() - Method in exception org.apache.flink.runtime.util.SerializedThrowable
-
- getCauseAsString() - Method in exception org.apache.flink.runtime.io.network.partition.ProducerFailedException
-
Returns the stringified cause of the producer failure.
- 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
-
- getChannel() - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.ChannelWithBlockCount
-
- 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
-
- getCheckpointCoordinator() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- getCheckpointDirectory() - Method in class org.apache.flink.runtime.state.filesystem.FsStateBackend
-
Gets the directory where this state backend stores its checkpoint data.
- 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.stats.CheckpointStats
-
Returns the ID of the checkpoint.
- getCheckpointId() - Method in class org.apache.flink.runtime.messages.checkpoint.AbstractCheckpointMessage
-
- getCheckpointId() - Method in class org.apache.flink.runtime.state.SerializedCheckpointData
-
Gets the checkpointId of the checkpoint.
- getCheckpointInterval() - Method in class org.apache.flink.runtime.jobgraph.tasks.JobSnapshottingSettings
-
- getCheckpointStatsTracker() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- getCheckpointTimeout() - Method in class org.apache.flink.runtime.jobgraph.tasks.JobSnapshottingSettings
-
- getCheckpointTimestamp() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
-
- getClass(String, Class<? extends T>, ClassLoader) - Method in class org.apache.flink.runtime.operators.util.TaskConfig.DelegatingConfiguration
-
- getClassLoader(JobID) - Method in class org.apache.flink.runtime.execution.librarycache.BlobLibraryCacheManager
-
- getClassLoader(JobID) - Method in class org.apache.flink.runtime.execution.librarycache.FallbackLibraryCacheManager
-
- getClassLoader(JobID) - Method in interface org.apache.flink.runtime.execution.librarycache.LibraryCacheManager
-
Returns the user code class loader associated with id.
- getClasspaths() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
- getClientChannelHandlers() - Method in interface org.apache.flink.runtime.io.network.netty.NettyProtocol
-
- getClientConnectTimeoutSeconds() - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
-
- getClientNumThreads() - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
-
- getClusterDescription() - Method in class org.apache.flink.runtime.yarn.AbstractFlinkYarnClient
-
Returns a String containing details about the cluster (NodeManagers, available memory, ...)
- getClusterStatus() - Method in class org.apache.flink.runtime.yarn.AbstractFlinkYarnCluster
-
Returns the latest cluster status, with number of Taskmanagers and slots
- getCollectedStates() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
-
- getCoLocationGroup() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
- getCoLocationGroup() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
- getComparatorWithCurrentReference() - Method in class org.apache.flink.runtime.util.NonReusingKeyGroupedIterator
-
- getComparatorWithCurrentReference() - Method in class org.apache.flink.runtime.util.ReusingKeyGroupedIterator
-
- 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.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.operators.util.TaskConfig
-
Gets the configuration that holds the actual values encoded.
- getConfiguration() - Method in class org.apache.flink.runtime.taskmanager.TaskManagerRuntimeInfo
-
Gets the configuration that the TaskManager was started with.
- 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
-
- getConsumedPartitionId() - Method in class org.apache.flink.runtime.deployment.InputChannelDeploymentDescriptor
-
- getConsumedPartitionLocation() - Method in class org.apache.flink.runtime.deployment.InputChannelDeploymentDescriptor
-
- 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
-
- getConvergenceCriterion(ClassLoader) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getConvergenceCriterionAggregatorName() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getCopyOfBuffer() - Method in class org.apache.flink.runtime.util.DataOutputSerializer
-
- getCount() - Method in interface org.apache.flink.runtime.checkpoint.stats.JobCheckpointStats
-
Returns the total number of completed checkpoints.
- 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
-
- getCurrentAssignedResource() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- 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 class org.apache.flink.runtime.io.network.api.serialization.AdaptiveSpanningRecordDeserializer
-
- getCurrentBuffer() - Method in interface org.apache.flink.runtime.io.network.api.serialization.RecordDeserializer
-
- getCurrentBuffer() - Method in interface org.apache.flink.runtime.io.network.api.serialization.RecordSerializer
-
- getCurrentBuffer() - Method in class org.apache.flink.runtime.io.network.api.serialization.SpanningRecordSerializer
-
- getCurrentBuffer() - Method in class org.apache.flink.runtime.io.network.api.serialization.SpillingAdaptiveSpanningRecordDeserializer
-
- getCurrentExecutionAttempt() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- getCurrentKey() - Method in class org.apache.flink.runtime.state.AbstractStateBackend
-
- 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
-
- 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
-
- 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.
- getDefaultBlockSize() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileSystem
-
- getDefaultBlockSize() - Method in class org.apache.flink.runtime.fs.maprfs.MapRFileSystem
-
- getDefaultIOMode() - Method in class org.apache.flink.runtime.io.network.NetworkEnvironment
-
- getDiagnostics() - Method in class org.apache.flink.runtime.yarn.AbstractFlinkYarnCluster
-
- getDirectMemoryStatsAsString(BufferPoolMXBean) - Static method in class org.apache.flink.runtime.taskmanager.MemoryLogger
-
Returns a String with the direct memory footprint.
- getDistributedCacheEntries() - Method in interface org.apache.flink.runtime.execution.Environment
-
- getDistributedCacheEntries() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
-
- getDistributionPattern() - Method in class org.apache.flink.runtime.jobgraph.JobEdge
-
Returns the distribution pattern used for this edge.
- getDouble(String, double) - Method in class org.apache.flink.runtime.operators.util.TaskConfig.DelegatingConfiguration
-
- 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.runtime.operators.util.TaskConfig
-
- getDuration() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
-
- getDuration() - Method in class org.apache.flink.runtime.checkpoint.StateForTask
-
- getDuration() - Method in class org.apache.flink.runtime.checkpoint.stats.CheckpointStats
-
Returns the duration in milliseconds.
- getDynamicPropertiesEncoded() - Method in class org.apache.flink.runtime.yarn.AbstractFlinkYarnClient
-
- getEagerlyDeployConsumers() - Method in class org.apache.flink.runtime.deployment.ResultPartitionDeploymentDescriptor
-
Returns whether consumers should be deployed eagerly (as soon as they
are registered at the result manager of the task manager).
- getEagerlyDeployConsumers() - Method in class org.apache.flink.runtime.executiongraph.IntermediateResult
-
- getEagerlyDeployConsumers() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
-
Returns whether consumers should be deployed eagerly (as soon as they
are registered at the result manager of the task manager).
- getEagerlyDeployConsumers() - Method in class org.apache.flink.runtime.jobgraph.IntermediateDataSet
-
Returns whether consumers should be deployed eagerly (as soon as they
are registered at the result manager of the task manager).
- getElementsCollectedAndReset() - Method in class org.apache.flink.runtime.iterative.io.WorksetUpdateOutputCollector
-
- getEndTime() - Method in class org.apache.flink.runtime.messages.webmonitor.JobDetails
-
- getEntryIterator() - Method in class org.apache.flink.runtime.operators.hash.AbstractMutableHashTable
-
- getEntryIterator() - Method in class org.apache.flink.runtime.operators.hash.CompactingHashTable
-
- getEnvironment() - Method in class org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
-
Returns the environment of this task.
- getError(ClassLoader) - Method in class org.apache.flink.runtime.taskmanager.TaskExecutionState
-
Gets the attached exception, which is in serialized form.
- getEvent() - Method in class org.apache.flink.runtime.io.network.partition.consumer.BufferOrEvent
-
- getExecutedVertex() - Method in class org.apache.flink.runtime.instance.SimpleSlot
-
Gets the task execution attempt currently executed in this slot.
- getExecutingThread() - Method in class org.apache.flink.runtime.taskmanager.Task
-
- getExecutionAttemptID() - Method in class org.apache.flink.runtime.accumulators.AccumulatorSnapshot
-
- getExecutionConfig() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- getExecutionConfig() - Method in class org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
-
Returns the global ExecutionConfig, obtained from the job configuration.
- getExecutionConfig() - Method in interface org.apache.flink.runtime.operators.TaskContext
-
- getExecutionContext() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
Returns the ExecutionContext associated with this ExecutionGraph.
- getExecutionGraph() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- getExecutionId() - Method in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
-
- 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
-
- getExecutionState() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- 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.
- 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 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.taskmanager.Task
-
If the task has failed, this method gets the exception that caused this task to fail.
- getFile(BlobKey) - Method in class org.apache.flink.runtime.execution.librarycache.BlobLibraryCacheManager
-
- getFile(BlobKey) - Method in class org.apache.flink.runtime.execution.librarycache.FallbackLibraryCacheManager
-
- getFile(BlobKey) - Method in interface org.apache.flink.runtime.execution.librarycache.LibraryCacheManager
-
Returns a file handle to the file identified by the blob key.
- getFileBlockLocations(FileStatus, long, long) - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileSystem
-
- getFileBlockLocations(FileStatus, long, long) - Method in class org.apache.flink.runtime.fs.maprfs.MapRFileSystem
-
- 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
-
- getFilePath() - Method in class org.apache.flink.runtime.state.filesystem.AbstractFileStateHandle
-
Gets the path where this handle's state is stored.
- getFileSize() - Method in class org.apache.flink.runtime.state.filesystem.AbstractFileStateHandle
-
Returns the file size in bytes.
- getFileStateSizeThreshold() - Method in class org.apache.flink.runtime.state.filesystem.FsStateBackend
-
Gets the size (in bytes) above which the state will written to files.
- getFileStatus(Path) - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileSystem
-
- getFileStatus(Path) - Method in class org.apache.flink.runtime.fs.maprfs.MapRFileSystem
-
- getFileSystem() - Method in class org.apache.flink.runtime.state.filesystem.AbstractFileStateHandle
-
Gets the file system that stores the file state.
- getFileSystem() - Method in class org.apache.flink.runtime.state.filesystem.FsStateBackend
-
Gets the file system handle for the file system that stores the state for this backend.
- getFinishedJobs() - Method in class org.apache.flink.runtime.messages.webmonitor.MultipleJobsDetails
-
- getFlinkAccumulators() - Method in class org.apache.flink.runtime.executiongraph.Execution
-
- getFlinkAccumulators() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
Gets the internal flink accumulator map of maps which contains some metrics.
- getFlinkConfiguration() - Method in class org.apache.flink.runtime.yarn.AbstractFlinkYarnClient
-
- getFlinkConfiguration() - Method in class org.apache.flink.runtime.yarn.AbstractFlinkYarnCluster
-
Return the Flink configuration object
- getFlinkLoggingConfigurationPath() - Method in class org.apache.flink.runtime.yarn.AbstractFlinkYarnClient
-
- getFloat(String, float) - Method in class org.apache.flink.runtime.operators.util.TaskConfig.DelegatingConfiguration
-
- getForForwardExchange(ExecutionMode) - Static method in enum org.apache.flink.runtime.io.network.DataExchangeMode
-
- getFormatDescription() - Method in class org.apache.flink.runtime.jobgraph.InputFormatVertex
-
- getFormatDescription() - Method in class org.apache.flink.runtime.jobgraph.OutputFormatVertex
-
- getForShuffleOrBroadcast(ExecutionMode) - Static method in enum org.apache.flink.runtime.io.network.DataExchangeMode
-
- getFQDNHostname() - Method in class org.apache.flink.runtime.instance.InstanceConnectionInfo
-
Returns the fully-qualified domain name the TaskManager.
- 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
-
- getFreeSlotForTask(ExecutionVertex, Iterable<Instance>, boolean) - Method in class org.apache.flink.runtime.jobmanager.scheduler.Scheduler
-
Gets a suitable instance to schedule the vertex execution to.
- getFullSegments() - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBulkBlockReader
-
- getFullSegments() - Method in interface org.apache.flink.runtime.io.disk.iomanager.BulkBlockChannelReader
-
- getGarbageCollectorStatsAsString(List<GarbageCollectorMXBean>) - Static method in class org.apache.flink.runtime.taskmanager.MemoryLogger
-
Gets the garbage collection statistics from the JVM.
- getGraph() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
- 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.
- getGroupSize(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getHadoopConfiguration() - Static method in class org.apache.flink.runtime.fs.hdfs.HadoopFileSystem
-
Returns a new Hadoop Configuration object using the path to the hadoop conf configured
in the main configuration (flink-conf.yaml).
- getHadoopFileSystem() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileSystem
-
Gets the underlying Hadoop FileSystem.
- 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.
- getHadoopWrapperClassNameForFileSystem(String) - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileSystem
-
- 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
-
- getHomeDirectory() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileSystem
-
- getHomeDirectory() - Method in class org.apache.flink.runtime.fs.maprfs.MapRFileSystem
-
- getHost() - Method in class org.apache.flink.runtime.jobmanager.JobManagerCliOptions
-
- getHostname() - Method in class org.apache.flink.runtime.instance.InstanceConnectionInfo
-
Gets the hostname of the TaskManager.
- getHostname() - Method in class org.apache.flink.runtime.taskmanager.TaskManagerRuntimeInfo
-
Gets host name of the interface that the TaskManager uses to communicate.
- getHosts() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopBlockLocation
-
- 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.taskmanager.TaskExecutionState
-
Returns the ID of the task this result belongs to
- getIndexInSubtaskGroup() - Method in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
-
Returns the task's index in the subtask group.
- getIndexInSubtaskGroup() - Method in class org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
-
Returns the index of this subtask in the subtask group.
- getInetAdress() - Method in class org.apache.flink.runtime.instance.InstanceConnectionInfo
-
Gets the IP address where the TaskManager operates.
- getInitialTableSize(int, int, int, int) - Static method in class org.apache.flink.runtime.operators.hash.MutableHashTable
-
- getInput(int) - Method in class org.apache.flink.runtime.operators.BatchTask
-
- getInput(int) - Method in interface org.apache.flink.runtime.operators.TaskContext
-
- getInputChannelDeploymentDescriptors() - Method in class org.apache.flink.runtime.deployment.InputGateDeploymentDescriptor
-
- getInputChannelId() - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
-
- getInputComparator(int, ClassLoader) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getInputEdges(int) - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- 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.runtime.executiongraph.ExecutionJobVertex
-
- getInputs() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
- 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
-
- 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
-
- getInputSplitSource() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
- getInstance() - Method in exception org.apache.flink.runtime.instance.InstanceDiedException
-
- getInstance() - Method in class org.apache.flink.runtime.instance.Slot
-
Gets the instance from which the slot was allocated.
- 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
-
- getInstanceConnectionInfo() - Method in class org.apache.flink.runtime.instance.Instance
-
- getInstancesByHost() - Method in class org.apache.flink.runtime.jobmanager.scheduler.Scheduler
-
- getInteger(String, int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig.DelegatingConfiguration
-
- getIntermediateResult() - Method in class org.apache.flink.runtime.executiongraph.IntermediateResultPartition
-
- getInternalFileStatus() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileStatus
-
- 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.deployment.TaskDeploymentDescriptor
-
Returns the name of the class containing the task code to be executed.
- getInvokableClassName() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
Returns the name of the invokable class which represents the task of this vertex.
- 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.taskmanager.RuntimeEnvironment
-
- 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
-
- getIterationAggregators() - Method in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
-
- getIterationAggregators(ClassLoader) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- 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
-
- 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
-
- getJob() - Method in class org.apache.flink.runtime.messages.checkpoint.AbstractCheckpointMessage
-
- getJobConfiguration() - Method in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
-
Returns the configuration of the job the task belongs to.
- 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.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
-
- getJobGraph() - Method in class org.apache.flink.runtime.jobmanager.SubmittedJobGraph
-
- 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.JobStatusMessage
-
- getJobId() - Method in class org.apache.flink.runtime.client.SerializedJobExecutionResult
-
- getJobID() - Method in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
-
Returns the ID of the job the tasks belongs to.
- getJobID() - Method in interface org.apache.flink.runtime.execution.Environment
-
Returns the ID of the job that the task belongs to.
- 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.instance.Slot
-
Returns the ID of the job this allocated slot belongs to.
- 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
-
Returns the
JobID
of the submitted
JobGraph
.
- getJobId() - Method in class org.apache.flink.runtime.messages.webmonitor.JobDetails
-
- 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
- getJobInfo() - Method in class org.apache.flink.runtime.jobmanager.SubmittedJobGraph
-
Returns the
JobInfo
of the client who submitted the
JobGraph
.
- getJobManagerAddress() - Method in class org.apache.flink.runtime.yarn.AbstractFlinkYarnCluster
-
Get hostname and port of the JobManager.
- getJobManagerMode() - Method in class org.apache.flink.runtime.jobmanager.JobManagerCliOptions
-
- getJobName() - Method in class org.apache.flink.runtime.client.JobStatusMessage
-
- getJobName() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- getJobName() - Method in class org.apache.flink.runtime.messages.webmonitor.JobDetails
-
- getJobsCancelled() - Method in class org.apache.flink.runtime.messages.webmonitor.JobsWithIDsOverview
-
- getJobsFailed() - Method in class org.apache.flink.runtime.messages.webmonitor.JobsWithIDsOverview
-
- getJobsFinished() - Method in class org.apache.flink.runtime.messages.webmonitor.JobsWithIDsOverview
-
- getJobsRunningOrPending() - Method in class org.apache.flink.runtime.messages.webmonitor.JobsWithIDsOverview
-
- getJobState() - Method in class org.apache.flink.runtime.client.JobStatusMessage
-
- getJobStats() - Method in interface org.apache.flink.runtime.checkpoint.stats.CheckpointStatsTracker
-
Returns a snapshot of the checkpoint statistics for a job.
- getJobStats() - Method in class org.apache.flink.runtime.checkpoint.stats.DisabledCheckpointStatsTracker
-
- getJobStats() - Method in class org.apache.flink.runtime.checkpoint.stats.SimpleCheckpointStatsTracker
-
- getJobStatusListener() - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
- 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
-
- 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 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.jobmanager.scheduler.ScheduledUnit
-
- 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
-
- getJsonPlan() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- 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".
- getKeySerializer() - Method in class org.apache.flink.runtime.state.AbstractHeapState
-
Gets the serializer for the keys.
- getLastHeartBeat() - Method in class org.apache.flink.runtime.instance.Instance
-
Gets the timestamp of the last heartbeat.
- getLastMetricsReport() - Method in class org.apache.flink.runtime.instance.Instance
-
- getLastOutputCollector() - Method in class org.apache.flink.runtime.operators.BatchTask
-
- getLastTasksConfig() - Method in class org.apache.flink.runtime.operators.BatchTask
-
- getLastUpdateTime() - Method in class org.apache.flink.runtime.messages.webmonitor.JobDetails
-
- getLatestCheckpoint() - Method in interface org.apache.flink.runtime.checkpoint.CompletedCheckpointStore
-
- getLatestCheckpoint() - Method in class org.apache.flink.runtime.checkpoint.ZooKeeperCompletedCheckpointStore
-
- getLeaderConnectionInfoFuture() - Method in class org.apache.flink.runtime.util.LeaderRetrievalUtils.LeaderConnectionInfoListener
-
- getLeaderSessionID() - Method in class org.apache.flink.runtime.akka.FlinkUntypedActor
-
Returns the current leader session ID associcated with this actor.
- getLeaderSessionID() - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinatorDeActivator
-
- getLeaderSessionID() - Method in class org.apache.flink.runtime.checkpoint.SavepointCoordinatorDeActivator
-
- getLeaderSessionID() - Method in class org.apache.flink.runtime.client.JobClientActor
-
- 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
-
- getLen() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileStatus
-
- 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
-
- 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
-
- getLocality() - Method in class org.apache.flink.runtime.instance.SimpleSlot
-
Gets the locality information attached to this slot.
- getLocation() - Method in class org.apache.flink.runtime.jobmanager.scheduler.CoLocationConstraint
-
Gets the location assigned to this slot.
- getLocationConstraint() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- getLocationConstraint(int) - Method in class org.apache.flink.runtime.jobmanager.scheduler.CoLocationGroup
-
- getLocationConstraint() - Method in class org.apache.flink.runtime.jobmanager.scheduler.ScheduledUnit
-
- getLong(String, long) - Method in class org.apache.flink.runtime.operators.util.TaskConfig.DelegatingConfiguration
-
- getLRU() - Method in class org.apache.flink.runtime.util.LRUCache
-
- getLRU() - Method in class org.apache.flink.runtime.util.LRUCacheMap
-
- 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, 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
-
- getMaxConcurrentCheckpoints() - Method in class org.apache.flink.runtime.jobgraph.tasks.JobSnapshottingSettings
-
- getMaxDepth(int) - Static method in class org.apache.flink.runtime.operators.sort.QuickSort
-
Deepest recursion before giving up and doing a heapsort.
- getMaxDuration() - Method in interface org.apache.flink.runtime.checkpoint.stats.JobCheckpointStats
-
Returns the maximum checkpoint duration ever seen over all completed
checkpoints.
- getMaximumParallelism() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
Gets the maximum parallelism of all operations in this job graph.
- getMaxJvmHeapMemory() - Static method in class org.apache.flink.runtime.util.EnvironmentInformation
-
The maximum JVM heap size, in bytes.
- getMaxStateSize() - Method in interface org.apache.flink.runtime.checkpoint.stats.JobCheckpointStats
-
Returns the maximum checkpoint state size ever seen over all completed
checkpoints.
- 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.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 class org.apache.flink.runtime.io.network.buffer.Buffer
-
- getMemorySegment() - Method in class org.apache.flink.runtime.operators.util.BloomFilter.BitSet
-
- 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.
- getMemoryUsageStatsAsString(MemoryMXBean) - Static method in class org.apache.flink.runtime.taskmanager.MemoryLogger
-
Gets the memory footprint of the JVM in a string representation.
- 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.
- getMessage() - Method in exception org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel.BufferReorderingException
-
- getMessage() - Method in exception org.apache.flink.runtime.io.network.partition.PartitionNotFoundException
-
- getMinDuration() - Method in interface org.apache.flink.runtime.checkpoint.stats.JobCheckpointStats
-
Returns the minimum checkpoint duration ever seen over all completed
checkpoints.
- getMinPauseBetweenCheckpoints() - Method in class org.apache.flink.runtime.jobgraph.tasks.JobSnapshottingSettings
-
- getMinStateSize() - Method in interface org.apache.flink.runtime.checkpoint.stats.JobCheckpointStats
-
Returns the minimum checkpoint state size ever seen over all completed
checkpoints.
- getModificationTime() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileStatus
-
- getMutableObjectMode() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getName() - Method in class org.apache.flink.runtime.accumulators.StringifiedAccumulatorResult
-
- getName() - Method in class org.apache.flink.runtime.broadcast.BroadcastVariableKey
-
- 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.
- getNamespaceSerializer() - Method in class org.apache.flink.runtime.state.AbstractHeapState
-
Gets the serializer for the namespace.
- 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.
- getNetworkBufferPool() - Method in class org.apache.flink.runtime.io.network.NetworkEnvironment
-
- 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
-
- getNewMessages() - Method in class org.apache.flink.runtime.yarn.AbstractFlinkYarnCluster
-
May return new messages from the cluster.
- getNewSlotForSharingGroup(ExecutionVertex, Iterable<Instance>, 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.
- getNextBuffer() - Method in class org.apache.flink.runtime.io.network.api.reader.BufferReader
-
- getNextBuffer() - Method in class org.apache.flink.runtime.io.network.partition.consumer.UnknownInputChannel
-
- 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.runtime.executiongraph.ExecutionJobVertex.PredeterminedInputSplitAssigner
-
- getNextInputSplit() - Method in interface org.apache.flink.runtime.jobgraph.tasks.InputSplitProvider
-
Requests the next input split to be consumed by the calling task.
- getNextInputSplit() - Method in class org.apache.flink.runtime.taskmanager.TaskInputSplitProvider
-
- getNextPathNum() - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManager
-
- getNextRecord(T) - Method in class org.apache.flink.runtime.io.network.api.serialization.AdaptiveSpanningRecordDeserializer
-
- 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.
- getNioBuffer() - Method in class org.apache.flink.runtime.io.network.buffer.Buffer
-
- getNioFileChannel() - Method in class org.apache.flink.runtime.io.disk.iomanager.AbstractFileIOChannel
-
- getNioFileChannel() - Method in interface org.apache.flink.runtime.io.disk.iomanager.FileIOChannel
-
- 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
-
- getNumberCPUCores() - Static method in class org.apache.flink.runtime.instance.Hardware
-
Gets the number of CPU cores (hardware contexts) that the JVM has access to.
- 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.
- 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
-
- 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.
- getNumberOfChainedStubs() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getNumberOfCPUCores() - Method in class org.apache.flink.runtime.instance.HardwareDescription
-
Returns the number of CPU cores available to the JVM on the compute node.
- 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
-
- 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.
- 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.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
-
- getNumberOfInstancesWithAvailableSlots() - Method in class org.apache.flink.runtime.jobmanager.scheduler.Scheduler
-
- getNumberOfIterations() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- 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
-
- getNumberOfOutputChannels() - Method in class org.apache.flink.runtime.io.network.api.writer.ResultPartitionWriter
-
- 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.
- 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
-
- getNumberOfReferenceHolders(JobID) - Method in class org.apache.flink.runtime.execution.librarycache.BlobLibraryCacheManager
-
- getNumberOfRegisteredBufferPools() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
-
- getNumberOfRegisteredTaskManagers() - Method in class org.apache.flink.runtime.instance.InstanceManager
-
- 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.
- 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.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.yarn.FlinkYarnClusterStatus
-
- 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.
- getNumberOfSubpartitions() - Method in class org.apache.flink.runtime.deployment.ResultPartitionDeploymentDescriptor
-
- getNumberOfSubpartitions() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
-
- getNumberOfSubTasks() - Method in class org.apache.flink.runtime.checkpoint.stats.OperatorCheckpointStats
-
Returns the number of sub tasks.
- getNumberOfSubtasks() - Method in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
-
Returns the current number of subtasks.
- getNumberOfTaskManagers() - Method in class org.apache.flink.runtime.yarn.FlinkYarnClusterStatus
-
- getNumberOfUnconstrainedAssignments() - Method in class org.apache.flink.runtime.jobmanager.scheduler.Scheduler
-
- getNumberOfVariablesWithReferences() - Method in class org.apache.flink.runtime.broadcast.BroadcastVariableManager
-
- getNumberOfVertices() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
Returns the number of all vertices.
- 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.
- getNumIds() - Method in class org.apache.flink.runtime.state.SerializedCheckpointData
-
Gets the number of IDs in the checkpoint.
- 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
-
- 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
-
- getNumRequiredComparators() - Method in enum org.apache.flink.runtime.operators.DriverStrategy
-
- getNumSlotsAvailable() - Method in class org.apache.flink.runtime.messages.webmonitor.StatusOverview
-
- getNumSlotsTotal() - Method in class org.apache.flink.runtime.messages.webmonitor.StatusOverview
-
- getNumTaskInputs() - Method in class org.apache.flink.runtime.iterative.task.IterationHeadTask
-
- getNumTaskInputs() - Method in class org.apache.flink.runtime.operators.BatchTask
-
- getNumTaskManagersConnected() - Method in class org.apache.flink.runtime.messages.webmonitor.StatusOverview
-
- getNumTasks() - Method in class org.apache.flink.runtime.messages.webmonitor.JobDetails
-
- getNumVerticesPerExecutionState() - Method in class org.apache.flink.runtime.messages.webmonitor.JobDetails
-
- 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.
- 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
-
- getOffset() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopBlockLocation
-
- getOpenFileHandlesLimit() - Static method in class org.apache.flink.runtime.util.EnvironmentInformation
-
Tries to retrieve the maximum number of open file handles.
- getOperatorDescription() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
- getOperatorId() - Method in class org.apache.flink.runtime.checkpoint.StateForTask
-
- 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.runtime.jobgraph.JobVertex
-
- getOperatorPrettyName() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
- getOperatorState() - Method in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
-
- getOperatorStats(JobVertexID) - Method in interface org.apache.flink.runtime.checkpoint.stats.CheckpointStatsTracker
-
Returns a snapshot of the checkpoint statistics for an operator.
- getOperatorStats(JobVertexID) - Method in class org.apache.flink.runtime.checkpoint.stats.DisabledCheckpointStatsTracker
-
- getOperatorStats(JobVertexID) - Method in class org.apache.flink.runtime.checkpoint.stats.SimpleCheckpointStatsTracker
-
- getOutputCollector() - Method in class org.apache.flink.runtime.operators.BatchTask
-
- getOutputCollector(AbstractInvokable, TaskConfig, ClassLoader, List<RecordWriter<?>>, int, int, AccumulatorRegistry.Reporter) - 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
-
- getOutputPartitioner(int, ClassLoader) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getOutputSerializer(ClassLoader) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getOutputShipStrategy(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getOversizedRecordCount() - Method in class org.apache.flink.runtime.operators.GroupReduceCombineDriver
-
Gets the number of oversized records handled by this combiner.
- getOwningNepheleTask() - Method in class org.apache.flink.runtime.operators.BatchTask
-
- getOwningNepheleTask() - Method in interface org.apache.flink.runtime.operators.TaskContext
-
- getPackages() - Method in class org.apache.flink.runtime.util.DependencyVisitor
-
- 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.
- getPairComparatorFactory(ClassLoader) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- 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.
- getParallelSubtaskIndex() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- getParent() - Method in class org.apache.flink.runtime.instance.Slot
-
Gets the parent slot of this slot.
- getPartitionConsumableNotifier() - Method in class org.apache.flink.runtime.io.network.NetworkEnvironment
-
- getPartitionedState(N, TypeSerializer<N>, StateDescriptor<S, ?>) - Method in class org.apache.flink.runtime.state.AbstractStateBackend
-
Creates or retrieves a partitioned state backed by this state backend.
- getPartitionId() - Method in class org.apache.flink.runtime.deployment.ResultPartitionDeploymentDescriptor
-
- getPartitionId() - Method in class org.apache.flink.runtime.executiongraph.IntermediateResultPartition
-
- getPartitionId() - Method in class org.apache.flink.runtime.io.network.api.writer.ResultPartitionWriter
-
- 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
-
- 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.
- getPartitionManager() - Method in class org.apache.flink.runtime.io.network.NetworkEnvironment
-
- 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.
- getPartitionRequestInitialAndMaxBackoff() - Method in class org.apache.flink.runtime.io.network.NetworkEnvironment
-
- getPartitions() - Method in class org.apache.flink.runtime.executiongraph.IntermediateResult
-
- getPartitionStateChecker() - Method in class org.apache.flink.runtime.io.network.NetworkEnvironment
-
- getPartitionType() - Method in class org.apache.flink.runtime.deployment.ResultPartitionDeploymentDescriptor
-
- 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.
- 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).
- getPendingCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
- getPipelineBreakingExchange(ExecutionMode) - Static method in enum org.apache.flink.runtime.io.network.DataExchangeMode
-
- getPort() - Method in class org.apache.flink.runtime.blob.BlobCache
-
- 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 service.
- getPos() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopDataInputStream
-
- getPosition() - Method in class org.apache.flink.runtime.io.disk.iomanager.FileSegment
-
- getPreferredLocations() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
Gets the location preferences of this task, determined by the locations of the predecessors from which
it receives input data.
- getPreProcessingOperationName() - Method in class org.apache.flink.runtime.jobgraph.JobEdge
-
Gets the name of the pro-processing operation for this input.
- getPreviousGlobalAggregate(String) - Method in class org.apache.flink.runtime.iterative.task.RuntimeAggregatorRegistry
-
- getPriorExecutionAttempt(int) - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- 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
-
- 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
-
- 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
-
- 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
-
- getPushChainDriverClass() - Method in enum org.apache.flink.runtime.operators.DriverStrategy
-
- getRandomFilename(String) - Static method in class org.apache.flink.runtime.util.FileUtils
-
Constructs a random filename with the given prefix and
a random part generated from hex characters.
- 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).
- 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.
- getReadWriteReporter() - Method in class org.apache.flink.runtime.accumulators.AccumulatorRegistry
-
Gets the reporter for flink internal metrics.
- getRecentHistory() - Method in interface org.apache.flink.runtime.checkpoint.stats.JobCheckpointStats
-
Returns a list of recently completed checkpoints stats.
- 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.runtime.operators.hash.InMemoryPartition
-
number of records in partition including garbage
- getRecoveryTimestamp() - Method in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
-
- getRecursionLevel() - Method in class org.apache.flink.runtime.operators.hash.HashPartition
-
Gets this partition's recursion level.
- getRecycler() - Method in class org.apache.flink.runtime.io.network.buffer.Buffer
-
- getRegisteredExecutions() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- getRegisteredInstance(ActorRef) - Method in class org.apache.flink.runtime.instance.InstanceManager
-
- getRegisteredInstanceById(InstanceID) - Method in class org.apache.flink.runtime.instance.InstanceManager
-
- 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
-
- getRelativeSolutionSetMemory() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getReplication() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileStatus
-
- getRequiredClasspaths() - Method in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
-
- 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
- getRequiredJarFiles() - Method in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
-
- 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
- getResources() - Method in class org.apache.flink.runtime.instance.Instance
-
- getRestartStrategy() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- getRestartStrategyConfiguration() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
Gets the restart strategy configuration
- getResultId() - Method in class org.apache.flink.runtime.deployment.PartialInputChannelDeploymentDescriptor
-
- getResultId() - Method in class org.apache.flink.runtime.deployment.ResultPartitionDeploymentDescriptor
-
- getResultOptimizerProperties() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
- getResultType() - Method in class org.apache.flink.runtime.executiongraph.IntermediateResult
-
- getResultType() - Method in class org.apache.flink.runtime.jobgraph.IntermediateDataSet
-
- 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
- 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.
- getRoot() - Method in class org.apache.flink.runtime.instance.Slot
-
- getRootSlotNumber() - Method in class org.apache.flink.runtime.instance.Slot
-
Gets the number of the root slot.
- getRunningJobs() - Method in class org.apache.flink.runtime.messages.webmonitor.MultipleJobsDetails
-
- getSavepointCoordinator() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- getSavepointPath() - Method in class org.apache.flink.runtime.jobgraph.tasks.JobSnapshottingSettings
-
Returns the configured savepoint path or null
if none is configured.
- getSavepointRestorePath() - Method in class org.apache.flink.runtime.checkpoint.SavepointCoordinator
-
- getScheduleMode() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- getScheduleMode() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
- getScheduler() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- 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.
- getSendAndReceiveBufferSize() - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
-
- getSerializedAccumulatorResults() - Method in class org.apache.flink.runtime.client.SerializedJobExecutionResult
-
- getSerializedData() - Method in class org.apache.flink.runtime.state.SerializedCheckpointData
-
Gets the binary data for the serialized elements.
- getServerChannelHandlers() - Method in interface org.apache.flink.runtime.io.network.netty.NettyProtocol
-
- getServerConnectBacklog() - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
-
- getServerNumThreads() - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
-
- getServerPort() - Method in interface org.apache.flink.runtime.webmonitor.WebMonitor
-
Gets the port that the web server actually binds to.
- getSessionFilesDir() - Method in class org.apache.flink.runtime.yarn.AbstractFlinkYarnClient
-
- 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.
- getSharedSlot() - Method in class org.apache.flink.runtime.jobmanager.scheduler.CoLocationConstraint
-
Gets the shared slot into which this constraint's tasks are places.
- 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", ...
- getSimpleName() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- 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 class org.apache.flink.runtime.io.network.buffer.Buffer
-
- 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() - Static method in class org.apache.flink.runtime.instance.Hardware
-
Returns the size of the physical memory in bytes.
- getSizeOfPhysicalMemory() - Method in class org.apache.flink.runtime.instance.HardwareDescription
-
Returns the size of physical memory in bytes available on the compute node.
- getSizeOfSerializedState() - Method in class org.apache.flink.runtime.state.memory.SerializedStateHandle
-
Gets the size of the serialized state.
- getSlotForTask(ExecutionVertex) - Method in class org.apache.flink.runtime.instance.SlotSharingGroupAssignment
-
Gets a slot suitable for the given task vertex.
- getSlotForTask(ExecutionVertex, CoLocationConstraint) - Method in class org.apache.flink.runtime.instance.SlotSharingGroupAssignment
-
Gets a slot for a task that has a co-location constraint.
- getSlotNumber() - Method in class org.apache.flink.runtime.instance.Slot
-
Gets the number of the slot.
- 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() - Method in class org.apache.flink.runtime.jobmanager.scheduler.ScheduledUnit
-
- getSnapshot() - Method in class org.apache.flink.runtime.accumulators.AccumulatorRegistry
-
Creates a snapshot of this accumulator registry.
- getSnapshotSettings() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
Gets the settings for asynchronous snapshots.
- getSolutionSetComparator(ClassLoader) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getSolutionSetSerializer(ClassLoader) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getSortingThread(ExceptionHandler<IOException>, UnilateralSortMerger.CircularQueues<E>, AbstractInvokable) - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger
-
- 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.
- getSourceId() - Method in class org.apache.flink.runtime.jobgraph.JobEdge
-
Gets the ID of the consumed data set.
- getSpillingDirectories() - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManager
-
Gets the directories that the I/O manager spills to.
- 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
-
- getSplitAssigner() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
- getStackTrace() - Method in exception org.apache.flink.runtime.util.SerializedThrowable
-
- getStartTime() - Method in class org.apache.flink.runtime.client.JobStatusMessage
-
- getStartTime() - Method in class org.apache.flink.runtime.messages.webmonitor.JobDetails
-
- getState(String) - Method in class org.apache.flink.runtime.checkpoint.SavepointStore
-
- getState() - Method in class org.apache.flink.runtime.checkpoint.StateForTask
-
- getState(String) - Method in interface org.apache.flink.runtime.checkpoint.StateStore
-
Returns the object identified by the given (logical) path.
- 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.messages.checkpoint.AcknowledgeCheckpoint
-
- getState(ClassLoader) - Method in class org.apache.flink.runtime.state.AsynchronousStateHandle
-
- getState(ClassLoader) - Method in class org.apache.flink.runtime.state.filesystem.FileSerializableStateHandle
-
- getState(ClassLoader) - Method in class org.apache.flink.runtime.state.filesystem.FileStreamStateHandle
-
- getState(ClassLoader) - Method in class org.apache.flink.runtime.state.LocalStateHandle
-
- getState(ClassLoader) - Method in class org.apache.flink.runtime.state.memory.ByteStreamStateHandle
-
- getState(ClassLoader) - Method in class org.apache.flink.runtime.state.memory.SerializedStateHandle
-
- getState(ClassLoader) - Method in interface org.apache.flink.runtime.state.StateHandle
-
This retrieves and return the state represented by the handle.
- getStates() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
-
- getStateSize() - Method in class org.apache.flink.runtime.checkpoint.StateForTask
-
- getStateSize() - Method in class org.apache.flink.runtime.checkpoint.stats.CheckpointStats
-
Returns the state size in bytes.
- getStateSize() - Method in class org.apache.flink.runtime.messages.checkpoint.AcknowledgeCheckpoint
-
- getStateSize() - Method in class org.apache.flink.runtime.state.AsynchronousKvStateSnapshot
-
- getStateSize() - Method in class org.apache.flink.runtime.state.filesystem.AbstractFsStateSnapshot
-
Returns the file size in bytes.
- getStateSize() - Method in class org.apache.flink.runtime.state.filesystem.FileSerializableStateHandle
-
Returns the file size in bytes.
- getStateSize() - Method in class org.apache.flink.runtime.state.filesystem.FileStreamStateHandle
-
Returns the file size in bytes.
- getStateSize() - Method in interface org.apache.flink.runtime.state.KvStateSnapshot
-
Returns the size of the state in bytes.
- getStateSize() - Method in class org.apache.flink.runtime.state.LocalStateHandle
-
- getStateSize() - Method in class org.apache.flink.runtime.state.memory.AbstractMemStateSnapshot
-
- getStateSize() - Method in class org.apache.flink.runtime.state.memory.ByteStreamStateHandle
-
- getStateSize() - Method in class org.apache.flink.runtime.state.memory.SerializedStateHandle
-
- getStateSize() - Method in interface org.apache.flink.runtime.state.StateHandle
-
Returns the size of the state in bytes.
- 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 class org.apache.flink.runtime.executiongraph.Execution
-
- getStatus() - Method in class org.apache.flink.runtime.messages.webmonitor.JobDetails
-
- getStatusTimestamp(JobStatus) - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- getStorageDir() - Method in class org.apache.flink.runtime.blob.BlobCache
-
- getStrigifiedStackTrace() - Method in exception org.apache.flink.runtime.util.SerializedThrowable
-
- getString(String, String) - Method in class org.apache.flink.runtime.operators.util.TaskConfig.DelegatingConfiguration
-
- 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.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
-
- getSubtask() - Method in class org.apache.flink.runtime.checkpoint.StateForTask
-
- getSubTaskDuration(int) - Method in class org.apache.flink.runtime.checkpoint.stats.OperatorCheckpointStats
-
Returns the duration of a specific sub task.
- getSubTaskStateSize(int) - Method in class org.apache.flink.runtime.checkpoint.stats.OperatorCheckpointStats
-
Returns the state size of a specific sub task.
- getSuccessfulCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
- getSuperstep() - Method in class org.apache.flink.runtime.broadcast.BroadcastVariableKey
-
- 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.
- getTargetSlotNumber() - Method in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
-
Gets the number of the slot into which the task is to be deployed.
- getTaskAssignment() - Method in class org.apache.flink.runtime.jobmanager.scheduler.SlotSharingGroup
-
- 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 class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
-
Returns the task's configuration object.
- getTaskConfiguration() - Method in interface org.apache.flink.runtime.execution.Environment
-
Returns the task-wide configuration object, originally attache to the job vertex.
- 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 class org.apache.flink.runtime.io.network.NetworkEnvironment
-
- getTaskExecutionId() - Method in class org.apache.flink.runtime.messages.checkpoint.AbstractCheckpointMessage
-
- getTaskInfo() - Method in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
-
Returns the TaskInfo
object for the subtask
- 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
-
- getTaskManagerCount() - Method in class org.apache.flink.runtime.yarn.AbstractFlinkYarnClient
-
- 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
-
- getTaskManagerSlots() - Method in class org.apache.flink.runtime.yarn.AbstractFlinkYarnClient
-
- getTaskName() - Method in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
-
Returns the task's name.
- getTaskName() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- 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.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 class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- getTaskToExecute() - Method in class org.apache.flink.runtime.jobmanager.scheduler.ScheduledUnit
-
- getTaskVertices() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
- 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".
- getTimestamp() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
-
- getTimestamp() - Method in class org.apache.flink.runtime.io.network.api.CheckpointBarrier
-
- getTimestamp() - Method in class org.apache.flink.runtime.messages.checkpoint.DeclineCheckpoint
-
- getTimestamp() - Method in class org.apache.flink.runtime.messages.checkpoint.NotifyCheckpointComplete
-
- getTimestamp() - Method in class org.apache.flink.runtime.messages.checkpoint.TriggerCheckpoint
-
- getTotalNumberOfBuffers() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
-
- getTotalNumberOfBuffers() - Method in class org.apache.flink.runtime.io.network.partition.ResultSubpartition
-
- getTotalNumberOfBytes() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
-
- getTotalNumberOfBytes() - Method in class org.apache.flink.runtime.io.network.partition.ResultSubpartition
-
- getTotalNumberOfMemorySegments() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
-
- 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
-
- getTotalNumPages() - Method in class org.apache.flink.runtime.memory.MemoryManager
-
Gets the total number of memory pages managed by this memory manager.
- getTransportType() - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
-
- getTriggerTimestamp() - Method in class org.apache.flink.runtime.checkpoint.stats.CheckpointStats
-
Returns the timestamp when the checkpoint was triggered.
- getType() - Method in class org.apache.flink.runtime.accumulators.StringifiedAccumulatorResult
-
- getType() - Method in exception org.apache.flink.runtime.broadcast.InitializationTypeConflictException
-
- getUdfRuntimeContext() - Method in class org.apache.flink.runtime.operators.chaining.ChainedDriver
-
- getUri() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileSystem
-
- getUri() - Method in class org.apache.flink.runtime.fs.maprfs.MapRFileSystem
-
- getURL(BlobKey) - Method in class org.apache.flink.runtime.blob.BlobCache
-
Returns the URL for the BLOB with the given key.
- getURL(BlobKey) - Method in class org.apache.flink.runtime.blob.BlobServer
-
Method which retrieves the URL of a file associated with a blob key.
- getURL(BlobKey) - Method in interface org.apache.flink.runtime.blob.BlobService
-
This method returns the URL of the file associated with the provided blob key.
- getUserAccumulators() - Method in class org.apache.flink.runtime.executiongraph.Execution
-
- 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
-
- 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
-
- getUserCodeClassLoaderInfo(ClassLoader) - Static method in class org.apache.flink.runtime.util.ClassLoaderUtil
-
Gets information about URL class loaders.
- 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.
- getUserMap() - Method in class org.apache.flink.runtime.accumulators.AccumulatorRegistry
-
Gets the map for user-defined accumulators.
- getUserRunning() - Static method in class org.apache.flink.runtime.util.EnvironmentInformation
-
Gets the name of the user that is running the JVM.
- getValue() - Method in class org.apache.flink.runtime.accumulators.StringifiedAccumulatorResult
-
- 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.
- 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.
- getVariable() - Method in class org.apache.flink.runtime.broadcast.BroadcastVariableMaterialization
-
- getVariable(BroadcastVariableInitializer<T, C>) - Method in class org.apache.flink.runtime.broadcast.BroadcastVariableMaterialization
-
- getVersion() - Static method in class org.apache.flink.runtime.util.EnvironmentInformation
-
Returns the version of the code as String.
- getVertex() - Method in class org.apache.flink.runtime.executiongraph.Execution
-
- getVertexId() - Method in class org.apache.flink.runtime.broadcast.BroadcastVariableKey
-
- getVertexID() - Method in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
-
Returns the task's execution vertex ID.
- getVertexWithAttempt() - Method in class org.apache.flink.runtime.executiongraph.Execution
-
- 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.
- getVerticesSortedTopologicallyFromSources() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
- getVerticesToAcknowledge() - Method in class org.apache.flink.runtime.jobgraph.tasks.JobSnapshottingSettings
-
- getVerticesToConfirm() - Method in class org.apache.flink.runtime.jobgraph.tasks.JobSnapshottingSettings
-
- getVerticesTopologically() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- getVerticesToTrigger() - Method in class org.apache.flink.runtime.jobgraph.tasks.JobSnapshottingSettings
-
- getWaitForSolutionSetUpdate() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getWebInterfaceURL() - Method in class org.apache.flink.runtime.yarn.AbstractFlinkYarnCluster
-
Returns an URL (as a string) to the JobManager web interface, running next to the
ApplicationMaster and JobManager in a YARN container
- getWebUIPort() - Method in class org.apache.flink.runtime.jobmanager.JobManagerCliOptions
-
- getWorkerIndex() - Method in class org.apache.flink.runtime.iterative.event.WorkerDoneEvent
-
- getWorkingDirectory() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileSystem
-
- getWorkingDirectory() - Method in class org.apache.flink.runtime.fs.maprfs.MapRFileSystem
-
- getWrappedException() - Method in exception org.apache.flink.runtime.operators.chaining.ExceptionInChainedStubException
-
- getWriteEnd() - Method in class org.apache.flink.runtime.iterative.concurrent.BlockingBackChannel
-
Called by iteration tail to save the output of the current superstep.
- getWriteOffset() - Method in class org.apache.flink.runtime.io.disk.FileChannelOutputView
-
- getWriter(int) - Method in interface org.apache.flink.runtime.execution.Environment
-
- getWriter(int) - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
-
- getWriters() - Method in class org.apache.flink.runtime.operators.shipping.OutputCollector
-
List of writers that are associated with this output collector
- 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).
- 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.
- 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.
- 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
-
- 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
-
- 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
-
- increaseBackoff() - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputChannel
-
Increases the current backoff and returns whether the operation was successful.
- increment() - Method in class org.apache.flink.runtime.util.AtomicDisposableReferenceCounter
-
Increments the reference count and returns whether it was successful.
- incrementIterationCounter() - Method in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
-
- 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
-
- inFirstIteration() - Method in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
-
- 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.
- 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.
- InitializationTypeConflictException - Exception in org.apache.flink.runtime.broadcast
-
- InitializationTypeConflictException(Class<?>) - Constructor for exception org.apache.flink.runtime.broadcast.InitializationTypeConflictException
-
- initialize(URI) - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileSystem
-
- initialize(URI) - Method in class org.apache.flink.runtime.fs.maprfs.MapRFileSystem
-
- 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
-
- initializeBroadcastVariable(Iterable<T>) - Method in class org.apache.flink.runtime.broadcast.DefaultBroadcastVariableInitializer
-
- initializeForJob(Environment, String, TypeSerializer<?>) - Method in class org.apache.flink.runtime.state.AbstractStateBackend
-
This method is called by the task upon deployment to initialize the state backend for
data for a specific job.
- initializeForJob(Environment, String, TypeSerializer<?>) - Method in class org.apache.flink.runtime.state.filesystem.FsStateBackend
-
- 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
-
- initialPartitionBuffersCount - Variable in class org.apache.flink.runtime.operators.hash.ReOpenableHashPartition
-
- 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)
!
- 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, AccumulatorRegistry.Reporter, Map<String, Accumulator<?, ?>>) - Static method in class org.apache.flink.runtime.operators.BatchTask
-
Creates a writer for each output.
- initStub(Class<? super S>) - Method in class org.apache.flink.runtime.operators.BatchTask
-
- initTable(int, byte) - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
-
- injectKeyValueStateSnapshots(HashMap<String, KvStateSnapshot>, long) - Method in class org.apache.flink.runtime.state.AbstractStateBackend
-
Injects K/V state snapshots for lazy restore.
- 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
-
- 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
-
- InputChannel - Class in org.apache.flink.runtime.io.network.partition.consumer
-
- InputChannel(SingleInputGate, int, ResultPartitionID, Tuple2<Integer, Integer>) - Constructor for class org.apache.flink.runtime.io.network.partition.consumer.InputChannel
-
- 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
-
- 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
-
- inputComparators - Variable in class org.apache.flink.runtime.operators.BatchTask
-
The comparators for the central driver.
- 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
-
- 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, int, InputChannelDeploymentDescriptor[]) - Constructor for class org.apache.flink.runtime.deployment.InputGateDeploymentDescriptor
-
- inputIterators - Variable in class org.apache.flink.runtime.operators.BatchTask
-
The inputs reader, wrapped in an iterator.
- 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.
- InputSplitIterator<T extends org.apache.flink.core.io.InputSplit> - Class in org.apache.flink.runtime.jobgraph.tasks
-
The input split iterator allows a task to iterate over all input splits it is supposed to
consume.
- InputSplitIterator(InputSplitProvider) - Constructor for class org.apache.flink.runtime.jobgraph.tasks.InputSplitIterator
-
Constructs a new input split iterator.
- 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.
- InputViewIterator<E> - Class in org.apache.flink.runtime.io.disk
-
- InputViewIterator(DataInputView, TypeSerializer<E>) - Constructor for class org.apache.flink.runtime.io.disk.InputViewIterator
-
- insert(T) - Method in class org.apache.flink.runtime.operators.hash.AbstractMutableHashTable
-
- insert(T) - Method in class org.apache.flink.runtime.operators.hash.CompactingHashTable
-
- 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
-
- 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.
- instance() - Static method in class org.apache.flink.runtime.broadcast.DefaultBroadcastVariableInitializer
-
- Instance - Class in org.apache.flink.runtime.instance
-
An instance represents a TaskManager
registered at a JobManager and ready to receive work.
- Instance(ActorGateway, InstanceConnectionInfo, 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
-
- INSTANCE - Static variable in class org.apache.flink.runtime.iterative.event.TerminationEvent
-
- INSTANCE - Static variable in class org.apache.flink.runtime.util.ExecutorThreadFactory
-
- InstanceConnectionInfo - Class in org.apache.flink.runtime.instance
-
This class encapsulates the connection information of a TaskManager.
- InstanceConnectionInfo(InetAddress, int) - Constructor for class org.apache.flink.runtime.instance.InstanceConnectionInfo
-
Constructs a new instance connection info object.
- InstanceConnectionInfo() - Constructor for class org.apache.flink.runtime.instance.InstanceConnectionInfo
-
Constructs an empty object.
- 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.
- 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.
- 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
-
- 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(JobVertex) - Constructor for class org.apache.flink.runtime.jobgraph.IntermediateDataSet
-
- IntermediateDataSet(IntermediateDataSetID, JobVertex) - Constructor for class org.apache.flink.runtime.jobgraph.IntermediateDataSet
-
- 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, boolean) - 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
-
- 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.
- 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
-
- ioBuffer() - Method in class org.apache.flink.runtime.io.network.netty.NettyBufferPool
-
- ioBuffer(int) - Method in class org.apache.flink.runtime.io.network.netty.NettyBufferPool
-
- ioBuffer(int, int) - Method in class org.apache.flink.runtime.io.network.netty.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.
- IOUtils - Class in org.apache.flink.runtime.util
-
An utility class for I/O related functionality.
- 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.
- 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.
- isAssignedAndAlive() - Method in class org.apache.flink.runtime.jobmanager.scheduler.CoLocationConstraint
-
- isAssociated() - Method in class org.apache.flink.runtime.io.network.NetworkEnvironment
-
- isBlocking() - Method in enum org.apache.flink.runtime.io.network.partition.ResultPartitionType
-
- isBuffer() - Method in class org.apache.flink.runtime.io.disk.iomanager.FileSegment
-
- isBuffer() - Method in class org.apache.flink.runtime.io.network.buffer.Buffer
-
- 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
-
- isCanceled() - Method in interface org.apache.flink.runtime.execution.ExecutionObserver
-
Returns whether the task has been canceled.
- isCanceled() - Method in class org.apache.flink.runtime.instance.Slot
-
Checks of the slot has been cancelled.
- 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.
- 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
-
- isCompacted() - Method in class org.apache.flink.runtime.operators.hash.InMemoryPartition
-
- isConsumable() - Method in class org.apache.flink.runtime.executiongraph.IntermediateResultPartition
-
- isConverged(int, LongValue) - Method in class org.apache.flink.runtime.iterative.convergence.WorksetEmptyConvergenceCriterion
-
- 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.runtime.yarn.AbstractFlinkYarnClient
-
- isDetached() - Method in class org.apache.flink.runtime.yarn.AbstractFlinkYarnCluster
-
Flink's YARN cluster abstraction has two modes for connecting to the YARN AM.
- isDir() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileStatus
-
- isDirectBufferPooled() - Method in class org.apache.flink.runtime.io.network.netty.NettyBufferPool
-
- isDiscarded() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
-
- 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.runtime.fs.hdfs.HadoopFileSystem
-
- isDistributedFS() - Method in class org.apache.flink.runtime.fs.maprfs.MapRFileSystem
-
- 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.util.IntArrayList
-
- isEmpty() - Method in class org.apache.flink.runtime.util.LongArrayList
-
- isEmpty() - Method in class org.apache.flink.runtime.util.LRUCache
-
- isEmpty() - Method in class org.apache.flink.runtime.util.LRUCacheMap
-
- isEndOfSuperstep() - Method in class org.apache.flink.runtime.iterative.task.SyncEventHandler
-
- isEvent() - Method in class org.apache.flink.runtime.io.network.partition.consumer.BufferOrEvent
-
- 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 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
-
- isFullBuffer() - Method in enum org.apache.flink.runtime.io.network.api.serialization.RecordSerializer.SerializationResult
-
- 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
-
- isFullyAcknowledged() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
-
- isHighAvailabilityModeActivated(Configuration) - Static method in enum org.apache.flink.runtime.jobmanager.RecoveryMode
-
Returns true if the defined recovery mode supports high availability.
- isIdReference() - Method in class org.apache.flink.runtime.jobgraph.JobEdge
-
- isImmutableType() - Method in class org.apache.flink.runtime.state.ArrayListSerializer
-
- isInFinalState() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
- isInitialized() - Method in class org.apache.flink.runtime.state.filesystem.FsStateBackend
-
Checks whether this state backend is initialized.
- isInMemory() - Method in class org.apache.flink.runtime.operators.hash.HashPartition
-
Checks whether this partition is in memory or spilled.
- isInputAsynchronouslyMaterialized(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- isInputCached(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- 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
-
- isIterativeInputGate(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- isLeader() - Method in class org.apache.flink.runtime.leaderelection.ZooKeeperLeaderElectionService
-
- isLocal() - Method in class org.apache.flink.runtime.deployment.ResultPartitionLocation
-
- 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
-
- isNetworkStrategy() - Method in enum org.apache.flink.runtime.operators.shipping.ShipStrategyType
-
- isOutputVertex() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
- isPersistent() - Method in enum org.apache.flink.runtime.io.network.partition.ResultPartitionType
-
- isPipelined() - Method in enum org.apache.flink.runtime.io.network.partition.ResultPartitionType
-
- isPowerOf2(long) - Static method in class org.apache.flink.runtime.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.
- 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.
- isQueuedSchedulingAllowed() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- isRecycled() - Method in class org.apache.flink.runtime.io.network.buffer.Buffer
-
- isRegistered(ActorRef) - Method in class org.apache.flink.runtime.instance.InstanceManager
-
- isReleased() - Method in class org.apache.flink.runtime.instance.Slot
-
Checks of the slot has been released.
- isReleased() - Method in class org.apache.flink.runtime.io.network.partition.consumer.UnknownInputChannel
-
Returns false
.
- isReleased() - Method in class org.apache.flink.runtime.io.network.partition.ResultSubpartition
-
- isReleased() - Method in interface org.apache.flink.runtime.io.network.partition.ResultSubpartitionView
-
- isRemote() - Method in class org.apache.flink.runtime.deployment.ResultPartitionLocation
-
- 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.runtime.operators.sort.UnilateralSortMerger.ThreadBase
-
Checks whether this thread is still alive.
- isScheduleLocalOnly() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- isSecurityEnabled() - Static method in class org.apache.flink.runtime.security.SecurityUtils
-
- 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.io.network.NetworkEnvironment
-
- isShutdown() - Method in class org.apache.flink.runtime.memory.MemoryManager
-
Checks whether the MemoryManager has been shut down.
- isSolutionSetUnmanaged() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- isSolutionSetUpdate - Variable in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
-
- 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
.
- isStoppable() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- isStoppable() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
- isSynchronous() - Method in enum org.apache.flink.runtime.io.disk.iomanager.IOManager.IOMode
-
- isTerminal() - Method in enum org.apache.flink.runtime.execution.ExecutionState
-
- isTerminalState() - Method in enum org.apache.flink.runtime.jobgraph.JobStatus
-
- isUnknown() - Method in class org.apache.flink.runtime.deployment.ResultPartitionLocation
-
- isWorksetIteration - Variable in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
-
- isWorksetUpdate - Variable in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
-
- isZooKeeperRecoveryMode(Configuration) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
-
- IterationAggregatorBroker - Class in org.apache.flink.runtime.iterative.concurrent
-
- IterationAggregatorBroker() - Constructor for class org.apache.flink.runtime.iterative.concurrent.IterationAggregatorBroker
-
- IterationEventWithAggregators - Class in org.apache.flink.runtime.iterative.event
-
- 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 org.apache.flink.api.common.functions.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() - Constructor for class org.apache.flink.runtime.iterative.task.IterationHeadTask
-
- IterationIntermediateTask<S extends org.apache.flink.api.common.functions.Function,OT> - Class in org.apache.flink.runtime.iterative.task
-
An intermediate iteration task, which runs a
Driver
inside.
- IterationIntermediateTask() - Constructor for class org.apache.flink.runtime.iterative.task.IterationIntermediateTask
-
- IterationSynchronizationSinkTask - Class in org.apache.flink.runtime.iterative.task
-
The task responsible for synchronizing all iteration heads, implemented as an output task.
- IterationSynchronizationSinkTask() - Constructor for class org.apache.flink.runtime.iterative.task.IterationSynchronizationSinkTask
-
- IterationTailTask<S extends org.apache.flink.api.common.functions.Function,OT> - Class in org.apache.flink.runtime.iterative.task
-
An iteration tail, which runs a driver inside.
- IterationTailTask() - Constructor for class org.apache.flink.runtime.iterative.task.IterationTailTask
-
- iterativeBroadcastInputs - Variable in class org.apache.flink.runtime.operators.BatchTask
-
The indices of the iterative broadcast inputs.
- iterativeInputs - Variable in class org.apache.flink.runtime.operators.BatchTask
-
The indices of the iterative inputs.
- 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.util.EmptyIterator
-
- 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.runtime.util.UnionIterator
-
- 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.
- iteratorLock - Variable in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger
-
The monitor which guards the iterator field.
- 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
-
- 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
-
- 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(DataInputView) - Method in class org.apache.flink.runtime.instance.InstanceConnectionInfo
-
- 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.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.operators.util.TaskConfig.DelegatingConfiguration
-
- 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(byte[], int, int) - Method in class org.apache.flink.runtime.util.DataInputDeserializer
-
- read(byte[]) - Method in class org.apache.flink.runtime.util.DataInputDeserializer
-
- read(DataInputView) - Method in class org.apache.flink.runtime.util.SerializableArrayList
-
- read(DataInputView) - Method in class org.apache.flink.runtime.util.SerializableHashMap
-
- read(DataInputView) - Method in class org.apache.flink.runtime.util.SerializableHashSet
-
- readAndSetBroadcastInput(int, String, DistributedRuntimeUDFContext, int) - Method in class org.apache.flink.runtime.operators.BatchTask
-
- 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.runtime.memory.AbstractPagedInputView
-
- readBoolean() - Method in class org.apache.flink.runtime.util.DataInputDeserializer
-
- readByte() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
-
- readByte() - Method in class org.apache.flink.runtime.util.DataInputDeserializer
-
- readChar() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
-
- readChar() - Method in class org.apache.flink.runtime.util.DataInputDeserializer
-
- readDouble() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
-
- readDouble() - Method in class org.apache.flink.runtime.util.DataInputDeserializer
-
- reader - Variable in class org.apache.flink.runtime.io.disk.iomanager.ChannelReaderInputView
-
- Reader<T extends org.apache.flink.core.io.IOReadableWritable> - Interface in org.apache.flink.runtime.io.network.api.reader
-
A record-oriented reader for immutable record types.
- 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
-
A MutableObjectIterator
that wraps a reader from an input channel and
produces the reader's records.
- ReaderIterator(MutableReader<DeserializationDelegate<T>>, TypeSerializer<T>) - Constructor for class org.apache.flink.runtime.operators.util.ReaderIterator
-
Creates a new iterator, wrapping the given reader.
- readFloat() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
-
- readFloat() - Method in class org.apache.flink.runtime.util.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(byte[]) - Method in class org.apache.flink.runtime.util.DataInputDeserializer
-
- readFully(byte[], int, int) - Method in class org.apache.flink.runtime.util.DataInputDeserializer
-
- readFully(InputStream, byte[], int, int) - Static method in class org.apache.flink.runtime.util.IOUtils
-
Reads len bytes in a loop.
- 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.runtime.memory.AbstractPagedInputView
-
- readInt() - Method in class org.apache.flink.runtime.util.DataInputDeserializer
-
- 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
-
- readLine() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
-
- readLine() - Method in class org.apache.flink.runtime.util.DataInputDeserializer
-
- readLong() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
-
- readLong() - Method in class org.apache.flink.runtime.util.DataInputDeserializer
-
- readPhase - Variable in class org.apache.flink.runtime.operators.resettable.NonReusingBlockResettableIterator
-
- 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
-
- readShort() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
-
- readShort() - Method in class org.apache.flink.runtime.util.DataInputDeserializer
-
- readUnsignedByte() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
-
- readUnsignedByte() - Method in class org.apache.flink.runtime.util.DataInputDeserializer
-
- readUnsignedShort() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
-
- readUnsignedShort() - Method in class org.apache.flink.runtime.util.DataInputDeserializer
-
- readUTF() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
-
- readUTF() - Method in class org.apache.flink.runtime.util.DataInputDeserializer
-
- 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
-
Receives a
DeclineCheckpoint
message and returns whether the
message was associated with a pending checkpoint.
- RecordDeserializer<T extends org.apache.flink.core.io.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
-
- RecordReader<T extends org.apache.flink.core.io.IOReadableWritable> - Class in org.apache.flink.runtime.io.network.api.reader
-
- RecordReader(InputGate, Class<T>) - Constructor for class org.apache.flink.runtime.io.network.api.reader.RecordReader
-
- RecordSerializer<T extends org.apache.flink.core.io.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
-
- RecordWriter<T extends org.apache.flink.core.io.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
-
- recover() - Method in interface org.apache.flink.runtime.checkpoint.CompletedCheckpointStore
-
- recover() - Method in class org.apache.flink.runtime.checkpoint.ZooKeeperCompletedCheckpointStore
-
Gets the latest checkpoint from ZooKeeper and removes all others.
- 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
-
- recoverJobGraphs() - Method in class org.apache.flink.runtime.jobmanager.StandaloneSubmittedJobGraphStore
-
- recoverJobGraphs() - Method in interface org.apache.flink.runtime.jobmanager.SubmittedJobGraphStore
-
Returns a list of all submitted
JobGraph
instances.
- recoverJobGraphs() - Method in class org.apache.flink.runtime.jobmanager.ZooKeeperSubmittedJobGraphStore
-
- RecoveryMode - Enum in org.apache.flink.runtime.jobmanager
-
Recovery mode for Flink's cluster execution.
- recursionLevel - Variable in class org.apache.flink.runtime.operators.hash.HashPartition
-
- recycle() - Method in class org.apache.flink.runtime.io.network.buffer.Buffer
-
- recycle(MemorySegment) - Method in interface org.apache.flink.runtime.io.network.buffer.BufferRecycler
-
Recycles the
MemorySegment
to its original
BufferPool
instance.
- 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
-
- 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
-
- register(Logger) - Static method in class org.apache.flink.runtime.util.SignalHandler
-
Register some signal handlers.
- 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.
- 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.
- registerConsumer() - Method in class org.apache.flink.runtime.executiongraph.IntermediateResult
-
- registeredPartitions - Variable in class org.apache.flink.runtime.io.network.partition.ResultPartitionManager
-
- registerExecutionListener(ActorGateway) - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- registerExecutionListener(ActorGateway) - Method in class org.apache.flink.runtime.taskmanager.Task
-
- registerJob(JobID, Collection<BlobKey>, Collection<URL>) - Method in class org.apache.flink.runtime.execution.librarycache.BlobLibraryCacheManager
-
- registerJob(JobID, Collection<BlobKey>, Collection<URL>) - Method in class org.apache.flink.runtime.execution.librarycache.FallbackLibraryCacheManager
-
- registerJob(JobID, Collection<BlobKey>, Collection<URL>) - Method in interface org.apache.flink.runtime.execution.librarycache.LibraryCacheManager
-
Registers a job with its required jar files and classpaths.
- registerJobStatusListener(ActorGateway) - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- registerListener(EventListener<InputGate>) - Method in interface org.apache.flink.runtime.io.network.partition.consumer.InputGate
-
- registerListener(EventListener<InputGate>) - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
-
- registerListener(EventListener<InputGate>) - Method in class org.apache.flink.runtime.io.network.partition.consumer.UnionInputGate
-
- registerListener(NotificationListener) - Method in interface org.apache.flink.runtime.io.network.partition.ResultSubpartitionView
-
Subscribes to data availability notifications.
- 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.
- registerResultPartition(ResultPartition) - Method in class org.apache.flink.runtime.io.network.partition.ResultPartitionManager
-
- registerTask(JobID, ExecutionAttemptID, Collection<BlobKey>, Collection<URL>) - Method in class org.apache.flink.runtime.execution.librarycache.BlobLibraryCacheManager
-
- registerTask(JobID, ExecutionAttemptID, Collection<BlobKey>, Collection<URL>) - Method in class org.apache.flink.runtime.execution.librarycache.FallbackLibraryCacheManager
-
- registerTask(JobID, ExecutionAttemptID, Collection<BlobKey>, 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
-
- registerTaskManager(ActorRef, InstanceConnectionInfo, HardwareDescription, int, UUID) - Method in class org.apache.flink.runtime.instance.InstanceManager
-
Registers a task manager.
- registerWriterForIncomingTaskEvents(ResultPartitionID, ResultPartitionWriter) - Method in class org.apache.flink.runtime.io.network.TaskEventDispatcher
-
- RegularToMutableObjectIterator<T> - Class in org.apache.flink.runtime.util
-
- RegularToMutableObjectIterator(Iterator<T>, TypeSerializer<T>) - Constructor for class org.apache.flink.runtime.util.RegularToMutableObjectIterator
-
- 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(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.
- releaseAll(Object) - Method in class org.apache.flink.runtime.memory.MemoryManager
-
Releases all memory segments for the given owner.
- releaseAllReferencesFromTask(BatchTask<?, ?>) - Method in class org.apache.flink.runtime.broadcast.BroadcastVariableManager
-
- releaseAllResources() - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
-
- releaseAllResources() - Method in class org.apache.flink.runtime.io.network.partition.consumer.UnknownInputChannel
-
- releaseAllResources() - Method in interface org.apache.flink.runtime.io.network.partition.ResultSubpartitionView
-
- releaseArrays() - Method in class org.apache.flink.runtime.util.DataInputDeserializer
-
- releaseBroadcastVariables(String, int, DistributedRuntimeUDFContext) - Method in class org.apache.flink.runtime.operators.BatchTask
-
- 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.
- 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
-
- 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
-
- releaseSlot() - Method in class org.apache.flink.runtime.instance.SharedSlot
-
- releaseSlot() - Method in class org.apache.flink.runtime.instance.SimpleSlot
-
- releaseSlot() - Method in class org.apache.flink.runtime.instance.Slot
-
This method cancels and releases the slot and all its sub-slots.
- 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
-
- remainingCapacity() - Method in class org.apache.flink.runtime.operators.sort.PartialOrderPriorityQueue
-
Returns the remaining capacity of the backing array.
- 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) - Constructor for class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
-
- RemoteInputChannel(SingleInputGate, int, ResultPartitionID, ConnectionID, ConnectionManager, Tuple2<Integer, Integer>) - Constructor for class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
-
- RemoteInputChannel.BufferReorderingException - Exception in org.apache.flink.runtime.io.network.partition.consumer
-
- 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(String) - Method in class org.apache.flink.runtime.iterative.concurrent.Broker
-
blocking retrieval and removal of the object to share
- remove() - Method in class org.apache.flink.runtime.jobgraph.tasks.InputSplitIterator
-
- 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.util.EmptyIterator
-
- remove(K) - Method in class org.apache.flink.runtime.util.LRUCacheMap
-
- 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() - Method in class org.apache.flink.runtime.util.UnionIterator
-
- remove(String) - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
-
Removes a state handle from ZooKeeper.
- remove(String, BackgroundCallback) - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
-
Removes a state handle from ZooKeeper asynchronously.
- removeAll(Collection<?>) - Method in class org.apache.flink.runtime.jobmanager.scheduler.SetQueue
-
- removeAndDiscardAllState() - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
-
Discards all available state handles and removes them from ZooKeeper.
- removeAndDiscardState(String) - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
-
Discards a state handle and removes it from ZooKeeper.
- removeInstanceListener(InstanceListener) - Method in class org.apache.flink.runtime.instance.InstanceManager
-
- 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
-
- removeLast() - Method in class org.apache.flink.runtime.util.IntArrayList
-
- removeLong(int) - Method in class org.apache.flink.runtime.util.LongArrayList
-
- removeLRU() - Method in class org.apache.flink.runtime.util.LRUCache
-
- removeLRU() - Method in class org.apache.flink.runtime.util.LRUCacheMap
-
- RemoveRangeIndex<T> - Class in org.apache.flink.runtime.operators.udf
-
- RemoveRangeIndex() - Constructor for class org.apache.flink.runtime.operators.udf.RemoveRangeIndex
-
- removeSlotListener() - Method in class org.apache.flink.runtime.instance.Instance
-
Removes the listener that receives notifications for slot availability.
- removeVertexFromGroup(JobVertexID) - Method in class org.apache.flink.runtime.jobmanager.scheduler.SlotSharingGroup
-
- rename(Path, Path) - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileSystem
-
- rename(Path, Path) - Method in class org.apache.flink.runtime.fs.maprfs.MapRFileSystem
-
- 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
- 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.
- 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, byte[]) - Method in class org.apache.flink.runtime.instance.InstanceManager
-
- reportNumBytesIn(long) - Method in interface org.apache.flink.runtime.accumulators.AccumulatorRegistry.Reporter
-
- reportNumBytesOut(long) - Method in interface org.apache.flink.runtime.accumulators.AccumulatorRegistry.Reporter
-
- reportNumRecordsIn(long) - Method in interface org.apache.flink.runtime.accumulators.AccumulatorRegistry.Reporter
-
- reportNumRecordsOut(long) - Method in interface org.apache.flink.runtime.accumulators.AccumulatorRegistry.Reporter
-
- requestBuffer() - Method in interface org.apache.flink.runtime.io.network.buffer.BufferProvider
-
Returns a
Buffer
instance from the buffer provider, if one is available.
- requestBufferBlocking() - Method in interface org.apache.flink.runtime.io.network.buffer.BufferProvider
-
Returns a
Buffer
instance from the buffer provider.
- RequestDoneCallback<T> - Interface in org.apache.flink.runtime.io.disk.iomanager
-
Callback to be executed on completion of an asynchronous I/O request.
- 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
-
- 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
-
- RequestJobsOverview - Class in org.apache.flink.runtime.messages.webmonitor
-
This message requests an overview of how many jobs are in which status.
- RequestJobsWithIDsOverview - Class in org.apache.flink.runtime.messages.webmonitor
-
This message requests an overview of how many jobs are in which status.
- requestMemorySegment() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
-
- 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
-
- 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
-
- 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.
- 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.UnknownInputChannel
-
- 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
-
- 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
-
- requiresComparator() - Method in enum org.apache.flink.runtime.operators.shipping.ShipStrategyType
-
- requiresComparator() - Method in enum org.apache.flink.runtime.operators.util.LocalStrategy
-
- RequiresLeaderSessionID - Interface in org.apache.flink.runtime.messages
-
Marks messages to be sent wrapped in a
JobManagerMessages.LeaderSessionMessage
- 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 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
-
- resetConstraints() - Method in class org.apache.flink.runtime.jobmanager.scheduler.CoLocationGroup
-
- resetEndOfSuperstep() - Method in class org.apache.flink.runtime.iterative.task.SyncEventHandler
-
- resetForNewExecution() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
- resetForNewExecution() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- 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
- 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
- ResettableDriver<S extends org.apache.flink.api.common.functions.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.
- ResourceId - Class in org.apache.flink.runtime.jobmanager.scheduler
-
- ResourceId() - Constructor for class org.apache.flink.runtime.jobmanager.scheduler.ResourceId
-
- restart() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- restart(ExecutionGraph) - Method in class org.apache.flink.runtime.executiongraph.restart.FixedDelayRestartStrategy
-
- restart(ExecutionGraph) - Method in class org.apache.flink.runtime.executiongraph.restart.NoRestartStrategy
-
- restart(ExecutionGraph) - Method in interface org.apache.flink.runtime.executiongraph.restart.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
-
- restoreLatestCheckpointedState(Map<JobVertexID, ExecutionJobVertex>, boolean, boolean) - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
- restoreLatestCheckpointedState() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
Restores the latest checkpointed state.
- restoreSavepoint(Map<JobVertexID, ExecutionJobVertex>, String) - Method in class org.apache.flink.runtime.checkpoint.SavepointCoordinator
-
Resets the state of
Execution
instances back to the state of a savepoint.
- restoreSavepoint(String) - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
Restores the execution state back to a savepoint.
- restoreState(Backend, TypeSerializer<K>, ClassLoader, long) - Method in class org.apache.flink.runtime.state.AsynchronousKvStateSnapshot
-
- restoreState(FsStateBackend, TypeSerializer<K>, ClassLoader, long) - Method in class org.apache.flink.runtime.state.filesystem.AbstractFsStateSnapshot
-
- restoreState(Backend, TypeSerializer<K>, ClassLoader, long) - Method in interface org.apache.flink.runtime.state.KvStateSnapshot
-
Loads the key/value state back from this snapshot.
- restoreState(MemoryStateBackend, TypeSerializer<K>, ClassLoader, long) - Method in class org.apache.flink.runtime.state.memory.AbstractMemStateSnapshot
-
- resultHandler - Variable in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousFileIOChannel
-
Handler for completed requests
- ResultPartition - Class in org.apache.flink.runtime.io.network.partition
-
A result partition for data produced by a single task.
- ResultPartition(String, JobID, ResultPartitionID, ResultPartitionType, boolean, int, ResultPartitionManager, ResultPartitionConsumableNotifier, IOManager, IOManager.IOMode) - Constructor for class org.apache.flink.runtime.io.network.partition.ResultPartition
-
- ResultPartitionConsumableNotifier - Interface in org.apache.flink.runtime.io.network.partition
-
- ResultPartitionDeploymentDescriptor - Class in org.apache.flink.runtime.deployment
-
Deployment descriptor for a result partition.
- ResultPartitionDeploymentDescriptor(IntermediateDataSetID, IntermediateResultPartitionID, ResultPartitionType, 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
-
- ResultPartitionProvider - Interface in org.apache.flink.runtime.io.network.partition
-
- ResultPartitionType - Enum in org.apache.flink.runtime.io.network.partition
-
- ResultPartitionWriter - Class in org.apache.flink.runtime.io.network.api.writer
-
A buffer-oriented runtime result writer.
- ResultPartitionWriter(ResultPartition) - Constructor for class org.apache.flink.runtime.io.network.api.writer.ResultPartitionWriter
-
- ResultSubpartition - Class in org.apache.flink.runtime.io.network.partition
-
- ResultSubpartition(int, ResultPartition) - Constructor for class org.apache.flink.runtime.io.network.partition.ResultSubpartition
-
- ResultSubpartitionView - Interface in org.apache.flink.runtime.io.network.partition
-
- retain() - Method in class org.apache.flink.runtime.io.network.buffer.Buffer
-
- retainAll(Collection<?>) - Method in class org.apache.flink.runtime.jobmanager.scheduler.SetQueue
-
- 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
-
- retriggerPartitionRequest(IntermediateResultPartitionID) - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
-
Retriggers a partition request.
- 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.
- returnAllocatedSlot(Slot) - Method in class org.apache.flink.runtime.instance.Instance
-
Returns a slot that has been allocated from this instance.
- 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
-
This class wraps a
MutableObjectIterator
into a regular
Iterator
.
- 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
-
- RevisionInformation(String, String) - Constructor for class org.apache.flink.runtime.util.EnvironmentInformation.RevisionInformation
-
- 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.
- 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
-
- 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.runtime.util.MathUtils
-
Decrements the given number down to the closest power of two.
- RoundRobinChannelSelector<T extends org.apache.flink.core.io.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.
- run() - Method in class org.apache.flink.runtime.blob.BlobServer
-
- run() - Method in class org.apache.flink.runtime.execution.librarycache.BlobLibraryCacheManager
-
Cleans up blobs which are not referenced anymore
- 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 interface org.apache.flink.runtime.security.SecurityUtils.FlinkSecuredRunner
-
- 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 it code
- 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.
- 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
-
- runSecured(SecurityUtils.FlinkSecuredRunner<T>) - Static method in class org.apache.flink.runtime.security.SecurityUtils
-
- RuntimeAggregatorRegistry - Class in org.apache.flink.runtime.iterative.task
-
- RuntimeAggregatorRegistry(Collection<AggregatorWithName<?>>) - Constructor for class org.apache.flink.runtime.iterative.task.RuntimeAggregatorRegistry
-
- RuntimeEnvironment - Class in org.apache.flink.runtime.taskmanager
-
- RuntimeEnvironment(JobID, JobVertexID, ExecutionAttemptID, TaskInfo, Configuration, Configuration, ClassLoader, MemoryManager, IOManager, BroadcastVariableManager, AccumulatorRegistry, InputSplitProvider, Map<String, Future<Path>>, ResultPartitionWriter[], InputGate[], ActorGateway, TaskManagerRuntimeInfo) - 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
-
- runtimeUdfContext - Variable in class org.apache.flink.runtime.operators.BatchTask
-
The udf's runtime context.
- SAVEPOINT_BACKEND_KEY - Static variable in class org.apache.flink.runtime.checkpoint.SavepointStoreFactory
-
- SAVEPOINT_DIRECTORY_KEY - Static variable in class org.apache.flink.runtime.checkpoint.SavepointStoreFactory
-
- SavepointCoordinator - Class in org.apache.flink.runtime.checkpoint
-
The savepoint coordinator is a slightly modified variant of the regular
checkpoint coordinator.
- SavepointCoordinator(JobID, long, long, ExecutionVertex[], ExecutionVertex[], ExecutionVertex[], ClassLoader, CheckpointIDCounter, StateStore<CompletedCheckpoint>, CheckpointStatsTracker) - Constructor for class org.apache.flink.runtime.checkpoint.SavepointCoordinator
-
- SavepointCoordinatorDeActivator - Class in org.apache.flink.runtime.checkpoint
-
This actor listens to changes in the JobStatus and deactivates the
savepoint scheduler and discards all pending checkpoints.
- SavepointCoordinatorDeActivator(SavepointCoordinator, UUID) - Constructor for class org.apache.flink.runtime.checkpoint.SavepointCoordinatorDeActivator
-
- SavepointStore - Class in org.apache.flink.runtime.checkpoint
-
Simple wrapper around the state store for savepoints.
- SavepointStore(StateStore<CompletedCheckpoint>) - Constructor for class org.apache.flink.runtime.checkpoint.SavepointStore
-
- SavepointStoreFactory - Class in org.apache.flink.runtime.checkpoint
-
- SavepointStoreFactory() - Constructor for class org.apache.flink.runtime.checkpoint.SavepointStoreFactory
-
- scheduleAll(Scheduler, boolean) - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
- ScheduledUnit - Class in org.apache.flink.runtime.jobmanager.scheduler
-
- ScheduledUnit(Execution) - Constructor for class org.apache.flink.runtime.jobmanager.scheduler.ScheduledUnit
-
- ScheduledUnit(Execution, SlotSharingGroup) - Constructor for class org.apache.flink.runtime.jobmanager.scheduler.ScheduledUnit
-
- ScheduledUnit(Execution, SlotSharingGroup, CoLocationConstraint) - Constructor for class org.apache.flink.runtime.jobmanager.scheduler.ScheduledUnit
-
- scheduleForExecution(Scheduler, boolean) - 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(Scheduler) - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- scheduleForExecution(Scheduler, boolean) - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- scheduleImmediately(ScheduledUnit) - Method in class org.apache.flink.runtime.jobmanager.scheduler.Scheduler
-
- ScheduleMode - Enum in org.apache.flink.runtime.jobgraph
-
- scheduleOrUpdateConsumers(ResultPartitionID) - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- scheduleQueued(ScheduledUnit) - Method in class org.apache.flink.runtime.jobmanager.scheduler.Scheduler
-
- 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(ExecutionContext) - Constructor for class org.apache.flink.runtime.jobmanager.scheduler.Scheduler
-
Creates a new scheduler.
- secondDam() - Method in enum org.apache.flink.runtime.operators.DriverStrategy
-
- SecurityUtils - Class in org.apache.flink.runtime.security
-
A utility class that lets program code run in a security context provided by the
Hadoop security user groups.
- SecurityUtils.FlinkSecuredRunner<T> - Interface in org.apache.flink.runtime.security
-
- seek(long) - Method in class org.apache.flink.runtime.fs.hdfs.HadoopDataInputStream
-
- seek(long) - Method in class org.apache.flink.runtime.io.disk.SeekableFileChannelInputView
-
- SeekableFileChannelInputView - Class in org.apache.flink.runtime.io.disk
-
A
DataInputView
that is backed by a
BlockChannelReader
,
making it effectively a data input stream.
- 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.
- 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
-
- 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(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.
- 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
-
- SEND_RECEIVE_BUFFER_SIZE - Static variable in class org.apache.flink.runtime.io.network.netty.NettyConfig
-
- sendEndOfSuperstep() - Method in class org.apache.flink.runtime.io.network.api.writer.RecordWriter
-
- sendMessageToCurrentExecution(Serializable, ExecutionAttemptID) - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- sendMessageToCurrentExecution(Serializable, ExecutionAttemptID, ActorGateway) - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- sendReadRequest(MemorySegment) - Method in class org.apache.flink.runtime.io.disk.iomanager.ChannelReaderInputView
-
Sends a new read requests, if further requests remain.
- 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
-
- sendTaskEvent(TaskEvent) - Method in class org.apache.flink.runtime.io.network.partition.consumer.UnknownInputChannel
-
- SerializableArrayList<E extends org.apache.flink.core.io.IOReadableWritable> - Class in org.apache.flink.runtime.util
-
This class extends a standard
ArrayList
by implementing the
IOReadableWritable
interface.
- SerializableArrayList() - Constructor for class org.apache.flink.runtime.util.SerializableArrayList
-
Constructs an empty list with an initial capacity of ten.
- SerializableArrayList(int) - Constructor for class org.apache.flink.runtime.util.SerializableArrayList
-
Constructs an empty list with the specified initial capacity.
- SerializableHashMap<K extends org.apache.flink.core.io.IOReadableWritable,V extends org.apache.flink.core.io.IOReadableWritable> - Class in org.apache.flink.runtime.util
-
This class extends a standard
HashMap
by implementing the
IOReadableWritable
interface.
- SerializableHashMap() - Constructor for class org.apache.flink.runtime.util.SerializableHashMap
-
- SerializableHashSet<T extends org.apache.flink.core.io.IOReadableWritable> - Class in org.apache.flink.runtime.util
-
This class extends a standard
HashSet
by implementing the
IOReadableWritable
interface.
- SerializableHashSet() - Constructor for class org.apache.flink.runtime.util.SerializableHashSet
-
- SerializableObject - Class in org.apache.flink.runtime.util
-
A simple object that only implements
Serializable
, so it can be used
in serializable classes.
- SerializableObject() - Constructor for class org.apache.flink.runtime.util.SerializableObject
-
- 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
-
- serialize(ArrayList<T>, DataOutputView) - Method in class org.apache.flink.runtime.state.ArrayListSerializer
-
- SerializedCheckpointData - Class in org.apache.flink.runtime.state
-
This class represents serialized checkpoint data for a collection of elements.
- SerializedCheckpointData(long, byte[], int) - Constructor for class org.apache.flink.runtime.state.SerializedCheckpointData
-
Creates a SerializedCheckpointData object for the given serialized data.
- SerializedJobExecutionResult - Class in org.apache.flink.runtime.client
-
A variant of the JobExecutionResult
that holds
its accumulator data in serialized form.
- SerializedJobExecutionResult(JobID, long, Map<String, SerializedValue<Object>>) - Constructor for class org.apache.flink.runtime.client.SerializedJobExecutionResult
-
Creates a new SerializedJobExecutionResult.
- SerializedStateHandle<T extends Serializable> - Class in org.apache.flink.runtime.state.memory
-
A state handle that represents its state in serialized form as bytes.
- SerializedStateHandle(T) - Constructor for class org.apache.flink.runtime.state.memory.SerializedStateHandle
-
Creates a new serialized state handle, eagerly serializing the given state object.
- SerializedStateHandle(byte[]) - Constructor for class org.apache.flink.runtime.state.memory.SerializedStateHandle
-
Creates a new serialized state handle, based in the given already serialized data.
- SerializedThrowable - Exception in org.apache.flink.runtime.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.runtime.util.SerializedThrowable
-
Create a new SerializedThrowable.
- 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
-
- 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
-
- serializer1 - Variable in class org.apache.flink.runtime.operators.sort.AbstractMergeIterator
-
- serializer2 - Variable in class org.apache.flink.runtime.operators.sort.AbstractMergeIterator
-
- 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(E) - Method in class org.apache.flink.runtime.util.SingleElementIterator
-
Resets the element.
- setAccumulators(Map<AccumulatorRegistry.Metric, Accumulator<?, ?>>, Map<String, Accumulator<?, ?>>) - Method in class org.apache.flink.runtime.executiongraph.Execution
-
Update accumulators (discarded when the Execution has already been terminated).
- setAllowQueuedScheduling(boolean) - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
- setBitsLocation(MemorySegment, int) - Method in class org.apache.flink.runtime.operators.util.BloomFilter
-
- setBoolean(String, boolean) - Method in class org.apache.flink.runtime.operators.util.TaskConfig.DelegatingConfiguration
-
- setBroadcastGateIterativeWithNumberOfEventsUntilInterrupt(int, int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setBroadcastInputName(String, int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setBroadcastInputSerializer(TypeSerializerFactory<?>, int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setBroadcastVariable(String, BroadcastVariableMaterialization<?, ?>) - Method in class org.apache.flink.runtime.operators.util.DistributedRuntimeUDFContext
-
- setBuffer(ByteBuffer) - Method in class org.apache.flink.runtime.util.DataInputDeserializer
-
- setBuffer(byte[], int, int) - Method in class org.apache.flink.runtime.util.DataInputDeserializer
-
- setBufferPool(BufferPool) - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
-
- setBufferPoolOwner(BufferPoolOwner) - Method in interface org.apache.flink.runtime.io.network.buffer.BufferPool
-
The owner of this buffer pool to be called when memory needs to be released to avoid back
pressure.
- setBytes(String, byte[]) - Method in class org.apache.flink.runtime.operators.util.TaskConfig.DelegatingConfiguration
-
- setChannelIndex(int) - Method in class org.apache.flink.runtime.io.network.partition.consumer.BufferOrEvent
-
- setClass(String, Class<?>) - Method in class org.apache.flink.runtime.operators.util.TaskConfig.DelegatingConfiguration
-
- setClasspaths(List<URL>) - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
Sets the classpaths required to run the job on a task manager.
- setClientConnectTimeoutSeconds(int) - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
-
- setClientNumThreads(int) - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
-
- setConfigDir(String) - Method in class org.apache.flink.runtime.jobmanager.JobManagerCliOptions
-
- setConfigDir(String) - Method in class org.apache.flink.runtime.taskmanager.TaskManagerCliOptions
-
- setConfigurationDirectory(String) - Method in class org.apache.flink.runtime.yarn.AbstractFlinkYarnClient
-
- setConfigurationFilePath(Path) - Method in class org.apache.flink.runtime.yarn.AbstractFlinkYarnClient
-
- setConvergenceCriterion(String, ConvergenceCriterion<?>) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- 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
-
- setCurrentKey(K) - Method in class org.apache.flink.runtime.state.AbstractHeapState
-
- setCurrentKey(Object) - Method in class org.apache.flink.runtime.state.AbstractStateBackend
-
Sets the current key that is used for partitioned state.
- setCurrentKey(K) - Method in class org.apache.flink.runtime.state.GenericFoldingState
-
- setCurrentKey(K) - Method in class org.apache.flink.runtime.state.GenericListState
-
- setCurrentKey(K) - Method in class org.apache.flink.runtime.state.GenericReducingState
-
- setCurrentKey(K) - Method in interface org.apache.flink.runtime.state.KvState
-
Sets the current key, which will be used when using the state access methods.
- setCurrentNamespace(N) - Method in class org.apache.flink.runtime.state.AbstractHeapState
-
- setCurrentNamespace(N) - Method in class org.apache.flink.runtime.state.GenericFoldingState
-
- setCurrentNamespace(N) - Method in class org.apache.flink.runtime.state.GenericListState
-
- setCurrentNamespace(N) - Method in class org.apache.flink.runtime.state.GenericReducingState
-
- setCurrentNamespace(N) - Method in interface org.apache.flink.runtime.state.KvState
-
Sets the current namespace, which will be used when using the state access methods.
- setDetachedMode(boolean) - Method in class org.apache.flink.runtime.yarn.AbstractFlinkYarnClient
-
- setDouble(String, double) - Method in class org.apache.flink.runtime.operators.util.TaskConfig.DelegatingConfiguration
-
- 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
-
- setDriverPairComparator(TypePairComparatorFactory<?, ?>) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setDriverStrategy(DriverStrategy) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setDynamicPropertiesEncoded(String) - Method in class org.apache.flink.runtime.yarn.AbstractFlinkYarnClient
-
- setEagerlyDeployConsumers(boolean) - Method in class org.apache.flink.runtime.jobgraph.IntermediateDataSet
-
Sets the flag indicating whether to eagerly deploy consumers (default:
false
).
- setEnvironment(Environment) - Method in class org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
-
Sets the environment of this task.
- 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.
- setExecutedVertex(Execution) - 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.
- 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
-
- setFlinkConfiguration(Configuration) - Method in class org.apache.flink.runtime.yarn.AbstractFlinkYarnClient
-
Flink configuration
- setFlinkLoggingConfigurationPath(Path) - Method in class org.apache.flink.runtime.yarn.AbstractFlinkYarnClient
-
- setFloat(String, float) - Method in class org.apache.flink.runtime.operators.util.TaskConfig.DelegatingConfiguration
-
- setFormatDescription(String) - Method in class org.apache.flink.runtime.jobgraph.InputFormatVertex
-
- setFormatDescription(String) - Method in class org.apache.flink.runtime.jobgraph.OutputFormatVertex
-
- setFurtherPatitioning(boolean) - Method in class org.apache.flink.runtime.operators.hash.HashPartition
-
- setFutureAction(SlotAllocationFutureAction) - Method in class org.apache.flink.runtime.jobmanager.scheduler.SlotAllocationFuture
-
- setGateIterativeWithNumberOfEventsUntilInterrupt(int, int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setHost(String) - Method in class org.apache.flink.runtime.jobmanager.JobManagerCliOptions
-
- setInitialState(SerializedValue<StateHandle<?>>, long) - Method in class org.apache.flink.runtime.executiongraph.Execution
-
- setInitialState(T, long) - Method in interface org.apache.flink.runtime.jobgraph.tasks.StatefulTask
-
Sets the initial state of the operator, upon recovery.
- 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
-
- setInputLocalStrategy(int, LocalStrategy) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setInputSerializer(TypeSerializerFactory<?>, int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setInputSplitSource(InputSplitSource<?>) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
- 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
-
- setInteger(String, int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig.DelegatingConfiguration
-
- 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
-
- 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
-
- 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
-
- setJobManagerMemory(int) - Method in class org.apache.flink.runtime.yarn.AbstractFlinkYarnClient
-
- setJobManagerMode(String) - Method in class org.apache.flink.runtime.jobmanager.JobManagerCliOptions
-
- setJobStatusListener(ActorGateway) - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
- setJsonPlan(String) - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- setLastOutputCollector(Collector<OT>) - Method in class org.apache.flink.runtime.operators.BatchTask
-
Sets the last output
Collector
of the collector chain of this
BatchTask
.
- 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.runtime.yarn.AbstractFlinkYarnClient
-
- setLocationConstraintHosts(List<Instance>) - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- setLong(String, long) - Method in class org.apache.flink.runtime.operators.util.TaskConfig.DelegatingConfiguration
-
- 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
-
- setMetricsReport(byte[]) - Method in class org.apache.flink.runtime.instance.Instance
-
- setMutableObjectMode(boolean) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- 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.runtime.yarn.AbstractFlinkYarnClient
-
Set a name for the YARN application
- setNextBuffer(Buffer) - Method in class org.apache.flink.runtime.io.network.api.serialization.AdaptiveSpanningRecordDeserializer
-
- setNextBuffer(Buffer) - Method in interface org.apache.flink.runtime.io.network.api.serialization.RecordDeserializer
-
- setNextBuffer(Buffer) - Method in interface org.apache.flink.runtime.io.network.api.serialization.RecordSerializer
-
- setNextBuffer(Buffer) - Method in class org.apache.flink.runtime.io.network.api.serialization.SpanningRecordSerializer
-
- setNextBuffer(Buffer) - Method in class org.apache.flink.runtime.io.network.api.serialization.SpillingAdaptiveSpanningRecordDeserializer
-
- setNextMemorySegment(MemorySegment, int) - Method in class org.apache.flink.runtime.io.network.api.serialization.AdaptiveSpanningRecordDeserializer
-
- setNextMemorySegment(MemorySegment, int) - Method in interface org.apache.flink.runtime.io.network.api.serialization.RecordDeserializer
-
- setNextMemorySegment(MemorySegment, int) - Method in class org.apache.flink.runtime.io.network.api.serialization.SpillingAdaptiveSpanningRecordDeserializer
-
- setNumberOfIterations(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setNumberOfSlots(int) - Method in class org.apache.flink.runtime.yarn.FlinkYarnClusterStatus
-
- setNumberOfTaskManagers(int) - Method in class org.apache.flink.runtime.yarn.FlinkYarnClusterStatus
-
- setNumBuffers(int) - Method in interface org.apache.flink.runtime.io.network.buffer.BufferPool
-
Sets the current size of this buffer pool.
- setOperatorDescription(String) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
- 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
-
- setOperatorPrettyName(String) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
- setOperatorState(StatefulTask<?>, StateHandle<?>, long) - Static method in class org.apache.flink.runtime.state.StateUtils
-
Utility method to define a common generic bound to be used for setting a
generic state handle on a generic state carrier.
- 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
-
- setOutputPartitioner(Partitioner<?>, int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setOutputSerializer(TypeSerializerFactory<?>) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setParallelism(int) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
Sets the parallelism for the task.
- setPartition(int, IntermediateResultPartition) - Method in class org.apache.flink.runtime.executiongraph.IntermediateResult
-
- setPartitionNumber(int) - Method in class org.apache.flink.runtime.operators.hash.InMemoryPartition
-
overwrites partition number and should only be used on compaction partition
- setPreProcessingOperationName(String) - Method in class org.apache.flink.runtime.jobgraph.JobEdge
-
Sets the name of the pre-processing operation for this input.
- 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.runtime.yarn.AbstractFlinkYarnClient
-
- setQueuedSchedulingAllowed(boolean) - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- setReadPosition(long) - Method in class org.apache.flink.runtime.io.disk.RandomAccessInputView
-
- setReadPosition(long) - Method in class org.apache.flink.runtime.operators.hash.HashPartition
-
- 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
-
- setRelativeSolutionSetMemory(double) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setReporter(AccumulatorRegistry.Reporter) - Method in class org.apache.flink.runtime.io.network.api.reader.BufferReader
-
- setReporter(AccumulatorRegistry.Reporter) - Method in interface org.apache.flink.runtime.io.network.api.reader.ReaderBase
-
Setter for the reporter, e.g.
- setReporter(AccumulatorRegistry.Reporter) - Method in class org.apache.flink.runtime.io.network.api.serialization.AdaptiveSpanningRecordDeserializer
-
- setReporter(AccumulatorRegistry.Reporter) - Method in interface org.apache.flink.runtime.io.network.api.serialization.RecordDeserializer
-
Setter for the reporter, e.g.
- setReporter(AccumulatorRegistry.Reporter) - Method in interface org.apache.flink.runtime.io.network.api.serialization.RecordSerializer
-
Setter for the reporter, e.g.
- setReporter(AccumulatorRegistry.Reporter) - Method in class org.apache.flink.runtime.io.network.api.serialization.SpanningRecordSerializer
-
- setReporter(AccumulatorRegistry.Reporter) - Method in class org.apache.flink.runtime.io.network.api.serialization.SpillingAdaptiveSpanningRecordDeserializer
-
- setReporter(AccumulatorRegistry.Reporter) - Method in class org.apache.flink.runtime.io.network.api.writer.RecordWriter
-
Counter for the number of records emitted and the records processed.
- setRestartStrategyConfiguration(RestartStrategies.RestartStrategyConfiguration) - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
Sets the restart strategy configuration.
- 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
-
- setSavepointPath(String) - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
Sets the savepoint path to rollback the deployment to.
- setSavepointPath(String) - Method in class org.apache.flink.runtime.jobgraph.tasks.JobSnapshottingSettings
-
Sets the savepoint path.
- setScheduleLocalOnly(boolean) - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- setScheduleMode(ScheduleMode) - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- setScheduleMode(ScheduleMode) - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
- setSendAndReceiveBufferSize(int) - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
-
- setServerConnectBacklog(int) - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
-
- setServerNumThreads(int) - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
-
- setSessionTimeout(long) - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
Sets the timeout of the session in seconds.
- setSharedSlot(SharedSlot) - Method in class org.apache.flink.runtime.jobmanager.scheduler.CoLocationConstraint
-
Assigns a new shared slot to this co-location constraint.
- setShipFiles(List<File>) - Method in class org.apache.flink.runtime.yarn.AbstractFlinkYarnClient
-
List of files to transfer to the YARN containers.
- 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 class org.apache.flink.runtime.io.network.buffer.Buffer
-
- setSlot(SimpleSlot) - Method in class org.apache.flink.runtime.jobmanager.scheduler.SlotAllocationFuture
-
- setSlotAvailabilityListener(SlotAvailabilityListener) - Method in class org.apache.flink.runtime.instance.Instance
-
Sets the listener that receives notifications for slot availability.
- setSlotSharingGroup(SlotSharingGroup) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
Associates this vertex with a slot sharing group for scheduling.
- setSnapshotSettings(JobSnapshottingSettings) - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
Sets the settings for asynchronous snapshots.
- setSolutionSetComparator(TypeComparatorFactory<?>) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setSolutionSetSerializer(TypeSerializerFactory<?>) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setSolutionSetUnmanaged(boolean) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- 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
-
- 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.runtime.operators.util.TaskConfig.DelegatingConfiguration
-
- 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
-
- setTaskManagerCount(int) - Method in class org.apache.flink.runtime.yarn.AbstractFlinkYarnClient
-
- setTaskManagerMemory(int) - Method in class org.apache.flink.runtime.yarn.AbstractFlinkYarnClient
-
- setTaskManagerSlots(int) - Method in class org.apache.flink.runtime.yarn.AbstractFlinkYarnClient
-
- setTaskName(String) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setTransportType(String) - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
-
- setUdfConfiguration(Configuration) - Method in class org.apache.flink.runtime.operators.sort.CombiningUnilateralSortMerger
-
- 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.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
-
- setWaitForSolutionSetUpdate() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setWebUIPort(int) - Method in class org.apache.flink.runtime.jobmanager.JobManagerCliOptions
-
- setWritePosition(long) - Method in class org.apache.flink.runtime.io.disk.RandomAccessOutputView
-
- SharedSlot - Class in org.apache.flink.runtime.instance
-
This class represents a shared slot.
- SharedSlot(JobID, Instance, int, 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(JobID, Instance, int, 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.
- 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.
- shouldIncludeFinished() - Method in class org.apache.flink.runtime.messages.webmonitor.RequestJobDetails
-
- shouldIncludeRunning() - Method in class org.apache.flink.runtime.messages.webmonitor.RequestJobDetails
-
- shutdown() - Method in class org.apache.flink.runtime.blob.BlobCache
-
- shutdown() - Method in class org.apache.flink.runtime.blob.BlobServer
-
Shuts down the BLOB server.
- shutdown() - Method in interface org.apache.flink.runtime.blob.BlobService
-
Shutdown method which is called to terminate the blob service.
- shutdown() - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
Shuts down the checkpoint coordinator.
- shutdown() - Method in class org.apache.flink.runtime.execution.librarycache.BlobLibraryCacheManager
-
- shutdown() - Method in class org.apache.flink.runtime.execution.librarycache.FallbackLibraryCacheManager
-
- shutdown() - Method in interface org.apache.flink.runtime.execution.librarycache.LibraryCacheManager
-
Shutdown method
- 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.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.memory.MemoryManager
-
Shuts the memory manager down, trying to release all the memory it managed.
- shutdown() - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.ThreadBase
-
Forces an immediate shutdown of the thread.
- shutdown() - Method in class org.apache.flink.runtime.taskmanager.MemoryLogger
-
- shutdown(boolean) - Method in class org.apache.flink.runtime.yarn.AbstractFlinkYarnCluster
-
Request the YARN cluster to shut down.
- 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
-
- SimpleCheckpointStatsTracker - Class in org.apache.flink.runtime.checkpoint.stats
-
A simple checkpoint stats tracker.
- SimpleCheckpointStatsTracker(int, List<ExecutionJobVertex>) - Constructor for class org.apache.flink.runtime.checkpoint.stats.SimpleCheckpointStatsTracker
-
- 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
-
- 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
-
- 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(JobID, Instance, 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(JobID, Instance, int, 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..
- 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, ExecutionAttemptID, IntermediateDataSetID, int, int, PartitionStateChecker) - Constructor for class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
-
- 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.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.state.AbstractHeapState
-
Returns the number of all state pairs in this state, across namespaces.
- 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.runtime.util.LRUCache
-
- size() - Method in class org.apache.flink.runtime.util.LRUCacheMap
-
- skip(long) - Method in class org.apache.flink.runtime.fs.hdfs.HadoopDataInputStream
-
- skipBytes(int) - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
-
- skipBytes(int) - Method in class org.apache.flink.runtime.util.DataInputDeserializer
-
- skipBytesToRead(int) - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
-
- skipBytesToRead(int) - Method in class org.apache.flink.runtime.util.DataInputDeserializer
-
- skipBytesToWrite(int) - Method in class org.apache.flink.runtime.memory.AbstractPagedOutputView
-
- skipBytesToWrite(int) - Method in class org.apache.flink.runtime.util.DataOutputSerializer
-
- skipFully(InputStream, long) - Static method in class org.apache.flink.runtime.util.IOUtils
-
Similar to readFully().
- Slot - Class in org.apache.flink.runtime.instance
-
Base class for task slots.
- Slot(JobID, Instance, int, SharedSlot, AbstractID) - Constructor for class org.apache.flink.runtime.instance.Slot
-
Base constructor for slots.
- slotAllocated(SimpleSlot) - Method in interface org.apache.flink.runtime.jobmanager.scheduler.SlotAllocationFutureAction
-
This method is called as soon as the SlotAllocationFuture is triggered.
- SlotAllocationFuture - Class in org.apache.flink.runtime.jobmanager.scheduler
-
- SlotAllocationFuture() - Constructor for class org.apache.flink.runtime.jobmanager.scheduler.SlotAllocationFuture
-
- SlotAllocationFuture(SimpleSlot) - Constructor for class org.apache.flink.runtime.jobmanager.scheduler.SlotAllocationFuture
-
- SlotAllocationFutureAction - Interface in org.apache.flink.runtime.jobmanager.scheduler
-
- SlotAvailabilityListener - Interface in org.apache.flink.runtime.jobmanager.scheduler
-
A SlotAvailabilityListener can be notified when new
Slot
s become available on an
Instance
.
- 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
-
- 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
-
- snapshot(long, long) - Method in class org.apache.flink.runtime.state.filesystem.AbstractFsState
-
- Snapshot(TypeSerializer<K>, TypeSerializer<N>, TypeSerializer<ACC>, FoldingStateDescriptor<T, ACC>, Path) - Constructor for class org.apache.flink.runtime.state.filesystem.FsFoldingState.Snapshot
-
- Snapshot(TypeSerializer<K>, TypeSerializer<N>, TypeSerializer<ArrayList<V>>, ListStateDescriptor<V>, Path) - Constructor for class org.apache.flink.runtime.state.filesystem.FsListState.Snapshot
-
- Snapshot(TypeSerializer<K>, TypeSerializer<N>, TypeSerializer<V>, ReducingStateDescriptor<V>, Path) - Constructor for class org.apache.flink.runtime.state.filesystem.FsReducingState.Snapshot
-
- Snapshot(TypeSerializer<K>, TypeSerializer<N>, TypeSerializer<V>, ValueStateDescriptor<V>, Path) - Constructor for class org.apache.flink.runtime.state.filesystem.FsValueState.Snapshot
-
- snapshot(long, long) - Method in class org.apache.flink.runtime.state.GenericFoldingState
-
- snapshot(long, long) - Method in class org.apache.flink.runtime.state.GenericListState
-
- snapshot(long, long) - Method in class org.apache.flink.runtime.state.GenericReducingState
-
- snapshot(long, long) - Method in interface org.apache.flink.runtime.state.KvState
-
Creates a snapshot of this state.
- snapshot(long, long) - Method in class org.apache.flink.runtime.state.memory.AbstractMemState
-
- Snapshot(TypeSerializer<K>, TypeSerializer<N>, TypeSerializer<ACC>, FoldingStateDescriptor<T, ACC>, byte[]) - Constructor for class org.apache.flink.runtime.state.memory.MemFoldingState.Snapshot
-
- Snapshot(TypeSerializer<K>, TypeSerializer<N>, TypeSerializer<ArrayList<V>>, ListStateDescriptor<V>, byte[]) - Constructor for class org.apache.flink.runtime.state.memory.MemListState.Snapshot
-
- Snapshot(TypeSerializer<K>, TypeSerializer<N>, TypeSerializer<V>, ReducingStateDescriptor<V>, byte[]) - Constructor for class org.apache.flink.runtime.state.memory.MemReducingState.Snapshot
-
- Snapshot(TypeSerializer<K>, TypeSerializer<N>, TypeSerializer<V>, ValueStateDescriptor<V>, byte[]) - Constructor for class org.apache.flink.runtime.state.memory.MemValueState.Snapshot
-
- snapshotPartitionedState(long, long) - Method in class org.apache.flink.runtime.state.AbstractStateBackend
-
- 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.
- 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
-
- 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
-
- 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
-
- Sorter<E> - Interface in org.apache.flink.runtime.operators.sort
-
The SortMerger interface representing the public interface to all specific Sort-Merge implementations.
- SortingThread(ExceptionHandler<IOException>, UnilateralSortMerger.CircularQueues<E>, AbstractInvokable) - Constructor for class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SortingThread
-
Creates a new sorting thread.
- 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.
- SpanningRecordSerializer<T extends org.apache.flink.core.io.IOReadableWritable> - Class in org.apache.flink.runtime.io.network.api.serialization
-
- SpanningRecordSerializer() - Constructor for class org.apache.flink.runtime.io.network.api.serialization.SpanningRecordSerializer
-
- spillHeadCopy - Variable in class org.apache.flink.runtime.operators.sort.AbstractMergeIterator
-
- SpillingAdaptiveSpanningRecordDeserializer<T extends org.apache.flink.core.io.IOReadableWritable> - Class in org.apache.flink.runtime.io.network.api.serialization
-
- SpillingAdaptiveSpanningRecordDeserializer() - 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.
- 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
-
- 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
-
Creates a StandaloneLeaderRetrievalService with the given JobManager address.
- StandaloneSubmittedJobGraphStore - Class in org.apache.flink.runtime.jobmanager
-
- StandaloneSubmittedJobGraphStore() - Constructor for class org.apache.flink.runtime.jobmanager.StandaloneSubmittedJobGraphStore
-
- StandaloneUtils - Class in org.apache.flink.runtime.util
-
Utility class to work with Flink standalone mode.
- start() - Method in interface org.apache.flink.runtime.checkpoint.CheckpointIDCounter
-
- start() - Method in interface org.apache.flink.runtime.checkpoint.CheckpointRecoveryFactory
-
- start() - Method in class org.apache.flink.runtime.checkpoint.SavepointStore
-
- start() - Method in class org.apache.flink.runtime.checkpoint.StandaloneCheckpointIDCounter
-
- start() - Method in class org.apache.flink.runtime.checkpoint.StandaloneCheckpointRecoveryFactory
-
- start() - Method in class org.apache.flink.runtime.checkpoint.ZooKeeperCheckpointIDCounter
-
- start() - Method in class org.apache.flink.runtime.checkpoint.ZooKeeperCheckpointRecoveryFactory
-
- start(ResultPartitionProvider, TaskEventDispatcher, NetworkBufferPool) - Method in interface org.apache.flink.runtime.io.network.ConnectionManager
-
- start(ResultPartitionProvider, TaskEventDispatcher, NetworkBufferPool) - Method in class org.apache.flink.runtime.io.network.LocalConnectionManager
-
- start(ResultPartitionProvider, TaskEventDispatcher, NetworkBufferPool) - Method in class org.apache.flink.runtime.io.network.netty.NettyConnectionManager
-
- 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(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.StandaloneLeaderRetrievalService
-
- start(LeaderRetrievalListener) - Method in class org.apache.flink.runtime.leaderretrieval.ZooKeeperLeaderRetrievalService
-
- start(String) - Method in interface org.apache.flink.runtime.webmonitor.WebMonitor
-
Starts the web monitor.
- startCheckpointScheduler() - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
- startCuratorFramework(Configuration) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
-
Starts a CuratorFramework
instance and connects it to the given ZooKeeper
quorum.
- startJobClientActorSystem(Configuration) - Static method in class org.apache.flink.runtime.client.JobClient
-
- 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
-
- startReading() - Method in class org.apache.flink.runtime.operators.TempBarrier
-
- 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.
- startWebRuntimeMonitor(Configuration, LeaderRetrievalService, ActorSystem) - Static method in class org.apache.flink.runtime.webmonitor.WebMonitorUtils
-
Starts the web runtime monitor.
- state - Variable in class org.apache.flink.runtime.state.AbstractHeapState
-
Map containing the actual key/value pairs
- StateBackendFactory<T extends AbstractStateBackend> - Interface in org.apache.flink.runtime.state
-
A factory to create a specific state backend.
- stateDesc - Variable in class org.apache.flink.runtime.state.AbstractHeapState
-
This holds the name of the state and can create an initial default value for the state.
- stateDesc - Variable in class org.apache.flink.runtime.state.filesystem.AbstractFsStateSnapshot
-
StateDescriptor, for sanity checks
- stateDesc - Variable in class org.apache.flink.runtime.state.memory.AbstractMemStateSnapshot
-
StateDescriptor, for sanity checks
- StateForTask - Class in org.apache.flink.runtime.checkpoint
-
Simple bean to describe the state belonging to a parallel operator.
- StateForTask(SerializedValue<StateHandle<?>>, long, JobVertexID, int, long) - Constructor for class org.apache.flink.runtime.checkpoint.StateForTask
-
- StatefulTask<T extends StateHandle<?>> - Interface in org.apache.flink.runtime.jobgraph.tasks
-
This interface must be implemented by any invokable that has recoverable state and participates
in checkpointing.
- StateHandle<T> - Interface in org.apache.flink.runtime.state
-
StateHandle is a general handle interface meant to abstract operator state fetching.
- stateSerializer - Variable in class org.apache.flink.runtime.state.AbstractHeapState
-
Serializer for the state value.
- stateSerializer - Variable in class org.apache.flink.runtime.state.filesystem.AbstractFsStateSnapshot
-
Serializer for the state value
- stateSerializer - Variable in class org.apache.flink.runtime.state.memory.AbstractMemStateSnapshot
-
Serializer for the state value
- StateStorageHelper<T extends Serializable> - Interface in org.apache.flink.runtime.zookeeper
-
State storage helper which is used by
ZooKeeperStateHandleStore
to persiste state before
the state handle is written to ZooKeeper.
- StateStore<T extends Serializable> - Interface in org.apache.flink.runtime.checkpoint
-
A simple org.apache.flink.runtime.state.StateBackend
backend object
store interface.
- StateUtils - Class in org.apache.flink.runtime.state
-
A collection of utility methods for dealing with operator state.
- StatusOverview - Class in org.apache.flink.runtime.messages.webmonitor
-
- StatusOverview(int, int, int, int, int, int, int) - Constructor for class org.apache.flink.runtime.messages.webmonitor.StatusOverview
-
- StatusOverview(int, int, int, JobsOverview, JobsOverview) - Constructor for class org.apache.flink.runtime.messages.webmonitor.StatusOverview
-
- stdOutFile - Variable in class org.apache.flink.runtime.webmonitor.WebMonitorUtils.LogFileLocation
-
- stop() - Method in interface org.apache.flink.runtime.checkpoint.CheckpointIDCounter
-
- stop() - Method in interface org.apache.flink.runtime.checkpoint.CheckpointRecoveryFactory
-
- stop() - Method in class org.apache.flink.runtime.checkpoint.SavepointStore
-
- stop() - Method in class org.apache.flink.runtime.checkpoint.StandaloneCheckpointIDCounter
-
- stop() - Method in class org.apache.flink.runtime.checkpoint.StandaloneCheckpointRecoveryFactory
-
- stop() - Method in class org.apache.flink.runtime.checkpoint.ZooKeeperCheckpointIDCounter
-
- stop() - Method in class org.apache.flink.runtime.checkpoint.ZooKeeperCheckpointRecoveryFactory
-
- 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.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() - 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.StandaloneLeaderRetrievalService
-
- stop() - Method in class org.apache.flink.runtime.leaderretrieval.ZooKeeperLeaderRetrievalService
-
- stop() - Method in interface org.apache.flink.runtime.webmonitor.WebMonitor
-
Stops the web server.
- stopAfterJob(JobID) - Method in class org.apache.flink.runtime.yarn.AbstractFlinkYarnCluster
-
Tells the ApplicationMaster to monitor the status of JobId and stop itself once the specified
job has finished.
- stopCheckpointScheduler() - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
- stopExecution() - Method in class org.apache.flink.runtime.taskmanager.Task
-
- StoppableTask - Interface in org.apache.flink.runtime.jobgraph.tasks
-
Implemented by tasks that can receive STOP signal.
- 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
-
- store(T) - Method in class org.apache.flink.runtime.zookeeper.filesystem.FileSystemStateStorageHelper
-
- store(T) - Method in interface org.apache.flink.runtime.zookeeper.StateStorageHelper
-
Stores the given state and returns a state handle to it.
- StreamStateHandle - Interface in org.apache.flink.runtime.state
-
A state handle that produces an input stream when resolved.
- 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, Accumulator<?, ?>>) - Static method in class org.apache.flink.runtime.accumulators.StringifiedAccumulatorResult
-
- stub - Variable in class org.apache.flink.runtime.operators.BatchTask
-
The instantiated user code of this task's main operator (driver).
- submitJobAndWait(ActorSystem, LeaderRetrievalService, 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(ActorGateway, JobGraph, FiniteDuration, ClassLoader) - Static method in class org.apache.flink.runtime.client.JobClient
-
Submits a job in detached mode.
- 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
-
- subscribe(EventListener<TaskEvent>, Class<? extends TaskEvent>) - Method in class org.apache.flink.runtime.io.network.api.TaskEventHandler
-
- subscribeToEvent(EventListener<TaskEvent>, Class<? extends TaskEvent>) - Method in class org.apache.flink.runtime.io.network.api.writer.ResultPartitionWriter
-
- 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
-
- SuperstepKickoffLatch() - Constructor for class org.apache.flink.runtime.iterative.concurrent.SuperstepKickoffLatch
-
- SuperstepKickoffLatchBroker - Class in org.apache.flink.runtime.iterative.concurrent
-
- swap(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) - Method in class org.apache.flink.runtime.operators.sort.NormalizedKeySorter
-
- switchBuffers() - Method in class org.apache.flink.runtime.iterative.io.SerializedUpdateBuffer
-
- sync() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopDataOutputStream
-
- SyncEventHandler - Class in org.apache.flink.runtime.iterative.task
-
- 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
-