Package | Description |
---|---|
org.apache.flink.streaming.api.operators.sort | |
org.apache.flink.streaming.runtime.io | |
org.apache.flink.streaming.runtime.io.recovery | |
org.apache.flink.streaming.runtime.tasks |
This package contains classes that realize streaming tasks.
|
Modifier and Type | Class and Description |
---|---|
class |
MultiInputSortingDataInput<IN,K>
An input that wraps an underlying input and sorts the incoming records.
|
class |
SortingDataInput<T,K>
A
StreamTaskInput which sorts in the incoming records from a chained input. |
Modifier and Type | Method and Description |
---|---|
StreamTaskInput<?>[] |
MultiInputSortingDataInput.SelectableSortingInputs.getPassThroughInputs() |
StreamTaskInput<?>[] |
MultiInputSortingDataInput.SelectableSortingInputs.getSortedInputs() |
Modifier and Type | Method and Description |
---|---|
static <K> MultiInputSortingDataInput.SelectableSortingInputs |
MultiInputSortingDataInput.wrapInputs(org.apache.flink.runtime.jobgraph.tasks.TaskInvokable containingTask,
StreamTaskInput<Object>[] sortingInputs,
org.apache.flink.api.java.functions.KeySelector<Object,K>[] keySelectors,
org.apache.flink.api.common.typeutils.TypeSerializer<Object>[] inputSerializers,
org.apache.flink.api.common.typeutils.TypeSerializer<K> keySerializer,
StreamTaskInput<Object>[] passThroughInputs,
org.apache.flink.runtime.memory.MemoryManager memoryManager,
org.apache.flink.runtime.io.disk.iomanager.IOManager ioManager,
boolean objectReuse,
double managedMemoryFraction,
org.apache.flink.configuration.Configuration jobConfiguration,
org.apache.flink.api.common.ExecutionConfig executionConfig) |
static <K> MultiInputSortingDataInput.SelectableSortingInputs |
MultiInputSortingDataInput.wrapInputs(org.apache.flink.runtime.jobgraph.tasks.TaskInvokable containingTask,
StreamTaskInput<Object>[] sortingInputs,
org.apache.flink.api.java.functions.KeySelector<Object,K>[] keySelectors,
org.apache.flink.api.common.typeutils.TypeSerializer<Object>[] inputSerializers,
org.apache.flink.api.common.typeutils.TypeSerializer<K> keySerializer,
StreamTaskInput<Object>[] passThroughInputs,
org.apache.flink.runtime.memory.MemoryManager memoryManager,
org.apache.flink.runtime.io.disk.iomanager.IOManager ioManager,
boolean objectReuse,
double managedMemoryFraction,
org.apache.flink.configuration.Configuration jobConfiguration,
org.apache.flink.api.common.ExecutionConfig executionConfig) |
Constructor and Description |
---|
SelectableSortingInputs(StreamTaskInput<?>[] sortedInputs,
StreamTaskInput<?>[] passThroughInputs,
InputSelectable inputSelectable) |
SelectableSortingInputs(StreamTaskInput<?>[] sortedInputs,
StreamTaskInput<?>[] passThroughInputs,
InputSelectable inputSelectable) |
SortingDataInput(StreamTaskInput<T> wrappedInput,
org.apache.flink.api.common.typeutils.TypeSerializer<T> typeSerializer,
org.apache.flink.api.common.typeutils.TypeSerializer<K> keySerializer,
org.apache.flink.api.java.functions.KeySelector<T,K> keySelector,
org.apache.flink.runtime.memory.MemoryManager memoryManager,
org.apache.flink.runtime.io.disk.iomanager.IOManager ioManager,
boolean objectReuse,
double managedMemoryFraction,
org.apache.flink.configuration.Configuration jobConfiguration,
org.apache.flink.runtime.jobgraph.tasks.TaskInvokable containingTask,
org.apache.flink.api.common.ExecutionConfig executionConfig) |
Modifier and Type | Interface and Description |
---|---|
interface |
RecoverableStreamTaskInput<T>
A
StreamTaskInput used during recovery of in-flight data. |
Modifier and Type | Class and Description |
---|---|
class |
AbstractStreamTaskNetworkInput<T,R extends org.apache.flink.runtime.io.network.api.serialization.RecordDeserializer<org.apache.flink.runtime.plugable.DeserializationDelegate<StreamElement>>>
Base class for network-based StreamTaskInput where each channel has a designated
RecordDeserializer for spanning records. |
class |
StreamTaskExternallyInducedSourceInput<T>
A subclass of
StreamTaskSourceInput for ExternallyInducedSourceReader . |
class |
StreamTaskNetworkInput<T>
Implementation of
StreamTaskInput that wraps an input from network taken from CheckpointedInputGate . |
class |
StreamTaskSourceInput<T>
Implementation of
StreamTaskInput that reads data from the SourceOperator and
returns the DataInputStatus to indicate whether the source state is available,
unavailable or finished. |
Modifier and Type | Method and Description |
---|---|
static <T> StreamTaskInput<T> |
StreamTaskNetworkInputFactory.create(CheckpointedInputGate checkpointedInputGate,
org.apache.flink.api.common.typeutils.TypeSerializer<T> inputSerializer,
org.apache.flink.runtime.io.disk.iomanager.IOManager ioManager,
StatusWatermarkValve statusWatermarkValve,
int inputIndex,
org.apache.flink.runtime.checkpoint.InflightDataRescalingDescriptor rescalingDescriptorinflightDataRescalingDescriptor,
java.util.function.Function<Integer,StreamPartitioner<?>> gatePartitioners,
org.apache.flink.api.common.TaskInfo taskInfo,
StreamTask.CanEmitBatchOfRecordsChecker canEmitBatchOfRecords)
Factory method for
StreamTaskNetworkInput or RescalingStreamTaskNetworkInput
depending on InflightDataRescalingDescriptor . |
StreamTaskInput<T> |
RecoverableStreamTaskInput.finishRecovery() |
Constructor and Description |
---|
StreamOneInputProcessor(StreamTaskInput<IN> input,
PushingAsyncDataInput.DataOutput<IN> output,
BoundedMultiInput endOfInputAware) |
Modifier and Type | Class and Description |
---|---|
class |
RescalingStreamTaskNetworkInput<T>
A
StreamTaskNetworkInput implementation that demultiplexes virtual channels. |
Modifier and Type | Method and Description |
---|---|
StreamTaskInput<T> |
RescalingStreamTaskNetworkInput.finishRecovery() |
Modifier and Type | Class and Description |
---|---|
class |
StreamTaskFinishedOnRestoreSourceInput<T>
A special source input implementation that immediately emit END_OF_INPUT.
|
Copyright © 2014–2023 The Apache Software Foundation. All rights reserved.