public enum DataExchangeMode extends Enum<DataExchangeMode>
Enum Constant and Description |
---|
BATCH
The data exchange is decoupled.
|
PIPELINE_WITH_BATCH_FALLBACK
|
PIPELINED
The data exchange is streamed, sender and receiver are online at the same time,
and the receiver back-pressures the sender.
|
Modifier and Type | Method and Description |
---|---|
static DataExchangeMode |
getForForwardExchange(ExecutionMode mode) |
static DataExchangeMode |
getForShuffleOrBroadcast(ExecutionMode mode) |
static DataExchangeMode |
getPipelineBreakingExchange(ExecutionMode mode) |
static 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 |
valueOf(String name)
Returns the enum constant of this type with the specified name.
|
static DataExchangeMode[] |
values()
Returns an array containing the constants of this enum type, in
the order they are declared.
|
public static final DataExchangeMode PIPELINED
public static final DataExchangeMode BATCH
public static final DataExchangeMode PIPELINE_WITH_BATCH_FALLBACK
public static DataExchangeMode[] values()
for (DataExchangeMode c : DataExchangeMode.values()) System.out.println(c);
public static DataExchangeMode valueOf(String name)
name
- the name of the enum constant to be returned.IllegalArgumentException
- if this enum type has no constant with the specified nameNullPointerException
- if the argument is nullpublic static DataExchangeMode getForForwardExchange(ExecutionMode mode)
public static DataExchangeMode getForShuffleOrBroadcast(ExecutionMode mode)
public static DataExchangeMode getPipelineBreakingExchange(ExecutionMode mode)
public static DataExchangeMode select(ExecutionMode executionMode, ShipStrategyType shipStrategy, boolean breakPipeline)
getPipelineBreakingExchange(org.apache.flink.api.common.ExecutionMode)
.
getForForwardExchange(org.apache.flink.api.common.ExecutionMode)
.
getForShuffleOrBroadcast(org.apache.flink.api.common.ExecutionMode)
.
shipStrategy
- The ship strategy (FORWARD, PARTITION, BROADCAST, ...) of the runtime data exchange.Copyright © 2014–2020 The Apache Software Foundation. All rights reserved.