A B C D E F G H I J K L M N O P Q R S T U V W Y Z _
All Classes All Packages
All Classes All Packages
All Classes All Packages
A
- a - Variable in class org.reactfx.EmitBothOnEachStream
- AbsentSegment(int) - Constructor for class org.reactfx.util.SparseList.AbsentSegment
- AbstractListModificationSequence<E,M extends ListModificationLike<? extends E>> - Interface in org.reactfx.collection
- AbstractReducibleEventStream<T> - Class in org.reactfx
- AbstractReducibleEventStream(EventStream<T>, NotificationAccumulator<Consumer<? super T>, T, T>) - Constructor for class org.reactfx.AbstractReducibleEventStream
- AbstractReducingStreamNotifications<T> - Class in org.reactfx.util
- AbstractReducingStreamNotifications() - Constructor for class org.reactfx.util.AbstractReducingStreamNotifications
- acc - Variable in class org.reactfx.ThenAccumulateForStream
- ACC_HAS_EVENT - org.reactfx.ThenAccumulateForStream.State
- ACC_NO_EVENT - org.reactfx.ThenAccumulateForStream.State
- accept(A, B, C) - Method in interface org.reactfx.util.TriConsumer
- accept(A, B, C, D) - Method in interface org.reactfx.util.TetraConsumer
- accept(A, B, C, D, E) - Method in interface org.reactfx.util.PentaConsumer
- accept(A, B, C, D, E, F) - Method in interface org.reactfx.util.HexaConsumer
- accept(T) - Method in class org.reactfx.LimitedInvocationSubscriber
- accept(T) - Method in class org.reactfx.value.ChangeListenerWrapper
- accept(T) - Method in class org.reactfx.value.InvalidationListenerWrapper
- AccessorListMethods<E> - Interface in org.reactfx.collection
-
Plain boilerplate, because java.util.List does not have default methods.
- accum - Variable in class org.reactfx.AccumulateBetweenStream
- accum - Variable in class org.reactfx.AccumulateUntilLaterStream
- accuMap - Variable in class org.reactfx.util.NotificationAccumulatorBase
- AccuMap<K,V,A> - Interface in org.reactfx.util
-
Accumulation map.
- accumulate(BiFunction<? super U, ? super T, ? extends U>, Function<? super T, ? extends U>) - Method in interface org.reactfx.EventStream
-
Returns an event stream that accumulates events emitted from this event stream and emits the accumulated value every time this stream emits a value.
- accumulate(BinaryOperator<T>) - Method in interface org.reactfx.EventStream
-
Returns an event stream that accumulates events emitted from this event stream and emits the accumulated value every time this stream emits a value.
- accumulate(U, BiFunction<? super U, ? super T, ? extends U>) - Method in interface org.reactfx.EventStream
-
Returns an event stream that accumulates events emitted from this event stream and emits the accumulated value every time this stream emits a value.
- accumulateBetween(EventStream<?>, Function<? super T, ? extends A>, BiFunction<? super A, ? super T, ? extends A>, Function<? super A, List<T>>) - Method in interface org.reactfx.EventStream
-
Returns an event stream that, when an event arrives from this stream, transforms it into a cumulative value using the
initialTransformation
function. - accumulateBetween(EventStream<?>, Supplier<? extends A>, BiFunction<? super A, ? super T, ? extends A>, Function<? super A, List<T>>) - Method in interface org.reactfx.EventStream
-
A variation on
EventStream.accumulateBetween(EventStream, Function, BiFunction, Function)
to use when it is more convenient to provide a unit element of the accumulation than to transform the initial event to a cumulative value. - AccumulateBetweenStream<T,A> - Class in org.reactfx
- AccumulateBetweenStream(EventStream<T>, EventStream<?>, Function<? super T, ? extends A>, BiFunction<? super A, ? super T, ? extends A>, Function<? super A, List<T>>) - Constructor for class org.reactfx.AccumulateBetweenStream
- accumulatedValue - Variable in class org.reactfx.SuspendableBase
- accumulateUntilLater(Function<? super T, ? extends A>, BiFunction<? super A, ? super T, ? extends A>, Function<? super A, List<T>>) - Method in interface org.reactfx.EventStream
-
Returns an event stream that, when an event is emitted from this stream, transforms the event to a cumulative value using the
initialTransformation
function and schedules emission usingPlatform.runLater(Runnable)
, if not already scheduled. - accumulateUntilLater(Function<? super T, ? extends A>, BiFunction<? super A, ? super T, ? extends A>, Function<? super A, List<T>>, Executor) - Method in interface org.reactfx.EventStream
-
Version of
EventStream.accumulateUntilLater(Function, BiFunction, Function)
for event streams that don't live on the JavaFX application thread. - accumulateUntilLater(Supplier<? extends A>, BiFunction<? super A, ? super T, ? extends A>, Function<? super A, List<T>>) - Method in interface org.reactfx.EventStream
-
A variation on
EventStream.accumulateUntilLater(Function, BiFunction, Function)
to use when it is more convenient to provide a unit element of the accumulation than to transform the initial event to a cumulative value. - accumulateUntilLater(Supplier<? extends A>, BiFunction<? super A, ? super T, ? extends A>, Function<? super A, List<T>>, Executor) - Method in interface org.reactfx.EventStream
-
Version of
EventStream.accumulateUntilLater(Supplier, BiFunction, Function)
for event streams that don't live on the JavaFX application thread. - AccumulateUntilLaterStream<T,A> - Class in org.reactfx
- AccumulateUntilLaterStream(EventStream<T>, Function<? super T, ? extends A>, BiFunction<? super A, ? super T, ? extends A>, Function<? super A, List<T>>, Executor) - Constructor for class org.reactfx.AccumulateUntilLaterStream
- accumulateWhen(ObservableValue<Boolean>, Function<? super T, ? extends A>, BiFunction<? super A, ? super T, ? extends A>, Function<? super A, AccumulatorSize>, Function<? super A, ? extends T>, Function<? super A, ? extends A>) - Method in interface org.reactfx.EventStream
-
Shortcut for
- accumulateWhen(ObservableValue<Boolean>, Supplier<? extends A>, BiFunction<? super A, ? super T, ? extends A>, Function<? super A, AccumulatorSize>, Function<? super A, ? extends T>, Function<? super A, ? extends A>) - Method in interface org.reactfx.EventStream
-
Shortcut for
- AccumulatingStream<T,U> - Class in org.reactfx
- AccumulatingStream(EventStream<T>, Function<? super T, ? extends U>, BiFunction<? super U, ? super T, ? extends U>) - Constructor for class org.reactfx.AccumulatingStream
- accumulation - Variable in class org.reactfx.AccumulateBetweenStream
- accumulation - Variable in class org.reactfx.AccumulateUntilLaterStream
- AccumulationFacility<T,A> - Interface in org.reactfx.util
- AccumulationFacility.HomotypicAccumulation<T> - Interface in org.reactfx.util
- AccumulationFacility.IllegalAccumulation<T,A> - Interface in org.reactfx.util
- AccumulationFacility.ListChangeAccumulation<E> - Interface in org.reactfx.util
- AccumulationFacility.NoAccumulation<T> - Interface in org.reactfx.util
- AccumulationFacility.Queuing<T> - Interface in org.reactfx.util
- AccumulationFacility.RetainLatest<T> - Interface in org.reactfx.util
- AccumulationFacility.RetainOldest<T> - Interface in org.reactfx.util
- accumulative(Function<? super T, ? extends A>, BiFunction<? super A, ? super T, ? extends A>, Function<? super A, AccumulatorSize>, Function<? super A, ? extends T>, Function<? super A, ? extends A>) - Method in interface org.reactfx.EventStream
-
Returns a suspendable event stream that, when suspended, accumulates incoming events to a cumulative value of type
A
. - accumulative(Supplier<? extends A>, BiFunction<? super A, ? super T, ? extends A>, Function<? super A, AccumulatorSize>, Function<? super A, ? extends T>, Function<? super A, ? extends A>) - Method in interface org.reactfx.EventStream
-
A variation on
EventStream.accumulative(Function, BiFunction, Function, Function, Function)
to use when it is more convenient to provide a unit element of the accumulation than to transform the initial event to a cumulative value. - AccumulativeEventStream<T,A> - Class in org.reactfx
- AccumulativeEventStream(EventStream<T>, Function<? super T, ? extends A>, BiFunction<? super A, ? super T, ? extends A>, Function<? super A, AccumulatorSize>, Function<? super A, ? extends T>, Function<? super A, ? extends A>) - Constructor for class org.reactfx.AccumulativeEventStream
- accumulativeStreamNotifications(Function<? super A, AccumulatorSize>, Function<? super A, ? extends T>, Function<? super A, ? extends A>, Function<? super T, ? extends A>, BiFunction<? super A, ? super T, ? extends A>) - Static method in interface org.reactfx.util.NotificationAccumulator
- AccumulativeStreamNotifications<T,A> - Class in org.reactfx.util
- AccumulativeStreamNotifications(Function<? super A, AccumulatorSize>, Function<? super A, ? extends T>, Function<? super A, ? extends A>, Function<? super T, ? extends A>, BiFunction<? super A, ? super T, ? extends A>) - Constructor for class org.reactfx.util.AccumulativeStreamNotifications
- AccumulatorSize - Enum in org.reactfx.util
- AccumulatorSize() - Constructor for enum org.reactfx.util.AccumulatorSize
- action - Variable in class org.reactfx.ScheduledExecutorServiceTimer
- action - Variable in class org.reactfx.util.FxTimer
- actionTime - Variable in class org.reactfx.util.FxTimer
- adaptObserver(Consumer<? super Boolean>) - Method in class org.reactfx.ToggleFromVal
- adaptObserver(Consumer<? super T>) - Method in class org.reactfx.value.VarFromVal
- adaptObserver(O) - Method in class org.reactfx.ProxyObservable
-
Adapts the given observer to observer of the underlying Observable.
- add(int, E) - Method in class org.reactfx.collection.LiveArrayList
- add(int, E) - Method in class org.reactfx.collection.SubList
- add(int, E) - Method in class org.reactfx.collection.SuspendableListWrapper
- add(int, E) - Method in interface org.reactfx.collection.UnmodifiableByDefaultList
- add(E) - Method in class org.reactfx.collection.ListIteratorImpl
- add(E) - Method in class org.reactfx.collection.LiveArrayList
- add(E) - Method in class org.reactfx.collection.SuspendableListWrapper
- add(E) - Method in interface org.reactfx.collection.UnmodifiableByDefaultList
- add(ListChangeListener.Change<? extends E>) - Method in class org.reactfx.collection.ListChangeAccumulator
- add(QuasiListChange<? extends E>) - Method in class org.reactfx.collection.ListChangeAccumulator
- add(QuasiListModification<? extends E>) - Method in class org.reactfx.collection.ListChangeAccumulator
- add(ListHelper<T>, T) - Static method in class org.reactfx.util.ListHelper
- add(T) - Method in class org.reactfx.util.ListHelper
- add(T) - Method in class org.reactfx.util.ListHelper.MultiElemHelper
- add(T) - Method in class org.reactfx.util.ListHelper.SingleElemHelper
- addAll(int, Collection<? extends E>) - Method in class org.reactfx.collection.LiveArrayList
- addAll(int, Collection<? extends E>) - Method in class org.reactfx.collection.SuspendableListWrapper
- addAll(int, Collection<? extends E>) - Method in interface org.reactfx.collection.UnmodifiableByDefaultList
- addAll(E...) - Method in class org.reactfx.collection.LiveArrayList
- addAll(E...) - Method in class org.reactfx.collection.SuspendableListWrapper
- addAll(E...) - Method in interface org.reactfx.collection.UnmodifiableByDefaultLiveList
- addAll(Collection<? extends E>) - Method in class org.reactfx.collection.LiveArrayList
- addAll(Collection<? extends E>) - Method in class org.reactfx.collection.SuspendableListWrapper
- addAll(Collection<? extends E>) - Method in interface org.reactfx.collection.UnmodifiableByDefaultList
- addAll(Iterator<K>, V, AccumulationFacility<V, A>) - Method in interface org.reactfx.util.AccuMap
- addAll(Iterator<K>, V, AccumulationFacility<V, A>) - Method in class org.reactfx.util.EmptyAccuMap
- addAll(Iterator<K>, V, AccumulationFacility<V, A>) - Method in class org.reactfx.util.HashAccuMap
- addAll(Iterator<K>, V, AccumulationFacility<V, A>) - Method in class org.reactfx.util.IteratorBasedAccuMap
- addAll(Iterator<O>, V) - Method in interface org.reactfx.util.NotificationAccumulator
- addAll(Iterator<O>, V) - Method in class org.reactfx.util.NotificationAccumulatorBase
- addChangeObserver(Consumer<? super ListChange<? extends E>>) - Method in interface org.reactfx.collection.LiveList
- addCompletionHandler - Variable in class org.reactfx.Await
- addCompletionHandler - Variable in class org.reactfx.AwaitLatest
- addCompletionHandler(CompletionStage<T>, TriConsumer<T, Throwable, Boolean>, Executor) - Static method in class org.reactfx.Await
- addCompletionHandler(Task<T>, TriConsumer<T, Throwable, Boolean>) - Static method in class org.reactfx.Await
- added - Variable in class org.reactfx.collection.MaterializedListModificationImpl
- addedSize - Variable in class org.reactfx.collection.ListModificationImpl
- addedSize - Variable in class org.reactfx.collection.QuasiListModificationImpl
- addInvalidationObserver(Consumer<? super T>) - Method in interface org.reactfx.value.Val
- addListener(InvalidationListener) - Method in interface org.reactfx.collection.LiveList
- addListener(InvalidationListener) - Method in class org.reactfx.Indicator
-
Deprecated.
- addListener(InvalidationListener) - Method in class org.reactfx.inhibeans.binding.BooleanBinding
-
Deprecated.Override adding/removing listeners.
- addListener(InvalidationListener) - Method in class org.reactfx.inhibeans.binding.DoubleBinding
-
Deprecated.Override adding/removing listeners.
- addListener(InvalidationListener) - Method in class org.reactfx.inhibeans.binding.FloatBinding
-
Deprecated.Override adding/removing listeners.
- addListener(InvalidationListener) - Method in class org.reactfx.inhibeans.binding.IntegerBinding
-
Deprecated.Override adding/removing listeners.
- addListener(InvalidationListener) - Method in class org.reactfx.inhibeans.binding.LongBinding
-
Deprecated.Override adding/removing listeners.
- addListener(InvalidationListener) - Method in class org.reactfx.inhibeans.binding.ObjectBinding
-
Deprecated.Override adding/removing listeners.
- addListener(InvalidationListener) - Method in class org.reactfx.inhibeans.binding.StringBinding
-
Deprecated.Override adding/removing listeners.
- addListener(InvalidationListener) - Method in class org.reactfx.inhibeans.ObservableBase
-
Deprecated.
- addListener(InvalidationListener) - Method in interface org.reactfx.value.Val
- addListener(ChangeListener<? super Boolean>) - Method in class org.reactfx.Indicator
-
Deprecated.
- addListener(ChangeListener<? super Boolean>) - Method in class org.reactfx.inhibeans.binding.BooleanBinding
-
Deprecated.
- addListener(ChangeListener<? super Number>) - Method in class org.reactfx.inhibeans.binding.DoubleBinding
-
Deprecated.
- addListener(ChangeListener<? super Number>) - Method in class org.reactfx.inhibeans.binding.FloatBinding
-
Deprecated.
- addListener(ChangeListener<? super Number>) - Method in class org.reactfx.inhibeans.binding.IntegerBinding
-
Deprecated.
- addListener(ChangeListener<? super Number>) - Method in class org.reactfx.inhibeans.binding.LongBinding
-
Deprecated.
- addListener(ChangeListener<? super String>) - Method in class org.reactfx.inhibeans.binding.StringBinding
-
Deprecated.
- addListener(ChangeListener<? super T>) - Method in class org.reactfx.inhibeans.binding.ObjectBinding
-
Deprecated.
- addListener(ChangeListener<? super T>) - Method in interface org.reactfx.value.Val
- addListener(ListChangeListener<? super E>) - Method in interface org.reactfx.collection.LiveList
- addModificationObserver(Consumer<? super ListModification<? extends E>>) - Method in interface org.reactfx.collection.LiveList
- addObserver(O) - Method in interface org.reactfx.Observable
- addObserver(O) - Method in class org.reactfx.ObservableBase
- addObserver(O) - Method in class org.reactfx.ProxyObservable
- addObserver(O) - Method in class org.reactfx.RigidObservable
-
Adding an observer to a RigidObservable is a no-op.
- addQuasiChangeObserver(LiveList.QuasiChangeObserver<? super E>) - Method in interface org.reactfx.collection.LiveList
- addQuasiModificationObserver(LiveList.QuasiModificationObserver<? super E>) - Method in interface org.reactfx.collection.LiveList
- adjustMajor(int) - Method in class org.reactfx.util.BiIndex
- adjustMinor(int) - Method in class org.reactfx.util.BiIndex
- af - Variable in class org.reactfx.SuspendableBase
- all(Predicate<T>) - Method in class org.reactfx.util.LL
- and(Subscription) - Method in interface org.reactfx.Subscription
-
Returns a new aggregate subscription whose
Subscription.unsubscribe()
method callsunsubscribe()
on both this subscription andother
subscription. - animate(Duration, Interpolator<T>) - Method in interface org.reactfx.value.Val
- animate(BiFunction<? super T, ? super T, Duration>, Interpolator<T>) - Method in interface org.reactfx.value.Val
- animate(ObservableValue<T>, Duration) - Static method in interface org.reactfx.value.Val
-
Like
Val.animate(ObservableValue, Duration, Interpolator)
, but uses the interpolation defined by the Interpolatable typeT
. - animate(ObservableValue<T>, Duration, Interpolator<T>) - Static method in interface org.reactfx.value.Val
-
Creates a new Val that gradually transitions to the value of the given ObservableValue
obs
every timeobs
changes. - animate(ObservableValue<T>, BiFunction<? super T, ? super T, Duration>) - Static method in interface org.reactfx.value.Val
-
Like
Val.animate(ObservableValue, BiFunction, Interpolator)
, but uses the interpolation defined by the Interpolatable typeT
. - animate(ObservableValue<T>, BiFunction<? super T, ? super T, Duration>, Interpolator<T>) - Static method in interface org.reactfx.value.Val
-
Creates a new Val that gradually transitions to the value of the given ObservableValue
obs
every timeobs
changes. - AnimatedVal<T> - Class in org.reactfx.value
- AnimatedVal(ObservableValue<T>, BiFunction<? super T, ? super T, Duration>, Interpolator<T>) - Constructor for class org.reactfx.value.AnimatedVal
- AnimatedVal.FractionTransition - Class in org.reactfx.value
- animationFrames() - Static method in class org.reactfx.EventStreams
-
Returns a stream that, on each animation frame, emits the duration elapsed since the previous animation frame, in nanoseconds.
- animationTicks() - Static method in class org.reactfx.EventStreams
-
Returns an event stream that emits a timestamp of the current frame in nanoseconds on every frame.
- append(FingerTree<SparseList.Segment<E>, SparseList.Stats>, SparseList.Segment<E>) - Method in class org.reactfx.util.SparseList
- append(T) - Method in class org.reactfx.util.FingerTree
- appendLte(FingerTree<T, S>) - Method in class org.reactfx.util.FingerTree.Branch
- appendLte(FingerTree<T, S>) - Method in class org.reactfx.util.FingerTree.Leaf
- appendLte(FingerTree<T, S>) - Method in class org.reactfx.util.FingerTree.NonEmptyFingerTree
- appendRangeTo(List<E>, int, int) - Method in class org.reactfx.util.SparseList.AbsentSegment
- appendRangeTo(List<E>, int, int) - Method in class org.reactfx.util.SparseList.PresentSegment
- appendRangeTo(List<E>, int, int) - Method in interface org.reactfx.util.SparseList.Segment
- appendTo(List<E>) - Method in class org.reactfx.util.SparseList.AbsentSegment
- appendTo(List<E>) - Method in class org.reactfx.util.SparseList.PresentSegment
- appendTo(List<E>) - Method in interface org.reactfx.util.SparseList.Segment
- appendTree(FingerTree<T, S>) - Method in class org.reactfx.util.FingerTree.NonEmptyFingerTree
- apply(A, B, C) - Method in interface org.reactfx.util.TriFunction
- apply(A, B, C, D) - Method in interface org.reactfx.util.TetraFunction
- apply(A, B, C, D, E) - Method in interface org.reactfx.util.PentaFunction
- apply(A, B, C, D, E, F) - Method in interface org.reactfx.util.HexaFunction
- asLeft() - Method in interface org.reactfx.util.Either
- asLeft() - Method in class org.reactfx.util.Left
- asLeft() - Method in class org.reactfx.util.Right
- asList() - Method in class org.reactfx.util.FingerTree
-
Returns a list view of this tree.
- asList() - Method in class org.reactfx.util.FingerTree.Branch
- asList() - Method in class org.reactfx.util.FingerTree.Empty
- asList() - Method in class org.reactfx.util.FingerTree.Leaf
- asList() - Method in interface org.reactfx.value.Val
- asListChange() - Method in class org.reactfx.collection.ListChangeAccumulator
- asListChange() - Method in interface org.reactfx.collection.ListModificationSequence
-
May be destructive for this object.
- asListChange() - Method in interface org.reactfx.collection.QuasiListChange
- asListChange() - Method in interface org.reactfx.collection.QuasiListModification
- asListChangeAccumulator() - Method in class org.reactfx.collection.ListChangeAccumulator
- asListChangeAccumulator() - Method in interface org.reactfx.collection.ListModificationSequence
-
May be destructive for this object.
- asListChangeAccumulator() - Method in interface org.reactfx.collection.QuasiListChange
- asRight() - Method in interface org.reactfx.util.Either
- asRight() - Method in class org.reactfx.util.Left
- asRight() - Method in class org.reactfx.util.Right
- asVar(Consumer<T>) - Method in interface org.reactfx.value.Val
- await() - Method in interface org.reactfx.CompletionStageStream
-
Returns a new stream that emits the results of completions stages emitted from this stream when they become available.
- await() - Method in interface org.reactfx.TaskStream
-
Returns a new stream that emits the results of tasks emitted from this stream when they become available.
- await(Executor) - Method in interface org.reactfx.CompletionStageStream
-
A variant of
CompletionStageStream.await()
for streams that do not live on the JavaFX application thread. - Await<T,F> - Class in org.reactfx
- Await(EventStream<F>, BiConsumer<F, TriConsumer<T, Throwable, Boolean>>) - Constructor for class org.reactfx.Await
- awaitCompletionStage(EventStream<CompletionStage<T>>, Executor) - Static method in class org.reactfx.Await
- awaitCompletionStage(EventStream<CompletionStage<T>>, Executor) - Static method in class org.reactfx.AwaitLatest
- awaitCompletionStage(EventStream<CompletionStage<T>>, EventStream<?>, Executor) - Static method in class org.reactfx.AwaitLatest
- AwaitingEventStream<T> - Interface in org.reactfx
-
An event stream that indicates whether there is a pending event that can be expected to be emitted in the future.
- awaitLatest() - Method in interface org.reactfx.CompletionStageStream
-
Similar to
CompletionStageStream.await()
, with one difference: for completion stages s1 and s2 emitted from this stream in this order, if s2 arrives before s1 is completed, then the result of s1 is discarded (i.e. - awaitLatest() - Method in interface org.reactfx.TaskStream
-
Similar to
TaskStream.await()
, with one difference: for tasks t1 and t2 emitted from this stream in this order, if t2 arrives before t1 is completed, then t1 is cancelled and its result is discarded (i.e. - awaitLatest(Executor) - Method in interface org.reactfx.CompletionStageStream
-
A variant of
CompletionStageStream.awaitLatest()
for streams that do not live on the JavaFX application thread. - awaitLatest(EventStream<?>) - Method in interface org.reactfx.CompletionStageStream
-
Similar to
CompletionStageStream.awaitLatest()
, with one addition: When an event is emitted fromcanceller
, if the completion stage most recently emitted from this stream has not yet completed, its result is discarded (i.e. - awaitLatest(EventStream<?>) - Method in interface org.reactfx.TaskStream
-
Similar to
TaskStream.awaitLatest()
, with one addition: When an event is emitted fromcanceller
, if the task most recently emitted from this stream has not yet completed, it is cancelled and its result discarded (i.e. - awaitLatest(EventStream<?>, Executor) - Method in interface org.reactfx.CompletionStageStream
-
A variant of
CompletionStageStream.awaitLatest(EventStream)
for streams that do not live on the JavaFX application thread. - AwaitLatest<T,F> - Class in org.reactfx
- AwaitLatest(EventStream<F>, EventStream<?>, Consumer<F>, BiConsumer<F, TriConsumer<T, Throwable, Boolean>>) - Constructor for class org.reactfx.AwaitLatest
- awaitTask(EventStream<Task<T>>) - Static method in class org.reactfx.Await
- awaitTask(EventStream<Task<T>>) - Static method in class org.reactfx.AwaitLatest
- awaitTask(EventStream<Task<T>>, EventStream<?>) - Static method in class org.reactfx.AwaitLatest
B
- BiGuard - Class in org.reactfx
- BiGuard(Guard, Guard) - Constructor for class org.reactfx.BiGuard
- BiGuardian - Class in org.reactfx
- BiGuardian(Guardian, Guardian) - Constructor for class org.reactfx.BiGuardian
- BiIndex - Class in org.reactfx.util
- BiIndex(int, int) - Constructor for class org.reactfx.util.BiIndex
- bind(ObservableValue<? extends T>) - Method in class org.reactfx.value.SimpleVar
- bind(ObservableValue<? extends T>) - Method in class org.reactfx.value.SuspendableVarWrapper
- bind(ObservableValue<? extends T>) - Method in class org.reactfx.value.VarFromVal
- bind(ObservableValue<? extends T>) - Method in class org.reactfx.value.VarWrapper
- bind(ObservableValue<? extends U>) - Method in class org.reactfx.value.FlatMappedVar
- bindBidirectional(Property<T>) - Method in interface org.reactfx.value.Var
- binding - Variable in class org.reactfx.value.VarFromVal
- Binding<T> - Interface in org.reactfx.inhibeans.binding
-
Deprecated.
- BiSubscription - Class in org.reactfx
- BiSubscription(Subscription, Subscription) - Constructor for class org.reactfx.BiSubscription
- BiSuspendable - Class in org.reactfx
- BiSuspendable(Suspendable, Suspendable) - Constructor for class org.reactfx.BiSuspendable
- block() - Method in interface org.reactfx.collection.SuspendableList
-
Deprecated.
- block() - Method in class org.reactfx.inhibeans.binding.BooleanBinding
-
Deprecated.
- block() - Method in class org.reactfx.inhibeans.binding.DoubleBinding
-
Deprecated.
- block() - Method in class org.reactfx.inhibeans.binding.FloatBinding
-
Deprecated.
- block() - Method in class org.reactfx.inhibeans.binding.IntegerBinding
-
Deprecated.
- block() - Method in class org.reactfx.inhibeans.binding.LongBinding
-
Deprecated.
- block() - Method in class org.reactfx.inhibeans.binding.ObjectBinding
-
Deprecated.
- block() - Method in class org.reactfx.inhibeans.binding.StringBinding
-
Deprecated.
- block() - Method in interface org.reactfx.inhibeans.Observable
-
Deprecated.Prevents invalidation and change events from being emitted, until the returned guard is released.
- block() - Method in class org.reactfx.inhibeans.property.BooleanPropertyBase
-
Deprecated.
- block() - Method in class org.reactfx.inhibeans.property.DoublePropertyBase
-
Deprecated.
- block() - Method in class org.reactfx.inhibeans.property.FloatPropertyBase
-
Deprecated.
- block() - Method in class org.reactfx.inhibeans.property.IntegerPropertyBase
-
Deprecated.
- block() - Method in class org.reactfx.inhibeans.property.LongPropertyBase
-
Deprecated.
- block() - Method in class org.reactfx.inhibeans.property.ObjectPropertyBase
-
Deprecated.
- block() - Method in class org.reactfx.inhibeans.property.ReadOnlyBooleanPropertyBase
-
Deprecated.
- block() - Method in class org.reactfx.inhibeans.property.ReadOnlyBooleanWrapper
-
Deprecated.
- block() - Method in class org.reactfx.inhibeans.property.ReadOnlyDoublePropertyBase
-
Deprecated.
- block() - Method in class org.reactfx.inhibeans.property.ReadOnlyDoubleWrapper
-
Deprecated.
- block() - Method in class org.reactfx.inhibeans.property.ReadOnlyFloatPropertyBase
-
Deprecated.
- block() - Method in class org.reactfx.inhibeans.property.ReadOnlyFloatWrapper
-
Deprecated.
- block() - Method in class org.reactfx.inhibeans.property.ReadOnlyIntegerPropertyBase
-
Deprecated.
- block() - Method in class org.reactfx.inhibeans.property.ReadOnlyIntegerWrapper
-
Deprecated.
- block() - Method in class org.reactfx.inhibeans.property.ReadOnlyLongPropertyBase
-
Deprecated.
- block() - Method in class org.reactfx.inhibeans.property.ReadOnlyLongWrapper
-
Deprecated.
- block() - Method in class org.reactfx.inhibeans.property.ReadOnlyObjectPropertyBase
-
Deprecated.
- block() - Method in class org.reactfx.inhibeans.property.ReadOnlyObjectWrapper
-
Deprecated.
- block() - Method in class org.reactfx.inhibeans.property.ReadOnlyStringPropertyBase
-
Deprecated.
- block() - Method in class org.reactfx.inhibeans.property.ReadOnlyStringWrapper
-
Deprecated.
- block() - Method in class org.reactfx.inhibeans.property.SimpleBooleanProperty
-
Deprecated.
- block() - Method in class org.reactfx.inhibeans.property.SimpleDoubleProperty
-
Deprecated.
- block() - Method in class org.reactfx.inhibeans.property.SimpleFloatProperty
-
Deprecated.
- block() - Method in class org.reactfx.inhibeans.property.SimpleIntegerProperty
-
Deprecated.
- block() - Method in class org.reactfx.inhibeans.property.SimpleLongProperty
-
Deprecated.
- block() - Method in class org.reactfx.inhibeans.property.SimpleObjectProperty
-
Deprecated.
- block() - Method in class org.reactfx.inhibeans.property.SimpleStringProperty
-
Deprecated.
- block() - Method in class org.reactfx.inhibeans.property.StringPropertyBase
-
Deprecated.
- block() - Method in class org.reactfx.inhibeans.value.ObservableValueBase
-
Deprecated.
- blocked - Variable in class org.reactfx.inhibeans.binding.BooleanBinding
-
Deprecated.
- blocked - Variable in class org.reactfx.inhibeans.binding.DoubleBinding
-
Deprecated.
- blocked - Variable in class org.reactfx.inhibeans.binding.FloatBinding
-
Deprecated.
- blocked - Variable in class org.reactfx.inhibeans.binding.IntegerBinding
-
Deprecated.
- blocked - Variable in class org.reactfx.inhibeans.binding.LongBinding
-
Deprecated.
- blocked - Variable in class org.reactfx.inhibeans.binding.ObjectBinding
-
Deprecated.
- blocked - Variable in class org.reactfx.inhibeans.binding.StringBinding
-
Deprecated.
- blocked - Variable in class org.reactfx.inhibeans.property.BooleanPropertyBase
-
Deprecated.
- blocked - Variable in class org.reactfx.inhibeans.property.DoublePropertyBase
-
Deprecated.
- blocked - Variable in class org.reactfx.inhibeans.property.FloatPropertyBase
-
Deprecated.
- blocked - Variable in class org.reactfx.inhibeans.property.IntegerPropertyBase
-
Deprecated.
- blocked - Variable in class org.reactfx.inhibeans.property.LongPropertyBase
-
Deprecated.
- blocked - Variable in class org.reactfx.inhibeans.property.ObjectPropertyBase
-
Deprecated.
- blocked - Variable in class org.reactfx.inhibeans.property.ReadOnlyBooleanPropertyBase
-
Deprecated.
- blocked - Variable in class org.reactfx.inhibeans.property.ReadOnlyBooleanWrapper
-
Deprecated.
- blocked - Variable in class org.reactfx.inhibeans.property.ReadOnlyDoublePropertyBase
-
Deprecated.
- blocked - Variable in class org.reactfx.inhibeans.property.ReadOnlyDoubleWrapper
-
Deprecated.
- blocked - Variable in class org.reactfx.inhibeans.property.ReadOnlyFloatPropertyBase
-
Deprecated.
- blocked - Variable in class org.reactfx.inhibeans.property.ReadOnlyFloatWrapper
-
Deprecated.
- blocked - Variable in class org.reactfx.inhibeans.property.ReadOnlyIntegerPropertyBase
-
Deprecated.
- blocked - Variable in class org.reactfx.inhibeans.property.ReadOnlyIntegerWrapper
-
Deprecated.
- blocked - Variable in class org.reactfx.inhibeans.property.ReadOnlyLongPropertyBase
-
Deprecated.
- blocked - Variable in class org.reactfx.inhibeans.property.ReadOnlyLongWrapper
-
Deprecated.
- blocked - Variable in class org.reactfx.inhibeans.property.ReadOnlyObjectPropertyBase
-
Deprecated.
- blocked - Variable in class org.reactfx.inhibeans.property.ReadOnlyObjectWrapper
-
Deprecated.
- blocked - Variable in class org.reactfx.inhibeans.property.ReadOnlyStringPropertyBase
-
Deprecated.
- blocked - Variable in class org.reactfx.inhibeans.property.ReadOnlyStringWrapper
-
Deprecated.
- blocked - Variable in class org.reactfx.inhibeans.property.SimpleBooleanProperty
-
Deprecated.
- blocked - Variable in class org.reactfx.inhibeans.property.SimpleDoubleProperty
-
Deprecated.
- blocked - Variable in class org.reactfx.inhibeans.property.SimpleFloatProperty
-
Deprecated.
- blocked - Variable in class org.reactfx.inhibeans.property.SimpleIntegerProperty
-
Deprecated.
- blocked - Variable in class org.reactfx.inhibeans.property.SimpleLongProperty
-
Deprecated.
- blocked - Variable in class org.reactfx.inhibeans.property.SimpleObjectProperty
-
Deprecated.
- blocked - Variable in class org.reactfx.inhibeans.property.SimpleStringProperty
-
Deprecated.
- blocked - Variable in class org.reactfx.inhibeans.property.StringPropertyBase
-
Deprecated.
- blocked - Variable in class org.reactfx.inhibeans.value.ObservableValueBase
-
Deprecated.
- blockWhile(Runnable) - Method in interface org.reactfx.inhibeans.Observable
-
Deprecated.Runs the given computation, making sure the invalidation and change events are blocked.
- blockWhile(Supplier<T>) - Method in interface org.reactfx.inhibeans.Observable
-
Deprecated.Runs the given computation, making sure the invalidation and change events are blocked.
- BooleanBinding - Class in org.reactfx.inhibeans.binding
-
Deprecated.
- BooleanBinding() - Constructor for class org.reactfx.inhibeans.binding.BooleanBinding
-
Deprecated.
- BooleanPropertyBase - Class in org.reactfx.inhibeans.property
-
Deprecated.
- BooleanPropertyBase() - Constructor for class org.reactfx.inhibeans.property.BooleanPropertyBase
-
Deprecated.Superclass constructors.
- BooleanPropertyBase(boolean) - Constructor for class org.reactfx.inhibeans.property.BooleanPropertyBase
-
Deprecated.
- boundTo - Variable in class org.reactfx.value.FlatMappedVar
- boundTo - Variable in class org.reactfx.value.SimpleVar
- boundToListener - Variable in class org.reactfx.value.SimpleVar
- branch(FingerTree.NonEmptyFingerTree<T, S>, FingerTree.NonEmptyFingerTree<T, S>) - Static method in class org.reactfx.util.FingerTree
- branch(FingerTree.NonEmptyFingerTree<T, S>, FingerTree.NonEmptyFingerTree<T, S>, FingerTree.NonEmptyFingerTree<T, S>) - Static method in class org.reactfx.util.FingerTree
- branch(LL.Cons<FingerTree.NonEmptyFingerTree<T, S>>) - Static method in class org.reactfx.util.FingerTree
- Branch(LL.Cons<FingerTree.NonEmptyFingerTree<T, S>>) - Constructor for class org.reactfx.util.FingerTree.Branch
- build(Consumer<Function<S, TGT>>) - Method in class org.reactfx.InputHandlerBuilder
C
- cancelImpulse - Variable in class org.reactfx.AwaitLatest
- canceller - Variable in class org.reactfx.AwaitLatest
- caseEmpty() - Method in class org.reactfx.util.FingerTree
- caseEmpty() - Method in class org.reactfx.util.FingerTree.Empty
- caseEmpty() - Method in class org.reactfx.util.FingerTree.NonEmptyFingerTree
- cast(Class<U>) - Method in interface org.reactfx.EventStream
-
Returns a new event stream that emits events emitted by this stream cast to the given type.
- Change<T> - Class in org.reactfx
-
Represents a change of a value.
- Change(T, T) - Constructor for class org.reactfx.Change
- ChangeListenerWrapper<T> - Class in org.reactfx.collection
- ChangeListenerWrapper<T> - Class in org.reactfx.value
- ChangeListenerWrapper(ObservableValue<T>, ChangeListener<? super T>) - Constructor for class org.reactfx.value.ChangeListenerWrapper
- ChangeListenerWrapper(ObservableList<T>, ListChangeListener<? super T>) - Constructor for class org.reactfx.collection.ChangeListenerWrapper
- ChangeObserverWrapper<T> - Class in org.reactfx.collection
- ChangeObserverWrapper(ObservableList<T>, Consumer<? super ListChange<? extends T>>) - Constructor for class org.reactfx.collection.ChangeObserverWrapper
- changes() - Method in interface org.reactfx.collection.LiveList
- changes() - Method in interface org.reactfx.value.Val
-
Returns a stream of changed values, which emits the changed value (i.e.
- changesOf(ObservableValue<T>) - Static method in class org.reactfx.EventStreams
- changesOf(ObservableList<E>) - Static method in interface org.reactfx.collection.LiveList
- changesOf(ObservableList<T>) - Static method in class org.reactfx.EventStreams
- changesOf(ObservableMap<K, V>) - Static method in class org.reactfx.EventStreams
- changesOf(ObservableSet<T>) - Static method in class org.reactfx.EventStreams
- checkIndex(int) - Method in class org.reactfx.collection.SubList
- checkIndex(int, int) - Static method in class org.reactfx.util.Lists
- checkIndex(int, int, int) - Static method in class org.reactfx.util.Lists
- checkPeeked() - Method in class org.reactfx.util.IteratorBasedAccuMap
- checkPosition(int, int) - Static method in class org.reactfx.util.Lists
- checkPosition(int, int, int) - Static method in class org.reactfx.util.Lists
- checkRange(int, int, int) - Static method in class org.reactfx.util.Lists
- checkRange(int, int, int, int) - Static method in class org.reactfx.util.Lists
- children - Variable in class org.reactfx.util.FingerTree.Branch
- chooseKey() - Method in class org.reactfx.util.MapHelper
- chooseKey() - Method in class org.reactfx.util.MapHelper.MultiEntryHelper
- chooseKey() - Method in class org.reactfx.util.MapHelper.SingleEntryHelper
- chooseKey(MapHelper<K, V>) - Static method in class org.reactfx.util.MapHelper
- clear() - Method in class org.reactfx.collection.LiveArrayList
- clear() - Method in class org.reactfx.collection.SuspendableListWrapper
- clear() - Method in interface org.reactfx.collection.UnmodifiableByDefaultList
- clear() - Method in class org.reactfx.EventStreams.Pocket
- clear() - Method in interface org.reactfx.util.NotificationAccumulator
- clear() - Method in class org.reactfx.util.NotificationAccumulatorBase
- clear() - Method in class org.reactfx.util.SparseList
- cListeners - Variable in class org.reactfx.Indicator
-
Deprecated.
- close() - Method in class org.reactfx.BiGuard
- close() - Method in class org.reactfx.CloseableOnceGuard
- close() - Method in interface org.reactfx.Guard
-
Releases this guard.
- close() - Method in class org.reactfx.MultiGuard
- closeableOnce() - Method in interface org.reactfx.Guard
- closeableOnce(Guard) - Static method in interface org.reactfx.Guard
- CloseableOnceGuard - Class in org.reactfx
- CloseableOnceGuard(Guard) - Constructor for class org.reactfx.CloseableOnceGuard
- collapse(Function<? super List<E>, ? extends T>) - Method in interface org.reactfx.collection.LiveList
- collapse(ObservableList<? extends E>, Function<? super List<E>, ? extends T>) - Static method in interface org.reactfx.collection.LiveList
- collapseDynamic(ObservableValue<? extends Function<? super List<E>, ? extends T>>) - Method in interface org.reactfx.collection.LiveList
- collapseDynamic(ObservableList<? extends E>, ObservableValue<? extends Function<? super List<E>, ? extends T>>) - Static method in interface org.reactfx.collection.LiveList
- collect() - Method in class org.reactfx.util.SparseList
- collect(int, int) - Method in class org.reactfx.util.SparseList
- Collections - Class in org.reactfx.inhibeans.collection
-
Deprecated.
- Collections() - Constructor for class org.reactfx.inhibeans.collection.Collections
-
Deprecated.
- combine(ObservableValue<A>, ObservableValue<B>, BiFunction<? super A, ? super B, ? extends R>) - Static method in interface org.reactfx.value.Val
- combine(ObservableValue<A>, ObservableValue<B>, ObservableValue<C>, ObservableValue<D>, ObservableValue<E>, ObservableValue<F>, HexaFunction<? super A, ? super B, ? super C, ? super D, ? super E, ? super F, ? extends R>) - Static method in interface org.reactfx.value.Val
- combine(ObservableValue<A>, ObservableValue<B>, ObservableValue<C>, ObservableValue<D>, ObservableValue<E>, PentaFunction<? super A, ? super B, ? super C, ? super D, ? super E, ? extends R>) - Static method in interface org.reactfx.value.Val
- combine(ObservableValue<A>, ObservableValue<B>, ObservableValue<C>, ObservableValue<D>, TetraFunction<? super A, ? super B, ? super C, ? super D, ? extends R>) - Static method in interface org.reactfx.value.Val
- combine(ObservableValue<A>, ObservableValue<B>, ObservableValue<C>, TriFunction<? super A, ? super B, ? super C, ? extends R>) - Static method in interface org.reactfx.value.Val
- combine(QuasiListModification<? extends E>, QuasiListModification<? extends E>) - Static method in class org.reactfx.collection.ListChangeAccumulator
- combine(EventStream<A>, EventStream<B>) - Static method in class org.reactfx.EventStreams
- combine(EventStream<A>, EventStream<B>, EventStream<C>) - Static method in class org.reactfx.EventStreams
- combine(EventStream<A>, EventStream<B>, EventStream<C>, EventStream<D>) - Static method in class org.reactfx.EventStreams
- combine(EventStream<A>, EventStream<B>, EventStream<C>, EventStream<D>, EventStream<E>) - Static method in class org.reactfx.EventStreams
- combine(EventStream<A>, EventStream<B>, EventStream<C>, EventStream<D>, EventStream<E>, EventStream<F>) - Static method in class org.reactfx.EventStreams
- combine(Guardian...) - Static method in interface org.reactfx.Guardian
-
Deprecated.Returns a guardian that combines all of the given guardians into one.
- combine(Suspendable...) - Static method in interface org.reactfx.Suspendable
-
Returns a Suspendable that combines all the given Suspendables into one.
- commonPrefixLength(List<?>, List<?>) - Static method in class org.reactfx.util.Lists
- commonPrefixSuffixLengths(List<?>, List<?>) - Static method in class org.reactfx.util.Lists
-
Returns the lengths of common prefix and common suffix of two lists.
- commonSuffixLength(List<?>, List<?>) - Static method in class org.reactfx.util.Lists
- CompletionStageStream<T> - Interface in org.reactfx
- computeValue() - Method in class org.reactfx.collection.ListReduction
- computeValue() - Method in class org.reactfx.SuspendableBoolean
- computeValue() - Method in class org.reactfx.value.AnimatedVal
- computeValue() - Method in class org.reactfx.value.FlatMapped
- computeValue() - Method in class org.reactfx.value.MappedVal
- computeValue() - Method in class org.reactfx.value.OrElse
- computeValue() - Method in class org.reactfx.value.OrElseConst
- computeValue() - Method in class org.reactfx.value.SimpleVar
- computeValue() - Method in class org.reactfx.value.ValBase
- computeValue() - Method in class org.reactfx.value.ValWrapper
- concat(List<? extends E>...) - Static method in class org.reactfx.util.Lists
- concat(List<List<? extends E>>) - Static method in class org.reactfx.util.Lists
-
Returns a list that is a concatenation of the given lists.
- concat(LL.Cons<? extends FingerTree<T, S>>) - Static method in class org.reactfx.util.FingerTree
- concat(LL<? extends T>, LL<? extends T>) - Static method in class org.reactfx.util.LL
- concatView - Variable in class org.reactfx.LatestNStream
- concatView(List<? extends E>...) - Static method in class org.reactfx.util.Lists
- concatView(List<List<? extends E>>) - Static method in class org.reactfx.util.Lists
-
Returns a list that is a concatenation of the given lists.
- concatView(List<List<? extends E>>, boolean) - Static method in class org.reactfx.util.ConcatView
- ConcatView<E> - Class in org.reactfx.util
- ConcatView(List<? extends E>, List<? extends E>) - Constructor for class org.reactfx.util.ConcatView
- condition - Variable in class org.reactfx.SuspendedWhenStream
- conditionOn(ObservableValue<Boolean>) - Method in interface org.reactfx.EventStream
- conditionOn(ObservableValue<Boolean>) - Method in interface org.reactfx.value.Val
- conditionOn(ObservableValue<T>, ObservableValue<Boolean>) - Static method in interface org.reactfx.value.Val
- conditionOnShowing(ObservableValue<T>, Node) - Static method in interface org.reactfx.value.Val
- conditionOnShowing(Node) - Method in interface org.reactfx.EventStream
-
Equivalent to
EventStream.conditionOn(ObservableValue)
where the condition is thatnode
is showing: it is part of a scene graph (Node.sceneProperty()
is notnull
), its scene is part of a window (Scene.windowProperty()
is notnull
) and the window is showing (Window.showingProperty()
istrue
). - conditionOnShowing(Node) - Method in interface org.reactfx.value.Val
-
Equivalent to
Val.conditionOn(ObservableValue)
where the condition is thatnode
is showing: it is part of a scene graph (Node.sceneProperty()
is notnull
), its scene is part of a window (Scene.windowProperty()
is notnull
) and the window is showing (Window.showingProperty()
istrue
). - connect() - Method in class org.reactfx.collection.ListRangeReduction
- connect() - Method in class org.reactfx.collection.ListReduction
- connect() - Method in class org.reactfx.SuspendableBoolean
- connect() - Method in class org.reactfx.value.AnimatedVal
- connect() - Method in class org.reactfx.value.FlatMapped
- connect() - Method in class org.reactfx.value.MappedVal
- connect() - Method in class org.reactfx.value.OrElse
- connect() - Method in class org.reactfx.value.OrElseConst
- connect() - Method in class org.reactfx.value.SimpleVar
- connect() - Method in class org.reactfx.value.ValBase
-
Implementation of this method should start observing inputs.
- connect() - Method in class org.reactfx.value.ValWrapper
- Connectable<T> - Interface in org.reactfx
-
Interface for objects that can be (lazily) connected to event streams.
- ConnectableEventSink<T> - Interface in org.reactfx
- ConnectableEventSource<T> - Class in org.reactfx
- ConnectableEventSource() - Constructor for class org.reactfx.ConnectableEventSource
- ConnectableEventStream<T> - Interface in org.reactfx
- connectTo(EventStream<? extends T>) - Method in interface org.reactfx.Connectable
-
Connects this connectable object to
source
event stream. - connectTo(EventStream<? extends T>) - Method in class org.reactfx.ConnectableEventSource
- cons(T, LL<? extends T>) - Static method in class org.reactfx.util.LL
- Cons(T, LL<? extends T>) - Constructor for class org.reactfx.util.LL.Cons
- constant(T) - Static method in interface org.reactfx.value.Val
-
Returns a constant Val that holds the given value.
- ConstVal<T> - Class in org.reactfx.value
- ConstVal(T) - Constructor for class org.reactfx.value.ConstVal
- contains(Object) - Method in interface org.reactfx.collection.AccessorListMethods
- contains(Object) - Method in class org.reactfx.collection.SuspendableListWrapper
- containsAll(Collection<?>) - Method in interface org.reactfx.collection.AccessorListMethods
- containsAll(Collection<?>) - Method in class org.reactfx.collection.SuspendableListWrapper
- containsKey(K) - Method in class org.reactfx.util.MapHelper
- containsKey(K) - Method in class org.reactfx.util.MapHelper.MultiEntryHelper
- containsKey(K) - Method in class org.reactfx.util.MapHelper.SingleEntryHelper
- containsKey(MapHelper<K, ?>, K) - Static method in class org.reactfx.util.MapHelper
- contentReplacement(List<E>) - Method in interface org.reactfx.collection.ProperLiveList
- copy() - Method in class org.reactfx.util.ListHelper.MultiElemHelper
- create(int, List<? extends E>, int) - Static method in interface org.reactfx.collection.QuasiListModification
- create(int, List<? extends E>, List<? extends E>) - Static method in interface org.reactfx.collection.MaterializedListModification
-
Doesn't create defensive copies of the passed lists.
- create(Duration, Runnable) - Static method in class org.reactfx.util.FxTimer
-
Prepares a (stopped) timer that lasts for
delay
and whose action runs when timer ends. - create(Duration, Runnable, ScheduledExecutorService, Executor) - Static method in class org.reactfx.ScheduledExecutorServiceTimer
- create(Supplier<? extends T>, Observable...) - Static method in class org.reactfx.EventStreams
- create(Supplier<? extends T>, Observable...) - Static method in interface org.reactfx.value.Val
- create(Supplier<? extends T>, EventStream<?>) - Static method in interface org.reactfx.value.Val
- create(List<List<? extends E>>) - Static method in class org.reactfx.util.ConcatView
- create(List<List<? extends E>>) - Static method in class org.reactfx.util.ListConcatenation
- createPeriodic(Duration, Runnable) - Static method in class org.reactfx.util.FxTimer
-
Prepares a (stopped) timer that lasts for
interval
and that executes the given action periodically when the timer ends. - createPeriodic(Duration, Runnable, ScheduledExecutorService, Executor) - Static method in class org.reactfx.ScheduledExecutorServiceTimer
- createPeriodic0(Duration, Runnable) - Static method in class org.reactfx.util.FxTimer
-
Prepares a (stopped) timer that lasts for
interval
and that executes the given action periodically when the timer starts. - currentAccumulatedValue - Variable in class org.reactfx.util.IteratorBasedAccuMap
- currentKey - Variable in class org.reactfx.util.IteratorBasedAccuMap
D
- data - Variable in class org.reactfx.util.FingerTree.Leaf
- deconstruction - Variable in class org.reactfx.AccumulateBetweenStream
- deconstruction - Variable in class org.reactfx.AccumulateUntilLaterStream
- deconstruction - Variable in class org.reactfx.ThenAccumulateForStream
- defaultEquals(Object) - Method in interface org.reactfx.collection.ProperLiveList
- defaultEquals(Object) - Method in interface org.reactfx.ProperObservable
- DefaultEventStream<T> - Class in org.reactfx
- DefaultEventStream(EventStream<T>, T) - Constructor for class org.reactfx.DefaultEventStream
- defaultHashCode() - Method in interface org.reactfx.collection.ProperLiveList
- defaultHashCode() - Method in interface org.reactfx.ProperObservable
- defaultNotificationAccumulator() - Method in interface org.reactfx.collection.ProperLiveList
- defaultNotificationAccumulator() - Method in interface org.reactfx.ProperEventStream
- defaultNotificationAccumulator() - Method in interface org.reactfx.ProperObservable
- defaultNotificationAccumulator() - Method in interface org.reactfx.value.ProperVal
- defaultToString() - Method in interface org.reactfx.collection.ProperLiveList
- defaultToString() - Method in interface org.reactfx.ProperObservable
- delegate - Variable in class org.reactfx.CloseableOnceGuard
- delegate - Variable in class org.reactfx.collection.SuspendableListWrapper
- delegate - Variable in class org.reactfx.util.WrapperBase
- delegate - Variable in class org.reactfx.value.SuspendableValWrapper
- delegate - Variable in class org.reactfx.value.SuspendableVarWrapper
- delegate - Variable in class org.reactfx.value.ValWrapper
- depth - Variable in class org.reactfx.util.FingerTree.Branch
- dispose() - Method in class org.reactfx.StreamBinding
- distinct() - Method in interface org.reactfx.EventStream
-
Returns a new event stream that emits repetitive events only once.
- DistinctStream<T> - Class in org.reactfx
- DistinctStream(EventStream<T>) - Constructor for class org.reactfx.DistinctStream
- DoubleBinding - Class in org.reactfx.inhibeans.binding
-
Deprecated.
- DoubleBinding() - Constructor for class org.reactfx.inhibeans.binding.DoubleBinding
-
Deprecated.
- DoublePropertyBase - Class in org.reactfx.inhibeans.property
-
Deprecated.
- DoublePropertyBase() - Constructor for class org.reactfx.inhibeans.property.DoublePropertyBase
-
Deprecated.Superclass constructors.
- DoublePropertyBase(double) - Constructor for class org.reactfx.inhibeans.property.DoublePropertyBase
-
Deprecated.
- doubleVar(DoubleProperty) - Static method in interface org.reactfx.value.Var
-
Converts DoubleProperty to
Var<Double>
to help deal with the consequences of DoubleProperty not being a subtype ofProperty<Double>
. - drop(int) - Method in class org.reactfx.collection.ListChangeAccumulator
- drop(int) - Method in class org.reactfx.util.ListConcatenation
- dropPeeked() - Method in interface org.reactfx.util.AccuMap
- dropPeeked() - Method in class org.reactfx.util.EmptyAccuMap
- dropPeeked() - Method in class org.reactfx.util.HashAccuMap
- dropPeeked() - Method in class org.reactfx.util.IteratorBasedAccuMap
- duration - Variable in class org.reactfx.value.AnimatedVal
- dynamic(ObservableSet<T>, Function<? super T, ? extends Subscription>) - Static method in interface org.reactfx.Subscription
-
Dynamically subscribes to all elements of the given observable set.
- DynamicallyMappedList<E,F> - Class in org.reactfx.collection
- DynamicallyMappedList(ObservableList<? extends E>, ObservableValue<? extends Function<? super E, ? extends F>>) - Constructor for class org.reactfx.collection.DynamicallyMappedList
E
- EASE_BOTH_DOUBLE - Static variable in interface org.reactfx.util.Interpolator
- EASE_BOTH_INTEGER - Static variable in interface org.reactfx.util.Interpolator
- EASE_BOTH_LONG - Static variable in interface org.reactfx.util.Interpolator
- EASE_BOTH_NUMBER - Static variable in interface org.reactfx.util.Interpolator
- EASE_IN_DOUBLE - Static variable in interface org.reactfx.util.Interpolator
- EASE_IN_INTEGER - Static variable in interface org.reactfx.util.Interpolator
- EASE_IN_LONG - Static variable in interface org.reactfx.util.Interpolator
- EASE_IN_NUMBER - Static variable in interface org.reactfx.util.Interpolator
- EASE_OUT_DOUBLE - Static variable in interface org.reactfx.util.Interpolator
- EASE_OUT_INTEGER - Static variable in interface org.reactfx.util.Interpolator
- EASE_OUT_LONG - Static variable in interface org.reactfx.util.Interpolator
- EASE_OUT_NUMBER - Static variable in interface org.reactfx.util.Interpolator
- Either<L,R> - Interface in org.reactfx.util
- elem - Variable in class org.reactfx.util.ListHelper.SingleElemHelper
- elemInsertion(int) - Static method in interface org.reactfx.collection.ProperLiveList
- elemRemoval(int, E) - Static method in interface org.reactfx.collection.ProperLiveList
- elemReplacement(int, E) - Static method in interface org.reactfx.collection.ProperLiveList
- elems - Variable in class org.reactfx.util.ListHelper.MultiElemHelper
- EmissionBuilder<S,O> - Class in org.reactfx
- EmissionBuilder(EventStream<I>, BiFunction<? super S, ? super I, ? extends Optional<O>>) - Constructor for class org.reactfx.EmissionBuilder
- emissions - Variable in class org.reactfx.StatefulStreamBuilderImpl
- emissions - Variable in class org.reactfx.StatefulStreamBuilderOnImpl
- emit(BiFunction<? super S, ? super I, Optional<O>>) - Method in class org.reactfx.ObservableStateBuilderOnImpl
- emit(BiFunction<? super S, ? super I, Optional<O>>) - Method in class org.reactfx.StatefulStreamBuilderOnImpl
- emit(BiFunction<? super S, ? super I, Optional<O>>) - Method in interface org.reactfx.StateMachine.ObservableStateBuilderOn
- emit(BiFunction<? super S, ? super I, Optional<O>>) - Method in interface org.reactfx.StateMachine.StatefulStreamBuilderOn
- emit(T) - Method in interface org.reactfx.ProperEventStream
- emitAccum() - Method in class org.reactfx.AccumulateUntilLaterStream
- emitBothOnEach(EventStream<I>) - Method in interface org.reactfx.EventStream
-
Similar to
EventStream.emitOnEach(EventStream)
, but also includes the impulse in the emitted value. - EmitBothOnEachStream<A,I> - Class in org.reactfx
- EmitBothOnEachStream(EventStream<A>, EventStream<I>) - Constructor for class org.reactfx.EmitBothOnEachStream
- emitOn(EventStream<?>) - Method in interface org.reactfx.EventStream
-
Returns a new event stream that, when an event arrives from the
impulse
stream, emits the most recent event emitted by this stream. - emitOnEach(EventStream<?>) - Method in interface org.reactfx.EventStream
-
Returns a new event stream that, when an event arrives from the
impulse
stream, emits the most recent event emitted by this stream. - EmitOnEachStream<T> - Class in org.reactfx
- EmitOnEachStream(EventStream<T>, EventStream<?>) - Constructor for class org.reactfx.EmitOnEachStream
- EmitOnStream<T> - Class in org.reactfx
- EmitOnStream(EventStream<T>, EventStream<?>) - Constructor for class org.reactfx.EmitOnStream
- emitted - Variable in class org.reactfx.DefaultEventStream
- empty() - Static method in interface org.reactfx.util.AccuMap
- empty() - Method in class org.reactfx.util.FingerTree
- empty(ToSemigroup<? super T, S>) - Static method in class org.reactfx.util.FingerTree
- Empty(ToSemigroup<? super T, S>) - Constructor for class org.reactfx.util.FingerTree.Empty
- EMPTY - Static variable in interface org.reactfx.Guardian
-
Deprecated.
- EMPTY - Static variable in interface org.reactfx.Subscription
- EMPTY_GUARD - Static variable in interface org.reactfx.Guard
- EmptyAccuMap<K,V,A> - Class in org.reactfx.util
- EmptyAccuMap() - Constructor for class org.reactfx.util.EmptyAccuMap
- emptyTree() - Static method in class org.reactfx.util.SparseList
- enqueueNotifications(T) - Method in class org.reactfx.ObservableBase
- entries - Variable in class org.reactfx.util.MapHelper.MultiEntryHelper
- equals(Object) - Method in class org.reactfx.ObservableBase
- equals(Object) - Method in class org.reactfx.util.Left
- equals(Object) - Method in class org.reactfx.util.Right
- equals(Object) - Method in class org.reactfx.util.Tuple2
- equals(Object) - Method in class org.reactfx.util.Tuple3
- equals(Object) - Method in class org.reactfx.util.Tuple4
- equals(Object) - Method in class org.reactfx.util.Tuple5
- equals(Object) - Method in class org.reactfx.util.Tuple6
- equals(Object) - Method in class org.reactfx.util.WrapperBase
- equals(List<?>, Object) - Static method in class org.reactfx.util.Lists
- event - Variable in class org.reactfx.AccumulatingStream
- event - Variable in class org.reactfx.SuccessionReducingStream
- EventSink<T> - Interface in org.reactfx
- eventsOf(MenuItem, EventType<T>) - Static method in class org.reactfx.EventStreams
- eventsOf(Node, EventType<T>) - Static method in class org.reactfx.EventStreams
- eventsOf(Scene, EventType<T>) - Static method in class org.reactfx.EventStreams
- eventsOf(Window, EventType<T>) - Static method in class org.reactfx.EventStreams
- EventSource<T> - Class in org.reactfx
-
EventSource is an EventSink that serves also as an EventStream - every value pushed to EventSource is immediately emitted by it.
- EventSource() - Constructor for class org.reactfx.EventSource
- EventStream<T> - Interface in org.reactfx
-
Stream of values (events).
- EventStreamBase<T> - Class in org.reactfx
-
Base class for event streams.
- EventStreamBase() - Constructor for class org.reactfx.EventStreamBase
- EventStreamBase(NotificationAccumulator<Consumer<? super T>, T, ?>) - Constructor for class org.reactfx.EventStreamBase
- EventStreams - Class in org.reactfx
- EventStreams() - Constructor for class org.reactfx.EventStreams
- EventStreams.ExclusivePocket<T> - Class in org.reactfx
- EventStreams.Never<T> - Class in org.reactfx
- EventStreams.Pocket<T> - Class in org.reactfx
- eventThreadExecutor - Variable in class org.reactfx.AccumulateUntilLaterStream
- eventThreadExecutor - Variable in class org.reactfx.ScheduledExecutorServiceTimer
- ExclusivePocket() - Constructor for class org.reactfx.EventStreams.ExclusivePocket
- exec(BiConsumer<? super A, ? super B>) - Method in class org.reactfx.util.Tuple2
- exec(Consumer<? super L>, Consumer<? super R>) - Method in interface org.reactfx.util.Either
- exec(Consumer<? super L>, Consumer<? super R>) - Method in class org.reactfx.util.Left
- exec(Consumer<? super L>, Consumer<? super R>) - Method in class org.reactfx.util.Right
- exec(HexaConsumer<? super A, ? super B, ? super C, ? super D, ? super E, ? super F>) - Method in class org.reactfx.util.Tuple6
- exec(PentaConsumer<? super A, ? super B, ? super C, ? super D, ? super E>) - Method in class org.reactfx.util.Tuple5
- exec(TetraConsumer<? super A, ? super B, ? super C, ? super D>) - Method in class org.reactfx.util.Tuple4
- exec(TriConsumer<? super A, ? super B, ? super C>) - Method in class org.reactfx.util.Tuple3
- expectedFuture - Variable in class org.reactfx.AwaitLatest
- Experimental - Annotation Type in org.reactfx.util
-
Used to annotate functionality that is likely to change or be removed in the future.
F
- f - Variable in class org.reactfx.FilterMapStream
- f - Variable in class org.reactfx.MappedStream
- f - Variable in class org.reactfx.value.MappedVal
- failure(Throwable) - Static method in interface org.reactfx.util.Try
- Failure<T> - Class in org.reactfx.util
- Failure(Throwable) - Constructor for class org.reactfx.util.Failure
- feedFrom(EventStream<? extends T>) - Method in interface org.reactfx.EventSink
-
Starts pushing all events emitted by
source
to this event sink. - feedTo(WritableValue<? super T>) - Method in interface org.reactfx.EventStream
-
Starts setting all events emitted by this stream as the value of the given writable value.
- feedTo(EventSink<? super T>) - Method in interface org.reactfx.EventStream
-
Starts pushing all events emitted by this stream to the given event sink.
- fetch() - Method in class org.reactfx.collection.ListChangeAccumulator
- filter(Class<U>) - Method in interface org.reactfx.EventStream
-
Filters this event stream by the runtime type of the values.
- filter(Predicate<? super T>) - Method in interface org.reactfx.EventStream
-
Returns a new event stream that emits events emitted from this stream that satisfy the given predicate.
- filter(Predicate<? super T>) - Method in interface org.reactfx.value.Val
- filter(ObservableValue<T>, Predicate<? super T>) - Static method in interface org.reactfx.value.Val
- filterMap(Function<? super T, Optional<U>>) - Method in interface org.reactfx.EventStream
-
Equivalent to
- filterMap(Predicate<? super T>, Function<? super T, ? extends U>) - Method in interface org.reactfx.EventStream
-
A more efficient equivalent to
filter(predicate).map(f)
. - FilterMapStream<T,U> - Class in org.reactfx
- FilterMapStream(EventStream<T>, Predicate<? super T>, Function<? super T, ? extends U>) - Constructor for class org.reactfx.FilterMapStream
- FilterStream<T> - Class in org.reactfx
- FilterStream(EventStream<T>, Predicate<? super T>) - Constructor for class org.reactfx.FilterStream
- FingerTree<T,S> - Class in org.reactfx.util
- FingerTree(ToSemigroup<? super T, S>) - Constructor for class org.reactfx.util.FingerTree
- FingerTree.Branch<T,S> - Class in org.reactfx.util
- FingerTree.Empty<T,S> - Class in org.reactfx.util
- FingerTree.Leaf<T,S> - Class in org.reactfx.util
- FingerTree.NonEmptyFingerTree<T,S> - Class in org.reactfx.util
- fireContentReplacement(List<E>) - Method in interface org.reactfx.collection.ProperLiveList
- fireElemInsertion(int) - Method in interface org.reactfx.collection.ProperLiveList
- fireElemRemoval(int, E) - Method in interface org.reactfx.collection.ProperLiveList
- fireElemReplacement(int, E) - Method in interface org.reactfx.collection.ProperLiveList
- fireModification(QuasiListModification<? extends E>) - Method in interface org.reactfx.collection.ProperLiveList
- fireOnRelease - Variable in class org.reactfx.inhibeans.binding.BooleanBinding
-
Deprecated.
- fireOnRelease - Variable in class org.reactfx.inhibeans.binding.DoubleBinding
-
Deprecated.
- fireOnRelease - Variable in class org.reactfx.inhibeans.binding.FloatBinding
-
Deprecated.
- fireOnRelease - Variable in class org.reactfx.inhibeans.binding.IntegerBinding
-
Deprecated.
- fireOnRelease - Variable in class org.reactfx.inhibeans.binding.LongBinding
-
Deprecated.
- fireOnRelease - Variable in class org.reactfx.inhibeans.binding.ObjectBinding
-
Deprecated.
- fireOnRelease - Variable in class org.reactfx.inhibeans.binding.StringBinding
-
Deprecated.
- fireOnRelease - Variable in class org.reactfx.inhibeans.property.BooleanPropertyBase
-
Deprecated.
- fireOnRelease - Variable in class org.reactfx.inhibeans.property.DoublePropertyBase
-
Deprecated.
- fireOnRelease - Variable in class org.reactfx.inhibeans.property.FloatPropertyBase
-
Deprecated.
- fireOnRelease - Variable in class org.reactfx.inhibeans.property.IntegerPropertyBase
-
Deprecated.
- fireOnRelease - Variable in class org.reactfx.inhibeans.property.LongPropertyBase
-
Deprecated.
- fireOnRelease - Variable in class org.reactfx.inhibeans.property.ObjectPropertyBase
-
Deprecated.
- fireOnRelease - Variable in class org.reactfx.inhibeans.property.ReadOnlyBooleanPropertyBase
-
Deprecated.
- fireOnRelease - Variable in class org.reactfx.inhibeans.property.ReadOnlyBooleanWrapper
-
Deprecated.
- fireOnRelease - Variable in class org.reactfx.inhibeans.property.ReadOnlyDoublePropertyBase
-
Deprecated.
- fireOnRelease - Variable in class org.reactfx.inhibeans.property.ReadOnlyDoubleWrapper
-
Deprecated.
- fireOnRelease - Variable in class org.reactfx.inhibeans.property.ReadOnlyFloatPropertyBase
-
Deprecated.
- fireOnRelease - Variable in class org.reactfx.inhibeans.property.ReadOnlyFloatWrapper
-
Deprecated.
- fireOnRelease - Variable in class org.reactfx.inhibeans.property.ReadOnlyIntegerPropertyBase
-
Deprecated.
- fireOnRelease - Variable in class org.reactfx.inhibeans.property.ReadOnlyIntegerWrapper
-
Deprecated.
- fireOnRelease - Variable in class org.reactfx.inhibeans.property.ReadOnlyLongPropertyBase
-
Deprecated.
- fireOnRelease - Variable in class org.reactfx.inhibeans.property.ReadOnlyLongWrapper
-
Deprecated.
- fireOnRelease - Variable in class org.reactfx.inhibeans.property.ReadOnlyObjectPropertyBase
-
Deprecated.
- fireOnRelease - Variable in class org.reactfx.inhibeans.property.ReadOnlyObjectWrapper
-
Deprecated.
- fireOnRelease - Variable in class org.reactfx.inhibeans.property.ReadOnlyStringPropertyBase
-
Deprecated.
- fireOnRelease - Variable in class org.reactfx.inhibeans.property.ReadOnlyStringWrapper
-
Deprecated.
- fireOnRelease - Variable in class org.reactfx.inhibeans.property.SimpleBooleanProperty
-
Deprecated.
- fireOnRelease - Variable in class org.reactfx.inhibeans.property.SimpleDoubleProperty
-
Deprecated.
- fireOnRelease - Variable in class org.reactfx.inhibeans.property.SimpleFloatProperty
-
Deprecated.
- fireOnRelease - Variable in class org.reactfx.inhibeans.property.SimpleIntegerProperty
-
Deprecated.
- fireOnRelease - Variable in class org.reactfx.inhibeans.property.SimpleLongProperty
-
Deprecated.
- fireOnRelease - Variable in class org.reactfx.inhibeans.property.SimpleObjectProperty
-
Deprecated.
- fireOnRelease - Variable in class org.reactfx.inhibeans.property.SimpleStringProperty
-
Deprecated.
- fireOnRelease - Variable in class org.reactfx.inhibeans.property.StringPropertyBase
-
Deprecated.
- fireOnRelease - Variable in class org.reactfx.inhibeans.value.ObservableValueBase
-
Deprecated.
- fireRangeInsertion(int, int) - Method in interface org.reactfx.collection.ProperLiveList
- fireRemoveRange(int, List<E>) - Method in interface org.reactfx.collection.ProperLiveList
- fireValueChangedEvent() - Method in class org.reactfx.inhibeans.property.BooleanPropertyBase
-
Deprecated.
- fireValueChangedEvent() - Method in class org.reactfx.inhibeans.property.DoublePropertyBase
-
Deprecated.
- fireValueChangedEvent() - Method in class org.reactfx.inhibeans.property.FloatPropertyBase
-
Deprecated.
- fireValueChangedEvent() - Method in class org.reactfx.inhibeans.property.IntegerPropertyBase
-
Deprecated.
- fireValueChangedEvent() - Method in class org.reactfx.inhibeans.property.LongPropertyBase
-
Deprecated.
- fireValueChangedEvent() - Method in class org.reactfx.inhibeans.property.ObjectPropertyBase
-
Deprecated.
- fireValueChangedEvent() - Method in class org.reactfx.inhibeans.property.ReadOnlyBooleanPropertyBase
-
Deprecated.
- fireValueChangedEvent() - Method in class org.reactfx.inhibeans.property.ReadOnlyBooleanWrapper
-
Deprecated.
- fireValueChangedEvent() - Method in class org.reactfx.inhibeans.property.ReadOnlyDoublePropertyBase
-
Deprecated.
- fireValueChangedEvent() - Method in class org.reactfx.inhibeans.property.ReadOnlyDoubleWrapper
-
Deprecated.
- fireValueChangedEvent() - Method in class org.reactfx.inhibeans.property.ReadOnlyFloatPropertyBase
-
Deprecated.
- fireValueChangedEvent() - Method in class org.reactfx.inhibeans.property.ReadOnlyFloatWrapper
-
Deprecated.
- fireValueChangedEvent() - Method in class org.reactfx.inhibeans.property.ReadOnlyIntegerPropertyBase
-
Deprecated.
- fireValueChangedEvent() - Method in class org.reactfx.inhibeans.property.ReadOnlyIntegerWrapper
-
Deprecated.
- fireValueChangedEvent() - Method in class org.reactfx.inhibeans.property.ReadOnlyLongPropertyBase
-
Deprecated.
- fireValueChangedEvent() - Method in class org.reactfx.inhibeans.property.ReadOnlyLongWrapper
-
Deprecated.
- fireValueChangedEvent() - Method in class org.reactfx.inhibeans.property.ReadOnlyObjectPropertyBase
-
Deprecated.
- fireValueChangedEvent() - Method in class org.reactfx.inhibeans.property.ReadOnlyObjectWrapper
-
Deprecated.
- fireValueChangedEvent() - Method in class org.reactfx.inhibeans.property.ReadOnlyStringPropertyBase
-
Deprecated.
- fireValueChangedEvent() - Method in class org.reactfx.inhibeans.property.ReadOnlyStringWrapper
-
Deprecated.
- fireValueChangedEvent() - Method in class org.reactfx.inhibeans.property.SimpleBooleanProperty
-
Deprecated.
- fireValueChangedEvent() - Method in class org.reactfx.inhibeans.property.SimpleDoubleProperty
-
Deprecated.
- fireValueChangedEvent() - Method in class org.reactfx.inhibeans.property.SimpleFloatProperty
-
Deprecated.
- fireValueChangedEvent() - Method in class org.reactfx.inhibeans.property.SimpleIntegerProperty
-
Deprecated.
- fireValueChangedEvent() - Method in class org.reactfx.inhibeans.property.SimpleLongProperty
-
Deprecated.
- fireValueChangedEvent() - Method in class org.reactfx.inhibeans.property.SimpleObjectProperty
-
Deprecated.
- fireValueChangedEvent() - Method in class org.reactfx.inhibeans.property.SimpleStringProperty
-
Deprecated.
- fireValueChangedEvent() - Method in class org.reactfx.inhibeans.property.StringPropertyBase
-
Deprecated.
- fireValueChangedEvent() - Method in class org.reactfx.inhibeans.value.ObservableValueBase
-
Deprecated.
- first - Variable in class org.reactfx.LatestNStream
- first - Variable in class org.reactfx.util.ConcatView
- firstObserver - Variable in class org.reactfx.DefaultEventStream
- flatMap(Function<? super L, Either<L2, R2>>, Function<? super R, Either<L2, R2>>) - Method in interface org.reactfx.util.Either
- flatMap(Function<? super L, Either<L2, R2>>, Function<? super R, Either<L2, R2>>) - Method in class org.reactfx.util.Left
- flatMap(Function<? super L, Either<L2, R2>>, Function<? super R, Either<L2, R2>>) - Method in class org.reactfx.util.Right
- flatMap(Function<? super T, ? extends ObservableValue<U>>) - Method in interface org.reactfx.value.Val
- flatMap(Function<? super T, ? extends EventStream<U>>) - Method in interface org.reactfx.EventStream
-
Returns a new event stream that, for each event x emitted from this stream, obtains the event stream f(x) and keeps emitting its events until the next event is emitted from this stream.
- flatMap(Function<? super T, Try<U>>) - Method in class org.reactfx.util.Failure
- flatMap(Function<? super T, Try<U>>) - Method in class org.reactfx.util.Success
- flatMap(Function<? super T, Try<U>>) - Method in interface org.reactfx.util.Try
- flatMap(ObservableValue<T>, Function<? super T, ? extends ObservableValue<U>>) - Static method in interface org.reactfx.value.Val
- flatMapLeft(Function<? super L, Either<L2, R>>) - Method in interface org.reactfx.util.Either
- flatMapLeft(Function<? super L, Either<L2, R>>) - Method in class org.reactfx.util.Left
- flatMapLeft(Function<? super L, Either<L2, R>>) - Method in class org.reactfx.util.Right
- FlatMapOptStream<T,U> - Class in org.reactfx
- FlatMapOptStream(EventStream<T>, Function<? super T, Optional<U>>) - Constructor for class org.reactfx.FlatMapOptStream
- FlatMapped<T,U,O extends javafx.beans.value.ObservableValue<U>> - Class in org.reactfx.value
- FlatMapped(ObservableValue<T>, Function<? super T, O>) - Constructor for class org.reactfx.value.FlatMapped
- FlatMappedVal<T,U,O extends javafx.beans.value.ObservableValue<U>> - Class in org.reactfx.value
- FlatMappedVal(ObservableValue<T>, Function<? super T, O>) - Constructor for class org.reactfx.value.FlatMappedVal
- FlatMappedVar<T,U,O extends javafx.beans.property.Property<U>> - Class in org.reactfx.value
- FlatMappedVar(ObservableValue<T>, Function<? super T, O>) - Constructor for class org.reactfx.value.FlatMappedVar
- FlatMappedVar(ObservableValue<T>, Function<? super T, O>, Consumer<O>) - Constructor for class org.reactfx.value.FlatMappedVar
- FlatMappedVar(ObservableValue<T>, Function<? super T, O>, U) - Constructor for class org.reactfx.value.FlatMappedVar
- flatMapRight(Function<? super R, Either<L, R2>>) - Method in interface org.reactfx.util.Either
- flatMapRight(Function<? super R, Either<L, R2>>) - Method in class org.reactfx.util.Left
- flatMapRight(Function<? super R, Either<L, R2>>) - Method in class org.reactfx.util.Right
- FlatMapStream<T,U> - Class in org.reactfx
- FlatMapStream(EventStream<T>, Function<? super T, ? extends EventStream<U>>) - Constructor for class org.reactfx.FlatMapStream
- FloatBinding - Class in org.reactfx.inhibeans.binding
-
Deprecated.
- FloatBinding() - Constructor for class org.reactfx.inhibeans.binding.FloatBinding
-
Deprecated.
- FloatPropertyBase - Class in org.reactfx.inhibeans.property
-
Deprecated.
- FloatPropertyBase() - Constructor for class org.reactfx.inhibeans.property.FloatPropertyBase
-
Deprecated.Superclass constructors.
- FloatPropertyBase(float) - Constructor for class org.reactfx.inhibeans.property.FloatPropertyBase
-
Deprecated.
- floatVar(FloatProperty) - Static method in interface org.reactfx.value.Var
-
Converts FloatProperty to
Var<Float>
to help deal with the consequences of FloatProperty not being a subtype ofProperty<Float>
. - fold(R, BiFunction<? super R, ? super T, ? extends R>) - Method in class org.reactfx.util.FingerTree.Branch
- fold(R, BiFunction<? super R, ? super T, ? extends R>) - Method in class org.reactfx.util.FingerTree.Empty
- fold(R, BiFunction<? super R, ? super T, ? extends R>) - Method in class org.reactfx.util.FingerTree
- fold(R, BiFunction<? super R, ? super T, ? extends R>) - Method in class org.reactfx.util.FingerTree.Leaf
- fold(R, BiFunction<? super R, ? super T, ? extends R>) - Method in class org.reactfx.util.LL.Cons
- fold(R, BiFunction<? super R, ? super T, ? extends R>) - Method in class org.reactfx.util.LL
- fold(R, BiFunction<? super R, ? super T, ? extends R>) - Method in class org.reactfx.util.LL.Nil
- foldBetween(R, BiFunction<? super R, ? super T, ? extends R>, int, int) - Method in class org.reactfx.util.FingerTree
- foldBetween(R, BiFunction<? super R, ? super T, ? extends R>, ToIntFunction<? super S>, int, int, TetraFunction<? super R, ? super T, Integer, Integer, ? extends R>) - Method in class org.reactfx.util.FingerTree
- foldBetween0(R, BiFunction<? super R, ? super T, ? extends R>, int, int) - Method in class org.reactfx.util.FingerTree.Branch
- foldBetween0(R, BiFunction<? super R, ? super T, ? extends R>, int, int) - Method in class org.reactfx.util.FingerTree.Empty
- foldBetween0(R, BiFunction<? super R, ? super T, ? extends R>, int, int) - Method in class org.reactfx.util.FingerTree
- foldBetween0(R, BiFunction<? super R, ? super T, ? extends R>, int, int) - Method in class org.reactfx.util.FingerTree.Leaf
- foldBetween0(R, BiFunction<? super R, ? super T, ? extends R>, int, int, LL<? extends FingerTree<T, S>>) - Method in class org.reactfx.util.FingerTree.Branch
- foldBetween0(R, BiFunction<? super R, ? super T, ? extends R>, ToIntFunction<? super S>, int, int, TetraFunction<? super R, ? super T, Integer, Integer, ? extends R>) - Method in class org.reactfx.util.FingerTree.Branch
- foldBetween0(R, BiFunction<? super R, ? super T, ? extends R>, ToIntFunction<? super S>, int, int, TetraFunction<? super R, ? super T, Integer, Integer, ? extends R>) - Method in class org.reactfx.util.FingerTree.Empty
- foldBetween0(R, BiFunction<? super R, ? super T, ? extends R>, ToIntFunction<? super S>, int, int, TetraFunction<? super R, ? super T, Integer, Integer, ? extends R>) - Method in class org.reactfx.util.FingerTree
- foldBetween0(R, BiFunction<? super R, ? super T, ? extends R>, ToIntFunction<? super S>, int, int, TetraFunction<? super R, ? super T, Integer, Integer, ? extends R>) - Method in class org.reactfx.util.FingerTree.Leaf
- foldBetween0(R, BiFunction<? super R, ? super T, ? extends R>, ToIntFunction<? super S>, int, int, TetraFunction<? super R, ? super T, Integer, Integer, ? extends R>, LL<? extends FingerTree<T, S>>) - Method in class org.reactfx.util.FingerTree.Branch
- force(int, int) - Method in interface org.reactfx.collection.MemoizationList
- force(int, int) - Method in class org.reactfx.collection.MemoizationListImpl
- forEach(BiConsumer<K, V>) - Method in class org.reactfx.util.MapHelper
- forEach(BiConsumer<K, V>) - Method in class org.reactfx.util.MapHelper.MultiEntryHelper
- forEach(BiConsumer<K, V>) - Method in class org.reactfx.util.MapHelper.SingleEntryHelper
- forEach(Consumer<? super T>) - Method in class org.reactfx.util.ListHelper
- forEach(Consumer<? super T>) - Method in class org.reactfx.util.ListHelper.MultiElemHelper
- forEach(Consumer<? super T>) - Method in class org.reactfx.util.ListHelper.SingleElemHelper
- forEach(ListHelper<T>, Consumer<? super T>) - Static method in class org.reactfx.util.ListHelper
- forEach(MapHelper<K, V>, BiConsumer<K, V>) - Static method in class org.reactfx.util.MapHelper
- forEachBetween(int, int, Consumer<? super T>) - Method in class org.reactfx.util.ListHelper
- forEachBetween(int, int, Consumer<? super T>) - Method in class org.reactfx.util.ListHelper.MultiElemHelper
- forEachBetween(int, int, Consumer<? super T>) - Method in class org.reactfx.util.ListHelper.SingleElemHelper
- forEachBetween(ListHelper<T>, int, int, Consumer<? super T>) - Static method in class org.reactfx.util.ListHelper
- forEachObserver(Consumer<O>) - Method in class org.reactfx.ObservableBase
-
Executes action for each observer, regardless of recursion state.
- forget(int, int) - Method in interface org.reactfx.collection.MemoizationList
- forget(int, int) - Method in class org.reactfx.collection.MemoizationListImpl
- forgetful() - Method in interface org.reactfx.EventStream
-
Returns a suspendable event stream that, when suspended, forgets all but the latest event emitted by this event stream.
- ForgetfulEventStream<T> - Class in org.reactfx
- ForgetfulEventStream(EventStream<T>) - Constructor for class org.reactfx.ForgetfulEventStream
- fork(Predicate<? super T>) - Method in interface org.reactfx.EventStream
-
Returns two event streams, the first one emitting events of this stream that satisfy the given
test
and the second one emitting events of this stream that do not satisfy the test. - fork(EventStream<? extends Either<L, R>>) - Static method in class org.reactfx.EventStreams
- fraction - Variable in class org.reactfx.value.AnimatedVal
- FractionTransition() - Constructor for class org.reactfx.value.AnimatedVal.FractionTransition
- from - Variable in class org.reactfx.collection.MaterializedListModificationImpl
- from - Variable in class org.reactfx.collection.SubList
- from(ObservableValue<Boolean>, Suspendable) - Static method in interface org.reactfx.Toggle
-
Creates a Toggle view of an observable boolean and a Suspendable whose suspension causes the boolean value to switch.
- from(ListChangeListener.Change<? extends E>) - Static method in interface org.reactfx.collection.QuasiListChange
- fromCurrentStateOf(ListChangeListener.Change<F>) - Static method in interface org.reactfx.collection.QuasiListModification
- fromInt(int) - Static method in enum org.reactfx.util.AccumulatorSize
- fromVal(ObservableValue<T>, Consumer<T>) - Static method in interface org.reactfx.value.Var
-
Creates a Var from ObservableValue, using the given
setValue
function in place of theWritableValue.setValue(Object)
method. - ft - Variable in class org.reactfx.util.ListConcatenation
- FxTimer - Class in org.reactfx.util
-
Provides factory methods for timers that are manipulated from and execute their action on the JavaFX application thread.
- FxTimer(Duration, Duration, Runnable, int) - Constructor for class org.reactfx.util.FxTimer
G
- g1 - Variable in class org.reactfx.BiGuard
- g1 - Variable in class org.reactfx.BiGuardian
- g2 - Variable in class org.reactfx.BiGuard
- g2 - Variable in class org.reactfx.BiGuardian
- get() - Method in class org.reactfx.EventStreams.Pocket
- get() - Method in class org.reactfx.Indicator
-
Deprecated.
- get() - Method in class org.reactfx.SuspendableNo
- get() - Method in class org.reactfx.SuspendableYes
- get() - Static method in interface org.reactfx.util.Interpolator
- get() - Method in interface org.reactfx.util.Try
- get(int) - Method in class org.reactfx.collection.DynamicallyMappedList
- get(int) - Method in class org.reactfx.collection.LiveArrayList
- get(int) - Method in class org.reactfx.collection.MappedList
- get(int) - Method in class org.reactfx.collection.MemoizationListImpl
- get(int) - Method in class org.reactfx.collection.MemoizationListImpl.MemoizedView
- get(int) - Method in class org.reactfx.collection.SubList
- get(int) - Method in class org.reactfx.collection.SuspendableListWrapper
- get(int) - Method in class org.reactfx.collection.ValAsList
- get(int) - Method in class org.reactfx.util.ConcatView
- get(int) - Method in class org.reactfx.util.ListConcatenation
- get(int) - Method in class org.reactfx.util.ListHelper
- get(int) - Method in class org.reactfx.util.ListHelper.MultiElemHelper
- get(int) - Method in class org.reactfx.util.ListHelper.SingleElemHelper
- get(int) - Method in class org.reactfx.util.SparseList.AbsentSegment
- get(int) - Method in class org.reactfx.util.SparseList
- get(int) - Method in class org.reactfx.util.SparseList.PresentSegment
- get(int) - Method in interface org.reactfx.util.SparseList.Segment
- get(ToIntFunction<? super S>, int) - Method in class org.reactfx.util.FingerTree
- get(ToIntFunction<? super S>, int, BiFunction<? super T, Integer, ? extends E>) - Method in class org.reactfx.util.FingerTree
- get(K) - Method in class org.reactfx.util.MapHelper
- get(K) - Method in class org.reactfx.util.MapHelper.MultiEntryHelper
- get(K) - Method in class org.reactfx.util.MapHelper.SingleEntryHelper
- get(ListHelper<T>, int) - Static method in class org.reactfx.util.ListHelper
- get(MapHelper<K, V>, K) - Static method in class org.reactfx.util.MapHelper
- get1() - Method in class org.reactfx.util.Tuple2
- get1() - Method in class org.reactfx.util.Tuple3
- get1() - Method in class org.reactfx.util.Tuple4
- get1() - Method in class org.reactfx.util.Tuple5
- get1() - Method in class org.reactfx.util.Tuple6
- get2() - Method in class org.reactfx.util.Tuple2
- get2() - Method in class org.reactfx.util.Tuple3
- get2() - Method in class org.reactfx.util.Tuple4
- get2() - Method in class org.reactfx.util.Tuple5
- get2() - Method in class org.reactfx.util.Tuple6
- get3() - Method in class org.reactfx.util.Tuple3
- get3() - Method in class org.reactfx.util.Tuple4
- get3() - Method in class org.reactfx.util.Tuple5
- get3() - Method in class org.reactfx.util.Tuple6
- get4() - Method in class org.reactfx.util.Tuple4
- get4() - Method in class org.reactfx.util.Tuple5
- get4() - Method in class org.reactfx.util.Tuple6
- get5() - Method in class org.reactfx.util.Tuple5
- get5() - Method in class org.reactfx.util.Tuple6
- get6() - Method in class org.reactfx.util.Tuple6
- getAccumulationFacility() - Method in interface org.reactfx.util.NotificationAccumulator
- getAccumulationFacility() - Method in class org.reactfx.util.NotificationAccumulatorBase
- getAdded() - Method in interface org.reactfx.collection.MaterializedListModification
- getAdded() - Method in class org.reactfx.collection.MaterializedListModificationImpl
- getAddedSize() - Method in class org.reactfx.collection.ListModificationImpl
- getAddedSize() - Method in interface org.reactfx.collection.ListModificationLike
-
Returns the number of items added by this change.
- getAddedSize() - Method in interface org.reactfx.collection.MaterializedListModification
- getAddedSize() - Method in class org.reactfx.collection.QuasiListModificationImpl
- getAddedSubList() - Method in interface org.reactfx.collection.ListModification
- getAddedSubList() - Method in class org.reactfx.collection.ListModificationImpl
- getAndClear() - Method in class org.reactfx.EventStreams.Pocket
- getBean() - Method in interface org.reactfx.value.Var
- getData() - Method in class org.reactfx.util.FingerTree.Branch
- getData() - Method in class org.reactfx.util.FingerTree.Empty
- getData() - Method in class org.reactfx.util.FingerTree
- getData() - Method in class org.reactfx.util.FingerTree.Leaf
- getDelegate() - Method in class org.reactfx.value.ValWrapper
- getDependencies() - Method in class org.reactfx.StreamBinding
- getDepth() - Method in class org.reactfx.util.FingerTree.Branch
- getDepth() - Method in class org.reactfx.util.FingerTree.Empty
- getDepth() - Method in class org.reactfx.util.FingerTree
- getDepth() - Method in class org.reactfx.util.FingerTree.Leaf
- getDepth() - Method in class org.reactfx.util.SparseList
-
For testing only.
- getFailure() - Method in interface org.reactfx.util.Try
- getFrom() - Method in class org.reactfx.collection.ListModificationImpl
- getFrom() - Method in interface org.reactfx.collection.ListModificationLike
-
Returns the position in the list where this change occurred.
- getFrom() - Method in class org.reactfx.collection.MaterializedListModificationImpl
- getFrom() - Method in class org.reactfx.collection.QuasiListModificationImpl
- getFrom(int) - Method in class org.reactfx.collection.ListRangeReduction
- getFrom(int) - Method in class org.reactfx.collection.ListReduction
- getIfMemoized(int) - Method in interface org.reactfx.collection.MemoizationList
- getIfMemoized(int) - Method in class org.reactfx.collection.MemoizationListImpl
- getLeaf(int) - Method in class org.reactfx.util.FingerTree
- getLeaf0(int) - Method in class org.reactfx.util.FingerTree.Branch
- getLeaf0(int) - Method in class org.reactfx.util.FingerTree.Empty
- getLeaf0(int) - Method in class org.reactfx.util.FingerTree
- getLeaf0(int) - Method in class org.reactfx.util.FingerTree.Leaf
- getLeaf0(int, LL<? extends FingerTree<T, S>>) - Method in class org.reactfx.util.FingerTree.Branch
- getLeafCount() - Method in class org.reactfx.util.FingerTree.Branch
- getLeafCount() - Method in class org.reactfx.util.FingerTree.Empty
- getLeafCount() - Method in class org.reactfx.util.FingerTree
- getLeafCount() - Method in class org.reactfx.util.FingerTree.Leaf
- getLeft() - Method in interface org.reactfx.util.Either
- getLeft() - Method in class org.reactfx.util.Left
- getLeft() - Method in class org.reactfx.util.Right
- getLength() - Method in class org.reactfx.util.SparseList.AbsentSegment
- getLength() - Method in class org.reactfx.util.SparseList.PresentSegment
- getLength() - Method in interface org.reactfx.util.SparseList.Segment
- getMemoizedCount() - Method in interface org.reactfx.collection.MemoizationList
- getMemoizedCount() - Method in class org.reactfx.collection.MemoizationListImpl
- getMemoizedCountAfter(int) - Method in interface org.reactfx.collection.MemoizationList
- getMemoizedCountAfter(int) - Method in class org.reactfx.collection.MemoizationListImpl
- getMemoizedCountBefore(int) - Method in interface org.reactfx.collection.MemoizationList
- getMemoizedCountBefore(int) - Method in class org.reactfx.collection.MemoizationListImpl
- getMemoizedItemsRange() - Method in interface org.reactfx.collection.MemoizationList
- getMemoizedItemsRange() - Method in class org.reactfx.collection.MemoizationListImpl
- getModificationCount() - Method in interface org.reactfx.collection.AbstractListModificationSequence
- getModifications() - Method in interface org.reactfx.collection.AbstractListModificationSequence
- getModifications() - Method in class org.reactfx.collection.ListChangeAccumulator
- getModifications() - Method in class org.reactfx.collection.QuasiListChangeImpl
- getName() - Method in interface org.reactfx.value.Var
- getNewValue() - Method in class org.reactfx.Change
- getObserverCount() - Method in class org.reactfx.ObservableBase
- getOldValue() - Method in class org.reactfx.Change
- getOpt() - Method in interface org.reactfx.value.Val
- getOrElse(Supplier<T>) - Method in class org.reactfx.util.Failure
- getOrElse(Supplier<T>) - Method in class org.reactfx.util.Success
- getOrElse(Supplier<T>) - Method in interface org.reactfx.util.Try
- getOrElse(T) - Method in class org.reactfx.util.Failure
- getOrElse(T) - Method in class org.reactfx.util.Success
- getOrElse(T) - Method in interface org.reactfx.util.Try
- getOrElse(T) - Method in interface org.reactfx.value.Val
-
Returns the value currently held by this Val.
- getOrSupply(Supplier<? extends T>) - Method in interface org.reactfx.value.Val
-
Like
Val.getOrElse(Object)
, except the default value is computed bydefaultSupplier
only when necessary. - getOrThrow() - Method in interface org.reactfx.value.Val
-
Returns the value currently held by this Val.
- getOrThrow(int) - Method in class org.reactfx.util.SparseList.AbsentSegment
- getOrThrow(int) - Method in class org.reactfx.util.SparseList
- getOrThrow(int) - Method in class org.reactfx.util.SparseList.PresentSegment
- getOrThrow(int) - Method in interface org.reactfx.util.SparseList.Segment
- getPresent(int) - Method in class org.reactfx.util.SparseList
- getPresentCount() - Method in class org.reactfx.util.SparseList.AbsentSegment
- getPresentCount() - Method in class org.reactfx.util.SparseList
- getPresentCount() - Method in class org.reactfx.util.SparseList.PresentSegment
- getPresentCount() - Method in interface org.reactfx.util.SparseList.Segment
- getPresentCount() - Method in class org.reactfx.util.SparseList.Stats
- getPresentCountAfter(int) - Method in class org.reactfx.util.SparseList
- getPresentCountBefore(int) - Method in class org.reactfx.util.SparseList
- getPresentCountBetween(int, int) - Method in class org.reactfx.util.SparseList.AbsentSegment
- getPresentCountBetween(int, int) - Method in class org.reactfx.util.SparseList
- getPresentCountBetween(int, int) - Method in class org.reactfx.util.SparseList.PresentSegment
- getPresentCountBetween(int, int) - Method in interface org.reactfx.util.SparseList.Segment
- getPresentItemsRange() - Method in class org.reactfx.util.SparseList
- getRemoved() - Method in class org.reactfx.collection.ListModificationImpl
- getRemoved() - Method in interface org.reactfx.collection.ListModificationLike
-
Returns an immutable list of elements removed by this change.
- getRemoved() - Method in class org.reactfx.collection.MaterializedListModificationImpl
- getRemoved() - Method in class org.reactfx.collection.QuasiListModificationImpl
- getRemovedSize() - Method in interface org.reactfx.collection.ListModificationLike
-
Returns the number of items removed by this change.
- getRight() - Method in interface org.reactfx.util.Either
- getRight() - Method in class org.reactfx.util.Left
- getRight() - Method in class org.reactfx.util.Right
- getSize() - Method in class org.reactfx.util.SparseList.Stats
- getStatsBetween(int, int) - Method in interface org.reactfx.util.SparseList.Segment
- getSummary() - Method in class org.reactfx.util.FingerTree.Branch
- getSummary() - Method in class org.reactfx.util.FingerTree.Leaf
- getSummary() - Method in class org.reactfx.util.FingerTree.NonEmptyFingerTree
- getSummary(S) - Method in class org.reactfx.util.FingerTree
- getSummaryBetween(int, int) - Method in class org.reactfx.util.FingerTree
- getSummaryBetween(ToIntFunction<? super S>, int, int, TriFunction<? super T, Integer, Integer, ? extends S>) - Method in class org.reactfx.util.FingerTree
- getSummaryBetween0(int, int) - Method in class org.reactfx.util.FingerTree.Branch
- getSummaryBetween0(int, int) - Method in class org.reactfx.util.FingerTree.Empty
- getSummaryBetween0(int, int) - Method in class org.reactfx.util.FingerTree
- getSummaryBetween0(int, int) - Method in class org.reactfx.util.FingerTree.Leaf
- getSummaryBetween0(int, int, LL<? extends FingerTree<T, S>>) - Method in class org.reactfx.util.FingerTree.Branch
- getSummaryBetween0(ToIntFunction<? super S>, int, int, TriFunction<? super T, Integer, Integer, ? extends S>) - Method in class org.reactfx.util.FingerTree.Branch
- getSummaryBetween0(ToIntFunction<? super S>, int, int, TriFunction<? super T, Integer, Integer, ? extends S>) - Method in class org.reactfx.util.FingerTree.Empty
- getSummaryBetween0(ToIntFunction<? super S>, int, int, TriFunction<? super T, Integer, Integer, ? extends S>) - Method in class org.reactfx.util.FingerTree
- getSummaryBetween0(ToIntFunction<? super S>, int, int, TriFunction<? super T, Integer, Integer, ? extends S>) - Method in class org.reactfx.util.FingerTree.Leaf
- getSummaryBetween0(ToIntFunction<? super S>, int, int, TriFunction<? super T, Integer, Integer, ? extends S>, LL<? extends FingerTree<T, S>>) - Method in class org.reactfx.util.FingerTree.Branch
- getSummaryOpt() - Method in class org.reactfx.util.FingerTree.Branch
- getSummaryOpt() - Method in class org.reactfx.util.FingerTree.Empty
- getSummaryOpt() - Method in class org.reactfx.util.FingerTree
- getSummaryOpt() - Method in class org.reactfx.util.FingerTree.Leaf
- getSuspendable() - Method in interface org.reactfx.Suspender
- getSuspendable() - Method in class org.reactfx.SuspenderBase
- getTo() - Method in interface org.reactfx.collection.ListModificationLike
-
Returns the end position of the change in the modified list.
- getTo(int) - Method in class org.reactfx.collection.ListRangeReduction
- getTo(int) - Method in class org.reactfx.collection.ListReduction
- getTree() - Method in class org.reactfx.util.SparseList
-
For testing only.
- getUnderlyingObservable() - Method in class org.reactfx.ProxyObservable
- getValue() - Method in class org.reactfx.Indicator
-
Deprecated.
- getValue() - Method in class org.reactfx.StreamBinding
- getValue() - Method in class org.reactfx.ToggleFromVal
- getValue() - Method in class org.reactfx.value.ConstVal
- getValue() - Method in class org.reactfx.value.SuspendableValWrapper
- getValue() - Method in class org.reactfx.value.ValBase
- getValue() - Method in class org.reactfx.value.VarFromVal
- getWrappedValue() - Method in class org.reactfx.util.WrapperBase
- guard() - Method in class org.reactfx.BiGuardian
- guard() - Method in interface org.reactfx.Guardian
-
Deprecated.
- guard() - Method in class org.reactfx.Indicator
-
Deprecated.Equivalent to
Indicator.on()
. - guard() - Method in interface org.reactfx.inhibeans.Observable
-
Deprecated.Equivalent to
Observable.block()
. - guard() - Method in class org.reactfx.MultiGuardian
- Guard - Interface in org.reactfx
- guardedBy(Guardian...) - Method in interface org.reactfx.EventStream
-
Deprecated.Use
EventStream.suspenderOf(Suspendable)
instead. - Guardian - Interface in org.reactfx
-
Deprecated.superseded by
Suspendable
. - guardians - Variable in class org.reactfx.MultiGuardian
- guards - Variable in class org.reactfx.MultiGuard
- guardWhile(Runnable) - Method in interface org.reactfx.Guardian
-
Deprecated.
- guardWhile(Supplier<T>) - Method in interface org.reactfx.Guardian
-
Deprecated.
H
- handleEmission(Function<S, Optional<O>>) - Method in class org.reactfx.StatefulStream
- handleEvent(I) - Method in class org.reactfx.SuccessionReducingStream
- handleEvent(T) - Method in class org.reactfx.AccumulateBetweenStream
- handleEvent(T) - Method in class org.reactfx.AccumulateUntilLaterStream
- handleEvent(T) - Method in class org.reactfx.SuspendableBase
- handleEvent(T) - Method in class org.reactfx.ThenAccumulateForStream
- handleTick(Object) - Method in class org.reactfx.AccumulateBetweenStream
- handleTimeout() - Method in class org.reactfx.SuccessionReducingStream
- handleTimeout() - Method in class org.reactfx.ThenAccumulateForStream
- handleTransition(Function<S, S>) - Method in class org.reactfx.StatefulStream
- handleTransition(Function<S, S>) - Method in class org.reactfx.StateStream
- handleTransmission(Function<S, Tuple2<S, Optional<O>>>) - Method in class org.reactfx.StatefulStream
- hasEvent - Variable in class org.reactfx.AccumulatingStream
- hasEvent - Variable in class org.reactfx.SuccessionReducingStream
- HashAccuMap<K,V,A> - Class in org.reactfx.util
- HashAccuMap() - Constructor for class org.reactfx.util.HashAccuMap
- hashCode() - Method in class org.reactfx.ObservableBase
- hashCode() - Method in class org.reactfx.util.Left
- hashCode() - Method in class org.reactfx.util.Right
- hashCode() - Method in class org.reactfx.util.Tuple2
- hashCode() - Method in class org.reactfx.util.Tuple3
- hashCode() - Method in class org.reactfx.util.Tuple4
- hashCode() - Method in class org.reactfx.util.Tuple5
- hashCode() - Method in class org.reactfx.util.Tuple6
- hashCode() - Method in class org.reactfx.util.WrapperBase
- hashCode(List<E>) - Static method in class org.reactfx.util.Lists
- hasNext() - Method in class org.reactfx.collection.ListIteratorImpl
- hasPrevious() - Method in class org.reactfx.collection.ListIteratorImpl
- hasValue - Variable in class org.reactfx.AccumulateBetweenStream
- hasValue - Variable in class org.reactfx.AccumulateUntilLaterStream
- hasValue - Variable in class org.reactfx.EmitBothOnEachStream
- hasValue - Variable in class org.reactfx.EmitOnEachStream
- hasValue - Variable in class org.reactfx.EmitOnStream
- hasValue - Variable in class org.reactfx.EventStreams.Pocket
- hasValue - Variable in class org.reactfx.RepeatOnStream
- hasValue - Variable in class org.reactfx.SuspendableBase
- hasValue() - Method in class org.reactfx.EventStreams.Pocket
- head - Variable in class org.reactfx.AccumulativeEventStream
- head - Variable in class org.reactfx.util.AccumulativeStreamNotifications
- head - Variable in class org.reactfx.util.LL.Cons
- head() - Method in class org.reactfx.util.LL.Cons
- head() - Method in class org.reactfx.util.LL
- head() - Method in class org.reactfx.util.LL.Nil
- head(Consumer<? super T>, A) - Method in class org.reactfx.util.AccumulativeStreamNotifications
- head(Consumer<? super T>, Deque<T>) - Method in class org.reactfx.util.QueuingStreamNotifications
- head(Consumer<? super T>, T) - Method in class org.reactfx.util.AbstractReducingStreamNotifications
- head(Consumer<? super T>, T) - Method in class org.reactfx.util.NonAccumulativeStreamNotifications
- head(O, A) - Method in class org.reactfx.util.NotificationAccumulatorBase
- head(LiveList.Observer<? super E, ?>, ListModificationSequence<E>) - Method in class org.reactfx.util.ListNotifications
- headOf(A) - Method in class org.reactfx.AccumulativeEventStream
- headOf(A) - Method in class org.reactfx.SuspendableBase
- headOf(Deque<T>) - Method in class org.reactfx.PausableEventStream
- headOf(ListModificationSequence<? extends E>) - Method in interface org.reactfx.collection.LiveList.Observer
- headOf(ListModificationSequence<? extends E>) - Method in interface org.reactfx.collection.LiveList.QuasiChangeObserver
- headOf(ListModificationSequence<? extends E>) - Method in interface org.reactfx.collection.LiveList.QuasiModificationObserver
- headOf(ListModificationSequence<E>) - Method in class org.reactfx.collection.SuspendableListWrapper
- headOf(T) - Method in class org.reactfx.AbstractReducibleEventStream
- headOf(T) - Method in class org.reactfx.SuppressibleEventStream
- headOf(T) - Method in class org.reactfx.value.SuspendableValWrapper
- helper - Variable in class org.reactfx.inhibeans.binding.BooleanBinding
-
Deprecated.
- helper - Variable in class org.reactfx.inhibeans.binding.DoubleBinding
-
Deprecated.
- helper - Variable in class org.reactfx.inhibeans.binding.FloatBinding
-
Deprecated.
- helper - Variable in class org.reactfx.inhibeans.binding.IntegerBinding
-
Deprecated.
- helper - Variable in class org.reactfx.inhibeans.binding.LongBinding
-
Deprecated.
- helper - Variable in class org.reactfx.inhibeans.binding.ObjectBinding
-
Deprecated.
- helper - Variable in class org.reactfx.inhibeans.binding.StringBinding
-
Deprecated.
- HexaConsumer<A,B,C,D,E,F> - Interface in org.reactfx.util
- HexaFunction<A,B,C,D,E,F,R> - Interface in org.reactfx.util
- HexaPredicate<A,B,C,D,E,F> - Interface in org.reactfx.util
- hook(Consumer<? super T>) - Method in interface org.reactfx.EventStream
-
Returns an event stream that emits the same(*) events as this stream, but before emitting each event performs the given side effect.
- HookStream<T> - Class in org.reactfx
- HookStream(EventStream<T>, Consumer<? super T>) - Constructor for class org.reactfx.HookStream
I
- ifFailure(Consumer<? super Throwable>) - Method in interface org.reactfx.util.Try
- ifLeft(Consumer<? super L>) - Method in interface org.reactfx.util.Either
- ifLeft(Consumer<? super L>) - Method in class org.reactfx.util.Left
- ifLeft(Consumer<? super L>) - Method in class org.reactfx.util.Right
- ifPresent(Consumer<? super T>) - Method in interface org.reactfx.value.Val
-
Invokes the given function if this Val holds a (non-null) value.
- ifRight(Consumer<? super R>) - Method in interface org.reactfx.util.Either
- ifRight(Consumer<? super R>) - Method in class org.reactfx.util.Left
- ifRight(Consumer<? super R>) - Method in class org.reactfx.util.Right
- ifSuccess(Consumer<? super T>) - Method in interface org.reactfx.util.Try
- iListeners - Variable in class org.reactfx.Indicator
-
Deprecated.
- impulse - Variable in class org.reactfx.EmitBothOnEachStream
- impulse - Variable in class org.reactfx.EmitOnEachStream
- impulse - Variable in class org.reactfx.EmitOnStream
- impulse - Variable in class org.reactfx.RepeatOnStream
- indexOf(Object) - Method in interface org.reactfx.collection.AccessorListMethods
- indexOf(Object) - Method in class org.reactfx.collection.SuspendableListWrapper
- indexOfMemoizedItem(int) - Method in interface org.reactfx.collection.MemoizationList
- indexOfMemoizedItem(int) - Method in class org.reactfx.collection.MemoizationListImpl
- indexOfPresentItem(int) - Method in class org.reactfx.util.SparseList
- Indicator - Class in org.reactfx
-
Deprecated.Indicator is unsafe on recursion: it may report misleading changes. Use
SuspendableNo
instead. - Indicator() - Constructor for class org.reactfx.Indicator
-
Deprecated.
- init(S) - Static method in class org.reactfx.StateMachine
- initial - Variable in class org.reactfx.DefaultEventStream
- initial - Variable in class org.reactfx.SuccessionReducingStream
- initial - Variable in class org.reactfx.ThenAccumulateForStream
- initialAccumulator(QuasiListChange<? extends E>) - Method in interface org.reactfx.util.AccumulationFacility.ListChangeAccumulation
- initialAccumulator(T) - Method in class org.reactfx.SuppressibleEventStream
- initialAccumulator(T) - Method in class org.reactfx.SuspendableBase
- initialAccumulator(T) - Method in interface org.reactfx.util.AccumulationFacility.HomotypicAccumulation
- initialAccumulator(T) - Method in interface org.reactfx.util.AccumulationFacility
- initialAccumulator(T) - Method in interface org.reactfx.util.AccumulationFacility.Queuing
- initialAccumulator(T) - Method in class org.reactfx.util.AccumulativeStreamNotifications
- initialState - Variable in class org.reactfx.InitialStateImpl
- initialState - Variable in class org.reactfx.ObservableStateBuilderImpl
- initialState - Variable in class org.reactfx.ObservableStateBuilderOnImpl
- initialState - Variable in class org.reactfx.StatefulStreamBuilderImpl
- initialState - Variable in class org.reactfx.StatefulStreamBuilderOnImpl
- InitialStateImpl<S> - Class in org.reactfx
- InitialStateImpl(S) - Constructor for class org.reactfx.InitialStateImpl
- initialTransformation - Variable in class org.reactfx.AccumulateBetweenStream
- initialTransformation - Variable in class org.reactfx.AccumulateUntilLaterStream
- initialTransformation - Variable in class org.reactfx.AccumulatingStream
- initialTransformation - Variable in class org.reactfx.util.AccumulativeStreamNotifications
- input - Variable in class org.reactfx.AccumulatingStream
- input - Variable in class org.reactfx.collection.ListReduction
- input - Variable in class org.reactfx.DefaultEventStream
- input - Variable in class org.reactfx.DistinctStream
- input - Variable in class org.reactfx.MappedStream
- input - Variable in class org.reactfx.ObservableStateBuilderOnImpl
- input - Variable in class org.reactfx.RecursiveStream
- input - Variable in class org.reactfx.StatefulStreamBuilderOnImpl
- input - Variable in class org.reactfx.SuccessionReducingStream
- input - Variable in class org.reactfx.SuspendableBase
- input - Variable in class org.reactfx.ThenAccumulateForStream
- input - Variable in class org.reactfx.ThreadBridge
- InputHandler - Interface in org.reactfx
- InputHandlerBuilder<S,TGT> - Class in org.reactfx
- InputHandlerBuilder(EventStream<I>, BiFunction<? super S, ? super I, ? extends TGT>) - Constructor for class org.reactfx.InputHandlerBuilder
- inputHandlers - Variable in class org.reactfx.StatefulStream
- inputHandlers - Variable in class org.reactfx.StateStream
- inputSubscriberProvider - Variable in class org.reactfx.InputHandlerBuilder
- inputSubscription - Variable in class org.reactfx.ObservableBase
- insert(int, E) - Method in class org.reactfx.util.SparseList
- insertAll(int, Collection<? extends E>) - Method in class org.reactfx.util.SparseList
- insertLeaf(int, T) - Method in class org.reactfx.util.FingerTree
- insertVoid(int, int) - Method in class org.reactfx.util.SparseList
- instance() - Static method in class org.reactfx.util.EmptyAccuMap
- instance() - Static method in class org.reactfx.util.LL.Nil
- INSTANCE - Static variable in class org.reactfx.util.EmptyAccuMap
- INSTANCE - Static variable in class org.reactfx.util.LL.Nil
- instantiate(ObservableList<E>) - Method in interface org.reactfx.collection.QuasiListModification
- instantiate(QuasiListChange<? extends E>, ObservableList<E>) - Static method in interface org.reactfx.collection.QuasiListChange
- instantiate(QuasiListModification<? extends E>, ObservableList<E>) - Static method in interface org.reactfx.collection.QuasiListModification
- IntegerBinding - Class in org.reactfx.inhibeans.binding
-
Deprecated.
- IntegerBinding() - Constructor for class org.reactfx.inhibeans.binding.IntegerBinding
-
Deprecated.
- IntegerPropertyBase - Class in org.reactfx.inhibeans.property
-
Deprecated.
- IntegerPropertyBase() - Constructor for class org.reactfx.inhibeans.property.IntegerPropertyBase
-
Deprecated.Superclass constructors.
- IntegerPropertyBase(int) - Constructor for class org.reactfx.inhibeans.property.IntegerPropertyBase
-
Deprecated.
- integerVar(IntegerProperty) - Static method in interface org.reactfx.value.Var
-
Converts IntegerProperty to
Var<Integer>
to help deal with the consequences of IntegerProperty not being a subtype ofProperty<Integer>
. - interpolate(double) - Method in class org.reactfx.value.AnimatedVal.FractionTransition
- interpolate(T, T, double) - Method in interface org.reactfx.util.Interpolator
- interpolator - Variable in class org.reactfx.value.AnimatedVal
- Interpolator<T> - Interface in org.reactfx.util
-
Interpolates values between two boundary values.
- invalidate() - Method in class org.reactfx.StreamBinding
- invalidate() - Method in class org.reactfx.value.ValBase
- invalidatePending() - Method in class org.reactfx.SuccessionReducingStream
- invalidatePending() - Method in class org.reactfx.ThenAccumulateForStream
- InvalidationListenerWrapper<T> - Class in org.reactfx.collection
- InvalidationListenerWrapper<T> - Class in org.reactfx.value
- InvalidationListenerWrapper(ObservableValue<T>, InvalidationListener) - Constructor for class org.reactfx.value.InvalidationListenerWrapper
- InvalidationListenerWrapper(ObservableList<T>, InvalidationListener) - Constructor for class org.reactfx.collection.InvalidationListenerWrapper
- invalidations() - Method in interface org.reactfx.value.Val
-
Returns a stream of invalidated values, which emits the invalidated value (i.e.
- invalidationsOf(Observable) - Static method in class org.reactfx.EventStreams
-
Creates an event stream that emits an impulse on every invalidation of the given observable.
- isBound() - Method in class org.reactfx.value.FlatMappedVar
- isBound() - Method in class org.reactfx.value.SimpleVar
- isBound() - Method in class org.reactfx.value.SuspendableVarWrapper
- isBound() - Method in class org.reactfx.value.VarFromVal
- isBound() - Method in class org.reactfx.value.VarWrapper
- isEmpty() - Method in interface org.reactfx.collection.AccessorListMethods
- isEmpty() - Method in class org.reactfx.collection.ListChangeAccumulator
- isEmpty() - Method in class org.reactfx.collection.SuspendableListWrapper
- isEmpty() - Method in interface org.reactfx.util.AccuMap
- isEmpty() - Method in class org.reactfx.util.EmptyAccuMap
- isEmpty() - Method in class org.reactfx.util.FingerTree
- isEmpty() - Method in class org.reactfx.util.IteratorBasedAccuMap
- isEmpty() - Method in class org.reactfx.util.LL.Cons
- isEmpty() - Method in class org.reactfx.util.LL
- isEmpty() - Method in class org.reactfx.util.LL.Nil
- isEmpty() - Method in interface org.reactfx.util.NotificationAccumulator
- isEmpty() - Method in class org.reactfx.util.NotificationAccumulatorBase
- isEmpty() - Method in interface org.reactfx.value.Val
-
Inverse of
Val.isPresent()
. - isEmpty(ListHelper<T>) - Static method in class org.reactfx.util.ListHelper
- isEmpty(MapHelper<K, V>) - Static method in class org.reactfx.util.MapHelper
- isFailure() - Method in interface org.reactfx.util.Try
- isLeft() - Method in interface org.reactfx.util.Either
- isLeft() - Method in class org.reactfx.util.Left
- isLeft() - Method in class org.reactfx.util.Right
- isMemoized(int) - Method in interface org.reactfx.collection.MemoizationList
- isMemoized(int) - Method in class org.reactfx.collection.MemoizationListImpl
- isNonEmptyRange(int, int, int) - Static method in class org.reactfx.util.Lists
- isNonEmptyRange(int, int, int, int) - Static method in class org.reactfx.util.Lists
- isObservingInputs() - Method in class org.reactfx.ObservableBase
- isOff() - Method in class org.reactfx.Indicator
-
Deprecated.
- isOn() - Method in class org.reactfx.Indicator
-
Deprecated.
- isPending() - Method in class org.reactfx.Await
- isPending() - Method in interface org.reactfx.AwaitingEventStream
- isPending() - Method in class org.reactfx.AwaitLatest
- isPending() - Method in class org.reactfx.SuccessionReducingStream
- isPending() - Method in class org.reactfx.ThenAccumulateForStream
- isPresent() - Method in class org.reactfx.util.SparseList.AbsentSegment
- isPresent() - Method in class org.reactfx.util.SparseList.PresentSegment
- isPresent() - Method in interface org.reactfx.util.SparseList.Segment
- isPresent() - Method in interface org.reactfx.value.Val
-
Checks whether this Val holds a (non-null) value.
- isPresent(int) - Method in class org.reactfx.util.SparseList.AbsentSegment
- isPresent(int) - Method in class org.reactfx.util.SparseList
- isPresent(int) - Method in class org.reactfx.util.SparseList.PresentSegment
- isPresent(int) - Method in interface org.reactfx.util.SparseList.Segment
- isProperNonEmptyRange(int, int, int) - Static method in class org.reactfx.util.Lists
- isProperNonEmptyRange(int, int, int, int) - Static method in class org.reactfx.util.Lists
- isProperRange(int, int, int) - Static method in class org.reactfx.util.Lists
- isProperRange(int, int, int, int) - Static method in class org.reactfx.util.Lists
- isRight() - Method in interface org.reactfx.util.Either
- isRight() - Method in class org.reactfx.util.Left
- isRight() - Method in class org.reactfx.util.Right
- isStrictlyInsideNonEmptyRange(int, int, int) - Static method in class org.reactfx.util.Lists
- isStrictlyInsideNonEmptyRange(int, int, int, int) - Static method in class org.reactfx.util.Lists
- isStrictlyInsideRange(int, int, int) - Static method in class org.reactfx.util.Lists
- isStrictlyInsideRange(int, int, int, int) - Static method in class org.reactfx.util.Lists
- isSuccess() - Method in interface org.reactfx.util.Try
- isSuspended() - Method in class org.reactfx.SuspendableBase
- isSuspended() - Method in class org.reactfx.SuspendableBoolean
- isValid() - Method in class org.reactfx.StreamBinding
- isValidIndex(int, int) - Static method in class org.reactfx.util.Lists
- isValidIndex(int, int, int) - Static method in class org.reactfx.util.Lists
- isValidPosition(int, int) - Static method in class org.reactfx.util.Lists
- isValidPosition(int, int, int) - Static method in class org.reactfx.util.Lists
- isValidRange(int, int, int) - Static method in class org.reactfx.util.Lists
- isValidRange(int, int, int, int) - Static method in class org.reactfx.util.Lists
- it - Variable in class org.reactfx.util.IteratorBasedAccuMap
- iterating - Variable in class org.reactfx.util.ListHelper.MultiElemHelper
- iterator() - Method in interface org.reactfx.collection.AbstractListModificationSequence
- iterator() - Method in interface org.reactfx.collection.AccessorListMethods
- iterator() - Method in class org.reactfx.collection.SuspendableListWrapper
- iterator() - Method in class org.reactfx.util.ListHelper
- iterator() - Method in class org.reactfx.util.ListHelper.MultiElemHelper
- iterator() - Method in class org.reactfx.util.ListHelper.SingleElemHelper
- iterator() - Method in class org.reactfx.util.LL.Cons
- iterator() - Method in class org.reactfx.util.LL.Nil
- iterator(int, int) - Method in class org.reactfx.util.ListHelper
- iterator(int, int) - Method in class org.reactfx.util.ListHelper.MultiElemHelper
- iterator(int, int) - Method in class org.reactfx.util.ListHelper.SingleElemHelper
- iterator(ListHelper<T>) - Static method in class org.reactfx.util.ListHelper
- iterator(ListHelper<T>, int, int) - Static method in class org.reactfx.util.ListHelper
- IteratorBasedAccuMap<K,V,A> - Class in org.reactfx.util
- IteratorBasedAccuMap(Iterator<K>, V) - Constructor for class org.reactfx.util.IteratorBasedAccuMap
J
- join(List<QuasiListModification<? extends E>>, List<? extends E>, int) - Static method in class org.reactfx.collection.ListChangeAccumulator
- join(FingerTree<SparseList.Segment<E>, SparseList.Stats>, List<SparseList.Segment<E>>, FingerTree<SparseList.Segment<E>, SparseList.Stats>) - Method in class org.reactfx.util.SparseList
- join(FingerTree<SparseList.Segment<E>, SparseList.Stats>, FingerTree<SparseList.Segment<E>, SparseList.Stats>) - Method in class org.reactfx.util.SparseList
- join(FingerTree<SparseList.Segment<E>, SparseList.Stats>, Tuple2<SparseList.Segment<E>, Integer>, List<SparseList.Segment<E>>, Tuple2<SparseList.Segment<E>, Integer>, FingerTree<SparseList.Segment<E>, SparseList.Stats>) - Method in class org.reactfx.util.SparseList
- join(FingerTree<SparseList.Segment<E>, SparseList.Stats>, Tuple2<SparseList.Segment<E>, Integer>, SparseList.Segment<E>, Tuple2<SparseList.Segment<E>, Integer>, FingerTree<SparseList.Segment<E>, SparseList.Stats>) - Method in class org.reactfx.util.SparseList
- join(FingerTree<T, S>) - Method in class org.reactfx.util.FingerTree.Empty
- join(FingerTree<T, S>) - Method in class org.reactfx.util.FingerTree
- join(FingerTree<T, S>) - Method in class org.reactfx.util.FingerTree.NonEmptyFingerTree
K
- key - Variable in class org.reactfx.util.MapHelper.SingleEntryHelper
L
- lastIndexOf(Object) - Method in interface org.reactfx.collection.AccessorListMethods
- lastIndexOf(Object) - Method in class org.reactfx.collection.SuspendableListWrapper
- latestEvent - Variable in class org.reactfx.DefaultEventStream
- latestN(int) - Method in interface org.reactfx.EventStream
-
Returns an event stream that emits lists of
n
latest events emitted from this stream. - LatestNStream<T> - Class in org.reactfx
- LatestNStream(EventStream<T>, int) - Constructor for class org.reactfx.LatestNStream
- leaf(T) - Method in class org.reactfx.util.FingerTree
- Leaf(ToSemigroup<? super T, S>, T) - Constructor for class org.reactfx.util.FingerTree.Leaf
- leafCount - Variable in class org.reactfx.util.FingerTree.Branch
- left(L) - Static method in interface org.reactfx.util.Either
- Left<L,R> - Class in org.reactfx.util
- Left(L) - Constructor for class org.reactfx.util.Left
- leftOrDefault(Optional<L>, R) - Static method in interface org.reactfx.util.Either
- leftOrNull(Optional<L>) - Static method in interface org.reactfx.util.Either
- length - Variable in class org.reactfx.util.SparseList.AbsentSegment
- LimitedInvocationSubscriber<T> - Class in org.reactfx
- LimitedInvocationSubscriber(int, Consumer<? super T>) - Constructor for class org.reactfx.LimitedInvocationSubscriber
- LINEAR_DOUBLE - Static variable in interface org.reactfx.util.Interpolator
- LINEAR_INTEGER - Static variable in interface org.reactfx.util.Interpolator
- LINEAR_LONG - Static variable in interface org.reactfx.util.Interpolator
- LINEAR_NUMBER - Static variable in interface org.reactfx.util.Interpolator
- list - Variable in class org.reactfx.collection.ChangeListenerWrapper
- list - Variable in class org.reactfx.collection.ChangeObserverWrapper
- list - Variable in class org.reactfx.collection.InvalidationListenerWrapper
- list - Variable in class org.reactfx.collection.ListIteratorImpl
- list - Variable in class org.reactfx.collection.ListModificationImpl
- list - Variable in class org.reactfx.collection.LiveArrayList
- list - Variable in class org.reactfx.collection.ModificationObserverWrapper
- list - Variable in class org.reactfx.collection.SubList
- list - Variable in class org.reactfx.util.SparseList.PresentSegment
- LIST_SIZE_MONOID - Static variable in class org.reactfx.util.ListConcatenation
- ListChange<E> - Interface in org.reactfx.collection
- ListChangeAccumulator<E> - Class in org.reactfx.collection
- ListChangeAccumulator() - Constructor for class org.reactfx.collection.ListChangeAccumulator
- ListChangeAccumulator(QuasiListChange<E>) - Constructor for class org.reactfx.collection.ListChangeAccumulator
- ListConcatenation<E> - Class in org.reactfx.util
- ListConcatenation(FingerTree<List<E>, Integer>) - Constructor for class org.reactfx.util.ListConcatenation
- listeners - Variable in class org.reactfx.inhibeans.ObservableBase
-
Deprecated.
- ListHelper<T> - Class in org.reactfx.util
- ListHelper() - Constructor for class org.reactfx.util.ListHelper
- ListHelper.MultiElemHelper<T> - Class in org.reactfx.util
- ListHelper.SingleElemHelper<T> - Class in org.reactfx.util
- listIterator() - Method in interface org.reactfx.collection.AccessorListMethods
- listIterator() - Method in class org.reactfx.collection.SuspendableListWrapper
- listIterator(int) - Method in interface org.reactfx.collection.AccessorListMethods
- listIterator(int) - Method in class org.reactfx.collection.SuspendableListWrapper
- ListIteratorImpl<E> - Class in org.reactfx.collection
- ListIteratorImpl(List<E>) - Constructor for class org.reactfx.collection.ListIteratorImpl
- ListIteratorImpl(List<E>, int) - Constructor for class org.reactfx.collection.ListIteratorImpl
- ListModification<E> - Interface in org.reactfx.collection
- ListModificationImpl<E> - Class in org.reactfx.collection
- ListModificationImpl(int, List<? extends E>, int, ObservableList<E>) - Constructor for class org.reactfx.collection.ListModificationImpl
- ListModificationLike<E> - Interface in org.reactfx.collection
-
Describes an elementary modification made to a list.
- ListModificationSequence<E> - Interface in org.reactfx.collection
-
Common supertype for
QuasiListChange
andListChangeAccumulator
. - listNotifications() - Static method in interface org.reactfx.util.NotificationAccumulator
- ListNotifications<E> - Class in org.reactfx.util
- ListNotifications() - Constructor for class org.reactfx.util.ListNotifications
- ListRangeReduction<T> - Class in org.reactfx.collection
- ListRangeReduction(ObservableList<T>, ObservableValue<IndexRange>, BinaryOperator<T>) - Constructor for class org.reactfx.collection.ListRangeReduction
- ListReduction<T> - Class in org.reactfx.collection
- ListReduction(ObservableList<T>, BinaryOperator<T>) - Constructor for class org.reactfx.collection.ListReduction
- Lists - Class in org.reactfx.util
- Lists() - Constructor for class org.reactfx.util.Lists
- LiveArrayList<E> - Class in org.reactfx.collection
- LiveArrayList() - Constructor for class org.reactfx.collection.LiveArrayList
- LiveArrayList(E...) - Constructor for class org.reactfx.collection.LiveArrayList
- LiveArrayList(Collection<? extends E>) - Constructor for class org.reactfx.collection.LiveArrayList
- LiveList<E> - Interface in org.reactfx.collection
-
Adds additional methods to
ObservableList
. - LiveList.Observer<E,O> - Interface in org.reactfx.collection
- LiveList.QuasiChangeObserver<E> - Interface in org.reactfx.collection
- LiveList.QuasiModificationObserver<E> - Interface in org.reactfx.collection
- LiveListBase<E> - Class in org.reactfx.collection
- LiveListBase() - Constructor for class org.reactfx.collection.LiveListBase
- LL<T> - Class in org.reactfx.util
-
Immutable singly-linked list.
- LL() - Constructor for class org.reactfx.util.LL
- LL.Cons<T> - Class in org.reactfx.util
- LL.Nil<T> - Class in org.reactfx.util
- locate(BiFunction<? super S, Integer, Either<Integer, Integer>>, int) - Method in class org.reactfx.util.FingerTree
- locate(BiFunction<? super S, Integer, Either<Integer, Integer>>, int) - Method in class org.reactfx.util.FingerTree.NonEmptyFingerTree
- locate0(BiFunction<? super S, Integer, Either<Integer, Integer>>, int) - Method in class org.reactfx.util.FingerTree.Branch
- locate0(BiFunction<? super S, Integer, Either<Integer, Integer>>, int) - Method in class org.reactfx.util.FingerTree.Leaf
- locate0(BiFunction<? super S, Integer, Either<Integer, Integer>>, int) - Method in class org.reactfx.util.FingerTree.NonEmptyFingerTree
- locate0(BiFunction<? super S, Integer, Either<Integer, Integer>>, int, LL<? extends FingerTree.NonEmptyFingerTree<T, S>>) - Method in class org.reactfx.util.FingerTree.Branch
- locateProgressively(ToIntFunction<? super S>, int) - Method in class org.reactfx.util.FingerTree
- locateProgressively(ToIntFunction<? super S>, int) - Method in class org.reactfx.util.FingerTree.NonEmptyFingerTree
- locateProgressively0(ToIntFunction<? super S>, int) - Method in class org.reactfx.util.FingerTree.Branch
- locateProgressively0(ToIntFunction<? super S>, int) - Method in class org.reactfx.util.FingerTree.Leaf
- locateProgressively0(ToIntFunction<? super S>, int) - Method in class org.reactfx.util.FingerTree.NonEmptyFingerTree
- locateProgressively0(ToIntFunction<? super S>, int, LL<? extends FingerTree.NonEmptyFingerTree<T, S>>) - Method in class org.reactfx.util.FingerTree.Branch
- locateRegressively(ToIntFunction<? super S>, int) - Method in class org.reactfx.util.FingerTree
- locateRegressively(ToIntFunction<? super S>, int) - Method in class org.reactfx.util.FingerTree.NonEmptyFingerTree
- locateRegressively0(ToIntFunction<? super S>, int) - Method in class org.reactfx.util.FingerTree.Branch
- locateRegressively0(ToIntFunction<? super S>, int) - Method in class org.reactfx.util.FingerTree.Leaf
- locateRegressively0(ToIntFunction<? super S>, int) - Method in class org.reactfx.util.FingerTree.NonEmptyFingerTree
- locateRegressively0(ToIntFunction<? super S>, int, LL<? extends FingerTree.NonEmptyFingerTree<T, S>>) - Method in class org.reactfx.util.FingerTree.Branch
- locationToPosition(int, int) - Method in class org.reactfx.util.SparseList
- LongBinding - Class in org.reactfx.inhibeans.binding
-
Deprecated.
- LongBinding() - Constructor for class org.reactfx.inhibeans.binding.LongBinding
-
Deprecated.
- LongPropertyBase - Class in org.reactfx.inhibeans.property
-
Deprecated.
- LongPropertyBase() - Constructor for class org.reactfx.inhibeans.property.LongPropertyBase
-
Deprecated.Superclass constructors.
- LongPropertyBase(long) - Constructor for class org.reactfx.inhibeans.property.LongPropertyBase
-
Deprecated.
- longVar(LongProperty) - Static method in interface org.reactfx.value.Var
-
Converts LongProperty to
Var<Long>
to help deal with the consequences of LongProperty not being a subtype ofProperty<Long>
.
M
- major - Variable in class org.reactfx.util.BiIndex
- MANY - org.reactfx.util.AccumulatorSize
- map(BiFunction<? super A, ? super B, ? extends T>) - Method in class org.reactfx.util.Tuple2
- map(BiFunction<Integer, Integer, T>) - Method in class org.reactfx.util.BiIndex
- map(Function<? super E, ? extends F>) - Method in interface org.reactfx.collection.LiveList
- map(Function<? super L, ? extends L2>, Function<? super R, ? extends R2>) - Method in interface org.reactfx.util.Either
- map(Function<? super L, ? extends L2>, Function<? super R, ? extends R2>) - Method in class org.reactfx.util.Left
- map(Function<? super L, ? extends L2>, Function<? super R, ? extends R2>) - Method in class org.reactfx.util.Right
- map(Function<? super T, ? extends U>) - Method in interface org.reactfx.EventStream
-
Returns a new event stream that applies the given function to every value emitted from this stream and emits the result.
- map(Function<? super T, ? extends U>) - Method in class org.reactfx.util.Failure
- map(Function<? super T, ? extends U>) - Method in class org.reactfx.util.LL.Cons
- map(Function<? super T, ? extends U>) - Method in class org.reactfx.util.LL
- map(Function<? super T, ? extends U>) - Method in class org.reactfx.util.LL.Nil
- map(Function<? super T, ? extends U>) - Method in class org.reactfx.util.Success
- map(Function<? super T, ? extends U>) - Method in interface org.reactfx.util.Try
- map(Function<? super T, ? extends U>) - Method in interface org.reactfx.value.Val
- map(ObservableValue<T>, Function<? super T, ? extends U>) - Static method in interface org.reactfx.value.Val
- map(ObservableList<? extends E>, Function<? super E, ? extends F>) - Static method in interface org.reactfx.collection.LiveList
- map(HexaFunction<? super A, ? super B, ? super C, ? super D, ? super E, ? super F, ? extends T>) - Method in class org.reactfx.util.Tuple6
- map(PentaFunction<? super A, ? super B, ? super C, ? super D, ? super E, ? extends T>) - Method in class org.reactfx.util.Tuple5
- map(TetraFunction<? super A, ? super B, ? super C, ? super D, ? extends T>) - Method in class org.reactfx.util.Tuple4
- map(TriFunction<? super A, ? super B, ? super C, ? extends T>) - Method in class org.reactfx.util.Tuple3
- mapBidirectional(Function<? super T, ? extends U>, Function<? super U, ? extends T>) - Method in interface org.reactfx.value.Var
- mapBidirectional(Property<T>, Function<? super T, ? extends U>, Function<? super U, ? extends T>) - Static method in interface org.reactfx.value.Var
- mapDynamic(ObservableValue<? extends Function<? super E, ? extends F>>) - Method in interface org.reactfx.collection.LiveList
- mapDynamic(ObservableValue<? extends Function<? super T, ? extends U>>) - Method in interface org.reactfx.value.Val
-
Like
Val.map(Function)
, but also allows dynamically changing map function. - mapDynamic(ObservableValue<T>, ObservableValue<? extends Function<? super T, ? extends U>>) - Static method in interface org.reactfx.value.Val
- mapDynamic(ObservableList<? extends E>, ObservableValue<? extends Function<? super E, ? extends F>>) - Static method in interface org.reactfx.collection.LiveList
- mapFirst2(BiFunction<? super T, ? super T, ? extends U>) - Method in class org.reactfx.util.LL
- mapFirst3(TriFunction<? super T, ? super T, ? super T, ? extends U>) - Method in class org.reactfx.util.LL
- mapFirst4(TetraFunction<? super T, ? super T, ? super T, ? super T, ? extends U>) - Method in class org.reactfx.util.LL
- mapFirst5(PentaFunction<? super T, ? super T, ? super T, ? super T, ? super T, ? extends U>) - Method in class org.reactfx.util.LL
- mapFirst6(HexaFunction<? super T, ? super T, ? super T, ? super T, ? super T, ? super T, ? extends U>) - Method in class org.reactfx.util.LL
- MapHelper<K,V> - Class in org.reactfx.util
- MapHelper() - Constructor for class org.reactfx.util.MapHelper
- MapHelper.MultiEntryHelper<K,V> - Class in org.reactfx.util
- MapHelper.SingleEntryHelper<K,V> - Class in org.reactfx.util
- mapLeft(Function<? super L, ? extends L2>) - Method in interface org.reactfx.util.Either
- mapLeft(Function<? super L, ? extends L2>) - Method in class org.reactfx.util.Left
- mapLeft(Function<? super L, ? extends L2>) - Method in class org.reactfx.util.Right
- mappedChangeView(QuasiListChange<? extends E>, Function<? super E, ? extends F>) - Static method in class org.reactfx.collection.MappedList
- MappedList<E,F> - Class in org.reactfx.collection
- MappedList(ObservableList<? extends E>, Function<? super E, ? extends F>) - Constructor for class org.reactfx.collection.MappedList
- MappedStream<T,U> - Class in org.reactfx
- MappedStream(EventStream<T>, Function<? super T, ? extends U>) - Constructor for class org.reactfx.MappedStream
- mappedSubscription - Variable in class org.reactfx.FlatMapStream
- MappedToCompletionStageStream<T,U> - Class in org.reactfx
- MappedToCompletionStageStream(EventStream<T>, Function<? super T, CompletionStage<U>>) - Constructor for class org.reactfx.MappedToCompletionStageStream
- MappedToTaskStream<T,U> - Class in org.reactfx
- MappedToTaskStream(EventStream<T>, Function<? super T, Task<U>>) - Constructor for class org.reactfx.MappedToTaskStream
- MappedVal<T,U> - Class in org.reactfx.value
- MappedVal(ObservableValue<T>, Function<? super T, ? extends U>) - Constructor for class org.reactfx.value.MappedVal
- mappedView(List<? extends E>, Function<? super E, ? extends F>) - Static method in class org.reactfx.util.Lists
- mapper - Variable in class org.reactfx.collection.DynamicallyMappedList
- mapper - Variable in class org.reactfx.collection.MappedList
- mapper - Variable in class org.reactfx.FlatMapOptStream
- mapper - Variable in class org.reactfx.FlatMapStream
- mapperInvalidated(Function<? super E, ? extends F>) - Method in class org.reactfx.collection.DynamicallyMappedList
- mapReduce(Function<? super T, ? extends R>, BinaryOperator<R>) - Method in class org.reactfx.util.LL.Cons
- mapReduce(Function<? super T, ? extends R>, BinaryOperator<R>) - Method in class org.reactfx.util.LL
- mapReduce(Function<? super T, ? extends R>, BinaryOperator<R>) - Method in class org.reactfx.util.LL.Nil
- mapReduce1(Function<? super T, ? extends R>, BinaryOperator<R>) - Method in class org.reactfx.util.LL.Cons
- mapRight(Function<? super R, ? extends R2>) - Method in interface org.reactfx.util.Either
- mapRight(Function<? super R, ? extends R2>) - Method in class org.reactfx.util.Left
- mapRight(Function<? super R, ? extends R2>) - Method in class org.reactfx.util.Right
- mapToCompletionStage(Function<? super T, CompletionStage<U>>) - Method in interface org.reactfx.EventStream
-
Similar to
EventStream.map(Function)
, but the returned stream is aCompletionStageStream
, which can be used to await the results of asynchronous computation. - mapToTask(Function<? super T, Task<U>>) - Method in interface org.reactfx.EventStream
-
Similar to
EventStream.map(Function)
, but the returned stream is aTaskStream
, which can be used to await the results of asynchronous computation. - materialize() - Method in interface org.reactfx.collection.ListModification
- materialize(ObservableList<E>) - Method in interface org.reactfx.collection.QuasiListModification
- materialize(QuasiListModification<? extends E>, ObservableList<E>) - Static method in interface org.reactfx.collection.QuasiListModification
- MaterializedListModification<E> - Interface in org.reactfx.collection
- MaterializedListModificationImpl<E> - Class in org.reactfx.collection
- MaterializedListModificationImpl(int, List<? extends E>, List<? extends E>) - Constructor for class org.reactfx.collection.MaterializedListModificationImpl
- measure(ToIntFunction<? super S>) - Method in class org.reactfx.util.FingerTree
- MemoizationList<E> - Interface in org.reactfx.collection
- MemoizationListImpl<E> - Class in org.reactfx.collection
- MemoizationListImpl(ObservableList<E>) - Constructor for class org.reactfx.collection.MemoizationListImpl
- MemoizationListImpl.MemoizedView - Class in org.reactfx.collection
- memoize() - Method in interface org.reactfx.collection.LiveList
- memoize(ObservableList<E>) - Static method in interface org.reactfx.collection.LiveList
- memoizedItems - Variable in class org.reactfx.collection.MemoizationListImpl
- memoizedItems() - Method in interface org.reactfx.collection.MemoizationList
- memoizedItems() - Method in class org.reactfx.collection.MemoizationListImpl
- MemoizedView() - Constructor for class org.reactfx.collection.MemoizationListImpl.MemoizedView
- merge(ObservableSet<? extends EventStream<T>>) - Static method in class org.reactfx.EventStreams
-
Returns an event stream that emits all the events emitted from any of the event streams in the given observable set.
- merge(ObservableSet<? extends T>, Function<? super T, ? extends EventStream<U>>) - Static method in class org.reactfx.EventStreams
-
A more general version of
EventStreams.merge(ObservableSet)
for a set of arbitrary element type and a function to obtain an event stream from the element. - merge(EventStream<? extends T>...) - Static method in class org.reactfx.EventStreams
-
Returns an event stream that emits all the events emitted from any of the
inputs
. - minor - Variable in class org.reactfx.util.BiIndex
- mkTree(List<? extends T>) - Static method in class org.reactfx.util.FingerTree
- mkTree(List<? extends T>, ToSemigroup<? super T, S>) - Static method in class org.reactfx.util.FingerTree
- ModificationObserverWrapper<T> - Class in org.reactfx.collection
- ModificationObserverWrapper(ObservableList<T>, Consumer<? super ListModification<? extends T>>) - Constructor for class org.reactfx.collection.ModificationObserverWrapper
- modifications - Variable in class org.reactfx.collection.ListChangeAccumulator
- modifications() - Method in interface org.reactfx.collection.LiveList
- monoid - Variable in class org.reactfx.collection.ListReduction
- multi(Function<? super T, ? extends Subscription>, Collection<T>) - Static method in interface org.reactfx.Subscription
-
Subscribes to all elements of the given collection by the given function and returns an aggregate subscription that can be used to cancel all element subscriptions.
- multi(Function<? super T, ? extends Subscription>, T...) - Static method in interface org.reactfx.Subscription
-
Subscribes to all elements by the given function and returns an aggregate subscription that can be used to cancel all element subscriptions.
- multi(Guard...) - Static method in interface org.reactfx.Guard
-
Returns a guard that is a composition of multiple guards.
- multi(Subscription...) - Static method in interface org.reactfx.Subscription
-
Returns a new aggregate subscription whose
Subscription.unsubscribe()
method callsunsubscribe()
on all arguments to this method. - MultiElemHelper(List<T>) - Constructor for class org.reactfx.util.ListHelper.MultiElemHelper
- MultiElemHelper(T...) - Constructor for class org.reactfx.util.ListHelper.MultiElemHelper
- MultiEntryHelper(K, V, K, V) - Constructor for class org.reactfx.util.MapHelper.MultiEntryHelper
- MultiGuard - Class in org.reactfx
- MultiGuard(Guard...) - Constructor for class org.reactfx.MultiGuard
- MultiGuardian - Class in org.reactfx
- MultiGuardian(Guardian...) - Constructor for class org.reactfx.MultiGuardian
- MultiSubscription - Class in org.reactfx
- MultiSubscription(Subscription...) - Constructor for class org.reactfx.MultiSubscription
- MultiSuspendable - Class in org.reactfx
- MultiSuspendable(Suspendable...) - Constructor for class org.reactfx.MultiSuspendable
N
- n - Variable in class org.reactfx.LatestNStream
- never() - Static method in class org.reactfx.EventStreams
-
Returns an event stream that never emits any value.
- Never() - Constructor for class org.reactfx.EventStreams.Never
- NEVER - Static variable in class org.reactfx.EventStreams
- newObserver(Consumer<? super T>) - Method in class org.reactfx.DefaultEventStream
- newObserver(Consumer<? super T>) - Method in class org.reactfx.value.ValBase
- newObserver(O) - Method in class org.reactfx.ObservableBase
-
Called for each new observer.
- newSimpleVar(T) - Static method in interface org.reactfx.value.Var
- newValue - Variable in class org.reactfx.Change
- next() - Method in class org.reactfx.collection.ListIteratorImpl
- nextIndex() - Method in class org.reactfx.collection.ListIteratorImpl
- nil() - Static method in class org.reactfx.util.LL
- Nil() - Constructor for class org.reactfx.util.LL.Nil
- noes() - Method in class org.reactfx.SuspendableBoolean
- nonAccumulativeStreamNotifications() - Static method in interface org.reactfx.util.NotificationAccumulator
- NonAccumulativeStreamNotifications<T> - Class in org.reactfx.util
- NonAccumulativeStreamNotifications() - Constructor for class org.reactfx.util.NonAccumulativeStreamNotifications
- NONE - Static variable in class org.reactfx.DistinctStream
- NonEmptyFingerTree(ToSemigroup<? super T, S>) - Constructor for class org.reactfx.util.FingerTree.NonEmptyFingerTree
- nonNullValuesOf(ObservableValue<T>) - Static method in class org.reactfx.EventStreams
- NotificationAccumulator<O,V,A> - Interface in org.reactfx.util
- NotificationAccumulatorBase<O,V,A> - Class in org.reactfx.util
- NotificationAccumulatorBase() - Constructor for class org.reactfx.util.NotificationAccumulatorBase
- notifyListeners() - Method in class org.reactfx.inhibeans.ObservableBase
-
Deprecated.
- notifyListeners(boolean) - Method in class org.reactfx.Indicator
-
Deprecated.
- notifyObservers() - Method in class org.reactfx.ObservableBase
- notifyObservers(T) - Method in class org.reactfx.ObservableBase
- notifyObservers(T) - Method in interface org.reactfx.ProperObservable
- notifyObserversWhileSuspended(T) - Method in class org.reactfx.SuspenderBase
-
Use in subclasses instead of
ObservableBase.notifyObservers(Object)
in order to suspend the associated Suspendable while notifying observers.
O
- ObjectBinding<T> - Class in org.reactfx.inhibeans.binding
-
Deprecated.
- ObjectBinding() - Constructor for class org.reactfx.inhibeans.binding.ObjectBinding
-
Deprecated.
- ObjectPropertyBase<T> - Class in org.reactfx.inhibeans.property
-
Deprecated.
- ObjectPropertyBase() - Constructor for class org.reactfx.inhibeans.property.ObjectPropertyBase
-
Deprecated.Superclass constructors.
- ObjectPropertyBase(T) - Constructor for class org.reactfx.inhibeans.property.ObjectPropertyBase
-
Deprecated.
- obs - Variable in class org.reactfx.value.ChangeListenerWrapper
- obs - Variable in class org.reactfx.value.InvalidationListenerWrapper
- Observable - Interface in org.reactfx.inhibeans
-
Deprecated.Superseded by
Suspendable
. - Observable<O> - Interface in org.reactfx
-
Anything that can be observed, that is have an observer added and removed.
- ObservableBase - Class in org.reactfx.inhibeans
-
Deprecated.
- ObservableBase<O,T> - Class in org.reactfx
-
Base class for observable objects.
- ObservableBase() - Constructor for class org.reactfx.inhibeans.ObservableBase
-
Deprecated.
- ObservableBase() - Constructor for class org.reactfx.ObservableBase
- ObservableBase(NotificationAccumulator<O, T, ?>) - Constructor for class org.reactfx.ObservableBase
- ObservableList<E> - Interface in org.reactfx.inhibeans.collection
-
Deprecated.Use
SuspendableList
instead. - ObservableStateBuilderImpl<S> - Class in org.reactfx
- ObservableStateBuilderImpl(S, LL<TransitionBuilder<S>>) - Constructor for class org.reactfx.ObservableStateBuilderImpl
- ObservableStateBuilderOnImpl<S,I> - Class in org.reactfx
- ObservableStateBuilderOnImpl(S, LL<TransitionBuilder<S>>, EventStream<I>) - Constructor for class org.reactfx.ObservableStateBuilderOnImpl
- ObservableValue<T> - Interface in org.reactfx.inhibeans.value
-
Deprecated.
- ObservableValueBase<T> - Class in org.reactfx.inhibeans.value
-
Deprecated.
- ObservableValueBase() - Constructor for class org.reactfx.inhibeans.value.ObservableValueBase
-
Deprecated.
- observe(O) - Method in interface org.reactfx.Observable
- observe(O) - Method in class org.reactfx.ObservableBase
- observe(O) - Method in class org.reactfx.ProxyObservable
- observe(O) - Method in class org.reactfx.RigidObservable
-
Returns an empty Subscription (
Subscription.EMPTY
). - observeChanges(Consumer<? super ListChange<? extends E>>) - Method in interface org.reactfx.collection.LiveList
- observeChanges(ChangeListener<? super T>) - Method in interface org.reactfx.value.Val
-
Adds a change listener and returns a Subscription that can be used to remove that listener.
- observeChanges(ObservableValue<? extends T>, ChangeListener<? super T>) - Static method in interface org.reactfx.value.Val
- observeChanges(ObservableList<E>, Consumer<? super ListChange<? extends E>>) - Static method in interface org.reactfx.collection.LiveList
- observeInputs() - Method in class org.reactfx.AccumulateBetweenStream
- observeInputs() - Method in class org.reactfx.AccumulateUntilLaterStream
- observeInputs() - Method in class org.reactfx.AccumulatingStream
- observeInputs() - Method in class org.reactfx.Await
- observeInputs() - Method in class org.reactfx.AwaitLatest
- observeInputs() - Method in class org.reactfx.collection.DynamicallyMappedList
- observeInputs() - Method in class org.reactfx.collection.LiveArrayList
- observeInputs() - Method in class org.reactfx.collection.MappedList
- observeInputs() - Method in class org.reactfx.collection.MemoizationListImpl.MemoizedView
- observeInputs() - Method in class org.reactfx.collection.MemoizationListImpl
- observeInputs() - Method in class org.reactfx.collection.ValAsList
- observeInputs() - Method in class org.reactfx.ConnectableEventSource
- observeInputs() - Method in class org.reactfx.DefaultEventStream
- observeInputs() - Method in class org.reactfx.DistinctStream
- observeInputs() - Method in class org.reactfx.EmitBothOnEachStream
- observeInputs() - Method in class org.reactfx.EmitOnEachStream
- observeInputs() - Method in class org.reactfx.EmitOnStream
- observeInputs() - Method in class org.reactfx.EventSource
- observeInputs() - Method in class org.reactfx.FilterMapStream
- observeInputs() - Method in class org.reactfx.FilterStream
- observeInputs() - Method in class org.reactfx.FlatMapOptStream
- observeInputs() - Method in class org.reactfx.FlatMapStream
- observeInputs() - Method in class org.reactfx.HookStream
- observeInputs() - Method in class org.reactfx.LatestNStream
- observeInputs() - Method in class org.reactfx.MappedStream
- observeInputs() - Method in class org.reactfx.ObservableBase
-
Starts observing this observable's input(s), if any.
- observeInputs() - Method in class org.reactfx.RecursiveStream
- observeInputs() - Method in class org.reactfx.RepeatOnStream
- observeInputs() - Method in class org.reactfx.StatefulStream
- observeInputs() - Method in class org.reactfx.StateStream
- observeInputs() - Method in class org.reactfx.SuccessionReducingStream
- observeInputs() - Method in class org.reactfx.SuspendableBase
- observeInputs() - Method in class org.reactfx.SuspendedWhenStream
- observeInputs() - Method in class org.reactfx.SuspenderStreamImpl
- observeInputs() - Method in class org.reactfx.ThenAccumulateForStream
- observeInputs() - Method in class org.reactfx.ThreadBridge
- observeInputs() - Method in class org.reactfx.value.ValBase
- observeInvalidations(Consumer<? super T>) - Method in interface org.reactfx.value.Val
- observeInvalidations(ObservableValue<?>, InvalidationListener) - Static method in interface org.reactfx.value.Val
- observeModifications(Consumer<? super ListModification<? extends E>>) - Method in interface org.reactfx.collection.LiveList
- observeQuasiChanges(ObservableList<? extends E>, LiveList.QuasiChangeObserver<? super E>) - Static method in interface org.reactfx.collection.LiveList
- observeQuasiChanges(LiveList.QuasiChangeObserver<? super E>) - Method in interface org.reactfx.collection.LiveList
- observeQuasiModifications(LiveList.QuasiModificationObserver<? super E>) - Method in interface org.reactfx.collection.LiveList
- observers - Variable in class org.reactfx.ObservableBase
- of(T[], int, LL<T>) - Static method in class org.reactfx.util.LL
- of(T, T...) - Static method in class org.reactfx.util.LL
- offs() - Method in class org.reactfx.Indicator
-
Deprecated.
- offsetPendingModifications(int, int) - Method in class org.reactfx.collection.ListChangeAccumulator
- oldValue - Variable in class org.reactfx.Change
- oldValue - Variable in class org.reactfx.value.AnimatedVal
- on - Variable in class org.reactfx.Indicator
-
Deprecated.
- on() - Method in class org.reactfx.Indicator
-
Deprecated.Turns this indicator on.
- on(EventStream<I>) - Method in class org.reactfx.InitialStateImpl
- on(EventStream<I>) - Method in class org.reactfx.ObservableStateBuilderImpl
- on(EventStream<I>) - Method in class org.reactfx.StatefulStreamBuilderImpl
- on(EventStream<I>) - Method in interface org.reactfx.StateMachine.InitialState
- on(EventStream<I>) - Method in interface org.reactfx.StateMachine.ObservableStateBuilder
- on(EventStream<I>) - Method in interface org.reactfx.StateMachine.StatefulStreamBuilder
- onChange(O) - Method in interface org.reactfx.collection.LiveList.Observer
- onChange(QuasiListChange<? extends T>) - Method in class org.reactfx.collection.ChangeListenerWrapper
- onChange(QuasiListChange<? extends T>) - Method in class org.reactfx.collection.ChangeObserverWrapper
- onChange(QuasiListChange<? extends T>) - Method in class org.reactfx.collection.InvalidationListenerWrapper
- onChange(QuasiListModification<? extends T>) - Method in class org.reactfx.collection.ModificationObserverWrapper
- ONE - org.reactfx.util.AccumulatorSize
- onEvent(T) - Method in class org.reactfx.LatestNStream
- onInvalidating() - Method in class org.reactfx.inhibeans.binding.BooleanBinding
-
Deprecated.
- onInvalidating() - Method in class org.reactfx.inhibeans.binding.DoubleBinding
-
Deprecated.
- onInvalidating() - Method in class org.reactfx.inhibeans.binding.FloatBinding
-
Deprecated.
- onInvalidating() - Method in class org.reactfx.inhibeans.binding.IntegerBinding
-
Deprecated.
- onInvalidating() - Method in class org.reactfx.inhibeans.binding.LongBinding
-
Deprecated.
- onInvalidating() - Method in class org.reactfx.inhibeans.binding.ObjectBinding
-
Deprecated.
- onInvalidating() - Method in class org.reactfx.inhibeans.binding.StringBinding
-
Deprecated.
- onRecurseAccumulate(Function<? super T, ? extends A>, BiFunction<? super A, ? super T, ? extends A>, Function<? super A, AccumulatorSize>, Function<? super A, ? extends T>, Function<? super A, ? extends A>) - Method in interface org.reactfx.EventStream
- onRecurseAccumulate(Supplier<? extends A>, BiFunction<? super A, ? super T, ? extends A>, Function<? super A, AccumulatorSize>, Function<? super A, ? extends T>, Function<? super A, ? extends A>) - Method in interface org.reactfx.EventStream
- onRecurseQueue() - Method in interface org.reactfx.EventStream
- onRecurseReduce(BinaryOperator<T>) - Method in interface org.reactfx.EventStream
- onRecurseRetainLatest() - Method in interface org.reactfx.EventStream
- ons() - Method in class org.reactfx.Indicator
-
Deprecated.
- onWhile(Runnable) - Method in class org.reactfx.Indicator
-
Deprecated.Runs the given computation, making sure this indicator is on.
- onWhile(Supplier<T>) - Method in class org.reactfx.Indicator
-
Deprecated.Runs the given computation, making sure this indicator is on.
- or(EventStream<? extends U>) - Method in interface org.reactfx.EventStream
-
Returns an event stream that emits all the events emitted from either this stream or the
right
stream. - orElse(Supplier<Try<T>>) - Method in class org.reactfx.util.Failure
- orElse(Supplier<Try<T>>) - Method in class org.reactfx.util.Success
- orElse(Supplier<Try<T>>) - Method in interface org.reactfx.util.Try
- orElse(ObservableValue<? extends T>, ObservableValue<? extends T>) - Static method in interface org.reactfx.value.Val
- orElse(ObservableValue<T>) - Method in interface org.reactfx.value.Val
- orElse(Try<T>) - Method in class org.reactfx.util.Failure
- orElse(Try<T>) - Method in class org.reactfx.util.Success
- orElse(Try<T>) - Method in interface org.reactfx.util.Try
- OrElse<T> - Class in org.reactfx.value
- OrElse(ObservableValue<? extends T>, ObservableValue<? extends T>) - Constructor for class org.reactfx.value.OrElse
- orElseConst(ObservableValue<? extends T>, T) - Static method in interface org.reactfx.value.Val
- orElseConst(T) - Method in interface org.reactfx.value.Val
- OrElseConst<T> - Class in org.reactfx.value
- OrElseConst(ObservableValue<? extends T>, T) - Constructor for class org.reactfx.value.OrElseConst
- orElseTry(Callable<? extends T>) - Method in class org.reactfx.util.Failure
- orElseTry(Callable<? extends T>) - Method in class org.reactfx.util.Success
- orElseTry(Callable<? extends T>) - Method in interface org.reactfx.util.Try
- org.reactfx - package org.reactfx
- org.reactfx.collection - package org.reactfx.collection
- org.reactfx.inhibeans - package org.reactfx.inhibeans
- org.reactfx.inhibeans.binding - package org.reactfx.inhibeans.binding
- org.reactfx.inhibeans.collection - package org.reactfx.inhibeans.collection
- org.reactfx.inhibeans.property - package org.reactfx.inhibeans.property
- org.reactfx.inhibeans.value - package org.reactfx.inhibeans.value
- org.reactfx.util - package org.reactfx.util
- org.reactfx.value - package org.reactfx.value
- other - Variable in class org.reactfx.value.OrElse
- other - Variable in class org.reactfx.value.OrElseConst
P
- pApply(A) - Method in interface org.reactfx.util.HexaFunction
- pApply(A) - Method in interface org.reactfx.util.PentaFunction
- pApply(A) - Method in interface org.reactfx.util.TetraFunction
- pApply(A) - Method in interface org.reactfx.util.TriFunction
- pausable() - Method in interface org.reactfx.EventStream
-
Returns a suspendable event stream that, when suspended, stores the events emitted by this event stream and emits them when the returned stream's emission is resumed.
- PausableEventStream<T> - Class in org.reactfx
- PausableEventStream(EventStream<T>) - Constructor for class org.reactfx.PausableEventStream
- pauseWhen(ObservableValue<Boolean>) - Method in interface org.reactfx.EventStream
-
Shortcut for
pausable().suspendedWhen(condition)
. - peek(AccumulationFacility<V, A>) - Method in interface org.reactfx.util.AccuMap
- peek(AccumulationFacility<V, A>) - Method in class org.reactfx.util.EmptyAccuMap
- peek(AccumulationFacility<V, A>) - Method in class org.reactfx.util.HashAccuMap
- peek(AccumulationFacility<V, A>) - Method in class org.reactfx.util.IteratorBasedAccuMap
- pending - Variable in class org.reactfx.Await
- pending - Variable in class org.reactfx.AwaitLatest
- pending - Variable in class org.reactfx.SuccessionReducingStream
- pending - Variable in class org.reactfx.ThenAccumulateForStream
- pendingNotifications - Variable in class org.reactfx.ObservableBase
- pendingProperty() - Method in class org.reactfx.Await
- pendingProperty() - Method in interface org.reactfx.AwaitingEventStream
-
Indicates whether there is a pending event that will be emitted by this stream in the (near) future.
- pendingProperty() - Method in class org.reactfx.AwaitLatest
- pendingProperty() - Method in class org.reactfx.SuccessionReducingStream
- pendingProperty() - Method in class org.reactfx.ThenAccumulateForStream
- pendingTimer - Variable in class org.reactfx.ScheduledExecutorServiceTimer
- PentaConsumer<A,B,C,D,E> - Interface in org.reactfx.util
- PentaFunction<A,B,C,D,E,R> - Interface in org.reactfx.util
- PentaPredicate<A,B,C,D,E> - Interface in org.reactfx.util
- pickKey() - Method in class org.reactfx.util.HashAccuMap
- pin() - Method in interface org.reactfx.collection.LiveList
- pin() - Method in interface org.reactfx.EventStream
-
If this stream is a compound stream lazily subscribed to its inputs, that is, subscribed to inputs only when it itself has some subscribers,
pin
ning this stream causes it to stay subscribed until the pinning is revoked by callingunsubscribe()
on the returned subscription. - pin() - Method in interface org.reactfx.value.Val
- Pocket() - Constructor for class org.reactfx.EventStreams.Pocket
- position - Variable in class org.reactfx.collection.ListIteratorImpl
- position - Variable in class org.reactfx.collection.ListModificationImpl
- position - Variable in class org.reactfx.collection.QuasiListModificationImpl
- possiblyDestructiveAppend(SparseList.Segment<E>) - Method in class org.reactfx.util.SparseList.AbsentSegment
- possiblyDestructiveAppend(SparseList.Segment<E>) - Method in class org.reactfx.util.SparseList.PresentSegment
- possiblyDestructiveAppend(SparseList.Segment<E>) - Method in interface org.reactfx.util.SparseList.Segment
- predicate - Variable in class org.reactfx.FilterMapStream
- predicate - Variable in class org.reactfx.FilterStream
- prepareNotifications(QuasiListChange<? extends E>) - Method in class org.reactfx.collection.MemoizationListImpl.MemoizedView
- prepareNotifications(QuasiListModification<? extends E>) - Method in class org.reactfx.collection.MemoizationListImpl.MemoizedView
- prepend(T) - Method in class org.reactfx.util.FingerTree
- prependLte(FingerTree<T, S>) - Method in class org.reactfx.util.FingerTree.Branch
- prependLte(FingerTree<T, S>) - Method in class org.reactfx.util.FingerTree.Leaf
- prependLte(FingerTree<T, S>) - Method in class org.reactfx.util.FingerTree.NonEmptyFingerTree
- prependTree(FingerTree<T, S>) - Method in class org.reactfx.util.FingerTree.NonEmptyFingerTree
- presentCount - Variable in class org.reactfx.util.SparseList.Stats
- PresentSegment(Collection<? extends E>) - Constructor for class org.reactfx.util.SparseList.PresentSegment
- previous - Variable in class org.reactfx.DistinctStream
- previous() - Method in class org.reactfx.collection.ListIteratorImpl
- previousIndex() - Method in class org.reactfx.collection.ListIteratorImpl
- ProperEventStream<T> - Interface in org.reactfx
-
Trait to be mixed into
ObservableBase
to obtain default implementation of someEventStream
methods on top of Observable methods and get additional helper methods for proper event streams implemented as default methods on top of ProperObservable methods. - ProperLiveList<E> - Interface in org.reactfx.collection
-
Trait to be mixed into
ObservableBase
to obtain default implementation of someLiveList
methods and get additional helper methods for implementations of proper LiveList. - ProperObservable<O,T> - Interface in org.reactfx
-
An Observable that maintains a collection of registered observers and notifies them when a change occurs.
- Property<T> - Interface in org.reactfx.inhibeans.property
-
Deprecated.Superseded by
SuspendableVar
. - ProperVal<T> - Interface in org.reactfx.value
- ProxyObservable<O,P,U extends Observable<P>> - Class in org.reactfx
-
An Observable that does not maintain its own collection of observers, but rather adapts and registers every given observer with the underlying Observable
- ProxyObservable(U) - Constructor for class org.reactfx.ProxyObservable
- ProxyVal<T,U> - Class in org.reactfx.value
- ProxyVal(Val<U>) - Constructor for class org.reactfx.value.ProxyVal
- publishNotifications() - Method in class org.reactfx.collection.MemoizationListImpl.MemoizedView
- push(T) - Method in class org.reactfx.ConnectableEventSource
- push(T) - Method in interface org.reactfx.EventSink
- push(T) - Method in class org.reactfx.EventSource
-
Make this event stream immediately emit the given value.
- put(K, V) - Method in class org.reactfx.util.MapHelper.MultiEntryHelper
- put(K, V) - Method in class org.reactfx.util.MapHelper
- put(K, V) - Method in class org.reactfx.util.MapHelper.SingleEntryHelper
- put(MapHelper<K, V>, K, V) - Static method in class org.reactfx.util.MapHelper
Q
- quasiChanges() - Method in interface org.reactfx.collection.LiveList
- quasiChangesOf(ObservableList<E>) - Static method in interface org.reactfx.collection.LiveList
- QuasiListChange<E> - Interface in org.reactfx.collection
- QuasiListChangeImpl<E> - Class in org.reactfx.collection
- QuasiListChangeImpl() - Constructor for class org.reactfx.collection.QuasiListChangeImpl
- QuasiListChangeImpl(int) - Constructor for class org.reactfx.collection.QuasiListChangeImpl
- QuasiListChangeImpl(QuasiListChange<E>) - Constructor for class org.reactfx.collection.QuasiListChangeImpl
- QuasiListModification<E> - Interface in org.reactfx.collection
- QuasiListModificationImpl<E> - Class in org.reactfx.collection
- QuasiListModificationImpl(int, List<? extends E>, int) - Constructor for class org.reactfx.collection.QuasiListModificationImpl
- quasiModifications() - Method in interface org.reactfx.collection.LiveList
- queueBetween(EventStream<?>) - Method in interface org.reactfx.EventStream
-
Returns an event stream that, when an event arrives from this stream, enqueues it for emission.
- queueUntilLater() - Method in interface org.reactfx.EventStream
-
Returns an event stream that, when an event is emitted from this stream, enqueues the event for emission and schedules emission using
Platform.runLater(Runnable)
, if not already scheduled. - queueUntilLater(Executor) - Method in interface org.reactfx.EventStream
-
Version of
EventStream.queueUntilLater()
for event streams that don't live on the JavaFX application thread. - queuingStreamNotifications() - Static method in interface org.reactfx.util.NotificationAccumulator
- QueuingStreamNotifications<T> - Class in org.reactfx.util
- QueuingStreamNotifications() - Constructor for class org.reactfx.util.QueuingStreamNotifications
R
- range - Variable in class org.reactfx.collection.ListRangeReduction
- rangeInsertion(int, int) - Static method in interface org.reactfx.collection.ProperLiveList
- rangeRemoval(int, List<E>) - Static method in interface org.reactfx.collection.ProperLiveList
- ReadOnlyBooleanPropertyBase - Class in org.reactfx.inhibeans.property
-
Deprecated.
- ReadOnlyBooleanPropertyBase() - Constructor for class org.reactfx.inhibeans.property.ReadOnlyBooleanPropertyBase
-
Deprecated.
- ReadOnlyBooleanWrapper - Class in org.reactfx.inhibeans.property
-
Deprecated.
- ReadOnlyBooleanWrapper() - Constructor for class org.reactfx.inhibeans.property.ReadOnlyBooleanWrapper
-
Deprecated.Superclass constructors.
- ReadOnlyBooleanWrapper(boolean) - Constructor for class org.reactfx.inhibeans.property.ReadOnlyBooleanWrapper
-
Deprecated.
- ReadOnlyBooleanWrapper(Object, String) - Constructor for class org.reactfx.inhibeans.property.ReadOnlyBooleanWrapper
-
Deprecated.
- ReadOnlyBooleanWrapper(Object, String, boolean) - Constructor for class org.reactfx.inhibeans.property.ReadOnlyBooleanWrapper
-
Deprecated.
- ReadOnlyDoublePropertyBase - Class in org.reactfx.inhibeans.property
-
Deprecated.
- ReadOnlyDoublePropertyBase() - Constructor for class org.reactfx.inhibeans.property.ReadOnlyDoublePropertyBase
-
Deprecated.
- ReadOnlyDoubleWrapper - Class in org.reactfx.inhibeans.property
-
Deprecated.
- ReadOnlyDoubleWrapper() - Constructor for class org.reactfx.inhibeans.property.ReadOnlyDoubleWrapper
-
Deprecated.Superclass constructors.
- ReadOnlyDoubleWrapper(double) - Constructor for class org.reactfx.inhibeans.property.ReadOnlyDoubleWrapper
-
Deprecated.
- ReadOnlyDoubleWrapper(Object, String) - Constructor for class org.reactfx.inhibeans.property.ReadOnlyDoubleWrapper
-
Deprecated.
- ReadOnlyDoubleWrapper(Object, String, double) - Constructor for class org.reactfx.inhibeans.property.ReadOnlyDoubleWrapper
-
Deprecated.
- ReadOnlyFloatPropertyBase - Class in org.reactfx.inhibeans.property
-
Deprecated.
- ReadOnlyFloatPropertyBase() - Constructor for class org.reactfx.inhibeans.property.ReadOnlyFloatPropertyBase
-
Deprecated.
- ReadOnlyFloatWrapper - Class in org.reactfx.inhibeans.property
-
Deprecated.
- ReadOnlyFloatWrapper() - Constructor for class org.reactfx.inhibeans.property.ReadOnlyFloatWrapper
-
Deprecated.Superclass constructors.
- ReadOnlyFloatWrapper(float) - Constructor for class org.reactfx.inhibeans.property.ReadOnlyFloatWrapper
-
Deprecated.
- ReadOnlyFloatWrapper(Object, String) - Constructor for class org.reactfx.inhibeans.property.ReadOnlyFloatWrapper
-
Deprecated.
- ReadOnlyFloatWrapper(Object, String, float) - Constructor for class org.reactfx.inhibeans.property.ReadOnlyFloatWrapper
-
Deprecated.
- ReadOnlyIntegerPropertyBase - Class in org.reactfx.inhibeans.property
-
Deprecated.
- ReadOnlyIntegerPropertyBase() - Constructor for class org.reactfx.inhibeans.property.ReadOnlyIntegerPropertyBase
-
Deprecated.
- ReadOnlyIntegerWrapper - Class in org.reactfx.inhibeans.property
-
Deprecated.
- ReadOnlyIntegerWrapper() - Constructor for class org.reactfx.inhibeans.property.ReadOnlyIntegerWrapper
-
Deprecated.Superclass constructors.
- ReadOnlyIntegerWrapper(int) - Constructor for class org.reactfx.inhibeans.property.ReadOnlyIntegerWrapper
-
Deprecated.
- ReadOnlyIntegerWrapper(Object, String) - Constructor for class org.reactfx.inhibeans.property.ReadOnlyIntegerWrapper
-
Deprecated.
- ReadOnlyIntegerWrapper(Object, String, int) - Constructor for class org.reactfx.inhibeans.property.ReadOnlyIntegerWrapper
-
Deprecated.
- readOnlyIterator(Collection<? extends E>) - Static method in class org.reactfx.util.Lists
- ReadOnlyLongPropertyBase - Class in org.reactfx.inhibeans.property
-
Deprecated.
- ReadOnlyLongPropertyBase() - Constructor for class org.reactfx.inhibeans.property.ReadOnlyLongPropertyBase
-
Deprecated.
- ReadOnlyLongWrapper - Class in org.reactfx.inhibeans.property
-
Deprecated.
- ReadOnlyLongWrapper() - Constructor for class org.reactfx.inhibeans.property.ReadOnlyLongWrapper
-
Deprecated.Superclass constructors.
- ReadOnlyLongWrapper(long) - Constructor for class org.reactfx.inhibeans.property.ReadOnlyLongWrapper
-
Deprecated.
- ReadOnlyLongWrapper(Object, String) - Constructor for class org.reactfx.inhibeans.property.ReadOnlyLongWrapper
-
Deprecated.
- ReadOnlyLongWrapper(Object, String, long) - Constructor for class org.reactfx.inhibeans.property.ReadOnlyLongWrapper
-
Deprecated.
- ReadOnlyObjectPropertyBase<T> - Class in org.reactfx.inhibeans.property
-
Deprecated.
- ReadOnlyObjectPropertyBase() - Constructor for class org.reactfx.inhibeans.property.ReadOnlyObjectPropertyBase
-
Deprecated.
- ReadOnlyObjectWrapper<T> - Class in org.reactfx.inhibeans.property
-
Deprecated.
- ReadOnlyObjectWrapper() - Constructor for class org.reactfx.inhibeans.property.ReadOnlyObjectWrapper
-
Deprecated.Superclass constructors.
- ReadOnlyObjectWrapper(Object, String) - Constructor for class org.reactfx.inhibeans.property.ReadOnlyObjectWrapper
-
Deprecated.
- ReadOnlyObjectWrapper(Object, String, T) - Constructor for class org.reactfx.inhibeans.property.ReadOnlyObjectWrapper
-
Deprecated.
- ReadOnlyObjectWrapper(T) - Constructor for class org.reactfx.inhibeans.property.ReadOnlyObjectWrapper
-
Deprecated.
- ReadOnlyStringPropertyBase - Class in org.reactfx.inhibeans.property
-
Deprecated.
- ReadOnlyStringPropertyBase() - Constructor for class org.reactfx.inhibeans.property.ReadOnlyStringPropertyBase
-
Deprecated.
- ReadOnlyStringWrapper - Class in org.reactfx.inhibeans.property
-
Deprecated.
- ReadOnlyStringWrapper() - Constructor for class org.reactfx.inhibeans.property.ReadOnlyStringWrapper
-
Deprecated.Superclass constructors.
- ReadOnlyStringWrapper(Object, String) - Constructor for class org.reactfx.inhibeans.property.ReadOnlyStringWrapper
-
Deprecated.
- ReadOnlyStringWrapper(Object, String, String) - Constructor for class org.reactfx.inhibeans.property.ReadOnlyStringWrapper
-
Deprecated.
- ReadOnlyStringWrapper(String) - Constructor for class org.reactfx.inhibeans.property.ReadOnlyStringWrapper
-
Deprecated.
- READY - org.reactfx.ThenAccumulateForStream.State
- recover(Function<Throwable, Optional<T>>) - Method in class org.reactfx.util.Failure
- recover(Function<Throwable, Optional<T>>) - Method in class org.reactfx.util.Success
- recover(Function<Throwable, Optional<T>>) - Method in interface org.reactfx.util.Try
- RecursiveStream<T> - Class in org.reactfx
- RecursiveStream(EventStream<T>, NotificationAccumulator<Consumer<? super T>, T, ?>) - Constructor for class org.reactfx.RecursiveStream
- reduce(A, T) - Method in class org.reactfx.SuspendableBase
- reduce(A, T) - Method in interface org.reactfx.util.AccumulationFacility.IllegalAccumulation
- reduce(A, T) - Method in interface org.reactfx.util.AccumulationFacility
- reduce(A, T) - Method in class org.reactfx.util.AccumulativeStreamNotifications
- reduce(Deque<T>, T) - Method in interface org.reactfx.util.AccumulationFacility.Queuing
- reduce(BinaryOperator<E>) - Method in interface org.reactfx.collection.LiveList
- reduce(BinaryOperator<T>) - Method in class org.reactfx.util.ListHelper.MultiElemHelper
- reduce(BinaryOperator<T>) - Method in class org.reactfx.util.ListHelper
- reduce(BinaryOperator<T>) - Method in class org.reactfx.util.ListHelper.SingleElemHelper
- reduce(ObservableList<E>, BinaryOperator<E>) - Static method in interface org.reactfx.collection.LiveList
- reduce(ListModificationSequence<E>, QuasiListChange<? extends E>) - Method in interface org.reactfx.util.AccumulationFacility.ListChangeAccumulation
- reduce(ListHelper<T>, BinaryOperator<T>) - Static method in class org.reactfx.util.ListHelper
- reduce(ListHelper<T>, U, BiFunction<U, T, U>) - Static method in class org.reactfx.util.ListHelper
- reduce(T, T) - Method in class org.reactfx.SuppressibleEventStream
- reduce(T, T) - Method in interface org.reactfx.util.AccumulationFacility.RetainLatest
- reduce(T, T) - Method in interface org.reactfx.util.AccumulationFacility.RetainOldest
- reduce(T, T) - Method in class org.reactfx.util.ReducingStreamNotifications
- reduce(T, T) - Method in interface org.reactfx.util.Semigroup
- reduce(U, BiFunction<U, T, U>) - Method in class org.reactfx.util.ListHelper.MultiElemHelper
- reduce(U, BiFunction<U, T, U>) - Method in class org.reactfx.util.ListHelper
- reduce(U, BiFunction<U, T, U>) - Method in class org.reactfx.util.ListHelper.SingleElemHelper
- reduceBetween(EventStream<?>, BinaryOperator<T>) - Method in interface org.reactfx.EventStream
-
Returns an event stream that, when an event arrives from this stream, stores it for emission.
- reduceRange(ObservableValue<IndexRange>, BinaryOperator<E>) - Method in interface org.reactfx.collection.LiveList
- reduceRange(ObservableList<E>, ObservableValue<IndexRange>, BinaryOperator<E>) - Static method in interface org.reactfx.collection.LiveList
- reduceSuccessions(BinaryOperator<T>, Duration) - Method in interface org.reactfx.EventStream
-
Returns an event stream that accumulates events emitted from this event stream in close temporal succession.
- reduceSuccessions(BinaryOperator<T>, Duration, ScheduledExecutorService, Executor) - Method in interface org.reactfx.EventStream
-
An analog to
EventStream.reduceSuccessions(BinaryOperator, Duration)
to use outside of JavaFX application thread. - reduceSuccessions(Function<? super T, ? extends U>, BiFunction<? super U, ? super T, ? extends U>, Duration) - Method in interface org.reactfx.EventStream
-
A more general version of
EventStream.reduceSuccessions(BinaryOperator, Duration)
that allows the accumulated event to be of different type. - reduceSuccessions(Function<? super T, ? extends U>, BiFunction<? super U, ? super T, ? extends U>, Duration, ScheduledExecutorService, Executor) - Method in interface org.reactfx.EventStream
-
An analog to
EventStream.reduceSuccessions(Function, BiFunction, Duration)
to use outside of JavaFX application thread. - reduceSuccessions(Supplier<? extends U>, BiFunction<? super U, ? super T, ? extends U>, Duration) - Method in interface org.reactfx.EventStream
-
A convenient method that can be used when it is more convenient to supply an identity of the type
U
than to transform an event of typeT
to an event of typeU
. - reduceSuccessions(Supplier<? extends U>, BiFunction<? super U, ? super T, ? extends U>, Duration, ScheduledExecutorService, Executor) - Method in interface org.reactfx.EventStream
-
An analog to
EventStream.reduceSuccessions(Supplier, BiFunction, Duration)
to use outside of JavaFX application thread. - reduceUntilLater(BinaryOperator<T>) - Method in interface org.reactfx.EventStream
-
Returns an event stream that, when an event is emitted from this stream, stores the event for emission and schedules emission using
Platform.runLater(Runnable)
, if not already scheduled. - reduceUntilLater(BinaryOperator<T>, Executor) - Method in interface org.reactfx.EventStream
-
Version of
EventStream.reduceUntilLater(BinaryOperator)
for event streams that don't live on the JavaFX application thread. - reduceWhen(ObservableValue<Boolean>, BinaryOperator<T>) - Method in interface org.reactfx.EventStream
-
Shortcut for
reducible(reduction).suspendedWhen(condition)
. - reducible(BinaryOperator<T>) - Method in interface org.reactfx.EventStream
-
Returns a suspendable event stream that, when suspended, reduces incoming events by the given
reduction
function into one. - ReducibleEventStream<T> - Class in org.reactfx
- ReducibleEventStream(EventStream<T>, BinaryOperator<T>) - Constructor for class org.reactfx.ReducibleEventStream
- reducingStreamNotifications(BinaryOperator<T>) - Static method in interface org.reactfx.util.NotificationAccumulator
- ReducingStreamNotifications<T> - Class in org.reactfx.util
- ReducingStreamNotifications(BinaryOperator<T>) - Constructor for class org.reactfx.util.ReducingStreamNotifications
- reduction - Variable in class org.reactfx.AccumulatingStream
- reduction - Variable in class org.reactfx.collection.ListReduction
- reduction - Variable in class org.reactfx.SuccessionReducingStream
- reduction - Variable in class org.reactfx.ThenAccumulateForStream
- reduction - Variable in class org.reactfx.util.AccumulativeStreamNotifications
- reduction - Variable in class org.reactfx.util.ReducingStreamNotifications
- release() - Method in class org.reactfx.Indicator
-
Deprecated.
- release() - Method in class org.reactfx.inhibeans.binding.BooleanBinding
-
Deprecated.
- release() - Method in class org.reactfx.inhibeans.binding.DoubleBinding
-
Deprecated.
- release() - Method in class org.reactfx.inhibeans.binding.FloatBinding
-
Deprecated.
- release() - Method in class org.reactfx.inhibeans.binding.IntegerBinding
-
Deprecated.
- release() - Method in class org.reactfx.inhibeans.binding.LongBinding
-
Deprecated.
- release() - Method in class org.reactfx.inhibeans.binding.ObjectBinding
-
Deprecated.
- release() - Method in class org.reactfx.inhibeans.binding.StringBinding
-
Deprecated.
- release() - Method in class org.reactfx.inhibeans.property.BooleanPropertyBase
-
Deprecated.
- release() - Method in class org.reactfx.inhibeans.property.DoublePropertyBase
-
Deprecated.
- release() - Method in class org.reactfx.inhibeans.property.FloatPropertyBase
-
Deprecated.
- release() - Method in class org.reactfx.inhibeans.property.IntegerPropertyBase
-
Deprecated.
- release() - Method in class org.reactfx.inhibeans.property.LongPropertyBase
-
Deprecated.
- release() - Method in class org.reactfx.inhibeans.property.ObjectPropertyBase
-
Deprecated.
- release() - Method in class org.reactfx.inhibeans.property.ReadOnlyBooleanPropertyBase
-
Deprecated.
- release() - Method in class org.reactfx.inhibeans.property.ReadOnlyBooleanWrapper
-
Deprecated.
- release() - Method in class org.reactfx.inhibeans.property.ReadOnlyDoublePropertyBase
-
Deprecated.
- release() - Method in class org.reactfx.inhibeans.property.ReadOnlyDoubleWrapper
-
Deprecated.
- release() - Method in class org.reactfx.inhibeans.property.ReadOnlyFloatPropertyBase
-
Deprecated.
- release() - Method in class org.reactfx.inhibeans.property.ReadOnlyFloatWrapper
-
Deprecated.
- release() - Method in class org.reactfx.inhibeans.property.ReadOnlyIntegerPropertyBase
-
Deprecated.
- release() - Method in class org.reactfx.inhibeans.property.ReadOnlyIntegerWrapper
-
Deprecated.
- release() - Method in class org.reactfx.inhibeans.property.ReadOnlyLongPropertyBase
-
Deprecated.
- release() - Method in class org.reactfx.inhibeans.property.ReadOnlyLongWrapper
-
Deprecated.
- release() - Method in class org.reactfx.inhibeans.property.ReadOnlyObjectPropertyBase
-
Deprecated.
- release() - Method in class org.reactfx.inhibeans.property.ReadOnlyObjectWrapper
-
Deprecated.
- release() - Method in class org.reactfx.inhibeans.property.ReadOnlyStringPropertyBase
-
Deprecated.
- release() - Method in class org.reactfx.inhibeans.property.ReadOnlyStringWrapper
-
Deprecated.
- release() - Method in class org.reactfx.inhibeans.property.SimpleBooleanProperty
-
Deprecated.
- release() - Method in class org.reactfx.inhibeans.property.SimpleDoubleProperty
-
Deprecated.
- release() - Method in class org.reactfx.inhibeans.property.SimpleFloatProperty
-
Deprecated.
- release() - Method in class org.reactfx.inhibeans.property.SimpleIntegerProperty
-
Deprecated.
- release() - Method in class org.reactfx.inhibeans.property.SimpleLongProperty
-
Deprecated.
- release() - Method in class org.reactfx.inhibeans.property.SimpleObjectProperty
-
Deprecated.
- release() - Method in class org.reactfx.inhibeans.property.SimpleStringProperty
-
Deprecated.
- release() - Method in class org.reactfx.inhibeans.property.StringPropertyBase
-
Deprecated.
- release() - Method in class org.reactfx.inhibeans.value.ObservableValueBase
-
Deprecated.
- release() - Method in class org.reactfx.SuspendableBoolean
- remainingInvocations - Variable in class org.reactfx.LimitedInvocationSubscriber
- remove() - Method in class org.reactfx.collection.ListIteratorImpl
- remove(int) - Method in class org.reactfx.collection.LiveArrayList
- remove(int) - Method in class org.reactfx.collection.SubList
- remove(int) - Method in class org.reactfx.collection.SuspendableListWrapper
- remove(int) - Method in interface org.reactfx.collection.UnmodifiableByDefaultList
- remove(int) - Method in class org.reactfx.util.SparseList
- remove(int, int) - Method in class org.reactfx.collection.LiveArrayList
- remove(int, int) - Method in class org.reactfx.collection.SuspendableListWrapper
- remove(int, int) - Method in interface org.reactfx.collection.UnmodifiableByDefaultLiveList
- remove(int, int) - Method in class org.reactfx.util.SparseList
- remove(Object) - Method in class org.reactfx.collection.LiveArrayList
- remove(Object) - Method in class org.reactfx.collection.SuspendableListWrapper
- remove(Object) - Method in interface org.reactfx.collection.UnmodifiableByDefaultList
- remove(K) - Method in class org.reactfx.util.MapHelper.MultiEntryHelper
- remove(K) - Method in class org.reactfx.util.MapHelper
- remove(K) - Method in class org.reactfx.util.MapHelper.SingleEntryHelper
- remove(ListHelper<T>, T) - Static method in class org.reactfx.util.ListHelper
- remove(MapHelper<K, V>, K) - Static method in class org.reactfx.util.MapHelper
- remove(T) - Method in class org.reactfx.util.ListHelper.MultiElemHelper
- remove(T) - Method in class org.reactfx.util.ListHelper
- remove(T) - Method in class org.reactfx.util.ListHelper.SingleElemHelper
- removeAll(E...) - Method in class org.reactfx.collection.LiveArrayList
- removeAll(E...) - Method in class org.reactfx.collection.SuspendableListWrapper
- removeAll(E...) - Method in interface org.reactfx.collection.UnmodifiableByDefaultLiveList
- removeAll(Collection<?>) - Method in class org.reactfx.collection.LiveArrayList
- removeAll(Collection<?>) - Method in class org.reactfx.collection.SuspendableListWrapper
- removeAll(Collection<?>) - Method in interface org.reactfx.collection.UnmodifiableByDefaultList
- removeChangeObserver(Consumer<? super ListChange<? extends E>>) - Method in interface org.reactfx.collection.LiveList
- removed - Variable in class org.reactfx.collection.ListModificationImpl
- removed - Variable in class org.reactfx.collection.MaterializedListModificationImpl
- removed - Variable in class org.reactfx.collection.QuasiListModificationImpl
- removeInvalidationObserver(Consumer<? super T>) - Method in interface org.reactfx.value.Val
- removeLeafs(int, int) - Method in class org.reactfx.util.FingerTree
- removeListener(InvalidationListener) - Method in interface org.reactfx.collection.LiveList
- removeListener(InvalidationListener) - Method in class org.reactfx.Indicator
-
Deprecated.
- removeListener(InvalidationListener) - Method in class org.reactfx.inhibeans.binding.BooleanBinding
-
Deprecated.
- removeListener(InvalidationListener) - Method in class org.reactfx.inhibeans.binding.DoubleBinding
-
Deprecated.
- removeListener(InvalidationListener) - Method in class org.reactfx.inhibeans.binding.FloatBinding
-
Deprecated.
- removeListener(InvalidationListener) - Method in class org.reactfx.inhibeans.binding.IntegerBinding
-
Deprecated.
- removeListener(InvalidationListener) - Method in class org.reactfx.inhibeans.binding.LongBinding
-
Deprecated.
- removeListener(InvalidationListener) - Method in class org.reactfx.inhibeans.binding.ObjectBinding
-
Deprecated.
- removeListener(InvalidationListener) - Method in class org.reactfx.inhibeans.binding.StringBinding
-
Deprecated.
- removeListener(InvalidationListener) - Method in class org.reactfx.inhibeans.ObservableBase
-
Deprecated.
- removeListener(InvalidationListener) - Method in interface org.reactfx.value.Val
- removeListener(ChangeListener<? super Boolean>) - Method in class org.reactfx.Indicator
-
Deprecated.
- removeListener(ChangeListener<? super Boolean>) - Method in class org.reactfx.inhibeans.binding.BooleanBinding
-
Deprecated.
- removeListener(ChangeListener<? super Number>) - Method in class org.reactfx.inhibeans.binding.DoubleBinding
-
Deprecated.
- removeListener(ChangeListener<? super Number>) - Method in class org.reactfx.inhibeans.binding.FloatBinding
-
Deprecated.
- removeListener(ChangeListener<? super Number>) - Method in class org.reactfx.inhibeans.binding.IntegerBinding
-
Deprecated.
- removeListener(ChangeListener<? super Number>) - Method in class org.reactfx.inhibeans.binding.LongBinding
-
Deprecated.
- removeListener(ChangeListener<? super String>) - Method in class org.reactfx.inhibeans.binding.StringBinding
-
Deprecated.
- removeListener(ChangeListener<? super T>) - Method in class org.reactfx.inhibeans.binding.ObjectBinding
-
Deprecated.
- removeListener(ChangeListener<? super T>) - Method in interface org.reactfx.value.Val
- removeListener(ListChangeListener<? super E>) - Method in interface org.reactfx.collection.LiveList
- removeModificationObserver(Consumer<? super ListModification<? extends E>>) - Method in interface org.reactfx.collection.LiveList
- removeObserver(O) - Method in interface org.reactfx.Observable
- removeObserver(O) - Method in class org.reactfx.ObservableBase
- removeObserver(O) - Method in class org.reactfx.ProxyObservable
- removeObserver(O) - Method in class org.reactfx.RigidObservable
-
Removing an observer from a RigidObservable is a no-op.
- removeQuasiChangeObserver(LiveList.QuasiChangeObserver<? super E>) - Method in interface org.reactfx.collection.LiveList
- removeQuasiModificationObserver(LiveList.QuasiModificationObserver<? super E>) - Method in interface org.reactfx.collection.LiveList
- repeatOn(EventStream<?>) - Method in interface org.reactfx.EventStream
-
Returns a new event stream that emits all the events emitted from this stream and in addition to that re-emits the most recent event on every event emitted from
impulse
. - repeatOnInvalidation(O) - Static method in class org.reactfx.EventStreams
-
Creates an event stream that emits the given observable immediately for every subscriber and re-emits it on every subsequent invalidation of the observable.
- RepeatOnStream<T> - Class in org.reactfx
- RepeatOnStream(EventStream<T>, EventStream<?>) - Constructor for class org.reactfx.RepeatOnStream
- replaceAll(BiFunction<? super K, ? super V, ? extends V>) - Method in class org.reactfx.util.MapHelper.MultiEntryHelper
- replaceAll(BiFunction<? super K, ? super V, ? extends V>) - Method in class org.reactfx.util.MapHelper
- replaceAll(BiFunction<? super K, ? super V, ? extends V>) - Method in class org.reactfx.util.MapHelper.SingleEntryHelper
- replaceAll(MapHelper<K, V>, BiFunction<? super K, ? super V, ? extends V>) - Static method in class org.reactfx.util.MapHelper
- replaceExpected(F) - Method in class org.reactfx.AwaitLatest
- reset() - Method in class org.reactfx.AccumulateBetweenStream
- reset() - Method in class org.reactfx.SuspendableBase
- restart() - Method in class org.reactfx.ScheduledExecutorServiceTimer
- restart() - Method in class org.reactfx.util.FxTimer
- restart() - Method in interface org.reactfx.util.Timer
-
Schedules the associated action to be executed after the associated delay.
- restartableTicks(Duration, EventStream<?>) - Static method in class org.reactfx.EventStreams
-
Returns a
EventStreams.ticks(Duration)
EventStream whose timer restarts whenever impulse emits an event. - restartableTicks0(Duration, EventStream<?>) - Static method in class org.reactfx.EventStreams
-
Returns a
EventStreams.ticks0(Duration)
EventStream whose timer restarts whenever impulse emits an event. - resume() - Method in class org.reactfx.SuspendableBase
- RetailOldestValNotifications<T> - Class in org.reactfx.util
- RetailOldestValNotifications() - Constructor for class org.reactfx.util.RetailOldestValNotifications
- retainAll(E...) - Method in class org.reactfx.collection.LiveArrayList
- retainAll(E...) - Method in class org.reactfx.collection.SuspendableListWrapper
- retainAll(E...) - Method in interface org.reactfx.collection.UnmodifiableByDefaultLiveList
- retainAll(Collection<?>) - Method in class org.reactfx.collection.LiveArrayList
- retainAll(Collection<?>) - Method in class org.reactfx.collection.SuspendableListWrapper
- retainAll(Collection<?>) - Method in interface org.reactfx.collection.UnmodifiableByDefaultList
- retainLatestBetween(EventStream<?>) - Method in interface org.reactfx.EventStream
-
Equivalent to
EventStream.emitOn(EventStream)
. - retainLatestStreamNotifications() - Static method in interface org.reactfx.util.NotificationAccumulator
- RetainLatestStreamNotifications<T> - Class in org.reactfx.util
- RetainLatestStreamNotifications() - Constructor for class org.reactfx.util.RetainLatestStreamNotifications
- retainLatestUntilLater() - Method in interface org.reactfx.EventStream
-
Returns an event stream that, when an event is emitted from this stream, stores the event for emission and schedules emission using
Platform.runLater(Runnable)
, if not already scheduled. - retainLatestUntilLater(Executor) - Method in interface org.reactfx.EventStream
-
Version of
EventStream.retainLatestUntilLater()
for event streams that don't live on the JavaFX application thread. - retainLatestWhen(ObservableValue<Boolean>) - Method in interface org.reactfx.EventStream
-
Shortcut for
forgetful().suspendedWhen(condition)
. - retainOldestValNotifications() - Static method in interface org.reactfx.util.NotificationAccumulator
- revision - Variable in class org.reactfx.AwaitLatest
- right(R) - Static method in interface org.reactfx.util.Either
- Right<L,R> - Class in org.reactfx.util
- Right(R) - Constructor for class org.reactfx.util.Right
- rightOrDefault(Optional<R>, L) - Static method in interface org.reactfx.util.Either
- rightOrNull(Optional<R>) - Static method in interface org.reactfx.util.Either
- RigidObservable<O> - Class in org.reactfx
-
An observable that does not change and does not produce any notifications.
- RigidObservable() - Constructor for class org.reactfx.RigidObservable
- runLater(Duration, Runnable) - Static method in class org.reactfx.util.FxTimer
-
Equivalent to
create(delay, action).restart()
. - runPeriodically(Duration, Runnable) - Static method in class org.reactfx.util.FxTimer
-
Equivalent to
createPeriodic(interval, action).restart()
. - runPeriodically0(Duration, Runnable) - Static method in class org.reactfx.util.FxTimer
-
Equivalent to
createPeriodic0(interval, action).restart()
.
S
- s1 - Variable in class org.reactfx.BiSubscription
- s1 - Variable in class org.reactfx.BiSuspendable
- s2 - Variable in class org.reactfx.BiSubscription
- s2 - Variable in class org.reactfx.BiSuspendable
- safeCast(QuasiListChange<? extends E>) - Static method in interface org.reactfx.collection.QuasiListChange
- ScheduledExecutorServiceTimer - Class in org.reactfx
- ScheduledExecutorServiceTimer(Duration, Runnable, TriFunction<Long, TimeUnit, Runnable, ScheduledFuture<?>>, Executor) - Constructor for class org.reactfx.ScheduledExecutorServiceTimer
- scheduler - Variable in class org.reactfx.ScheduledExecutorServiceTimer
- second - Variable in class org.reactfx.LatestNStream
- second - Variable in class org.reactfx.util.ConcatView
- SEGMENT_STATS - Static variable in class org.reactfx.util.SparseList
- selectedInvalidated() - Method in class org.reactfx.value.FlatMapped
- selectedSubscription - Variable in class org.reactfx.value.FlatMapped
- selectVar(Function<? super T, ? extends Property<U>>) - Method in interface org.reactfx.value.Val
-
Similar to
Val.flatMap(Function)
, except the returned Val is also a Var. - selectVar(Function<? super T, ? extends Property<U>>, U) - Method in interface org.reactfx.value.Val
- selectVar(ObservableValue<T>, Function<? super T, ? extends Property<U>>) - Static method in interface org.reactfx.value.Val
- selectVar(ObservableValue<T>, Function<? super T, ? extends Property<U>>, U) - Static method in interface org.reactfx.value.Val
- semigroup - Variable in class org.reactfx.util.FingerTree
- Semigroup<T> - Interface in org.reactfx.util
- seq - Variable in class org.reactfx.ScheduledExecutorServiceTimer
- seq - Variable in class org.reactfx.util.FxTimer
- set(int, E) - Method in class org.reactfx.collection.LiveArrayList
- set(int, E) - Method in class org.reactfx.collection.SubList
- set(int, E) - Method in class org.reactfx.collection.SuspendableListWrapper
- set(int, E) - Method in interface org.reactfx.collection.UnmodifiableByDefaultList
- set(int, E) - Method in class org.reactfx.util.SparseList
- set(E) - Method in class org.reactfx.collection.ListIteratorImpl
- set(T) - Method in class org.reactfx.EventStreams.ExclusivePocket
- set(T) - Method in class org.reactfx.EventStreams.Pocket
- setAll(E...) - Method in class org.reactfx.collection.LiveArrayList
- setAll(E...) - Method in class org.reactfx.collection.SuspendableListWrapper
- setAll(E...) - Method in interface org.reactfx.collection.UnmodifiableByDefaultLiveList
- setAll(Collection<? extends E>) - Method in class org.reactfx.collection.LiveArrayList
- setAll(Collection<? extends E>) - Method in class org.reactfx.collection.SuspendableListWrapper
- setAll(Collection<? extends E>) - Method in interface org.reactfx.collection.UnmodifiableByDefaultLiveList
- setDuration(Duration) - Method in class org.reactfx.value.AnimatedVal.FractionTransition
- setExpected(F) - Method in class org.reactfx.AwaitLatest
- setIfAbsent(int, E) - Method in class org.reactfx.util.SparseList
- setOrThrow(int, E) - Method in class org.reactfx.util.SparseList.AbsentSegment
- setOrThrow(int, E) - Method in class org.reactfx.util.SparseList.PresentSegment
- setOrThrow(int, E) - Method in interface org.reactfx.util.SparseList.Segment
- setState(ThenAccumulateForStream.State) - Method in class org.reactfx.ThenAccumulateForStream
- setter - Variable in class org.reactfx.value.VarFromVal
- setValue(T) - Method in class org.reactfx.value.SimpleVar
- setValue(T) - Method in class org.reactfx.value.SuspendableVarWrapper
- setValue(T) - Method in class org.reactfx.value.VarFromVal
- setValue(T) - Method in class org.reactfx.value.VarWrapper
- setValue(U) - Method in class org.reactfx.value.FlatMappedVar
- showingProperty(Node) - Static method in interface org.reactfx.value.Val
-
Returns a Val whose value is
true
whennode
is showing: it is part of a scene graph (Node.sceneProperty()
is notnull
), its scene is part of a window (Scene.windowProperty()
is notnull
) and the window is showing (Window.showingProperty()
istrue
). - sideEffect - Variable in class org.reactfx.HookStream
- sideEffectInProgress - Variable in class org.reactfx.HookStream
- SimpleBooleanProperty - Class in org.reactfx.inhibeans.property
-
Deprecated.
- SimpleBooleanProperty() - Constructor for class org.reactfx.inhibeans.property.SimpleBooleanProperty
-
Deprecated.Superclass constructors.
- SimpleBooleanProperty(boolean) - Constructor for class org.reactfx.inhibeans.property.SimpleBooleanProperty
-
Deprecated.
- SimpleBooleanProperty(Object, String) - Constructor for class org.reactfx.inhibeans.property.SimpleBooleanProperty
-
Deprecated.
- SimpleBooleanProperty(Object, String, boolean) - Constructor for class org.reactfx.inhibeans.property.SimpleBooleanProperty
-
Deprecated.
- simpleChangesOf(ObservableList<T>) - Static method in class org.reactfx.EventStreams
-
Use only when the subscriber does not cause
list
modification of the underlying list. - SimpleDoubleProperty - Class in org.reactfx.inhibeans.property
-
Deprecated.
- SimpleDoubleProperty() - Constructor for class org.reactfx.inhibeans.property.SimpleDoubleProperty
-
Deprecated.Superclass constructors.
- SimpleDoubleProperty(double) - Constructor for class org.reactfx.inhibeans.property.SimpleDoubleProperty
-
Deprecated.
- SimpleDoubleProperty(Object, String) - Constructor for class org.reactfx.inhibeans.property.SimpleDoubleProperty
-
Deprecated.
- SimpleDoubleProperty(Object, String, double) - Constructor for class org.reactfx.inhibeans.property.SimpleDoubleProperty
-
Deprecated.
- SimpleFloatProperty - Class in org.reactfx.inhibeans.property
-
Deprecated.
- SimpleFloatProperty() - Constructor for class org.reactfx.inhibeans.property.SimpleFloatProperty
-
Deprecated.Superclass constructors.
- SimpleFloatProperty(float) - Constructor for class org.reactfx.inhibeans.property.SimpleFloatProperty
-
Deprecated.
- SimpleFloatProperty(Object, String) - Constructor for class org.reactfx.inhibeans.property.SimpleFloatProperty
-
Deprecated.
- SimpleFloatProperty(Object, String, float) - Constructor for class org.reactfx.inhibeans.property.SimpleFloatProperty
-
Deprecated.
- SimpleIntegerProperty - Class in org.reactfx.inhibeans.property
-
Deprecated.
- SimpleIntegerProperty() - Constructor for class org.reactfx.inhibeans.property.SimpleIntegerProperty
-
Deprecated.Superclass constructors.
- SimpleIntegerProperty(int) - Constructor for class org.reactfx.inhibeans.property.SimpleIntegerProperty
-
Deprecated.
- SimpleIntegerProperty(Object, String) - Constructor for class org.reactfx.inhibeans.property.SimpleIntegerProperty
-
Deprecated.
- SimpleIntegerProperty(Object, String, int) - Constructor for class org.reactfx.inhibeans.property.SimpleIntegerProperty
-
Deprecated.
- SimpleLongProperty - Class in org.reactfx.inhibeans.property
-
Deprecated.
- SimpleLongProperty() - Constructor for class org.reactfx.inhibeans.property.SimpleLongProperty
-
Deprecated.Superclass constructors.
- SimpleLongProperty(long) - Constructor for class org.reactfx.inhibeans.property.SimpleLongProperty
-
Deprecated.
- SimpleLongProperty(Object, String) - Constructor for class org.reactfx.inhibeans.property.SimpleLongProperty
-
Deprecated.
- SimpleLongProperty(Object, String, long) - Constructor for class org.reactfx.inhibeans.property.SimpleLongProperty
-
Deprecated.
- SimpleObjectProperty<T> - Class in org.reactfx.inhibeans.property
-
Deprecated.
- SimpleObjectProperty() - Constructor for class org.reactfx.inhibeans.property.SimpleObjectProperty
-
Deprecated.Superclass constructors.
- SimpleObjectProperty(Object, String) - Constructor for class org.reactfx.inhibeans.property.SimpleObjectProperty
-
Deprecated.
- SimpleObjectProperty(Object, String, T) - Constructor for class org.reactfx.inhibeans.property.SimpleObjectProperty
-
Deprecated.
- SimpleObjectProperty(T) - Constructor for class org.reactfx.inhibeans.property.SimpleObjectProperty
-
Deprecated.
- SimpleStringProperty - Class in org.reactfx.inhibeans.property
-
Deprecated.
- SimpleStringProperty() - Constructor for class org.reactfx.inhibeans.property.SimpleStringProperty
-
Deprecated.Superclass constructors.
- SimpleStringProperty(Object, String) - Constructor for class org.reactfx.inhibeans.property.SimpleStringProperty
-
Deprecated.
- SimpleStringProperty(Object, String, String) - Constructor for class org.reactfx.inhibeans.property.SimpleStringProperty
-
Deprecated.
- SimpleStringProperty(String) - Constructor for class org.reactfx.inhibeans.property.SimpleStringProperty
-
Deprecated.
- SimpleVar<T> - Class in org.reactfx.value
- SimpleVar(T) - Constructor for class org.reactfx.value.SimpleVar
- SingleElemHelper(T) - Constructor for class org.reactfx.util.ListHelper.SingleElemHelper
- SingleEntryHelper(K, V) - Constructor for class org.reactfx.util.MapHelper.SingleEntryHelper
- size - Variable in class org.reactfx.AccumulativeEventStream
- size - Variable in class org.reactfx.util.AccumulativeStreamNotifications
- size - Variable in class org.reactfx.util.LL.Cons
- size - Variable in class org.reactfx.util.SparseList.Stats
- size() - Method in class org.reactfx.collection.DynamicallyMappedList
- size() - Method in class org.reactfx.collection.LiveArrayList
- size() - Method in class org.reactfx.collection.MappedList
- size() - Method in class org.reactfx.collection.MemoizationListImpl.MemoizedView
- size() - Method in class org.reactfx.collection.MemoizationListImpl
- size() - Method in class org.reactfx.collection.SubList
- size() - Method in class org.reactfx.collection.SuspendableListWrapper
- size() - Method in class org.reactfx.collection.ValAsList
- size() - Method in class org.reactfx.util.ConcatView
- size() - Method in class org.reactfx.util.ListConcatenation
- size() - Method in class org.reactfx.util.ListHelper.MultiElemHelper
- size() - Method in class org.reactfx.util.ListHelper.SingleElemHelper
- size() - Method in class org.reactfx.util.ListHelper
- size() - Method in class org.reactfx.util.LL.Cons
- size() - Method in class org.reactfx.util.LL.Nil
- size() - Method in class org.reactfx.util.LL
- size() - Method in class org.reactfx.util.MapHelper.MultiEntryHelper
- size() - Method in class org.reactfx.util.MapHelper.SingleEntryHelper
- size() - Method in class org.reactfx.util.MapHelper
- size() - Method in class org.reactfx.util.SparseList
- size(Consumer<? super T>, A) - Method in class org.reactfx.util.AccumulativeStreamNotifications
- size(Consumer<? super T>, Deque<T>) - Method in class org.reactfx.util.QueuingStreamNotifications
- size(Consumer<? super T>, T) - Method in class org.reactfx.util.AbstractReducingStreamNotifications
- size(Consumer<? super T>, T) - Method in class org.reactfx.util.NonAccumulativeStreamNotifications
- size(O, A) - Method in class org.reactfx.util.NotificationAccumulatorBase
- size(LiveList.Observer<? super E, ?>, ListModificationSequence<E>) - Method in class org.reactfx.util.ListNotifications
- size(ListHelper<T>) - Static method in class org.reactfx.util.ListHelper
- size(MapHelper<K, V>) - Static method in class org.reactfx.util.MapHelper
- sizeOf(A) - Method in class org.reactfx.AccumulativeEventStream
- sizeOf(A) - Method in class org.reactfx.SuspendableBase
- sizeOf(C) - Static method in class org.reactfx.EventStreams
- sizeOf(Deque<T>) - Method in class org.reactfx.PausableEventStream
- sizeOf(ObservableList<?>) - Static method in interface org.reactfx.collection.LiveList
- sizeOf(ObservableMap<?, ?>) - Static method in class org.reactfx.EventStreams
- sizeOf(ListModificationSequence<? extends E>) - Method in interface org.reactfx.collection.LiveList.Observer
- sizeOf(ListModificationSequence<? extends E>) - Method in interface org.reactfx.collection.LiveList.QuasiChangeObserver
- sizeOf(ListModificationSequence<? extends E>) - Method in interface org.reactfx.collection.LiveList.QuasiModificationObserver
- sizeOf(ListModificationSequence<E>) - Method in class org.reactfx.collection.SuspendableListWrapper
- sizeOf(T) - Method in class org.reactfx.AbstractReducibleEventStream
- sizeOf(T) - Method in class org.reactfx.SuppressibleEventStream
- sizeOf(T) - Method in class org.reactfx.value.SuspendableValWrapper
- sizeProperty() - Method in interface org.reactfx.collection.LiveList
- source - Variable in class org.reactfx.AccumulateBetweenStream
- source - Variable in class org.reactfx.AccumulateUntilLaterStream
- source - Variable in class org.reactfx.Await
- source - Variable in class org.reactfx.AwaitLatest
- source - Variable in class org.reactfx.collection.DynamicallyMappedList
- source - Variable in class org.reactfx.collection.MappedList
- source - Variable in class org.reactfx.collection.MemoizationListImpl
- source - Variable in class org.reactfx.EmitBothOnEachStream
- source - Variable in class org.reactfx.EmitOnEachStream
- source - Variable in class org.reactfx.EmitOnStream
- source - Variable in class org.reactfx.FilterMapStream
- source - Variable in class org.reactfx.FilterStream
- source - Variable in class org.reactfx.FlatMapOptStream
- source - Variable in class org.reactfx.FlatMapStream
- source - Variable in class org.reactfx.HookStream
- source - Variable in class org.reactfx.LatestNStream
- source - Variable in class org.reactfx.RepeatOnStream
- source - Variable in class org.reactfx.SuspendedWhenStream
- source - Variable in class org.reactfx.SuspenderStreamImpl
- sourceChanged(QuasiListChange<? extends E>) - Method in class org.reactfx.collection.DynamicallyMappedList
- sourceChanged(QuasiListChange<? extends E>) - Method in class org.reactfx.collection.MappedList
- sourceChanged(QuasiListChange<? extends E>) - Method in class org.reactfx.collection.MemoizationListImpl
- sourceThreadExecutor - Variable in class org.reactfx.ThreadBridge
- sparseList - Variable in class org.reactfx.collection.MemoizationListImpl
- SparseList<E> - Class in org.reactfx.util
- SparseList() - Constructor for class org.reactfx.util.SparseList
- SparseList.AbsentSegment<E> - Class in org.reactfx.util
- SparseList.PresentSegment<E> - Class in org.reactfx.util
- SparseList.Segment<E> - Interface in org.reactfx.util
- SparseList.Stats - Class in org.reactfx.util
- splice(int, int, Collection<? extends E>) - Method in class org.reactfx.util.SparseList
- spliceByVoid(int, int, int) - Method in class org.reactfx.util.SparseList
- spliceSegments(int, int, List<SparseList.Segment<E>>) - Method in class org.reactfx.util.SparseList
- split(int) - Method in class org.reactfx.util.FingerTree
- split(BiFunction<? super S, Integer, Either<Integer, Integer>>, int) - Method in class org.reactfx.util.FingerTree.NonEmptyFingerTree
- split(ToIntFunction<? super S>, int) - Method in class org.reactfx.util.FingerTree.NonEmptyFingerTree
- split0(int) - Method in class org.reactfx.util.FingerTree.Branch
- split0(int) - Method in class org.reactfx.util.FingerTree.Empty
- split0(int) - Method in class org.reactfx.util.FingerTree.Leaf
- split0(int) - Method in class org.reactfx.util.FingerTree
- split0(int, LL<? extends FingerTree<T, S>>) - Method in class org.reactfx.util.FingerTree.Branch
- splitAt(int) - Method in class org.reactfx.util.FingerTree.NonEmptyFingerTree
- splitBy(Predicate<? super T>) - Method in interface org.reactfx.EventStream
-
Returns a new event stream that, for event
e
emitted from this stream, emitsleft(e)
ife
passes the given test, and emitsright(e)
ife
does not pass the test. - src - Variable in class org.reactfx.value.AnimatedVal
- src - Variable in class org.reactfx.value.FlatMapped
- src - Variable in class org.reactfx.value.MappedVal
- src - Variable in class org.reactfx.value.OrElse
- src - Variable in class org.reactfx.value.OrElseConst
- srcInvalidated() - Method in class org.reactfx.value.FlatMapped
- srcListenerWhenBound - Variable in class org.reactfx.value.FlatMappedVar
- startObservingSelected() - Method in class org.reactfx.value.FlatMapped
- state - Variable in class org.reactfx.StatefulStream
- state - Variable in class org.reactfx.StateStream
- state - Variable in class org.reactfx.ThenAccumulateForStream
- State() - Constructor for enum org.reactfx.ThenAccumulateForStream.State
- StatefulStream<S,O> - Class in org.reactfx
- StatefulStream(S, LL<TransitionBuilder<S>>, LL<EmissionBuilder<S, O>>, LL<TransmissionBuilder<S, O>>) - Constructor for class org.reactfx.StatefulStream
- StatefulStreamBuilderImpl<S,O> - Class in org.reactfx
- StatefulStreamBuilderImpl(S, LL<TransitionBuilder<S>>, LL<EmissionBuilder<S, O>>, LL<TransmissionBuilder<S, O>>) - Constructor for class org.reactfx.StatefulStreamBuilderImpl
- StatefulStreamBuilderOnImpl<S,O,I> - Class in org.reactfx
- StatefulStreamBuilderOnImpl(S, LL<TransitionBuilder<S>>, LL<EmissionBuilder<S, O>>, LL<TransmissionBuilder<S, O>>, EventStream<I>) - Constructor for class org.reactfx.StatefulStreamBuilderOnImpl
- StateMachine - Class in org.reactfx
- StateMachine() - Constructor for class org.reactfx.StateMachine
- StateMachine.InitialState<S> - Interface in org.reactfx
- StateMachine.ObservableStateBuilder<S> - Interface in org.reactfx
- StateMachine.ObservableStateBuilderOn<S,I> - Interface in org.reactfx
- StateMachine.StatefulStreamBuilder<S,O> - Interface in org.reactfx
- StateMachine.StatefulStreamBuilderOn<S,O,I> - Interface in org.reactfx
- StateStream<S> - Class in org.reactfx
- StateStream(S, LL<TransitionBuilder<S>>) - Constructor for class org.reactfx.StateStream
- Stats(int, int) - Constructor for class org.reactfx.util.SparseList.Stats
- stop() - Method in class org.reactfx.ScheduledExecutorServiceTimer
- stop() - Method in class org.reactfx.util.FxTimer
- stop() - Method in interface org.reactfx.util.Timer
-
If the associated action has been scheduled for execution but not yet executed, this method prevents it from being executed at all.
- stopObservingSelected() - Method in class org.reactfx.value.FlatMapped
- stream() - Method in class org.reactfx.util.LL
- StreamBinding<T> - Class in org.reactfx
- StreamBinding(EventStream<T>, T) - Constructor for class org.reactfx.StreamBinding
- StringBinding - Class in org.reactfx.inhibeans.binding
-
Deprecated.
- StringBinding() - Constructor for class org.reactfx.inhibeans.binding.StringBinding
-
Deprecated.
- StringPropertyBase - Class in org.reactfx.inhibeans.property
-
Deprecated.
- StringPropertyBase() - Constructor for class org.reactfx.inhibeans.property.StringPropertyBase
-
Deprecated.Superclass constructors.
- StringPropertyBase(String) - Constructor for class org.reactfx.inhibeans.property.StringPropertyBase
-
Deprecated.
- subList(int, int) - Method in interface org.reactfx.collection.AccessorListMethods
- subList(int, int) - Method in class org.reactfx.collection.SuspendableListWrapper
- subList(int, int) - Method in class org.reactfx.util.FingerTree.Branch
-
Complexity of calling once: O(log(n)).
- subList(int, int) - Method in class org.reactfx.util.ListConcatenation
- SubList<E> - Class in org.reactfx.collection
- SubList(List<E>, int, int) - Constructor for class org.reactfx.collection.SubList
- subList0(int, int) - Method in class org.reactfx.util.FingerTree.Branch
- subscribe(Consumer<? super T>) - Method in interface org.reactfx.EventStream
-
Get notified every time this event stream emits a value.
- subscribeFor(int, Consumer<? super T>) - Method in interface org.reactfx.EventStream
-
Subscribes to this event stream for at most
n
events. - subscribeForOne(Consumer<? super T>) - Method in interface org.reactfx.EventStream
-
Shorthand for
subscribeFor(1, subscriber)
. - subscriber - Variable in class org.reactfx.LimitedInvocationSubscriber
- subscribeTo(EventStream<? extends T>) - Method in class org.reactfx.LimitedInvocationSubscriber
- subscribeToInput() - Method in interface org.reactfx.InputHandler
- subscribeToInput(EventStream<? extends T>) - Method in class org.reactfx.ConnectableEventSource
- subscription - Variable in class org.reactfx.LimitedInvocationSubscriber
- subscription - Variable in class org.reactfx.StreamBinding
- Subscription - Interface in org.reactfx
- subscriptions - Variable in class org.reactfx.ConnectableEventSource
- subscriptions - Variable in class org.reactfx.MultiSubscription
- subSegment(int, int) - Method in class org.reactfx.util.SparseList.AbsentSegment
- subSegment(int, int) - Method in class org.reactfx.util.SparseList.PresentSegment
- subSegment(int, int) - Method in interface org.reactfx.util.SparseList.Segment
- success(T) - Static method in interface org.reactfx.util.Try
- Success<T> - Class in org.reactfx.util
- Success(T) - Constructor for class org.reactfx.util.Success
- successionEnds(Duration) - Method in interface org.reactfx.EventStream
-
Returns an event stream that, when events are emitted from this stream in close temporal succession, emits only the last event of the succession.
- successionEnds(Duration, ScheduledExecutorService, Executor) - Method in interface org.reactfx.EventStream
-
An analog to
EventStream.successionEnds(Duration)
to use outside of JavaFX application thread. - SuccessionReducingStream<I,O> - Class in org.reactfx
- SuccessionReducingStream(EventStream<I>, Function<? super I, ? extends O>, BiFunction<? super O, ? super I, ? extends O>, Function<Runnable, Timer>) - Constructor for class org.reactfx.SuccessionReducingStream
- summary - Variable in class org.reactfx.util.FingerTree.Branch
- summary - Variable in class org.reactfx.util.FingerTree.Leaf
- supply(Supplier<? extends U>) - Method in interface org.reactfx.EventStream
-
Returns an event stream that emits a value obtained from the given supplier every time this event stream emits a value.
- supply(U) - Method in interface org.reactfx.EventStream
-
Returns an event stream that emits the given constant value every time this stream emits a value.
- supplyCompletionStage(Supplier<CompletionStage<U>>) - Method in interface org.reactfx.EventStream
-
Similar to
EventStream.supply(Supplier)
, but the returned stream is aCompletionStageStream
, which can be used to await the results of asynchronous computation. - supplyTask(Supplier<Task<U>>) - Method in interface org.reactfx.EventStream
-
Similar to
EventStream.supply(Supplier)
, but the returned stream is aCompletionStageStream
, which can be used to await the results of asynchronous computation. - suppressible() - Method in interface org.reactfx.EventStream
-
Returns a suspendable event stream that, when suspended, suppresses any events emitted by this event stream.
- SuppressibleEventStream<T> - Class in org.reactfx
- SuppressibleEventStream(EventStream<T>) - Constructor for class org.reactfx.SuppressibleEventStream
- suppressWhen(ObservableValue<Boolean>) - Method in interface org.reactfx.EventStream
-
Shortcut for
suppressible().suspendedWhen(condition)
. - suspend() - Method in class org.reactfx.BiSuspendable
- suspend() - Method in class org.reactfx.MultiSuspendable
- suspend() - Method in interface org.reactfx.Suspendable
-
Suspends this suspendable object.
- suspend() - Method in class org.reactfx.SuspendableBase
- suspend() - Method in class org.reactfx.SuspendableBoolean
- suspend() - Method in class org.reactfx.ToggleFromVal
- suspendable - Variable in class org.reactfx.SuspenderBase
- suspendable() - Method in interface org.reactfx.collection.LiveList
- suspendable() - Method in interface org.reactfx.value.Val
- suspendable() - Method in interface org.reactfx.value.Var
- suspendable(Property<T>) - Static method in interface org.reactfx.value.Var
- suspendable(ObservableValue<T>) - Static method in interface org.reactfx.value.Val
- suspendable(ObservableList<E>) - Static method in interface org.reactfx.collection.LiveList
- Suspendable - Interface in org.reactfx
-
Interface for objects that can be temporarily suspended, where the definition of "suspended" depends on the context.
- SuspendableBase<O,T,A> - Class in org.reactfx
- SuspendableBase(EventStream<T>, NotificationAccumulator<O, T, A>) - Constructor for class org.reactfx.SuspendableBase
- SuspendableBoolean - Class in org.reactfx
- SuspendableBoolean() - Constructor for class org.reactfx.SuspendableBoolean
- SuspendableEventStream<T> - Interface in org.reactfx
-
An event stream whose emission of events can be suspended temporarily.
- SuspendableEventStreamBase<T,A> - Class in org.reactfx
- SuspendableEventStreamBase(EventStream<T>, NotificationAccumulator<Consumer<? super T>, T, A>) - Constructor for class org.reactfx.SuspendableEventStreamBase
- SuspendableList<E> - Interface in org.reactfx.collection
- SuspendableListWrapper<E> - Class in org.reactfx.collection
- SuspendableListWrapper(ObservableList<E>) - Constructor for class org.reactfx.collection.SuspendableListWrapper
- SuspendableNo - Class in org.reactfx
-
Observable boolean value that is normally
false
, but istrue
when suspended. - SuspendableNo() - Constructor for class org.reactfx.SuspendableNo
- suspendables - Variable in class org.reactfx.MultiSuspendable
- SuspendableVal<T> - Interface in org.reactfx.value
-
Observable value whose invalidation and change notifications can be temporarily suspended.
- SuspendableValWrapper<T> - Class in org.reactfx.value
- SuspendableValWrapper(Val<T>) - Constructor for class org.reactfx.value.SuspendableValWrapper
- SuspendableVar<T> - Interface in org.reactfx.value
-
Writable value whose invalidation and change notifications can be temporarily suspended.
- SuspendableVarWrapper<T> - Class in org.reactfx.value
- SuspendableVarWrapper(Var<T>) - Constructor for class org.reactfx.value.SuspendableVarWrapper
- SuspendableYes - Class in org.reactfx
-
Observable boolean value that is normally
true
, but isfalse
when suspended. - SuspendableYes() - Constructor for class org.reactfx.SuspendableYes
- suspended - Variable in class org.reactfx.SuspendableBase
- suspendedWhen(ObservableValue<Boolean>) - Method in interface org.reactfx.SuspendableEventStream
-
Returns an event stream that is suspended when the given
condition
istrue
and emits normally whencondition
isfalse
. - SuspendedWhenStream<T> - Class in org.reactfx
- SuspendedWhenStream(SuspendableEventStream<T>, ObservableValue<Boolean>) - Constructor for class org.reactfx.SuspendedWhenStream
- suspender - Variable in class org.reactfx.ToggleFromVal
- Suspender<S extends Suspendable> - Interface in org.reactfx
-
Suspender is an object capable of suspending another suspendable object.
- SuspenderBase<O,T,S extends Suspendable> - Class in org.reactfx
- SuspenderBase(S) - Constructor for class org.reactfx.SuspenderBase
- suspenderOf(S) - Method in interface org.reactfx.EventStream
-
Returns an event stream that emits the same events as this event stream, but before each emission, suspends the given Suspendable and unsuspends it after the emission has completed.
- suspenders - Variable in class org.reactfx.SuspendableBoolean
- SuspenderStream<T,S extends Suspendable> - Interface in org.reactfx
-
An event stream that suspends a suspendable object during emission.
- SuspenderStreamImpl<T,S extends Suspendable> - Class in org.reactfx
- SuspenderStreamImpl(EventStream<T>, S) - Constructor for class org.reactfx.SuspenderStreamImpl
- suspendWhen(ObservableValue<Boolean>) - Method in interface org.reactfx.Suspendable
- suspendWhile(Runnable) - Method in interface org.reactfx.Suspendable
-
Runs the given computation while suspended.
- suspendWhile(Supplier<U>) - Method in interface org.reactfx.Suspendable
-
Runs the given computation while suspended.
T
- t(A, B) - Static method in class org.reactfx.util.Tuples
- t(A, B, C) - Static method in class org.reactfx.util.Tuples
- t(A, B, C, D) - Static method in class org.reactfx.util.Tuples
- t(A, B, C, D, E) - Static method in class org.reactfx.util.Tuples
- t(A, B, C, D, E, F) - Static method in class org.reactfx.util.Tuples
- tail - Variable in class org.reactfx.AccumulativeEventStream
- tail - Variable in class org.reactfx.util.AccumulativeStreamNotifications
- tail - Variable in class org.reactfx.util.LL.Cons
- tail() - Method in class org.reactfx.util.LL.Cons
- tail() - Method in class org.reactfx.util.LL.Nil
- tail() - Method in class org.reactfx.util.LL
- tail(Consumer<? super T>, A) - Method in class org.reactfx.util.AccumulativeStreamNotifications
- tail(Consumer<? super T>, Deque<T>) - Method in class org.reactfx.util.QueuingStreamNotifications
- tail(Consumer<? super T>, T) - Method in class org.reactfx.util.AbstractReducingStreamNotifications
- tail(Consumer<? super T>, T) - Method in class org.reactfx.util.NonAccumulativeStreamNotifications
- tail(O, A) - Method in class org.reactfx.util.NotificationAccumulatorBase
- tail(LiveList.Observer<? super E, ?>, ListModificationSequence<E>) - Method in class org.reactfx.util.ListNotifications
- tailOf(A) - Method in class org.reactfx.AccumulativeEventStream
- tailOf(A) - Method in class org.reactfx.SuspendableBase
- tailOf(Deque<T>) - Method in class org.reactfx.PausableEventStream
- tailOf(ListModificationSequence<E>) - Method in class org.reactfx.collection.SuspendableListWrapper
- tailOf(ListModificationSequence<F>) - Method in interface org.reactfx.collection.LiveList.Observer
- tailOf(ListModificationSequence<F>) - Method in interface org.reactfx.collection.LiveList.QuasiChangeObserver
- tailOf(ListModificationSequence<F>) - Method in interface org.reactfx.collection.LiveList.QuasiModificationObserver
- tailOf(T) - Method in class org.reactfx.AbstractReducibleEventStream
- tailOf(T) - Method in class org.reactfx.SuppressibleEventStream
- tailOf(T) - Method in class org.reactfx.value.SuspendableValWrapper
- takeHead(LiveList.Observer<? super E, O>, ListModificationSequence<E>) - Method in class org.reactfx.util.ListNotifications
- takeOne() - Method in interface org.reactfx.util.NotificationAccumulator
- takeOne() - Method in class org.reactfx.util.NotificationAccumulatorBase
- targetThreadExecutor - Variable in class org.reactfx.ThreadBridge
- TaskStream<T> - Interface in org.reactfx
- test(A, B, C) - Method in interface org.reactfx.util.TriPredicate
- test(A, B, C, D) - Method in interface org.reactfx.util.TetraPredicate
- test(A, B, C, D, E) - Method in interface org.reactfx.util.PentaPredicate
- test(A, B, C, D, E, F) - Method in interface org.reactfx.util.HexaPredicate
- test(BiPredicate<? super A, ? super B>) - Method in class org.reactfx.util.Tuple2
- test(HexaPredicate<? super A, ? super B, ? super C, ? super D, ? super E, ? super F>) - Method in class org.reactfx.util.Tuple6
- test(PentaPredicate<? super A, ? super B, ? super C, ? super D, ? super E>) - Method in class org.reactfx.util.Tuple5
- test(TetraPredicate<? super A, ? super B, ? super C, ? super D>) - Method in class org.reactfx.util.Tuple4
- test(TriPredicate<? super A, ? super B, ? super C>) - Method in class org.reactfx.util.Tuple3
- TetraConsumer<A,B,C,D> - Interface in org.reactfx.util
- TetraFunction<A,B,C,D,R> - Interface in org.reactfx.util
- TetraPredicate<A,B,C,D> - Interface in org.reactfx.util
- thenAccumulateFor(Duration, Function<? super T, ? extends A>, BiFunction<? super A, ? super T, ? extends A>, Function<? super A, List<T>>) - Method in interface org.reactfx.EventStream
-
Returns an event stream that emits the first event emitted from this stream and then, if the next event arrives within the given duration since the last emitted event, it is converted to an accumulator value using
initialTransformation
. - thenAccumulateFor(Duration, Function<? super T, ? extends A>, BiFunction<? super A, ? super T, ? extends A>, Function<? super A, List<T>>, ScheduledExecutorService, Executor) - Method in interface org.reactfx.EventStream
- thenAccumulateFor(Duration, Supplier<? extends A>, BiFunction<? super A, ? super T, ? extends A>, Function<? super A, List<T>>) - Method in interface org.reactfx.EventStream
-
A variant of
EventStream.thenAccumulateFor(Duration, Function, BiFunction, Function)
for cases when it is more convenient to provide a unit element for accumulation than the initial transformation. - thenAccumulateFor(Duration, Supplier<? extends A>, BiFunction<? super A, ? super T, ? extends A>, Function<? super A, List<T>>, ScheduledExecutorService, Executor) - Method in interface org.reactfx.EventStream
- ThenAccumulateForStream<T,A> - Class in org.reactfx
- ThenAccumulateForStream(EventStream<T>, Function<? super T, ? extends A>, BiFunction<? super A, ? super T, ? extends A>, Function<? super A, List<T>>, Function<Runnable, Timer>) - Constructor for class org.reactfx.ThenAccumulateForStream
- ThenAccumulateForStream.State - Enum in org.reactfx
- thenIgnoreFor(Duration) - Method in interface org.reactfx.EventStream
-
Returns an event stream that emits the first event emitted from this stream and then ignores the following events for the given duration.
- thenIgnoreFor(Duration, ScheduledExecutorService, Executor) - Method in interface org.reactfx.EventStream
- thenReduceFor(Duration, BinaryOperator<T>) - Method in interface org.reactfx.EventStream
-
Returns an event stream that emits the first event emitted from this stream and then reduces all following events that arrive within the given duration into a single event using the given reduction function.
- thenReduceFor(Duration, BinaryOperator<T>, ScheduledExecutorService, Executor) - Method in interface org.reactfx.EventStream
- thenRetainLatestFor(Duration) - Method in interface org.reactfx.EventStream
-
Returns an event stream that emits the first event emitted from this stream and then remembers, but does not emit, the latest event emitted from this stream.
- thenRetainLatestFor(Duration, ScheduledExecutorService, Executor) - Method in interface org.reactfx.EventStream
- threadBridge(Executor, Executor) - Method in interface org.reactfx.EventStream
-
Transfers events from one thread to another.
- ThreadBridge<T> - Class in org.reactfx
- ThreadBridge(EventStream<T>, Executor, Executor) - Constructor for class org.reactfx.ThreadBridge
- threadBridgeFromFx(Executor) - Method in interface org.reactfx.EventStream
-
Transfers events from the JavaFX application thread to another thread.
- threadBridgeToFx(Executor) - Method in interface org.reactfx.EventStream
-
Transfers events to the JavaFX application thread.
- ticks - Variable in class org.reactfx.AccumulateBetweenStream
- ticks(Duration) - Static method in class org.reactfx.EventStreams
-
Returns an event stream that emits periodic ticks.
- ticks(Duration, ScheduledExecutorService, Executor) - Static method in class org.reactfx.EventStreams
-
Returns an event stream that emits periodic ticks on the given
eventThreadExecutor
. - ticks0(Duration) - Static method in class org.reactfx.EventStreams
-
Returns an event stream that emits periodic ticks.
- timeline - Variable in class org.reactfx.util.FxTimer
- timeout - Variable in class org.reactfx.ScheduledExecutorServiceTimer
- timer - Variable in class org.reactfx.SuccessionReducingStream
- timer - Variable in class org.reactfx.ThenAccumulateForStream
- Timer - Interface in org.reactfx.util
-
Timer represents a delayed action.
- to - Variable in class org.reactfx.collection.SubList
- toArray() - Method in interface org.reactfx.collection.AccessorListMethods
- toArray() - Method in class org.reactfx.collection.SuspendableListWrapper
- toArray(IntFunction<T[]>) - Method in class org.reactfx.util.ListHelper.MultiElemHelper
- toArray(IntFunction<T[]>) - Method in class org.reactfx.util.ListHelper.SingleElemHelper
- toArray(IntFunction<T[]>) - Method in class org.reactfx.util.ListHelper
- toArray(ListHelper<T>, IntFunction<T[]>) - Static method in class org.reactfx.util.ListHelper
- toArray(T[]) - Method in interface org.reactfx.collection.AccessorListMethods
- toArray(T[]) - Method in class org.reactfx.collection.SuspendableListWrapper
- toBinding(T) - Method in interface org.reactfx.EventStream
-
Returns a binding that holds the most recent event emitted from this stream.
- toEventStream() - Method in class org.reactfx.StatefulStreamBuilderImpl
- toEventStream() - Method in interface org.reactfx.StateMachine.StatefulStreamBuilder
-
Returns an event stream that emits a value when one of the state machine's input streams causes the state machine to emit a value.
- Toggle - Interface in org.reactfx
-
Observable boolean that changes value when suspended.
- ToggleFromVal - Class in org.reactfx
- ToggleFromVal(Val<Boolean>, Suspendable) - Constructor for class org.reactfx.ToggleFromVal
- toLeft(Function<? super R, ? extends L>) - Method in interface org.reactfx.util.Either
- toLeft(Function<? super R, ? extends L>) - Method in class org.reactfx.util.Left
- toLeft(Function<? super R, ? extends L>) - Method in class org.reactfx.util.Right
- toObservableState() - Method in class org.reactfx.ObservableStateBuilderImpl
- toObservableState() - Method in interface org.reactfx.StateMachine.ObservableStateBuilder
-
Returns a binding that reflects the current state of the state machine.
- toOptional() - Method in interface org.reactfx.util.Try
- toRight(Function<? super L, ? extends R>) - Method in interface org.reactfx.util.Either
- toRight(Function<? super L, ? extends R>) - Method in class org.reactfx.util.Left
- toRight(Function<? super L, ? extends R>) - Method in class org.reactfx.util.Right
- ToSemigroup<T,U> - Interface in org.reactfx.util
- toStateStream() - Method in class org.reactfx.ObservableStateBuilderImpl
- toStateStream() - Method in interface org.reactfx.StateMachine.ObservableStateBuilder
-
Returns an event stream that emits the current state of the state machine every time it changes.
- toString() - Method in class org.reactfx.collection.ListModificationImpl
- toString() - Method in class org.reactfx.collection.QuasiListModificationImpl
- toString() - Method in class org.reactfx.ObservableBase
- toString() - Method in class org.reactfx.util.BiIndex
- toString() - Method in class org.reactfx.util.Failure
- toString() - Method in class org.reactfx.util.FingerTree.Branch
- toString() - Method in class org.reactfx.util.FingerTree.Empty
- toString() - Method in class org.reactfx.util.FingerTree.Leaf
- toString() - Method in class org.reactfx.util.Left
- toString() - Method in class org.reactfx.util.LL
- toString() - Method in class org.reactfx.util.Right
- toString() - Method in class org.reactfx.util.SparseList.AbsentSegment
- toString() - Method in class org.reactfx.util.SparseList.PresentSegment
- toString() - Method in class org.reactfx.util.Success
- toString() - Method in class org.reactfx.util.Tuple2
- toString() - Method in class org.reactfx.util.Tuple3
- toString() - Method in class org.reactfx.util.Tuple4
- toString() - Method in class org.reactfx.util.Tuple5
- toString() - Method in class org.reactfx.util.Tuple6
- toString(List<?>) - Static method in class org.reactfx.util.Lists
- transition - Variable in class org.reactfx.value.AnimatedVal
- transition(BiFunction<? super S, ? super I, ? extends S>) - Method in class org.reactfx.ObservableStateBuilderOnImpl
- transition(BiFunction<? super S, ? super I, ? extends S>) - Method in class org.reactfx.StatefulStreamBuilderOnImpl
- transition(BiFunction<? super S, ? super I, ? extends S>) - Method in interface org.reactfx.StateMachine.ObservableStateBuilderOn
- transition(BiFunction<? super S, ? super I, ? extends S>) - Method in interface org.reactfx.StateMachine.StatefulStreamBuilderOn
- TransitionBuilder<S> - Class in org.reactfx
- TransitionBuilder(EventStream<I>, BiFunction<? super S, ? super I, ? extends S>) - Constructor for class org.reactfx.TransitionBuilder
- transitions - Variable in class org.reactfx.ObservableStateBuilderImpl
- transitions - Variable in class org.reactfx.ObservableStateBuilderOnImpl
- transitions - Variable in class org.reactfx.StatefulStreamBuilderImpl
- transitions - Variable in class org.reactfx.StatefulStreamBuilderOnImpl
- TransmissionBuilder<S,O> - Class in org.reactfx
- TransmissionBuilder(EventStream<I>, BiFunction<? super S, ? super I, ? extends Tuple2<S, Optional<O>>>) - Constructor for class org.reactfx.TransmissionBuilder
- transmissions - Variable in class org.reactfx.StatefulStreamBuilderImpl
- transmissions - Variable in class org.reactfx.StatefulStreamBuilderOnImpl
- transmit(BiFunction<? super S, ? super I, Tuple2<S, Optional<O>>>) - Method in class org.reactfx.ObservableStateBuilderOnImpl
- transmit(BiFunction<? super S, ? super I, Tuple2<S, Optional<O>>>) - Method in class org.reactfx.StatefulStreamBuilderOnImpl
- transmit(BiFunction<? super S, ? super I, Tuple2<S, Optional<O>>>) - Method in interface org.reactfx.StateMachine.ObservableStateBuilderOn
- transmit(BiFunction<? super S, ? super I, Tuple2<S, Optional<O>>>) - Method in interface org.reactfx.StateMachine.StatefulStreamBuilderOn
- tree - Variable in class org.reactfx.collection.ListReduction
- tree - Variable in class org.reactfx.util.SparseList
- TriConsumer<A,B,C> - Interface in org.reactfx.util
- TriFunction<A,B,C,R> - Interface in org.reactfx.util
- trim() - Method in interface org.reactfx.collection.ListModification
- trim() - Method in class org.reactfx.collection.ListModificationImpl
- trim() - Method in interface org.reactfx.collection.MaterializedListModification
- trim(int) - Method in class org.reactfx.util.ListConcatenation
- TriPredicate<A,B,C> - Interface in org.reactfx.util
- Try<T> - Interface in org.reactfx.util
- tryGet(Callable<? extends T>) - Static method in interface org.reactfx.util.Try
- trySrc - Variable in class org.reactfx.value.OrElse
- Tuple2<A,B> - Class in org.reactfx.util
- Tuple2(A, B) - Constructor for class org.reactfx.util.Tuple2
- Tuple3<A,B,C> - Class in org.reactfx.util
- Tuple3(A, B, C) - Constructor for class org.reactfx.util.Tuple3
- Tuple4<A,B,C,D> - Class in org.reactfx.util
- Tuple4(A, B, C, D) - Constructor for class org.reactfx.util.Tuple4
- Tuple5<A,B,C,D,E> - Class in org.reactfx.util
- Tuple5(A, B, C, D, E) - Constructor for class org.reactfx.util.Tuple5
- Tuple6<A,B,C,D,E,F> - Class in org.reactfx.util
- Tuple6(A, B, C, D, E, F) - Constructor for class org.reactfx.util.Tuple6
- Tuples - Class in org.reactfx.util
- Tuples() - Constructor for class org.reactfx.util.Tuples
U
- unbind() - Method in class org.reactfx.value.FlatMappedVar
- unbind() - Method in class org.reactfx.value.SimpleVar
- unbind() - Method in class org.reactfx.value.SuspendableVarWrapper
- unbind() - Method in class org.reactfx.value.VarFromVal
- unbind() - Method in class org.reactfx.value.VarWrapper
- unbindBidirectional(Property<T>) - Method in interface org.reactfx.value.Var
- underlying - Variable in class org.reactfx.collection.ValAsList
- underlying - Variable in class org.reactfx.ProxyObservable
- unify(Function<? super L, ? extends T>, Function<? super R, ? extends T>) - Method in interface org.reactfx.util.Either
- unify(Function<? super L, ? extends T>, Function<? super R, ? extends T>) - Method in class org.reactfx.util.Left
- unify(Function<? super L, ? extends T>, Function<? super R, ? extends T>) - Method in class org.reactfx.util.Right
- unit - Variable in class org.reactfx.ScheduledExecutorServiceTimer
- UnmodifiableByDefaultList<E> - Interface in org.reactfx.collection
-
Trait to be mixed into implementations of unmodifiable lists.
- UnmodifiableByDefaultLiveList<E> - Interface in org.reactfx.collection
-
Trait to be mixed into implementations of unmodifiable
LiveList
s. - unsubscribe() - Method in class org.reactfx.BiSubscription
- unsubscribe() - Method in class org.reactfx.MultiSubscription
- unsubscribe() - Method in interface org.reactfx.Subscription
- update1(A) - Method in class org.reactfx.util.Tuple2
- update1(A) - Method in class org.reactfx.util.Tuple3
- update1(A) - Method in class org.reactfx.util.Tuple4
- update1(A) - Method in class org.reactfx.util.Tuple5
- update1(A) - Method in class org.reactfx.util.Tuple6
- update2(B) - Method in class org.reactfx.util.Tuple2
- update2(B) - Method in class org.reactfx.util.Tuple3
- update2(B) - Method in class org.reactfx.util.Tuple4
- update2(B) - Method in class org.reactfx.util.Tuple5
- update2(B) - Method in class org.reactfx.util.Tuple6
- update3(C) - Method in class org.reactfx.util.Tuple3
- update3(C) - Method in class org.reactfx.util.Tuple4
- update3(C) - Method in class org.reactfx.util.Tuple5
- update3(C) - Method in class org.reactfx.util.Tuple6
- update4(D) - Method in class org.reactfx.util.Tuple4
- update4(D) - Method in class org.reactfx.util.Tuple5
- update4(D) - Method in class org.reactfx.util.Tuple6
- update5(E) - Method in class org.reactfx.util.Tuple5
- update5(E) - Method in class org.reactfx.util.Tuple6
- update6(F) - Method in class org.reactfx.util.Tuple6
- updateLeaf(int, T) - Method in class org.reactfx.util.FingerTree
- updateLeaf0(int, T) - Method in class org.reactfx.util.FingerTree.Branch
- updateLeaf0(int, T) - Method in class org.reactfx.util.FingerTree.Empty
- updateLeaf0(int, T) - Method in class org.reactfx.util.FingerTree.Leaf
- updateLeaf0(int, T) - Method in class org.reactfx.util.FingerTree
- updateLeaf0(int, T, LL<? extends FingerTree.NonEmptyFingerTree<T, S>>) - Method in class org.reactfx.util.FingerTree.Branch
- updatePeeked(A) - Method in interface org.reactfx.util.AccuMap
- updatePeeked(A) - Method in class org.reactfx.util.EmptyAccuMap
- updatePeeked(A) - Method in class org.reactfx.util.HashAccuMap
- updatePeeked(A) - Method in class org.reactfx.util.IteratorBasedAccuMap
V
- Val<T> - Interface in org.reactfx.value
-
Adds more operations to
ObservableValue
. - ValAsList<T> - Class in org.reactfx.collection
- ValAsList(ObservableValue<T>) - Constructor for class org.reactfx.collection.ValAsList
- ValBase<T> - Class in org.reactfx.value
- ValBase() - Constructor for class org.reactfx.value.ValBase
- valid - Variable in class org.reactfx.value.ValBase
- value - Variable in class org.reactfx.EmitOnEachStream
- value - Variable in class org.reactfx.EmitOnStream
- value - Variable in class org.reactfx.EventStreams.Pocket
- value - Variable in class org.reactfx.RepeatOnStream
- value - Variable in class org.reactfx.StreamBinding
- value - Variable in class org.reactfx.util.IteratorBasedAccuMap
- value - Variable in class org.reactfx.util.Left
- value - Variable in class org.reactfx.util.MapHelper.SingleEntryHelper
- value - Variable in class org.reactfx.util.Right
- value - Variable in class org.reactfx.value.ConstVal
- value - Variable in class org.reactfx.value.SimpleVar
- value - Variable in class org.reactfx.value.ValBase
- valueOf(String) - Static method in enum org.reactfx.ThenAccumulateForStream.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.reactfx.util.AccumulatorSize
-
Returns the enum constant of this type with the specified name.
- values() - Static method in enum org.reactfx.ThenAccumulateForStream.State
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.reactfx.util.AccumulatorSize
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Method in interface org.reactfx.value.Val
-
Returns a stream of values of this Val.
- valuesOf(ObservableValue<T>) - Static method in class org.reactfx.EventStreams
-
Creates an event stream that emits the value of the given
ObservableValue
immediately for every subscriber and then on every change. - ValWrapper<T,D extends javafx.beans.value.ObservableValue<T>> - Class in org.reactfx.value
- ValWrapper(D) - Constructor for class org.reactfx.value.ValWrapper
- Var<T> - Interface in org.reactfx.value
- VarFromVal<T> - Class in org.reactfx.value
- VarFromVal(Val<T>, Consumer<T>) - Constructor for class org.reactfx.value.VarFromVal
- VarWrapper<T> - Class in org.reactfx.value
- VarWrapper(Property<T>) - Constructor for class org.reactfx.value.VarWrapper
W
- withDefaultEvent(T) - Method in interface org.reactfx.EventStream
-
Returns an event stream that immediately emits its event when something subscribes to it.
- wrap(ObservableBooleanValue) - Static method in class org.reactfx.inhibeans.binding.BooleanBinding
-
Deprecated.
- wrap(ObservableObjectValue<T>) - Static method in class org.reactfx.inhibeans.binding.ObjectBinding
-
Deprecated.
- wrap(ObservableStringValue) - Static method in class org.reactfx.inhibeans.binding.StringBinding
-
Deprecated.
- wrap(ObservableValue<? extends Number>) - Static method in class org.reactfx.inhibeans.binding.DoubleBinding
-
Deprecated.
- wrap(ObservableValue<? extends Number>) - Static method in class org.reactfx.inhibeans.binding.FloatBinding
-
Deprecated.
- wrap(ObservableValue<? extends Number>) - Static method in class org.reactfx.inhibeans.binding.IntegerBinding
-
Deprecated.
- wrap(ObservableValue<? extends Number>) - Static method in class org.reactfx.inhibeans.binding.LongBinding
-
Deprecated.
- wrap(ObservableValue<T>) - Static method in interface org.reactfx.inhibeans.binding.Binding
-
Deprecated.
- wrap(ObservableValue<T>) - Static method in interface org.reactfx.value.Val
-
Returns a Val wrapper around ObservableValue.
- wrap(ObservableList<E>) - Static method in class org.reactfx.inhibeans.collection.Collections
-
Deprecated.
- WrapperBase<T> - Class in org.reactfx.util
-
Base class for value-based wrappers, that is wrappers that implement
WrapperBase.equals(Object)
andWrapperBase.hashCode()
solely by comparing/hashing the wrapped values. - WrapperBase(T) - Constructor for class org.reactfx.util.WrapperBase
- wrapVal(ObservableValue<E>) - Static method in interface org.reactfx.collection.LiveList
-
Returns a LiveList view of the given ObservableValue
obs
.
Y
- yeses() - Method in class org.reactfx.SuspendableBoolean
Z
- ZERO - org.reactfx.util.AccumulatorSize
- ZERO - Static variable in class org.reactfx.util.SparseList.Stats
- zip(EventStream<A>, EventStream<B>) - Static method in class org.reactfx.EventStreams
- zip(EventStream<A>, EventStream<B>, EventStream<C>) - Static method in class org.reactfx.EventStreams
_
- _1 - Variable in class org.reactfx.util.Tuple2
- _1 - Variable in class org.reactfx.util.Tuple3
- _1 - Variable in class org.reactfx.util.Tuple4
- _1 - Variable in class org.reactfx.util.Tuple5
- _1 - Variable in class org.reactfx.util.Tuple6
- _2 - Variable in class org.reactfx.util.Tuple2
- _2 - Variable in class org.reactfx.util.Tuple3
- _2 - Variable in class org.reactfx.util.Tuple4
- _2 - Variable in class org.reactfx.util.Tuple5
- _2 - Variable in class org.reactfx.util.Tuple6
- _3 - Variable in class org.reactfx.util.Tuple3
- _3 - Variable in class org.reactfx.util.Tuple4
- _3 - Variable in class org.reactfx.util.Tuple5
- _3 - Variable in class org.reactfx.util.Tuple6
- _4 - Variable in class org.reactfx.util.Tuple4
- _4 - Variable in class org.reactfx.util.Tuple5
- _4 - Variable in class org.reactfx.util.Tuple6
- _5 - Variable in class org.reactfx.util.Tuple5
- _5 - Variable in class org.reactfx.util.Tuple6
- _6 - Variable in class org.reactfx.util.Tuple6
All Classes All Packages