Package | Description |
---|---|
org.apache.flink.optimizer.plan | |
org.apache.flink.runtime.io.network |
Modifier and Type | Method and Description |
---|---|
DataExchangeMode |
Channel.getDataExchangeMode()
Gets the data exchange mode (batch / pipelined) to use for the data exchange of this channel.
|
Modifier and Type | Method and Description |
---|---|
void |
Channel.setDataExchangeMode(DataExchangeMode dataExchangeMode)
Sets the data exchange mode (batch / pipelined) to use for the data exchange of this channel.
|
void |
Channel.setShipStrategy(ShipStrategyType strategy,
DataExchangeMode dataExchangeMode) |
void |
Channel.setShipStrategy(ShipStrategyType strategy,
FieldList keys,
boolean[] sortDirection,
DataExchangeMode dataExchangeMode) |
void |
Channel.setShipStrategy(ShipStrategyType strategy,
FieldList keys,
boolean[] sortDirection,
Partitioner<?> partitioner,
DataExchangeMode dataExchangeMode) |
void |
Channel.setShipStrategy(ShipStrategyType strategy,
FieldList keys,
DataExchangeMode dataExchangeMode) |
void |
Channel.setShipStrategy(ShipStrategyType strategy,
FieldList keys,
Partitioner<?> partitioner,
DataExchangeMode dataExchangeMode) |
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.
|
static DataExchangeMode |
DataExchangeMode.valueOf(String name)
Returns the enum constant of this type with the specified name.
|
static DataExchangeMode[] |
DataExchangeMode.values()
Returns an array containing the constants of this enum type, in
the order they are declared.
|
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.