Modifier and Type | Method and Description |
---|---|
void |
RecordWriter.setMetricGroup(TaskIOMetricGroup metrics)
Sets the metric group for this RecordWriter.
|
Modifier and Type | Method and Description |
---|---|
static SingleInputGate |
SingleInputGate.create(String owningTaskName,
JobID jobId,
ExecutionAttemptID executionId,
InputGateDeploymentDescriptor igdd,
NetworkEnvironment networkEnvironment,
TaskActions taskActions,
TaskIOMetricGroup metrics)
Creates an input gate and all of its input channels.
|
Constructor and Description |
---|
LocalInputChannel(SingleInputGate inputGate,
int channelIndex,
ResultPartitionID partitionId,
ResultPartitionManager partitionManager,
TaskEventDispatcher taskEventDispatcher,
int initialBackoff,
int maxBackoff,
TaskIOMetricGroup metrics) |
LocalInputChannel(SingleInputGate inputGate,
int channelIndex,
ResultPartitionID partitionId,
ResultPartitionManager partitionManager,
TaskEventDispatcher taskEventDispatcher,
TaskIOMetricGroup metrics) |
RemoteInputChannel(SingleInputGate inputGate,
int channelIndex,
ResultPartitionID partitionId,
ConnectionID connectionId,
ConnectionManager connectionManager,
int initialBackOff,
int maxBackoff,
TaskIOMetricGroup metrics) |
RemoteInputChannel(SingleInputGate inputGate,
int channelIndex,
ResultPartitionID partitionId,
ConnectionID connectionId,
ConnectionManager connectionManager,
TaskIOMetricGroup metrics) |
SingleInputGate(String owningTaskName,
JobID jobId,
IntermediateDataSetID consumedResultId,
ResultPartitionType consumedPartitionType,
int consumedSubpartitionIndex,
int numberOfInputChannels,
TaskActions taskActions,
TaskIOMetricGroup metrics,
boolean isCreditBased) |
Modifier and Type | Method and Description |
---|---|
TaskIOMetricGroup |
TaskMetricGroup.getIOMetricGroup()
Returns the TaskIOMetricGroup for this task.
|
Constructor and Description |
---|
StreamInputProcessor(InputGate[] inputGates,
TypeSerializer<IN> inputSerializer,
StreamTask<?,?> checkpointedTask,
CheckpointingMode checkpointMode,
Object lock,
IOManager ioManager,
Configuration taskManagerConfig,
StreamStatusMaintainer streamStatusMaintainer,
OneInputStreamOperator<IN,?> streamOperator,
TaskIOMetricGroup metrics,
WatermarkGauge watermarkGauge) |
StreamTwoInputProcessor(Collection<InputGate> inputGates1,
Collection<InputGate> inputGates2,
TypeSerializer<IN1> inputSerializer1,
TypeSerializer<IN2> inputSerializer2,
TwoInputStreamTask<IN1,IN2,?> checkpointedTask,
CheckpointingMode checkpointMode,
Object lock,
IOManager ioManager,
Configuration taskManagerConfig,
StreamStatusMaintainer streamStatusMaintainer,
TwoInputStreamOperator<IN1,IN2,?> streamOperator,
TaskIOMetricGroup metrics,
WatermarkGauge input1WatermarkGauge,
WatermarkGauge input2WatermarkGauge) |
Copyright © 2014–2019 The Apache Software Foundation. All rights reserved.