Package | Description |
---|---|
org.apache.flink.api.common | |
org.apache.flink.optimizer.dag | |
org.apache.flink.optimizer.dataproperties | |
org.apache.flink.optimizer.traversals |
This package contains the various traversals over the program plan and the optimizer DAG
(directed acyclic graph) that are made in the course of the optimization.
|
org.apache.flink.runtime.io.network |
Modifier and Type | Method and Description |
---|---|
ExecutionMode |
ExecutionConfig.getExecutionMode()
Gets the execution mode used to execute the program.
|
static ExecutionMode |
ExecutionMode.valueOf(String name)
Returns the enum constant of this type with the specified name.
|
static ExecutionMode[] |
ExecutionMode.values()
Returns an array containing the constants of this enum type, in
the order they are declared.
|
Modifier and Type | Method and Description |
---|---|
void |
ExecutionConfig.setExecutionMode(ExecutionMode executionMode)
Sets the execution mode to execute the program.
|
Modifier and Type | Method and Description |
---|---|
ExecutionMode |
DagConnection.getDataExchangeMode()
Gets the data exchange mode to use for this connection.
|
Modifier and Type | Method and Description |
---|---|
void |
OptimizerNode.setBroadcastInputs(Map<Operator<?>,OptimizerNode> operatorToNode,
ExecutionMode defaultExchangeMode)
This function connects the operators that produce the broadcast inputs to this operator.
|
abstract void |
OptimizerNode.setInput(Map<Operator<?>,OptimizerNode> operatorToNode,
ExecutionMode defaultExchangeMode)
This function connects the predecessors to this operator.
|
void |
TwoInputNode.setInput(Map<Operator<?>,OptimizerNode> contractToNode,
ExecutionMode defaultExecutionMode) |
void |
DataSourceNode.setInput(Map<Operator<?>,OptimizerNode> contractToNode,
ExecutionMode defaultDataExchangeMode) |
void |
SingleInputNode.setInput(Map<Operator<?>,OptimizerNode> contractToNode,
ExecutionMode defaultExchangeMode) |
void |
AbstractPartialSolutionNode.setInput(Map<Operator<?>,OptimizerNode> contractToNode,
ExecutionMode dataExchangeMode) |
void |
DataSinkNode.setInput(Map<Operator<?>,OptimizerNode> contractToNode,
ExecutionMode defaultExchangeMode) |
void |
WorksetIterationNode.setNextPartialSolution(OptimizerNode solutionSetDelta,
OptimizerNode nextWorkset,
ExecutionMode executionMode) |
Constructor and Description |
---|
DagConnection(OptimizerNode source,
ExecutionMode exchangeMode)
Constructor to create a result from an operator that is not consumed by another operator.
|
DagConnection(OptimizerNode source,
OptimizerNode target,
ExecutionMode exchangeMode)
Creates a new Connection between two nodes.
|
DagConnection(OptimizerNode source,
OptimizerNode target,
ShipStrategyType shipStrategy,
ExecutionMode exchangeMode)
Creates a new Connection between two nodes.
|
Modifier and Type | Method and Description |
---|---|
void |
GlobalProperties.parameterizeChannel(Channel channel,
boolean globalDopChange,
ExecutionMode exchangeMode,
boolean breakPipeline) |
void |
RequestedGlobalProperties.parameterizeChannel(Channel channel,
boolean globalDopChange,
ExecutionMode exchangeMode,
boolean breakPipeline)
Parametrizes the ship strategy fields of a channel such that the channel produces the desired
global properties.
|
Constructor and Description |
---|
GraphCreatingVisitor(int defaultParallelism,
ExecutionMode defaultDataExchangeMode) |
Modifier and Type | Method and Description |
---|---|
static DataExchangeMode |
DataExchangeMode.getForForwardExchange(ExecutionMode mode) |
static DataExchangeMode |
DataExchangeMode.getForShuffleOrBroadcast(ExecutionMode mode) |
static DataExchangeMode |
DataExchangeMode.getPipelineBreakingExchange(ExecutionMode mode) |
static DataExchangeMode |
DataExchangeMode.select(ExecutionMode executionMode,
ShipStrategyType shipStrategy,
boolean breakPipeline)
Computes the mode of data exchange to be used for a given execution mode and ship strategy.
|
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.