本文整理汇总了Golang中github.com/rafrombrc/gomock/gomock.NewController函数 的典型用法代码示例。如果您正苦于以下问题:Golang NewController函数的具体用法?Golang NewController怎么用?Golang NewController使用的例子?那么恭喜您, 这里精选的函数代码示例或许可以为您提供帮助。
在下文中一共展示了NewController函数 的20个代码示例,这些例子默认根据受欢迎程度排序。您可以为喜欢或者感觉有用的代码点赞,您的评价将有助于我们的系统推荐出更棒的Golang代码示例。
示例1: ProtobufDecoderSpec
func ProtobufDecoderSpec(c gospec.Context) {
t := &ts.SimpleT{}
ctrl := gomock.NewController(t)
defer ctrl.Finish()
msg := ts.GetTestMessage()
config := NewPipelineConfig(nil) // Initializes globals.
c.Specify("A ProtobufDecoder", func() {
encoded, err := proto.Marshal(msg)
c.Assume(err, gs.IsNil)
pack := NewPipelinePack(config.inputRecycleChan)
decoder := new(ProtobufDecoder)
decoder.sampleDenominator = 1000 // Since we don't call decoder.Init().
c.Specify("decodes a protobuf message", func() {
pack.MsgBytes = encoded
_, err := decoder.Decode(pack)
c.Expect(err, gs.IsNil)
c.Expect(pack.Message, gs.Equals, msg)
v, ok := pack.Message.GetFieldValue("foo")
c.Expect(ok, gs.IsTrue)
c.Expect(v, gs.Equals, "bar")
})
c.Specify("returns an error for bunk encoding", func() {
bunk := append([]byte{0, 0, 0}, encoded...)
pack.MsgBytes = bunk
_, err := decoder.Decode(pack)
c.Expect(err, gs.Not(gs.IsNil))
})
})
}
开发者ID:Nitro, 项目名称:heka, 代码行数:33, 代码来源:protobuf_test.go
示例2: TestRun
func TestRun(t *testing.T) {
mockCtrl := gomock.NewController(t)
defer mockCtrl.Finish()
mockOR := pipelinemock.NewMockOutputRunner(mockCtrl)
mockPH := pipelinemock.NewMockPluginHelper(mockCtrl)
mockFirehose := NewMockRecordPutter(mockCtrl)
firehoseOutput := FirehoseOutput{
client: mockFirehose,
}
testChan := make(chan *pipeline.PipelinePack)
mockOR.EXPECT().InChan().Return(testChan)
// Send test input through the channel
input := `{"key":"value"}`
go func() {
testPack := pipeline.PipelinePack{
Message: &message.Message{
Payload: &input,
},
}
testChan <- &testPack
close(testChan)
}()
mockFirehose.EXPECT().PutRecord([]byte(input)).Return(nil)
err := firehoseOutput.Run(mockOR, mockPH)
assert.NoError(t, err, "did not expect err for valid Run()")
}
开发者ID:ianneub, 项目名称:heka-clever-plugins, 代码行数:33, 代码来源:firehose_output_test.go
示例3: StatsdInputSpec
func StatsdInputSpec(c gs.Context) {
t := &pipeline_ts.SimpleT{}
ctrl := gomock.NewController(t)
defer ctrl.Finish()
pConfig := NewPipelineConfig(nil)
ith := new(plugins_ts.InputTestHelper)
ith.Msg = pipeline_ts.GetTestMessage()
ith.Pack = NewPipelinePack(pConfig.InputRecycleChan())
ith.PackSupply = make(chan *PipelinePack, 1)
// Specify localhost, but we're not really going to use the network
ith.AddrStr = "localhost:55565"
ith.ResolvedAddrStr = "127.0.0.1:55565"
// set up mock helper, input runner, and stat accumulator
ith.MockHelper = NewMockPluginHelper(ctrl)
ith.MockInputRunner = NewMockInputRunner(ctrl)
mockStatAccum := NewMockStatAccumulator(ctrl)
c.Specify("A StatsdInput", func() {
statsdInput := StatsdInput{}
config := statsdInput.ConfigStruct().(*StatsdInputConfig)
config.Address = ith.AddrStr
err := statsdInput.Init(config)
c.Assume(err, gs.IsNil)
realListener := statsdInput.listener
c.Expect(realListener.LocalAddr().String(), gs.Equals, ith.ResolvedAddrStr)
realListener.Close()
mockListener := pipeline_ts.NewMockConn(ctrl)
statsdInput.listener = mockListener
ith.MockHelper.EXPECT().StatAccumulator("StatAccumInput").Return(mockStatAccum, nil)
mockListener.EXPECT().Close()
mockListener.EXPECT().SetReadDeadline(gomock.Any())
c.Specify("sends a Stat to the StatAccumulator", func() {
statName := "sample.count"
statVal := 303
msg := fmt.Sprintf("%s:%d|c\n", statName, statVal)
expected := Stat{statName, strconv.Itoa(statVal), "c", float32(1)}
mockStatAccum.EXPECT().DropStat(expected).Return(true)
readCall := mockListener.EXPECT().Read(make([]byte, 512))
readCall.Return(len(msg), nil)
readCall.Do(func(msgBytes []byte) {
copy(msgBytes, []byte(msg))
statsdInput.Stop()
})
var wg sync.WaitGroup
wg.Add(1)
go func() {
err = statsdInput.Run(ith.MockInputRunner, ith.MockHelper)
c.Expect(err, gs.IsNil)
wg.Done()
}()
wg.Wait()
})
})
}
开发者ID:salekseev, 项目名称:heka, 代码行数:60, 代码来源:statsd_input_test.go
示例4: createFixtures
func createFixtures(t *testing.T) (reporter *ErrorReporter, ctrl *gomock.Controller) {
// reporter acts as a testing.T-like object that we pass to the
// Controller. We use it to test that the mock considered tests
// successful or failed.
reporter = NewErrorReporter(t)
ctrl = gomock.NewController(reporter)
return
}
开发者ID:joesustaric, 项目名称:gomock, 代码行数:8, 代码来源:controller_test.go
示例5: TestPanicOverridesExpectationChecks
func TestPanicOverridesExpectationChecks(t *testing.T) {
ctrl := gomock.NewController(t)
reporter := NewErrorReporter(t)
reporter.assertFatal(func() {
ctrl.RecordCall(new(Subject), "FooMethod", "1")
defer ctrl.Finish()
reporter.Fatalf("Intentional panic")
})
}
开发者ID:joesustaric, 项目名称:gomock, 代码行数:10, 代码来源:controller_test.go
示例6: TestCreateEndpoint
func TestCreateEndpoint(t *testing.T) {
useMockFuncs()
defer useStdFuncs()
mockCtrl := gomock.NewController(t)
defer mockCtrl.Finish()
mckEndHandler := NewMockHandler(mockCtrl)
Convey("Should allocate update endpoints", t, func() {
app := NewApplication()
app.endpointTemplate = testEndpointTemplate
Convey("Should not encrypt endpoints without a key", func() {
app.SetTokenKey("")
app.SetEndpointHandler(mckEndHandler)
mckEndHandler.EXPECT().URL().Return("https://example.com")
endpoint, err := app.CreateEndpoint("123")
So(err, ShouldBeNil)
So(endpoint, ShouldEqual, "https://example.com/123")
})
Convey("Should encrypt endpoints with a key", func() {
app.SetTokenKey("HVozKz_n-DPopP5W877DpRKQOW_dylVf")
app.SetEndpointHandler(mckEndHandler)
mckEndHandler.EXPECT().URL().Return("https://example.com")
endpoint, err := app.CreateEndpoint("456")
So(err, ShouldBeNil)
So(endpoint, ShouldEqual,
"https://example.com/AAAAAAAAAAAAAAAAAAAAAGMKig==")
})
Convey("Should reject invalid keys", func() {
app.SetTokenKey("lLyhlLk8qus1ky4ER8yjN5o=")
app.SetEndpointHandler(mckEndHandler)
_, err := app.CreateEndpoint("123")
So(err, ShouldEqual, aes.KeySizeError(17))
})
Convey("Should return a relative URL without an update handler", func() {
app.SetTokenKey("O03rpLsdafhIhJEjEJt-CgVHyqHI650oy0pZZvplKDc=")
endpoint, err := app.CreateEndpoint("789")
So(err, ShouldBeNil)
So(endpoint, ShouldEqual, "/AAAAAAAAAAAAAAAAAAAAAPfdsA==")
})
})
}
开发者ID:jrconlin, 项目名称:pushgo, 代码行数:52, 代码来源:app_test.go
示例7: GeoIpDecoderSpec
func GeoIpDecoderSpec(c gs.Context) {
t := &ts.SimpleT{}
ctrl := gomock.NewController(t)
defer ctrl.Finish()
pConfig := NewPipelineConfig(nil)
pConfig.Globals.ShareDir = "/foo/bar/baz"
c.Specify("A GeoIpDecoder", func() {
decoder := new(GeoIpDecoder)
decoder.SetPipelineConfig(pConfig)
rec := new(geoip.GeoIPRecord)
conf := decoder.ConfigStruct().(*GeoIpDecoderConfig)
c.Expect(conf.DatabaseFile, gs.Equals, "/foo/bar/baz/GeoLiteCity.dat")
supply := make(chan *PipelinePack, 1)
pack := NewPipelinePack(supply)
nf, _ := message.NewField("remote_host", "74.125.142.147", "")
pack.Message.AddField(nf)
decoder.SourceIpField = "remote_host"
conf.SourceIpField = "remote_host"
decoder.Init(conf)
rec.CountryCode = "US"
rec.CountryCode3 = "USA"
rec.CountryName = "United States"
rec.Region = "CA"
rec.City = "Mountain View"
rec.PostalCode = "94043"
rec.Latitude = 37.4192
rec.Longitude = -122.0574
rec.AreaCode = 650
rec.CharSet = 1
rec.ContinentCode = "NA"
c.Specify("Test GeoIpDecoder Output", func() {
buf := decoder.GeoBuff(rec)
nf, _ = message.NewField("geoip", buf.Bytes(), "")
pack.Message.AddField(nf)
b, ok := pack.Message.GetFieldValue("geoip")
c.Expect(ok, gs.IsTrue)
c.Expect(string(b.([]byte)), gs.Equals, `{"latitude":37.4192008972168,"longitude":-122.0574035644531,"location":[-122.0574035644531,37.4192008972168],"coordinates":["-122.0574035644531","37.4192008972168"],"countrycode":"US","countrycode3":"USA","countryname":"United States","region":"CA","city":"Mountain View","postalcode":"94043","areacode":650,"charset":1,"continentcode":"NA"}`)
})
})
}
开发者ID:orangemi, 项目名称:heka, 代码行数:50, 代码来源:geoip_decoder_test.go
示例8: TestSocketListenConfig
func TestSocketListenConfig(t *testing.T) {
mockCtrl := gomock.NewController(t)
defer mockCtrl.Finish()
mckLogger := NewMockLogger(mockCtrl)
mckLogger.EXPECT().ShouldLog(gomock.Any()).Return(true).AnyTimes()
mckLogger.EXPECT().Log(gomock.Any(), gomock.Any(),
gomock.Any(), gomock.Any()).AnyTimes()
mckStat := NewMockStatistician(mockCtrl)
mckListenerConfig := NewMockListenerConfig(mockCtrl)
app := NewApplication()
app.hostname = "example.org"
app.SetLogger(mckLogger)
app.SetMetrics(mckStat)
sh := NewSocketHandler()
sh.setApp(app)
// Should forward Listen errors.
listenErr := errors.New("splines not reticulated")
mckListenerConfig.EXPECT().Listen().Return(nil, listenErr)
if err := sh.listenWithConfig(mckListenerConfig); err != listenErr {
t.Errorf("Wrong error: got %#v; want %#v", err, listenErr)
}
// Should use the wss:// scheme if UseTLS returns true.
ml := newMockListener(netAddr{"test", "[::1]:8080"})
gomock.InOrder(
mckListenerConfig.EXPECT().Listen().Return(ml, nil),
mckListenerConfig.EXPECT().UseTLS().Return(true),
mckListenerConfig.EXPECT().GetMaxConns().Return(1),
)
if err := sh.listenWithConfig(mckListenerConfig); err != nil {
t.Errorf("Error setting listener: %s", err)
}
if maxConns := sh.MaxConns(); maxConns != 1 {
t.Errorf("Mismatched maximum connection count: got %d; want 1",
maxConns)
}
expectedURL := "wss://example.org:8080"
if url := sh.URL(); url != expectedURL {
t.Errorf("Mismatched handler URL: got %q; want %q",
url, expectedURL)
}
}
开发者ID:jrconlin, 项目名称:pushgo, 代码行数:46, 代码来源:handlers_socket_test.go
示例9: TestNotMatcher
// A more thorough test of notMatcher
func TestNotMatcher(t *testing.T) {
ctrl := gomock.NewController(t)
defer ctrl.Finish()
mockMatcher := mock_matcher.NewMockMatcher(ctrl)
notMatcher := gomock.Not(mockMatcher)
mockMatcher.EXPECT().Matches(4).Return(true)
if match := notMatcher.Matches(4); match {
t.Errorf("notMatcher should not match 4")
}
mockMatcher.EXPECT().Matches(5).Return(false)
if match := notMatcher.Matches(5); !match {
t.Errorf("notMatcher should match 5")
}
}
开发者ID:joesustaric, 项目名称:gomock, 代码行数:18, 代码来源:matchers_test.go
示例10: decodeMessageAndVerifyOutput
// decodeMessageAndVerifyOutput takes a decoder conf, message payload, and a fn -> the fn is a number of
// assertions to verify that the message after decoding is as expected.
func decodeMessageAndVerifyOutput(c gs.Context, conf *JsonDecoderConfig, payload string, fn packVerifier) {
t := &pipeline_ts.SimpleT{}
ctrl := gomock.NewController(t)
defer ctrl.Finish()
// 1. Initialize test decoder
decoder := new(JsonDecoder)
err := decoder.Init(conf)
c.Assume(err, gs.IsNil)
dRunner := pipelinemock.NewMockDecoderRunner(ctrl)
decoder.SetDecoderRunner(dRunner)
// 2. Set payload to be tested, and decode it
supply := make(chan *PipelinePack, 1)
pack := NewPipelinePack(supply)
pack.Message.SetPayload(payload)
_, err = decoder.Decode(pack)
// 3. Assert outcome of decoding
fn(c, pack)
pack.Zero()
}
开发者ID:ericx10ng, 项目名称:heka-clever-plugins, 代码行数:24, 代码来源:json_decoder_test.go
示例11: BenchmarkCreateEndpoint
func BenchmarkCreateEndpoint(b *testing.B) {
mockCtrl := gomock.NewController(b)
defer mockCtrl.Finish()
app := NewApplication()
app.endpointTemplate = testEndpointTemplate
app.SetTokenKey("")
mckEndHandler := NewMockHandler(mockCtrl)
mckEndHandler.EXPECT().URL().Return("https://example.com").Times(b.N)
app.SetEndpointHandler(mckEndHandler)
b.ResetTimer()
for i := 0; i < b.N; i++ {
endpoint, err := app.CreateEndpoint("123")
if err != nil {
b.Fatalf("Error generating update endpoint: %s", err)
}
expected := "https://example.com/123"
if endpoint != expected {
b.Fatalf("Wrong endpoint: got %q; want %q", endpoint, expected)
}
}
}
开发者ID:jrconlin, 项目名称:pushgo, 代码行数:23, 代码来源:app_test.go
示例12: TestRunWithTimestamp
// TestRunWithTimestamp tests that if a TimestampColumn is provided in the config
// then the Heka message's timestamp gets added to the message with that column name.
func TestRunWithTimestamp(t *testing.T) {
mockCtrl := gomock.NewController(t)
defer mockCtrl.Finish()
mockOR := pipelinemock.NewMockOutputRunner(mockCtrl)
mockPH := pipelinemock.NewMockPluginHelper(mockCtrl)
mockFirehose := NewMockRecordPutter(mockCtrl)
firehoseOutput := FirehoseOutput{
client: mockFirehose,
timestampColumn: "created",
}
testChan := make(chan *pipeline.PipelinePack)
mockOR.EXPECT().InChan().Return(testChan)
// Send test input through the channel
input := `{}`
timestamp := time.Date(2015, 07, 1, 13, 14, 15, 0, time.UTC).UnixNano()
go func() {
testPack := pipeline.PipelinePack{
Message: &message.Message{
Payload: &input,
Timestamp: ×tamp,
},
}
testChan <- &testPack
close(testChan)
}()
expected := `{"created":"2015-07-01 13:14:15.000"}`
mockFirehose.EXPECT().PutRecord([]byte(expected)).Return(nil)
err := firehoseOutput.Run(mockOR, mockPH)
assert.NoError(t, err, "did not expect err for valid Run()")
}
开发者ID:ianneub, 项目名称:heka-clever-plugins, 代码行数:39, 代码来源:firehose_output_test.go
示例13: ScribbleDecoderSpec
func ScribbleDecoderSpec(c gs.Context) {
t := &pipeline_ts.SimpleT{}
ctrl := gomock.NewController(t)
defer ctrl.Finish()
c.Specify("A ScribbleDecoder", func() {
decoder := new(ScribbleDecoder)
config := decoder.ConfigStruct().(*ScribbleDecoderConfig)
myType := "myType"
myPayload := "myPayload"
config.MessageFields = MessageTemplate{"Type": myType, "Payload": myPayload}
supply := make(chan *PipelinePack, 1)
pack := NewPipelinePack(supply)
c.Specify("sets basic values correctly", func() {
decoder.Init(config)
packs, err := decoder.Decode(pack)
c.Expect(err, gs.IsNil)
c.Expect(len(packs), gs.Equals, 1)
c.Expect(pack.Message.GetType(), gs.Equals, myType)
c.Expect(pack.Message.GetPayload(), gs.Equals, myPayload)
})
})
}
开发者ID:orangemi, 项目名称:heka, 代码行数:24, 代码来源:scribble_decoder_test.go
示例14: TestLocatorReadyNotify
func TestLocatorReadyNotify(t *testing.T) {
mockCtrl := gomock.NewController(t)
defer mockCtrl.Finish()
uaid := "fce61180716a40ed8e79bf5ff0ba34bc"
mckLogger := NewMockLogger(mockCtrl)
mckLogger.EXPECT().ShouldLog(gomock.Any()).Return(true).AnyTimes()
mckLogger.EXPECT().Log(gomock.Any(), gomock.Any(), gomock.Any(),
gomock.Any()).AnyTimes()
var (
// routerPipes maps fake peer addresses to their respective pipes. Used
// by dialRouter to connect to peers.
routerPipes = make(map[netAddr]*pipeListener)
// contacts is a list of peer URLs for the locator.
contacts []string
)
// Fake listener for the sender's router, used to test self-routing.
sndRouterAddr := netAddr{"tcp", "snd-router.example.com:3000"}
sndRouterPipe := newPipeListener()
defer sndRouterPipe.Close()
routerPipes[sndRouterAddr] = sndRouterPipe
contacts = append(contacts, "http://snd-router.example.com:3000")
// Fake listener for the receiver's router, used to test routing updates
// to different hosts.
recvRouterAddr := netAddr{"tcp", "recv-router.example.com:3000"}
recvRouterPipe := newPipeListener()
defer recvRouterPipe.Close()
routerPipes[recvRouterAddr] = recvRouterPipe
contacts = append(contacts, "http://recv-router.example.com:3000")
// Fake listener for the receiver's WebSocket handler, used to accept a
// WebSocket client connection.
socketHandlerPipe := newPipeListener()
defer socketHandlerPipe.Close()
// Fake locator.
mckLocator := NewMockLocator(mockCtrl)
mckLocator.EXPECT().Contacts(uaid).Return(contacts, nil).Times(2)
// Fake dialer to connect to each peer's routing listener.
dialRouter := func(network, address string) (net.Conn, error) {
if pipe, ok := routerPipes[netAddr{network, address}]; ok {
return pipe.Dial(network, address)
}
return nil, &netErr{temporary: false, timeout: false}
}
// Configures a fake router for the app.
setRouter := func(app *Application, listener net.Listener) {
r := NewBroadcastRouter()
r.setApp(app)
r.setClientOptions(10, 3*time.Second, 3*time.Second) // Defaults.
r.setClientTransport(&http.Transport{Dial: dialRouter})
r.listenWithConfig(listenerConfig{listener: listener})
r.maxDataLen = 4096
r.server = newServeWaiter(&http.Server{Handler: r.ServeMux()})
app.SetRouter(r)
}
// sndApp is the server broadcasting the update. The locator returns the
// addresses of the sender and receiver to test self-routing.
sndApp := NewApplication()
sndApp.SetLogger(mckLogger)
sndStat := NewMockStatistician(mockCtrl)
sndApp.SetMetrics(sndStat)
sndStore := NewMockStore(mockCtrl)
sndApp.SetStore(sndStore)
sndApp.SetLocator(mckLocator)
// Set up a fake router for the sender.
setRouter(sndApp, sndRouterPipe)
// recvApp is the server receiving the update.
recvApp := NewApplication()
recvApp.SetLogger(mckLogger)
recvStat := NewMockStatistician(mockCtrl)
recvApp.SetMetrics(recvStat)
recvStore := NewMockStore(mockCtrl)
recvApp.SetStore(recvStore)
// Wrap the fake locator in a type that implements ReadyNotifier.
recvLocator := newMockReadyNotifier(mckLocator)
recvApp.SetLocator(recvLocator)
// Set up a fake WebSocket handler for the receiver.
recvSocketHandler := NewSocketHandler()
recvSocketHandler.setApp(recvApp)
recvSocketHandler.listenWithConfig(listenerConfig{
listener: socketHandlerPipe})
recvSocketHandler.server = newServeWaiter(&http.Server{Handler: recvSocketHandler.ServeMux()})
recvApp.SetSocketHandler(recvSocketHandler)
// Set up a fake router for the receiver.
setRouter(recvApp, recvRouterPipe)
chid := "2b7c5c27d6224bfeaf1c158c3c57fca3"
version := int64(2)
data := "I'm a little teapot, short and stout."
var wg sync.WaitGroup // Waits for the client to close.
//.........这里部分代码省略.........
开发者ID:jrconlin, 项目名称:pushgo, 代码行数:101, 代码来源:locator_test.go
示例15: ReportSpec
func ReportSpec(c gs.Context) {
t := new(ts.SimpleT)
ctrl := gomock.NewController(t)
defer ctrl.Finish()
pConfig := NewPipelineConfig(nil)
chanSize := pConfig.Globals.PluginChanSize
checkForFields := func(c gs.Context, msg *message.Message) {
f0Val, ok := msg.GetFieldValue(f0.GetName())
c.Expect(ok, gs.IsTrue)
c.Expect(f0Val.(int64), gs.Equals, f0.GetValue().(int64))
f1Val, ok := msg.GetFieldValue(f1.GetName())
c.Expect(ok, gs.IsTrue)
c.Expect(f1Val.(string), gs.Equals, f1.GetValue().(string))
}
hasChannelData := func(msg *message.Message) (ok bool) {
capVal, _ := msg.GetFieldValue("InChanCapacity")
lenVal, _ := msg.GetFieldValue("InChanLength")
var i int64
if i, ok = capVal.(int64); !ok {
return
}
if ok = (i == int64(chanSize)); !ok {
return
}
if i, ok = lenVal.(int64); !ok {
return
}
ok = (i == int64(0))
return
}
fName := "counter"
filter := new(CounterFilter)
fRunner := NewFORunner(fName, filter, nil, chanSize)
var err error
fRunner.matcher, err = NewMatchRunner("Type == ''", "", fRunner, chanSize)
c.Assume(err, gs.IsNil)
fRunner.matcher.inChan = make(chan *PipelinePack, chanSize)
leakCount := 10
fRunner.SetLeakCount(leakCount)
iName := "stat_accum"
input := new(StatAccumInput)
iRunner := NewInputRunner(iName, input, nil, false)
c.Specify("`PopulateReportMsg`", func() {
msg := ts.GetTestMessage()
c.Specify("w/ a filter", func() {
err := PopulateReportMsg(fRunner, msg)
c.Assume(err, gs.IsNil)
c.Specify("invokes `ReportMsg` on the filter", func() {
checkForFields(c, msg)
})
c.Specify("adds the channel data", func() {
c.Expect(hasChannelData(msg), gs.IsTrue)
})
c.Specify("has its leak count set properly", func() {
leakVal, ok := msg.GetFieldValue("LeakCount")
c.Assume(ok, gs.IsTrue)
i, ok := leakVal.(int64)
c.Assume(ok, gs.IsTrue)
c.Expect(int(i), gs.Equals, leakCount)
})
})
c.Specify("w/ an input", func() {
err := PopulateReportMsg(iRunner, msg)
c.Assume(err, gs.IsNil)
c.Specify("invokes `ReportMsg` on the input", func() {
checkForFields(c, msg)
})
c.Specify("doesn't add any channel data", func() {
capVal, ok := msg.GetFieldValue("InChanCapacity")
c.Expect(capVal, gs.IsNil)
c.Expect(ok, gs.IsFalse)
lenVal, ok := msg.GetFieldValue("InChanLength")
c.Expect(lenVal, gs.IsNil)
c.Expect(ok, gs.IsFalse)
})
})
})
c.Specify("PipelineConfig", func() {
pc := NewPipelineConfig(nil)
// Initialize all of the PipelinePacks that we'll need
pc.reportRecycleChan <- NewPipelinePack(pc.reportRecycleChan)
pc.FilterRunners = map[string]FilterRunner{fName: fRunner}
pc.InputRunners = map[string]InputRunner{iName: iRunner}
c.Specify("returns full set of accurate reports", func() {
//.........这里部分代码省略.........
开发者ID:salekseev, 项目名称:heka, 代码行数:101, 代码来源:report_test.go
示例16: KeenOutputSpec
func KeenOutputSpec(c gs.Context) {
ctrl := gomock.NewController(universalT)
defer ctrl.Finish()
c.Specify("A KeenOutput", func() {
successTests := []SuccessfulTestCase{
SuccessfulTestCase{
"successfully records a valid job-finished message",
"{\"JobType\":\"nyc_aris\",\"SystemId\":\"1234567890abcdefghijklmn\",\"TimeCreated\":\"2014-07-03T23:35:24.000Z\",\"Duration\":38900,\"Success\":true,\"Message\":\"\"}",
func(eventData map[string]interface{}) bool {
return eventData["JobType"] == "nyc_aris" &&
eventData["SystemId"] == "1234567890abcdefghijklmn" &&
eventData["TimeCreated"] == "2014-07-03T23:35:24.000Z" &&
eventData["Duration"] == float64(38900) &&
eventData["Success"] == true &&
eventData["Message"] == ""
},
},
}
errorTests := []ErrorTestCase{
ErrorTestCase{
"logs an error but does not crash when the message payload is not valid JSON",
"not json",
"*json.SyntaxError",
"invalid character 'o' in literal null (expecting 'u')",
},
}
for _, test := range successTests {
oth := NewOutputTestHelper(universalT, ctrl)
output := new(KeenOutput)
output.Init(&KeenOutputConfig{Collection: "job-finished"})
mockClient := MockKeenClient{mock.Mock{}}
output.client = &mockClient
inChan := make(chan *pipeline.PipelinePack, 1)
oth.MockOutputRunner.EXPECT().On("InChan").Return(inChan)
mockClient.EXPECT().On("AddEvent", "job-finished", mock.Anything).Return(nil)
pack := getEmptyKeenOutputPack()
pack.Message.SetPayload(test.MessagePayload)
inChan <- pack
close(inChan)
output.Run(oth.MockOutputRunner, oth.MockHelper)
ExpectCall(universalT, &mockClient.mock, "AddEvent with expected JSON", "AddEvent",
func(args []interface{}) bool {
if len(args) != 2 {
return false
}
eventData, ok := args[1].(map[string]interface{})
return ok && test.IsEventDataCorrect(eventData)
})
}
for _, test := range errorTests {
oth := NewOutputTestHelper(universalT, ctrl)
output := new(KeenOutput)
output.Init(&KeenOutputConfig{})
mockClient := MockKeenClient{mock.Mock{}}
output.client = &mockClient
inChan := make(chan *pipeline.PipelinePack, 1)
oth.MockOutputRunner.EXPECT().On("InChan").Return(inChan)
oth.MockOutputRunner.EXPECT().On("LogError", mock.AnythingOfType(test.ExpectedErrorType)).Return()
pack := getEmptyKeenOutputPack()
pack.Message.SetPayload(test.MessagePayload)
inChan <- pack
close(inChan)
output.Run(oth.MockOutputRunner, oth.MockHelper)
ExpectCall(universalT, &oth.MockOutputRunner.mock, "Log correct error", "LogError",
func(args []interface{}) bool {
if len(args) != 1 {
return false
}
err, ok := args[0].(error)
return ok && err.Error() == test.ExpectedErrorMessage
})
oth.MockOutputRunner.EXPECT().AssertExpectations(universalT)
}
})
}
开发者ID:ericx10ng, 项目名称:heka-clever-plugins, 代码行数:89, 代码来源:keen_output_test.go
示例17: HttpInputSpec
func HttpInputSpec(c gs.Context) {
t := &pipeline_ts.SimpleT{}
ctrl := gomock.NewController(t)
defer ctrl.Finish()
pConfig := NewPipelineConfig(nil)
json_post := `{"uuid": "xxBI3zyeXU+spG8Uiveumw==", "timestamp": 1372966886023588, "hostname": "Victors-MacBook-Air.local", "pid": 40183, "fields": [{"representation": "", "value_type": "STRING", "name": "cef_meta.syslog_priority", "value_string": [""]}, {"representation": "", "value_type": "STRING", "name": "cef_meta.syslog_ident", "value_string": [""]}, {"representation": "", "value_type": "STRING", "name": "cef_meta.syslog_facility", "value_string": [""]}, {"representation": "", "value_type": "STRING", "name": "cef_meta.syslog_options", "value_string": [""]}], "logger": "", "env_version": "0.8", "type": "cef", "payload": "Jul 04 15:41:26 Victors-MacBook-Air.local CEF:0|mozilla|weave|3|xx\\\\|x|xx\\\\|x|5|cs1Label=requestClientApplication cs1=MySuperBrowser requestMethod=GET request=/ src=127.0.0.1 dest=127.0.0.1 suser=none", "severity": 6}'`
c.Specify("A HttpInput", func() {
httpInput := HttpInput{}
ith := new(plugins_ts.InputTestHelper)
ith.MockHelper = pipelinemock.NewMockPluginHelper(ctrl)
ith.MockInputRunner = pipelinemock.NewMockInputRunner(ctrl)
ith.MockSplitterRunner = pipelinemock.NewMockSplitterRunner(ctrl)
runOutputChan := make(chan error, 1)
startInput := func() {
go func() {
runOutputChan <- httpInput.Run(ith.MockInputRunner, ith.MockHelper)
}()
}
ith.Pack = NewPipelinePack(pConfig.InputRecycleChan())
// These assume that every sub-spec starts the input.
config := httpInput.ConfigStruct().(*HttpInputConfig)
tickChan := make(chan time.Time)
ith.MockInputRunner.EXPECT().Ticker().Return(tickChan)
ith.MockHelper.EXPECT().Hostname().Return("hekatests.example.com")
// These assume that every sub-spec makes exactly one HTTP request.
ith.MockInputRunner.EXPECT().NewSplitterRunner("0").Return(ith.MockSplitterRunner)
getRecCall := ith.MockSplitterRunner.EXPECT().GetRecordFromStream(gomock.Any())
getRecCall.Return(len(json_post), []byte(json_post), io.EOF)
ith.MockSplitterRunner.EXPECT().UseMsgBytes().Return(false)
decChan := make(chan func(*PipelinePack), 1)
packDecCall := ith.MockSplitterRunner.EXPECT().SetPackDecorator(gomock.Any())
packDecCall.Do(func(dec func(*PipelinePack)) {
decChan <- dec
})
ith.MockSplitterRunner.EXPECT().DeliverRecord([]byte(json_post), nil)
ith.MockSplitterRunner.EXPECT().IncompleteFinal().Return(false).AnyTimes()
splitter := &TokenSplitter{} // not actually used
ith.MockSplitterRunner.EXPECT().Splitter().Return(splitter)
c.Specify("honors time ticker to flush", func() {
// Spin up a http server.
server, err := plugins_ts.NewOneHttpServer(json_post, "localhost", 9876)
c.Expect(err, gs.IsNil)
go server.Start("/")
time.Sleep(10 * time.Millisecond)
config.Url = "http://localhost:9876/"
err = httpInput.Init(config)
c.Assume(err, gs.IsNil)
startInput()
tickChan <- time.Now()
// Getting the decorator means we've made our HTTP request.
<-decChan
})
c.Specify("supports configuring HTTP Basic Authentication", func() {
// Spin up a http server which expects username "user" and password "password"
server, err := plugins_ts.NewHttpBasicAuthServer("user", "password", "localhost", 9875)
c.Expect(err, gs.IsNil)
go server.Start("/BasicAuthTest")
time.Sleep(10 * time.Millisecond)
config.Url = "http://localhost:9875/BasicAuthTest"
config.User = "user"
config.Password = "password"
err = httpInput.Init(config)
c.Assume(err, gs.IsNil)
startInput()
tickChan <- time.Now()
dec := <-decChan
dec(ith.Pack)
// we expect a statuscode 200 (i.e. success)
statusCode, ok := ith.Pack.Message.GetFieldValue("StatusCode")
c.Assume(ok, gs.IsTrue)
c.Expect(statusCode, gs.Equals, int64(200))
})
c.Specify("supports configuring a different HTTP method", func() {
// Spin up a http server which expects requests with method "POST"
server, err := plugins_ts.NewHttpMethodServer("POST", "localhost", 9874)
c.Expect(err, gs.IsNil)
go server.Start("/PostTest")
time.Sleep(10 * time.Millisecond)
config.Url = "http://localhost:9874/PostTest"
config.Method = "POST"
//.........这里部分代码省略.........
开发者ID:orangemi, 项目名称:heka, 代码行数:101, 代码来源:http_input_test.go
示例18: LogstreamerInputSpec
func LogstreamerInputSpec(c gs.Context) {
t := &pipeline_ts.SimpleT{}
ctrl := gomock.NewController(t)
defer ctrl.Finish()
here, _ := os.Getwd()
dirPath := filepath.Join(here, "../../logstreamer", "testdir", "filehandling/subdir")
tmpDir, tmpErr := ioutil.TempDir("", "hekad-tests")
c.Expect(tmpErr, gs.Equals, nil)
defer func() {
tmpErr = os.RemoveAll(tmpDir)
c.Expect(tmpErr, gs.IsNil)
}()
globals := DefaultGlobals()
globals.BaseDir = tmpDir
pConfig := NewPipelineConfig(globals)
ith := new(plugins_ts.InputTestHelper)
ith.Msg = pipeline_ts.GetTestMessage()
ith.Pack = NewPipelinePack(pConfig.InputRecycleChan())
// Specify localhost, but we're not really going to use the network.
ith.AddrStr = "localhost:55565"
ith.ResolvedAddrStr = "127.0.0.1:55565"
// Set up mock helper, runner, and pack supply channel.
ith.MockHelper = pipelinemock.NewMockPluginHelper(ctrl)
ith.MockInputRunner = pipelinemock.NewMockInputRunner(ctrl)
ith.MockDeliverer = pipelinemock.NewMockDeliverer(ctrl)
ith.MockSplitterRunner = pipelinemock.NewMockSplitterRunner(ctrl)
ith.PackSupply = make(chan *PipelinePack, 1)
c.Specify("A LogstreamerInput", func() {
lsInput := &LogstreamerInput{pConfig: pConfig}
lsiConfig := lsInput.ConfigStruct().(*LogstreamerInputConfig)
lsiConfig.LogDirectory = dirPath
lsiConfig.FileMatch = `file.log(\.?)(?P<Seq>\d+)?`
lsiConfig.Differentiator = []string{"logfile"}
lsiConfig.Priority = []string{"^Seq"}
c.Specify("w/ no translation map", func() {
err := lsInput.Init(lsiConfig)
c.Expect(err, gs.IsNil)
c.Expect(len(lsInput.plugins), gs.Equals, 1)
// Create pool of packs.
numLines := 5 // # of lines in the log file we're parsing.
packs := make([]*PipelinePack, numLines)
ith.PackSupply = make(chan *PipelinePack, numLines)
for i := 0; i < numLines; i++ {
packs[i] = NewPipelinePack(ith.PackSupply)
ith.PackSupply <- packs[i]
}
c.Specify("reads a log file", func() {
// Expect InputRunner calls to get InChan and inject outgoing msgs.
ith.MockInputRunner.EXPECT().LogError(gomock.Any()).AnyTimes()
ith.MockInputRunner.EXPECT().LogMessage(gomock.Any()).AnyTimes()
ith.MockInputRunner.EXPECT().NewDeliverer("1").Return(ith.MockDeliverer)
ith.MockInputRunner.EXPECT().NewSplitterRunner("1").Return(
ith.MockSplitterRunner)
ith.MockSplitterRunner.EXPECT().UseMsgBytes().Return(false)
ith.MockSplitterRunner.EXPECT().IncompleteFinal().Return(false)
ith.MockSplitterRunner.EXPECT().SetPackDecorator(gomock.Any())
getRecCall := ith.MockSplitterRunner.EXPECT().GetRecordFromStream(
gomock.Any()).Times(numLines)
line := "boo hoo foo foo"
getRecCall.Return(len(line), []byte(line), nil)
getRecCall = ith.MockSplitterRunner.EXPECT().GetRecordFromStream(gomock.Any())
getRecCall.Return(0, make([]byte, 0), io.EOF)
deliverChan := make(chan []byte, 1)
deliverCall := ith.MockSplitterRunner.EXPECT().DeliverRecord(gomock.Any(),
ith.MockDeliverer).Times(numLines)
deliverCall.Do(func(record []byte, del Deliverer) {
deliverChan <- record
})
ith.MockDeliverer.EXPECT().Done()
runOutChan := make(chan error, 1)
go func() {
err = lsInput.Run(ith.MockInputRunner, ith.MockHelper)
runOutChan <- err
}()
dur, _ := time.ParseDuration("5s")
timeout := time.After(dur)
timed := false
for x := 0; x < numLines; x++ {
select {
case record := <-deliverChan:
c.Expect(string(record), gs.Equals, line)
case <-timeout:
timed = true
x += numLines
}
// Free up the scheduler while we wait for the log file lines
//.........这里部分代码省略.........
开发者ID:orangemi, 项目名称:heka, 代码行数:101, 代码来源:logstreamer_input_test.go
示例19: TestEndpointResolveKey
func TestEndpointResolveKey(t *testing.T) {
mockCtrl := gomock.NewController(t)
defer mockCtrl.Finish()
mckLogger := NewMockLogger(mockCtrl)
mckLogger.EXPECT().ShouldLog(gomock.Any()).Return(true).AnyTimes()
mckLogger.EXPECT().Log(gomock.Any(), gomock.Any(),
gomock.Any(), gomock.Any()).AnyTimes()
mckStat := NewMockStatistician(mockCtrl)
mckStore := NewMockStore(mockCtrl)
Convey("Endpoint tokens", t, func() {
app := NewApplication()
app.SetLogger(mckLogger)
app.SetMetrics(mckStat)
app.SetStore(mckStore)
Convey("Should return a 404 for invalid tokens", func() {
app.SetTokenKey("c3v0AlmmxXu_LSfdZY3l3eayLsIwkX48")
eh := NewEndpointHandler()
eh.setApp(app)
app.SetEndpointHandler(eh)
resp := httptest.NewRecorder()
req := &http.Request{
Method: "PUT",
Header: http.Header{},
URL: &url.URL{
Path: "/update/j1bqzFq9WiwFZbqay-y7xVlfSvtO1eY="}, // "123.456"
}
gomock.InOrder(
mckStore.EXPECT().KeyToIDs("123.456").Return("", "", ErrInvalidKey),
mckStat.EXPECT().Increment("updates.appserver.invalid"),
)
eh.ServeMux().ServeHTTP(resp, req)
So(resp.Code, ShouldEqual, 404)
body, isJSON := getJSON(resp.HeaderMap, resp.Body)
So(isJSON, ShouldBeTrue)
So(body.String(), ShouldEqual, `"Invalid Token"`)
})
Convey("Should not decode plaintext tokens without a key", func() {
var err error
app.SetTokenKey("")
eh := NewEndpointHandler()
eh.setApp(app)
app.SetEndpointHandler(eh)
_, err = eh.decodePK("")
So(err, ShouldNotBeNil)
pk, err := eh.decodePK("123.456")
So(pk, ShouldEqual, "123.456")
})
Convey("Should normalize decoded tokens", func() {
app.SetTokenKey("LM1xDImCx0rB46LCnx-3v4-Iyfk1LeKJbx9wuvx_z3U=")
eh := NewEndpointHandler()
eh.setApp(app)
app.SetEndpointHandler(eh)
// Hyphenated IDs should be normalized.
uaid := "dbda2ba2-004c-491f-9e3d-c5950aee93de"
chid := "848cd568-3f2a-4108-9ce4-bd0d928ecad4"
// " \t%s.%s\r\n" % (uaid, chid)
encodedKey := "qfGSdZzwf20GXiYubmZfIXj11Rx4RGJujFsjSQGdF4LRBhHbB_vt3hdW7cRvL9Fq_t_guMBGkDgebOoa5gRd1GGLN-Cv6h5hkpRTbdju8Tk-hMyC91BP4CEres_8"
// decodePK should trim whitespace from encoded keys.
mckStore.EXPECT().KeyToIDs(
fmt.Sprintf("%s.%s", uaid, chid)).Return(uaid, chid, nil)
actualUAID, actualCHID, err := eh.resolvePK(encodedKey)
So(err, ShouldBeNil)
So(actualUAID, ShouldEqual, uaid)
So(actualCHID, ShouldEqual, chid)
})
Convey("Should reject invalid tokens", func() {
var err error
app.SetTokenKey("IhnNwMNbsFWiafTXSgF4Ag==")
eh := NewEndpointHandler()
eh.setApp(app)
app.SetEndpointHandler(eh)
invalidKey := "b54QOw2omSWBiEq0IuyfBGxHBIR7AI9YhCMA0lP9" // "[email protected]#$%^&*()[]"
uaid := "82398a648c834f8b838cb3945eceaf29"
chid := "af445ad07e5f46b7a6c858150fc5aa92"
validKey := fmt.Sprintf("%s.%s", uaid, chid)
encodedKey := "swKSH8P2qprRt5y0J4Wi7ybl-qzFv1j09WPOfuabpEJmVUqwUpxjprXc2R3Yw0ITbqc_Swntw9_EpCgo_XuRTn7Q7opQYoQUgMPhCgT0EGbK"
_, _, err = eh.resolvePK(invalidKey[:8])
So(err, ShouldNotBeNil)
_, _, err = eh.resolvePK(invalidKey)
So(err, ShouldNotBeNil)
// Reject plaintext tokens if a key is specified.
//.........这里部分代码省略.........
开发者ID:jrconlin, 项目名称:pushgo, 代码行数:101, 代码来源:handlers_endpoint_test.go
示例20: TestEndpointDelivery
请发表评论