Package | Description |
---|---|
org.apache.flink.runtime.execution | |
org.apache.flink.runtime.io.network.partition.consumer | |
org.apache.flink.runtime.shuffle | |
org.apache.flink.runtime.taskmanager | |
org.apache.flink.state.api.runtime | |
org.apache.flink.streaming.runtime.io | |
org.apache.flink.streaming.runtime.tasks |
This package contains classes that realize streaming tasks.
|
org.apache.flink.streaming.runtime.tasks.bufferdebloat |
Modifier and Type | Method and Description |
---|---|
IndexedInputGate[] |
Environment.getAllInputGates() |
IndexedInputGate |
Environment.getInputGate(int index) |
Modifier and Type | Class and Description |
---|---|
class |
SingleInputGate
An input gate consumes one or more partitions of a single produced intermediate result.
|
Constructor and Description |
---|
UnionInputGate(IndexedInputGate... inputGates) |
Modifier and Type | Interface and Description |
---|---|
interface |
ShuffleEnvironment<P extends ResultPartitionWriter,G extends IndexedInputGate>
Interface for the implementation of shuffle service local environment.
|
interface |
ShuffleServiceFactory<SD extends ShuffleDescriptor,P extends ResultPartitionWriter,G extends IndexedInputGate>
Interface for shuffle service factory implementations.
|
Modifier and Type | Class and Description |
---|---|
class |
InputGateWithMetrics
This class wraps
InputGate provided by shuffle service and it is mainly used for
increasing general input metrics from TaskIOMetricGroup . |
Modifier and Type | Method and Description |
---|---|
IndexedInputGate[] |
RuntimeEnvironment.getAllInputGates() |
IndexedInputGate |
RuntimeEnvironment.getInputGate(int index) |
Constructor and Description |
---|
InputGateWithMetrics(IndexedInputGate inputGate,
Counter numBytesIn,
ThroughputCalculator throughputCalculator) |
RuntimeEnvironment(JobID jobId,
JobVertexID jobVertexId,
ExecutionAttemptID executionId,
ExecutionConfig executionConfig,
TaskInfo taskInfo,
Configuration jobConfiguration,
Configuration taskConfiguration,
UserCodeClassLoader userCodeClassLoader,
MemoryManager memManager,
IOManager ioManager,
BroadcastVariableManager bcVarManager,
TaskStateManager taskStateManager,
GlobalAggregateManager aggregateManager,
AccumulatorRegistry accumulatorRegistry,
TaskKvStateRegistry kvStateRegistry,
InputSplitProvider splitProvider,
Map<String,Future<Path>> distCacheEntries,
ResultPartitionWriter[] writers,
IndexedInputGate[] inputGates,
TaskEventDispatcher taskEventDispatcher,
CheckpointResponder checkpointResponder,
TaskOperatorEventGateway operatorEventGateway,
TaskManagerRuntimeInfo taskManagerInfo,
TaskMetricGroup metrics,
Task containingTask,
ExternalResourceInfoProvider externalResourceInfoProvider,
ThroughputCalculator throughputCalculator) |
Modifier and Type | Method and Description |
---|---|
IndexedInputGate[] |
SavepointEnvironment.getAllInputGates() |
IndexedInputGate |
SavepointEnvironment.getInputGate(int index) |
Modifier and Type | Method and Description |
---|---|
static InputGate |
InputGateUtil.createInputGate(List<IndexedInputGate> inputGates) |
Modifier and Type | Method and Description |
---|---|
protected abstract void |
AbstractTwoInputStreamTask.createInputProcessor(List<IndexedInputGate> inputGates1,
List<IndexedInputGate> inputGates2,
java.util.function.Function<Integer,StreamPartitioner<?>> gatePartitioners) |
protected abstract void |
AbstractTwoInputStreamTask.createInputProcessor(List<IndexedInputGate> inputGates1,
List<IndexedInputGate> inputGates2,
java.util.function.Function<Integer,StreamPartitioner<?>> gatePartitioners) |
protected void |
TwoInputStreamTask.createInputProcessor(List<IndexedInputGate> inputGates1,
List<IndexedInputGate> inputGates2,
java.util.function.Function<Integer,StreamPartitioner<?>> gatePartitioners) |
protected void |
TwoInputStreamTask.createInputProcessor(List<IndexedInputGate> inputGates1,
List<IndexedInputGate> inputGates2,
java.util.function.Function<Integer,StreamPartitioner<?>> gatePartitioners) |
Constructor and Description |
---|
BufferDebloater(Configuration taskConfig,
IndexedInputGate[] inputGates) |
Copyright © 2014–2023 The Apache Software Foundation. All rights reserved.