All Methods Instance Methods Concrete Methods
Modifier and Type |
Method |
Description |
void |
addBroadcastInputToGroup(int groupIndex) |
|
void |
addChainedTask(Class<? extends ChainedDriver> chainedTaskClass,
TaskConfig conf,
String taskName) |
|
void |
addInputToGroup(int groupIndex) |
|
void |
addIterationAggregator(String name,
Aggregator<?> aggregator) |
|
void |
addIterationAggregators(Collection<AggregatorWithName<?>> aggregators) |
|
void |
addOutputShipStrategy(ShipStrategyType strategy) |
|
int |
getBroadcastGroupSize(int groupIndex) |
|
String |
getBroadcastInputName(int groupIndex) |
|
<T> TypeSerializerFactory<T> |
getBroadcastInputSerializer(int inputNum,
ClassLoader cl) |
|
TaskConfig |
getChainedStubConfig(int chainPos) |
|
Class<? extends ChainedDriver<?,?>> |
getChainedTask(int chainPos) |
|
String |
getChainedTaskName(int chainPos) |
|
Configuration |
getConfiguration() |
Gets the configuration that holds the actual values encoded.
|
<T extends Value> ConvergenceCriterion<T> |
getConvergenceCriterion(ClassLoader cl) |
|
String |
getConvergenceCriterionAggregatorName() |
|
<S extends Function,OT> Class<? extends Driver<S,OT>> |
getDriver() |
|
<T> TypeComparatorFactory<T> |
getDriverComparator(int inputNum,
ClassLoader cl) |
|
DriverStrategy |
getDriverStrategy() |
|
int |
getFilehandlesDriver() |
|
int |
getFilehandlesInput(int inputNum) |
|
int |
getGroupSize(int groupIndex) |
|
<T extends Value> ConvergenceCriterion<T> |
getImplicitConvergenceCriterion(ClassLoader cl) |
|
String |
getImplicitConvergenceCriterionAggregatorName() |
|
<T> TypeComparatorFactory<T> |
getInputComparator(int inputNum,
ClassLoader cl) |
|
LocalStrategy |
getInputLocalStrategy(int inputNum) |
|
<T> TypeSerializerFactory<T> |
getInputSerializer(int inputNum,
ClassLoader cl) |
|
boolean |
getIsSolutionSetUpdate() |
|
boolean |
getIsWorksetIteration() |
|
boolean |
getIsWorksetUpdate() |
|
Collection<AggregatorWithName<?>> |
getIterationAggregators(ClassLoader cl) |
|
TaskConfig |
getIterationHeadFinalOutputConfig() |
|
int |
getIterationHeadIndexOfSyncOutput() |
|
int |
getIterationHeadPartialSolutionOrWorksetInputIndex() |
|
int |
getIterationHeadSolutionSetInputIndex() |
|
int |
getIterationId() |
|
int |
getNumberOfChainedStubs() |
|
int |
getNumberOfEventsUntilInterruptInIterativeBroadcastGate(int bcGateIndex) |
|
int |
getNumberOfEventsUntilInterruptInIterativeGate(int inputGateIndex) |
|
int |
getNumberOfIterations() |
|
int |
getNumBroadcastInputs() |
|
int |
getNumInputs() |
|
int |
getNumOutputs() |
|
<T> TypeComparatorFactory<T> |
getOutputComparator(int outputNum,
ClassLoader cl) |
|
DataDistribution |
getOutputDataDistribution(int outputNum,
ClassLoader cl) |
|
Partitioner<?> |
getOutputPartitioner(int outputNum,
ClassLoader cl) |
|
<T> TypeSerializerFactory<T> |
getOutputSerializer(ClassLoader cl) |
|
ShipStrategyType |
getOutputShipStrategy(int outputNum) |
|
<T1,T2> TypePairComparatorFactory<T1,T2> |
getPairComparatorFactory(ClassLoader cl) |
|
double |
getRelativeBackChannelMemory() |
|
double |
getRelativeInputMaterializationMemory(int inputNum) |
|
double |
getRelativeMemoryDriver() |
|
double |
getRelativeMemoryInput(int inputNum) |
|
double |
getRelativeSolutionSetMemory() |
|
<T> TypeComparatorFactory<T> |
getSolutionSetComparator(ClassLoader cl) |
|
<T> TypeSerializerFactory<T> |
getSolutionSetSerializer(ClassLoader cl) |
|
float |
getSpillingThresholdDriver() |
|
float |
getSpillingThresholdInput(int inputNum) |
|
String |
getStubParameter(String key,
String defaultValue) |
|
Configuration |
getStubParameters() |
|
<T> UserCodeWrapper<T> |
getStubWrapper(ClassLoader cl) |
|
String |
getTaskName() |
|
boolean |
getUseLargeRecordHandler() |
|
boolean |
getWaitForSolutionSetUpdate() |
|
boolean |
hasStubWrapper() |
|
boolean |
isInputAsynchronouslyMaterialized(int inputNum) |
|
boolean |
isInputCached(int inputNum) |
|
boolean |
isIterativeInputGate(int inputGateIndex) |
|
boolean |
isSolutionSetUnmanaged() |
|
void |
setBroadcastGateIterativeWithNumberOfEventsUntilInterrupt(int bcGateIndex,
int numEvents) |
|
void |
setBroadcastInputName(String name,
int groupIndex) |
|
void |
setBroadcastInputSerializer(TypeSerializerFactory<?> factory,
int inputNum) |
|
void |
setConvergenceCriterion(String aggregatorName,
ConvergenceCriterion<?> convCriterion) |
|
void |
setDriver(Class<? extends Driver> driver) |
|
void |
setDriverComparator(TypeComparatorFactory<?> factory,
int inputNum) |
|
void |
setDriverPairComparator(TypePairComparatorFactory<?,?> factory) |
|
void |
setDriverStrategy(DriverStrategy strategy) |
|
void |
setFilehandlesDriver(int filehandles) |
|
void |
setFilehandlesInput(int inputNum,
int filehandles) |
|
void |
setGateIterativeWithNumberOfEventsUntilInterrupt(int inputGateIndex,
int numEvents) |
|
void |
setImplicitConvergenceCriterion(String aggregatorName,
ConvergenceCriterion<?> convCriterion) |
Sets the default convergence criterion of a DeltaIteration
|
void |
setInputAsynchronouslyMaterialized(int inputNum,
boolean temp) |
|
void |
setInputCached(int inputNum,
boolean persistent) |
|
void |
setInputComparator(TypeComparatorFactory<?> factory,
int inputNum) |
|
void |
setInputLocalStrategy(int inputNum,
LocalStrategy strategy) |
|
void |
setInputSerializer(TypeSerializerFactory<?> factory,
int inputNum) |
|
void |
setIsSolutionSetUpdate() |
|
void |
setIsSolutionSetUpdateWithoutReprobe() |
|
void |
setIsWorksetIteration() |
|
void |
setIsWorksetUpdate() |
|
void |
setIterationHeadFinalOutputConfig(TaskConfig conf) |
|
void |
setIterationHeadIndexOfSyncOutput(int outputIndex) |
|
void |
setIterationHeadPartialSolutionOrWorksetInputIndex(int inputIndex) |
|
void |
setIterationHeadSolutionSetInputIndex(int inputIndex) |
|
void |
setIterationId(int id) |
|
void |
setNumberOfIterations(int numberOfIterations) |
|
void |
setOutputComparator(TypeComparatorFactory<?> factory,
int outputNum) |
|
void |
setOutputDataDistribution(DataDistribution distribution,
int outputNum) |
|
void |
setOutputPartitioner(Partitioner<?> partitioner,
int outputNum) |
|
void |
setOutputSerializer(TypeSerializerFactory<?> factory) |
|
void |
setRelativeBackChannelMemory(double relativeMemory) |
|
void |
setRelativeInputMaterializationMemory(int inputNum,
double relativeMemory) |
|
void |
setRelativeMemoryDriver(double relativeMemorySize) |
|
void |
setRelativeMemoryInput(int inputNum,
double relativeMemorySize) |
|
void |
setRelativeSolutionSetMemory(double relativeMemory) |
|
void |
setSolutionSetComparator(TypeComparatorFactory<?> factory) |
|
void |
setSolutionSetSerializer(TypeSerializerFactory<?> factory) |
|
void |
setSolutionSetUnmanaged(boolean unmanaged) |
|
void |
setSpillingThresholdDriver(float threshold) |
|
void |
setSpillingThresholdInput(int inputNum,
float threshold) |
|
void |
setStubParameter(String key,
String value) |
|
void |
setStubParameters(Configuration parameters) |
|
void |
setStubWrapper(UserCodeWrapper<?> wrapper) |
|
void |
setTaskName(String name) |
|
void |
setUseLargeRecordHandler(boolean useLargeRecordHandler) |
|
void |
setWaitForSolutionSetUpdate() |
|
boolean |
usesConvergenceCriterion() |
|
boolean |
usesImplicitConvergenceCriterion() |
|