You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@pinot.apache.org by ja...@apache.org on 2019/06/27 00:57:24 UTC

[incubator-pinot] branch mutable_off_heap updated (08744b6 -> 6250aee)

This is an automated email from the ASF dual-hosted git repository.

jackie pushed a change to branch mutable_off_heap
in repository https://gitbox.apache.org/repos/asf/incubator-pinot.git.


 discard 08744b6  Optimize MutableOffHeapByteArrayStore by directly calling the PinotDataBuffer API
     add 3eef6ea  Update quick_start.rst (#4319)
     add 9497a75  [TE] Fix doc - add import sql url, disable pinot build (#4357)
     add 81f433f  Raise the threshold of using MMAP for inverted index creation from 100M to 2G (#4358)
     add 859c68c  [TE] Tuning of Composite alert - Store metric refs in component spec (#4359)
     add b75a4c0  Adding support for udfs in Selection (#4346)
     add ab6dd9f  [TE] Trigger expression based grouping of anomalies - AND, OR and combinations (#4354)
     add 4ce688e  [TE] update detection health (#4364)
     add 866e29a  Adding util methods for controller that will be used in offline push (#4360)
     add 39811df  [TE] frontend - harleyjj/alert-overview - dont use anomalies from bounds endpoint in Alert Overview (#4366)
     add 49902ae  [TE] set detection window based on detection granularity (#4352)
     add 583548c  [TE] Bug Fix - Inject the correct metric ref in component spec (#4369)
     add db7cd63  [TE] Update name for entity anomalies (#4370)
     add 6250aee  Optimize MutableOffHeapByteArrayStore by directly calling the PinotDataBuffer API

This update added new revisions after undoing existing revisions.
That is to say, some revisions that were in the old version of the
branch are not in the new version.  This situation occurs
when a user --force pushes a change and generates a repository
containing something like this:

 * -- * -- B -- O -- O -- O   (08744b6)
            \
             N -- N -- N   refs/heads/mutable_off_heap (6250aee)

You should already have received notification emails for all of the O
revisions, and so the following emails describe only the N revisions
from the common base, B.

Any revisions marked "omit" are not gone; other references still
refer to them.  Any revisions marked "discard" are gone forever.

No new revisions were added by this update.

Summary of changes:
 .../common}/function/AggregationFunctionType.java  |   5 +-
 .../FunctionDefinitionRegistry.java}               |  21 +-
 .../common/utils/FileUploadDownloadClient.java     |  41 +++
 .../pinot/common/utils/request/RequestUtils.java   |   3 +-
 .../parsers/PinotQuery2BrokerRequestConverter.java |  19 +-
 .../pinot/pql/parsers/pql2/ast/OrderByAstNode.java |   5 +-
 .../pql/parsers/pql2/ast/OutputColumnAstNode.java  |  20 +-
 .../core/data/aggregator/AvgValueAggregator.java   |   2 +-
 .../core/data/aggregator/CountValueAggregator.java |   2 +-
 .../DistinctCountHLLValueAggregator.java           |   2 +-
 .../core/data/aggregator/MaxValueAggregator.java   |   2 +-
 .../aggregator/MinMaxRangeValueAggregator.java     |   2 +-
 .../core/data/aggregator/MinValueAggregator.java   |   2 +-
 .../aggregator/PercentileEstValueAggregator.java   |   2 +-
 .../PercentileTDigestValueAggregator.java          |   2 +-
 .../core/data/aggregator/SumValueAggregator.java   |   2 +-
 .../core/data/aggregator/ValueAggregator.java      |   2 +-
 .../data/aggregator/ValueAggregatorFactory.java    |   2 +-
 .../query/DictionaryBasedAggregationOperator.java  |   2 +-
 .../query/MetadataBasedAggregationOperator.java    |   2 +-
 .../core/operator/query/SelectionOnlyOperator.java | 109 -------
 .../core/operator/query/SelectionOperator.java     | 282 +++++++++++++++++
 .../operator/query/SelectionOrderByOperator.java   | 116 -------
 .../transform/TransformBlockDataFetcher.java       | 340 +++++++++++++++++++++
 .../core/operator/transform/TransformOperator.java |  13 +-
 .../plan/MetadataBasedAggregationPlanNode.java     |   2 +-
 .../apache/pinot/core/plan/SelectionPlanNode.java  |  38 +--
 .../apache/pinot/core/plan/TransformPlanNode.java  |  50 ++-
 .../core/plan/maker/InstancePlanMakerImplV2.java   |   2 +-
 .../aggregation/DefaultAggregationExecutor.java    |   2 +-
 .../aggregation/function/AggregationFunction.java  |   1 +
 .../function/AggregationFunctionFactory.java       |   1 +
 .../function/AggregationFunctionUtils.java         |   1 +
 .../function/AvgAggregationFunction.java           |   1 +
 .../function/AvgMVAggregationFunction.java         |   1 +
 .../function/CountAggregationFunction.java         |   1 +
 .../function/CountMVAggregationFunction.java       |   1 +
 .../function/DistinctCountAggregationFunction.java |   1 +
 .../DistinctCountHLLAggregationFunction.java       |   1 +
 .../DistinctCountHLLMVAggregationFunction.java     |   1 +
 .../DistinctCountMVAggregationFunction.java        |   1 +
 .../DistinctCountRawHLLAggregationFunction.java    |   1 +
 .../DistinctCountRawHLLMVAggregationFunction.java  |   1 +
 .../function/FastHLLAggregationFunction.java       |   1 +
 .../function/MaxAggregationFunction.java           |   1 +
 .../function/MaxMVAggregationFunction.java         |   1 +
 .../function/MinAggregationFunction.java           |   1 +
 .../function/MinMVAggregationFunction.java         |   1 +
 .../function/MinMaxRangeAggregationFunction.java   |   1 +
 .../function/MinMaxRangeMVAggregationFunction.java |   1 +
 .../function/PercentileAggregationFunction.java    |   1 +
 .../function/PercentileEstAggregationFunction.java |   1 +
 .../PercentileEstMVAggregationFunction.java        |   1 +
 .../function/PercentileMVAggregationFunction.java  |   1 +
 .../PercentileTDigestAggregationFunction.java      |   1 +
 .../PercentileTDigestMVAggregationFunction.java    |   1 +
 .../function/SumAggregationFunction.java           |   1 +
 .../function/SumMVAggregationFunction.java         |   1 +
 .../groupby/DefaultGroupByExecutor.java            |   2 +-
 .../core/query/request/ServerQueryRequest.java     |  18 +-
 .../query/selection/SelectionOperatorUtils.java    |   4 +-
 .../inv/OffHeapBitmapInvertedIndexCreator.java     |   4 +-
 .../executor/StarTreeAggregationExecutor.java      |   2 +-
 .../startree/executor/StarTreeGroupByExecutor.java |   2 +-
 .../startree/plan/StarTreeTransformPlanNode.java   |   3 +-
 .../startree/v2/AggregationFunctionColumnPair.java |   2 +-
 .../startree/v2/builder/BaseSingleTreeBuilder.java |   2 +-
 .../startree/v2/store/StarTreeLoaderUtils.java     |   2 +-
 .../function/AggregationFunctionFactoryTest.java   |   1 +
 .../function/AggregationFunctionTypeTest.java      |   1 +
 .../v2/AggregationFunctionColumnPairTest.java      |   2 +-
 .../pinot/core/startree/v2/BaseStarTreeV2Test.java |   2 +-
 ...InnerSegmentSelectionMultiValueQueriesTest.java | 123 +++++---
 ...nnerSegmentSelectionSingleValueQueriesTest.java | 146 +++++----
 .../DefaultAggregationExecutorTest.java            |   2 +-
 .../apache/pinot/hadoop/job/ControllerRestApi.java |   4 +
 .../pinot/hadoop/job/DefaultControllerRestApi.java |  50 +++
 .../DeleteAPIHybridClusterIntegrationTest.java     |  23 ++
 .../tests/OfflineClusterIntegrationTest.java       |  86 +++++-
 .../tests/StarTreeV2ClusterIntegrationTest.java    |   2 +-
 .../pinot/perf/BenchmarkPinotDataBuffer.java       | 137 +++++++++
 thirdeye/docs/import_sql_metric.rst                |   7 +-
 thirdeye/docs/production.rst                       |   4 +-
 thirdeye/docs/quick_start.rst                      |  10 +-
 thirdeye/install.sh                                |  10 +-
 .../app/pods/components/alert-details/component.js |   7 +-
 thirdeye/thirdeye-frontend/app/utils/anomaly.js    |  11 +-
 .../thirdeye-frontend/app/utils/api/anomaly.js     |   6 +-
 .../config/data-sources/data-sources-config.yml    |   2 +-
 .../thirdeye/detection/DetectionPipeline.java      |   2 +-
 .../pinot/thirdeye/detection/DetectionUtils.java   |  57 ++++
 .../components/TriggerConditionGrouper.java        | 202 ++++++++++++
 .../thirdeye/detection/health/DetectionHealth.java |   6 +-
 .../detection/health/DetectionTaskStatus.java      |  31 +-
 ...rSpec.java => TriggerConditionGrouperSpec.java} |  40 ++-
 .../thirdeye/detection/wrapper/GrouperWrapper.java |  13 +-
 .../detection/yaml/DetectionConfigTuner.java       |  41 +--
 .../yaml/translator/DetectionConfigTranslator.java |  99 +++---
 .../components/TriggerConditionGrouperTest.java    | 230 ++++++++++++++
 .../detection/health/DetectionHealthTest.java      |   3 +
 .../yaml/translator/pipeline-config-5.yaml         |   4 +-
 101 files changed, 1979 insertions(+), 548 deletions(-)
 rename {pinot-core/src/main/java/org/apache/pinot/core/query/aggregation => pinot-common/src/main/java/org/apache/pinot/common}/function/AggregationFunctionType.java (93%)
 copy pinot-common/src/main/java/org/apache/pinot/common/{data/DateTimeFieldSpecChildKeyHandler.java => function/FunctionDefinitionRegistry.java} (70%)
 delete mode 100644 pinot-core/src/main/java/org/apache/pinot/core/operator/query/SelectionOnlyOperator.java
 create mode 100644 pinot-core/src/main/java/org/apache/pinot/core/operator/query/SelectionOperator.java
 delete mode 100644 pinot-core/src/main/java/org/apache/pinot/core/operator/query/SelectionOrderByOperator.java
 create mode 100644 pinot-core/src/main/java/org/apache/pinot/core/operator/transform/TransformBlockDataFetcher.java
 create mode 100644 pinot-perf/src/main/java/org/apache/pinot/perf/BenchmarkPinotDataBuffer.java
 create mode 100644 thirdeye/thirdeye-pinot/src/main/java/org/apache/pinot/thirdeye/detection/components/TriggerConditionGrouper.java
 copy thirdeye/thirdeye-pinot/src/main/java/org/apache/pinot/thirdeye/detection/spec/{MockGrouperSpec.java => TriggerConditionGrouperSpec.java} (50%)
 create mode 100644 thirdeye/thirdeye-pinot/src/test/java/org/apache/pinot/thirdeye/detection/components/TriggerConditionGrouperTest.java


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@pinot.apache.org
For additional commands, e-mail: commits-help@pinot.apache.org