Package | Description |
---|---|
org.apache.flink.streaming.runtime.io | |
org.apache.flink.streaming.runtime.io.recovery |
Modifier and Type | Field and Description |
---|---|
protected StatusWatermarkValve |
AbstractStreamTaskNetworkInput.statusWatermarkValve
Valve that controls how watermarks and watermark statuses are forwarded.
|
Modifier and Type | Method and Description |
---|---|
static <T> StreamTaskInput<T> |
StreamTaskNetworkInputFactory.create(CheckpointedInputGate checkpointedInputGate,
TypeSerializer<T> inputSerializer,
IOManager ioManager,
StatusWatermarkValve statusWatermarkValve,
int inputIndex,
InflightDataRescalingDescriptor rescalingDescriptorinflightDataRescalingDescriptor,
Function<Integer,StreamPartitioner<?>> gatePartitioners,
TaskInfo taskInfo,
StreamTask.CanEmitBatchOfRecordsChecker canEmitBatchOfRecords)
Factory method for
StreamTaskNetworkInput or RescalingStreamTaskNetworkInput
depending on InflightDataRescalingDescriptor . |
Constructor and Description |
---|
AbstractStreamTaskNetworkInput(CheckpointedInputGate checkpointedInputGate,
TypeSerializer<T> inputSerializer,
StatusWatermarkValve statusWatermarkValve,
int inputIndex,
Map<InputChannelInfo,R> recordDeserializers,
StreamTask.CanEmitBatchOfRecordsChecker canEmitBatchOfRecords) |
StreamTaskNetworkInput(CheckpointedInputGate checkpointedInputGate,
TypeSerializer<T> inputSerializer,
IOManager ioManager,
StatusWatermarkValve statusWatermarkValve,
int inputIndex,
StreamTask.CanEmitBatchOfRecordsChecker canEmitBatchOfRecords) |
Constructor and Description |
---|
RescalingStreamTaskNetworkInput(CheckpointedInputGate checkpointedInputGate,
TypeSerializer<T> inputSerializer,
IOManager ioManager,
StatusWatermarkValve statusWatermarkValve,
int inputIndex,
InflightDataRescalingDescriptor inflightDataRescalingDescriptor,
Function<Integer,StreamPartitioner<?>> gatePartitioners,
TaskInfo taskInfo,
StreamTask.CanEmitBatchOfRecordsChecker canEmitBatchOfRecords) |
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.