001/*
002 * Licensed to the Apache Software Foundation (ASF) under one
003 * or more contributor license agreements.  See the NOTICE file
004 * distributed with this work for additional information
005 * regarding copyright ownership.  The ASF licenses this file
006 * to you under the Apache License, Version 2.0 (the
007 * "License"); you may not use this file except in compliance
008 * with the License.  You may obtain a copy of the License at
009 *
010 *     http://www.apache.org/licenses/LICENSE-2.0
011 *
012 * Unless required by applicable law or agreed to in writing, software
013 * distributed under the License is distributed on an "AS IS" BASIS,
014 * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
015 * See the License for the specific language governing permissions and
016 * limitations under the License.
017 */
018package org.apache.hadoop.hbase.hbtop.mode;
019
020import java.util.List;
021import java.util.stream.Collectors;
022import java.util.stream.Stream;
023import org.apache.hadoop.hbase.hbtop.Record;
024import org.apache.hadoop.hbase.hbtop.RecordFilter;
025import org.apache.hadoop.hbase.hbtop.field.Field;
026
027public final class ModeStrategyUtils {
028  private ModeStrategyUtils() {
029
030  }
031
032  /**
033   * Filter records as per the supplied filters,
034   * @param records records to be processed
035   * @param filters List of filters
036   * @return filtered records
037   */
038  public static List<Record> applyFilterAndGet(List<Record> records, List<RecordFilter> filters) {
039    if (filters != null && !filters.isEmpty()) {
040      return records.stream().filter(r -> filters.stream().allMatch(f -> f.execute(r)))
041        .collect(Collectors.toList());
042    }
043    return records;
044  }
045
046  /**
047   * Group by records on the basis of supplied groupBy field and Aggregate records using
048   * {@link Record#combine(Record)}
049   * @param records records needs to be processed
050   * @param groupBy Field to be used for group by
051   * @return aggregated records
052   */
053  public static List<Record> aggregateRecords(List<Record> records, Field groupBy) {
054    return records.stream().collect(Collectors.groupingBy(r -> r.get(groupBy))).entrySet().stream()
055      .flatMap(
056        e -> e.getValue().stream().reduce(Record::combine).map(Stream::of).orElse(Stream.empty()))
057      .collect(Collectors.toList());
058  }
059
060}