github.com/apache/beam/sdks/v2@v2.48.2/go/test/integration/primitives/windowinto_test.go (about)

     1  // Licensed to the Apache Software Foundation (ASF) under one or more
     2  // contributor license agreements.  See the NOTICE file distributed with
     3  // this work for additional information regarding copyright ownership.
     4  // The ASF licenses this file to You under the Apache License, Version 2.0
     5  // (the "License"); you may not use this file except in compliance with
     6  // the License.  You may obtain a copy of the License at
     7  //
     8  //    http://www.apache.org/licenses/LICENSE-2.0
     9  //
    10  // Unless required by applicable law or agreed to in writing, software
    11  // distributed under the License is distributed on an "AS IS" BASIS,
    12  // WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
    13  // See the License for the specific language governing permissions and
    14  // limitations under the License.
    15  
    16  package primitives
    17  
    18  import (
    19  	"testing"
    20  
    21  	"github.com/apache/beam/sdks/v2/go/pkg/beam"
    22  	"github.com/apache/beam/sdks/v2/go/pkg/beam/testing/ptest"
    23  	"github.com/apache/beam/sdks/v2/go/test/integration"
    24  )
    25  
    26  func TestWindowSums_Lifted(t *testing.T) {
    27  	integration.CheckFilters(t)
    28  	p, s := beam.NewPipelineWithRoot()
    29  	WindowSums_Lifted(s)
    30  	ptest.RunAndValidate(t, p)
    31  }
    32  
    33  func TestWindowSums_GBK(t *testing.T) {
    34  	integration.CheckFilters(t)
    35  	p, s := beam.NewPipelineWithRoot()
    36  	WindowSums_GBK(s)
    37  	ptest.RunAndValidate(t, p)
    38  }
    39  
    40  func TestValidateWindowedSideInputs(t *testing.T) {
    41  	integration.CheckFilters(t)
    42  	p, s := beam.NewPipelineWithRoot()
    43  	ValidateWindowedSideInputs(s)
    44  	ptest.RunAndValidate(t, p)
    45  }
    46  
    47  func TestTriggerDefault(t *testing.T) {
    48  	integration.CheckFilters(t)
    49  	p, s := beam.NewPipelineWithRoot()
    50  	TriggerDefault(s)
    51  	ptest.RunAndValidate(t, p)
    52  }
    53  
    54  func TestTriggerAlways(t *testing.T) {
    55  	integration.CheckFilters(t)
    56  	p, s := beam.NewPipelineWithRoot()
    57  	TriggerAlways(s)
    58  	ptest.RunAndValidate(t, p)
    59  }
    60  
    61  func TestTriggerElementCount(t *testing.T) {
    62  	integration.CheckFilters(t)
    63  	p, s := beam.NewPipelineWithRoot()
    64  	TriggerElementCount(s)
    65  	ptest.RunAndValidate(t, p)
    66  }
    67  
    68  func TestTriggerRepeat(t *testing.T) {
    69  	integration.CheckFilters(t)
    70  	p, s := beam.NewPipelineWithRoot()
    71  	TriggerRepeat(s)
    72  	ptest.RunAndValidate(t, p)
    73  }
    74  
    75  func TestTriggerAfterEndOfWindow(t *testing.T) {
    76  	integration.CheckFilters(t)
    77  	p, s := beam.NewPipelineWithRoot()
    78  	TriggerAfterEndOfWindow(s)
    79  	ptest.RunAndValidate(t, p)
    80  }
    81  
    82  func TestTriggerAfterAll(t *testing.T) {
    83  	integration.CheckFilters(t)
    84  	p, s := beam.NewPipelineWithRoot()
    85  	TriggerAfterAll(s)
    86  	ptest.RunAndValidate(t, p)
    87  }
    88  
    89  func TestTriggerAfterEach(t *testing.T) {
    90  	integration.CheckFilters(t)
    91  	p, s := beam.NewPipelineWithRoot()
    92  	TriggerAfterEach(s)
    93  	ptest.RunAndValidate(t, p)
    94  }
    95  
    96  func TestTriggerAfterAny(t *testing.T) {
    97  	integration.CheckFilters(t)
    98  	p, s := beam.NewPipelineWithRoot()
    99  	TriggerAfterAny(s)
   100  	ptest.RunAndValidate(t, p)
   101  }
   102  
   103  func TestTriggerAfterSynchronizedProcessingTime(t *testing.T) {
   104  	integration.CheckFilters(t)
   105  	p, s := beam.NewPipelineWithRoot()
   106  	TriggerAfterSynchronizedProcessingTime(s)
   107  	ptest.RunAndValidate(t, p)
   108  }
   109  
   110  func TestTriggerNever(t *testing.T) {
   111  	integration.CheckFilters(t)
   112  	p, s := beam.NewPipelineWithRoot()
   113  	TriggerNever(s)
   114  	ptest.RunAndValidate(t, p)
   115  }
   116  
   117  func TestTriggerOrFinally(t *testing.T) {
   118  	integration.CheckFilters(t)
   119  	p, s := beam.NewPipelineWithRoot()
   120  	TriggerOrFinally(s)
   121  	ptest.RunAndValidate(t, p)
   122  }