Tabnine Logo
ExecutionConfig.isObjectReuseEnabled
Code IndexAdd Tabnine to your IDE (free)

How to use
isObjectReuseEnabled
method
in
org.apache.flink.api.common.ExecutionConfig

Best Java code snippets using org.apache.flink.api.common.ExecutionConfig.isObjectReuseEnabled (Showing top 20 results out of 315)

origin: apache/flink

private void bufferEvent(IN event, long currentTime) throws Exception {
  List<IN> elementsForTimestamp =  elementQueueState.get(currentTime);
  if (elementsForTimestamp == null) {
    elementsForTimestamp = new ArrayList<>();
  }
  if (getExecutionConfig().isObjectReuseEnabled()) {
    // copy the StreamRecord so that it cannot be changed
    elementsForTimestamp.add(inputSerializer.copy(event));
  } else {
    elementsForTimestamp.add(event);
  }
  elementQueueState.put(currentTime, elementsForTimestamp);
}
origin: apache/flink

  @Override
  public ExecutionEnvironment createExecutionEnvironment() {
    lastEnv = new TestEnvironment(jobExecutor, getParallelism(), getConfig().isObjectReuseEnabled());
    return lastEnv;
  }
};
origin: apache/flink

  if (containingTask.getExecutionConfig().isObjectReuseEnabled()) {
    return new CopyingBroadcastingOutputCollector<>(asArray, this);
  } else  {
if (containingTask.getExecutionConfig().isObjectReuseEnabled()) {
  return new CopyingDirectedOutput<>(selectors, allOutputs);
} else {
origin: apache/flink

public ArchivedExecutionConfig(ExecutionConfig ec) {
  executionMode = ec.getExecutionMode().name();
  if (ec.getRestartStrategy() != null) {
    restartStrategyDescription = ec.getRestartStrategy().getDescription();
  } else {
    restartStrategyDescription = "default";
  }
  parallelism = ec.getParallelism();
  objectReuseEnabled = ec.isObjectReuseEnabled();
  if (ec.getGlobalJobParameters() != null
      && ec.getGlobalJobParameters().toMap() != null) {
    globalJobParameters = ec.getGlobalJobParameters().toMap();
  } else {
    globalJobParameters = Collections.emptyMap();
  }
}
origin: apache/flink

if (containingTask.getExecutionConfig().isObjectReuseEnabled()) {
  currentOperatorOutput = new ChainingOutput<>(chainedOperator, this, outputTag);
origin: apache/flink

assertEquals(forceKryoEnabled, copy1.isForceKryoEnabled());
assertEquals(disableGenericTypes, copy1.hasGenericTypesDisabled());
assertEquals(objectReuseEnabled, copy1.isObjectReuseEnabled());
assertEquals(sysoutLoggingEnabled, copy1.isSysoutLoggingEnabled());
assertEquals(parallelism, copy1.getParallelism());
origin: apache/flink

Collections.sort(is, new TupleComparator<Tuple2<String, Integer>>());
List<Tuple2<String, Integer>> expected = env.getConfig().isObjectReuseEnabled() ?
  Arrays.asList(new Tuple2<>("a", 4), new Tuple2<>("a", 4),
    new Tuple2<>("a", 5), new Tuple2<>("a", 5), new Tuple2<>("a", 5)) :
origin: apache/flink

Collections.sort(is, new TupleComparator<Tuple2<String, Integer>>());
List<Tuple2<String, Integer>> expected = env.getConfig().isObjectReuseEnabled() ?
  Arrays.asList(new Tuple2<>("a", 4), new Tuple2<>("a", 4),
    new Tuple2<>("a", 5), new Tuple2<>("a", 5), new Tuple2<>("a", 5)) :
origin: org.apache.flink/flink-runtime_2.10

@Override
public void setup(TaskContext<MapFunction<IT, OT>, OT> context) {
  this.taskContext = context;
  this.running = true;
  ExecutionConfig executionConfig = taskContext.getExecutionConfig();
  this.objectReuseEnabled = executionConfig.isObjectReuseEnabled();
}
origin: org.apache.flink/flink-runtime_2.11

@Override
public void prepare() {
  ExecutionConfig executionConfig = taskContext.getExecutionConfig();
  this.objectReuseEnabled = executionConfig.isObjectReuseEnabled();
  if (LOG.isDebugEnabled()) {
    LOG.debug("FlatMapDriver object reuse: " + (this.objectReuseEnabled ? "ENABLED" : "DISABLED") + ".");
  }
}
origin: org.apache.flink/flink-runtime_2.10

@Override
public void prepare() {
  ExecutionConfig executionConfig = taskContext.getExecutionConfig();
  this.objectReuseEnabled = executionConfig.isObjectReuseEnabled();
  if (LOG.isDebugEnabled()) {
    LOG.debug("FlatMapDriver object reuse: " + (this.objectReuseEnabled ? "ENABLED" : "DISABLED") + ".");
  }
}
origin: org.apache.flink/flink-runtime_2.11

@Override
public void setup(TaskContext<MapFunction<IT, OT>, OT> context) {
  this.taskContext = context;
  this.running = true;
  ExecutionConfig executionConfig = taskContext.getExecutionConfig();
  this.objectReuseEnabled = executionConfig.isObjectReuseEnabled();
}
origin: org.apache.flink/flink-runtime

@Override
public void prepare() {
  ExecutionConfig executionConfig = taskContext.getExecutionConfig();
  this.objectReuseEnabled = executionConfig.isObjectReuseEnabled();
  if (LOG.isDebugEnabled()) {
    LOG.debug("MapPartitionDriver object reuse: " + (this.objectReuseEnabled ? "ENABLED" : "DISABLED") + ".");
  }
}
origin: com.alibaba.blink/flink-runtime

@Override
public void prepare() {
  ExecutionConfig executionConfig = taskContext.getExecutionConfig();
  this.objectReuseEnabled = executionConfig.isObjectReuseEnabled();
  if (LOG.isDebugEnabled()) {
    LOG.debug("NoOpDriver object reuse: " + (this.objectReuseEnabled ? "ENABLED" : "DISABLED") + ".");
  }
}
origin: org.apache.flink/flink-runtime_2.10

@Override
public void prepare() {
  ExecutionConfig executionConfig = taskContext.getExecutionConfig();
  this.objectReuseEnabled = executionConfig.isObjectReuseEnabled();
  if (LOG.isDebugEnabled()) {
    LOG.debug("MapPartitionDriver object reuse: " + (this.objectReuseEnabled ? "ENABLED" : "DISABLED") + ".");
  }
}
origin: org.apache.flink/flink-runtime

@Override
public void setup(TaskContext<MapFunction<IT, OT>, OT> context) {
  this.taskContext = context;
  this.running = true;
  ExecutionConfig executionConfig = taskContext.getExecutionConfig();
  this.objectReuseEnabled = executionConfig.isObjectReuseEnabled();
}
origin: com.alibaba.blink/flink-examples-streaming

@Override
public void open(Configuration parameters) throws Exception {
  lineitems = new HashMap<>();
  objectReuse = getRuntimeContext().getExecutionConfig().isObjectReuseEnabled();
}
origin: org.apache.flink/flink-test-utils

  @Override
  public ExecutionEnvironment createExecutionEnvironment() {
    lastEnv = new TestEnvironment(jobExecutor, getParallelism(), getConfig().isObjectReuseEnabled());
    return lastEnv;
  }
};
origin: com.alibaba.blink/flink-test-utils

  @Override
  public ExecutionEnvironment createExecutionEnvironment() {
    lastEnv = new TestEnvironment(jobExecutor, getParallelism(), getConfig().isObjectReuseEnabled(), jarFiles, classPaths);
    return lastEnv;
  }
};
origin: org.apache.flink/flink-test-utils_2.10

  @Override
  public ExecutionEnvironment createExecutionEnvironment() {
    lastEnv = new TestEnvironment(miniCluster, getParallelism(), getConfig().isObjectReuseEnabled());
    return lastEnv;
  }
};
org.apache.flink.api.commonExecutionConfigisObjectReuseEnabled

Javadoc

Returns whether object reuse has been enabled or disabled. @see #enableObjectReuse()

Popular methods of ExecutionConfig

  • <init>
  • disableSysoutLogging
    Disables the printing of progress update messages to System.out
  • getAutoWatermarkInterval
    Returns the interval of the automatic watermark emission.
  • setGlobalJobParameters
    Register a custom, serializable user configuration object.
  • enableObjectReuse
    Enables reusing objects that Flink internally uses for deserialization and passing data to user-code
  • setAutoWatermarkInterval
    Sets the interval of the automatic watermark emission. Watermarks are used throughout the streaming
  • disableObjectReuse
    Disables reusing objects that Flink internally uses for deserialization and passing data to user-cod
  • getRestartStrategy
    Returns the restart strategy which has been set for the current job.
  • isSysoutLoggingEnabled
    Gets whether progress update messages should be printed to System.out
  • registerKryoType
    Registers the given type with the serialization stack. If the type is eventually serialized as a POJ
  • registerTypeWithKryoSerializer
    Registers the given Serializer via its class as a serializer for the given type at the KryoSerialize
  • setRestartStrategy
    Sets the restart strategy to be used for recovery. ExecutionConfig config = env.getConfig();
  • registerTypeWithKryoSerializer,
  • setRestartStrategy,
  • getParallelism,
  • addDefaultKryoSerializer,
  • getGlobalJobParameters,
  • getNumberOfExecutionRetries,
  • getRegisteredKryoTypes,
  • setParallelism,
  • getDefaultKryoSerializerClasses

Popular in Java

  • Updating database using SQL prepared statement
  • setContentView (Activity)
  • getSharedPreferences (Context)
  • putExtra (Intent)
  • BufferedInputStream (java.io)
    A BufferedInputStream adds functionality to another input stream-namely, the ability to buffer the i
  • SecureRandom (java.security)
    This class generates cryptographically secure pseudo-random numbers. It is best to invoke SecureRand
  • DateFormat (java.text)
    Formats or parses dates and times.This class provides factories for obtaining instances configured f
  • JLabel (javax.swing)
  • JPanel (javax.swing)
  • Location (org.springframework.beans.factory.parsing)
    Class that models an arbitrary location in a Resource.Typically used to track the location of proble
  • Best IntelliJ plugins
Tabnine Logo
  • Products

    Search for Java codeSearch for JavaScript code
  • IDE Plugins

    IntelliJ IDEAWebStormVisual StudioAndroid StudioEclipseVisual Studio CodePyCharmSublime TextPhpStormVimGoLandRubyMineEmacsJupyter NotebookJupyter LabRiderDataGripAppCode
  • Company

    About UsContact UsCareers
  • Resources

    FAQBlogTabnine AcademyTerms of usePrivacy policyJava Code IndexJavascript Code Index
Get Tabnine for your IDE now