You are viewing a plain text version of this content. The canonical link for it is here.
Posted to github@beam.apache.org by GitBox <gi...@apache.org> on 2022/03/14 10:54:47 UTC

[GitHub] [beam] brachi-wernick opened a new pull request #17081: [BEAM-14094]Fix null pointer exception in HllCountInitFn

brachi-wernick opened a new pull request #17081:
URL: https://github.com/apache/beam/pull/17081


   When trying to aggregate input with null value we will fail on null pointer exception, when we deal with high events rate we can have sometimes "broken" events and I don't want them the break all the pipline.
   
   trace:
   ```stacktrace
   exception: "java.lang.NullPointerException
   at com.google.zetasketch.HyperLogLogPlusPlus.add(HyperLogLogPlusPlus.java:212)
   at org.apache.beam.sdk.extensions.zetasketch.HllCountInitFn$ForString.addInput(HllCountInitFn.java:147)
   at org.apache.beam.sdk.extensions.zetasketch.HllCountInitFn$ForString.addInput(HllCountInitFn.java:137)
   at org.apache.beam.sdk.extensions.sql.impl.transform.agg.AggregationCombineFnAdapter$WrappedCombinerBase.addInput(AggregationCombineFnAdapter.java:54)
   at org.apache.beam.sdk.transforms.CombineFns$ComposedCombineFn.addInput(CombineFns.java:382)
   at org.apache.beam.sdk.schemas.transforms.SchemaAggregateFn$Inner.addInput(SchemaAggregateFn.java:324)
   at org.apache.beam.sdk.schemas.transforms.SchemaAggregateFn$Inner.addInput(SchemaAggregateFn.java:63)
   at org.apache.beam.runners.dataflow.worker.WindmillStateInternals$WindmillCombiningState.add(WindmillStateInternals.java:2056)
   at org.apache.beam.runners.dataflow.worker.repackaged.org.apache.beam.runners.core.SystemReduceFn.processValue(SystemReduceFn.java:119)
   at org.apache.beam.runners.dataflow.worker.repackaged.org.apache.beam.runners.core.ReduceFnRunner.processElement(ReduceFnRunner.java:613)
   at org.apache.beam.runners.dataflow.worker.repackaged.org.apache.beam.runners.core.ReduceFnRunner.processElements(ReduceFnRunner.java:360)
   at org.apache.beam.runners.dataflow.worker.StreamingGroupAlsoByWindowViaWindowSetFn.processElement(StreamingGroupAlsoByWindowViaWindowSetFn.java:96)
   at org.apache.beam.runners.dataflow.worker.StreamingGroupAlsoByWindowViaWindowSetFn.processElement(StreamingGroupAlsoByWindowViaWindowSetFn.java:43)
   at org.apache.beam.runners.dataflow.worker.GroupAlsoByWindowFnRunner.invokeProcessElement(GroupAlsoByWindowFnRunner.java:121)
   at org.apache.beam.runners.dataflow.worker.GroupAlsoByWindowFnRunner.processElement(GroupAlsoByWindowFnRunner.java:73)
   at org.apache.beam.runners.dataflow.worker.repackaged.org.apache.beam.runners.core.LateDataDroppingDoFnRunner.processElement(LateDataDroppingDoFnRunner.java:80)
   at org.apache.beam.runners.dataflow.worker.GroupAlsoByWindowsParDoFn.processElement(GroupAlsoByWindowsParDoFn.java:137)
   at org.apache.beam.runners.dataflow.worker.util.common.worker.ParDoOperation.process(ParDoOperation.java:44)
   at org.apache.beam.runners.dataflow.worker.util.common.worker.OutputReceiver.process(OutputReceiver.java:49)
   at org.apache.beam.runners.dataflow.worker.util.common.worker.ReadOperation.runReadLoop(ReadOperation.java:212)
   at org.apache.beam.runners.dataflow.worker.util.common.worker.ReadOperation.start(ReadOperation.java:163)
   at org.apache.beam.runners.dataflow.worker.util.common.worker.MapTaskExecutor.execute(MapTaskExecutor.java:92)
   at org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker.process(StreamingDataflowWorker.java:1437)
   at org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker.access$1100(StreamingDataflowWorker.java:165)
   at org.apache.beam.runners.dataflow.worker.StreamingDataflowWorker$7.run(StreamingDataflowWorker.java:1113)
   at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
   at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
   at java.lang.Thread.run(Thread.java:748)
   ```


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: github-unsubscribe@beam.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [beam] ibzib merged pull request #17081: [BEAM-14094]Fix null pointer exception in HllCountInitFn

Posted by GitBox <gi...@apache.org>.
ibzib merged pull request #17081:
URL: https://github.com/apache/beam/pull/17081


   


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: github-unsubscribe@beam.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [beam] aaltay commented on pull request #17081: [BEAM-14094]Fix null pointer exception in HllCountInitFn

Posted by GitBox <gi...@apache.org>.
aaltay commented on pull request #17081:
URL: https://github.com/apache/beam/pull/17081#issuecomment-1078539013


   What is next on this PR?


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: github-unsubscribe@beam.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [beam] ibzib commented on pull request #17081: [BEAM-14094]Fix null pointer exception in HllCountInitFn

Posted by GitBox <gi...@apache.org>.
ibzib commented on pull request #17081:
URL: https://github.com/apache/beam/pull/17081#issuecomment-1083555161


   run java precommit


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: github-unsubscribe@beam.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [beam] brachi-wernick commented on pull request #17081: [BEAM-14094]Fix null pointer exception in HllCountInitFn

Posted by GitBox <gi...@apache.org>.
brachi-wernick commented on pull request #17081:
URL: https://github.com/apache/beam/pull/17081#issuecomment-1081139155


   @ibzib thanks on your review, just added


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: github-unsubscribe@beam.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [beam] brachipa removed a comment on pull request #17081: [BEAM-14094]Fix null pointer exception in HllCountInitFn

Posted by GitBox <gi...@apache.org>.
brachipa removed a comment on pull request #17081:
URL: https://github.com/apache/beam/pull/17081#issuecomment-1081136991


   @ibzib thanks on your review, added.


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: github-unsubscribe@beam.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [beam] ibzib commented on pull request #17081: [BEAM-14094]Fix null pointer exception in HllCountInitFn

Posted by GitBox <gi...@apache.org>.
ibzib commented on pull request #17081:
URL: https://github.com/apache/beam/pull/17081#issuecomment-1083681862


   Run Java PreCommit


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: github-unsubscribe@beam.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [beam] brachipa commented on pull request #17081: [BEAM-14094]Fix null pointer exception in HllCountInitFn

Posted by GitBox <gi...@apache.org>.
brachipa commented on pull request #17081:
URL: https://github.com/apache/beam/pull/17081#issuecomment-1081136991


   @ibzib thanks on your review, added.


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: github-unsubscribe@beam.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [beam] ibzib commented on pull request #17081: [BEAM-14094]Fix null pointer exception in HllCountInitFn

Posted by GitBox <gi...@apache.org>.
ibzib commented on pull request #17081:
URL: https://github.com/apache/beam/pull/17081#issuecomment-1083538234


   run java precommit


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: github-unsubscribe@beam.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org