All Downloads are FREE. Search and download functionalities are using the official Maven repository.

com.clickhouse.r2dbc.ClickHouseResult091 Maven / Gradle / Ivy

There is a newer version: 0.7.1-patch1
Show newest version
package com.clickhouse.r2dbc;

import com.clickhouse.client.ClickHouseResponse;
import com.clickhouse.client.ClickHouseResponseSummary;
import com.clickhouse.logging.Logger;
import com.clickhouse.logging.LoggerFactory;
import io.r2dbc.spi.Result;
import io.r2dbc.spi.Row;
import io.r2dbc.spi.RowMetadata;
import org.reactivestreams.Publisher;
import reactor.core.publisher.Flux;
import reactor.core.publisher.Mono;

import java.util.function.BiFunction;
import java.util.function.Function;
import java.util.function.Predicate;
import java.util.stream.StreamSupport;

class ClickHouseResult implements Result {

    private static final Logger log = LoggerFactory.getLogger(ClickHouseResult.class);

    private final Flux rowSegments;
    private final Mono updatedCount;
    private final Flux segments;

    ClickHouseResult(ClickHouseResponse response) {
        this.rowSegments = Mono.just(response)
                .flatMapMany(resp -> Flux
                        .fromStream(StreamSupport.stream(resp.records().spliterator(), false)
                                .map(rec -> ClickHousePair.of(resp.getColumns(), rec))))
                    .map(pair -> new ClickHouseRow(pair.getRight(), pair.getLeft()))
                .map(RowSegment::new);
        this.updatedCount =  Mono.just(response).map(ClickHouseResponse::getSummary)
                .map(ClickHouseResponseSummary::getProgress)
                .map(ClickHouseResponseSummary.Progress::getWrittenRows)
                .map(UpdateCount::new);
        this.segments = Flux.concat(this.updatedCount, this.rowSegments);
    }

    ClickHouseResult(Flux rowSegments, Mono updatedCount) {
        this.rowSegments = rowSegments;
        this.updatedCount = updatedCount;
        this.segments = Flux.concat(this.updatedCount, this.rowSegments);
    }

    /**
     * Returns updated count(written rows from summary of {@link ClickHouseResponse}).Important! if writtenRows is greater than MAX_INT then it will return MAX_INT.
     *
     * @return updated count
     */
    @Override
    public Mono getRowsUpdated() {
        return updatedCount.map(val -> (int) ((UpdateCount) val).value());
    }

    @Override
    public  Publisher map(BiFunction biFunction) {
        return rowSegments.cast(RowSegment.class)
                .map(RowSegment::row).handle((row, sink) -> {
            try {
                sink.next(biFunction.apply(row, row.getMetadata()));
            } catch (Exception e) {
                log.error("Provided function caused exception:", e);
            }
        });
    }

    @Override
    public Result filter(Predicate predicate) {
        return new ClickHouseResult(segments.filter(predicate), updatedCount.filter(predicate));
    }

    @Override
    public  Publisher flatMap(Function> function) {
        return segments.flatMap(segment -> {
            try {
                Publisher retValue = function.apply(segment);
                if (retValue == null) {
                    return Mono.error(new IllegalStateException("flatmap function returned null value"));
                }
                return retValue;
            } catch (Exception e) {
                log.error("Provided function caused exception:", e);
                return Mono.error(e);
            }
        });
    }


    class RowSegment implements Result.RowSegment {

        final ClickHouseRow row;

        RowSegment(ClickHouseRow row) {
            this.row = row;
        }

        @Override
        public Row row() {
            return row;
        }
    }

    class UpdateCount implements Result.UpdateCount {

        final long updateCount;

        UpdateCount(long updateCount) {
            this.updateCount = updateCount;
        }

        @Override
        public long value() {
            return updateCount;
        }
    }
}




© 2015 - 2024 Weber Informatics LLC | Privacy Policy