Package | Description |
---|---|
org.apache.flink.streaming.api.operators | |
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 | Method and Description |
---|---|
DataInputStatus |
SourceOperator.emitNext(PushingAsyncDataInput.DataOutput<OUT> output) |
Modifier and Type | Method and Description |
---|---|
DataInputStatus |
MultiInputSortingDataInput.emitNext(PushingAsyncDataInput.DataOutput<IN> output) |
DataInputStatus |
SortingDataInput.emitNext(PushingAsyncDataInput.DataOutput<T> output) |
Modifier and Type | Method and Description |
---|---|
DataInputStatus |
StreamTaskExternallyInducedSourceInput.emitNext(PushingAsyncDataInput.DataOutput<T> output) |
DataInputStatus |
AbstractStreamTaskNetworkInput.emitNext(PushingAsyncDataInput.DataOutput<T> output) |
DataInputStatus |
PushingAsyncDataInput.emitNext(PushingAsyncDataInput.DataOutput<T> output)
Pushes elements to the output from current data input, and returns the input status to
indicate whether there are more available data in current input.
|
DataInputStatus |
StreamTaskSourceInput.emitNext(PushingAsyncDataInput.DataOutput<T> output) |
protected DataInputStatus |
AbstractStreamTaskNetworkInput.processEvent(BufferOrEvent bufferOrEvent) |
DataInputStatus |
StreamInputProcessor.processInput()
In case of two and more input processors this method must call
InputSelectable.nextSelection() to choose which input to consume from next. |
DataInputStatus |
StreamOneInputProcessor.processInput() |
DataInputStatus |
StreamMultipleInputProcessor.processInput() |
DataInputStatus |
MultipleInputSelectionHandler.updateStatusAndSelection(DataInputStatus inputStatus,
int inputIndex) |
static DataInputStatus |
DataInputStatus.valueOf(String name)
Returns the enum constant of this type with the specified name.
|
static DataInputStatus[] |
DataInputStatus.values()
Returns an array containing the constants of this enum type, in
the order they are declared.
|
Modifier and Type | Method and Description |
---|---|
DataInputStatus |
MultipleInputSelectionHandler.updateStatusAndSelection(DataInputStatus inputStatus,
int inputIndex) |
Modifier and Type | Method and Description |
---|---|
protected DataInputStatus |
RescalingStreamTaskNetworkInput.processEvent(BufferOrEvent bufferOrEvent) |
Modifier and Type | Method and Description |
---|---|
DataInputStatus |
StreamTaskFinishedOnRestoreSourceInput.emitNext(PushingAsyncDataInput.DataOutput<T> output) |
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.