Tabnine Logo
ComputationState.getStartTimestamp
Code IndexAdd Tabnine to your IDE (free)

How to use
getStartTimestamp
method
in
org.apache.flink.cep.nfa.ComputationState

Best Java code snippets using org.apache.flink.cep.nfa.ComputationState.getStartTimestamp (Showing top 14 results out of 315)

origin: apache/flink

private boolean isStateTimedOut(final ComputationState state, final long timestamp) {
  return !isStartState(state) && windowTime > 0L && timestamp - state.getStartTimestamp() >= windowTime;
}
origin: apache/flink

  sharedBufferAccessor,
  computationState));
timeoutResult.add(Tuple2.of(timedOutPattern, computationState.getStartTimestamp() + windowTime));
origin: apache/flink

private void serializeSingleComputationState(
    ComputationState computationState,
    DataOutputView target) throws IOException {
  StringValue.writeString(computationState.getCurrentStateName(), target);
  nodeIdSerializer.serialize(computationState.getPreviousBufferEntry(), target);
  versionSerializer.serialize(computationState.getVersion(), target);
  target.writeLong(computationState.getStartTimestamp());
  serializeStartEvent(computationState.getStartEventID(), target);
}
origin: apache/flink

    computationState.getPreviousBufferEntry(),
    version,
    computationState.getStartTimestamp(),
    computationState.getStartEventID()
  );
  startEventId = event.getEventId();
} else {
  startTimestamp = computationState.getStartTimestamp();
  startEventId = computationState.getStartEventID();
origin: org.apache.flink/flink-cep_2.11

private boolean isStateTimedOut(final ComputationState state, final long timestamp) {
  return !isStartState(state) && windowTime > 0L && timestamp - state.getStartTimestamp() >= windowTime;
}
origin: org.apache.flink/flink-cep

private boolean isStateTimedOut(final ComputationState state, final long timestamp) {
  return !isStartState(state) && windowTime > 0L && timestamp - state.getStartTimestamp() >= windowTime;
}
origin: org.apache.flink/flink-cep_2.10

  readState.getTimestamp(),
  readState.getVersion(),
  readState.getStartTimestamp()
));
origin: org.apache.flink/flink-cep

private void serializeComputationStates(Queue<ComputationState> states, DataOutputView target) throws IOException {
  target.writeInt(states.size());
  for (ComputationState computationState : states) {
    STATE_NAME_SERIALIZER.serialize(computationState.getCurrentStateName(), target);
    NODE_ID_SERIALIZER.serialize(computationState.getPreviousBufferEntry(), target);
    VERSION_SERIALIZER.serialize(computationState.getVersion(), target);
    TIMESTAMP_SERIALIZER.serialize(computationState.getStartTimestamp(), target);
    if (computationState.getStartEventID() != null) {
      target.writeByte(1);
      EVENT_ID_SERIALIZER.serialize(computationState.getStartEventID(), target);
    } else {
      target.writeByte(0);
    }
  }
}
origin: org.apache.flink/flink-cep_2.11

private void serializeComputationStates(Queue<ComputationState> states, DataOutputView target) throws IOException {
  target.writeInt(states.size());
  for (ComputationState computationState : states) {
    STATE_NAME_SERIALIZER.serialize(computationState.getCurrentStateName(), target);
    NODE_ID_SERIALIZER.serialize(computationState.getPreviousBufferEntry(), target);
    VERSION_SERIALIZER.serialize(computationState.getVersion(), target);
    TIMESTAMP_SERIALIZER.serialize(computationState.getStartTimestamp(), target);
    if (computationState.getStartEventID() != null) {
      target.writeByte(1);
      EVENT_ID_SERIALIZER.serialize(computationState.getStartEventID(), target);
    } else {
      target.writeByte(0);
    }
  }
}
origin: org.apache.flink/flink-cep_2.10

timestamp - computationState.getStartTimestamp() >= windowTime) {
origin: org.apache.flink/flink-cep_2.10

@Override
public void serialize(NFA<T> record, DataOutputView target) throws IOException {
  serializeStates(record.states, target);
  target.writeLong(record.windowTime);
  target.writeBoolean(record.handleTimeout);
  sharedBufferSerializer.serialize(record.eventSharedBuffer, target);
  target.writeInt(record.computationStates.size());
  StringSerializer stateNameSerializer = StringSerializer.INSTANCE;
  LongSerializer timestampSerializer = LongSerializer.INSTANCE;
  DeweyNumber.DeweyNumberSerializer versionSerializer = new DeweyNumber.DeweyNumberSerializer();
  for (ComputationState<T> computationState: record.computationStates) {
    stateNameSerializer.serialize(computationState.getState().getName(), target);
    stateNameSerializer.serialize(computationState.getPreviousState() == null
        ? null : computationState.getPreviousState().getName(), target);
    timestampSerializer.serialize(computationState.getTimestamp(), target);
    versionSerializer.serialize(computationState.getVersion(), target);
    timestampSerializer.serialize(computationState.getStartTimestamp(), target);
    target.writeInt(computationState.getCounter());
    if (computationState.getEvent() == null) {
      target.writeBoolean(false);
    } else {
      target.writeBoolean(true);
      eventSerializer.serialize(computationState.getEvent(), target);
    }
  }
}
origin: org.apache.flink/flink-cep_2.11

    computationState.getPreviousBufferEntry(),
    version,
    computationState.getStartTimestamp(),
    computationState.getStartEventID()
  );
  startEventId = event.getEventId();
} else {
  startTimestamp = computationState.getStartTimestamp();
  startEventId = computationState.getStartEventID();
origin: org.apache.flink/flink-cep

    computationState.getPreviousBufferEntry(),
    version,
    computationState.getStartTimestamp(),
    computationState.getStartEventID()
  );
  startEventId = event.getEventId();
} else {
  startTimestamp = computationState.getStartTimestamp();
  startEventId = computationState.getStartEventID();
origin: org.apache.flink/flink-cep_2.10

      computationState.getTimestamp(),
      version,
      computationState.getStartTimestamp()
  );
    currentVersion);
} else {
  startTimestamp = computationState.getStartTimestamp();
  counter = eventSharedBuffer.put(
    NFAStateNameHandler.getOriginalNameFromInternal(
org.apache.flink.cep.nfaComputationStategetStartTimestamp

Popular methods of ComputationState

  • <init>
  • createStartState
  • createState
  • getCurrentStateName
  • getVersion
  • equals
  • getPreviousBufferEntry
  • getStartEventID
  • getConditionContext
  • getCounter
  • getEvent
  • getPreviousState
  • getEvent,
  • getPreviousState,
  • getState,
  • getTimestamp,
  • isFinalState,
  • isStartState,
  • isStopState

Popular in Java

  • Making http post requests using okhttp
  • scheduleAtFixedRate (ScheduledExecutorService)
  • getContentResolver (Context)
  • getSystemService (Context)
  • BigDecimal (java.math)
    An immutable arbitrary-precision signed decimal.A value is represented by an arbitrary-precision "un
  • URLEncoder (java.net)
    This class is used to encode a string using the format required by application/x-www-form-urlencoded
  • TreeSet (java.util)
    TreeSet is an implementation of SortedSet. All optional operations (adding and removing) are support
  • Executors (java.util.concurrent)
    Factory and utility methods for Executor, ExecutorService, ScheduledExecutorService, ThreadFactory,
  • ReentrantLock (java.util.concurrent.locks)
    A reentrant mutual exclusion Lock with the same basic behavior and semantics as the implicit monitor
  • HttpServlet (javax.servlet.http)
    Provides an abstract class to be subclassed to create an HTTP servlet suitable for a Web site. A sub
  • Top 12 Jupyter Notebook extensions
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