Uses of Class
org.apache.flink.runtime.state.ttl.TtlValue
-
Packages that use TtlValue Package Description org.apache.flink.runtime.state.ttl org.apache.flink.runtime.state.v2.ttl -
-
Uses of TtlValue in org.apache.flink.runtime.state.ttl
Methods in org.apache.flink.runtime.state.ttl that return TtlValue Modifier and Type Method Description TtlValue<T>
TtlStateFactory.TtlSerializer. createInstance(Object... values)
<SE extends Throwable,CE extends Throwable,CLE extends Throwable,V>
TtlValue<V>AbstractTtlDecorator. getWrappedWithTtlCheckAndUpdate(org.apache.flink.util.function.SupplierWithException<TtlValue<V>,SE> getter, org.apache.flink.util.function.ThrowingConsumer<TtlValue<V>,CE> updater, org.apache.flink.util.function.ThrowingRunnable<CLE> stateClear)
TtlValue<T>
TtlReduceFunction. reduce(TtlValue<T> value1, TtlValue<T> value2)
<V> TtlValue<V>
AbstractTtlDecorator. rewrapWithNewTs(TtlValue<V> ttlValue)
<V> TtlValue<V>
AbstractTtlDecorator. wrapWithTs(V value)
static <V> TtlValue<V>
TtlUtils. wrapWithTs(V value, long ts)
Methods in org.apache.flink.runtime.state.ttl that return types with arguments of type TtlValue Modifier and Type Method Description protected org.apache.flink.api.common.typeutils.CompositeSerializer<TtlValue<T>>
TtlStateFactory.TtlSerializer. createSerializerInstance(org.apache.flink.api.common.typeutils.CompositeSerializer.PrecomputedParameters precomputed, org.apache.flink.api.common.typeutils.TypeSerializer<?>... originalSerializers)
org.apache.flink.api.common.typeutils.TypeSerializerSnapshot<TtlValue<T>>
TtlStateFactory.TtlSerializer. snapshotConfiguration()
Methods in org.apache.flink.runtime.state.ttl with parameters of type TtlValue Modifier and Type Method Description <V> boolean
AbstractTtlDecorator. expired(TtlValue<V> ttlValue)
static <V> boolean
TtlUtils. expired(TtlValue<V> ttlValue, long ttl, long currentTimestamp)
static <V> boolean
TtlUtils. expired(TtlValue<V> ttlValue, long ttl, TtlTimeProvider timeProvider)
protected <T> T
AbstractTtlDecorator. getElementWithTtlCheck(TtlValue<T> ttlValue)
protected Object
TtlStateFactory.TtlSerializer. getField(TtlValue<T> v, int index)
<V> V
AbstractTtlDecorator. getUnexpired(TtlValue<V> ttlValue)
TtlValue<T>
TtlReduceFunction. reduce(TtlValue<T> value1, TtlValue<T> value2)
<V> TtlValue<V>
AbstractTtlDecorator. rewrapWithNewTs(TtlValue<V> ttlValue)
protected void
TtlStateFactory.TtlSerializer. setField(TtlValue<T> v, int index, Object fieldValue)
Method parameters in org.apache.flink.runtime.state.ttl with type arguments of type TtlValue Modifier and Type Method Description <SE extends Throwable,CE extends Throwable,CLE extends Throwable,V>
VAbstractTtlDecorator. getWithTtlCheckAndUpdate(org.apache.flink.util.function.SupplierWithException<TtlValue<V>,SE> getter, org.apache.flink.util.function.ThrowingConsumer<TtlValue<V>,CE> updater, org.apache.flink.util.function.ThrowingRunnable<CLE> stateClear)
<SE extends Throwable,CE extends Throwable,CLE extends Throwable,V>
VAbstractTtlDecorator. getWithTtlCheckAndUpdate(org.apache.flink.util.function.SupplierWithException<TtlValue<V>,SE> getter, org.apache.flink.util.function.ThrowingConsumer<TtlValue<V>,CE> updater, org.apache.flink.util.function.ThrowingRunnable<CLE> stateClear)
<SE extends Throwable,CE extends Throwable,CLE extends Throwable,V>
TtlValue<V>AbstractTtlDecorator. getWrappedWithTtlCheckAndUpdate(org.apache.flink.util.function.SupplierWithException<TtlValue<V>,SE> getter, org.apache.flink.util.function.ThrowingConsumer<TtlValue<V>,CE> updater, org.apache.flink.util.function.ThrowingRunnable<CLE> stateClear)
<SE extends Throwable,CE extends Throwable,CLE extends Throwable,V>
TtlValue<V>AbstractTtlDecorator. getWrappedWithTtlCheckAndUpdate(org.apache.flink.util.function.SupplierWithException<TtlValue<V>,SE> getter, org.apache.flink.util.function.ThrowingConsumer<TtlValue<V>,CE> updater, org.apache.flink.util.function.ThrowingRunnable<CLE> stateClear)
-
Uses of TtlValue in org.apache.flink.runtime.state.v2.ttl
Methods in org.apache.flink.runtime.state.v2.ttl that return TtlValue Modifier and Type Method Description TtlValue<ACC>
TtlAggregateFunction. add(IN value, TtlValue<ACC> accumulator)
TtlValue<ACC>
TtlAggregateFunction. createAccumulator()
TtlValue<T>
TtlStateFactory.TtlSerializer. createInstance(Object... values)
TtlValue<ACC>
TtlAggregateFunction. merge(TtlValue<ACC> a, TtlValue<ACC> b)
Methods in org.apache.flink.runtime.state.v2.ttl that return types with arguments of type TtlValue Modifier and Type Method Description protected org.apache.flink.api.common.typeutils.CompositeSerializer<TtlValue<T>>
TtlStateFactory.TtlSerializer. createSerializerInstance(org.apache.flink.api.common.typeutils.CompositeSerializer.PrecomputedParameters precomputed, org.apache.flink.api.common.typeutils.TypeSerializer<?>... originalSerializers)
org.apache.flink.api.common.typeutils.TypeSerializerSnapshot<TtlValue<T>>
TtlStateFactory.TtlSerializer. snapshotConfiguration()
Methods in org.apache.flink.runtime.state.v2.ttl with parameters of type TtlValue Modifier and Type Method Description TtlValue<ACC>
TtlAggregateFunction. add(IN value, TtlValue<ACC> accumulator)
protected Object
TtlStateFactory.TtlSerializer. getField(TtlValue<T> v, int index)
OUT
TtlAggregateFunction. getResult(TtlValue<ACC> accumulator)
TtlValue<ACC>
TtlAggregateFunction. merge(TtlValue<ACC> a, TtlValue<ACC> b)
protected void
TtlStateFactory.TtlSerializer. setField(TtlValue<T> v, int index, Object fieldValue)
-