/*
* Copyright 2014 Red Hat, Inc.
*
* Red Hat licenses this file to you under the Apache License, version 2.0
* (the "License"); you may not use this file except in compliance with the
* License. You may obtain a copy of the License at:
*
* http://www.apache.org/licenses/LICENSE-2.0
*
* Unless required by applicable law or agreed to in writing, software
* distributed under the License is distributed on an "AS IS" BASIS, WITHOUT
* WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the
* License for the specific language governing permissions and limitations
* under the License.
*/
package io.vertx.reactivex.pgclient.pubsub;
import java.util.Map;
import io.reactivex.Observable;
import io.reactivex.Flowable;
import io.reactivex.Single;
import io.reactivex.Completable;
import io.reactivex.Maybe;
import io.vertx.core.AsyncResult;
import io.vertx.core.Handler;
A channel to Postgres that tracks the subscription to a given Postgres channel using the LISTEN/UNLISTEN
commands.
When paused the channel discards the messages.
NOTE: This class has been automatically generated from the original
non RX-ified interface using Vert.x codegen. /**
* A channel to Postgres that tracks the subscription to a given Postgres channel using the <code>LISTEN/UNLISTEN</code> commands.
* <p/>
* When paused the channel discards the messages.
*
* <p/>
* NOTE: This class has been automatically generated from the {@link io.vertx.pgclient.pubsub.PgChannel original} non RX-ified interface using Vert.x codegen.
*/
@io.vertx.lang.rx.RxGen(io.vertx.pgclient.pubsub.PgChannel.class)
public class PgChannel implements io.vertx.reactivex.core.streams.ReadStream<String> {
@Override
public String toString() {
return delegate.toString();
}
@Override
public boolean equals(Object o) {
if (this == o) return true;
if (o == null || getClass() != o.getClass()) return false;
PgChannel that = (PgChannel) o;
return delegate.equals(that.delegate);
}
@Override
public int hashCode() {
return delegate.hashCode();
}
public static final io.vertx.lang.rx.TypeArg<PgChannel> __TYPE_ARG = new io.vertx.lang.rx.TypeArg<>( obj -> new PgChannel((io.vertx.pgclient.pubsub.PgChannel) obj),
PgChannel::getDelegate
);
private final io.vertx.pgclient.pubsub.PgChannel delegate;
public PgChannel(io.vertx.pgclient.pubsub.PgChannel delegate) {
this.delegate = delegate;
}
public io.vertx.pgclient.pubsub.PgChannel getDelegate() {
return delegate;
}
private io.reactivex.Observable<String> observable;
private io.reactivex.Flowable<String> flowable;
public synchronized io.reactivex.Observable<String> toObservable() {
if (observable == null) {
observable = io.vertx.reactivex.ObservableHelper.toObservable(this.getDelegate());
}
return observable;
}
public synchronized io.reactivex.Flowable<String> toFlowable() {
if (flowable == null) {
flowable = io.vertx.reactivex.FlowableHelper.toFlowable(this.getDelegate());
}
return flowable;
}
Fetch the specified amount
of elements. If the ReadStream
has been paused, reading will
recommence with the specified amount
of items, otherwise the specified amount
will
be added to the current stream demand.
Params: - amount –
Returns: a reference to this, so the API can be used fluently
/**
* Fetch the specified <code>amount</code> of elements. If the <code>ReadStream</code> has been paused, reading will
* recommence with the specified <code>amount</code> of items, otherwise the specified <code>amount</code> will
* be added to the current stream demand.
* @param amount
* @return a reference to this, so the API can be used fluently
*/
public io.vertx.reactivex.core.streams.ReadStream<String> fetch(long amount) {
delegate.fetch(amount);
return this;
}
Pause this stream and return a to transfer the elements of this stream to a destination .
The stream will be resumed when the pipe will be wired to a WriteStream
.
Returns: a pipe
/**
* Pause this stream and return a to transfer the elements of this stream to a destination .
* <p/>
* The stream will be resumed when the pipe will be wired to a <code>WriteStream</code>.
* @return a pipe
*/
public io.vertx.reactivex.core.streams.Pipe<String> pipe() {
io.vertx.reactivex.core.streams.Pipe<String> ret = io.vertx.reactivex.core.streams.Pipe.newInstance(delegate.pipe(), io.vertx.lang.rx.TypeArg.unknown());
return ret;
}
Like ReadStream.pipeTo
but with no completion handler. Params: - dst –
/**
* Like {@link io.vertx.reactivex.core.streams.ReadStream#pipeTo} but with no completion handler.
* @param dst
*/
public void pipeTo(io.vertx.reactivex.core.streams.WriteStream<String> dst) {
delegate.pipeTo(dst.getDelegate());
}
Pipe this ReadStream
to the WriteStream
.
Elements emitted by this stream will be written to the write stream until this stream ends or fails.
Once this stream has ended or failed, the write stream will be ended and the handler
will be
called with the result.
Params: - dst – the destination write stream
- handler –
/**
* Pipe this <code>ReadStream</code> to the <code>WriteStream</code>.
* <p>
* Elements emitted by this stream will be written to the write stream until this stream ends or fails.
* <p>
* Once this stream has ended or failed, the write stream will be ended and the <code>handler</code> will be
* called with the result.
* @param dst the destination write stream
* @param handler
*/
public void pipeTo(io.vertx.reactivex.core.streams.WriteStream<String> dst, Handler<AsyncResult<Void>> handler) {
delegate.pipeTo(dst.getDelegate(), handler);
}
Pipe this ReadStream
to the WriteStream
.
Elements emitted by this stream will be written to the write stream until this stream ends or fails.
Once this stream has ended or failed, the write stream will be ended and the handler
will be
called with the result.
Params: - dst – the destination write stream
Returns:
/**
* Pipe this <code>ReadStream</code> to the <code>WriteStream</code>.
* <p>
* Elements emitted by this stream will be written to the write stream until this stream ends or fails.
* <p>
* Once this stream has ended or failed, the write stream will be ended and the <code>handler</code> will be
* called with the result.
* @param dst the destination write stream
* @return
*/
public Completable rxPipeTo(io.vertx.reactivex.core.streams.WriteStream<String> dst) {
return io.vertx.reactivex.impl.AsyncResultCompletable.toCompletable(handler -> {
pipeTo(dst, handler);
});
}
Set an handler called when the the channel get subscribed.
Params: - handler – the handler
Returns: a reference to this, so the API can be used fluently
/**
* Set an handler called when the the channel get subscribed.
* @param handler the handler
* @return a reference to this, so the API can be used fluently
*/
public io.vertx.reactivex.pgclient.pubsub.PgChannel subscribeHandler(Handler<Void> handler) {
delegate.subscribeHandler(handler);
return this;
}
Set or unset an handler to be called when a the channel is notified by Postgres.
- when the handler is set, the subscriber sends a
LISTEN
command if needed
- when the handler is unset, the subscriber sends a
UNLISTEN
command if needed
Params: - handler – the handler
Returns: a reference to this, so the API can be used fluently
/**
* Set or unset an handler to be called when a the channel is notified by Postgres.
* <p/>
* <ul>
* <li>when the handler is set, the subscriber sends a <code>LISTEN</code> command if needed</li>
* <li>when the handler is unset, the subscriber sends a <code>UNLISTEN</code> command if needed</li>
* </ul>
* @param handler the handler
* @return a reference to this, so the API can be used fluently
*/
public io.vertx.reactivex.pgclient.pubsub.PgChannel handler(Handler<String> handler) {
delegate.handler(handler);
return this;
}
Pause the channel, all notifications are discarded.
Returns: a reference to this, so the API can be used fluently
/**
* Pause the channel, all notifications are discarded.
* @return a reference to this, so the API can be used fluently
*/
public io.vertx.reactivex.pgclient.pubsub.PgChannel pause() {
delegate.pause();
return this;
}
Resume the channel.
Returns: a reference to this, so the API can be used fluently
/**
* Resume the channel.
* @return a reference to this, so the API can be used fluently
*/
public io.vertx.reactivex.pgclient.pubsub.PgChannel resume() {
delegate.resume();
return this;
}
Set an handler to be called when no more notifications will be received.
Params: - endHandler – the handler
Returns: a reference to this, so the API can be used fluently
/**
* Set an handler to be called when no more notifications will be received.
* @param endHandler the handler
* @return a reference to this, so the API can be used fluently
*/
public io.vertx.reactivex.pgclient.pubsub.PgChannel endHandler(Handler<Void> endHandler) {
delegate.endHandler(endHandler);
return this;
}
public io.vertx.reactivex.pgclient.pubsub.PgChannel exceptionHandler(Handler<Throwable> handler) {
delegate.exceptionHandler(handler);
return this;
}
public static PgChannel newInstance(io.vertx.pgclient.pubsub.PgChannel arg) {
return arg != null ? new PgChannel(arg) : null;
}
}